You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@lucenenet.apache.org by sy...@apache.org on 2014/09/06 21:36:12 UTC

[01/51] [abbrv] [partial] Cleaning up and getting ready to development towards v4.8

Repository: lucenenet
Updated Branches:
  refs/heads/master fb5123036 -> 1da1cb5b5


http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/src/Lucene.Net.Codecs/SimpleText/SimpleTextFieldsReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Codecs/SimpleText/SimpleTextFieldsReader.cs b/src/Lucene.Net.Codecs/SimpleText/SimpleTextFieldsReader.cs
new file mode 100644
index 0000000..63e999a
--- /dev/null
+++ b/src/Lucene.Net.Codecs/SimpleText/SimpleTextFieldsReader.cs
@@ -0,0 +1,690 @@
+package org.apache.lucene.codecs.simpletext;
+
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+import java.io.IOException;
+import java.nio.charset.StandardCharsets;
+import java.util.Collections;
+import java.util.Comparator;
+import java.util.HashMap;
+import java.util.Iterator;
+import java.util.Map;
+import java.util.TreeMap;
+
+import org.apache.lucene.codecs.FieldsProducer;
+import org.apache.lucene.index.DocsAndPositionsEnum;
+import org.apache.lucene.index.DocsEnum;
+import org.apache.lucene.index.FieldInfo;
+import org.apache.lucene.index.FieldInfo.IndexOptions;
+import org.apache.lucene.index.FieldInfos;
+import org.apache.lucene.index.SegmentReadState;
+import org.apache.lucene.index.Terms;
+import org.apache.lucene.index.TermsEnum;
+import org.apache.lucene.store.BufferedChecksumIndexInput;
+import org.apache.lucene.store.ChecksumIndexInput;
+import org.apache.lucene.store.IndexInput;
+import org.apache.lucene.util.ArrayUtil;
+import org.apache.lucene.util.Bits;
+import org.apache.lucene.util.BytesRef;
+import org.apache.lucene.util.CharsRef;
+import org.apache.lucene.util.FixedBitSet;
+import org.apache.lucene.util.IOUtils;
+import org.apache.lucene.util.IntsRef;
+import org.apache.lucene.util.StringHelper;
+import org.apache.lucene.util.UnicodeUtil;
+import org.apache.lucene.util.fst.Builder;
+import org.apache.lucene.util.fst.BytesRefFSTEnum;
+import org.apache.lucene.util.fst.FST;
+import org.apache.lucene.util.fst.PairOutputs;
+import org.apache.lucene.util.fst.PositiveIntOutputs;
+import org.apache.lucene.util.fst.Util;
+
+import static org.apache.lucene.codecs.simpletext.SimpleTextFieldsWriter.END;
+import static org.apache.lucene.codecs.simpletext.SimpleTextFieldsWriter.FIELD;
+import static org.apache.lucene.codecs.simpletext.SimpleTextFieldsWriter.TERM;
+import static org.apache.lucene.codecs.simpletext.SimpleTextFieldsWriter.DOC;
+import static org.apache.lucene.codecs.simpletext.SimpleTextFieldsWriter.FREQ;
+import static org.apache.lucene.codecs.simpletext.SimpleTextFieldsWriter.POS;
+import static org.apache.lucene.codecs.simpletext.SimpleTextFieldsWriter.START_OFFSET;
+import static org.apache.lucene.codecs.simpletext.SimpleTextFieldsWriter.END_OFFSET;
+import static org.apache.lucene.codecs.simpletext.SimpleTextFieldsWriter.PAYLOAD;
+
+class SimpleTextFieldsReader extends FieldsProducer {
+  private final TreeMap<String,Long> fields;
+  private final IndexInput in;
+  private final FieldInfos fieldInfos;
+  private final int maxDoc;
+
+  public SimpleTextFieldsReader(SegmentReadState state)  {
+    this.maxDoc = state.segmentInfo.getDocCount();
+    fieldInfos = state.fieldInfos;
+    in = state.directory.openInput(SimpleTextPostingsFormat.getPostingsFileName(state.segmentInfo.name, state.segmentSuffix), state.context);
+    bool success = false;
+    try {
+      fields = readFields(in.clone());
+      success = true;
+    } finally {
+      if (!success) {
+        IOUtils.closeWhileHandlingException(this);
+      }
+    }
+  }
+  
+  private TreeMap<String,Long> readFields(IndexInput in)  {
+    ChecksumIndexInput input = new BufferedChecksumIndexInput(in);
+    BytesRef scratch = new BytesRef(10);
+    TreeMap<String,Long> fields = new TreeMap<>();
+    
+    while (true) {
+      SimpleTextUtil.readLine(input, scratch);
+      if (scratch.equals(END)) {
+        SimpleTextUtil.checkFooter(input);
+        return fields;
+      } else if (StringHelper.startsWith(scratch, FIELD)) {
+        String fieldName = new String(scratch.bytes, scratch.offset + FIELD.length, scratch.length - FIELD.length, StandardCharsets.UTF_8);
+        fields.put(fieldName, input.getFilePointer());
+      }
+    }
+  }
+
+  private class SimpleTextTermsEnum extends TermsEnum {
+    private final IndexOptions indexOptions;
+    private int docFreq;
+    private long totalTermFreq;
+    private long docsStart;
+    private bool ended;
+    private final BytesRefFSTEnum<PairOutputs.Pair<Long,PairOutputs.Pair<Long,Long>>> fstEnum;
+
+    public SimpleTextTermsEnum(FST<PairOutputs.Pair<Long,PairOutputs.Pair<Long,Long>>> fst, IndexOptions indexOptions) {
+      this.indexOptions = indexOptions;
+      fstEnum = new BytesRefFSTEnum<>(fst);
+    }
+
+    @Override
+    public bool seekExact(BytesRef text)  {
+
+      final BytesRefFSTEnum.InputOutput<PairOutputs.Pair<Long,PairOutputs.Pair<Long,Long>>> result = fstEnum.seekExact(text);
+      if (result != null) {
+        PairOutputs.Pair<Long,PairOutputs.Pair<Long,Long>> pair1 = result.output;
+        PairOutputs.Pair<Long,Long> pair2 = pair1.output2;
+        docsStart = pair1.output1;
+        docFreq = pair2.output1.intValue();
+        totalTermFreq = pair2.output2;
+        return true;
+      } else {
+        return false;
+      }
+    }
+
+    @Override
+    public SeekStatus seekCeil(BytesRef text)  {
+
+      //System.out.println("seek to text=" + text.utf8ToString());
+      final BytesRefFSTEnum.InputOutput<PairOutputs.Pair<Long,PairOutputs.Pair<Long,Long>>> result = fstEnum.seekCeil(text);
+      if (result == null) {
+        //System.out.println("  end");
+        return SeekStatus.END;
+      } else {
+        //System.out.println("  got text=" + term.utf8ToString());
+        PairOutputs.Pair<Long,PairOutputs.Pair<Long,Long>> pair1 = result.output;
+        PairOutputs.Pair<Long,Long> pair2 = pair1.output2;
+        docsStart = pair1.output1;
+        docFreq = pair2.output1.intValue();
+        totalTermFreq = pair2.output2;
+
+        if (result.input.equals(text)) {
+          //System.out.println("  match docsStart=" + docsStart);
+          return SeekStatus.FOUND;
+        } else {
+          //System.out.println("  not match docsStart=" + docsStart);
+          return SeekStatus.NOT_FOUND;
+        }
+      }
+    }
+
+    @Override
+    public BytesRef next()  {
+      Debug.Assert( !ended;
+      final BytesRefFSTEnum.InputOutput<PairOutputs.Pair<Long,PairOutputs.Pair<Long,Long>>> result = fstEnum.next();
+      if (result != null) {
+        PairOutputs.Pair<Long,PairOutputs.Pair<Long,Long>> pair1 = result.output;
+        PairOutputs.Pair<Long,Long> pair2 = pair1.output2;
+        docsStart = pair1.output1;
+        docFreq = pair2.output1.intValue();
+        totalTermFreq = pair2.output2;
+        return result.input;
+      } else {
+        return null;
+      }
+    }
+
+    @Override
+    public BytesRef term() {
+      return fstEnum.current().input;
+    }
+
+    @Override
+    public long ord()  {
+      throw new UnsupportedOperationException();
+    }
+
+    @Override
+    public void seekExact(long ord) {
+      throw new UnsupportedOperationException();
+    }
+
+    @Override
+    public int docFreq() {
+      return docFreq;
+    }
+
+    @Override
+    public long totalTermFreq() {
+      return indexOptions == IndexOptions.DOCS_ONLY ? -1 : totalTermFreq;
+    }
+ 
+    @Override
+    public DocsEnum docs(Bits liveDocs, DocsEnum reuse, int flags)  {
+      SimpleTextDocsEnum docsEnum;
+      if (reuse != null && reuse instanceof SimpleTextDocsEnum && ((SimpleTextDocsEnum) reuse).canReuse(SimpleTextFieldsReader.this.in)) {
+        docsEnum = (SimpleTextDocsEnum) reuse;
+      } else {
+        docsEnum = new SimpleTextDocsEnum();
+      }
+      return docsEnum.reset(docsStart, liveDocs, indexOptions == IndexOptions.DOCS_ONLY, docFreq);
+    }
+
+    @Override
+    public DocsAndPositionsEnum docsAndPositions(Bits liveDocs, DocsAndPositionsEnum reuse, int flags)  {
+
+      if (indexOptions.compareTo(IndexOptions.DOCS_AND_FREQS_AND_POSITIONS) < 0) {
+        // Positions were not indexed
+        return null;
+      }
+
+      SimpleTextDocsAndPositionsEnum docsAndPositionsEnum;
+      if (reuse != null && reuse instanceof SimpleTextDocsAndPositionsEnum && ((SimpleTextDocsAndPositionsEnum) reuse).canReuse(SimpleTextFieldsReader.this.in)) {
+        docsAndPositionsEnum = (SimpleTextDocsAndPositionsEnum) reuse;
+      } else {
+        docsAndPositionsEnum = new SimpleTextDocsAndPositionsEnum();
+      } 
+      return docsAndPositionsEnum.reset(docsStart, liveDocs, indexOptions, docFreq);
+    }
+    
+    @Override
+    public Comparator<BytesRef> getComparator() {
+      return BytesRef.getUTF8SortedAsUnicodeComparator();
+    }
+  }
+
+  private class SimpleTextDocsEnum extends DocsEnum {
+    private final IndexInput inStart;
+    private final IndexInput in;
+    private bool omitTF;
+    private int docID = -1;
+    private int tf;
+    private Bits liveDocs;
+    private final BytesRef scratch = new BytesRef(10);
+    private final CharsRef scratchUTF16 = new CharsRef(10);
+    private int cost;
+    
+    public SimpleTextDocsEnum() {
+      this.inStart = SimpleTextFieldsReader.this.in;
+      this.in = this.inStart.clone();
+    }
+
+    public bool canReuse(IndexInput in) {
+      return in == inStart;
+    }
+
+    public SimpleTextDocsEnum reset(long fp, Bits liveDocs, bool omitTF, int docFreq)  {
+      this.liveDocs = liveDocs;
+      in.seek(fp);
+      this.omitTF = omitTF;
+      docID = -1;
+      tf = 1;
+      cost = docFreq;
+      return this;
+    }
+
+    @Override
+    public int docID() {
+      return docID;
+    }
+
+    @Override
+    public int freq()  {
+      return tf;
+    }
+
+    @Override
+    public int nextDoc()  {
+      if (docID == NO_MORE_DOCS) {
+        return docID;
+      }
+      bool first = true;
+      int termFreq = 0;
+      while(true) {
+        final long lineStart = in.getFilePointer();
+        SimpleTextUtil.readLine(in, scratch);
+        if (StringHelper.startsWith(scratch, DOC)) {
+          if (!first && (liveDocs == null || liveDocs.get(docID))) {
+            in.seek(lineStart);
+            if (!omitTF) {
+              tf = termFreq;
+            }
+            return docID;
+          }
+          UnicodeUtil.UTF8toUTF16(scratch.bytes, scratch.offset+DOC.length, scratch.length-DOC.length, scratchUTF16);
+          docID = ArrayUtil.parseInt(scratchUTF16.chars, 0, scratchUTF16.length);
+          termFreq = 0;
+          first = false;
+        } else if (StringHelper.startsWith(scratch, FREQ)) {
+          UnicodeUtil.UTF8toUTF16(scratch.bytes, scratch.offset+FREQ.length, scratch.length-FREQ.length, scratchUTF16);
+          termFreq = ArrayUtil.parseInt(scratchUTF16.chars, 0, scratchUTF16.length);
+        } else if (StringHelper.startsWith(scratch, POS)) {
+          // skip termFreq++;
+        } else if (StringHelper.startsWith(scratch, START_OFFSET)) {
+          // skip
+        } else if (StringHelper.startsWith(scratch, END_OFFSET)) {
+          // skip
+        } else if (StringHelper.startsWith(scratch, PAYLOAD)) {
+          // skip
+        } else {
+          Debug.Assert( StringHelper.startsWith(scratch, TERM) || StringHelper.startsWith(scratch, FIELD) || StringHelper.startsWith(scratch, END): "scratch=" + scratch.utf8ToString();
+          if (!first && (liveDocs == null || liveDocs.get(docID))) {
+            in.seek(lineStart);
+            if (!omitTF) {
+              tf = termFreq;
+            }
+            return docID;
+          }
+          return docID = NO_MORE_DOCS;
+        }
+      }
+    }
+
+    @Override
+    public int advance(int target)  {
+      // Naive -- better to index skip data
+      return slowAdvance(target);
+    }
+    
+    @Override
+    public long cost() {
+      return cost;
+    }
+  }
+
+  private class SimpleTextDocsAndPositionsEnum extends DocsAndPositionsEnum {
+    private final IndexInput inStart;
+    private final IndexInput in;
+    private int docID = -1;
+    private int tf;
+    private Bits liveDocs;
+    private final BytesRef scratch = new BytesRef(10);
+    private final BytesRef scratch2 = new BytesRef(10);
+    private final CharsRef scratchUTF16 = new CharsRef(10);
+    private final CharsRef scratchUTF16_2 = new CharsRef(10);
+    private BytesRef payload;
+    private long nextDocStart;
+    private bool readOffsets;
+    private bool readPositions;
+    private int startOffset;
+    private int endOffset;
+    private int cost;
+
+    public SimpleTextDocsAndPositionsEnum() {
+      this.inStart = SimpleTextFieldsReader.this.in;
+      this.in = inStart.clone();
+    }
+
+    public bool canReuse(IndexInput in) {
+      return in == inStart;
+    }
+
+    public SimpleTextDocsAndPositionsEnum reset(long fp, Bits liveDocs, IndexOptions indexOptions, int docFreq) {
+      this.liveDocs = liveDocs;
+      nextDocStart = fp;
+      docID = -1;
+      readPositions = indexOptions.compareTo(IndexOptions.DOCS_AND_FREQS_AND_POSITIONS) >= 0;
+      readOffsets = indexOptions.compareTo(IndexOptions.DOCS_AND_FREQS_AND_POSITIONS_AND_OFFSETS) >= 0;
+      if (!readOffsets) {
+        startOffset = -1;
+        endOffset = -1;
+      }
+      cost = docFreq;
+      return this;
+    }
+
+    @Override
+    public int docID() {
+      return docID;
+    }
+
+    @Override
+    public int freq()  {
+      return tf;
+    }
+
+    @Override
+    public int nextDoc()  {
+      bool first = true;
+      in.seek(nextDocStart);
+      long posStart = 0;
+      while(true) {
+        final long lineStart = in.getFilePointer();
+        SimpleTextUtil.readLine(in, scratch);
+        //System.out.println("NEXT DOC: " + scratch.utf8ToString());
+        if (StringHelper.startsWith(scratch, DOC)) {
+          if (!first && (liveDocs == null || liveDocs.get(docID))) {
+            nextDocStart = lineStart;
+            in.seek(posStart);
+            return docID;
+          }
+          UnicodeUtil.UTF8toUTF16(scratch.bytes, scratch.offset+DOC.length, scratch.length-DOC.length, scratchUTF16);
+          docID = ArrayUtil.parseInt(scratchUTF16.chars, 0, scratchUTF16.length);
+          tf = 0;
+          first = false;
+        } else if (StringHelper.startsWith(scratch, FREQ)) {
+          UnicodeUtil.UTF8toUTF16(scratch.bytes, scratch.offset+FREQ.length, scratch.length-FREQ.length, scratchUTF16);
+          tf = ArrayUtil.parseInt(scratchUTF16.chars, 0, scratchUTF16.length);
+          posStart = in.getFilePointer();
+        } else if (StringHelper.startsWith(scratch, POS)) {
+          // skip
+        } else if (StringHelper.startsWith(scratch, START_OFFSET)) {
+          // skip
+        } else if (StringHelper.startsWith(scratch, END_OFFSET)) {
+          // skip
+        } else if (StringHelper.startsWith(scratch, PAYLOAD)) {
+          // skip
+        } else {
+          Debug.Assert( StringHelper.startsWith(scratch, TERM) || StringHelper.startsWith(scratch, FIELD) || StringHelper.startsWith(scratch, END);
+          if (!first && (liveDocs == null || liveDocs.get(docID))) {
+            nextDocStart = lineStart;
+            in.seek(posStart);
+            return docID;
+          }
+          return docID = NO_MORE_DOCS;
+        }
+      }
+    }
+
+    @Override
+    public int advance(int target)  {
+      // Naive -- better to index skip data
+      return slowAdvance(target);
+    }
+
+    @Override
+    public int nextPosition()  {
+      final int pos;
+      if (readPositions) {
+        SimpleTextUtil.readLine(in, scratch);
+        Debug.Assert( StringHelper.startsWith(scratch, POS): "got line=" + scratch.utf8ToString();
+        UnicodeUtil.UTF8toUTF16(scratch.bytes, scratch.offset+POS.length, scratch.length-POS.length, scratchUTF16_2);
+        pos = ArrayUtil.parseInt(scratchUTF16_2.chars, 0, scratchUTF16_2.length);
+      } else {
+        pos = -1;
+      }
+
+      if (readOffsets) {
+        SimpleTextUtil.readLine(in, scratch);
+        Debug.Assert( StringHelper.startsWith(scratch, START_OFFSET): "got line=" + scratch.utf8ToString();
+        UnicodeUtil.UTF8toUTF16(scratch.bytes, scratch.offset+START_OFFSET.length, scratch.length-START_OFFSET.length, scratchUTF16_2);
+        startOffset = ArrayUtil.parseInt(scratchUTF16_2.chars, 0, scratchUTF16_2.length);
+        SimpleTextUtil.readLine(in, scratch);
+        Debug.Assert( StringHelper.startsWith(scratch, END_OFFSET): "got line=" + scratch.utf8ToString();
+        UnicodeUtil.UTF8toUTF16(scratch.bytes, scratch.offset+END_OFFSET.length, scratch.length-END_OFFSET.length, scratchUTF16_2);
+        endOffset = ArrayUtil.parseInt(scratchUTF16_2.chars, 0, scratchUTF16_2.length);
+      }
+
+      final long fp = in.getFilePointer();
+      SimpleTextUtil.readLine(in, scratch);
+      if (StringHelper.startsWith(scratch, PAYLOAD)) {
+        final int len = scratch.length - PAYLOAD.length;
+        if (scratch2.bytes.length < len) {
+          scratch2.grow(len);
+        }
+        System.arraycopy(scratch.bytes, PAYLOAD.length, scratch2.bytes, 0, len);
+        scratch2.length = len;
+        payload = scratch2;
+      } else {
+        payload = null;
+        in.seek(fp);
+      }
+      return pos;
+    }
+
+    @Override
+    public int startOffset()  {
+      return startOffset;
+    }
+
+    @Override
+    public int endOffset()  {
+      return endOffset;
+    }
+
+    @Override
+    public BytesRef getPayload() {
+      return payload;
+    }
+    
+    @Override
+    public long cost() {
+      return cost;
+    }
+  }
+
+  static class TermData {
+    public long docsStart;
+    public int docFreq;
+
+    public TermData(long docsStart, int docFreq) {
+      this.docsStart = docsStart;
+      this.docFreq = docFreq;
+    }
+  }
+
+  private class SimpleTextTerms extends Terms {
+    private final long termsStart;
+    private final FieldInfo fieldInfo;
+    private final int maxDoc;
+    private long sumTotalTermFreq;
+    private long sumDocFreq;
+    private int docCount;
+    private FST<PairOutputs.Pair<Long,PairOutputs.Pair<Long,Long>>> fst;
+    private int termCount;
+    private final BytesRef scratch = new BytesRef(10);
+    private final CharsRef scratchUTF16 = new CharsRef(10);
+
+    public SimpleTextTerms(String field, long termsStart, int maxDoc)  {
+      this.maxDoc = maxDoc;
+      this.termsStart = termsStart;
+      fieldInfo = fieldInfos.fieldInfo(field);
+      loadTerms();
+    }
+
+    private void loadTerms()  {
+      PositiveIntOutputs posIntOutputs = PositiveIntOutputs.getSingleton();
+      final Builder<PairOutputs.Pair<Long,PairOutputs.Pair<Long,Long>>> b;
+      final PairOutputs<Long,Long> outputsInner = new PairOutputs<>(posIntOutputs, posIntOutputs);
+      final PairOutputs<Long,PairOutputs.Pair<Long,Long>> outputs = new PairOutputs<>(posIntOutputs,
+                                                                                                                      outputsInner);
+      b = new Builder<>(FST.INPUT_TYPE.BYTE1, outputs);
+      IndexInput in = SimpleTextFieldsReader.this.in.clone();
+      in.seek(termsStart);
+      final BytesRef lastTerm = new BytesRef(10);
+      long lastDocsStart = -1;
+      int docFreq = 0;
+      long totalTermFreq = 0;
+      FixedBitSet visitedDocs = new FixedBitSet(maxDoc);
+      final IntsRef scratchIntsRef = new IntsRef();
+      while(true) {
+        SimpleTextUtil.readLine(in, scratch);
+        if (scratch.equals(END) || StringHelper.startsWith(scratch, FIELD)) {
+          if (lastDocsStart != -1) {
+            b.add(Util.toIntsRef(lastTerm, scratchIntsRef),
+                  outputs.newPair(lastDocsStart,
+                                  outputsInner.newPair((long) docFreq, totalTermFreq)));
+            sumTotalTermFreq += totalTermFreq;
+          }
+          break;
+        } else if (StringHelper.startsWith(scratch, DOC)) {
+          docFreq++;
+          sumDocFreq++;
+          UnicodeUtil.UTF8toUTF16(scratch.bytes, scratch.offset+DOC.length, scratch.length-DOC.length, scratchUTF16);
+          int docID = ArrayUtil.parseInt(scratchUTF16.chars, 0, scratchUTF16.length);
+          visitedDocs.set(docID);
+        } else if (StringHelper.startsWith(scratch, FREQ)) {
+          UnicodeUtil.UTF8toUTF16(scratch.bytes, scratch.offset+FREQ.length, scratch.length-FREQ.length, scratchUTF16);
+          totalTermFreq += ArrayUtil.parseInt(scratchUTF16.chars, 0, scratchUTF16.length);
+        } else if (StringHelper.startsWith(scratch, TERM)) {
+          if (lastDocsStart != -1) {
+            b.add(Util.toIntsRef(lastTerm, scratchIntsRef), outputs.newPair(lastDocsStart,
+                                                                            outputsInner.newPair((long) docFreq, totalTermFreq)));
+          }
+          lastDocsStart = in.getFilePointer();
+          final int len = scratch.length - TERM.length;
+          if (len > lastTerm.length) {
+            lastTerm.grow(len);
+          }
+          System.arraycopy(scratch.bytes, TERM.length, lastTerm.bytes, 0, len);
+          lastTerm.length = len;
+          docFreq = 0;
+          sumTotalTermFreq += totalTermFreq;
+          totalTermFreq = 0;
+          termCount++;
+        }
+      }
+      docCount = visitedDocs.cardinality();
+      fst = b.finish();
+      /*
+      PrintStream ps = new PrintStream("out.dot");
+      fst.toDot(ps);
+      ps.close();
+      System.out.println("SAVED out.dot");
+      */
+      //System.out.println("FST " + fst.sizeInBytes());
+    }
+    
+    /** Returns approximate RAM bytes used */
+    public long ramBytesUsed() {
+      return (fst!=null) ? fst.sizeInBytes() : 0;
+    }
+
+    @Override
+    public TermsEnum iterator(TermsEnum reuse)  {
+      if (fst != null) {
+        return new SimpleTextTermsEnum(fst, fieldInfo.getIndexOptions());
+      } else {
+        return TermsEnum.EMPTY;
+      }
+    }
+
+    @Override
+    public Comparator<BytesRef> getComparator() {
+      return BytesRef.getUTF8SortedAsUnicodeComparator();
+    }
+
+    @Override
+    public long size() {
+      return (long) termCount;
+    }
+
+    @Override
+    public long getSumTotalTermFreq() {
+      return fieldInfo.getIndexOptions() == IndexOptions.DOCS_ONLY ? -1 : sumTotalTermFreq;
+    }
+
+    @Override
+    public long getSumDocFreq()  {
+      return sumDocFreq;
+    }
+
+    @Override
+    public int getDocCount()  {
+      return docCount;
+    }
+
+    @Override
+    public bool hasFreqs() {
+      return fieldInfo.getIndexOptions().compareTo(IndexOptions.DOCS_AND_FREQS) >= 0;
+    }
+
+    @Override
+    public bool hasOffsets() {
+      return fieldInfo.getIndexOptions().compareTo(IndexOptions.DOCS_AND_FREQS_AND_POSITIONS_AND_OFFSETS) >= 0;
+    }
+
+    @Override
+    public bool hasPositions() {
+      return fieldInfo.getIndexOptions().compareTo(IndexOptions.DOCS_AND_FREQS_AND_POSITIONS) >= 0;
+    }
+    
+    @Override
+    public bool hasPayloads() {
+      return fieldInfo.hasPayloads();
+    }
+  }
+
+  @Override
+  public Iterator<String> iterator() {
+    return Collections.unmodifiableSet(fields.keySet()).iterator();
+  }
+
+  private final Map<String,SimpleTextTerms> termsCache = new HashMap<>();
+
+  @Override
+  synchronized public Terms terms(String field)  {
+    Terms terms = termsCache.get(field);
+    if (terms == null) {
+      Long fp = fields.get(field);
+      if (fp == null) {
+        return null;
+      } else {
+        terms = new SimpleTextTerms(field, fp, maxDoc);
+        termsCache.put(field, (SimpleTextTerms) terms);
+      }
+    }
+    return terms;
+  }
+
+  @Override
+  public int size() {
+    return -1;
+  }
+
+  @Override
+  public void close()  {
+    in.close();
+  }
+
+  @Override
+  public long ramBytesUsed() {
+    long sizeInBytes = 0;
+    for(SimpleTextTerms simpleTextTerms : termsCache.values()) {
+      sizeInBytes += (simpleTextTerms!=null) ? simpleTextTerms.ramBytesUsed() : 0;
+    }
+    return sizeInBytes;
+  }
+
+  @Override
+  public void checkIntegrity()  {}
+}


[27/51] [abbrv] [partial] Cleaning up and getting ready to development towards v4.8

Posted by sy...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Resources/xsl/Gallio-Report.html+xhtml.xsl
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Resources/xsl/Gallio-Report.html+xhtml.xsl b/lib/Gallio.3.2.750/tools/Resources/xsl/Gallio-Report.html+xhtml.xsl
deleted file mode 100644
index 50f829a..0000000
--- a/lib/Gallio.3.2.750/tools/Resources/xsl/Gallio-Report.html+xhtml.xsl
+++ /dev/null
@@ -1,1060 +0,0 @@
-<?xml version="1.0" encoding="utf-8"?>
-<!--
-  This stylesheet is used for all HTML detail reports.
-  It can be rendered in any of the following modes.
-  
-  Document / Fragment:
-      A report can either be rendered a self-contained document or as
-      a fragment meant to be included in another document.
-  
-  HTML / XHTML:
-      A report can either be rendered in HTML or in XHTML syntax.
-      
-  One very important characteristic of the report is that while it uses JavaScript,
-  it does not require it.  All of the report's contents may be accessed without error
-  or serious inconvenience even with JavaScript disabled.  This is extremely important
-  for Visual Studio integration since the IE browser prevents execution of scripts
-  in local files by default.
--->
-<xsl:stylesheet version="1.0"
-                xmlns:xsl="http://www.w3.org/1999/XSL/Transform"
-                xmlns:msxsl="urn:schemas-microsoft-com:xslt"
-                xmlns:g="http://www.gallio.org/"
-                xmlns="http://www.w3.org/1999/xhtml">
-  <xsl:template match="g:report" mode="xhtml-document">
-    <xsl:param name="contentType" select="text/xhtml+xml" />
-    
-    <html xml:lang="en" lang="en" dir="ltr">
-      <xsl:comment> saved from url=(0014)about:internet </xsl:comment><xsl:text>&#13;&#10;</xsl:text>
-      <head>
-        <meta http-equiv="Content-Type" content="{$contentType}; charset=utf-8" />
-        <title>Gallio Test Report</title>
-        <link rel="stylesheet" type="text/css" href="{$cssDir}Gallio-Report.css" />
-        <link rel="stylesheet" type="text/css" href="{$cssDir}Gallio-Report.generated.css" />
-        <script type="text/javascript" src="{$jsDir}Gallio-Report.js" />
-        <xsl:if test="g:testPackageRun//g:testStepRun/g:testLog/g:attachments/g:attachment[@contentType='video/x-flv']">
-          <script type="text/javascript" src="{$jsDir}swfobject.js" />
-        </xsl:if>
-        <style type="text/css">
-html
-{
-	overflow: auto;
-}
-        </style>
-      </head>
-      <body class="gallio-report">
-        <xsl:apply-templates select="." mode="xhtml-body" />
-      </body>
-      <script type="text/javascript">reportLoaded();</script>
-    </html>
-  </xsl:template>
-  
-  <xsl:template match="g:report" mode="html-document">
-    <xsl:call-template name="strip-namespace">
-      <xsl:with-param name="nodes">
-        <xsl:apply-templates select="." mode="xhtml-document">
-          <xsl:with-param name="contentType" select="text/html" />
-        </xsl:apply-templates>
-      </xsl:with-param>
-    </xsl:call-template>
-  </xsl:template>
-
-  <xsl:template match="g:report" mode="xhtml-fragment">
-    <div class="gallio-report">
-      <!-- Technically a link element should not appear outside of the "head"
-           but most browsers tolerate it and this gives us better out of the box
-           support in embedded environments like CCNet since no changes need to
-           be made to the stylesheets of the containing application.
-      -->
-      <link rel="stylesheet" type="text/css" href="{$cssDir}Gallio-Report.css" />
-      <link rel="stylesheet" type="text/css" href="{$cssDir}Gallio-Report.generated.css" />
-      <style type="text/css">
-html
-{
-	margin: 0px 0px 0px 0px;
-	padding: 0px 17px 0px 0px;
-	overflow: auto;
-}
-      </style>
-      <script type="text/javascript" src="{$jsDir}Gallio-Report.js" />
-      <xsl:if test="g:testPackageRun//g:testStepRun/g:testLog/g:attachments/g:attachment[@contentType='video/x-flv']">
-        <script type="text/javascript" src="{$jsDir}swfobject.js" />
-      </xsl:if>
-
-      <xsl:apply-templates select="." mode="xhtml-body" />
-    </div>
-    <script type="text/javascript">reportLoaded();</script>
-  </xsl:template>
-
-  <xsl:template match="g:report" mode="html-fragment">
-    <xsl:call-template name="strip-namespace">
-      <xsl:with-param name="nodes"><xsl:apply-templates select="." mode="xhtml-fragment" /></xsl:with-param>
-    </xsl:call-template>
-  </xsl:template>
-  
-  <xsl:template match="g:report" mode="xhtml-body">
-    <div id="Header" class="header">
-      <div class="header-image"></div>
-    </div>
-    <div id="Navigator" class="navigator">
-      <xsl:apply-templates select="g:testPackageRun" mode="navigator" />
-    </div>
-    <div id="Content" class="content">
-      <iframe id="_asyncLoadFrame" src="about:blank" style="border: 0px; margin: 0px 0px 0px 0px; padding: 0px 0px 0px 0px; width: 0px; height: 0px; display: none;" onload="_asyncLoadFrameOnLoad()" />
-      
-      <xsl:apply-templates select="g:testPackageRun" mode="statistics" />
-      <xsl:apply-templates select="g:testPackage" mode="files" />
-      <xsl:apply-templates select="g:testModel/g:annotations" mode="annotations"/>
-      <xsl:apply-templates select="g:testPackageRun" mode="summary"/>
-      <xsl:apply-templates select="g:testPackageRun" mode="details"/>
-      <xsl:apply-templates select="g:logEntries" mode="log"/>
-    </div>
-  </xsl:template>
-  
-  <xsl:template match="g:testPackage" mode="files">
-    <div id="Files" class="section">
-      <h2>Files</h2>
-      <div class="section-content">
-        <ul>
-          <xsl:for-each select="g:files/g:file">
-            <li><xsl:call-template name="print-text-with-breaks"><xsl:with-param name="text" select="text()" /></xsl:call-template></li>
-          </xsl:for-each>
-        </ul>
-      </div>
-    </div>
-  </xsl:template>
-
-  <xsl:template match="g:annotations" mode="annotations">
-    <xsl:if test="g:annotation">
-      <div id="Annotations" class="section">
-        <h2>Annotations</h2>
-        <div class="section-content">
-          <ul>
-            <xsl:apply-templates select="g:annotation[@type='error']" mode="annotations"/>
-            <xsl:apply-templates select="g:annotation[@type='warning']" mode="annotations"/>
-            <xsl:apply-templates select="g:annotation[@type='info']" mode="annotations"/>
-          </ul>
-        </div>
-      </div>
-    </xsl:if>
-  </xsl:template>
-
-  <xsl:template match="g:annotation" mode="annotations">
-    <li>
-      <xsl:attribute name="class">annotation annotation-type-<xsl:value-of select="@type"/></xsl:attribute>
-      <div class="annotation-message">
-        <xsl:text>[</xsl:text><xsl:value-of select="@type"/><xsl:text>] </xsl:text>
-        <xsl:call-template name="print-text-with-breaks"><xsl:with-param name="text" select="@message" /></xsl:call-template>
-      </div>
-      
-      <xsl:if test="g:codeLocation/@path">
-        <div class="annotation-location">
-          <xsl:text>Location: </xsl:text>
-          <xsl:call-template name="code-location-link">
-            <xsl:with-param name="path" select="g:codeLocation/@path" />
-            <xsl:with-param name="line" select="g:codeLocation/@line" />
-            <xsl:with-param name="column" select="g:codeLocation/@column" />
-            <xsl:with-param name="content">
-              <xsl:call-template name="format-code-location">
-                <xsl:with-param name="codeLocation" select="g:codeLocation" />
-              </xsl:call-template>
-            </xsl:with-param>
-          </xsl:call-template>
-        </div>
-      </xsl:if>
-      
-      <xsl:if test="g:codeReference/@assembly">
-        <div class="annotation-reference">
-          <xsl:text>Reference: </xsl:text>
-          <xsl:call-template name="format-code-reference"><xsl:with-param name="codeReference" select="g:codeReference" /></xsl:call-template>
-        </div>
-      </xsl:if>
-      
-      <xsl:if test="@details">
-        <div class="annotation-details">
-          <xsl:text>Details: </xsl:text>
-          <xsl:call-template name="print-text-with-breaks"><xsl:with-param name="text" select="@details" /></xsl:call-template>
-        </div>
-      </xsl:if>
-    </li>
-  </xsl:template>
-  
-  <xsl:template match="g:testPackageRun" mode="navigator">
-    <xsl:variable name="box-label"><xsl:call-template name="format-statistics"><xsl:with-param name="statistics" select="g:statistics" /></xsl:call-template></xsl:variable>
-    <a href="#Statistics" title="{$box-label}">
-      <xsl:attribute name="class">navigator-box <xsl:call-template name="status-from-statistics"><xsl:with-param name="statistics" select="g:statistics" /></xsl:call-template></xsl:attribute>
-    </a>
-
-    <div class="navigator-stripes">
-      <xsl:for-each select="descendant::g:testStepRun">
-        <xsl:variable name="status" select="g:result/g:outcome/@status"/>
-        <xsl:if test="$status != 'passed' and (g:testStep/@isTestCase = 'true' or not(g:children/g:testStepRun))">
-          <xsl:variable name="stripe-label"><xsl:value-of select="g:testStep/@name"/><xsl:text> </xsl:text><xsl:value-of select="$status"/>.</xsl:variable>
-          <a href="#testStepRun-{g:testStep/@id}" style="top:{position() * 98 div last() + 1}%" class="status-{$status}" title="{$stripe-label}">
-            <xsl:attribute name="onclick">
-              <xsl:text>expand([</xsl:text>
-              <xsl:for-each select="ancestor-or-self::g:testStepRun">
-                <xsl:if test="position() != 1">
-                  <xsl:text>,</xsl:text>
-                </xsl:if>
-                <xsl:text>'detailPanel-</xsl:text>
-                <xsl:value-of select="g:testStep/@id"/>
-                <xsl:text>'</xsl:text>
-              </xsl:for-each>
-              <xsl:text>]);</xsl:text>
-            </xsl:attribute>
-          </a>
-        </xsl:if>
-      </xsl:for-each>
-    </div>
-  </xsl:template>
-  
-  <xsl:template match="g:testPackageRun" mode="statistics">
-    <div id="Statistics" class="section">
-      <h2>Statistics</h2>
-      <div class="section-content">
-        <table class="statistics-table">
-          <tr>
-            <td class="statistics-label-cell">Start time:</td>
-            <td><xsl:call-template name="format-datetime"><xsl:with-param name="datetime" select="@startTime" /></xsl:call-template></td>
-          </tr>
-          <tr class="alternate-row">
-            <td class="statistics-label-cell">End time:</td>
-            <td><xsl:call-template name="format-datetime"><xsl:with-param name="datetime" select="@endTime" /></xsl:call-template></td>
-          </tr>
-          <xsl:apply-templates select="g:statistics" />
-        </table>
-      </div>
-    </div>
-  </xsl:template>
-
-  <xsl:template match="g:statistics">
-    <tr>
-      <td class="statistics-label-cell">Tests:</td>
-      <td><xsl:value-of select="@testCount" /> (<xsl:value-of select="@stepCount" /> steps)</td>
-    </tr>
-    <tr class="alternate-row">
-      <td class="statistics-label-cell">Results:</td>
-      <td><xsl:call-template name="format-statistics"><xsl:with-param name="statistics" select="." /></xsl:call-template></td>
-    </tr>
-    <tr>
-      <td class="statistics-label-cell">Duration:</td>
-      <td><xsl:value-of select="format-number(@duration, '0.00')" />s</td>
-    </tr>
-    <tr class="alternate-row">
-      <td class="statistics-label-cell">Assertions:</td>
-      <td><xsl:value-of select="@assertCount" /></td>
-    </tr>
-  </xsl:template>
-
-  <xsl:template match="g:testPackageRun" mode="summary">
-    <div id="Summary" class="section">
-      <h2>Summary<xsl:if test="$condensed"> (Condensed)</xsl:if></h2>
-      <div class="section-content">
-        <xsl:choose>
-          <xsl:when test="g:testStepRun/g:children/g:testStepRun">
-            <xsl:choose>
-              <xsl:when test="not($condensed) or g:testStepRun/g:result/g:outcome/@status!='passed'">
-                <ul>
-                  <xsl:apply-templates select="g:testStepRun/g:children/g:testStepRun" mode="summary" />
-                </ul>
-              </xsl:when>
-              <xsl:otherwise>
-                <em>All tests passed.</em>
-              </xsl:otherwise>
-            </xsl:choose>
-          </xsl:when>
-          <xsl:otherwise>
-            <em>This report does not contain any test runs.</em>
-          </xsl:otherwise>
-        </xsl:choose>
-      </div>
-    </div>
-  </xsl:template>
-
-  <xsl:template match="g:testStepRun" mode="summary">
-    <xsl:variable name="id" select="g:testStep/@id" />
-    
-    <xsl:if test="g:testStep/@isTestCase='false' and (not($condensed) or g:result/g:outcome/@status!='passed')">
-      <xsl:variable name="statisticsRaw">
-        <xsl:call-template name="aggregate-statistics">
-          <xsl:with-param name="testStepRun" select="." />
-        </xsl:call-template>
-      </xsl:variable>
-      <xsl:variable name="statistics" select="msxsl:node-set($statisticsRaw)/g:statistics" />
-
-      <xsl:variable name="metadataEntries" select="g:testStep/g:metadata/g:entry" />
-      <xsl:variable name="kind" select="$metadataEntries[@key='TestKind']/g:value" />
-
-      <li>
-        <span>
-          <xsl:choose>
-            <xsl:when test="g:children/g:testStepRun/g:testStep/@isTestCase='false'">
-              <xsl:call-template name="toggle">
-                <xsl:with-param name="href">summaryPanel-<xsl:value-of select="$id"/></xsl:with-param>
-              </xsl:call-template>
-            </xsl:when>
-            <xsl:otherwise>
-              <xsl:call-template name="toggle-stop" />
-            </xsl:otherwise>
-          </xsl:choose>
-
-          <xsl:call-template name="icon">
-            <xsl:with-param name="kind" select="$kind" />
-          </xsl:call-template>
-
-          <a class="crossref" href="#testStepRun-{$id}">
-            <xsl:attribute name="onclick">
-              <xsl:text>expand([</xsl:text>
-              <xsl:for-each select="ancestor-or-self::g:testStepRun">
-                <xsl:if test="position() != 1">
-                  <xsl:text>,</xsl:text>
-                </xsl:if>
-                <xsl:text>'detailPanel-</xsl:text>
-                <xsl:value-of select="g:testStep/@id"/>
-                <xsl:text>'</xsl:text>
-              </xsl:for-each>
-              <xsl:text>]);</xsl:text>
-            </xsl:attribute>
-            <xsl:call-template name="print-text-with-breaks"><xsl:with-param name="text" select="g:testStep/@name" /></xsl:call-template>
-          </a>
-
-          <xsl:call-template name="outcome-bar">
-            <xsl:with-param name="outcome" select="g:result/g:outcome" />
-            <xsl:with-param name="statistics" select="$statistics" />
-          </xsl:call-template>
-        </span>
-        
-        <div class="panel">
-          <xsl:if test="g:children/g:testStepRun">
-            <ul id="summaryPanel-{$id}">
-              <xsl:apply-templates select="g:children/g:testStepRun" mode="summary" />
-            </ul>
-          </xsl:if>
-        </div>
-      </li>
-    </xsl:if>
-  </xsl:template>
-
-  <xsl:template match="g:testPackageRun" mode="details">
-    <div id="Details" class="section">
-      <h2>Details<xsl:if test="$condensed"> (Condensed)</xsl:if></h2>
-      <div class="section-content">
-        <xsl:choose>
-          <xsl:when test="g:testStepRun/g:children/g:testStepRun">
-            <xsl:choose>
-              <xsl:when test="not($condensed) or g:testStepRun/g:result/g:outcome/@status!='passed'">
-                <ul class="testStepRunContainer">
-                  <xsl:apply-templates select="g:testStepRun/g:children/g:testStepRun" mode="details" />
-                </ul>
-              </xsl:when>
-              <xsl:otherwise>
-                <em>All tests passed.</em>
-              </xsl:otherwise>
-            </xsl:choose>
-          </xsl:when>
-          <xsl:otherwise>
-            <em>This report does not contain any test runs.</em>
-          </xsl:otherwise>
-        </xsl:choose>
-      </div>
-    </div>
-  </xsl:template>
-
-  <xsl:template match="g:testStepRun" mode="details">
-    <xsl:if test="not($condensed) or g:result/g:outcome/@status!='passed'">
-      <xsl:variable name="id" select="g:testStep/@id" />
-      
-      <xsl:variable name="metadataEntries" select="g:testStep/g:metadata/g:entry" />      
-      <xsl:variable name="kind" select="$metadataEntries[@key='TestKind']/g:value" />    
-      <xsl:variable name="nestingLevel" select="count(ancestor::g:testStepRun)" />
-      
-      <xsl:variable name="statisticsRaw">
-        <xsl:call-template name="aggregate-statistics">
-          <xsl:with-param name="testStepRun" select="." />
-        </xsl:call-template>
-      </xsl:variable>
-      <xsl:variable name="statistics" select="msxsl:node-set($statisticsRaw)/g:statistics" />
-
-      <li id="testStepRun-{$id}">
-        <span class="testStepRunHeading testStepRunHeading-Level{$nestingLevel}">
-          <xsl:call-template name="toggle">
-            <xsl:with-param name="href">detailPanel-<xsl:value-of select="$id"/></xsl:with-param>
-          </xsl:call-template>
-          
-          <xsl:call-template name="icon">
-            <xsl:with-param name="kind" select="$kind" />
-          </xsl:call-template>
-
-          <xsl:call-template name="code-location-link">
-            <xsl:with-param name="path" select="g:testStep/g:codeLocation/@path" />
-            <xsl:with-param name="line" select="g:testStep/g:codeLocation/@line" />
-            <xsl:with-param name="column" select="g:testStep/g:codeLocation/@column" />
-            <xsl:with-param name="content">
-              <xsl:call-template name="print-text-with-breaks">
-                <xsl:with-param name="text" select="g:testStep/@name" />
-              </xsl:call-template>
-            </xsl:with-param>
-          </xsl:call-template>
-
-          <xsl:call-template name="outcome-bar">
-            <xsl:with-param name="outcome" select="g:result/g:outcome" />
-            <xsl:with-param name="statistics" select="$statistics" />
-            <xsl:with-param name="small" select="not(g:children/g:testStepRun)" />
-          </xsl:call-template>
-        </span>
-
-        <div id="detailPanel-{$id}" class="panel">
-          <xsl:choose>
-            <xsl:when test="$nestingLevel = 1">
-              <table class="statistics-table">
-                <tr class="alternate-row">
-                  <td class="statistics-label-cell">Results:</td>
-                  <td><xsl:call-template name="format-statistics"><xsl:with-param name="statistics" select="$statistics" /></xsl:call-template></td>
-                </tr>
-                <tr>
-                  <td class="statistics-label-cell">Duration:</td>
-                  <td><xsl:value-of select="format-number($statistics/@duration, '0.00')" />s</td>
-                </tr>
-                <tr class="alternate-row">
-                  <td class="statistics-label-cell">Assertions:</td>
-                  <td><xsl:value-of select="$statistics/@assertCount" /></td>
-                </tr>
-              </table>
-            </xsl:when>
-            <xsl:otherwise>
-              <xsl:text>Duration: </xsl:text>
-              <xsl:value-of select="format-number($statistics/@duration, '0.00')" />
-              <xsl:text>s, Assertions: </xsl:text>
-              <xsl:value-of select="$statistics/@assertCount"/>
-              <xsl:text>.</xsl:text>
-            </xsl:otherwise>
-          </xsl:choose>
-
-          <xsl:call-template name="print-metadata-entries">
-            <xsl:with-param name="entries" select="$metadataEntries" />
-          </xsl:call-template>
-
-          <div id="testStepRun-{g:testStepRun/g:testStep/@id}" class="testStepRun">
-            <xsl:apply-templates select="." mode="details-content" />
-          </div>
-
-          <xsl:choose>
-            <xsl:when test="g:children/g:testStepRun">
-              <ul class="testStepRunContainer">
-                <xsl:apply-templates select="g:children/g:testStepRun" mode="details" />
-              </ul>
-            </xsl:when>
-            <xsl:when test="g:result/g:outcome/@status = 'passed'">
-              <xsl:call-template name="toggle-autoclose">
-                <xsl:with-param name="href">detailPanel-<xsl:value-of select="$id"/></xsl:with-param>
-              </xsl:call-template>
-            </xsl:when>
-          </xsl:choose>
-        </div>
-      </li>
-    </xsl:if>
-  </xsl:template>
-
-  <xsl:template match="g:testStepRun" mode="details-content">
-    <xsl:apply-templates select="g:testLog">
-      <xsl:with-param name="stepId" select="g:testStep/@id" />
-    </xsl:apply-templates>
-  </xsl:template>
-
-  <xsl:template match="g:metadata">
-    <xsl:call-template name="print-metadata-entries">
-      <xsl:with-param name="entries" select="g:entry" />
-    </xsl:call-template>
-  </xsl:template>
-
-  <xsl:template name="print-metadata-entries">
-    <xsl:param name="entries" />
-    <xsl:variable name="visibleEntries" select="$entries[@key != 'TestKind']" />
-
-    <xsl:if test="$visibleEntries">
-      <ul class="metadata">
-        <xsl:apply-templates select="$visibleEntries">
-          <xsl:sort select="translate(@key, 'ABCDEFGHIJKLMNOPQRSTUVWXYZ', 'abcdefghijklmnopqrstuvwxyz')" lang="en" data-type="text" />
-          <xsl:sort select="translate(@value, 'ABCDEFGHIJKLMNOPQRSTUVWXYZ', 'abcdefghijklmnopqrstuvwxyz')" lang="en" data-type="text" />
-        </xsl:apply-templates>
-      </ul>
-    </xsl:if>
-  </xsl:template>
-
-  <xsl:template match="g:entry">
-    <li><xsl:value-of select="@key" />: <xsl:call-template name="print-text-with-breaks"><xsl:with-param name="text" select="g:value" /></xsl:call-template></li>
-  </xsl:template>
-
-  <xsl:template match="g:testLog">
-    <xsl:param name="stepId" />
-
-    <xsl:if test="g:streams/g:stream">
-      <div id="log-{$stepId}" class="log">
-        <xsl:apply-templates select="g:streams/g:stream" mode="stream">
-          <xsl:with-param name="attachments" select="g:attachments" />
-        </xsl:apply-templates>
-        
-        <xsl:if test="g:attachments/g:attachment">
-          <div class="logAttachmentList">
-            Attachments: <xsl:for-each select="g:attachments/g:attachment">
-              <xsl:apply-templates select="." mode="link" /><xsl:if test="position() != last()">, </xsl:if>
-            </xsl:for-each>.
-          </div>
-        </xsl:if>
-      </div>
-    </xsl:if>
-  </xsl:template>
-
-  <xsl:template match="g:streams/g:stream" mode="stream">
-    <xsl:param name="attachments" />
-
-    <div class="logStream logStream-{@name}">
-      <span class="logStreamHeading">
-        <xsl:value-of select="@name" />
-      </span>
-
-      <xsl:apply-templates select="g:body" mode="stream">
-        <xsl:with-param name="attachments" select="$attachments" />
-      </xsl:apply-templates>
-    </div>
-  </xsl:template>
-
-  <xsl:template match="g:body" mode="stream">
-    <xsl:param name="attachments" />
-
-    <div class="logStreamBody">
-      <xsl:apply-templates select="g:contents" mode="stream">
-        <xsl:with-param name="attachments" select="$attachments" />
-      </xsl:apply-templates>
-    </div>
-  </xsl:template>
-
-  <xsl:template match="g:section" mode="stream">
-    <xsl:param name="attachments" />
-
-    <div class="logStreamSection">
-      <span class="logStreamSectionHeading">
-        <xsl:value-of select="@name"/>
-      </span>
-      <div>
-        <xsl:apply-templates select="g:contents" mode="stream">
-          <xsl:with-param name="attachments" select="$attachments" />
-        </xsl:apply-templates>
-      </div>
-    </div>
-  </xsl:template>
-
-  <xsl:template match="g:marker" mode="stream">
-    <xsl:param name="attachments" />
-
-    <span class="logStreamMarker-{@class}">
-      <xsl:choose>
-        <xsl:when test="@class = 'CodeLocation'">
-          <xsl:call-template name="code-location-link">
-            <xsl:with-param name="path" select="g:attributes/g:attribute[@name='path']/@value" />
-            <xsl:with-param name="line" select="g:attributes/g:attribute[@name='line']/@value" />
-            <xsl:with-param name="column" select="g:attributes/g:attribute[@name='column']/@value" />
-            <xsl:with-param name="content">
-              <xsl:apply-templates select="g:contents" mode="stream">
-                <xsl:with-param name="attachments" select="$attachments" />
-              </xsl:apply-templates>
-            </xsl:with-param>
-          </xsl:call-template>
-        </xsl:when>
-        <xsl:when test="@class = 'Link'">
-          <a class="crossref" href="{g:attributes/g:attribute[@name = 'url']/@value}">
-            <xsl:apply-templates select="g:contents" mode="stream">
-              <xsl:with-param name="attachments" select="$attachments" />
-            </xsl:apply-templates>
-          </a>
-        </xsl:when>
-        <xsl:otherwise>
-          <xsl:apply-templates select="g:contents" mode="stream">
-            <xsl:with-param name="attachments" select="$attachments" />
-          </xsl:apply-templates>
-        </xsl:otherwise>
-      </xsl:choose>      
-    </span>
-  </xsl:template>
-
-  <xsl:template match="g:contents" mode="stream">
-    <xsl:param name="attachments" />
-
-    <xsl:apply-templates select="child::node()[self::g:text or self::g:section or self::g:embed or self::g:marker]" mode="stream">
-      <xsl:with-param name="attachments" select="$attachments" />
-    </xsl:apply-templates>
-  </xsl:template>
-
-  <xsl:template match="g:text" mode="stream">
-    <xsl:param name="attachments" />
-
-    <xsl:call-template name="print-text-with-breaks">
-      <xsl:with-param name="text" select="text()" />
-    </xsl:call-template>
-  </xsl:template>
-
-  <xsl:template match="g:embed" mode="stream">
-    <xsl:param name="attachments" />
-    <xsl:variable name="attachmentName" select="@attachmentName" />
-    
-    <xsl:apply-templates select="$attachments/g:attachment[@name=$attachmentName]" mode="embed">
-      <xsl:with-param name="id" select="generate-id(.)" />
-    </xsl:apply-templates>
-  </xsl:template>
-
-  <xsl:template match="g:attachment" mode="link">
-    <xsl:choose>
-      <xsl:when test="$attachmentBrokerUrl != ''">
-        <xsl:variable name="attachmentBrokerQuery"><xsl:value-of select="$attachmentBrokerUrl"/>testStepId=<xsl:value-of select="../../../g:testStep/@id"/>&amp;attachmentName=<xsl:value-of select="@name"/></xsl:variable>
-        
-        <a href="{$attachmentBrokerQuery}" class="attachmentLink"><xsl:value-of select="@name" /></a>
-      </xsl:when>
-      <xsl:when test="@contentDisposition = 'link'">
-        <xsl:variable name="attachmentUri"><xsl:call-template name="path-to-uri"><xsl:with-param name="path" select="@contentPath" /></xsl:call-template></xsl:variable>
-        
-        <a href="{$attachmentUri}" class="attachmentLink"><xsl:value-of select="@name" /></a>
-      </xsl:when>
-      <xsl:otherwise>
-        <xsl:value-of select="@name" /> (n/a)
-      </xsl:otherwise>
-    </xsl:choose>
-  </xsl:template>
-
-  <xsl:template match="g:attachment" mode="embed">
-    <xsl:param name="id" />
-    
-    <xsl:choose>
-      <!-- When using an attachment broker, we obtain content from a Uri consisting of a query for the attachment data. -->
-      <xsl:when test="$attachmentBrokerUrl != ''">
-        <xsl:variable name="attachmentBrokerQuery"><xsl:value-of select="$attachmentBrokerUrl"/>testStepId=<xsl:value-of select="../../../g:testStep/@id"/>&amp;attachmentName=<xsl:value-of select="@name"/></xsl:variable>
-
-        <xsl:call-template name="embed-attachment-with-uri">
-          <xsl:with-param name="id" select="$id" />
-          <xsl:with-param name="name" select="@name" />
-          <xsl:with-param name="contentType" select="@contentType" />
-          <xsl:with-param name="uri" select="$attachmentBrokerQuery" />
-        </xsl:call-template>
-      </xsl:when>
-      
-      <!-- When attachments are linked, we obtain content from a Uri generated from the attachment path. -->
-      <xsl:when test="@contentDisposition = 'link'">
-        <xsl:variable name="attachmentUri"><xsl:call-template name="path-to-uri"><xsl:with-param name="path" select="@contentPath" /></xsl:call-template></xsl:variable>
-
-        <xsl:call-template name="embed-attachment-with-uri">
-          <xsl:with-param name="id" select="$id" />
-          <xsl:with-param name="name" select="@name" />
-          <xsl:with-param name="contentType" select="@contentType" />
-          <xsl:with-param name="uri" select="$attachmentUri" />
-        </xsl:call-template>
-      </xsl:when>
-      
-      <!-- When attachments are inline, we try to embed the data within the HTML itself. -->
-      <xsl:when test="@contentDisposition = 'inline'">
-        <xsl:call-template name="embed-attachment-with-content">
-          <xsl:with-param name="id" select="$id" />
-          <xsl:with-param name="name" select="@name" />
-          <xsl:with-param name="contentType" select="@contentType" />
-          <xsl:with-param name="encoding" select="@encoding" />
-          <xsl:with-param name="content" select="text()" />
-        </xsl:call-template>
-      </xsl:when>
-      
-      <!-- When there is no data, we insert a placeholder. -->
-      <xsl:otherwise>
-        <xsl:call-template name="embed-attachment-placeholder">
-          <xsl:with-param name="id" select="$id" />
-          <xsl:with-param name="name" select="@name" />
-        </xsl:call-template>
-      </xsl:otherwise>
-    </xsl:choose>
-  </xsl:template>
-
-  <xsl:template name="embed-attachment-with-uri">
-    <xsl:param name="id" />
-    <xsl:param name="name" />
-    <xsl:param name="contentType" />
-    <xsl:param name="uri" />
-
-    <xsl:variable name="isImage" select="starts-with($contentType, 'image/')" />
-    <xsl:variable name="isHtml" select="starts-with($contentType, 'text/html') or starts-with($contentType, 'text/xhtml')" />
-    <xsl:variable name="isText" select="starts-with($contentType, 'text/')" />
-    <xsl:variable name="isFlashVideo" select="starts-with($contentType, 'video/x-flv')" />
-
-    <xsl:choose>
-      <xsl:when test="$isImage">
-        <xsl:call-template name="embed-attachment-image-from-uri">
-          <xsl:with-param name="id" select="$id" />
-          <xsl:with-param name="name" select="$name" />
-          <xsl:with-param name="uri" select="$uri" />
-        </xsl:call-template>
-      </xsl:when>
-      <xsl:when test="$isHtml">
-        <xsl:call-template name="embed-attachment-html-from-uri">
-          <xsl:with-param name="id" select="$id" />
-          <xsl:with-param name="name" select="$name" />
-          <xsl:with-param name="uri" select="$uri" />
-        </xsl:call-template>
-      </xsl:when>
-      <xsl:when test="$isText">
-        <xsl:call-template name="embed-attachment-text-from-uri">
-          <xsl:with-param name="id" select="$id" />
-          <xsl:with-param name="name" select="$name" />
-          <xsl:with-param name="uri" select="$uri" />
-        </xsl:call-template>
-      </xsl:when>
-      <xsl:when test="$isFlashVideo">
-        <xsl:call-template name="embed-attachment-flashvideo-from-uri">
-          <xsl:with-param name="id" select="$id" />
-          <xsl:with-param name="name" select="$name" />
-          <xsl:with-param name="uri" select="$uri" />
-        </xsl:call-template>
-      </xsl:when>
-      <xsl:otherwise>
-        <xsl:call-template name="embed-attachment-link">
-          <xsl:with-param name="id" select="$id" />
-          <xsl:with-param name="name" select="$name" />
-          <xsl:with-param name="uri" select="$uri" />
-        </xsl:call-template>
-      </xsl:otherwise>
-    </xsl:choose>
-  </xsl:template>
-
-  <xsl:template name="embed-attachment-with-content">
-    <xsl:param name="id" />
-    <xsl:param name="name" />
-    <xsl:param name="contentType" />
-    <xsl:param name="encoding" />
-    <xsl:param name="content" />
-
-    <xsl:variable name="isImage" select="starts-with($contentType, 'image/')" />
-    <xsl:variable name="isHtml" select="starts-with($contentType, 'text/html') or starts-with($contentType, 'text/xhtml')" />
-    <xsl:variable name="isText" select="starts-with($contentType, 'text/')" />
-
-    <xsl:choose>
-      <xsl:when test="$isImage and $encoding = 'base64'">
-        <xsl:call-template name="embed-attachment-image-from-content">
-          <xsl:with-param name="id" select="$id" />
-          <xsl:with-param name="name" select="$name" />
-          <xsl:with-param name="content" select="$content" />
-          <xsl:with-param name="contentType" select="$contentType" />
-        </xsl:call-template>
-      </xsl:when>
-      <xsl:when test="$isHtml and $encoding = 'text'">
-        <xsl:call-template name="embed-attachment-html-from-content">
-          <xsl:with-param name="id" select="$id" />
-          <xsl:with-param name="name" select="$name" />
-          <xsl:with-param name="content" select="$content" />
-        </xsl:call-template>
-      </xsl:when>
-      <xsl:when test="$isText and $encoding = 'text'">
-        <xsl:call-template name="embed-attachment-text-from-content">
-          <xsl:with-param name="id" select="$id" />
-          <xsl:with-param name="name" select="$name" />
-          <xsl:with-param name="content" select="$content" />
-        </xsl:call-template>
-      </xsl:when>
-      <xsl:otherwise>
-        <xsl:call-template name="embed-attachment-placeholder">
-          <xsl:with-param name="id" select="$id" />
-          <xsl:with-param name="name" select="$name" />
-        </xsl:call-template>
-      </xsl:otherwise>
-    </xsl:choose>
-  </xsl:template>
-
-  <xsl:template name="embed-attachment-placeholder">
-    <xsl:param name="id" />
-    <xsl:param name="name" />
-
-    <div id="{$id}" class="logStreamEmbed">
-      <xsl:call-template name="embed-attachment-placeholder-text">
-        <xsl:with-param name="name" select="$name" />
-      </xsl:call-template>
-    </div>
-  </xsl:template>
-
-  <xsl:template name="embed-attachment-placeholder-text">
-    <xsl:param name="name" />
-
-    <xsl:text>Attachment: </xsl:text><xsl:value-of select="$name" /><xsl:text> (n/a)</xsl:text>
-  </xsl:template>
-  
-  <xsl:template name="embed-attachment-link">
-    <xsl:param name="id" />
-    <xsl:param name="name" />
-    <xsl:param name="uri" />
-
-    <div id="{$id}" class="logStreamEmbed">
-      <xsl:call-template name="embed-attachment-link-text">
-        <xsl:with-param name="name" select="$name" />
-        <xsl:with-param name="uri" select="$uri" />
-      </xsl:call-template>
-    </div>
-  </xsl:template>
-
-  <xsl:template name="embed-attachment-link-text">
-    <xsl:param name="name" />
-    <xsl:param name="uri" />
-
-    <xsl:text>Attachment: </xsl:text><a href="{$uri}" class="attachmentLink"><xsl:value-of select="$name" /></a>
-  </xsl:template>
-  
-  <xsl:template name="embed-attachment-image-from-uri">
-    <xsl:param name="id" />
-    <xsl:param name="name" />
-    <xsl:param name="uri" />
-
-    <div id="{$id}" class="logStreamEmbed">
-      <a href="{$uri}" class="attachmentLink">
-        <img class="embeddedImage" src="{$uri}" alt="Attachment: {$name}" />
-      </a>
-    </div>
-  </xsl:template>
-  
-  <xsl:template name="embed-attachment-html-from-uri">
-    <xsl:param name="id" />
-    <xsl:param name="name" />
-    <xsl:param name="uri" />
-
-    <div id="{$id}" class="logStreamEmbed" title="{$name}">
-      <xsl:call-template name="embed-attachment-link-text">
-        <xsl:with-param name="name" select="$name" />
-        <xsl:with-param name="uri" select="$uri" />
-      </xsl:call-template>
-    </div>
-    <script type="text/javascript">setInnerHTMLFromUri('<xsl:value-of select="$id"/>', '<xsl:value-of select="$uri"/>');</script>
-  </xsl:template>
-
-  <xsl:template name="embed-attachment-text-from-uri">
-    <xsl:param name="id" />
-    <xsl:param name="name" />
-    <xsl:param name="uri" />
-
-    <div id="{$id}" class="logStreamEmbed" title="{$name}">
-      <xsl:call-template name="embed-attachment-link-text">
-        <xsl:with-param name="name" select="$name" />
-        <xsl:with-param name="uri" select="$uri" />
-      </xsl:call-template>
-    </div>
-    <script type="text/javascript">setPreformattedTextFromUri('<xsl:value-of select="$id"/>', '<xsl:value-of select="$uri"/>');</script>
-  </xsl:template>
-
-  <xsl:template name="embed-attachment-flashvideo-from-uri">
-    <xsl:param name="id" />
-    <xsl:param name="name" />
-    <xsl:param name="uri" />
-
-    <div id="{$id}" class="logStreamEmbed" title="{$name}">
-      <div id="{$id}-placeholder">
-        <xsl:call-template name="embed-attachment-link-text">
-          <xsl:with-param name="name" select="$name" />
-          <xsl:with-param name="uri" select="$uri" />
-        </xsl:call-template>
-      </div>
-    </div>
-
-    <script type="text/javascript">
-      <xsl:text>swfobject.embedSWF('</xsl:text>
-      <xsl:value-of select="$jsDir"/>
-      <xsl:text>player.swf', '</xsl:text>
-      <xsl:value-of select="$id"/>
-      <xsl:text>-placeholder', '400', '300', '9.0.98', '</xsl:text>
-      <xsl:value-of select="$jsDir"/>
-      <xsl:text>expressInstall.swf', {file: </xsl:text>
-      <xsl:choose>
-        <!-- When using a broker, the uri is absolute. -->
-        <xsl:when test="$attachmentBrokerUrl != ''">
-          <xsl:text>'</xsl:text>
-          <xsl:value-of select="$uri" />
-          <xsl:text>'</xsl:text>
-        </xsl:when>
-        <!-- Otherwise, the uri needs to be made relative to the player location. -->
-        <xsl:otherwise>
-          <xsl:text>'../../</xsl:text>
-          <xsl:value-of select="$uri" />
-          <xsl:text>'</xsl:text>
-        </xsl:otherwise>
-      </xsl:choose>
-      <xsl:text>}, {allowfullscreen: 'true', allowscriptaccess: 'always'}, {id: '</xsl:text>
-      <xsl:value-of select="$id"/>
-      <xsl:text>-player'})</xsl:text>
-    </script>
-  </xsl:template>
-
-  <xsl:template name="embed-attachment-image-from-content">
-    <xsl:param name="id" />
-    <xsl:param name="name" />
-    <xsl:param name="content" />
-    <xsl:param name="contentType" />
-
-    <div id="{$id}" class="logStreamEmbed">
-      <img class="embeddedImage" src="data:{$contentType};base64,{$content}" alt="Attachment: {$name}" />
-    </div>
-  </xsl:template>
-
-  <xsl:template name="embed-attachment-html-from-content">
-    <xsl:param name="id" />
-    <xsl:param name="name" />
-    <xsl:param name="content" />
-    
-    <div id="{$id}" class="logStreamEmbed" title="{$name}">
-      <xsl:call-template name="embed-attachment-placeholder-text">
-        <xsl:with-param name="name" select="$name" />
-      </xsl:call-template>
-      <div id="{$id}-hidden" class="logHiddenData"><xsl:value-of select="$content"/></div>
-    </div>
-    <script type="text/javascript">setInnerHTMLFromHiddenData('<xsl:value-of select="$id"/>');</script>
-  </xsl:template>
-
-  <xsl:template name="embed-attachment-text-from-content">
-    <xsl:param name="id" />
-    <xsl:param name="name" />
-    <xsl:param name="content" />
-
-    <div id="{$id}" class="logStreamEmbed" title="{$name}">
-      <xsl:call-template name="embed-attachment-placeholder-text">
-        <xsl:with-param name="name" select="$name" />
-      </xsl:call-template>
-      <div id="{$id}-hidden" class="logHiddenData"><xsl:value-of select="$content"/></div>
-    </div>
-    <script type="text/javascript">setPreformattedTextFromHiddenData('<xsl:value-of select="$id"/>');</script>
-  </xsl:template>
-
-  <xsl:template name="icon">
-    <xsl:param name="kind" />
-
-    <xsl:choose>
-      <xsl:when test="$kind">
-        <span class="testKind testKind-{translate($kind, ' .', '')}" />
-      </xsl:when>
-      <xsl:otherwise>
-        <span class="testKind" />
-      </xsl:otherwise>
-    </xsl:choose>
-  </xsl:template>
-
-  <!-- Toggle buttons -->
-  <xsl:template name="toggle">
-    <xsl:param name="href" />
-    
-    <img src="{$imgDir}Minus.gif" class="toggle" id="toggle-{$href}" onclick="toggle('{$href}');" alt="Toggle Button" />
-  </xsl:template>
-  
-  <xsl:template name="toggle-stop">
-    <img src="{$imgDir}FullStop.gif" class="toggle" alt="Toggle Placeholder" />
-  </xsl:template>
-  
-  <xsl:template name="toggle-autoclose">
-    <xsl:param name="href" />
-    
-    <!-- Auto-close certain toggles by default when JavaScript is available -->
-    <script type="text/javascript">toggle('<xsl:value-of select="$href"/>');</script>
-  </xsl:template>
-  
-  <!-- Displays visual statistics using a status bar and outcome icons -->
-  <xsl:template name="outcome-bar">
-    <xsl:param name="outcome" />
-    <xsl:param name="statistics"/>
-    <xsl:param name="small" select="0" />
-
-    <table class="outcome-bar">
-      <tr>
-        <td>
-          <div>
-            <xsl:attribute name="class">outcome-bar status-<xsl:value-of select="$outcome/@status"/><xsl:if test="$small"> condensed</xsl:if></xsl:attribute>
-            <xsl:attribute name="title">
-              <xsl:choose>
-                <xsl:when test="$outcome/@category"><xsl:value-of select="$outcome/@category"/></xsl:when>
-                <xsl:otherwise><xsl:value-of select="$outcome/@status"/></xsl:otherwise>
-              </xsl:choose>
-            </xsl:attribute>
-          </div>
-        </td>
-      </tr>
-    </table>
-    
-    <xsl:if test="not($small)">
-      <span class="outcome-icons">
-        <img src="{$imgDir}Passed.gif" alt="Passed"/>
-        <xsl:value-of select="$statistics/@passedCount"/>
-        <img src="{$imgDir}Failed.gif" alt="Failed"/>
-        <xsl:value-of select="$statistics/@failedCount"/>
-        <img src="{$imgDir}Ignored.gif" alt="Inconclusive or Skipped"/>
-        <xsl:value-of select="$statistics/@inconclusiveCount + $statistics/@skippedCount" />            
-      </span>
-    </xsl:if>
-  </xsl:template>
-  
-  <xsl:template name="status-from-statistics">
-    <xsl:param name="statistics"/>
-    
-    <xsl:choose>
-      <xsl:when test="$statistics/@failedCount > 0">status-failed</xsl:when>
-      <xsl:when test="$statistics/@inconclusiveCount > 0">status-inconclusive</xsl:when>
-      <xsl:when test="$statistics/@passedCount > 0">status-passed</xsl:when>
-      <xsl:otherwise>status-skipped</xsl:otherwise>
-    </xsl:choose>
-  </xsl:template>
-
-  <xsl:template name="code-location-link">
-    <xsl:param name="path" />
-    <xsl:param name="line" />
-    <xsl:param name="column" />
-    <xsl:param name="content" />
-
-    <xsl:choose>
-      <xsl:when test="$path and $line > 0 and $column > 0">
-        <a class="crossref" href="gallio:navigateTo?path={$path}&amp;line={$line}&amp;column={$column}"><xsl:value-of select="$content"/></a>
-      </xsl:when>
-      <xsl:when test="$path and $line > 0">
-        <a class="crossref" href="gallio:navigateTo?path={$path}&amp;line={$line}"><xsl:value-of select="$content"/></a>
-      </xsl:when>
-      <xsl:when test="$path">
-        <a class="crossref" href="gallio:navigateTo?path={$path}"><xsl:value-of select="$content"/></a>
-      </xsl:when>
-      <xsl:otherwise>
-        <xsl:value-of select="$content"/>
-      </xsl:otherwise>
-    </xsl:choose>
-  </xsl:template>
-
-  <xsl:template match="g:logEntries" mode="log">
-    <div id="Log" class="section">
-      <h2>Diagnostic Log</h2>
-      <div class="section-content">
-        <ul>
-          <xsl:apply-templates select="g:logEntry[@severity != 'debug']" mode="log" />
-        </ul>
-      </div>
-    </div>
-  </xsl:template>
-
-  <xsl:template match="g:logEntry" mode="log">
-    <li>
-      <xsl:attribute name="class">
-        logEntry logEntry-severity-<xsl:value-of select="@severity"/>
-      </xsl:attribute>
-      <div class="logEntry-text">
-        <xsl:text>[</xsl:text>
-        <xsl:value-of select="@severity"/>
-        <xsl:text>] </xsl:text>
-        <xsl:call-template name="print-text-with-breaks">
-          <xsl:with-param name="text" select="@message" />
-        </xsl:call-template>
-      </div>
-
-      <xsl:if test="@details">
-        <div class="logEntry-details">
-          <xsl:text>Details: </xsl:text>
-          <xsl:call-template name="print-text-with-breaks">
-            <xsl:with-param name="text" select="@details" />
-          </xsl:call-template>
-        </div>
-      </xsl:if>
-    </li>
-  </xsl:template>
-
-  <!-- Include the common report template -->
-  <xsl:include href="Gallio-Report.common.xsl" />  
-</xsl:stylesheet>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Resources/xsl/Gallio-Report.html-condensed.xsl
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Resources/xsl/Gallio-Report.html-condensed.xsl b/lib/Gallio.3.2.750/tools/Resources/xsl/Gallio-Report.html-condensed.xsl
deleted file mode 100644
index 7b3fc92..0000000
--- a/lib/Gallio.3.2.750/tools/Resources/xsl/Gallio-Report.html-condensed.xsl
+++ /dev/null
@@ -1,21 +0,0 @@
-<?xml version="1.0" encoding="iso-8859-1"?>
-<xsl:stylesheet version="1.0"
-                xmlns:xsl="http://www.w3.org/1999/XSL/Transform"
-                xmlns:g="http://www.gallio.org/">
-  <xsl:output method="html" doctype-system="http://www.w3.org/TR/html4/strict.dtd"
-              doctype-public="-//W3C//DTD HTML 4.01//EN" indent="no" encoding="utf-8" omit-xml-declaration="yes" />
-  <xsl:param name="resourceRoot" select="''" />
-
-  <xsl:variable name="cssDir"><xsl:if test="$resourceRoot != ''"><xsl:value-of select="$resourceRoot"/>/</xsl:if>css/</xsl:variable>
-  <xsl:variable name="jsDir"><xsl:if test="$resourceRoot != ''"><xsl:value-of select="$resourceRoot"/>/</xsl:if>js/</xsl:variable>
-  <xsl:variable name="imgDir"><xsl:if test="$resourceRoot != ''"><xsl:value-of select="$resourceRoot"/>/</xsl:if>img/</xsl:variable>
-  <xsl:variable name="attachmentBrokerUrl"></xsl:variable>
-  <xsl:variable name="condensed" select="1" />
-
-  <xsl:template match="/">
-    <xsl:apply-templates select="/g:report" mode="html-document" />
-  </xsl:template>
-  
-  <!-- Include the base HTML / XHTML report template -->
-  <xsl:include href="Gallio-Report.html+xhtml.xsl" />
-</xsl:stylesheet>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Resources/xsl/Gallio-Report.html.xsl
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Resources/xsl/Gallio-Report.html.xsl b/lib/Gallio.3.2.750/tools/Resources/xsl/Gallio-Report.html.xsl
deleted file mode 100644
index 8276d02..0000000
--- a/lib/Gallio.3.2.750/tools/Resources/xsl/Gallio-Report.html.xsl
+++ /dev/null
@@ -1,21 +0,0 @@
-<?xml version="1.0" encoding="iso-8859-1"?>
-<xsl:stylesheet version="1.0"
-                xmlns:xsl="http://www.w3.org/1999/XSL/Transform"
-                xmlns:g="http://www.gallio.org/">
-  <xsl:output method="html" doctype-system="http://www.w3.org/TR/html4/strict.dtd"
-              doctype-public="-//W3C//DTD HTML 4.01//EN" indent="no" encoding="utf-8" omit-xml-declaration="yes" />
-  <xsl:param name="resourceRoot" select="''" />
-
-  <xsl:variable name="cssDir"><xsl:if test="$resourceRoot != ''"><xsl:value-of select="$resourceRoot"/>/</xsl:if>css/</xsl:variable>
-  <xsl:variable name="jsDir"><xsl:if test="$resourceRoot != ''"><xsl:value-of select="$resourceRoot"/>/</xsl:if>js/</xsl:variable>
-  <xsl:variable name="imgDir"><xsl:if test="$resourceRoot != ''"><xsl:value-of select="$resourceRoot"/>/</xsl:if>img/</xsl:variable>
-  <xsl:variable name="attachmentBrokerUrl"></xsl:variable>
-  <xsl:variable name="condensed" select="0" />
-
-  <xsl:template match="/">
-    <xsl:apply-templates select="/g:report" mode="html-document" />
-  </xsl:template>
-  
-  <!-- Include the base HTML / XHTML report template -->
-  <xsl:include href="Gallio-Report.html+xhtml.xsl" />
-</xsl:stylesheet>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Resources/xsl/Gallio-Report.txt-common.xsl
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Resources/xsl/Gallio-Report.txt-common.xsl b/lib/Gallio.3.2.750/tools/Resources/xsl/Gallio-Report.txt-common.xsl
deleted file mode 100644
index bd92cd5..0000000
--- a/lib/Gallio.3.2.750/tools/Resources/xsl/Gallio-Report.txt-common.xsl
+++ /dev/null
@@ -1,228 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<xsl:stylesheet version="1.0" xmlns:xsl="http://www.w3.org/1999/XSL/Transform"
-                xmlns:msxsl="urn:schemas-microsoft-com:xslt"
-                xmlns:g="http://www.gallio.org/">
-
-  <xsl:output method="text" encoding="utf-8"/>
-
-  <xsl:param name="resourceRoot" select="''" />
-
-  <xsl:template match="/">
-    <xsl:apply-templates select="/g:report" />
-  </xsl:template>
-
-  <xsl:template match="g:report">
-    <xsl:apply-templates select="." mode="results"/>
-    <xsl:apply-templates select="." mode="annotations" />
-    <xsl:apply-templates select="." mode="log" />
-  </xsl:template>
-  
-  <!-- Results -->
-
-  <xsl:template match="g:report" mode="results">
-    <xsl:text>* Results: </xsl:text>
-    <xsl:call-template name="format-statistics">
-      <xsl:with-param name="statistics" select="g:testPackageRun/g:statistics" />
-    </xsl:call-template>
-		<xsl:text>&#xA;&#xA;</xsl:text>
-
-    <xsl:variable name="testCases" select="g:testPackageRun/g:testStepRun/descendant-or-self::g:testStepRun[g:testStep/@isTestCase='true']" />
-    
-    <xsl:variable name="passed" select="$testCases[g:result/g:outcome/@status='passed']" />
-    <xsl:variable name="failed" select="$testCases[g:result/g:outcome/@status='failed']" />
-    <xsl:variable name="inconclusive" select="$testCases[g:result/g:outcome/@status='inconclusive']" />
-    <xsl:variable name="skipped" select="$testCases[g:result/g:outcome/@status='skipped']" />
-
-    <xsl:if test="$show-failed-tests">
-      <xsl:apply-templates select="$failed" mode="results" />
-    </xsl:if>
-    
-    <xsl:if test="$show-inconclusive-tests">
-      <xsl:apply-templates select="$inconclusive" mode="results"/>
-    </xsl:if>
-
-    <xsl:if test="$show-passed-tests">
-      <xsl:apply-templates select="$passed" mode="results"/>
-    </xsl:if>
-
-    <xsl:if test="$show-skipped-tests">
-      <xsl:apply-templates select="$skipped" mode="results"/>
-    </xsl:if>
-
-    <xsl:text>&#xA;</xsl:text>
-  </xsl:template>
-  
-  <xsl:template match="g:testStepRun" mode="results">
-    <xsl:text>[</xsl:text>
-    <xsl:choose>
-      <xsl:when test="g:result/g:outcome/@category">
-        <xsl:value-of select="g:result/g:outcome/@category"/>
-      </xsl:when>
-      <xsl:otherwise>
-        <xsl:value-of select="g:result/g:outcome/@status"/>
-      </xsl:otherwise>
-    </xsl:choose>
-    <xsl:text>] </xsl:text>
-
-    <xsl:variable name="kind" select="g:testStep/g:metadata/g:entry[@key='TestKind']/g:value" />
-    <xsl:if test="$kind">
-      <xsl:value-of select="$kind"/>
-      <xsl:text> </xsl:text>
-    </xsl:if>
-
-    <xsl:value-of select="g:testStep/@fullName" />
-    <xsl:text>&#xA;</xsl:text>
-    <xsl:apply-templates select="g:testLog" mode="results"/>
-    <xsl:text>&#xA;</xsl:text>
-
-    <xsl:apply-templates select="g:children/g:testStepRun" mode="results"/>
-  </xsl:template>
-
-  <xsl:template match="g:testLog" mode="results">
-    <xsl:apply-templates select="g:streams/g:stream/g:body"/>
-  </xsl:template>
-
-  <xsl:template match="g:body">
-    <xsl:apply-templates select="g:contents" mode="block" />
-  </xsl:template>
-
-  <xsl:template match="g:contents" mode="block">
-    <xsl:variable name="text">
-      <xsl:apply-templates select="." mode="inline" />
-    </xsl:variable>
-    
-    <xsl:call-template name="indent">
-      <xsl:with-param name="text" select="$text"/>
-    </xsl:call-template>
-  </xsl:template>
-
-  <xsl:template match="g:contents" mode="inline">
-    <xsl:apply-templates select="child::node()[self::g:text or self::g:section or self::g:embed or self::g:marker]" />
-  </xsl:template>
-
-  <xsl:template match="g:text">
-    <xsl:value-of select="text()"/>
-  </xsl:template>
-
-  <xsl:template match="g:section">
-    <xsl:text>&#xA;</xsl:text>
-    <xsl:value-of select="@name" />
-    <xsl:text>&#xA;</xsl:text>
-    <xsl:apply-templates select="g:contents" mode="block" />
-  </xsl:template>
-
-  <xsl:template match="g:marker">
-    <xsl:apply-templates select="g:contents" mode="inline" />
-  </xsl:template>
-
-  <xsl:template match="g:embed">
-    <xsl:text>&#xA;[Attachment: </xsl:text>
-    <xsl:value-of select="@attachmentName"/>
-    <xsl:text>]&#xA;</xsl:text>
-  </xsl:template>
-
-  <!-- Annotations -->
-  
-  <xsl:template match="g:report" mode="annotations">
-    <xsl:variable name="annotations" select="g:testModel/g:annotations/g:annotation" />
-    
-    <xsl:if test="$annotations">
-      <xsl:text>* Annotations:&#xA;&#xA;</xsl:text>
-      <xsl:apply-templates select="$annotations[@type='error']"/>
-      <xsl:apply-templates select="$annotations[@type='warning']"/>
-      <xsl:apply-templates select="$annotations[@type='info']"/>
-      <xsl:text>&#xA;</xsl:text>
-    </xsl:if>
-  </xsl:template>
-
-  <xsl:template match="g:annotation">
-    <xsl:call-template name="indent">
-      <xsl:with-param name="text">
-        <xsl:text>[</xsl:text>
-        <xsl:value-of select="@type"/>
-        <xsl:text>] </xsl:text>
-        <xsl:value-of select="@message"/>
-      </xsl:with-param>
-      <xsl:with-param name="firstLinePrefix" select="''" />
-    </xsl:call-template>
-
-    <xsl:if test="g:codeLocation/@path">
-      <xsl:call-template name="indent">
-        <xsl:with-param name="text">
-          <xsl:text>Location: </xsl:text>
-          <xsl:call-template name="format-code-location">
-            <xsl:with-param name="codeLocation" select="g:codeLocation" />
-          </xsl:call-template>
-        </xsl:with-param>
-        <xsl:with-param name="secondLinePrefix" select="'    '" />
-      </xsl:call-template>
-    </xsl:if>
-
-    <xsl:if test="g:codeReference/@assembly">
-      <xsl:call-template name="indent">
-        <xsl:with-param name="text">
-          <xsl:text>Reference: </xsl:text>
-          <xsl:call-template name="format-code-reference">
-            <xsl:with-param name="codeReference" select="g:codeReference" />
-          </xsl:call-template>
-        </xsl:with-param>
-        <xsl:with-param name="secondLinePrefix" select="'    '" />
-      </xsl:call-template>
-    </xsl:if>
-
-    <xsl:if test="@details">
-      <xsl:call-template name="indent">
-        <xsl:with-param name="text">
-          <xsl:text>Details: </xsl:text>
-          <xsl:value-of select="@details"/>
-        </xsl:with-param>
-        <xsl:with-param name="secondLinePrefix" select="'    '" />
-      </xsl:call-template>
-    </xsl:if>
-
-    <xsl:text>&#xA;</xsl:text>
-  </xsl:template>
-
-  <!-- Log -->
-  
-  <xsl:template match="g:report" mode="log">
-    <xsl:variable name="logEntries" select="g:logEntries/g:logEntry[@severity != 'debug']"/>
-    
-    <xsl:if test="$logEntries">
-      <xsl:text>* Diagnostic Log:&#xA;&#xA;</xsl:text>
-      <xsl:apply-templates select="$logEntries"/>
-      <xsl:text>&#xA;</xsl:text>
-    </xsl:if>
-  </xsl:template>
-
-  <xsl:template match="g:logEntry">
-    <xsl:call-template name="indent">
-      <xsl:with-param name="text">
-        <xsl:text>[</xsl:text>
-        <xsl:value-of select="@severity"/>
-        <xsl:text>] </xsl:text>
-        <xsl:value-of select="@message"/>
-      </xsl:with-param>
-      <xsl:with-param name="firstLinePrefix" select="''" />
-    </xsl:call-template>
-
-    <xsl:if test="@details">
-      <xsl:call-template name="indent">
-        <xsl:with-param name="text">
-          <xsl:value-of select="@details"/>
-        </xsl:with-param>
-        <xsl:with-param name="secondLinePrefix" select="'    '" />
-      </xsl:call-template>
-    </xsl:if>
-
-    <xsl:text>&#xA;</xsl:text>
-  </xsl:template>
-  
-  <!-- -->
-
-  <xsl:template match="*">
-  </xsl:template>
-  
-  <!-- Include the common report template -->
-  <xsl:include href="Gallio-Report.common.xsl" />  
-</xsl:stylesheet>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Resources/xsl/Gallio-Report.txt-condensed.xsl
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Resources/xsl/Gallio-Report.txt-condensed.xsl b/lib/Gallio.3.2.750/tools/Resources/xsl/Gallio-Report.txt-condensed.xsl
deleted file mode 100644
index 264da71..0000000
--- a/lib/Gallio.3.2.750/tools/Resources/xsl/Gallio-Report.txt-condensed.xsl
+++ /dev/null
@@ -1,12 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<xsl:stylesheet version="1.0" xmlns:xsl="http://www.w3.org/1999/XSL/Transform"
-                xmlns:msxsl="urn:schemas-microsoft-com:xslt"
-                xmlns:g="http://www.gallio.org/">
-  
-  <xsl:param name="show-passed-tests" select="false()" />
-  <xsl:param name="show-failed-tests" select="true()" />
-  <xsl:param name="show-inconclusive-tests" select="true()" />
-  <xsl:param name="show-skipped-tests" select="true()" />
-
-  <xsl:include href="Gallio-Report.txt-common.xsl" />
-</xsl:stylesheet>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Resources/xsl/Gallio-Report.txt.xsl
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Resources/xsl/Gallio-Report.txt.xsl b/lib/Gallio.3.2.750/tools/Resources/xsl/Gallio-Report.txt.xsl
deleted file mode 100644
index 01b18b2..0000000
--- a/lib/Gallio.3.2.750/tools/Resources/xsl/Gallio-Report.txt.xsl
+++ /dev/null
@@ -1,12 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<xsl:stylesheet version="1.0" xmlns:xsl="http://www.w3.org/1999/XSL/Transform"
-                xmlns:msxsl="urn:schemas-microsoft-com:xslt"
-                xmlns:g="http://www.gallio.org/">
-
-  <xsl:param name="show-passed-tests" select="true()" />
-  <xsl:param name="show-failed-tests" select="true()" />
-  <xsl:param name="show-inconclusive-tests" select="true()" />
-  <xsl:param name="show-skipped-tests" select="true()" />
-  
-  <xsl:include href="Gallio-Report.txt-common.xsl" />
-</xsl:stylesheet>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Resources/xsl/Gallio-Report.xhtml-condensed.xsl
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Resources/xsl/Gallio-Report.xhtml-condensed.xsl b/lib/Gallio.3.2.750/tools/Resources/xsl/Gallio-Report.xhtml-condensed.xsl
deleted file mode 100644
index 287ec84..0000000
--- a/lib/Gallio.3.2.750/tools/Resources/xsl/Gallio-Report.xhtml-condensed.xsl
+++ /dev/null
@@ -1,22 +0,0 @@
-<?xml version="1.0" encoding="iso-8859-1"?>
-<xsl:stylesheet version="1.0"
-                xmlns:xsl="http://www.w3.org/1999/XSL/Transform"
-                xmlns:g="http://www.gallio.org/"
-                xmlns="http://www.w3.org/1999/xhtml">
-  <xsl:output method="xml" doctype-system="http://www.w3.org/TR/xhtml1/DTD/xhtml1-strict.dtd"
-              doctype-public="-//W3C//DTD XHTML 1.0 Strict//EN" indent="no" encoding="utf-8" />
-  <xsl:param name="resourceRoot" select="''" />
-  
-  <xsl:variable name="cssDir"><xsl:if test="$resourceRoot != ''"><xsl:value-of select="$resourceRoot"/>/</xsl:if>css/</xsl:variable>
-  <xsl:variable name="jsDir"><xsl:if test="$resourceRoot != ''"><xsl:value-of select="$resourceRoot"/>/</xsl:if>js/</xsl:variable>
-  <xsl:variable name="imgDir"><xsl:if test="$resourceRoot != ''"><xsl:value-of select="$resourceRoot"/>/</xsl:if>img/</xsl:variable>
-  <xsl:variable name="attachmentBrokerUrl"></xsl:variable>
-  <xsl:variable name="condensed" select="1" />
-  
-  <xsl:template match="/">
-    <xsl:apply-templates select="/g:report" mode="xhtml-document" />
-  </xsl:template>
-  
-  <!-- Include the base HTML / XHTML report template -->
-  <xsl:include href="Gallio-Report.html+xhtml.xsl" />
-</xsl:stylesheet>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Resources/xsl/Gallio-Report.xhtml.xsl
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Resources/xsl/Gallio-Report.xhtml.xsl b/lib/Gallio.3.2.750/tools/Resources/xsl/Gallio-Report.xhtml.xsl
deleted file mode 100644
index 7616969..0000000
--- a/lib/Gallio.3.2.750/tools/Resources/xsl/Gallio-Report.xhtml.xsl
+++ /dev/null
@@ -1,22 +0,0 @@
-<?xml version="1.0" encoding="iso-8859-1"?>
-<xsl:stylesheet version="1.0"
-                xmlns:xsl="http://www.w3.org/1999/XSL/Transform"
-                xmlns:g="http://www.gallio.org/"
-                xmlns="http://www.w3.org/1999/xhtml">
-  <xsl:output method="xml" doctype-system="http://www.w3.org/TR/xhtml1/DTD/xhtml1-strict.dtd"
-              doctype-public="-//W3C//DTD XHTML 1.0 Strict//EN" indent="no" encoding="utf-8" />
-  <xsl:param name="resourceRoot" select="''" />
-  
-  <xsl:variable name="cssDir"><xsl:if test="$resourceRoot != ''"><xsl:value-of select="$resourceRoot"/>/</xsl:if>css/</xsl:variable>
-  <xsl:variable name="jsDir"><xsl:if test="$resourceRoot != ''"><xsl:value-of select="$resourceRoot"/>/</xsl:if>js/</xsl:variable>
-  <xsl:variable name="imgDir"><xsl:if test="$resourceRoot != ''"><xsl:value-of select="$resourceRoot"/>/</xsl:if>img/</xsl:variable>
-  <xsl:variable name="attachmentBrokerUrl"></xsl:variable>
-  <xsl:variable name="condensed" select="0" />
-  
-  <xsl:template match="/">
-    <xsl:apply-templates select="/g:report" mode="xhtml-document" />
-  </xsl:template>
-  
-  <!-- Include the base HTML / XHTML report template -->
-  <xsl:include href="Gallio-Report.html+xhtml.xsl" />
-</xsl:stylesheet>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/TDNet/Gallio.TDNetRunner.UI.dll
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/TDNet/Gallio.TDNetRunner.UI.dll b/lib/Gallio.3.2.750/tools/TDNet/Gallio.TDNetRunner.UI.dll
deleted file mode 100644
index 242d55b..0000000
Binary files a/lib/Gallio.3.2.750/tools/TDNet/Gallio.TDNetRunner.UI.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/TDNet/Gallio.TDNetRunner.UI.plugin
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/TDNet/Gallio.TDNetRunner.UI.plugin b/lib/Gallio.3.2.750/tools/TDNet/Gallio.TDNetRunner.UI.plugin
deleted file mode 100644
index c9d7529..0000000
--- a/lib/Gallio.3.2.750/tools/TDNet/Gallio.TDNetRunner.UI.plugin
+++ /dev/null
@@ -1,57 +0,0 @@
-<?xml version="1.0" encoding="utf-8" ?>
-<plugin pluginId="Gallio.TDNetRunner.UI"
-        recommendedInstallationPath="TDNet"
-        xmlns="http://www.gallio.org/">
-  <traits>
-    <name>TestDriven.Net Runner UI</name>
-    <version>3.2.0.0</version>
-    <description>TestDriven.Net runner UI components.</description>
-    <icon>plugin://Gallio.TDNetRunner/Resources/TestDriven.ico</icon>
-  </traits>
-
-  <dependencies>
-    <dependency pluginId="Gallio" />
-    <dependency pluginId="Gallio.UI" />
-    <dependency pluginId="Gallio.TDNetRunner" />
-  </dependencies>
-
-  <files>
-    <file path="Gallio.TDNetRunner.UI.plugin" />
-    <file path="Gallio.TDNetRunner.UI.dll" />
-  </files>
-
-  <assemblies>
-    <assembly fullName="Gallio.TDNetRunner.UI, Version=3.2.0.0, Culture=neutral, PublicKeyToken=eb9cfa67ee6ab36e"
-              codeBase="Gallio.TDNetRunner.UI.dll"
-              qualifyPartialName="true" />
-  </assemblies>
-
-  <components>
-    <component componentId="TDNetRunner.UI.PlaceholderPreferencePaneProvider"
-                serviceId="Gallio.UI.PreferencePaneProvider">
-      <traits>
-        <path>TestDriven.Net</path>
-        <icon>plugin://Gallio.TDNetRunner/Resources/TestDriven.ico</icon>
-      </traits>
-    </component>
-
-    <component componentId="TDNetRunner.UI.RunnerInstallationPreferencePaneProvider"
-                serviceId="Gallio.UI.PreferencePaneProvider"
-                componentType="Gallio.TDNetRunner.UI.Preferences.TDNetRunnerInstallationPreferencePaneProvider, Gallio.TDNetRunner.UI">
-      <traits>
-        <path>TestDriven.Net/Frameworks</path>
-        <icon>plugin://Gallio.TDNetRunner/Resources/TestDriven.ico</icon>
-        <scope>Machine</scope>
-      </traits>
-    </component>
-
-    <component componentId="TDNetRunner.UI.RunnerReportPreferencePaneProvider"
-              serviceId="Gallio.UI.PreferencePaneProvider"
-              componentType="Gallio.TDNetRunner.UI.Preferences.TDNetRunnerReportPreferencePaneProvider, Gallio.TDNetRunner.UI">
-      <traits>
-        <path>TestDriven.Net/Reports</path>
-        <icon>plugin://Gallio.TDNetRunner/Resources/TestDriven.ico</icon>
-      </traits>
-    </component>
-  </components>
-</plugin>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/TDNet/Gallio.TDNetRunner.dll
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/TDNet/Gallio.TDNetRunner.dll b/lib/Gallio.3.2.750/tools/TDNet/Gallio.TDNetRunner.dll
deleted file mode 100644
index bdcfca2..0000000
Binary files a/lib/Gallio.3.2.750/tools/TDNet/Gallio.TDNetRunner.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/TDNet/Gallio.TDNetRunner.plugin
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/TDNet/Gallio.TDNetRunner.plugin b/lib/Gallio.3.2.750/tools/TDNet/Gallio.TDNetRunner.plugin
deleted file mode 100644
index ec61ed3..0000000
--- a/lib/Gallio.3.2.750/tools/TDNet/Gallio.TDNetRunner.plugin
+++ /dev/null
@@ -1,46 +0,0 @@
-<?xml version="1.0" encoding="utf-8" ?>
-<plugin pluginId="Gallio.TDNetRunner"
-        recommendedInstallationPath="TDNet"
-        xmlns="http://www.gallio.org/">
-  <traits>
-    <name>TestDriven.Net Runner</name>
-    <version>3.2.0.0</version>
-    <description>Enables TestDriven.Net to run tests using Gallio.</description>
-    <icon>plugin://Gallio.TDNetRunner/Resources/TestDriven.ico</icon>
-  </traits>
-
-  <dependencies>
-    <dependency pluginId="Gallio" />
-  </dependencies>
-
-  <files>
-    <file path="Gallio.TDNetRunner.plugin" />
-    <file path="Gallio.TDNetRunner.dll" />
-    <file path="Resources\TestDriven.ico" />
-  </files>
-
-  <assemblies>
-    <assembly fullName="Gallio.TDNetRunner, Version=3.2.0.0, Culture=neutral, PublicKeyToken=eb9cfa67ee6ab36e"
-              codeBase="Gallio.TDNetRunner.dll"
-              qualifyPartialName="true" />
-  </assemblies>
-
-  <services>
-    <service serviceId="TDNetRunner.PreferenceManager"
-             serviceType="Gallio.TDNetRunner.Core.TDNetPreferenceManager, Gallio.TDNetRunner" />
-  </services>
-  
-  <components>
-    <component componentId="TDNetRunner.Installer"
-               serviceId="Gallio.Installer"
-               componentType="Gallio.TDNetRunner.Core.TDNetRunnerInstaller, Gallio.TDNetRunner">
-      <traits>
-        <requiresElevation>true</requiresElevation>
-      </traits>
-    </component>
-    
-    <component componentId="TDNetRunner.PreferenceManager"
-               serviceId="TDNetRunner.PreferenceManager"
-               componentType="Gallio.TDNetRunner.Core.TDNetPreferenceManager, Gallio.TDNetRunner" />      
-  </components>
-</plugin>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/TDNet/Resources/TestDriven.ico
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/TDNet/Resources/TestDriven.ico b/lib/Gallio.3.2.750/tools/TDNet/Resources/TestDriven.ico
deleted file mode 100644
index 5881f91..0000000
Binary files a/lib/Gallio.3.2.750/tools/TDNet/Resources/TestDriven.ico and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/VisualStudio/Gallio.VisualStudio.Shell.dll
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/VisualStudio/Gallio.VisualStudio.Shell.dll b/lib/Gallio.3.2.750/tools/VisualStudio/Gallio.VisualStudio.Shell.dll
deleted file mode 100644
index 8849f60..0000000
Binary files a/lib/Gallio.3.2.750/tools/VisualStudio/Gallio.VisualStudio.Shell.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/VisualStudio/Gallio.VisualStudio.Shell.plugin
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/VisualStudio/Gallio.VisualStudio.Shell.plugin b/lib/Gallio.3.2.750/tools/VisualStudio/Gallio.VisualStudio.Shell.plugin
deleted file mode 100644
index c559524..0000000
--- a/lib/Gallio.3.2.750/tools/VisualStudio/Gallio.VisualStudio.Shell.plugin
+++ /dev/null
@@ -1,43 +0,0 @@
-<?xml version="1.0" encoding="utf-8" ?>
-<plugin pluginId="Gallio.VisualStudio.Shell"
-        recommendedInstallationPath="VisualStudio"
-        enableCondition="${process:DEVENV.EXE} or ${process:VSTESTHOST.EXE} or ${process:QTAGENT.EXE} or ${process:QTAGENT32.EXE} or ${process:QTDCAGENT.EXE} or ${process:QTDCAGENT32.EXE} or ${process:MSTEST.EXE} or ${minFramework:NET35}"
-        xmlns="http://www.gallio.org/">
-  <traits>
-    <name>Visual Studio Integration Shell</name>
-    <version>3.2.0.0</version>
-    <description>Provides a framework for hosting Gallio plugins within Visual Studio.</description>
-  </traits>
-
-  <dependencies>
-    <dependency pluginId="Gallio" />
-  </dependencies>
-
-  <files>
-    <file path="Gallio.VisualStudio.Shell.plugin" />
-    <file path="Gallio.VisualStudio.Shell.dll" />
-  </files>
-
-  <assemblies>
-    <assembly fullName="Gallio.VisualStudio.Shell, Version=3.2.0.0, Culture=neutral, PublicKeyToken=eb9cfa67ee6ab36e"
-              codeBase="Gallio.VisualStudio.Shell.dll"
-              qualifyPartialName="true" />
-  </assemblies>
-
-  <services>
-    <service serviceId="Shell.Shell"
-             serviceType="Gallio.VisualStudio.Shell.Core.IShell, Gallio.VisualStudio.Shell" />
-
-    <service serviceId="Shell.ShellExtension"
-             serviceType="Gallio.VisualStudio.Shell.Core.IShellExtension, Gallio.VisualStudio.Shell" />
-
-    <service serviceId="Shell.CommandManager"
-             serviceType="Gallio.VisualStudio.Shell.UI.Commands.ICommandManager, Gallio.VisualStudio.Shell" />
-
-    <service serviceId="Shell.Command"
-             serviceType="Gallio.VisualStudio.Shell.UI.Commands.ICommand, Gallio.VisualStudio.Shell" />
-
-    <service serviceId="Shell.ToolWindowManager"
-             serviceType="Gallio.VisualStudio.Shell.UI.ToolWindows.IToolWindowManager, Gallio.VisualStudio.Shell" />
-  </services>
-</plugin>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/VisualStudio/v10.0/Gallio.VisualStudio.Shell100.addin
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/VisualStudio/v10.0/Gallio.VisualStudio.Shell100.addin b/lib/Gallio.3.2.750/tools/VisualStudio/v10.0/Gallio.VisualStudio.Shell100.addin
deleted file mode 100644
index c31c71a..0000000
--- a/lib/Gallio.3.2.750/tools/VisualStudio/v10.0/Gallio.VisualStudio.Shell100.addin
+++ /dev/null
@@ -1,16 +0,0 @@
-<?xml version="1.0" encoding="utf-8"?>
-<Extensibility xmlns="http://schemas.microsoft.com/AutomationExtensibility">
-  <HostApplication>
-    <Name>Microsoft Visual Studio</Name>
-    <Version>10.0</Version>
-  </HostApplication>
-  <Addin>
-    <FriendlyName>Gallio</FriendlyName>
-    <Description>Gallio integration for Visual Studio</Description>
-    <Assembly>Gallio.VisualStudio.Shell100.dll</Assembly>
-    <FullClassName>Gallio.VisualStudio.Shell.Core.ShellAddInHandler</FullClassName>
-    <LoadBehavior>1</LoadBehavior>
-    <CommandPreload>0</CommandPreload>
-    <CommandLineSafe>0</CommandLineSafe>
-  </Addin>
-</Extensibility>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/VisualStudio/v10.0/Gallio.VisualStudio.Shell100.dll
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/VisualStudio/v10.0/Gallio.VisualStudio.Shell100.dll b/lib/Gallio.3.2.750/tools/VisualStudio/v10.0/Gallio.VisualStudio.Shell100.dll
deleted file mode 100644
index 233ab1a..0000000
Binary files a/lib/Gallio.3.2.750/tools/VisualStudio/v10.0/Gallio.VisualStudio.Shell100.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/VisualStudio/v10.0/Gallio.VisualStudio.Shell100.plugin
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/VisualStudio/v10.0/Gallio.VisualStudio.Shell100.plugin b/lib/Gallio.3.2.750/tools/VisualStudio/v10.0/Gallio.VisualStudio.Shell100.plugin
deleted file mode 100644
index ec63d6e..0000000
--- a/lib/Gallio.3.2.750/tools/VisualStudio/v10.0/Gallio.VisualStudio.Shell100.plugin
+++ /dev/null
@@ -1,49 +0,0 @@
-<?xml version="1.0" encoding="utf-8" ?>
-<plugin pluginId="Gallio.VisualStudio.Shell100"
-        recommendedInstallationPath="VisualStudio\v10.0"
-        enableCondition="${process:DEVENV.EXE_V10.0} or ${process:VSTESTHOST.EXE_V10.0} or ${process:QTAGENT.EXE_V10.0} or ${process:QTAGENT32.EXE_V10.0} or ${process:QTDCAGENT.EXE_V10.0} or ${process:QTDCAGENT32.EXE_V10.0} or ${process:MSTEST.EXE_V10.0} or ${framework:NET40}"
-        xmlns="http://www.gallio.org/">
-  <traits>
-    <name>Visual Studio 2010 Integration Shell</name>
-    <version>3.2.0.0</version>
-    <description>Provides a framework for hosting Gallio plugins within Visual Studio 2010.</description>
-  </traits>
-
-  <dependencies>
-    <dependency pluginId="Gallio.VisualStudio.Shell" />
-  </dependencies>
-
-  <files>
-    <file path="Gallio.VisualStudio.Shell100.plugin" />
-    <file path="Gallio.VisualStudio.Shell100.dll" />
-    <file path="Gallio.VisualStudio.Shell100.addin" />
-  </files>
-  
-  <probingPaths>
-    <probingPath>v10.0</probingPath>
-  </probingPaths>
-  
-  <assemblies>
-    <assembly fullName="Gallio.VisualStudio.Shell100, Version=3.2.0.0, Culture=neutral, PublicKeyToken=eb9cfa67ee6ab36e"
-              codeBase="Gallio.VisualStudio.Shell100.dll"
-              qualifyPartialName="true" />
-  </assemblies>
-
-  <components>
-    <component componentId="Shell100.Shell"
-               serviceId="Shell.Shell"
-               componentType="Gallio.VisualStudio.Shell.Core.DefaultShell, Gallio.VisualStudio.Shell100" />
-
-    <component componentId="Shell100.CommandManager"
-               serviceId="Shell.CommandManager"
-               componentType="Gallio.VisualStudio.Shell.UI.Commands.DefaultCommandManager, Gallio.VisualStudio.Shell100" />
-
-    <component componentId="Shell100.CommandManagerShellExtension"
-               serviceId="Shell.ShellExtension"
-               componentType="Gallio.VisualStudio.Shell.UI.Commands.DefaultCommandManagerShellExtension, Gallio.VisualStudio.Shell100" />
-
-    <component componentId="Shell100.ToolWindowManager"
-               serviceId="Shell.ToolWindowManager"
-               componentType="Gallio.VisualStudio.Shell.UI.ToolWindows.DefaultToolWindowManager, Gallio.VisualStudio.Shell100" />
-  </components>
-</plugin>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/VisualStudio/v10.0/Gallio.VisualStudio.Tip100.Proxy.dll
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/VisualStudio/v10.0/Gallio.VisualStudio.Tip100.Proxy.dll b/lib/Gallio.3.2.750/tools/VisualStudio/v10.0/Gallio.VisualStudio.Tip100.Proxy.dll
deleted file mode 100644
index a95bc11..0000000
Binary files a/lib/Gallio.3.2.750/tools/VisualStudio/v10.0/Gallio.VisualStudio.Tip100.Proxy.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/VisualStudio/v10.0/Gallio.VisualStudio.Tip100.dll
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/VisualStudio/v10.0/Gallio.VisualStudio.Tip100.dll b/lib/Gallio.3.2.750/tools/VisualStudio/v10.0/Gallio.VisualStudio.Tip100.dll
deleted file mode 100644
index 5bea6b4..0000000
Binary files a/lib/Gallio.3.2.750/tools/VisualStudio/v10.0/Gallio.VisualStudio.Tip100.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/VisualStudio/v10.0/Gallio.VisualStudio.Tip100.plugin
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/VisualStudio/v10.0/Gallio.VisualStudio.Tip100.plugin b/lib/Gallio.3.2.750/tools/VisualStudio/v10.0/Gallio.VisualStudio.Tip100.plugin
deleted file mode 100644
index 8c60f26..0000000
--- a/lib/Gallio.3.2.750/tools/VisualStudio/v10.0/Gallio.VisualStudio.Tip100.plugin
+++ /dev/null
@@ -1,51 +0,0 @@
-<?xml version="1.0" encoding="utf-8" ?>
-<plugin pluginId="Gallio.VisualStudio.Tip100"
-        recommendedInstallationPath="VisualStudio\v10.0"
-        enableCondition="${process:DEVENV.EXE_V10.0} or ${process:VSTESTHOST.EXE_V10.0} or ${process:QTAGENT.EXE_V10.0} or ${process:QTAGENT32.EXE_V10.0} or ${process:QTDCAGENT.EXE_V10.0} or ${process:QTDCAGENT32.EXE_V10.0} or ${process:MSTEST.EXE_V10.0} or ${framework:NET40}"
-        xmlns="http://www.gallio.org/">
-  <traits>
-    <name>Visual Studio 2010 Test Runner</name>
-    <version>3.2.0.0</version>
-    <description>Enables Visual Studio 2010 to run Gallio tests via the Test View.</description>
-  </traits>
-
-  <dependencies>
-    <dependency pluginId="Gallio.VisualStudio.Shell100" />
-  </dependencies>
-
-  <files>
-    <file path="Gallio.VisualStudio.Tip100.plugin" />
-    <file path="Gallio.VisualStudio.Tip100.dll" />
-    
-    <!-- Installed in the GAC only.
-    <file path="Gallio.VisualStudio.Tip100.Proxy.dll" />
-    -->
-  </files>
-
-  <probingPaths>
-    <probingPath>v10.0</probingPath>
-  </probingPaths>
-  
-  <assemblies>
-    <assembly fullName="Gallio.VisualStudio.Tip100, Version=3.2.0.0, Culture=neutral, PublicKeyToken=eb9cfa67ee6ab36e"
-              codeBase="Gallio.VisualStudio.Tip100.dll"
-              qualifyPartialName="true" />
-    
-    <assembly fullName="Gallio.VisualStudio.Tip100.Proxy, Version=3.2.0.0, Culture=neutral, PublicKeyToken=eb9cfa67ee6ab36e" />
-  </assemblies>
-
-  <services>
-    <service serviceId="Tip100.ProxyHandler"
-             serviceType="Gallio.VisualStudio.Tip.IProxyHandler, Gallio.VisualStudio.Tip100.Proxy, Version=3.2.0.0, Culture=neutral, PublicKeyToken=eb9cfa67ee6ab36e, processorArchitecture=MSIL" />
-  </services>
-  
-  <components>
-    <component componentId="Tip100.ShellExtension"
-               serviceId="Shell.ShellExtension"
-               componentType="Gallio.VisualStudio.Tip.TipShellExtension, Gallio.VisualStudio.Tip100" />
-
-    <component componentId="Tip100.ProxyHandler"
-               serviceId="Tip100.ProxyHandler"
-               componentType="Gallio.VisualStudio.Tip.DefaultProxyHandler, Gallio.VisualStudio.Tip100" />
-  </components>
-</plugin>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/VisualStudio/v9.0/Gallio.VisualStudio.Shell90.addin
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/VisualStudio/v9.0/Gallio.VisualStudio.Shell90.addin b/lib/Gallio.3.2.750/tools/VisualStudio/v9.0/Gallio.VisualStudio.Shell90.addin
deleted file mode 100644
index 2ba973a..0000000
--- a/lib/Gallio.3.2.750/tools/VisualStudio/v9.0/Gallio.VisualStudio.Shell90.addin
+++ /dev/null
@@ -1,16 +0,0 @@
-<?xml version="1.0" encoding="utf-8"?>
-<Extensibility xmlns="http://schemas.microsoft.com/AutomationExtensibility">
-  <HostApplication>
-    <Name>Microsoft Visual Studio</Name>
-    <Version>9.0</Version>
-  </HostApplication>
-  <Addin>
-    <FriendlyName>Gallio</FriendlyName>
-    <Description>Gallio integration for Visual Studio</Description>
-    <Assembly>Gallio.VisualStudio.Shell90.dll</Assembly>
-    <FullClassName>Gallio.VisualStudio.Shell.Core.ShellAddInHandler</FullClassName>
-    <LoadBehavior>1</LoadBehavior>
-    <CommandPreload>0</CommandPreload>
-    <CommandLineSafe>0</CommandLineSafe>
-  </Addin>
-</Extensibility>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/VisualStudio/v9.0/Gallio.VisualStudio.Shell90.dll
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/VisualStudio/v9.0/Gallio.VisualStudio.Shell90.dll b/lib/Gallio.3.2.750/tools/VisualStudio/v9.0/Gallio.VisualStudio.Shell90.dll
deleted file mode 100644
index 779d237..0000000
Binary files a/lib/Gallio.3.2.750/tools/VisualStudio/v9.0/Gallio.VisualStudio.Shell90.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/VisualStudio/v9.0/Gallio.VisualStudio.Shell90.plugin
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/VisualStudio/v9.0/Gallio.VisualStudio.Shell90.plugin b/lib/Gallio.3.2.750/tools/VisualStudio/v9.0/Gallio.VisualStudio.Shell90.plugin
deleted file mode 100644
index 75e577e..0000000
--- a/lib/Gallio.3.2.750/tools/VisualStudio/v9.0/Gallio.VisualStudio.Shell90.plugin
+++ /dev/null
@@ -1,49 +0,0 @@
-<?xml version="1.0" encoding="utf-8" ?>
-<plugin pluginId="Gallio.VisualStudio.Shell90"
-        recommendedInstallationPath="VisualStudio\v9.0"
-        enableCondition="${process:DEVENV.EXE_V9.0} or ${process:VSTESTHOST.EXE_V9.0} or ${process:MSTEST.EXE_V9.0} or ${framework:NET35}"
-        xmlns="http://www.gallio.org/">
-  <traits>
-    <name>Visual Studio 2008 Integration Shell</name>
-    <version>3.2.0.0</version>
-    <description>Provides a framework for hosting Gallio plugins within Visual Studio 2008.</description>
-  </traits>
-
-  <dependencies>
-    <dependency pluginId="Gallio.VisualStudio.Shell" />
-  </dependencies>
-
-  <files>
-    <file path="Gallio.VisualStudio.Shell90.plugin" />
-    <file path="Gallio.VisualStudio.Shell90.dll" />
-    <file path="Gallio.VisualStudio.Shell90.addin" />
-  </files>
-
-  <probingPaths>
-    <probingPath>v9.0</probingPath>
-  </probingPaths>
-  
-  <assemblies>
-    <assembly fullName="Gallio.VisualStudio.Shell90, Version=3.2.0.0, Culture=neutral, PublicKeyToken=eb9cfa67ee6ab36e"
-              codeBase="Gallio.VisualStudio.Shell90.dll"
-              qualifyPartialName="true" />
-  </assemblies>
-
-  <components>
-    <component componentId="Shell90.Shell"
-               serviceId="Shell.Shell"
-               componentType="Gallio.VisualStudio.Shell.Core.DefaultShell, Gallio.VisualStudio.Shell90" />
-
-    <component componentId="Shell90.CommandManager"
-               serviceId="Shell.CommandManager"
-               componentType="Gallio.VisualStudio.Shell.UI.Commands.DefaultCommandManager, Gallio.VisualStudio.Shell90" />
-
-    <component componentId="Shell90.CommandManagerShellExtension"
-               serviceId="Shell.ShellExtension"
-               componentType="Gallio.VisualStudio.Shell.UI.Commands.DefaultCommandManagerShellExtension, Gallio.VisualStudio.Shell90" />
-
-    <component componentId="Shell90.ToolWindowManager"
-               serviceId="Shell.ToolWindowManager"
-               componentType="Gallio.VisualStudio.Shell.UI.ToolWindows.DefaultToolWindowManager, Gallio.VisualStudio.Shell90" />
-  </components>
-</plugin>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/VisualStudio/v9.0/Gallio.VisualStudio.Tip90.Proxy.dll
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/VisualStudio/v9.0/Gallio.VisualStudio.Tip90.Proxy.dll b/lib/Gallio.3.2.750/tools/VisualStudio/v9.0/Gallio.VisualStudio.Tip90.Proxy.dll
deleted file mode 100644
index 7a60a36..0000000
Binary files a/lib/Gallio.3.2.750/tools/VisualStudio/v9.0/Gallio.VisualStudio.Tip90.Proxy.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/VisualStudio/v9.0/Gallio.VisualStudio.Tip90.dll
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/VisualStudio/v9.0/Gallio.VisualStudio.Tip90.dll b/lib/Gallio.3.2.750/tools/VisualStudio/v9.0/Gallio.VisualStudio.Tip90.dll
deleted file mode 100644
index a575b91..0000000
Binary files a/lib/Gallio.3.2.750/tools/VisualStudio/v9.0/Gallio.VisualStudio.Tip90.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/VisualStudio/v9.0/Gallio.VisualStudio.Tip90.plugin
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/VisualStudio/v9.0/Gallio.VisualStudio.Tip90.plugin b/lib/Gallio.3.2.750/tools/VisualStudio/v9.0/Gallio.VisualStudio.Tip90.plugin
deleted file mode 100644
index c9a6b6a..0000000
--- a/lib/Gallio.3.2.750/tools/VisualStudio/v9.0/Gallio.VisualStudio.Tip90.plugin
+++ /dev/null
@@ -1,51 +0,0 @@
-<?xml version="1.0" encoding="utf-8" ?>
-<plugin pluginId="Gallio.VisualStudio.Tip90"
-        recommendedInstallationPath="VisualStudio\v9.0"
-        enableCondition="${process:DEVENV.EXE_V9.0} or ${process:VSTESTHOST.EXE_V9.0} or ${process:MSTEST.EXE_V9.0} or ${framework:NET35}"
-        xmlns="http://www.gallio.org/">
-  <traits>
-    <name>Visual Studio 2008 Test Runner</name>
-    <version>3.2.0.0</version>
-    <description>Enables Visual Studio 2008 to run Gallio tests via the Test View.</description>
-  </traits>
-
-  <dependencies>
-    <dependency pluginId="Gallio.VisualStudio.Shell90" />
-  </dependencies>
-
-  <files>
-    <file path="Gallio.VisualStudio.Tip90.plugin" />
-    <file path="Gallio.VisualStudio.Tip90.dll" />
-    
-    <!-- Installed in the GAC only.
-    <file path="Gallio.VisualStudio.Tip90.Proxy.dll" />
-    -->
-  </files>
-
-  <probingPaths>
-    <probingPath>v9.0</probingPath>
-  </probingPaths>
-  
-  <assemblies>
-    <assembly fullName="Gallio.VisualStudio.Tip90, Version=3.2.0.0, Culture=neutral, PublicKeyToken=eb9cfa67ee6ab36e"
-              codeBase="Gallio.VisualStudio.Tip90.dll"
-              qualifyPartialName="true" />
-
-    <assembly fullName="Gallio.VisualStudio.Tip90.Proxy, Version=3.2.0.0, Culture=neutral, PublicKeyToken=eb9cfa67ee6ab36e" />
-  </assemblies>
-
-  <services>
-    <service serviceId="Tip90.ProxyHandler"
-             serviceType="Gallio.VisualStudio.Tip.IProxyHandler, Gallio.VisualStudio.Tip90.Proxy, Version=3.2.0.0, Culture=neutral, PublicKeyToken=eb9cfa67ee6ab36e, processorArchitecture=MSIL" />
-  </services>
-
-  <components>
-    <component componentId="Tip90.ShellExtension"
-               serviceId="Shell.ShellExtension"
-               componentType="Gallio.VisualStudio.Tip.TipShellExtension, Gallio.VisualStudio.Tip90" />
-
-    <component componentId="Tip90.ProxyHandler"
-               serviceId="Tip90.ProxyHandler"
-               componentType="Gallio.VisualStudio.Tip.DefaultProxyHandler, Gallio.VisualStudio.Tip90" />
-  </components>
-</plugin>
\ No newline at end of file


[49/51] [abbrv] [partial] Cleaning up and getting ready to development towards v4.8

Posted by sy...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/CHANGES.txt
----------------------------------------------------------------------
diff --git a/CHANGES.txt b/CHANGES.txt
index c0daf5a..9b9b2d2 100644
--- a/CHANGES.txt
+++ b/CHANGES.txt
@@ -1,4009 +1,4012 @@
-=================== Release 3.0.3 2012-10-05 =====================
-
-Bug
-•[LUCENENET-54] - ArgumentOutOfRangeException caused by SF.Snowball.Ext.DanishStemmer
-•[LUCENENET-420] - String.StartsWith has culture in it.
-•[LUCENENET-423] - QueryParser differences between Java and .NET when parsing range queries involving dates
-•[LUCENENET-445] - Lucene.Net.Index.TestIndexWriter.TestFutureCommit() Fails
-•[LUCENENET-464] - The Lucene.Net.FastVectorHighligher.dll of the latest release 2.9.4 breaks any ASP.NET application
-•[LUCENENET-472] - Operator == on Parameter does not check for null arguments
-•[LUCENENET-473] - Fix linefeeds in more than 600 files
-•[LUCENENET-474] - Missing License Headers in trunk after 3.0.3 merge
-•[LUCENENET-475] - DanishStemmer doesn't work.
-•[LUCENENET-476] - ScoreDocs in TopDocs is ambiguos when using Visual Basic .Net
-•[LUCENENET-477] - NullReferenceException in ThreadLocal when Lucene.Net compiled for .Net 2.0
-•[LUCENENET-478] - Parts of QueryParser are outdated or weren't previously ported correctly
-•[LUCENENET-479] - QueryParser.SetEnablePositionIncrements(false) doesn't work
-•[LUCENENET-483] - Spatial Search skipping records when one location is close to origin, another one is away and radius is wider
-•[LUCENENET-484] - Some possibly major tests intermittently fail 
-•[LUCENENET-485] - IndexOutOfRangeException in FrenchStemmer
-•[LUCENENET-490] - QueryParser is culture-sensitive
-•[LUCENENET-493] - Make lucene.net culture insensitive (like the java version)
-•[LUCENENET-494] - Port error in FieldCacheRangeFilter
-•[LUCENENET-495] - Use of DateTime.Now causes huge amount of System.Globalization.DaylightTime object allocations
-•[LUCENENET-500] - Lucene fails to run in medium trust ASP.NET Application
-
-Improvement
-•[LUCENENET-179] - SnowballFilter speed improvment
-•[LUCENENET-407] - Signing the assembly
-•[LUCENENET-408] - Mark assembly as CLS compliant; make AlreadyClosedException serializable
-•[LUCENENET-466] - optimisation for the GermanStemmer.vb‏
-•[LUCENENET-504] - FastVectorHighlighter - support for prefix query
-•[LUCENENET-506] - FastVectorHighlighter should use Query.ExtractTerms as fallback
-
-New Feature
-•[LUCENENET-463] - Would like to be able to use a SimpleSpanFragmenter for extrcting whole sentances 
-•[LUCENENET-481] - Port Contrib.MemoryIndex
-
-Task
-•[LUCENENET-446] - Make Lucene.Net CLS Compliant
-•[LUCENENET-471] - Remove Package.html and Overview.html artifacts
-•[LUCENENET-480] - Investigate what needs to happen to make both .NET 3.5 and 4.0 builds possible
-•[LUCENENET-487] - Remove Obsolete Members, Fields that are marked as obsolete and to be removed in 3.0
-•[LUCENENET-503] - Update binary names
-
-Sub-task
-•[LUCENENET-468] - Implement the Dispose pattern properly in classes with Close
-•[LUCENENET-470] - Change Getxxx() and Setxxx() methods to .NET Properties
-
-
-=================== Release 2.9.4 =====================
-
-Bug fixes
-
- * LUCENENET-355  [LUCENE-2387]: Don't hang onto Fieldables from the last doc indexed,
-   in IndexWriter, nor the Reader in Tokenizer after close is
-   called. (digy) [Ruben Laguna, Uwe Schindler, Mike McCandless]
-
-
-Change Log Copied from Lucene 
-======================= Release 2.9.2 2010-02-26 =======================
-
-Bug fixes
-
- * LUCENE-2045: Fix silly FileNotFoundException hit if you enable
-   infoStream on IndexWriter and then add an empty document and commit
-   (Shai Erera via Mike McCandless)
-
- * LUCENE-2088: addAttribute() should only accept interfaces that
-   extend Attribute. (Shai Erera, Uwe Schindler)
-
- * LUCENE-2092: BooleanQuery was ignoring disableCoord in its hashCode
-   and equals methods, cause bad things to happen when caching
-   BooleanQueries.  (Chris Hostetter, Mike McCandless)
-
- * LUCENE-2095: Fixes: when two threads call IndexWriter.commit() at
-   the same time, it's possible for commit to return control back to
-   one of the threads before all changes are actually committed.
-   (Sanne Grinovero via Mike McCandless)
-
- * LUCENE-2166: Don't incorrectly keep warning about the same immense
-    term, when IndexWriter.infoStream is on.  (Mike McCandless)
-
- * LUCENE-2158: At high indexing rates, NRT reader could temporarily
-   lose deletions.  (Mike McCandless)
-  
- * LUCENE-2182: DEFAULT_ATTRIBUTE_FACTORY was failing to load
-   implementation class when interface was loaded by a different
-   class loader.  (Uwe Schindler, reported on java-user by Ahmed El-dawy)
-  
- * LUCENE-2257: Increase max number of unique terms in one segment to
-   termIndexInterval (default 128) * ~2.1 billion = ~274 billion.
-   (Tom Burton-West via Mike McCandless)
-
- * LUCENE-2260: Fixed AttributeSource to not hold a strong
-   reference to the Attribute/AttributeImpl classes which prevents
-   unloading of custom attributes loaded by other classloaders
-   (e.g. in Solr plugins).  (Uwe Schindler)
- 
- * LUCENE-1941: Fix Min/MaxPayloadFunction returns 0 when
-   only one payload is present.  (Erik Hatcher, Mike McCandless
-   via Uwe Schindler)
-
- * LUCENE-2270: Queries consisting of all zero-boost clauses
-   (for example, text:foo^0) sorted incorrectly and produced
-   invalid docids. (yonik)
-
- * LUCENE-2422: Don't reuse byte[] in IndexInput/Output -- it gains
-   little performance, and ties up possibly large amounts of memory
-   for apps that index large docs.  (Ross Woolf via Mike McCandless)
-
-API Changes
-
- * LUCENE-2190: Added a new class CustomScoreProvider to function package
-   that can be subclassed to provide custom scoring to CustomScoreQuery.
-   The methods in CustomScoreQuery that did this before were deprecated
-   and replaced by a method getCustomScoreProvider(IndexReader) that
-   returns a custom score implementation using the above class. The change
-   is necessary with per-segment searching, as CustomScoreQuery is
-   a stateless class (like all other Queries) and does not know about
-   the currently searched segment. This API works similar to Filter's
-   getDocIdSet(IndexReader).  (Paul chez Jamespot via Mike McCandless,
-   Uwe Schindler)
-
- * LUCENE-2080: Deprecate Version.LUCENE_CURRENT, as using this constant
-   will cause backwards compatibility problems when upgrading Lucene. See
-   the Version javadocs for additional information.
-   (Robert Muir)
-
-Optimizations
-
- * LUCENE-2086: When resolving deleted terms, do so in term sort order
-   for better performance (Bogdan Ghidireac via Mike McCandless)
-
- * LUCENE-2258: Remove unneeded synchronization in FuzzyTermEnum.
-   (Uwe Schindler, Robert Muir)
-
-Test Cases
-
- * LUCENE-2114: Change TestFilteredSearch to test on multi-segment
-   index as well. (Simon Willnauer via Mike McCandless)
-
- * LUCENE-2211: Improves BaseTokenStreamTestCase to use a fake attribute
-   that checks if clearAttributes() was called correctly.
-   (Uwe Schindler, Robert Muir)
-
- * LUCENE-2207, LUCENE-2219: Improve BaseTokenStreamTestCase to check if
-   end() is implemented correctly.  (Koji Sekiguchi, Robert Muir)
-
-Documentation
-
- * LUCENE-2114: Improve javadocs of Filter to call out that the
-   provided reader is per-segment (Simon Willnauer via Mike
-   McCandless)
-
-======================= Release 2.9.1 2009-11-06 =======================
-
-Changes in backwards compatibility policy
-
- * LUCENE-2002: Add required Version matchVersion argument when
-   constructing QueryParser or MultiFieldQueryParser and, default (as
-   of 2.9) enablePositionIncrements to true to match
-   StandardAnalyzer's 2.9 default (Uwe Schindler, Mike McCandless)
-
-Bug fixes
-
- * LUCENE-1974: Fixed nasty bug in BooleanQuery (when it used
-   BooleanScorer for scoring), whereby some matching documents fail to
-   be collected.  (Fulin Tang via Mike McCandless)
-
- * LUCENE-1124: Make sure FuzzyQuery always matches the precise term.
-   (stefatwork@gmail.com via Mike McCandless)
-
- * LUCENE-1976: Fix IndexReader.isCurrent() to return the right thing
-   when the reader is a near real-time reader.  (Jake Mannix via Mike
-   McCandless)
-
- * LUCENE-1986: Fix NPE when scoring PayloadNearQuery (Peter Keegan,
-   Mark Miller via Mike McCandless)
-
- * LUCENE-1992: Fix thread hazard if a merge is committing just as an
-   exception occurs during sync (Uwe Schindler, Mike McCandless)
-
- * LUCENE-1995: Note in javadocs that IndexWriter.setRAMBufferSizeMB
-   cannot exceed 2048 MB, and throw IllegalArgumentException if it
-   does.  (Aaron McKee, Yonik Seeley, Mike McCandless)
-
- * LUCENE-2004: Fix Constants.LUCENE_MAIN_VERSION to not be inlined
-   by client code.  (Uwe Schindler)
-
- * LUCENE-2016: Replace illegal U+FFFF character with the replacement
-   char (U+FFFD) during indexing, to prevent silent index corruption.
-   (Peter Keegan, Mike McCandless)
-
-API Changes
-
- * Un-deprecate search(Weight weight, Filter filter, int n) from
-   Searchable interface (deprecated by accident).  (Uwe Schindler)
-
- * Un-deprecate o.a.l.util.Version constants.  (Mike McCandless)
-
- * LUCENE-1987: Un-deprecate some ctors of Token, as they will not
-   be removed in 3.0 and are still useful. Also add some missing
-   o.a.l.util.Version constants for enabling invalid acronym
-   settings in StandardAnalyzer to be compatible with the coming
-   Lucene 3.0.  (Uwe Schindler)
-
- * LUCENE-1973: Un-deprecate IndexSearcher.setDefaultFieldSortScoring,
-   to allow controlling per-IndexSearcher whether scores are computed
-   when sorting by field.  (Uwe Schindler, Mike McCandless)
-   
-Documentation
-
- * LUCENE-1955: Fix Hits deprecation notice to point users in right
-   direction. (Mike McCandless, Mark Miller)
-   
- * Fix javadoc about score tracking done by search methods in Searcher 
-   and IndexSearcher.  (Mike McCandless)
-
- * LUCENE-2008: Javadoc improvements for TokenStream/Tokenizer/Token
-   (Luke Nezda via Mike McCandless)
-
-======================= Release 2.9.0 2009-09-23 =======================
-
-Changes in backwards compatibility policy
-
- * LUCENE-1575: Searchable.search(Weight, Filter, int, Sort) no
-    longer computes a document score for each hit by default.  If
-    document score tracking is still needed, you can call
-    IndexSearcher.setDefaultFieldSortScoring(true, true) to enable
-    both per-hit and maxScore tracking; however, this is deprecated
-    and will be removed in 3.0.
-
-    Alternatively, use Searchable.search(Weight, Filter, Collector)
-    and pass in a TopFieldCollector instance, using the following code
-    sample:
- 
-    <code>
-      TopFieldCollector tfc = TopFieldCollector.create(sort, numHits, fillFields, 
-                                                       true /* trackDocScores */,
-                                                       true /* trackMaxScore */,
-                                                       false /* docsInOrder */);
-      searcher.search(query, tfc);
-      TopDocs results = tfc.topDocs();
-    </code>
-
-    Note that your Sort object cannot use SortField.AUTO when you
-    directly instantiate TopFieldCollector.
-
-    Also, the method search(Weight, Filter, Collector) was added to
-    the Searchable interface and the Searcher abstract class to
-    replace the deprecated HitCollector versions.  If you either
-    implement Searchable or extend Searcher, you should change your
-    code to implement this method.  If you already extend
-    IndexSearcher, no further changes are needed to use Collector.
-    
-    Finally, the values Float.NaN and Float.NEGATIVE_INFINITY are not
-    valid scores.  Lucene uses these values internally in certain
-    places, so if you have hits with such scores, it will cause
-    problems. (Shai Erera via Mike McCandless)
-
- * LUCENE-1687: All methods and parsers from the interface ExtendedFieldCache
-    have been moved into FieldCache. ExtendedFieldCache is now deprecated and
-    contains only a few declarations for binary backwards compatibility. 
-    ExtendedFieldCache will be removed in version 3.0. Users of FieldCache and 
-    ExtendedFieldCache will be able to plug in Lucene 2.9 without recompilation.
-    The auto cache (FieldCache.getAuto) is now deprecated. Due to the merge of
-    ExtendedFieldCache and FieldCache, FieldCache can now additionally return
-    long[] and double[] arrays in addition to int[] and float[] and StringIndex.
-    
-    The interface changes are only notable for users implementing the interfaces,
-    which was unlikely done, because there is no possibility to change
-    Lucene's FieldCache implementation.  (Grant Ingersoll, Uwe Schindler)
-    
- * LUCENE-1630, LUCENE-1771: Weight, previously an interface, is now an abstract 
-    class. Some of the method signatures have changed, but it should be fairly
-    easy to see what adjustments must be made to existing code to sync up
-    with the new API. You can find more detail in the API Changes section.
-    
-    Going forward Searchable will be kept for convenience only and may
-    be changed between minor releases without any deprecation
-    process. It is not recommended that you implement it, but rather extend
-    Searcher.  
-    (Shai Erera, Chris Hostetter, Martin Ruckli, Mark Miller via Mike McCandless)
-
- * LUCENE-1422, LUCENE-1693: The new Attribute based TokenStream API (see below)
-    has some backwards breaks in rare cases. We did our best to make the 
-    transition as easy as possible and you are not likely to run into any problems. 
-    If your tokenizers still implement next(Token) or next(), the calls are 
-    automatically wrapped. The indexer and query parser use the new API 
-    (eg use incrementToken() calls). All core TokenStreams are implemented using 
-    the new API. You can mix old and new API style TokenFilters/TokenStream. 
-    Problems only occur when you have done the following:
-    You have overridden next(Token) or next() in one of the non-abstract core
-    TokenStreams/-Filters. These classes should normally be final, but some
-    of them are not. In this case, next(Token)/next() would never be called.
-    To fail early with a hard compile/runtime error, the next(Token)/next()
-    methods in these TokenStreams/-Filters were made final in this release.
-    (Michael Busch, Uwe Schindler)
-
- * LUCENE-1763: MergePolicy now requires an IndexWriter instance to
-    be passed upon instantiation. As a result, IndexWriter was removed
-    as a method argument from all MergePolicy methods. (Shai Erera via
-    Mike McCandless)
-    
- * LUCENE-1748: LUCENE-1001 introduced PayloadSpans, but this was a back
-    compat break and caused custom SpanQuery implementations to fail at runtime
-    in a variety of ways. This issue attempts to remedy things by causing
-    a compile time break on custom SpanQuery implementations and removing 
-    the PayloadSpans class, with its functionality now moved to Spans. To
-    help in alleviating future back compat pain, Spans has been changed from
-    an interface to an abstract class.
-    (Hugh Cayless, Mark Miller)
-    
- * LUCENE-1808: Query.createWeight has been changed from protected to
-    public. This will be a back compat break if you have overridden this
-    method - but you are likely already affected by the LUCENE-1693 (make Weight 
-    abstract rather than an interface) back compat break if you have overridden 
-    Query.creatWeight, so we have taken the opportunity to make this change.
-    (Tim Smith, Shai Erera via Mark Miller)
-
- * LUCENE-1708 - IndexReader.document() no longer checks if the document is 
-    deleted. You can call IndexReader.isDeleted(n) prior to calling document(n).
-    (Shai Erera via Mike McCandless)
-
- 
-Changes in runtime behavior
-
- * LUCENE-1424: QueryParser now by default uses constant score auto
-    rewriting when it generates a WildcardQuery and PrefixQuery (it
-    already does so for TermRangeQuery, as well).  Call
-    setMultiTermRewriteMethod(MultiTermQuery.SCORING_BOOLEAN_QUERY_REWRITE)
-    to revert to slower BooleanQuery rewriting method.  (Mark Miller via Mike
-    McCandless)
-    
- * LUCENE-1575: As of 2.9, the core collectors as well as
-    IndexSearcher's search methods that return top N results, no
-    longer filter documents with scores <= 0.0. If you rely on this
-    functionality you can use PositiveScoresOnlyCollector like this:
-
-    <code>
-      TopDocsCollector tdc = new TopScoreDocCollector(10);
-      Collector c = new PositiveScoresOnlyCollector(tdc);
-      searcher.search(query, c);
-      TopDocs hits = tdc.topDocs();
-      ...
-    </code>
-
- * LUCENE-1604: IndexReader.norms(String field) is now allowed to
-    return null if the field has no norms, as long as you've
-    previously called IndexReader.setDisableFakeNorms(true).  This
-    setting now defaults to false (to preserve the fake norms back
-    compatible behavior) but in 3.0 will be hardwired to true.  (Shon
-    Vella via Mike McCandless).
-
- * LUCENE-1624: If you open IndexWriter with create=true and
-    autoCommit=false on an existing index, IndexWriter no longer
-    writes an empty commit when it's created.  (Paul Taylor via Mike
-    McCandless)
-
- * LUCENE-1593: When you call Sort() or Sort.setSort(String field,
-    boolean reverse), the resulting SortField array no longer ends
-    with SortField.FIELD_DOC (it was unnecessary as Lucene breaks ties
-    internally by docID). (Shai Erera via Michael McCandless)
-
- * LUCENE-1542: When the first token(s) have 0 position increment,
-    IndexWriter used to incorrectly record the position as -1, if no
-    payload is present, or Integer.MAX_VALUE if a payload is present.
-    This causes positional queries to fail to match.  The bug is now
-    fixed, but if your app relies on the buggy behavior then you must
-    call IndexWriter.setAllowMinus1Position().  That API is deprecated
-    so you must fix your application, and rebuild your index, to not
-    rely on this behavior by the 3.0 release of Lucene. (Jonathan
-    Mamou, Mark Miller via Mike McCandless)
-
-
- * LUCENE-1715: Finalizers have been removed from the 4 core classes
-    that still had them, since they will cause GC to take longer, thus
-    tying up memory for longer, and at best they mask buggy app code.
-    DirectoryReader (returned from IndexReader.open) & IndexWriter
-    previously released the write lock during finalize.
-    SimpleFSDirectory.FSIndexInput closed the descriptor in its
-    finalizer, and NativeFSLock released the lock.  It's possible
-    applications will be affected by this, but only if the application
-    is failing to close reader/writers.  (Brian Groose via Mike
-    McCandless)
-
- * LUCENE-1717: Fixed IndexWriter to account for RAM usage of
-    buffered deletions.  (Mike McCandless)
-
- * LUCENE-1727: Ensure that fields are stored & retrieved in the
-    exact order in which they were added to the document.  This was
-    true in all Lucene releases before 2.3, but was broken in 2.3 and
-    2.4, and is now fixed in 2.9.  (Mike McCandless)
-
- * LUCENE-1678: The addition of Analyzer.reusableTokenStream
-    accidentally broke back compatibility of external analyzers that
-    subclassed core analyzers that implemented tokenStream but not
-    reusableTokenStream.  This is now fixed, such that if
-    reusableTokenStream is invoked on such a subclass, that method
-    will forcefully fallback to tokenStream.  (Mike McCandless)
-    
- * LUCENE-1801: Token.clear() and Token.clearNoTermBuffer() now also clear
-    startOffset, endOffset and type. This is not likely to affect any
-    Tokenizer chains, as Tokenizers normally always set these three values.
-    This change was made to be conform to the new AttributeImpl.clear() and
-    AttributeSource.clearAttributes() to work identical for Token as one for all
-    AttributeImpl and the 6 separate AttributeImpls. (Uwe Schindler, Michael Busch)
-
- * LUCENE-1483: When searching over multiple segments, a new Scorer is now created 
-    for each segment. Searching has been telescoped out a level and IndexSearcher now
-    operates much like MultiSearcher does. The Weight is created only once for the top 
-    level Searcher, but each Scorer is passed a per-segment IndexReader. This will 
-    result in doc ids in the Scorer being internal to the per-segment IndexReader. It 
-    has always been outside of the API to count on a given IndexReader to contain every 
-    doc id in the index - and if you have been ignoring MultiSearcher in your custom code 
-    and counting on this fact, you will find your code no longer works correctly. If a 
-    custom Scorer implementation uses any caches/filters that rely on being based on the 
-    top level IndexReader, it will need to be updated to correctly use contextless 
-    caches/filters eg you can't count on the IndexReader to contain any given doc id or 
-    all of the doc ids. (Mark Miller, Mike McCandless)
-
- * LUCENE-1846: DateTools now uses the US locale to format the numbers in its
-    date/time strings instead of the default locale. For most locales there will
-    be no change in the index format, as DateFormatSymbols is using ASCII digits.
-    The usage of the US locale is important to guarantee correct ordering of
-    generated terms.  (Uwe Schindler)
-
- * LUCENE-1860: MultiTermQuery now defaults to
-    CONSTANT_SCORE_AUTO_REWRITE_DEFAULT rewrite method (previously it
-    was SCORING_BOOLEAN_QUERY_REWRITE).  This means that PrefixQuery
-    and WildcardQuery will now produce constant score for all matching
-    docs, equal to the boost of the query.  (Mike McCandless)
-
-API Changes
-
- * LUCENE-1419: Add expert API to set custom indexing chain. This API is 
-   package-protected for now, so we don't have to officially support it.
-   Yet, it will give us the possibility to try out different consumers
-   in the chain. (Michael Busch)
-
- * LUCENE-1427: DocIdSet.iterator() is now allowed to throw
-   IOException.  (Paul Elschot, Mike McCandless)
-
- * LUCENE-1422, LUCENE-1693: New TokenStream API that uses a new class called 
-   AttributeSource instead of the Token class, which is now a utility class that
-   holds common Token attributes. All attributes that the Token class had have 
-   been moved into separate classes: TermAttribute, OffsetAttribute, 
-   PositionIncrementAttribute, PayloadAttribute, TypeAttribute and FlagsAttribute. 
-   The new API is much more flexible; it allows to combine the Attributes 
-   arbitrarily and also to define custom Attributes. The new API has the same 
-   performance as the old next(Token) approach. For conformance with this new 
-   API Tee-/SinkTokenizer was deprecated and replaced by a new TeeSinkTokenFilter. 
-   (Michael Busch, Uwe Schindler; additional contributions and bug fixes by 
-   Daniel Shane, Doron Cohen)
-
- * LUCENE-1467: Add nextDoc() and next(int) methods to OpenBitSetIterator.
-   These methods can be used to avoid additional calls to doc(). 
-   (Michael Busch)
-
- * LUCENE-1468: Deprecate Directory.list(), which sometimes (in
-   FSDirectory) filters out files that don't look like index files, in
-   favor of new Directory.listAll(), which does no filtering.  Also,
-   listAll() will never return null; instead, it throws an IOException
-   (or subclass).  Specifically, FSDirectory.listAll() will throw the
-   newly added NoSuchDirectoryException if the directory does not
-   exist.  (Marcel Reutegger, Mike McCandless)
-
- * LUCENE-1546: Add IndexReader.flush(Map commitUserData), allowing
-   you to record an opaque commitUserData (maps String -> String) into
-   the commit written by IndexReader.  This matches IndexWriter's
-   commit methods.  (Jason Rutherglen via Mike McCandless)
-
- * LUCENE-652: Added org.apache.lucene.document.CompressionTools, to
-   enable compressing & decompressing binary content, external to
-   Lucene's indexing.  Deprecated Field.Store.COMPRESS.
-
- * LUCENE-1561: Renamed Field.omitTf to Field.omitTermFreqAndPositions
-    (Otis Gospodnetic via Mike McCandless)
-  
- * LUCENE-1500: Added new InvalidTokenOffsetsException to Highlighter methods
-    to denote issues when offsets in TokenStream tokens exceed the length of the
-    provided text.  (Mark Harwood)
-    
- * LUCENE-1575, LUCENE-1483: HitCollector is now deprecated in favor of 
-    a new Collector abstract class. For easy migration, people can use
-    HitCollectorWrapper which translates (wraps) HitCollector into
-    Collector. Note that this class is also deprecated and will be
-    removed when HitCollector is removed.  Also TimeLimitedCollector
-    is deprecated in favor of the new TimeLimitingCollector which
-    extends Collector.  (Shai Erera, Mark Miller, Mike McCandless)
-
- * LUCENE-1592: The method TermsEnum.skipTo() was deprecated, because
-    it is used nowhere in core/contrib and there is only a very ineffective
-    default implementation available. If you want to position a TermEnum
-    to another Term, create a new one using IndexReader.terms(Term).
-    (Uwe Schindler)
-
- * LUCENE-1621: MultiTermQuery.getTerm() has been deprecated as it does
-    not make sense for all subclasses of MultiTermQuery. Check individual
-    subclasses to see if they support getTerm().  (Mark Miller)
-
- * LUCENE-1636: Make TokenFilter.input final so it's set only
-    once. (Wouter Heijke, Uwe Schindler via Mike McCandless).
-
- * LUCENE-1658, LUCENE-1451: Renamed FSDirectory to SimpleFSDirectory
-    (but left an FSDirectory base class).  Added an FSDirectory.open
-    static method to pick a good default FSDirectory implementation
-    given the OS. FSDirectories should now be instantiated using
-    FSDirectory.open or with public constructors rather than
-    FSDirectory.getDirectory(), which has been deprecated.
-    (Michael McCandless, Uwe Schindler, yonik)
-
- * LUCENE-1665: Deprecate SortField.AUTO, to be removed in 3.0.
-    Instead, when sorting by field, the application should explicitly
-    state the type of the field.  (Mike McCandless)
-
- * LUCENE-1660: StopFilter, StandardAnalyzer, StopAnalyzer now
-    require up front specification of enablePositionIncrement (Mike
-    McCandless)
-
- * LUCENE-1614: DocIdSetIterator's next() and skipTo() were deprecated in favor
-    of the new nextDoc() and advance(). The new methods return the doc Id they 
-    landed on, saving an extra call to doc() in most cases.
-    For easy migration of the code, you can change the calls to next() to 
-    nextDoc() != DocIdSetIterator.NO_MORE_DOCS and similarly for skipTo(). 
-    However it is advised that you take advantage of the returned doc ID and not 
-    call doc() following those two.
-    Also, doc() was deprecated in favor of docID(). docID() should return -1 or 
-    NO_MORE_DOCS if nextDoc/advance were not called yet, or NO_MORE_DOCS if the 
-    iterator has exhausted. Otherwise it should return the current doc ID.
-    (Shai Erera via Mike McCandless)
-
- * LUCENE-1672: All ctors/opens and other methods using String/File to
-    specify the directory in IndexReader, IndexWriter, and IndexSearcher
-    were deprecated. You should instantiate the Directory manually before
-    and pass it to these classes (LUCENE-1451, LUCENE-1658).
-    (Uwe Schindler)
-
- * LUCENE-1407: Move RemoteSearchable, RemoteCachingWrapperFilter out
-    of Lucene's core into new contrib/remote package.  Searchable no
-    longer extends java.rmi.Remote (Simon Willnauer via Mike
-    McCandless)
-
- * LUCENE-1677: The global property
-    org.apache.lucene.SegmentReader.class, and
-    ReadOnlySegmentReader.class are now deprecated, to be removed in
-    3.0.  src/gcj/* has been removed. (Earwin Burrfoot via Mike
-    McCandless)
-
- * LUCENE-1673: Deprecated NumberTools in favour of the new
-    NumericRangeQuery and its new indexing format for numeric or
-    date values.  (Uwe Schindler)
-    
- * LUCENE-1630, LUCENE-1771: Weight is now an abstract class, and adds
-    a scorer(IndexReader, boolean /* scoreDocsInOrder */, boolean /*
-    topScorer */) method instead of scorer(IndexReader). IndexSearcher uses 
-    this method to obtain a scorer matching the capabilities of the Collector 
-    wrt orderedness of docIDs. Some Scorers (like BooleanScorer) are much more
-    efficient if out-of-order documents scoring is allowed by a Collector.  
-    Collector must now implement acceptsDocsOutOfOrder. If you write a 
-    Collector which does not care about doc ID orderness, it is recommended 
-    that you return true.  Weight has a scoresDocsOutOfOrder method, which by 
-    default returns false.  If you create a Weight which will score documents 
-    out of order if requested, you should override that method to return true. 
-    BooleanQuery's setAllowDocsOutOfOrder and getAllowDocsOutOfOrder have been 
-    deprecated as they are not needed anymore. BooleanQuery will now score docs 
-    out of order when used with a Collector that can accept docs out of order.
-    Finally, Weight#explain now takes a sub-reader and sub-docID, rather than
-    a top level reader and docID.
-    (Shai Erera, Chris Hostetter, Martin Ruckli, Mark Miller via Mike McCandless)
- 	
- * LUCENE-1466, LUCENE-1906: Added CharFilter and MappingCharFilter, which allows
-    chaining & mapping of characters before tokenizers run. CharStream (subclass of
-    Reader) is the base class for custom java.io.Reader's, that support offset
-    correction. Tokenizers got an additional method correctOffset() that is passed
-    down to the underlying CharStream if input is a subclass of CharStream/-Filter.
-    (Koji Sekiguchi via Mike McCandless, Uwe Schindler)
-
- * LUCENE-1703: Add IndexWriter.waitForMerges.  (Tim Smith via Mike
-    McCandless)
-
- * LUCENE-1625: CheckIndex's programmatic API now returns separate
-    classes detailing the status of each component in the index, and
-    includes more detailed status than previously.  (Tim Smith via
-    Mike McCandless)
-
- * LUCENE-1713: Deprecated RangeQuery and RangeFilter and renamed to
-    TermRangeQuery and TermRangeFilter. TermRangeQuery is in constant
-    score auto rewrite mode by default. The new classes also have new
-    ctors taking field and term ranges as Strings (see also
-    LUCENE-1424).  (Uwe Schindler)
-
- * LUCENE-1609: The termInfosIndexDivisor must now be specified
-    up-front when opening the IndexReader.  Attempts to call
-    IndexReader.setTermInfosIndexDivisor will hit an
-    UnsupportedOperationException.  This was done to enable removal of
-    all synchronization in TermInfosReader, which previously could
-    cause threads to pile up in certain cases. (Dan Rosher via Mike
-    McCandless)
-    
- * LUCENE-1688: Deprecate static final String stop word array in and 
-    StopAnalzyer and replace it with an immutable implementation of 
-    CharArraySet.  (Simon Willnauer via Mark Miller)
-
- * LUCENE-1742: SegmentInfos, SegmentInfo and SegmentReader have been
-    made public as expert, experimental APIs.  These APIs may suddenly
-    change from release to release (Jason Rutherglen via Mike
-    McCandless).
-    
- * LUCENE-1754: QueryWeight.scorer() can return null if no documents
-    are going to be matched by the query. Similarly,
-    Filter.getDocIdSet() can return null if no documents are going to
-    be accepted by the Filter. Note that these 'can' return null,
-    however they don't have to and can return a Scorer/DocIdSet which
-    does not match / reject all documents.  This is already the
-    behavior of some QueryWeight/Filter implementations, and is
-    documented here just for emphasis. (Shai Erera via Mike
-    McCandless)
-
- * LUCENE-1705: Added IndexWriter.deleteAllDocuments.  (Tim Smith via
-    Mike McCandless)
-
- * LUCENE-1460: Changed TokenStreams/TokenFilters in contrib to
-    use the new TokenStream API. (Robert Muir, Michael Busch)
-
- * LUCENE-1748: LUCENE-1001 introduced PayloadSpans, but this was a back
-    compat break and caused custom SpanQuery implementations to fail at runtime
-    in a variety of ways. This issue attempts to remedy things by causing
-    a compile time break on custom SpanQuery implementations and removing 
-    the PayloadSpans class, with its functionality now moved to Spans. To
-    help in alleviating future back compat pain, Spans has been changed from
-    an interface to an abstract class.
-    (Hugh Cayless, Mark Miller)
-    
- * LUCENE-1808: Query.createWeight has been changed from protected to
-    public. (Tim Smith, Shai Erera via Mark Miller)
-
- * LUCENE-1826: Add constructors that take AttributeSource and
-    AttributeFactory to all Tokenizer implementations.
-    (Michael Busch)
-    
- * LUCENE-1847: Similarity#idf for both a Term and Term Collection have
-    been deprecated. New versions that return an IDFExplanation have been
-    added.  (Yasoja Seneviratne, Mike McCandless, Mark Miller)
-    
- * LUCENE-1877: Made NativeFSLockFactory the default for
-    the new FSDirectory API (open(), FSDirectory subclass ctors).
-    All FSDirectory system properties were deprecated and all lock
-    implementations use no lock prefix if the locks are stored inside
-    the index directory. Because the deprecated String/File ctors of
-    IndexWriter and IndexReader (LUCENE-1672) and FSDirectory.getDirectory()
-    still use the old SimpleFSLockFactory and the new API
-    NativeFSLockFactory, we strongly recommend not to mix deprecated
-    and new API. (Uwe Schindler, Mike McCandless)
-
- * LUCENE-1911: Added a new method isCacheable() to DocIdSet. This method
-    should return true, if the underlying implementation does not use disk
-    I/O and is fast enough to be directly cached by CachingWrapperFilter.
-    OpenBitSet, SortedVIntList, and DocIdBitSet are such candidates.
-    The default implementation of the abstract DocIdSet class returns false.
-    In this case, CachingWrapperFilter copies the DocIdSetIterator into an
-    OpenBitSet for caching.  (Uwe Schindler, Thomas Becker)
-
-Bug fixes
-
- * LUCENE-1415: MultiPhraseQuery has incorrect hashCode() and equals()
-   implementation - Leads to Solr Cache misses. 
-   (Todd Feak, Mark Miller via yonik)
-
- * LUCENE-1327: Fix TermSpans#skipTo() to behave as specified in javadocs
-   of Terms#skipTo(). (Michael Busch)
-
- * LUCENE-1573: Do not ignore InterruptedException (caused by
-   Thread.interrupt()) nor enter deadlock/spin loop. Now, an interrupt
-   will cause a RuntimeException to be thrown.  In 3.0 we will change
-   public APIs to throw InterruptedException.  (Jeremy Volkman via
-   Mike McCandless)
-
- * LUCENE-1590: Fixed stored-only Field instances do not change the
-   value of omitNorms, omitTermFreqAndPositions in FieldInfo; when you
-   retrieve such fields they will now have omitNorms=true and
-   omitTermFreqAndPositions=false (though these values are unused).
-   (Uwe Schindler via Mike McCandless)
-
- * LUCENE-1587: RangeQuery#equals() could consider a RangeQuery
-   without a collator equal to one with a collator.
-   (Mark Platvoet via Mark Miller) 
-
- * LUCENE-1600: Don't call String.intern unnecessarily in some cases
-   when loading documents from the index.  (P Eger via Mike
-   McCandless)
-
- * LUCENE-1611: Fix case where OutOfMemoryException in IndexWriter
-   could cause "infinite merging" to happen.  (Christiaan Fluit via
-   Mike McCandless)
-
- * LUCENE-1623: Properly handle back-compatibility of 2.3.x indexes that
-   contain field names with non-ascii characters.  (Mike Streeton via
-   Mike McCandless)
-
- * LUCENE-1593: MultiSearcher and ParallelMultiSearcher did not break ties (in 
-   sort) by doc Id in a consistent manner (i.e., if Sort.FIELD_DOC was used vs. 
-   when it wasn't). (Shai Erera via Michael McCandless)
-
- * LUCENE-1647: Fix case where IndexReader.undeleteAll would cause
-    the segment's deletion count to be incorrect. (Mike McCandless)
-
- * LUCENE-1542: When the first token(s) have 0 position increment,
-    IndexWriter used to incorrectly record the position as -1, if no
-    payload is present, or Integer.MAX_VALUE if a payload is present.
-    This causes positional queries to fail to match.  The bug is now
-    fixed, but if your app relies on the buggy behavior then you must
-    call IndexWriter.setAllowMinus1Position().  That API is deprecated
-    so you must fix your application, and rebuild your index, to not
-    rely on this behavior by the 3.0 release of Lucene. (Jonathan
-    Mamou, Mark Miller via Mike McCandless)
-
- * LUCENE-1658: Fixed MMapDirectory to correctly throw IOExceptions
-    on EOF, removed numeric overflow possibilities and added support
-    for a hack to unmap the buffers on closing IndexInput.
-    (Uwe Schindler)
-    
- * LUCENE-1681: Fix infinite loop caused by a call to DocValues methods 
-    getMinValue, getMaxValue, getAverageValue. (Simon Willnauer via Mark Miller)
-
- * LUCENE-1599: Add clone support for SpanQuerys. SpanRegexQuery counts
-    on this functionality and does not work correctly without it.
-    (Billow Gao, Mark Miller)
-
- * LUCENE-1718: Fix termInfosIndexDivisor to carry over to reopened
-    readers (Mike McCandless)
-    
- * LUCENE-1583: SpanOrQuery skipTo() doesn't always move forwards as Spans
-	documentation indicates it should.  (Moti Nisenson via Mark Miller)
-
- * LUCENE-1566: Sun JVM Bug
-    http://bugs.sun.com/bugdatabase/view_bug.do?bug_id=6478546 causes
-    invalid OutOfMemoryError when reading too many bytes at once from
-    a file on 32bit JVMs that have a large maximum heap size.  This
-    fix adds set/getReadChunkSize to FSDirectory so that large reads
-    are broken into chunks, to work around this JVM bug.  On 32bit
-    JVMs the default chunk size is 100 MB; on 64bit JVMs, which don't
-    show the bug, the default is Integer.MAX_VALUE. (Simon Willnauer
-    via Mike McCandless)
-    
- * LUCENE-1448: Added TokenStream.end() to perform end-of-stream
-    operations (ie to return the end offset of the tokenization).  
-    This is important when multiple fields with the same name are added
-    to a document, to ensure offsets recorded in term vectors for all 
-    of the instances are correct.  
-    (Mike McCandless, Mark Miller, Michael Busch)
-
- * LUCENE-1805: CloseableThreadLocal did not allow a null Object in get(), 
-    although it does allow it in set(Object). Fix get() to not assert the object
-    is not null. (Shai Erera via Mike McCandless)
-    
- * LUCENE-1801: Changed all Tokenizers or TokenStreams in core/contrib)
-    that are the source of Tokens to always call
-    AttributeSource.clearAttributes() first. (Uwe Schindler)
-    
- * LUCENE-1819: MatchAllDocsQuery.toString(field) should produce output
-    that is parsable by the QueryParser.  (John Wang, Mark Miller)
-
- * LUCENE-1836: Fix localization bug in the new query parser and add 
-    new LocalizedTestCase as base class for localization junit tests.
-    (Robert Muir, Uwe Schindler via Michael Busch)
-
- * LUCENE-1847: PhraseQuery/TermQuery/SpanQuery use IndexReader specific stats 
-    in their Weight#explain methods - these stats should be corpus wide.
-    (Yasoja Seneviratne, Mike McCandless, Mark Miller)
-
- * LUCENE-1885: Fix the bug that NativeFSLock.isLocked() did not work,
-    if the lock was obtained by another NativeFSLock(Factory) instance.
-    Because of this IndexReader.isLocked() and IndexWriter.isLocked() did
-    not work correctly.  (Uwe Schindler)
-
- * LUCENE-1899: Fix O(N^2) CPU cost when setting docIDs in order in an
-    OpenBitSet, due to an inefficiency in how the underlying storage is
-    reallocated.  (Nadav Har'El via Mike McCandless)
-
- * LUCENE-1918: Fixed cases where a ParallelReader would
-   generate exceptions on being passed to
-   IndexWriter.addIndexes(IndexReader[]).  First case was when the
-   ParallelReader was empty.  Second case was when the ParallelReader
-   used to contain documents with TermVectors, but all such documents
-   have been deleted. (Christian Kohlschütter via Mike McCandless)
-
-New features
-
- * LUCENE-1411: Added expert API to open an IndexWriter on a prior
-    commit, obtained from IndexReader.listCommits.  This makes it
-    possible to rollback changes to an index even after you've closed
-    the IndexWriter that made the changes, assuming you are using an
-    IndexDeletionPolicy that keeps past commits around.  This is useful
-    when building transactional support on top of Lucene.  (Mike
-    McCandless)
-
- * LUCENE-1382: Add an optional arbitrary Map (String -> String)
-    "commitUserData" to IndexWriter.commit(), which is stored in the
-    segments file and is then retrievable via
-    IndexReader.getCommitUserData instance and static methods.
-    (Shalin Shekhar Mangar via Mike McCandless)
-
- * LUCENE-1420: Similarity now has a computeNorm method that allows
-    custom Similarity classes to override how norm is computed.  It's
-    provided a FieldInvertState instance that contains details from
-    inverting the field.  The default impl is boost *
-    lengthNorm(numTerms), to be backwards compatible.  Also added
-    {set/get}DiscountOverlaps to DefaultSimilarity, to control whether
-    overlapping tokens (tokens with 0 position increment) should be
-    counted in lengthNorm.  (Andrzej Bialecki via Mike McCandless)
-
- * LUCENE-1424: Moved constant score query rewrite capability into
-    MultiTermQuery, allowing TermRangeQuery, PrefixQuery and WildcardQuery
-    to switch between constant-score rewriting or BooleanQuery
-    expansion rewriting via a new setRewriteMethod method.
-    Deprecated ConstantScoreRangeQuery (Mark Miller via Mike
-    McCandless)
-
- * LUCENE-1461: Added FieldCacheRangeFilter, a RangeFilter for
-    single-term fields that uses FieldCache to compute the filter.  If
-    your documents all have a single term for a given field, and you
-    need to create many RangeFilters with varying lower/upper bounds,
-    then this is likely a much faster way to create the filters than
-    RangeFilter.  FieldCacheRangeFilter allows ranges on all data types,
-    FieldCache supports (term ranges, byte, short, int, long, float, double).
-    However, it comes at the expense of added RAM consumption and slower
-    first-time usage due to populating the FieldCache.  It also does not
-    support collation  (Tim Sturge, Matt Ericson via Mike McCandless and
-    Uwe Schindler)
-
- * LUCENE-1296: add protected method CachingWrapperFilter.docIdSetToCache 
-    to allow subclasses to choose which DocIdSet implementation to use
-    (Paul Elschot via Mike McCandless)
-    
- * LUCENE-1390: Added ASCIIFoldingFilter, a Filter that converts 
-    alphabetic, numeric, and symbolic Unicode characters which are not in 
-    the first 127 ASCII characters (the "Basic Latin" Unicode block) into 
-    their ASCII equivalents, if one exists. ISOLatin1AccentFilter, which
-    handles a subset of this filter, has been deprecated.
-    (Andi Vajda, Steven Rowe via Mark Miller)
-
- * LUCENE-1478: Added new SortField constructor allowing you to
-    specify a custom FieldCache parser to generate numeric values from
-    terms for a field.  (Uwe Schindler via Mike McCandless)
-
- * LUCENE-1528: Add support for Ideographic Space to the queryparser.
-    (Luis Alves via Michael Busch)
-
- * LUCENE-1487: Added FieldCacheTermsFilter, to filter by multiple
-    terms on single-valued fields.  The filter loads the FieldCache
-    for the field the first time it's called, and subsequent usage of
-    that field, even with different Terms in the filter, are fast.
-    (Tim Sturge, Shalin Shekhar Mangar via Mike McCandless).
-
- * LUCENE-1314: Add clone(), clone(boolean readOnly) and
-    reopen(boolean readOnly) to IndexReader.  Cloning an IndexReader
-    gives you a new reader which you can make changes to (deletions,
-    norms) without affecting the original reader.  Now, with clone or
-    reopen you can change the readOnly of the original reader.  (Jason
-    Rutherglen, Mike McCandless)
-
- * LUCENE-1506: Added FilteredDocIdSet, an abstract class which you
-    subclass to implement the "match" method to accept or reject each
-    docID.  Unlike ChainedFilter (under contrib/misc),
-    FilteredDocIdSet never requires you to materialize the full
-    bitset.  Instead, match() is called on demand per docID.  (John
-    Wang via Mike McCandless)
-
- * LUCENE-1398: Add ReverseStringFilter to contrib/analyzers, a filter
-    to reverse the characters in each token.  (Koji Sekiguchi via yonik)
-
- * LUCENE-1551: Add expert IndexReader.reopen(IndexCommit) to allow
-    efficiently opening a new reader on a specific commit, sharing
-    resources with the original reader.  (Torin Danil via Mike
-    McCandless)
-
- * LUCENE-1434: Added org.apache.lucene.util.IndexableBinaryStringTools,
-    to encode byte[] as String values that are valid terms, and
-    maintain sort order of the original byte[] when the bytes are
-    interpreted as unsigned.  (Steven Rowe via Mike McCandless)
-
- * LUCENE-1543: Allow MatchAllDocsQuery to optionally use norms from
-    a specific fields to set the score for a document.  (Karl Wettin
-    via Mike McCandless)
-
- * LUCENE-1586: Add IndexReader.getUniqueTermCount().  (Mike
-    McCandless via Derek)
-
- * LUCENE-1516: Added "near real-time search" to IndexWriter, via a
-    new expert getReader() method.  This method returns a reader that
-    searches the full index, including any uncommitted changes in the
-    current IndexWriter session.  This should result in a faster
-    turnaround than the normal approach of commiting the changes and
-    then reopening a reader.  (Jason Rutherglen via Mike McCandless)
-
- * LUCENE-1603: Added new MultiTermQueryWrapperFilter, to wrap any
-    MultiTermQuery as a Filter.  Also made some improvements to
-    MultiTermQuery: return DocIdSet.EMPTY_DOCIDSET if there are no
-    terms in the enum; track the total number of terms it visited
-    during rewrite (getTotalNumberOfTerms).  FilteredTermEnum is also
-    more friendly to subclassing.  (Uwe Schindler via Mike McCandless)
-
- * LUCENE-1605: Added BitVector.subset().  (Jeremy Volkman via Mike
-    McCandless)
-    
- * LUCENE-1618: Added FileSwitchDirectory that enables files with
-    specified extensions to be stored in a primary directory and the
-    rest of the files to be stored in the secondary directory.  For
-    example, this can be useful for the large doc-store (stored
-    fields, term vectors) files in FSDirectory and the rest of the
-    index files in a RAMDirectory. (Jason Rutherglen via Mike
-    McCandless)
-
- * LUCENE-1494: Added FieldMaskingSpanQuery which can be used to
-    cross-correlate Spans from different fields.
-    (Paul Cowan and Chris Hostetter)
-
- * LUCENE-1634: Add calibrateSizeByDeletes to LogMergePolicy, to take
-    deletions into account when considering merges.  (Yasuhiro Matsuda
-    via Mike McCandless)
-
- * LUCENE-1550: Added new n-gram based String distance measure for spell checking.
-    See the Javadocs for NGramDistance.java for a reference paper on why
-    this is helpful (Tom Morton via Grant Ingersoll)
-
- * LUCENE-1470, LUCENE-1582, LUCENE-1602, LUCENE-1673, LUCENE-1701, LUCENE-1712:
-    Added NumericRangeQuery and NumericRangeFilter, a fast alternative to
-    RangeQuery/RangeFilter for numeric searches. They depend on a specific
-    structure of terms in the index that can be created by indexing
-    using the new NumericField or NumericTokenStream classes. NumericField
-    can only be used for indexing and optionally stores the values as
-    string representation in the doc store. Documents returned from
-    IndexReader/IndexSearcher will return only the String value using
-    the standard Fieldable interface. NumericFields can be sorted on
-    and loaded into the FieldCache.  (Uwe Schindler, Yonik Seeley,
-    Mike McCandless)
-
- * LUCENE-1405: Added support for Ant resource collections in contrib/ant
-    <index> task.  (Przemyslaw Sztoch via Erik Hatcher)
-
- * LUCENE-1699: Allow setting a TokenStream on Field/Fieldable for indexing
-    in conjunction with any other ways to specify stored field values,
-    currently binary or string values.  (yonik)
-    
- * LUCENE-1701: Made the standard FieldCache.Parsers public and added
-    parsers for fields generated using NumericField/NumericTokenStream.
-    All standard parsers now also implement Serializable and enforce
-    their singleton status.  (Uwe Schindler, Mike McCandless)
-    
- * LUCENE-1741: User configurable maximum chunk size in MMapDirectory.
-    On 32 bit platforms, the address space can be very fragmented, so
-    one big ByteBuffer for the whole file may not fit into address space.
-    (Eks Dev via Uwe Schindler)
-
- * LUCENE-1644: Enable 4 rewrite modes for queries deriving from
-    MultiTermQuery (WildcardQuery, PrefixQuery, TermRangeQuery,
-    NumericRangeQuery): CONSTANT_SCORE_FILTER_REWRITE first creates a
-    filter and then assigns constant score (boost) to docs;
-    CONSTANT_SCORE_BOOLEAN_QUERY_REWRITE create a BooleanQuery but
-    uses a constant score (boost); SCORING_BOOLEAN_QUERY_REWRITE also
-    creates a BooleanQuery but keeps the BooleanQuery's scores;
-    CONSTANT_SCORE_AUTO_REWRITE tries to pick the most performant
-    constant-score rewrite method.  (Mike McCandless)
-    
- * LUCENE-1448: Added TokenStream.end(), to perform end-of-stream
-    operations.  This is currently used to fix offset problems when 
-    multiple fields with the same name are added to a document.
-    (Mike McCandless, Mark Miller, Michael Busch)
- 
- * LUCENE-1776: Add an option to not collect payloads for an ordered
-    SpanNearQuery. Payloads were not lazily loaded in this case as
-    the javadocs implied. If you have payloads and want to use an ordered
-    SpanNearQuery that does not need to use the payloads, you can
-    disable loading them with a new constructor switch.  (Mark Miller)
-
- * LUCENE-1341: Added PayloadNearQuery to enable SpanNearQuery functionality
-    with payloads (Peter Keegan, Grant Ingersoll, Mark Miller)
-
- * LUCENE-1790: Added PayloadTermQuery to enable scoring of payloads
-    based on the maximum payload seen for a document.
-    Slight refactoring of Similarity and other payload queries (Grant Ingersoll, Mark Miller)
-
- * LUCENE-1749: Addition of FieldCacheSanityChecker utility, and
-    hooks to use it in all existing Lucene Tests.  This class can
-    be used by any application to inspect the FieldCache and provide
-    diagnostic information about the possibility of inconsistent
-    FieldCache usage.  Namely: FieldCache entries for the same field
-    with different datatypes or parsers; and FieldCache entries for
-    the same field in both a reader, and one of it's (descendant) sub
-    readers. 
-    (Chris Hostetter, Mark Miller)
-
- * LUCENE-1789: Added utility class
-    oal.search.function.MultiValueSource to ease the transition to
-    segment based searching for any apps that directly call
-    oal.search.function.* APIs.  This class wraps any other
-    ValueSource, but takes care when composite (multi-segment) are
-    passed to not double RAM usage in the FieldCache.  (Chris
-    Hostetter, Mark Miller, Mike McCandless)
-   
-Optimizations
-
- * LUCENE-1427: Fixed QueryWrapperFilter to not waste time computing
-    scores of the query, since they are just discarded.  Also, made it
-    more efficient (single pass) by not creating & populating an
-    intermediate OpenBitSet (Paul Elschot, Mike McCandless)
-
- * LUCENE-1443: Performance improvement for OpenBitSetDISI.inPlaceAnd()
-    (Paul Elschot via yonik)
-
- * LUCENE-1484: Remove synchronization of IndexReader.document() by
-    using CloseableThreadLocal internally.  (Jason Rutherglen via Mike
-    McCandless).
-    
- * LUCENE-1124: Short circuit FuzzyQuery.rewrite when input token length 
-    is small compared to minSimilarity. (Timo Nentwig, Mark Miller)
-
- * LUCENE-1316: MatchAllDocsQuery now avoids the synchronized
-    IndexReader.isDeleted() call per document, by directly accessing
-    the underlying deleteDocs BitVector.  This improves performance
-    with non-readOnly readers, especially in a multi-threaded
-    environment.  (Todd Feak, Yonik Seeley, Jason Rutherglen via Mike
-    McCandless)
-
- * LUCENE-1483: When searching over multiple segments we now visit
-    each sub-reader one at a time.  This speeds up warming, since
-    FieldCache entries (if required) can be shared across reopens for
-    those segments that did not change, and also speeds up searches
-    that sort by relevance or by field values.  (Mark Miller, Mike
-    McCandless)
-    
- * LUCENE-1575: The new Collector class decouples collect() from
-    score computation.  Collector.setScorer is called to establish the
-    current Scorer in-use per segment.  Collectors that require the
-    score should then call Scorer.score() per hit inside
-    collect(). (Shai Erera via Mike McCandless)
-
- * LUCENE-1596: MultiTermDocs speedup when set with
-    MultiTermDocs.seek(MultiTermEnum) (yonik)
-    
- * LUCENE-1653: Avoid creating a Calendar in every call to 
-    DateTools#dateToString, DateTools#timeToString and
-    DateTools#round.  (Shai Erera via Mark Miller)
-    
- * LUCENE-1688: Deprecate static final String stop word array and 
-    replace it with an immutable implementation of CharArraySet.
-    Removes conversions between Set and array.
-    (Simon Willnauer via Mark Miller)
-
- * LUCENE-1754: BooleanQuery.queryWeight.scorer() will return null if
-    it won't match any documents (e.g. if there are no required and
-    optional scorers, or not enough optional scorers to satisfy
-    minShouldMatch).  (Shai Erera via Mike McCandless)
-
- * LUCENE-1607: To speed up string interning for commonly used
-    strings, the StringHelper.intern() interface was added with a
-    default implementation that uses a lockless cache.
-    (Earwin Burrfoot, yonik)
-
- * LUCENE-1800: QueryParser should use reusable TokenStreams. (yonik)
-    
-
-Documentation
-
- * LUCENE-1908: Scoring documentation imrovements in Similarity javadocs. 
-   (Mark Miller, Shai Erera, Ted Dunning, Jiri Kuhn, Marvin Humphrey, Doron Cohen)
-    
- * LUCENE-1872: NumericField javadoc improvements
-    (Michael McCandless, Uwe Schindler)
- 
- * LUCENE-1875: Make TokenStream.end javadoc less confusing.
-    (Uwe Schindler)
-
- * LUCENE-1862: Rectified duplicate package level javadocs for
-    o.a.l.queryParser and o.a.l.analysis.cn.
-    (Chris Hostetter)
-
- * LUCENE-1886: Improved hyperlinking in key Analysis javadocs
-    (Bernd Fondermann via Chris Hostetter)
-
- * LUCENE-1884: massive javadoc and comment cleanup, primarily dealing with
-    typos.
-    (Robert Muir via Chris Hostetter)
-    
- * LUCENE-1898: Switch changes to use bullets rather than numbers and 
-    update changes-to-html script to handle the new format. 
-    (Steven Rowe, Mark Miller)
-    
- * LUCENE-1900: Improve Searchable Javadoc.
-    (Nadav Har'El, Doron Cohen, Marvin Humphrey, Mark Miller)
-    
- * LUCENE-1896: Improve Similarity#queryNorm javadocs.
-    (Jiri Kuhn, Mark Miller)
-
-Build
-
- * LUCENE-1440: Add new targets to build.xml that allow downloading
-    and executing the junit testcases from an older release for
-    backwards-compatibility testing. (Michael Busch)
-
- * LUCENE-1446: Add compatibility tag to common-build.xml and run 
-    backwards-compatibility tests in the nightly build. (Michael Busch)
-
- * LUCENE-1529: Properly test "drop-in" replacement of jar with 
-    backwards-compatibility tests. (Mike McCandless, Michael Busch)
-
- * LUCENE-1851: Change 'javacc' and 'clean-javacc' targets to build
-    and clean contrib/surround files. (Luis Alves via Michael Busch)
-
- * LUCENE-1854: tar task should use longfile="gnu" to avoid false file
-    name length warnings.  (Mark Miller)
-
-Test Cases
-
- * LUCENE-1791: Enhancements to the QueryUtils and CheckHits utility 
-    classes to wrap IndexReaders and Searchers in MultiReaders or 
-    MultiSearcher when possible to help exercise more edge cases.
-    (Chris Hostetter, Mark Miller)
-
- * LUCENE-1852: Fix localization test failures. 
-    (Robert Muir via Michael Busch)
-    
- * LUCENE-1843: Refactored all tests that use assertAnalyzesTo() & others
-    in core and contrib to use a new BaseTokenStreamTestCase
-    base class. Also rewrote some tests to use this general analysis assert
-    functions instead of own ones (e.g. TestMappingCharFilter).
-    The new base class also tests tokenization with the TokenStream.next()
-    backwards layer enabled (using Token/TokenWrapper as attribute
-    implementation) and disabled (default for Lucene 3.0)
-    (Uwe Schindler, Robert Muir)
-    
- * LUCENE-1836: Added a new LocalizedTestCase as base class for localization
-    junit tests.  (Robert Muir, Uwe Schindler via Michael Busch)
-
-======================= Release 2.4.1 2009-03-09 =======================
-
-API Changes
-
-1. LUCENE-1186: Add Analyzer.close() to free internal ThreadLocal
-   resources.  (Christian Kohlschütter via Mike McCandless)
-
-Bug fixes
-
-1. LUCENE-1452: Fixed silent data-loss case whereby binary fields are
-   truncated to 0 bytes during merging if the segments being merged
-   are non-congruent (same field name maps to different field
-   numbers).  This bug was introduced with LUCENE-1219.  (Andrzej
-   Bialecki via Mike McCandless).
-
-2. LUCENE-1429: Don't throw incorrect IllegalStateException from
-   IndexWriter.close() if you've hit an OOM when autoCommit is true.
-   (Mike McCandless)
-
-3. LUCENE-1474: If IndexReader.flush() is called twice when there were
-   pending deletions, it could lead to later false AssertionError
-   during IndexReader.open.  (Mike McCandless)
-
-4. LUCENE-1430: Fix false AlreadyClosedException from IndexReader.open
-   (masking an actual IOException) that takes String or File path.
-   (Mike McCandless)
-
-5. LUCENE-1442: Multiple-valued NOT_ANALYZED fields can double-count
-   token offsets.  (Mike McCandless)
-
-6. LUCENE-1453: Ensure IndexReader.reopen()/clone() does not result in
-   incorrectly closing the shared FSDirectory. This bug would only
-   happen if you use IndexReader.open() with a File or String argument.
-   The returned readers are wrapped by a FilterIndexReader that
-   correctly handles closing of directory after reopen()/clone(). 
-   (Mark Miller, Uwe Schindler, Mike McCandless)
-
-7. LUCENE-1457: Fix possible overflow bugs during binary
-   searches. (Mark Miller via Mike McCandless)
-
-8. LUCENE-1459: Fix CachingWrapperFilter to not throw exception if
-   both bits() and getDocIdSet() methods are called. (Matt Jones via
-   Mike McCandless)
-
-9. LUCENE-1519: Fix int overflow bug during segment merging.  (Deepak
-   via Mike McCandless)
-
-10. LUCENE-1521: Fix int overflow bug when flushing segment.
-    (Shon Vella via Mike McCandless).
-
-11. LUCENE-1544: Fix deadlock in IndexWriter.addIndexes(IndexReader[]).
-    (Mike McCandless via Doug Sale)
-
-12. LUCENE-1547: Fix rare thread safety issue if two threads call
-    IndexWriter commit() at the same time.  (Mike McCandless)
-
-13. LUCENE-1465: NearSpansOrdered returns payloads from first possible match 
-    rather than the correct, shortest match; Payloads could be returned even
-    if the max slop was exceeded; The wrong payload could be returned in 
-    certain situations. (Jonathan Mamou, Greg Shackles, Mark Miller)
-
-14. LUCENE-1186: Add Analyzer.close() to free internal ThreadLocal
-    resources.  (Christian Kohlschütter via Mike McCandless)
-
-15. LUCENE-1552: Fix IndexWriter.addIndexes(IndexReader[]) to properly
-    rollback IndexWriter's internal state on hitting an
-    exception. (Scott Garland via Mike McCandless)
-
-======================= Release 2.4.0 2008-10-06 =======================
-
-Changes in backwards compatibility policy
-
-1. LUCENE-1340: In a minor change to Lucene's backward compatibility
-   policy, we are now allowing the Fieldable interface to have
-   changes, within reason, and made on a case-by-case basis.  If an
-   application implements it's own Fieldable, please be aware of
-   this.  Otherwise, no need to be concerned.  This is in effect for
-   all 2.X releases, starting with 2.4.  Also note, that in all
-   likelihood, Fieldable will be changed in 3.0.
-
-
-Changes in runtime behavior
-
- 1. LUCENE-1151: Fix StandardAnalyzer to not mis-identify host names
-    (eg lucene.apache.org) as an ACRONYM.  To get back to the pre-2.4
-    backwards compatible, but buggy, behavior, you can either call
-    StandardAnalyzer.setDefaultReplaceInvalidAcronym(false) (static
-    method), or, set system property
-    org.apache.lucene.analysis.standard.StandardAnalyzer.replaceInvalidAcronym
-    to "false" on JVM startup.  All StandardAnalyzer instances created
-    after that will then show the pre-2.4 behavior.  Alternatively,
-    you can call setReplaceInvalidAcronym(false) to change the
-    behavior per instance of StandardAnalyzer.  This backwards
-    compatibility will be removed in 3.0 (hardwiring the value to
-    true).  (Mike McCandless)
-
- 2. LUCENE-1044: IndexWriter with autoCommit=true now commits (such
-    that a reader can see the changes) far less often than it used to.
-    Previously, every flush was also a commit.  You can always force a
-    commit by calling IndexWriter.commit().  Furthermore, in 3.0,
-    autoCommit will be hardwired to false (IndexWriter constructors
-    that take an autoCommit argument have been deprecated) (Mike
-    McCandless)
-
- 3. LUCENE-1335: IndexWriter.addIndexes(Directory[]) and
-    addIndexesNoOptimize no longer allow the same Directory instance
-    to be passed in more than once.  Internally, IndexWriter uses
-    Directory and segment name to uniquely identify segments, so
-    adding the same Directory more than once was causing duplicates
-    which led to problems (Mike McCandless)
-
- 4. LUCENE-1396: Improve PhraseQuery.toString() so that gaps in the
-    positions are indicated with a ? and multiple terms at the same
-    position are joined with a |.  (Andrzej Bialecki via Mike
-    McCandless)
-
-API Changes
-
- 1. LUCENE-1084: Changed all IndexWriter constructors to take an
-    explicit parameter for maximum field size.  Deprecated all the
-    pre-existing constructors; these will be removed in release 3.0.
-    NOTE: these new constructors set autoCommit to false.  (Steven
-    Rowe via Mike McCandless)
-
- 2. LUCENE-584: Changed Filter API to return a DocIdSet instead of a
-    java.util.BitSet. This allows using more efficient data structures
-    for Filters and makes them more flexible. This deprecates
-    Filter.bits(), so all filters that implement this outside
-    the Lucene code base will need to be adapted. See also the javadocs
-    of the Filter class. (Paul Elschot, Michael Busch)
-
- 3. LUCENE-1044: Added IndexWriter.commit() which flushes any buffered
-    adds/deletes and then commits a new segments file so readers will
-    see the changes.  Deprecate IndexWriter.flush() in favor of
-    IndexWriter.commit().  (Mike McCandless)
-
- 4. LUCENE-325: Added IndexWriter.expungeDeletes methods, which
-    consult the MergePolicy to find merges necessary to merge away all
-    deletes from the index.  This should be a somewhat lower cost
-    operation than optimize.  (John Wang via Mike McCandless)
-
- 5. LUCENE-1233: Return empty array instead of null when no fields
-    match the specified name in these methods in Document:
-    getFieldables, getFields, getValues, getBinaryValues.  (Stefan
-    Trcek vai Mike McCandless)
-
- 6. LUCENE-1234: Make BoostingSpanScorer protected.  (Andi Vajda via Grant Ingersoll)
-
- 7. LUCENE-510: The index now stores strings as true UTF-8 bytes
-    (previously it was Java's modified UTF-8).  If any text, either
-    stored fields or a token, has illegal UTF-16 surrogate characters,
-    these characters are now silently replaced with the Unicode
-    replacement character U+FFFD.  This is a change to the index file
-    format.  (Marvin Humphrey via Mike McCandless)
-
- 8. LUCENE-852: Let the SpellChecker caller specify IndexWriter mergeFactor
-    and RAM buffer size.  (Otis Gospodnetic)
-	
- 9. LUCENE-1290: Deprecate org.apache.lucene.search.Hits, Hit and HitIterator
-    and remove all references to these classes from the core. Also update demos
-    and tutorials. (Michael Busch)
-
-10. LUCENE-1288: Add getVersion() and getGeneration() to IndexCommit.
-    getVersion() returns the same value that IndexReader.getVersion()
-    returns when the reader is opened on the same commit.  (Jason
-    Rutherglen via Mike McCandless)
-
-11. LUCENE-1311: Added IndexReader.listCommits(Directory) static
-    method to list all commits in a Directory, plus IndexReader.open
-    methods that accept an IndexCommit and open the index as of that
-    commit.  These methods are only useful if you implement a custom
-    DeletionPolicy that keeps more than the last commit around.
-    (Jason Rutherglen via Mike McCandless)
-
-12. LUCENE-1325: Added IndexCommit.isOptimized().  (Shalin Shekhar
-    Mangar via Mike McCandless)
-
-13. LUCENE-1324: Added TokenFilter.reset(). (Shai Erera via Mike
-    McCandless)
-
-14. LUCENE-1340: Added Fieldable.omitTf() method to skip indexing term
-    frequency, positions and payloads.  This saves index space, and
-    indexing/searching time.  (Eks Dev via Mike McCandless)
-
-15. LUCENE-1219: Add basic reuse API to Fieldable for binary fields:
-    getBinaryValue/Offset/Length(); currently only lazy fields reuse
-    the provided byte[] result to getBinaryValue.  (Eks Dev via Mike
-    McCandless)
-
-16. LUCENE-1334: Add new constructor for Term: Term(String fieldName)
-    which defaults term text to "".  (DM Smith via Mike McCandless)
-
-17. LUCENE-1333: Added Token.reinit(*) APIs to re-initialize (reuse) a
-    Token.  Also added term() method to return a String, with a
-    performance penalty clearly documented.  Also implemented
-    hashCode() and equals() in Token, and fixed all core and contrib
-    analyzers to use the re-use APIs.  (DM Smith via Mike McCandless)
-
-18. LUCENE-1329: Add optional readOnly boolean when opening an
-    IndexReader.  A readOnly reader is not allowed to make changes
-    (deletions, norms) to the index; in exchanged, the isDeleted
-    method, often a bottleneck when searching with many threads, is
-    not synchronized.  The default for readOnly is still false, but in
-    3.0 the default will become true.  (Jason Rutherglen via Mike
-    McCandless)
-
-19. LUCENE-1367: Add IndexCommit.isDeleted().  (Shalin Shekhar Mangar
-    via Mike McCandless)
-
-20. LUCENE-1061: Factored out all "new XXXQuery(...)" in
-    QueryParser.java into protected methods newXXXQuery(...) so that
-    subclasses can create their own subclasses of each Query type.
-    (John Wang via Mike McCandless)
-
-21. LUCENE-753: Added new Directory implementation
-    org.apache.lucene.store.NIOFSDirectory, which uses java.nio's
-    FileChannel to do file reads.  On most non-Windows platforms, with
-    many threads sharing a single searcher, this may yield sizable
-    improvement to query throughput when compared to FSDirectory,
-    which only allows a single thread to read from an open file at a
-    time.  (Jason Rutherglen via Mike McCandless)
-
-22. LUCENE-1371: Added convenience method TopDocs Searcher.search(Query query, int n).
-    (Mike McCandless)
-    
-23. LUCENE-1356: Allow easy extensions of TopDocCollector by turning
-    constructor and fields from package to protected. (Shai Erera
-    via Doron Cohen) 
-
-24. LUCENE-1375: Added convenience method IndexCommit.getTimestamp,
-    which is equivalent to
-    getDirectory().fileModified(getSegmentsFileName()).  (Mike McCandless)
-
-23. LUCENE-1366: Rename Field.Index options to be more accurate:
-    TOKENIZED becomes ANALYZED;  UN_TOKENIZED becomes NOT_ANALYZED;
-    NO_NORMS becomes NOT_ANALYZED_NO_NORMS and a new ANALYZED_NO_NORMS
-    is added.  (Mike McCandless)
-
-24. LUCENE-1131: Added numDeletedDocs method to IndexReader (Otis Gospodnetic)
-
-Bug fixes
-    
- 1. LUCENE-1134: Fixed BooleanQuery.rewrite to only optimize a single 
-    clause query if minNumShouldMatch<=0. (Shai Erera via Michael Busch)
-
- 2. LUCENE-1169: Fixed bug in IndexSearcher.search(): searching with
-    a filter might miss some hits because scorer.skipTo() is called
-    without checking if the scorer is already at the right position.
-    scorer.skipTo(scorer.doc()) is not a NOOP, it behaves as 
-    scorer.next(). (Eks Dev, Michael Busch)
-
- 3. LUCENE-1182: Added scorePayload to SimilarityDelegator (Andi Vajda via Grant Ingersoll)
- 
- 4. LUCENE-1213: MultiFieldQueryParser was ignoring slop in case
-    of a single field phrase. (Trejkaz via Doron Cohen)
-
- 5. LUCENE-1228: IndexWriter.commit() was not updating the index version and as
-    result IndexReader.reopen() failed to sense index changes. (Doron Cohen)
-
- 6. LUCENE-1267: Added numDocs() and maxDoc() to IndexWriter;
-    deprecated docCount().  (Mike McCandless)
-
- 7. LUCENE-1274: Added new prepareCommit() method to IndexWriter,
-    which does phase 1 of a 2-phase commit (commit() does phase 2).
-    This is needed when you want to update an index as part of a
-    transaction involving external resources (eg a database).  Also
-    deprecated abort(), renaming it to rollback().  (Mike McCandless)
-
- 8. LUCENE-1003: Stop RussianAnalyzer from removing numbers.
-    (TUSUR OpenTeam, Dmitry Lihachev via Otis Gospodnetic)
-
- 9. LUCENE-1152: SpellChecker fix around clearIndex and indexDictionary
-    methods, plus removal of IndexReader reference.
-    (Naveen Belkale via Otis Gospodnetic)
-
-10. LUCENE-1046: Removed dead code in SpellChecker
-    (Daniel Naber via Otis Gospodnetic)
-	
-11. LUCENE-1189: Fixed the QueryParser to handle escaped characters within 
-    quoted terms correctly. (Tomer Gabel via Michael Busch)
-
-12. LUCENE-1299: Fixed NPE in SpellChecker when IndexReader is not null and field is (Grant Ingersoll)
-
-13. LUCENE-1303: Fixed BoostingTermQuery's explanation to be marked as a Match 
-    depending only upon the non-payload score part, regardless of the effect of 
-    the payload on the score. Prior to this, score of a query containing a BTQ 
-    differed from its explanation. (Doron Cohen)
-    
-14. LUCENE-1310: Fixed SloppyPhraseScorer to work also for terms repeating more 
-    than twice in the query. (Doron Cohen)
-
-15. LUCENE-1351: ISOLatin1AccentFilter now cleans additional ligatures (Cedrik Lime via Grant Ingersoll)
-
-16. LUCENE-1383: Workaround a nasty "leak" in Java's builtin
-    ThreadLocal, to prevent Lucene from causing unexpected
-    OutOfMemoryError in certain situations (notably J2EE
-    applications).  (Chris Lu via Mike McCandless)
-
-New features
-
- 1. LUCENE-1137: Added Token.set/getFlags() accessors for passing more information about a Token through the analysis
-    process.  The flag is not indexed/stored and is thus only used by analysis.
-
- 2. LUCENE-1147: Add -segment option to CheckIndex tool so you can
-    check only a specific segment or segments in your index.  (Mike
-    McCandless)
-
- 3. LUCENE-1045: Reopened this issue to add support for short and bytes. 
- 
- 4. LUCENE-584: Added new data structures to o.a.l.util, such as 
-    OpenBitSet and SortedVIntList. These extend DocIdSet and can 
-    directly be used for Filters with the new Filter API. Also changed
-    the core Filters to use OpenBitSet instead of java.util.BitSet.
-    (Paul Elschot, Michael Busch)
-
- 5. LUCENE-494: Added QueryAutoStopWordAnalyzer to allow for the automatic removal, from a query of frequently occurring terms.
-    This Analyzer is not intended for use during indexing. (Mark Harwood via Grant Ingersoll)
-
- 6. LUCENE-1044: Change Lucene to properly "sync" files after
-    committing, to ensure on a machine or OS crash or power cut, even
-    with cached writes, the index remains consistent.  Also added
-    explicit commit() method to IndexWriter to force a commit without
-    having to close.  (Mike McCandless)
-    
- 7. LUCENE-997: Add search timeout (partial) support.
-    A TimeLimitedCollector was added to allow limiting search time.
-    It is a partial solution since timeout is checked only when 
-    collecting a hit, and therefore a search for rare words in a 
-    huge index might not stop within the specified time.
-    (Sean Timm via Doron Cohen) 
-
- 8. LUCENE-1184: Allow SnapshotDeletionPolicy to be re-used across
-    close/re-open of IndexWriter while still protecting an open
-    snapshot (Tim Brennan via Mike McCandless)
-
- 9. LUCENE-1194: Added IndexWriter.deleteDocuments(Query) to delete
-    documents matching the specified query.  Also added static unlock
-    and isLocked methods (deprecating the ones in IndexReader).  (Mike
-    McCandless)
-
-10. LUCENE-1201: Add IndexReader.getIndexCommit() method. (Tim Brennan
-    via Mike McCandless)
-
-11. LUCENE-550:  Added InstantiatedIndex implementation.  Experimental 
-    Index store similar to MemoryIndex but allows for multiple documents 
-    in memory.  (Karl Wettin via Grant Ingersoll)
-
-12. LUCENE-400: Added word based n-gram filter (in contrib/analyzers) called ShingleFilter and an Analyzer wrapper
-    that wraps another Analyzer's token stream with a ShingleFilter (Sebastian Kirsch, Steve Rowe via Grant Ingersoll) 
-
-13. LUCENE-1166: Decomposition tokenfilter for languages like German and Swedish (Thomas Peuss via Grant Ingersoll)
-
-14. LUCENE-1187: ChainedFilter and BooleanFilter now work with new Filter API
-    and DocIdSetIterator-based filters. Backwards-compatibility with old 
-    BitSet-based filters is ensured. (Paul Elschot via Michael Busch)
-
-15. LUCENE-1295: Added new method to MoreLikeThis for retrieving interesting terms and made retrieveTerms(int) public. (Grant Ingersoll)
-
-16. LUCENE-1298: MoreLikeThis can now accept a custom Similarity (Grant Ingersoll)
-
-17. LUCENE-1297: Allow other string distance measures for the SpellChecker
-    (Thomas Morton via Otis Gospodnetic)
-
-18. LUCENE-1001: Provide access to Payloads via Spans.  All existing Span Query implementations in Lucene implement. (Mark Miller, Grant Ingersoll)
-
-19. LUCENE-1354: Provide programmatic access to CheckIndex (Grant Ingersoll, Mike McCandless)
-
-20. LUCENE-1279: Add support for Collators to RangeFilter/Query and Query Parser.  (Steve Rowe via Grant Ingersoll) 
-
-Optimizations
-
- 1. LUCENE-705: When building a compound file, use
-    RandomAccessFile.setLength() to tell the OS/filesystem to
-    pre-allocate space for the file.  This may improve fragmentation
-    in how the CFS file is stored, and allows us to detect an upcoming
-    disk full situation before actually filling up the disk.  (Mike
-    McCandless)
-
- 2. LUCENE-1120: Speed up merging of term vectors by bulk-copying the
-    raw bytes for each contiguous range of non-deleted documents.
-    (Mike McCandless)
-	
- 3. LUCENE-1185: Avoid checking if the TermBuffer 'scratch' in 
-    SegmentTermEnum is null for every call of scanTo().
-    (Christian Kohlschuetter via Michael Busch)
-
- 4. LUCENE-1217: Internal to Field.java, use isBinary instead of
-    runtime type checking for possible speedup of binaryValue().
-    (Eks Dev via Mike McCandless)
-
- 5. LUCENE-1183: Optimized TRStringDistance class (in contrib/spell) that uses
-    less memory than the previous version.  (Cédrik LIME via Otis Gospodnetic)
-
- 6. LUCENE-1195: Improve term lookup performance by adding a LRU cache to the
-    TermInfosReader. In performance experiments the speedup was about 25% on 
-    average on mid-size indexes with ~500,000 documents for queries with 3 
-    terms and about 7% on larger indexes with ~4.3M documents. (Michael Busch)
-
-Documentation
-
-  1. LUCENE-1236:  Added some clarifying remarks to EdgeNGram*.java (Hiroaki Kawai via Grant Ingersoll)
-  
-  2. LUCENE-1157 and LUCENE-1256: HTML changes log, created automatically 
-     from CHANGES.txt. This HTML file is currently visible only via developers page.     
-     (Steven Rowe via Doron Cohen)
-
-  3. LUCENE-1349: Fieldable can now be changed without breaking backward compatibility rules (within reason.  See the note at
-  the top of this file and also on Fieldable.java).  (Grant Ingersoll)
-  
-  4. LUCENE-1873: Update documentation to reflect current Contrib area status.
-     (Steven Rowe, Mark Miller)
-
-Build
-
-  1. LUCENE-1153: Added JUnit JAR to new lib directory.  Updated build to rely on local JUnit instead of ANT/lib.
-  
-  2. LUCENE-1202: Small fixes to the way Clover is used to work better
-     with contribs.  Of particular note: a single clover db is used
-     regardless of whether tests are run globally or in the specific
-     contrib directories. 
-     
-  3. LUCENE-1353: Javacc target in contrib/miscellaneous for 
-     generating the precedence query parser. 
-
-Test Cases
-
- 1. LUCENE-1238: Fixed intermittent failures of TestTimeLimitedCollector.testTimeoutMultiThreaded.
-    Within this fix, "greedy" flag was added to TimeLimitedCollector, to allow the wrapped 
-    collector to collect also the last doc, after allowed-tTime passed. (Doron Cohen)   
-	
- 2. LUCENE-1348: relax TestTimeLimitedCollector to not fail due to 
-    timeout exceeded (just because test machine is very busy).
-	
-======================= Release 2.3.2 2008-05-05 =======================
-
-Bug fixes
-
- 1. LUCENE-1191: On hitting OutOfMemoryError in any index-modifying
-    methods in IndexWriter, do not commit any further changes to the
-    index to prevent risk of possible corruption.  (Mike McCandless)
-
- 2. LUCENE-1197: Fixed issue whereby IndexWriter would flush by RAM
-    too early when TermVectors were in use.  (Mike McCandless)
-
- 3. LUCENE-1198: Don't corrupt index if an exception happens inside
-    DocumentsWriter.init (Mike McCandless)
-
- 4. LUCENE-1199: Added defensive check for null indexReader before
-    calling close in IndexModifier.close() (Mike McCandless)
-
- 5. LUCENE-1200: Fix rare deadlock case in addIndexes* when
-    ConcurrentMergeScheduler is in use (Mike McCandless)
-
- 6. LUCENE-1208: Fix deadlock case on hitting an exception while
-    processing a document that had triggered a flush (Mike McCandless)
-
- 7. LUCENE-1210: Fix deadlock case on hitting an exception while
-    starting a merge when using ConcurrentMergeScheduler (Mike McCandless)
-
- 8. LUCENE-1222: Fix IndexWriter.doAfterFlush to always be called on
-    flush (Mark Ferguson via Mike McCandless)
-	
- 9. LUCENE-1226: Fixed IndexWriter.addIndexes(IndexReader[]) to commit
-    successfully created compound files. (Michael Busch)
-
-10. LUCENE-1150: Re-expose StandardTokenizer's constants publicly;
-    this was accidentally lost with LUCENE-966.  (Nicolas Lalevée via
-    Mike McCandless)
-
-11. LUCENE-1262: Fixed bug in BufferedIndexReader.refill whereby on
-    hitting an exception in readInternal, the buffer is incorrectly
-    filled with stale bytes such that subsequent calls to readByte()
-    return incorrect results.  (Trejkaz via Mike McCandless)
-
-12. LUCENE-1270: Fixed intermittent case where IndexWriter.close()
-    would hang after IndexWriter.addIndexesNoOptimize had been
-    called.  (Stu Hood via Mike McCandless)
-	
-Build
-
- 1. LUCENE-1230: Include *pom.xml* in source release files. (Michael Busch)
-
- 
-======================= Release 2.3.1 2008-02-22 =======================
-
-Bug fixes
-    
- 1. LUCENE-1168: Fixed corruption cases when autoCommit=false and
-    documents have mixed term vectors (Suresh Guvvala via Mike
-    McCandless).
-
- 2. LUCENE-1171: Fixed some cases where OOM errors could cause
-    deadlock in IndexWriter (Mike McCandless).
-
- 3. LUCENE-1173: Fixed corruption case when autoCommit=false and bulk
-    merging of stored fields is used (Yonik via Mike McCandless).
-
- 4. LUCENE-1163: Fixed bug in CharArraySet.contains(char[] buffer, int
-    offset, int len) that was ignoring offset and thus giving the
-    wrong answer.  (Thomas Peuss via Mike McCandless)
-	
- 5. LUCENE-1177: Fix rare case where IndexWriter.optimize might do too
-    many merges at the end.  (Mike McCandless)
-	
- 6. LUCENE-1176: Fix corruption case when documents with no term
-    vector fields are added before documents with term vector fields.
-    (Mike McCandless)
-	
- 7. LUCENE-1179: Fixed assert statement that was incorrectly
-    preventing Fields with empty-string field name from working.
-    (Sergey Kabashnyuk via Mike McCandless)
-
-======================= Release 2.3.0 2008-01-21 =======================
-
-Changes in runtime behavior
-
- 1. LUCENE-994: Defaults for IndexWriter have been changed to maximize
-    out-of-the-box indexing speed.  First, IndexWriter now flushes by
-    RAM usage (16 MB by default) instead of a fixed doc count (call
-    IndexWriter.setMaxBufferedDocs to get backwards compatible
-    behavior).  Second, ConcurrentMergeScheduler is used to run merges
-    using background threads (call IndexWriter.setMergeScheduler(new
-    SerialMergeScheduler()) to get backwards compatible behavior).
-    Third, merges are chosen based on size in bytes of each segment
-    rather than document count of each segment (call
-    IndexWriter.setMergePolicy(new LogDocMergePolicy()) to get
-    backwards compatible behavior).
-
-    NOTE: users of ParallelReader must change back all of these
-    defaults in order to ensure the docIDs "align" across all parallel
-    indices.
-
-    (Mike McCandless)
-
- 2. LUCENE-1045: SortField.AUTO didn't work with long. When detecting
-    the field type for sorting automatically, numbers used to be
-    interpreted as int, then as float, if parsing the number as an int
-    failed. Now the detection checks for int, then for long,
-    then for float. (Daniel Naber)
-
-API Changes
-
- 1. LUCENE-843: Added IndexWriter.setRAMBufferSizeMB(...) to have
-    IndexWriter flush whenever the buffered documents are using more
-    than the specified amount of RAM.  Also added new APIs to Token
-    that allow one to set a char[] plus offset and length to specify a
-    token (to avoid creating a new String() for each Token).  (Mike
-    McCandless)
-
- 2. LUCENE-963: Add setters to Field to allow for re-using a single
-    Field instance during indexing.  This is a sizable performance
-    gain, especially for small documents.  (Mike McCandless)
-
- 3. LUCENE-969: Add new APIs to Token, TokenStream and Analyzer to
-    permit re-using of Token and TokenStream instances during
-    indexing.  Changed Token to use a char[] as the store for the
-    termText instead of String.  This gives faster tokenization
-    performance (~10-15%).  (Mike McCandless)
-
- 4. LUCENE-847: Factored MergePolicy, which determines which merges
-    should take place and when, as well as MergeScheduler, which
-    determines when the selected merges should actually run, out of
-    IndexWriter.  The default merge policy is now
-    LogByteSizeMergePolicy (see LUCENE-845) and the default merge
-    scheduler is now ConcurrentMergeScheduler (see
-    LUCENE-870). (Steven Parkes via Mike McCandless)
-
- 5. LUCENE-1052: Add IndexReader.setTermInfosIndexDivisor(int) method
-    that allows you to reduce memory usage of the termInfos by further
-    sub-sampling (over the termIndexInterval that was used during
-    indexing) which terms are loaded into memory.  (Chuck Williams,
-    Doug Cutting via Mike McCandless)
-    
- 6. LUCENE-743: Add IndexReader.reopen() method that re-opens an
-    existing IndexReader (see New features -> 8.) (Michael Busch)
-
- 7. LUCENE-1062: Add setData(byte[] data), 
-    setData(byte[] data, int offset, int length), getData(), getOffset()
-    and clone() methods to o.a.l.index.Payload. Also add the field name 
-    as arg to Similarity.scorePayload(). (Michael Busch)
-
- 8. LUCENE-982: Add IndexWriter.optimize(int maxNumSegments) method to
-    "partially optimize" an index down to maxNumSegments segments.
-    (Mike McCandless)
-
- 9. LUCENE-1080: Changed Token.DEFAULT_TYPE to be public.
-
-10. LUCENE-1064: Changed TopDocs constructor to be public. 
-     (Shai Erera via Michael Busch)
-
-11. LUCENE-1079: DocValues cleanup: constructor now has no params,
-    and getInnerArray() now throws UnsupportedOperationException (Doron Cohen)
-
-12. LUCENE-1089: Added PriorityQueue.insertWithOverflow, which returns
-    the Object (if any) that was bumped from the queue to allow
-    re-use.  (Shai Erera via Mike McCandless)
-    
-13. LUCENE-1101: Token reuse 'contract' (defined LUCENE-969)
-    modified so it is token producer's responsibility
-    to call Token.clear(). (Doron Cohen)   
-
-14. LUCENE-1118: Changed StandardAnalyzer to skip too-long (default >
-    255 characters) tokens.  You can increase this limit by calling
-    StandardAnalyzer.setMaxTokenLength(...).  (Michael McCandless)
-
-
-Bug fixes
-
- 1. LUCENE-933: QueryParser fixed to not produce empty sub 
-    BooleanQueries "()" even if the Analyzer produced no 
-    tokens for input. (Doron Cohen)
-
- 2. LUCENE-955: Fixed SegmentTermPositions to work correctly with the
-    first term in the dictionary. (Michael Busch)
-
- 3. LUCENE-951: Fixed NullPointerException in MultiLevelSkipListReader
-    that was thrown after a call of TermPositions.seek(). 
-    (Rich Johnson via Michael Busch)
-    
- 4. LUCENE-938: Fixed cases where an unhandled exception in
-    IndexWriter's methods could cause deletes to be lost.
-    (Steven Parkes via Mike McCandless)
-      
- 5. LUCENE-962: Fixed case where an unhandled exception in
-    IndexWriter.addDocument or IndexWriter.updateDocument could cause
-    unreferenced files in the index to not be deleted
-    (Steven Parkes via Mike McCandless)
-  
- 6. LUCENE-957: RAMDirectory fixed to properly handle directories
-    larger than Integer.MAX_VALUE. (Doron Cohen)
-
- 7. LUCENE-781: MultiReader fixed to not throw NPE if isCurrent(),
-    isOptimized() or getVersion() is called. Separated MultiReader
-    into two classes: MultiSegmentReader extends IndexReader, is
-    package-protected and is created automatically by IndexReader.open()
-    in case the index has multiple segments. The public MultiReader 
-    now extends MultiSegmentReader and is intended to be used by users
-    who want to add their own subreaders. (Daniel Naber, Michael Busch)
-
- 8. LUCENE-970: FilterIndexReader now implements isOptimized(). Before
-    a call of isOptimized() would throw a NPE. (Michael Busch)
-
- 9. LUCENE-832: ParallelReader fixed to not throw NPE if isCurrent(),
-    isOptimized() or getVersion() is called. (Michael Busch)
-      
-10. LUCENE-948: Fix FNFE exception caused by stale NFS client
-    directory listing caches when writers on different machines are
-    sharing an index over NFS and using a custom deletion policy (Mike
-    McCandless)
-
-11. LUCENE-978: Ensure TermInfosReader, FieldsReader, and FieldsReader
-    close any streams they had opened if an 

<TRUNCATED>

[29/51] [abbrv] [partial] Cleaning up and getting ready to development towards v4.8

Posted by sy...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/NUnit/Latest/nunit.framework.xml
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/NUnit/Latest/nunit.framework.xml b/lib/Gallio.3.2.750/tools/NUnit/Latest/nunit.framework.xml
deleted file mode 100644
index b9e1dd0..0000000
--- a/lib/Gallio.3.2.750/tools/NUnit/Latest/nunit.framework.xml
+++ /dev/null
@@ -1,10385 +0,0 @@
-<?xml version="1.0"?>
-<doc>
-    <assembly>
-        <name>nunit.framework</name>
-    </assembly>
-    <members>
-        <member name="T:NUnit.Framework.CategoryAttribute">
-            <summary>
-            Attribute used to apply a category to a test
-            </summary>
-        </member>
-        <member name="F:NUnit.Framework.CategoryAttribute.categoryName">
-            <summary>
-            The name of the category
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.CategoryAttribute.#ctor(System.String)">
-            <summary>
-            Construct attribute for a given category based on
-            a name. The name may not contain the characters ',',
-            '+', '-' or '!'. However, this is not checked in the
-            constructor since it would cause an error to arise at
-            as the test was loaded without giving a clear indication
-            of where the problem is located. The error is handled
-            in NUnitFramework.cs by marking the test as not
-            runnable.
-            </summary>
-            <param name="name">The name of the category</param>
-        </member>
-        <member name="M:NUnit.Framework.CategoryAttribute.#ctor">
-            <summary>
-            Protected constructor uses the Type name as the name
-            of the category.
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.CategoryAttribute.Name">
-            <summary>
-            The name of the category
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.DatapointAttribute">
-            <summary>
-            Used to mark a field for use as a datapoint when executing a theory
-            within the same fixture that requires an argument of the field's Type.
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.DatapointsAttribute">
-            <summary>
-            Used to mark an array as containing a set of datapoints to be used
-            executing a theory within the same fixture that requires an argument 
-            of the Type of the array elements.
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.DescriptionAttribute">
-            <summary>
-            Attribute used to provide descriptive text about a 
-            test case or fixture.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.DescriptionAttribute.#ctor(System.String)">
-            <summary>
-            Construct the attribute
-            </summary>
-            <param name="description">Text describing the test</param>
-        </member>
-        <member name="P:NUnit.Framework.DescriptionAttribute.Description">
-            <summary>
-            Gets the test description
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.MessageMatch">
-            <summary>
-            Enumeration indicating how the expected message parameter is to be used
-            </summary>
-        </member>
-        <member name="F:NUnit.Framework.MessageMatch.Exact">
-            Expect an exact match
-        </member>
-        <member name="F:NUnit.Framework.MessageMatch.Contains">
-            Expect a message containing the parameter string
-        </member>
-        <member name="F:NUnit.Framework.MessageMatch.Regex">
-            Match the regular expression provided as a parameter
-        </member>
-        <member name="F:NUnit.Framework.MessageMatch.StartsWith">
-            Expect a message that starts with the parameter string
-        </member>
-        <member name="T:NUnit.Framework.ExpectedExceptionAttribute">
-            <summary>
-            ExpectedExceptionAttribute
-            </summary>
-            
-        </member>
-        <member name="M:NUnit.Framework.ExpectedExceptionAttribute.#ctor">
-            <summary>
-            Constructor for a non-specific exception
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.ExpectedExceptionAttribute.#ctor(System.Type)">
-            <summary>
-            Constructor for a given type of exception
-            </summary>
-            <param name="exceptionType">The type of the expected exception</param>
-        </member>
-        <member name="M:NUnit.Framework.ExpectedExceptionAttribute.#ctor(System.String)">
-            <summary>
-            Constructor for a given exception name
-            </summary>
-            <param name="exceptionName">The full name of the expected exception</param>
-        </member>
-        <member name="P:NUnit.Framework.ExpectedExceptionAttribute.ExpectedException">
-            <summary>
-            Gets or sets the expected exception type
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.ExpectedExceptionAttribute.ExpectedExceptionName">
-            <summary>
-            Gets or sets the full Type name of the expected exception
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.ExpectedExceptionAttribute.ExpectedMessage">
-            <summary>
-            Gets or sets the expected message text
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.ExpectedExceptionAttribute.UserMessage">
-            <summary>
-            Gets or sets the user message displayed in case of failure
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.ExpectedExceptionAttribute.MatchType">
-            <summary>
-             Gets or sets the type of match to be performed on the expected message
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.ExpectedExceptionAttribute.Handler">
-            <summary>
-             Gets the name of a method to be used as an exception handler
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.ExplicitAttribute">
-            <summary>
-            ExplicitAttribute marks a test or test fixture so that it will
-            only be run if explicitly executed from the gui or command line
-            or if it is included by use of a filter. The test will not be
-            run simply because an enclosing suite is run.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.ExplicitAttribute.#ctor">
-            <summary>
-            Default constructor
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.ExplicitAttribute.#ctor(System.String)">
-            <summary>
-            Constructor with a reason
-            </summary>
-            <param name="reason">The reason test is marked explicit</param>
-        </member>
-        <member name="P:NUnit.Framework.ExplicitAttribute.Reason">
-            <summary>
-            The reason test is marked explicit
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.IgnoreAttribute">
-            <summary>
-            Attribute used to mark a test that is to be ignored.
-            Ignored tests result in a warning message when the
-            tests are run.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.IgnoreAttribute.#ctor">
-            <summary>
-            Constructs the attribute without giving a reason 
-            for ignoring the test.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.IgnoreAttribute.#ctor(System.String)">
-            <summary>
-            Constructs the attribute giving a reason for ignoring the test
-            </summary>
-            <param name="reason">The reason for ignoring the test</param>
-        </member>
-        <member name="P:NUnit.Framework.IgnoreAttribute.Reason">
-            <summary>
-            The reason for ignoring a test
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.IncludeExcludeAttribute">
-            <summary>
-            Abstract base for Attributes that are used to include tests
-            in the test run based on environmental settings.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.IncludeExcludeAttribute.#ctor">
-            <summary>
-            Constructor with no included items specified, for use
-            with named property syntax.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.IncludeExcludeAttribute.#ctor(System.String)">
-            <summary>
-            Constructor taking one or more included items
-            </summary>
-            <param name="include">Comma-delimited list of included items</param>
-        </member>
-        <member name="P:NUnit.Framework.IncludeExcludeAttribute.Include">
-            <summary>
-            Name of the item that is needed in order for
-            a test to run. Multiple itemss may be given,
-            separated by a comma.
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.IncludeExcludeAttribute.Exclude">
-            <summary>
-            Name of the item to be excluded. Multiple items
-            may be given, separated by a comma.
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.IncludeExcludeAttribute.Reason">
-            <summary>
-            The reason for including or excluding the test
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.PlatformAttribute">
-            <summary>
-            PlatformAttribute is used to mark a test fixture or an
-            individual method as applying to a particular platform only.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.PlatformAttribute.#ctor">
-            <summary>
-            Constructor with no platforms specified, for use
-            with named property syntax.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.PlatformAttribute.#ctor(System.String)">
-            <summary>
-            Constructor taking one or more platforms
-            </summary>
-            <param name="platforms">Comma-deliminted list of platforms</param>
-        </member>
-        <member name="T:NUnit.Framework.CultureAttribute">
-            <summary>
-            CultureAttribute is used to mark a test fixture or an
-            individual method as applying to a particular Culture only.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.CultureAttribute.#ctor">
-            <summary>
-            Constructor with no cultures specified, for use
-            with named property syntax.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.CultureAttribute.#ctor(System.String)">
-            <summary>
-            Constructor taking one or more cultures
-            </summary>
-            <param name="cultures">Comma-deliminted list of cultures</param>
-        </member>
-        <member name="T:NUnit.Framework.CombinatorialAttribute">
-            <summary>
-            Marks a test to use a combinatorial join of any argument data 
-            provided. NUnit will create a test case for every combination of 
-            the arguments provided. This can result in a large number of test
-            cases and so should be used judiciously. This is the default join
-            type, so the attribute need not be used except as documentation.
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.PropertyAttribute">
-            <summary>
-            PropertyAttribute is used to attach information to a test as a name/value pair..
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.PropertyAttribute.#ctor(System.String,System.String)">
-            <summary>
-            Construct a PropertyAttribute with a name and string value
-            </summary>
-            <param name="propertyName">The name of the property</param>
-            <param name="propertyValue">The property value</param>
-        </member>
-        <member name="M:NUnit.Framework.PropertyAttribute.#ctor(System.String,System.Int32)">
-            <summary>
-            Construct a PropertyAttribute with a name and int value
-            </summary>
-            <param name="propertyName">The name of the property</param>
-            <param name="propertyValue">The property value</param>
-        </member>
-        <member name="M:NUnit.Framework.PropertyAttribute.#ctor(System.String,System.Double)">
-            <summary>
-            Construct a PropertyAttribute with a name and double value
-            </summary>
-            <param name="propertyName">The name of the property</param>
-            <param name="propertyValue">The property value</param>
-        </member>
-        <member name="M:NUnit.Framework.PropertyAttribute.#ctor">
-            <summary>
-            Constructor for derived classes that set the
-            property dictionary directly.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.PropertyAttribute.#ctor(System.Object)">
-            <summary>
-            Constructor for use by derived classes that use the
-            name of the type as the property name. Derived classes
-            must ensure that the Type of the property value is
-            a standard type supported by the BCL. Any custom
-            types will cause a serialization Exception when
-            in the client.
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.PropertyAttribute.Properties">
-            <summary>
-            Gets the property dictionary for this attribute
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.CombinatorialAttribute.#ctor">
-            <summary>
-            Default constructor
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.PairwiseAttribute">
-            <summary>
-            Marks a test to use pairwise join of any argument data provided. 
-            NUnit will attempt too excercise every pair of argument values at 
-            least once, using as small a number of test cases as it can. With
-            only two arguments, this is the same as a combinatorial join.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.PairwiseAttribute.#ctor">
-            <summary>
-            Default constructor
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.SequentialAttribute">
-            <summary>
-            Marks a test to use a sequential join of any argument data
-            provided. NUnit will use arguements for each parameter in
-            sequence, generating test cases up to the largest number
-            of argument values provided and using null for any arguments
-            for which it runs out of values. Normally, this should be
-            used with the same number of arguments for each parameter.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.SequentialAttribute.#ctor">
-            <summary>
-            Default constructor
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.MaxTimeAttribute">
-            <summary>
-            Summary description for MaxTimeAttribute.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.MaxTimeAttribute.#ctor(System.Int32)">
-            <summary>
-            Construct a MaxTimeAttribute, given a time in milliseconds.
-            </summary>
-            <param name="milliseconds">The maximum elapsed time in milliseconds</param>
-        </member>
-        <member name="T:NUnit.Framework.RandomAttribute">
-            <summary>
-            RandomAttribute is used to supply a set of random values
-            to a single parameter of a parameterized test.
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.ValuesAttribute">
-            <summary>
-            ValuesAttribute is used to provide literal arguments for
-            an individual parameter of a test.
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.ParameterDataAttribute">
-            <summary>
-            Abstract base class for attributes that apply to parameters 
-            and supply data for the parameter.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.ParameterDataAttribute.GetData(System.Reflection.ParameterInfo)">
-            <summary>
-            Gets the data to be provided to the specified parameter
-            </summary>
-        </member>
-        <member name="F:NUnit.Framework.ValuesAttribute.data">
-            <summary>
-            The collection of data to be returned. Must
-            be set by any derived attribute classes.
-            We use an object[] so that the individual
-            elements may have their type changed in GetData
-            if necessary.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.ValuesAttribute.#ctor(System.Object)">
-            <summary>
-            Construct with one argument
-            </summary>
-            <param name="arg1"></param>
-        </member>
-        <member name="M:NUnit.Framework.ValuesAttribute.#ctor(System.Object,System.Object)">
-            <summary>
-            Construct with two arguments
-            </summary>
-            <param name="arg1"></param>
-            <param name="arg2"></param>
-        </member>
-        <member name="M:NUnit.Framework.ValuesAttribute.#ctor(System.Object,System.Object,System.Object)">
-            <summary>
-            Construct with three arguments
-            </summary>
-            <param name="arg1"></param>
-            <param name="arg2"></param>
-            <param name="arg3"></param>
-        </member>
-        <member name="M:NUnit.Framework.ValuesAttribute.#ctor(System.Object[])">
-            <summary>
-            Construct with an array of arguments
-            </summary>
-            <param name="args"></param>
-        </member>
-        <member name="M:NUnit.Framework.ValuesAttribute.GetData(System.Reflection.ParameterInfo)">
-            <summary>
-            Get the collection of values to be used as arguments
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.RandomAttribute.#ctor(System.Int32)">
-            <summary>
-            Construct a set of doubles from 0.0 to 1.0,
-            specifying only the count.
-            </summary>
-            <param name="count"></param>
-        </member>
-        <member name="M:NUnit.Framework.RandomAttribute.#ctor(System.Double,System.Double,System.Int32)">
-            <summary>
-            Construct a set of doubles from min to max
-            </summary>
-            <param name="min"></param>
-            <param name="max"></param>
-            <param name="count"></param>
-        </member>
-        <member name="M:NUnit.Framework.RandomAttribute.#ctor(System.Int32,System.Int32,System.Int32)">
-            <summary>
-            Construct a set of ints from min to max
-            </summary>
-            <param name="min"></param>
-            <param name="max"></param>
-            <param name="count"></param>
-        </member>
-        <member name="M:NUnit.Framework.RandomAttribute.GetData(System.Reflection.ParameterInfo)">
-            <summary>
-            Get the collection of values to be used as arguments
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.RangeAttribute">
-            <summary>
-            RangeAttribute is used to supply a range of values to an
-            individual parameter of a parameterized test.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.RangeAttribute.#ctor(System.Int32,System.Int32)">
-            <summary>
-            Construct a range of ints using default step of 1
-            </summary>
-            <param name="from"></param>
-            <param name="to"></param>
-        </member>
-        <member name="M:NUnit.Framework.RangeAttribute.#ctor(System.Int32,System.Int32,System.Int32)">
-            <summary>
-            Construct a range of ints specifying the step size 
-            </summary>
-            <param name="from"></param>
-            <param name="to"></param>
-            <param name="step"></param>
-        </member>
-        <member name="M:NUnit.Framework.RangeAttribute.#ctor(System.Int64,System.Int64,System.Int64)">
-            <summary>
-            Construct a range of longs
-            </summary>
-            <param name="from"></param>
-            <param name="to"></param>
-            <param name="step"></param>
-        </member>
-        <member name="M:NUnit.Framework.RangeAttribute.#ctor(System.Double,System.Double,System.Double)">
-            <summary>
-            Construct a range of doubles
-            </summary>
-            <param name="from"></param>
-            <param name="to"></param>
-            <param name="step"></param>
-        </member>
-        <member name="M:NUnit.Framework.RangeAttribute.#ctor(System.Single,System.Single,System.Single)">
-            <summary>
-            Construct a range of floats
-            </summary>
-            <param name="from"></param>
-            <param name="to"></param>
-            <param name="step"></param>
-        </member>
-        <member name="T:NUnit.Framework.RepeatAttribute">
-            <summary>
-            RepeatAttribute may be applied to test case in order
-            to run it multiple times.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.RepeatAttribute.#ctor(System.Int32)">
-            <summary>
-            Construct a RepeatAttribute
-            </summary>
-            <param name="count">The number of times to run the test</param>
-        </member>
-        <member name="T:NUnit.Framework.RequiredAddinAttribute">
-            <summary>
-            RequiredAddinAttribute may be used to indicate the names of any addins
-            that must be present in order to run some or all of the tests in an
-            assembly. If the addin is not loaded, the entire assembly is marked
-            as NotRunnable.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.RequiredAddinAttribute.#ctor(System.String)">
-            <summary>
-            Initializes a new instance of the <see cref="T:RequiredAddinAttribute"/> class.
-            </summary>
-            <param name="requiredAddin">The required addin.</param>
-        </member>
-        <member name="P:NUnit.Framework.RequiredAddinAttribute.RequiredAddin">
-            <summary>
-            Gets the name of required addin.
-            </summary>
-            <value>The required addin name.</value>
-        </member>
-        <member name="T:NUnit.Framework.SetCultureAttribute">
-            <summary>
-            Summary description for SetCultureAttribute.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.SetCultureAttribute.#ctor(System.String)">
-            <summary>
-            Construct given the name of a culture
-            </summary>
-            <param name="culture"></param>
-        </member>
-        <member name="T:NUnit.Framework.SetUICultureAttribute">
-            <summary>
-            Summary description for SetUICultureAttribute.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.SetUICultureAttribute.#ctor(System.String)">
-            <summary>
-            Construct given the name of a culture
-            </summary>
-            <param name="culture"></param>
-        </member>
-        <member name="T:NUnit.Framework.SetUpAttribute">
-            <summary>
-            Attribute used to mark a class that contains one-time SetUp 
-            and/or TearDown methods that apply to all the tests in a
-            namespace or an assembly.
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.SetUpFixtureAttribute">
-            <summary>
-            SetUpFixtureAttribute is used to identify a SetUpFixture
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.SuiteAttribute">
-            <summary>
-            Attribute used to mark a static (shared in VB) property
-            that returns a list of tests.
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.TearDownAttribute">
-            <summary>
-            Attribute used to identify a method that is called 
-            immediately after each test is run. The method is 
-            guaranteed to be called, even if an exception is thrown.
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.TestAttribute">
-            <summary>
-            Adding this attribute to a method within a <seealso cref="T:NUnit.Framework.TestFixtureAttribute"/> 
-            class makes the method callable from the NUnit test runner. There is a property 
-            called Description which is optional which you can provide a more detailed test
-            description. This class cannot be inherited.
-            </summary>
-            
-            <example>
-            [TestFixture]
-            public class Fixture
-            {
-              [Test]
-              public void MethodToTest()
-              {}
-              
-              [Test(Description = "more detailed description")]
-              publc void TestDescriptionMethod()
-              {}
-            }
-            </example>
-            
-        </member>
-        <member name="P:NUnit.Framework.TestAttribute.Description">
-            <summary>
-            Descriptive text for this test
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.TestCaseAttribute">
-            <summary>
-            TestCaseAttribute is used to mark parameterized test cases
-            and provide them with their arguments.
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.ITestCaseData">
-            <summary>
-            The ITestCaseData interface is implemented by a class
-            that is able to return complete testcases for use by
-            a parameterized test method.
-            
-            NOTE: This interface is used in both the framework
-            and the core, even though that results in two different
-            types. However, sharing the source code guarantees that
-            the various implementations will be compatible and that
-            the core is able to reflect successfully over the
-            framework implementations of ITestCaseData.
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.ITestCaseData.Arguments">
-            <summary>
-            Gets the argument list to be provided to the test
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.ITestCaseData.Result">
-            <summary>
-            Gets the expected result
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.ITestCaseData.ExpectedException">
-            <summary>
-             Gets the expected exception Type
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.ITestCaseData.ExpectedExceptionName">
-            <summary>
-            Gets the FullName of the expected exception
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.ITestCaseData.TestName">
-            <summary>
-            Gets the name to be used for the test
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.ITestCaseData.Description">
-            <summary>
-            Gets the description of the test
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.ITestCaseData.Ignored">
-            <summary>
-            Gets a value indicating whether this <see cref="T:NUnit.Framework.ITestCaseData"/> is ignored.
-            </summary>
-            <value><c>true</c> if ignored; otherwise, <c>false</c>.</value>
-        </member>
-        <member name="P:NUnit.Framework.ITestCaseData.IgnoreReason">
-            <summary>
-            Gets the ignore reason.
-            </summary>
-            <value>The ignore reason.</value>
-        </member>
-        <member name="M:NUnit.Framework.TestCaseAttribute.#ctor(System.Object[])">
-            <summary>
-            Construct a TestCaseAttribute with a list of arguments.
-            This constructor is not CLS-Compliant
-            </summary>
-            <param name="arguments"></param>
-        </member>
-        <member name="M:NUnit.Framework.TestCaseAttribute.#ctor(System.Object)">
-            <summary>
-            Construct a TestCaseAttribute with a single argument
-            </summary>
-            <param name="arg"></param>
-        </member>
-        <member name="M:NUnit.Framework.TestCaseAttribute.#ctor(System.Object,System.Object)">
-            <summary>
-            Construct a TestCaseAttribute with a two arguments
-            </summary>
-            <param name="arg1"></param>
-            <param name="arg2"></param>
-        </member>
-        <member name="M:NUnit.Framework.TestCaseAttribute.#ctor(System.Object,System.Object,System.Object)">
-            <summary>
-            Construct a TestCaseAttribute with a three arguments
-            </summary>
-            <param name="arg1"></param>
-            <param name="arg2"></param>
-            <param name="arg3"></param>
-        </member>
-        <member name="P:NUnit.Framework.TestCaseAttribute.Arguments">
-            <summary>
-            Gets the list of arguments to a test case
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.TestCaseAttribute.Result">
-            <summary>
-            Gets or sets the expected result.
-            </summary>
-            <value>The result.</value>
-        </member>
-        <member name="P:NUnit.Framework.TestCaseAttribute.ExpectedException">
-            <summary>
-            Gets or sets the expected exception.
-            </summary>
-            <value>The expected exception.</value>
-        </member>
-        <member name="P:NUnit.Framework.TestCaseAttribute.ExpectedExceptionName">
-            <summary>
-            Gets or sets the name the expected exception.
-            </summary>
-            <value>The expected name of the exception.</value>
-        </member>
-        <member name="P:NUnit.Framework.TestCaseAttribute.ExpectedMessage">
-            <summary>
-            Gets or sets the expected message of the expected exception
-            </summary>
-            <value>The expected message of the exception.</value>
-        </member>
-        <member name="P:NUnit.Framework.TestCaseAttribute.MatchType">
-            <summary>
-             Gets or sets the type of match to be performed on the expected message
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.TestCaseAttribute.Description">
-            <summary>
-            Gets or sets the description.
-            </summary>
-            <value>The description.</value>
-        </member>
-        <member name="P:NUnit.Framework.TestCaseAttribute.TestName">
-            <summary>
-            Gets or sets the name of the test.
-            </summary>
-            <value>The name of the test.</value>
-        </member>
-        <member name="P:NUnit.Framework.TestCaseAttribute.Ignore">
-            <summary>
-            Gets or sets the ignored status of the test
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.TestCaseAttribute.Ignored">
-            <summary>
-            Gets or sets the ignored status of the test
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.TestCaseAttribute.IgnoreReason">
-            <summary>
-            Gets the ignore reason.
-            </summary>
-            <value>The ignore reason.</value>
-        </member>
-        <member name="T:NUnit.Framework.TestCaseSourceAttribute">
-            <summary>
-            FactoryAttribute indicates the source to be used to
-            provide test cases for a test method.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.TestCaseSourceAttribute.#ctor(System.String)">
-            <summary>
-            Construct with the name of the factory - for use with languages
-            that don't support params arrays.
-            </summary>
-            <param name="sourceName">An array of the names of the factories that will provide data</param>
-        </member>
-        <member name="M:NUnit.Framework.TestCaseSourceAttribute.#ctor(System.Type,System.String)">
-            <summary>
-            Construct with a Type and name - for use with languages
-            that don't support params arrays.
-            </summary>
-            <param name="sourceType">The Type that will provide data</param>
-            <param name="sourceName">The name of the method, property or field that will provide data</param>
-        </member>
-        <member name="P:NUnit.Framework.TestCaseSourceAttribute.SourceName">
-            <summary>
-            The name of a the method, property or fiend to be used as a source
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.TestCaseSourceAttribute.SourceType">
-            <summary>
-            A Type to be used as a source
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.TestFixtureAttribute">
-            <example>
-            [TestFixture]
-            public class ExampleClass 
-            {}
-            </example>
-        </member>
-        <member name="M:NUnit.Framework.TestFixtureAttribute.#ctor">
-            <summary>
-            Default constructor
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.TestFixtureAttribute.#ctor(System.Object[])">
-            <summary>
-            Construct with a object[] representing a set of arguments. 
-            In .NET 2.0, the arguments may later be separated into
-            type arguments and constructor arguments.
-            </summary>
-            <param name="arguments"></param>
-        </member>
-        <member name="P:NUnit.Framework.TestFixtureAttribute.Description">
-            <summary>
-            Descriptive text for this fixture
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.TestFixtureAttribute.Arguments">
-            <summary>
-            The arguments originally provided to the attribute
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.TestFixtureAttribute.Ignore">
-            <summary>
-            Gets or sets a value indicating whether this <see cref="T:NUnit.Framework.TestFixtureAttribute"/> should be ignored.
-            </summary>
-            <value><c>true</c> if ignore; otherwise, <c>false</c>.</value>
-        </member>
-        <member name="P:NUnit.Framework.TestFixtureAttribute.IgnoreReason">
-            <summary>
-            Gets or sets the ignore reason. May set Ignored as a side effect.
-            </summary>
-            <value>The ignore reason.</value>
-        </member>
-        <member name="P:NUnit.Framework.TestFixtureAttribute.TypeArgs">
-            <summary>
-            Get or set the type arguments. If not set
-            explicitly, any leading arguments that are
-            Types are taken as type arguments.
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.TestFixtureSetUpAttribute">
-            <summary>
-            Attribute used to identify a method that is 
-            called before any tests in a fixture are run.
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.TestFixtureTearDownAttribute">
-            <summary>
-            Attribute used to identify a method that is called after
-            all the tests in a fixture have run. The method is 
-            guaranteed to be called, even if an exception is thrown.
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.TheoryAttribute">
-            <summary>
-            Adding this attribute to a method within a <seealso cref="T:NUnit.Framework.TestFixtureAttribute"/> 
-            class makes the method callable from the NUnit test runner. There is a property 
-            called Description which is optional which you can provide a more detailed test
-            description. This class cannot be inherited.
-            </summary>
-            
-            <example>
-            [TestFixture]
-            public class Fixture
-            {
-              [Test]
-              public void MethodToTest()
-              {}
-              
-              [Test(Description = "more detailed description")]
-              publc void TestDescriptionMethod()
-              {}
-            }
-            </example>
-            
-        </member>
-        <member name="T:NUnit.Framework.TimeoutAttribute">
-            <summary>
-            WUsed on a method, marks the test with a timeout value in milliseconds. 
-            The test will be run in a separate thread and is cancelled if the timeout 
-            is exceeded. Used on a method or assembly, sets the default timeout 
-            for all contained test methods.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.TimeoutAttribute.#ctor(System.Int32)">
-            <summary>
-            Construct a TimeoutAttribute given a time in milliseconds
-            </summary>
-            <param name="timeout">The timeout value in milliseconds</param>
-        </member>
-        <member name="T:NUnit.Framework.RequiresSTAAttribute">
-            <summary>
-            Marks a test that must run in the STA, causing it
-            to run in a separate thread if necessary.
-            
-            On methods, you may also use STAThreadAttribute
-            to serve the same purpose.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.RequiresSTAAttribute.#ctor">
-            <summary>
-            Construct a RequiresSTAAttribute
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.RequiresMTAAttribute">
-            <summary>
-            Marks a test that must run in the MTA, causing it
-            to run in a separate thread if necessary.
-            
-            On methods, you may also use MTAThreadAttribute
-            to serve the same purpose.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.RequiresMTAAttribute.#ctor">
-            <summary>
-            Construct a RequiresMTAAttribute
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.RequiresThreadAttribute">
-            <summary>
-            Marks a test that must run on a separate thread.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.RequiresThreadAttribute.#ctor">
-            <summary>
-            Construct a RequiresThreadAttribute
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.RequiresThreadAttribute.#ctor(System.Threading.ApartmentState)">
-            <summary>
-            Construct a RequiresThreadAttribute, specifying the apartment
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.ValueSourceAttribute">
-            <summary>
-            ValueSourceAttribute indicates the source to be used to
-            provide data for one parameter of a test method.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.ValueSourceAttribute.#ctor(System.String)">
-            <summary>
-            Construct with the name of the factory - for use with languages
-            that don't support params arrays.
-            </summary>
-            <param name="sourceName">The name of the data source to be used</param>
-        </member>
-        <member name="M:NUnit.Framework.ValueSourceAttribute.#ctor(System.Type,System.String)">
-            <summary>
-            Construct with a Type and name - for use with languages
-            that don't support params arrays.
-            </summary>
-            <param name="sourceType">The Type that will provide data</param>
-            <param name="sourceName">The name of the method, property or field that will provide data</param>
-        </member>
-        <member name="P:NUnit.Framework.ValueSourceAttribute.SourceName">
-            <summary>
-            The name of a the method, property or fiend to be used as a source
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.ValueSourceAttribute.SourceType">
-            <summary>
-            A Type to be used as a source
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.AttributeExistsConstraint">
-            <summary>
-            AttributeExistsConstraint tests for the presence of a
-            specified attribute on  a Type.
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.Constraint">
-            <summary>
-            The Constraint class is the base of all built-in constraints
-            within NUnit. It provides the operator overloads used to combine 
-            constraints.
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.IResolveConstraint">
-            <summary>
-            The IConstraintExpression interface is implemented by all
-            complete and resolvable constraints and expressions.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.IResolveConstraint.Resolve">
-            <summary>
-            Return the top-level constraint for this expression
-            </summary>
-            <returns></returns>
-        </member>
-        <member name="F:NUnit.Framework.Constraints.Constraint.UNSET">
-            <summary>
-            Static UnsetObject used to detect derived constraints
-            failing to set the actual value.
-            </summary>
-        </member>
-        <member name="F:NUnit.Framework.Constraints.Constraint.actual">
-            <summary>
-            The actual value being tested against a constraint
-            </summary>
-        </member>
-        <member name="F:NUnit.Framework.Constraints.Constraint.displayName">
-            <summary>
-            The display name of this Constraint for use by ToString()
-            </summary>
-        </member>
-        <member name="F:NUnit.Framework.Constraints.Constraint.argcnt">
-            <summary>
-            Argument fields used by ToString();
-            </summary>
-        </member>
-        <member name="F:NUnit.Framework.Constraints.Constraint.builder">
-            <summary>
-            The builder holding this constraint
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.Constraint.#ctor">
-            <summary>
-            Construct a constraint with no arguments
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.Constraint.#ctor(System.Object)">
-            <summary>
-            Construct a constraint with one argument
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.Constraint.#ctor(System.Object,System.Object)">
-            <summary>
-            Construct a constraint with two arguments
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.Constraint.SetBuilder(NUnit.Framework.Constraints.ConstraintBuilder)">
-            <summary>
-            Sets the ConstraintBuilder holding this constraint
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.Constraint.WriteMessageTo(NUnit.Framework.Constraints.MessageWriter)">
-            <summary>
-            Write the failure message to the MessageWriter provided
-            as an argument. The default implementation simply passes
-            the constraint and the actual value to the writer, which
-            then displays the constraint description and the value.
-            
-            Constraints that need to provide additional details,
-            such as where the error occured can override this.
-            </summary>
-            <param name="writer">The MessageWriter on which to display the message</param>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.Constraint.Matches(System.Object)">
-            <summary>
-            Test whether the constraint is satisfied by a given value
-            </summary>
-            <param name="actual">The value to be tested</param>
-            <returns>True for success, false for failure</returns>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.Constraint.Matches(NUnit.Framework.Constraints.ActualValueDelegate)">
-            <summary>
-            Test whether the constraint is satisfied by an
-            ActualValueDelegate that returns the value to be tested.
-            The default implementation simply evaluates the delegate
-            but derived classes may override it to provide for delayed 
-            processing.
-            </summary>
-            <param name="del">An ActualValueDelegate</param>
-            <returns>True for success, false for failure</returns>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.Constraint.Matches``1(``0@)">
-            <summary>
-            Test whether the constraint is satisfied by a given reference.
-            The default implementation simply dereferences the value but
-            derived classes may override it to provide for delayed processing.
-            </summary>
-            <param name="actual">A reference to the value to be tested</param>
-            <returns>True for success, false for failure</returns>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.Constraint.WriteDescriptionTo(NUnit.Framework.Constraints.MessageWriter)">
-            <summary>
-            Write the constraint description to a MessageWriter
-            </summary>
-            <param name="writer">The writer on which the description is displayed</param>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.Constraint.WriteActualValueTo(NUnit.Framework.Constraints.MessageWriter)">
-            <summary>
-            Write the actual value for a failing constraint test to a
-            MessageWriter. The default implementation simply writes
-            the raw value of actual, leaving it to the writer to
-            perform any formatting.
-            </summary>
-            <param name="writer">The writer on which the actual value is displayed</param>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.Constraint.ToString">
-            <summary>
-            Default override of ToString returns the constraint DisplayName
-            followed by any arguments within angle brackets.
-            </summary>
-            <returns></returns>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.Constraint.GetStringRepresentation">
-            <summary>
-            Returns the string representation of this constraint
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.Constraint.op_BitwiseAnd(NUnit.Framework.Constraints.Constraint,NUnit.Framework.Constraints.Constraint)">
-            <summary>
-            This operator creates a constraint that is satisfied only if both 
-            argument constraints are satisfied.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.Constraint.op_BitwiseOr(NUnit.Framework.Constraints.Constraint,NUnit.Framework.Constraints.Constraint)">
-            <summary>
-            This operator creates a constraint that is satisfied if either 
-            of the argument constraints is satisfied.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.Constraint.op_LogicalNot(NUnit.Framework.Constraints.Constraint)">
-            <summary>
-            This operator creates a constraint that is satisfied if the 
-            argument constraint is not satisfied.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.Constraint.After(System.Int32)">
-            <summary>
-            Returns a DelayedConstraint with the specified delay time.
-            </summary>
-            <param name="delayInMilliseconds">The delay in milliseconds.</param>
-            <returns></returns>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.Constraint.After(System.Int32,System.Int32)">
-            <summary>
-            Returns a DelayedConstraint with the specified delay time
-            and polling interval.
-            </summary>
-            <param name="delayInMilliseconds">The delay in milliseconds.</param>
-            <param name="pollingInterval">The interval at which to test the constraint.</param>
-            <returns></returns>
-        </member>
-        <member name="P:NUnit.Framework.Constraints.Constraint.DisplayName">
-            <summary>
-            The display name of this Constraint for use by ToString().
-            The default value is the name of the constraint with
-            trailing "Constraint" removed. Derived classes may set
-            this to another name in their constructors.
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.Constraints.Constraint.And">
-            <summary>
-            Returns a ConstraintExpression by appending And
-            to the current constraint.
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.Constraints.Constraint.With">
-            <summary>
-            Returns a ConstraintExpression by appending And
-            to the current constraint.
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.Constraints.Constraint.Or">
-            <summary>
-            Returns a ConstraintExpression by appending Or
-            to the current constraint.
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.Constraint.UnsetObject">
-            <summary>
-            Class used to detect any derived constraints
-            that fail to set the actual value in their
-            Matches override.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.AttributeExistsConstraint.#ctor(System.Type)">
-            <summary>
-            Constructs an AttributeExistsConstraint for a specific attribute Type
-            </summary>
-            <param name="type"></param>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.AttributeExistsConstraint.Matches(System.Object)">
-            <summary>
-            Tests whether the object provides the expected attribute.
-            </summary>
-            <param name="actual">A Type, MethodInfo, or other ICustomAttributeProvider</param>
-            <returns>True if the expected attribute is present, otherwise false</returns>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.AttributeExistsConstraint.WriteDescriptionTo(NUnit.Framework.Constraints.MessageWriter)">
-            <summary>
-            Writes the description of the constraint to the specified writer
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.AttributeConstraint">
-            <summary>
-            AttributeConstraint tests that a specified attribute is present
-            on a Type or other provider and that the value of the attribute
-            satisfies some other constraint.
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.PrefixConstraint">
-            <summary>
-            Abstract base class used for prefixes
-            </summary>
-        </member>
-        <member name="F:NUnit.Framework.Constraints.PrefixConstraint.baseConstraint">
-            <summary>
-            The base constraint
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.PrefixConstraint.#ctor(NUnit.Framework.Constraints.IResolveConstraint)">
-            <summary>
-            Construct given a base constraint
-            </summary>
-            <param name="resolvable"></param>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.AttributeConstraint.#ctor(System.Type,NUnit.Framework.Constraints.Constraint)">
-            <summary>
-            Constructs an AttributeConstraint for a specified attriute
-            Type and base constraint.
-            </summary>
-            <param name="type"></param>
-            <param name="baseConstraint"></param>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.AttributeConstraint.Matches(System.Object)">
-            <summary>
-            Determines whether the Type or other provider has the 
-            expected attribute and if its value matches the
-            additional constraint specified.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.AttributeConstraint.WriteDescriptionTo(NUnit.Framework.Constraints.MessageWriter)">
-            <summary>
-            Writes a description of the attribute to the specified writer.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.AttributeConstraint.WriteActualValueTo(NUnit.Framework.Constraints.MessageWriter)">
-            <summary>
-            Writes the actual value supplied to the specified writer.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.AttributeConstraint.GetStringRepresentation">
-            <summary>
-            Returns a string representation of the constraint.
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.BasicConstraint">
-            <summary>
-            BasicConstraint is the abstract base for constraints that
-            perform a simple comparison to a constant value.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.BasicConstraint.#ctor(System.Object,System.String)">
-            <summary>
-            Initializes a new instance of the <see cref="T:BasicConstraint"/> class.
-            </summary>
-            <param name="expected">The expected.</param>
-            <param name="description">The description.</param>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.BasicConstraint.Matches(System.Object)">
-            <summary>
-            Test whether the constraint is satisfied by a given value
-            </summary>
-            <param name="actual">The value to be tested</param>
-            <returns>True for success, false for failure</returns>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.BasicConstraint.WriteDescriptionTo(NUnit.Framework.Constraints.MessageWriter)">
-            <summary>
-            Write the constraint description to a MessageWriter
-            </summary>
-            <param name="writer">The writer on which the description is displayed</param>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.NullConstraint">
-            <summary>
-            NullConstraint tests that the actual value is null
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.NullConstraint.#ctor">
-            <summary>
-            Initializes a new instance of the <see cref="T:NullConstraint"/> class.
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.TrueConstraint">
-            <summary>
-            TrueConstraint tests that the actual value is true
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.TrueConstraint.#ctor">
-            <summary>
-            Initializes a new instance of the <see cref="T:TrueConstraint"/> class.
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.FalseConstraint">
-            <summary>
-            FalseConstraint tests that the actual value is false
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.FalseConstraint.#ctor">
-            <summary>
-            Initializes a new instance of the <see cref="T:FalseConstraint"/> class.
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.NaNConstraint">
-            <summary>
-            NaNConstraint tests that the actual value is a double or float NaN
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.NaNConstraint.Matches(System.Object)">
-            <summary>
-            Test that the actual value is an NaN
-            </summary>
-            <param name="actual"></param>
-            <returns></returns>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.NaNConstraint.WriteDescriptionTo(NUnit.Framework.Constraints.MessageWriter)">
-            <summary>
-            Write the constraint description to a specified writer
-            </summary>
-            <param name="writer"></param>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.BinaryConstraint">
-            <summary>
-            BinaryConstraint is the abstract base of all constraints
-            that combine two other constraints in some fashion.
-            </summary>
-        </member>
-        <member name="F:NUnit.Framework.Constraints.BinaryConstraint.left">
-            <summary>
-            The first constraint being combined
-            </summary>
-        </member>
-        <member name="F:NUnit.Framework.Constraints.BinaryConstraint.right">
-            <summary>
-            The second constraint being combined
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.BinaryConstraint.#ctor(NUnit.Framework.Constraints.Constraint,NUnit.Framework.Constraints.Constraint)">
-            <summary>
-            Construct a BinaryConstraint from two other constraints
-            </summary>
-            <param name="left">The first constraint</param>
-            <param name="right">The second constraint</param>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.AndConstraint">
-            <summary>
-            AndConstraint succeeds only if both members succeed.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.AndConstraint.#ctor(NUnit.Framework.Constraints.Constraint,NUnit.Framework.Constraints.Constraint)">
-            <summary>
-            Create an AndConstraint from two other constraints
-            </summary>
-            <param name="left">The first constraint</param>
-            <param name="right">The second constraint</param>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.AndConstraint.Matches(System.Object)">
-            <summary>
-            Apply both member constraints to an actual value, succeeding 
-            succeeding only if both of them succeed.
-            </summary>
-            <param name="actual">The actual value</param>
-            <returns>True if the constraints both succeeded</returns>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.AndConstraint.WriteDescriptionTo(NUnit.Framework.Constraints.MessageWriter)">
-            <summary>
-            Write a description for this contraint to a MessageWriter
-            </summary>
-            <param name="writer">The MessageWriter to receive the description</param>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.AndConstraint.WriteActualValueTo(NUnit.Framework.Constraints.MessageWriter)">
-            <summary>
-            Write the actual value for a failing constraint test to a
-            MessageWriter. The default implementation simply writes
-            the raw value of actual, leaving it to the writer to
-            perform any formatting.
-            </summary>
-            <param name="writer">The writer on which the actual value is displayed</param>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.OrConstraint">
-            <summary>
-            OrConstraint succeeds if either member succeeds
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.OrConstraint.#ctor(NUnit.Framework.Constraints.Constraint,NUnit.Framework.Constraints.Constraint)">
-            <summary>
-            Create an OrConstraint from two other constraints
-            </summary>
-            <param name="left">The first constraint</param>
-            <param name="right">The second constraint</param>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.OrConstraint.Matches(System.Object)">
-            <summary>
-            Apply the member constraints to an actual value, succeeding 
-            succeeding as soon as one of them succeeds.
-            </summary>
-            <param name="actual">The actual value</param>
-            <returns>True if either constraint succeeded</returns>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.OrConstraint.WriteDescriptionTo(NUnit.Framework.Constraints.MessageWriter)">
-            <summary>
-            Write a description for this contraint to a MessageWriter
-            </summary>
-            <param name="writer">The MessageWriter to receive the description</param>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.CollectionConstraint">
-            <summary>
-            CollectionConstraint is the abstract base class for
-            constraints that operate on collections.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionConstraint.#ctor">
-            <summary>
-            Construct an empty CollectionConstraint
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionConstraint.#ctor(System.Object)">
-            <summary>
-            Construct a CollectionConstraint
-            </summary>
-            <param name="arg"></param>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionConstraint.IsEmpty(System.Collections.IEnumerable)">
-            <summary>
-            Determines whether the specified enumerable is empty.
-            </summary>
-            <param name="enumerable">The enumerable.</param>
-            <returns>
-            	<c>true</c> if the specified enumerable is empty; otherwise, <c>false</c>.
-            </returns>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionConstraint.Matches(System.Object)">
-            <summary>
-            Test whether the constraint is satisfied by a given value
-            </summary>
-            <param name="actual">The value to be tested</param>
-            <returns>True for success, false for failure</returns>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionConstraint.doMatch(System.Collections.IEnumerable)">
-            <summary>
-            Protected method to be implemented by derived classes
-            </summary>
-            <param name="collection"></param>
-            <returns></returns>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.CollectionItemsEqualConstraint">
-            <summary>
-            CollectionItemsEqualConstraint is the abstract base class for all
-            collection constraints that apply some notion of item equality
-            as a part of their operation.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionItemsEqualConstraint.#ctor">
-            <summary>
-            Construct an empty CollectionConstraint
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionItemsEqualConstraint.#ctor(System.Object)">
-            <summary>
-            Construct a CollectionConstraint
-            </summary>
-            <param name="arg"></param>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionItemsEqualConstraint.Using(System.Collections.IComparer)">
-            <summary>
-            Flag the constraint to use the supplied IComparer object.
-            </summary>
-            <param name="comparer">The IComparer object to use.</param>
-            <returns>Self.</returns>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionItemsEqualConstraint.Using``1(System.Collections.Generic.IComparer{``0})">
-            <summary>
-            Flag the constraint to use the supplied IComparer object.
-            </summary>
-            <param name="comparer">The IComparer object to use.</param>
-            <returns>Self.</returns>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionItemsEqualConstraint.Using``1(System.Comparison{``0})">
-            <summary>
-            Flag the constraint to use the supplied Comparison object.
-            </summary>
-            <param name="comparer">The IComparer object to use.</param>
-            <returns>Self.</returns>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionItemsEqualConstraint.Using(System.Collections.IEqualityComparer)">
-            <summary>
-            Flag the constraint to use the supplied IEqualityComparer object.
-            </summary>
-            <param name="comparer">The IComparer object to use.</param>
-            <returns>Self.</returns>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionItemsEqualConstraint.Using``1(System.Collections.Generic.IEqualityComparer{``0})">
-            <summary>
-            Flag the constraint to use the supplied IEqualityComparer object.
-            </summary>
-            <param name="comparer">The IComparer object to use.</param>
-            <returns>Self.</returns>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionItemsEqualConstraint.ItemsEqual(System.Object,System.Object)">
-            <summary>
-            Compares two collection members for equality
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionItemsEqualConstraint.Tally(System.Collections.IEnumerable)">
-            <summary>
-            Return a new CollectionTally for use in making tests
-            </summary>
-            <param name="c">The collection to be included in the tally</param>
-        </member>
-        <member name="P:NUnit.Framework.Constraints.CollectionItemsEqualConstraint.IgnoreCase">
-            <summary>
-            Flag the constraint to ignore case and return self.
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.EmptyCollectionConstraint">
-            <summary>
-            EmptyCollectionConstraint tests whether a collection is empty. 
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.EmptyCollectionConstraint.doMatch(System.Collections.IEnumerable)">
-            <summary>
-            Check that the collection is empty
-            </summary>
-            <param name="collection"></param>
-            <returns></returns>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.EmptyCollectionConstraint.WriteDescriptionTo(NUnit.Framework.Constraints.MessageWriter)">
-            <summary>
-            Write the constraint description to a MessageWriter
-            </summary>
-            <param name="writer"></param>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.UniqueItemsConstraint">
-            <summary>
-            UniqueItemsConstraint tests whether all the items in a 
-            collection are unique.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.UniqueItemsConstraint.doMatch(System.Collections.IEnumerable)">
-            <summary>
-            Check that all items are unique.
-            </summary>
-            <param name="actual"></param>
-            <returns></returns>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.UniqueItemsConstraint.WriteDescriptionTo(NUnit.Framework.Constraints.MessageWriter)">
-            <summary>
-            Write a description of this constraint to a MessageWriter
-            </summary>
-            <param name="writer"></param>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.CollectionContainsConstraint">
-            <summary>
-            CollectionContainsConstraint is used to test whether a collection
-            contains an expected object as a member.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionContainsConstraint.#ctor(System.Object)">
-            <summary>
-            Construct a CollectionContainsConstraint
-            </summary>
-            <param name="expected"></param>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionContainsConstraint.doMatch(System.Collections.IEnumerable)">
-            <summary>
-            Test whether the expected item is contained in the collection
-            </summary>
-            <param name="actual"></param>
-            <returns></returns>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionContainsConstraint.WriteDescriptionTo(NUnit.Framework.Constraints.MessageWriter)">
-            <summary>
-            Write a descripton of the constraint to a MessageWriter
-            </summary>
-            <param name="writer"></param>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.CollectionEquivalentConstraint">
-            <summary>
-            CollectionEquivalentCOnstraint is used to determine whether two
-            collections are equivalent.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionEquivalentConstraint.#ctor(System.Collections.IEnumerable)">
-            <summary>
-            Construct a CollectionEquivalentConstraint
-            </summary>
-            <param name="expected"></param>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionEquivalentConstraint.doMatch(System.Collections.IEnumerable)">
-            <summary>
-            Test whether two collections are equivalent
-            </summary>
-            <param name="actual"></param>
-            <returns></returns>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionEquivalentConstraint.WriteDescriptionTo(NUnit.Framework.Constraints.MessageWriter)">
-            <summary>
-            Write a description of this constraint to a MessageWriter
-            </summary>
-            <param name="writer"></param>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.CollectionSubsetConstraint">
-            <summary>
-            CollectionSubsetConstraint is used to determine whether
-            one collection is a subset of another
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionSubsetConstraint.#ctor(System.Collections.IEnumerable)">
-            <summary>
-            Construct a CollectionSubsetConstraint
-            </summary>
-            <param name="expected">The collection that the actual value is expected to be a subset of</param>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionSubsetConstraint.doMatch(System.Collections.IEnumerable)">
-            <summary>
-            Test whether the actual collection is a subset of 
-            the expected collection provided.
-            </summary>
-            <param name="actual"></param>
-            <returns></returns>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionSubsetConstraint.WriteDescriptionTo(NUnit.Framework.Constraints.MessageWriter)">
-            <summary>
-            Write a description of this constraint to a MessageWriter
-            </summary>
-            <param name="writer"></param>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.CollectionOrderedConstraint">
-            <summary>
-            CollectionOrderedConstraint is used to test whether a collection is ordered.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionOrderedConstraint.#ctor">
-            <summary>
-            Construct a CollectionOrderedConstraint
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionOrderedConstraint.Using(System.Collections.IComparer)">
-            <summary>
-            Modifies the constraint to use an IComparer and returns self.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionOrderedConstraint.Using``1(System.Collections.Generic.IComparer{``0})">
-            <summary>
-            Modifies the constraint to use an IComparer&lt;T&gt; and returns self.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionOrderedConstraint.Using``1(System.Comparison{``0})">
-            <summary>
-            Modifies the constraint to use a Comparison&lt;T&gt; and returns self.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionOrderedConstraint.By(System.String)">
-            <summary>
-            Modifies the constraint to test ordering by the value of
-            a specified property and returns self.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionOrderedConstraint.doMatch(System.Collections.IEnumerable)">
-            <summary>
-            Test whether the collection is ordered
-            </summary>
-            <param name="actual"></param>
-            <returns></returns>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionOrderedConstraint.WriteDescriptionTo(NUnit.Framework.Constraints.MessageWriter)">
-            <summary>
-            Write a description of the constraint to a MessageWriter
-            </summary>
-            <param name="writer"></param>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionOrderedConstraint.GetStringRepresentation">
-            <summary>
-            Returns the string representation of the constraint.
-            </summary>
-            <returns></returns>
-        </member>
-        <member name="P:NUnit.Framework.Constraints.CollectionOrderedConstraint.Descending">
-            <summary>
-             If used performs a reverse comparison
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.CollectionTally">
-            <summary>
-            CollectionTally counts (tallies) the number of
-            occurences of each object in one or more enumerations.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionTally.#ctor(NUnit.Framework.Constraints.NUnitEqualityComparer,System.Collections.IEnumerable)">
-            <summary>
-            Construct a CollectionTally object from a comparer and a collection
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionTally.TryRemove(System.Object)">
-            <summary>
-            Try to remove an object from the tally
-            </summary>
-            <param name="o">The object to remove</param>
-            <returns>True if successful, false if the object was not found</returns>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionTally.TryRemove(System.Collections.IEnumerable)">
-            <summary>
-            Try to remove a set of objects from the tally
-            </summary>
-            <param name="c">The objects to remove</param>
-            <returns>True if successful, false if any object was not found</returns>
-        </member>
-        <member name="P:NUnit.Framework.Constraints.CollectionTally.Count">
-            <summary>
-            The number of objects remaining in the tally
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.ComparisonAdapter">
-            <summary>
-            ComparisonAdapter class centralizes all comparisons of
-            values in NUnit, adapting to the use of any provided
-            IComparer, IComparer&lt;T&gt; or Comparison&lt;T&gt;
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.ComparisonAdapter.For(System.Collections.IComparer)">
-            <summary>
-            Returns a ComparisonAdapter that wraps an IComparer
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.ComparisonAdapter.For``1(System.Collections.Generic.IComparer{``0})">
-            <summary>
-            Returns a ComparisonAdapter that wraps an IComparer&lt;T&gt;
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.ComparisonAdapter.For``1(System.Comparison{``0})">
-            <summary>
-            Returns a ComparisonAdapter that wraps a Comparison&lt;T&gt;
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.ComparisonAdapter.Compare(System.Object,System.Object)">
-            <summary>
-            Compares two objects
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.Constraints.ComparisonAdapter.Default">
-            <summary>
-            Gets the default ComparisonAdapter, which wraps an
-            NUnitComparer object.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.ComparisonAdapter.ComparerAdapter.#ctor(System.Collections.IComparer)">
-            <summary>
-            Construct a ComparisonAdapter for an IComparer
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.ComparisonAdapter.ComparerAdapter.Compare(System.Object,System.Object)">
-            <summary>
-            Compares two objects
-            </summary>
-            <param name="expected"></param>
-            <param name="actual"></param>
-            <returns></returns>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.ComparisonAdapter.DefaultComparisonAdapter.#ctor">
-            <summary>
-            Construct a default ComparisonAdapter
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.ComparisonAdapter.ComparerAdapter`1">
-            <summary>
-            ComparisonAdapter&lt;T&gt; extends ComparisonAdapter and
-            allows use of an IComparer&lt;T&gt; or Comparison&lt;T&gt;
-            to actually perform the comparison.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.ComparisonAdapter.ComparerAdapter`1.#ctor(System.Collections.Generic.IComparer{`0})">
-            <summary>
-            Construct a ComparisonAdapter for an IComparer&lt;T&gt;
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.ComparisonAdapter.ComparerAdapter`1.Compare(System.Object,System.Object)">
-            <summary>
-            Compare a Type T to an object
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.ComparisonAdapter.ComparisonAdapterForComparison`1.#ctor(System.Comparison{`0})">
-            <summary>
-            Construct a ComparisonAdapter for a Comparison&lt;T&gt;
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.ComparisonAdapter.ComparisonAdapterForComparison`1.Compare(System.Object,System.Object)">
-            <summary>
-            Compare a Type T to an object
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.ComparisonConstraint">
-            <summary>
-            Abstract base class for constraints that compare values to
-            determine if one is greater than, equal to or less than
-            the other.
-            </summary>
-        </member>
-        <member name="F:NUnit.Framework.Constraints.ComparisonConstraint.expected">
-            <summary>
-            The value against which a comparison is to be made
-            </summary>
-        </member>
-        <member name="F:NUnit.Framework.Constraints.ComparisonConstraint.ltOK">
-            <summary>
-            If true, less than returns success
-            </summary>
-        </member>
-        <member name="F:NUnit.Framework.Constraints.ComparisonConstraint.eqOK">
-            <summary>
-            if true, equal returns success
-            </summary>
-        </member>
-        <member name="F:NUnit.Framework.Constraints.ComparisonConstraint.gtOK">
-            <summary>
-            if true, greater than returns success
-            </summary>
-        </member>
-        <member name="F:NUnit.Framework.Constraints.ComparisonConstraint.predicate">
-            <summary>
-            The predicate used as a part of the description
-            </summary>
-        </member>
-        <member name="F:NUnit.Framework.Constraints.ComparisonConstraint.comparer">
-            <summary>
-            ComparisonAdapter to be used in making the comparison
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.ComparisonConstraint.#ctor(System.Object,System.Boolean,System.Boolean,System.Boolean,System.String)">
-            <summary>
-            Initializes a new instance of the <see cref="T:ComparisonConstraint"/> class.
-            </summary>
-            <param name="value">The value against which to make a comparison.</param>
-            <param name="ltOK">if set to <c>true</c> less succeeds.</param>
-            <param name="eqOK">if set to <c>true</c> equal succeeds.</param>
-            <param name="gtOK">if set to <c>true</c> greater succeeds.</param>
-            <param name="predicate">String used in describing the constraint.</param>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.ComparisonConstraint.Matches(System.Object)">
-            <summary>
-            Test whether the constraint is satisfied by a given value
-            </summary>
-            <param name="actual">The value to be tested</param>
-            <returns>True for success, false for failure</returns>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.ComparisonConstraint.WriteDescriptionTo(NUnit.Framework.Constraints.MessageWriter)">
-            <summary>
-            Write the constraint description to a MessageWriter
-            </summary>
-            <param name="writer">The writer on which the description is displayed</param>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.ComparisonConstraint.Using(System.Collections.IComparer)">
-            <summary>
-            Modifies the constraint to use an IComparer and returns self
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.ComparisonConstraint.Using``1(System.Collections.Generic.IComparer{``0})">
-            <summary>
-            Modifies the constraint to use an IComparer&lt;T&gt; and returns self
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.ComparisonConstraint.Using``1(System.Comparison{``0})">
-            <summary>
-            Modifies the constraint to use a Comparison&lt;T&gt; and returns self
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.GreaterThanConstraint">
-            <summary>
-            Tests whether a value is greater than the value supplied to its constructor
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.GreaterThanConstraint.#ctor(System.Object)">
-            <summary>
-            Initializes a new instance of the <see cref="T:GreaterThanConstraint"/> class.
-            </summary>
-            <param name="expected">The expected value.</param>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.GreaterThanOrEqualConstraint">
-            <summary>
-            Tests whether a value is greater than or equal to the value supplied to its constructor
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.GreaterThanOrEqualConstraint.#ctor(System.Object)">
-            <summary>
-            Initializes a new instance of the <see cref="T:GreaterThanOrEqualConstraint"/> class.
-            </summary>
-            <param name="expected">The expected value.</param>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.LessThanConstraint">
-            <summary>
-            Tests whether a value is less than the value supplied to its constructor
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.LessThanConstraint.#ctor(System.Object)">
-            <summary>
-            Initializes a new instance of the <see cref="T:LessThanConstraint"/> class.
-            </summary>
-            <param name="expected">The expected value.</param>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.LessThanOrEqualConstraint">
-            <summary>
-            Tests whether a value i

<TRUNCATED>
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/NUnit/Latest/nunit.mocks.dll
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/NUnit/Latest/nunit.mocks.dll b/lib/Gallio.3.2.750/tools/NUnit/Latest/nunit.mocks.dll
deleted file mode 100644
index 97b88e7..0000000
Binary files a/lib/Gallio.3.2.750/tools/NUnit/Latest/nunit.mocks.dll and /dev/null differ


[05/51] [abbrv] [partial] Cleaning up and getting ready to development towards v4.8

Posted by sy...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/src/Lucene.Net.Codecs/Memory/FSTOrdTermsReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Codecs/Memory/FSTOrdTermsReader.cs b/src/Lucene.Net.Codecs/Memory/FSTOrdTermsReader.cs
new file mode 100644
index 0000000..67eaa6e
--- /dev/null
+++ b/src/Lucene.Net.Codecs/Memory/FSTOrdTermsReader.cs
@@ -0,0 +1,860 @@
+package org.apache.lucene.codecs.memory;
+
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+import java.io.IOException;
+import java.util.ArrayList;
+import java.util.Arrays;
+import java.util.BitSet;
+import java.util.Collections;
+import java.util.Comparator;
+import java.util.Iterator;
+import java.util.TreeMap;
+
+import org.apache.lucene.codecs.BlockTermState;
+import org.apache.lucene.codecs.CodecUtil;
+import org.apache.lucene.codecs.FieldsProducer;
+import org.apache.lucene.codecs.PostingsReaderBase;
+import org.apache.lucene.codecs.memory.FSTTermsReader.TermsReader;
+import org.apache.lucene.index.CorruptIndexException;
+import org.apache.lucene.index.DocsAndPositionsEnum;
+import org.apache.lucene.index.DocsEnum;
+import org.apache.lucene.index.FieldInfo.IndexOptions;
+import org.apache.lucene.index.FieldInfo;
+import org.apache.lucene.index.FieldInfos;
+import org.apache.lucene.index.IndexFileNames;
+import org.apache.lucene.index.SegmentInfo;
+import org.apache.lucene.index.SegmentReadState;
+import org.apache.lucene.index.TermState;
+import org.apache.lucene.index.Terms;
+import org.apache.lucene.index.TermsEnum;
+import org.apache.lucene.store.ByteArrayDataInput;
+import org.apache.lucene.store.ChecksumIndexInput;
+import org.apache.lucene.store.IndexInput;
+import org.apache.lucene.util.ArrayUtil;
+import org.apache.lucene.util.Bits;
+import org.apache.lucene.util.BytesRef;
+import org.apache.lucene.util.IOUtils;
+import org.apache.lucene.util.RamUsageEstimator;
+import org.apache.lucene.util.automaton.ByteRunAutomaton;
+import org.apache.lucene.util.automaton.CompiledAutomaton;
+import org.apache.lucene.util.fst.BytesRefFSTEnum.InputOutput;
+import org.apache.lucene.util.fst.BytesRefFSTEnum;
+import org.apache.lucene.util.fst.FST;
+import org.apache.lucene.util.fst.Outputs;
+import org.apache.lucene.util.fst.PositiveIntOutputs;
+import org.apache.lucene.util.fst.Util;
+
+/** 
+ * FST-based terms dictionary reader.
+ *
+ * The FST index maps each term and its ord, and during seek 
+ * the ord is used fetch metadata from a single block.
+ * The term dictionary is fully memory resident.
+ *
+ * @lucene.experimental
+ */
+public class FSTOrdTermsReader extends FieldsProducer {
+  static final int INTERVAL = FSTOrdTermsWriter.SKIP_INTERVAL;
+  final TreeMap<String, TermsReader> fields = new TreeMap<>();
+  final PostingsReaderBase postingsReader;
+  int version;
+  //static final bool TEST = false;
+
+  public FSTOrdTermsReader(SegmentReadState state, PostingsReaderBase postingsReader)  {
+    final String termsIndexFileName = IndexFileNames.segmentFileName(state.segmentInfo.name, state.segmentSuffix, FSTOrdTermsWriter.TERMS_INDEX_EXTENSION);
+    final String termsBlockFileName = IndexFileNames.segmentFileName(state.segmentInfo.name, state.segmentSuffix, FSTOrdTermsWriter.TERMS_BLOCK_EXTENSION);
+
+    this.postingsReader = postingsReader;
+    ChecksumIndexInput indexIn = null;
+    IndexInput blockIn = null;
+    bool success = false;
+    try {
+      indexIn = state.directory.openChecksumInput(termsIndexFileName, state.context);
+      blockIn = state.directory.openInput(termsBlockFileName, state.context);
+      version = readHeader(indexIn);
+      readHeader(blockIn);
+      if (version >= FSTOrdTermsWriter.TERMS_VERSION_CHECKSUM) {
+        CodecUtil.checksumEntireFile(blockIn);
+      }
+      
+      this.postingsReader.init(blockIn);
+      seekDir(blockIn);
+
+      final FieldInfos fieldInfos = state.fieldInfos;
+      final int numFields = blockIn.readVInt();
+      for (int i = 0; i < numFields; i++) {
+        FieldInfo fieldInfo = fieldInfos.fieldInfo(blockIn.readVInt());
+        bool hasFreq = fieldInfo.getIndexOptions() != IndexOptions.DOCS_ONLY;
+        long numTerms = blockIn.readVLong();
+        long sumTotalTermFreq = hasFreq ? blockIn.readVLong() : -1;
+        long sumDocFreq = blockIn.readVLong();
+        int docCount = blockIn.readVInt();
+        int longsSize = blockIn.readVInt();
+        FST<Long> index = new FST<>(indexIn, PositiveIntOutputs.getSingleton());
+
+        TermsReader current = new TermsReader(fieldInfo, blockIn, numTerms, sumTotalTermFreq, sumDocFreq, docCount, longsSize, index);
+        TermsReader previous = fields.put(fieldInfo.name, current);
+        checkFieldSummary(state.segmentInfo, indexIn, blockIn, current, previous);
+      }
+      if (version >= FSTOrdTermsWriter.TERMS_VERSION_CHECKSUM) {
+        CodecUtil.checkFooter(indexIn);
+      } else {
+        CodecUtil.checkEOF(indexIn);
+      }
+      success = true;
+    } finally {
+      if (success) {
+        IOUtils.close(indexIn, blockIn);
+      } else {
+        IOUtils.closeWhileHandlingException(indexIn, blockIn);
+      }
+    }
+  }
+
+  private int readHeader(IndexInput in)  {
+    return CodecUtil.checkHeader(in, FSTOrdTermsWriter.TERMS_CODEC_NAME,
+                                     FSTOrdTermsWriter.TERMS_VERSION_START,
+                                     FSTOrdTermsWriter.TERMS_VERSION_CURRENT);
+  }
+  private void seekDir(IndexInput in)  {
+    if (version >= FSTOrdTermsWriter.TERMS_VERSION_CHECKSUM) {
+      in.seek(in.length() - CodecUtil.footerLength() - 8);
+    } else {
+      in.seek(in.length() - 8);
+    }
+    in.seek(in.readLong());
+  }
+  private void checkFieldSummary(SegmentInfo info, IndexInput indexIn, IndexInput blockIn, TermsReader field, TermsReader previous)  {
+    // #docs with field must be <= #docs
+    if (field.docCount < 0 || field.docCount > info.getDocCount()) {
+      throw new CorruptIndexException("invalid docCount: " + field.docCount + " maxDoc: " + info.getDocCount() + " (resource=" + indexIn + ", " + blockIn + ")");
+    }
+    // #postings must be >= #docs with field
+    if (field.sumDocFreq < field.docCount) {
+      throw new CorruptIndexException("invalid sumDocFreq: " + field.sumDocFreq + " docCount: " + field.docCount + " (resource=" + indexIn + ", " + blockIn + ")");
+    }
+    // #positions must be >= #postings
+    if (field.sumTotalTermFreq != -1 && field.sumTotalTermFreq < field.sumDocFreq) {
+      throw new CorruptIndexException("invalid sumTotalTermFreq: " + field.sumTotalTermFreq + " sumDocFreq: " + field.sumDocFreq + " (resource=" + indexIn + ", " + blockIn + ")");
+    }
+    if (previous != null) {
+      throw new CorruptIndexException("duplicate fields: " + field.fieldInfo.name + " (resource=" + indexIn + ", " + blockIn + ")");
+    }
+  }
+
+  @Override
+  public Iterator<String> iterator() {
+    return Collections.unmodifiableSet(fields.keySet()).iterator();
+  }
+
+  @Override
+  public Terms terms(String field)  {
+    Debug.Assert( field != null;
+    return fields.get(field);
+  }
+
+  @Override
+  public int size() {
+    return fields.size();
+  }
+
+  @Override
+  public void close()  {
+    try {
+      IOUtils.close(postingsReader);
+    } finally {
+      fields.clear();
+    }
+  }
+
+  final class TermsReader extends Terms {
+    final FieldInfo fieldInfo;
+    final long numTerms;
+    final long sumTotalTermFreq;
+    final long sumDocFreq;
+    final int docCount;
+    final int longsSize;
+    final FST<Long> index;
+
+    final int numSkipInfo;
+    final long[] skipInfo;
+    final byte[] statsBlock;
+    final byte[] metaLongsBlock;
+    final byte[] metaBytesBlock;
+
+    TermsReader(FieldInfo fieldInfo, IndexInput blockIn, long numTerms, long sumTotalTermFreq, long sumDocFreq, int docCount, int longsSize, FST<Long> index)  {
+      this.fieldInfo = fieldInfo;
+      this.numTerms = numTerms;
+      this.sumTotalTermFreq = sumTotalTermFreq;
+      this.sumDocFreq = sumDocFreq;
+      this.docCount = docCount;
+      this.longsSize = longsSize;
+      this.index = index;
+
+      Debug.Assert( (numTerms & (~0xffffffffL)) == 0;
+      final int numBlocks = (int)(numTerms + INTERVAL - 1) / INTERVAL;
+      this.numSkipInfo = longsSize + 3;
+      this.skipInfo = new long[numBlocks * numSkipInfo];
+      this.statsBlock = new byte[(int)blockIn.readVLong()];
+      this.metaLongsBlock = new byte[(int)blockIn.readVLong()];
+      this.metaBytesBlock = new byte[(int)blockIn.readVLong()];
+
+      int last = 0, next = 0;
+      for (int i = 1; i < numBlocks; i++) {
+        next = numSkipInfo * i;
+        for (int j = 0; j < numSkipInfo; j++) {
+          skipInfo[next + j] = skipInfo[last + j] + blockIn.readVLong();
+        }
+        last = next;
+      }
+      blockIn.readBytes(statsBlock, 0, statsBlock.length);
+      blockIn.readBytes(metaLongsBlock, 0, metaLongsBlock.length);
+      blockIn.readBytes(metaBytesBlock, 0, metaBytesBlock.length);
+    }
+
+    @Override
+    public Comparator<BytesRef> getComparator() {
+      return BytesRef.getUTF8SortedAsUnicodeComparator();
+    }
+
+    @Override
+    public bool hasFreqs() {
+      return fieldInfo.getIndexOptions().compareTo(IndexOptions.DOCS_AND_FREQS) >= 0;
+    }
+
+    @Override
+    public bool hasOffsets() {
+      return fieldInfo.getIndexOptions().compareTo(IndexOptions.DOCS_AND_FREQS_AND_POSITIONS_AND_OFFSETS) >= 0;
+    }
+
+    @Override
+    public bool hasPositions() {
+      return fieldInfo.getIndexOptions().compareTo(IndexOptions.DOCS_AND_FREQS_AND_POSITIONS) >= 0;
+    }
+
+    @Override
+    public bool hasPayloads() {
+      return fieldInfo.hasPayloads();
+    }
+
+    @Override
+    public long size() {
+      return numTerms;
+    }
+
+    @Override
+    public long getSumTotalTermFreq() {
+      return sumTotalTermFreq;
+    }
+
+    @Override
+    public long getSumDocFreq()  {
+      return sumDocFreq;
+    }
+
+    @Override
+    public int getDocCount()  {
+      return docCount;
+    }
+
+    @Override
+    public TermsEnum iterator(TermsEnum reuse)  {
+      return new SegmentTermsEnum();
+    }
+
+    @Override
+    public TermsEnum intersect(CompiledAutomaton compiled, BytesRef startTerm)  {
+      return new IntersectTermsEnum(compiled, startTerm);
+    }
+
+    // Only wraps common operations for PBF interact
+    abstract class BaseTermsEnum extends TermsEnum {
+      /* Current term, null when enum ends or unpositioned */
+      BytesRef term;
+
+      /* Current term's ord, starts from 0 */
+      long ord;
+
+      /* Current term stats + decoded metadata (customized by PBF) */
+      final BlockTermState state;
+
+      /* Datainput to load stats & metadata */
+      final ByteArrayDataInput statsReader = new ByteArrayDataInput();
+      final ByteArrayDataInput metaLongsReader = new ByteArrayDataInput();
+      final ByteArrayDataInput metaBytesReader = new ByteArrayDataInput();
+
+      /* To which block is buffered */ 
+      int statsBlockOrd;
+      int metaBlockOrd;
+
+      /* Current buffered metadata (long[] & byte[]) */
+      long[][] longs;
+      int[] bytesStart;
+      int[] bytesLength;
+
+      /* Current buffered stats (df & ttf) */
+      int[] docFreq;
+      long[] totalTermFreq;
+
+      BaseTermsEnum()  {
+        this.state = postingsReader.newTermState();
+        this.term = null;
+        this.statsReader.reset(statsBlock);
+        this.metaLongsReader.reset(metaLongsBlock);
+        this.metaBytesReader.reset(metaBytesBlock);
+
+        this.longs = new long[INTERVAL][longsSize];
+        this.bytesStart = new int[INTERVAL];
+        this.bytesLength = new int[INTERVAL];
+        this.docFreq = new int[INTERVAL];
+        this.totalTermFreq = new long[INTERVAL];
+        this.statsBlockOrd = -1;
+        this.metaBlockOrd = -1;
+        if (!hasFreqs()) {
+          Arrays.fill(totalTermFreq, -1);
+        }
+      }
+
+      @Override
+      public Comparator<BytesRef> getComparator() {
+        return BytesRef.getUTF8SortedAsUnicodeComparator();
+      }
+
+      /** Decodes stats data into term state */
+      void decodeStats()  {
+        final int upto = (int)ord % INTERVAL;
+        final int oldBlockOrd = statsBlockOrd;
+        statsBlockOrd = (int)ord / INTERVAL;
+        if (oldBlockOrd != statsBlockOrd) {
+          refillStats();
+        }
+        state.docFreq = docFreq[upto];
+        state.totalTermFreq = totalTermFreq[upto];
+      }
+
+      /** Let PBF decode metadata */
+      void decodeMetaData()  {
+        final int upto = (int)ord % INTERVAL;
+        final int oldBlockOrd = metaBlockOrd;
+        metaBlockOrd = (int)ord / INTERVAL;
+        if (metaBlockOrd != oldBlockOrd) {
+          refillMetadata();
+        }
+        metaBytesReader.setPosition(bytesStart[upto]);
+        postingsReader.decodeTerm(longs[upto], metaBytesReader, fieldInfo, state, true);
+      }
+
+      /** Load current stats shard */
+      final void refillStats()  {
+        final int offset = statsBlockOrd * numSkipInfo;
+        final int statsFP = (int)skipInfo[offset];
+        statsReader.setPosition(statsFP);
+        for (int i = 0; i < INTERVAL && !statsReader.eof(); i++) {
+          int code = statsReader.readVInt();
+          if (hasFreqs()) {
+            docFreq[i] = (code >>> 1);
+            if ((code & 1) == 1) {
+              totalTermFreq[i] = docFreq[i];
+            } else {
+              totalTermFreq[i] = docFreq[i] + statsReader.readVLong();
+            }
+          } else {
+            docFreq[i] = code;
+          }
+        }
+      }
+
+      /** Load current metadata shard */
+      final void refillMetadata()  {
+        final int offset = metaBlockOrd * numSkipInfo;
+        final int metaLongsFP = (int)skipInfo[offset + 1];
+        final int metaBytesFP = (int)skipInfo[offset + 2];
+        metaLongsReader.setPosition(metaLongsFP);
+        for (int j = 0; j < longsSize; j++) {
+          longs[0][j] = skipInfo[offset + 3 + j] + metaLongsReader.readVLong();
+        }
+        bytesStart[0] = metaBytesFP; 
+        bytesLength[0] = (int)metaLongsReader.readVLong();
+        for (int i = 1; i < INTERVAL && !metaLongsReader.eof(); i++) {
+          for (int j = 0; j < longsSize; j++) {
+            longs[i][j] = longs[i-1][j] + metaLongsReader.readVLong();
+          }
+          bytesStart[i] = bytesStart[i-1] + bytesLength[i-1];
+          bytesLength[i] = (int)metaLongsReader.readVLong();
+        }
+      }
+
+      @Override
+      public TermState termState()  {
+        decodeMetaData();
+        return state.clone();
+      }
+
+      @Override
+      public BytesRef term() {
+        return term;
+      }
+
+      @Override
+      public int docFreq()  {
+        return state.docFreq;
+      }
+
+      @Override
+      public long totalTermFreq()  {
+        return state.totalTermFreq;
+      }
+
+      @Override
+      public DocsEnum docs(Bits liveDocs, DocsEnum reuse, int flags)  {
+        decodeMetaData();
+        return postingsReader.docs(fieldInfo, state, liveDocs, reuse, flags);
+      }
+
+      @Override
+      public DocsAndPositionsEnum docsAndPositions(Bits liveDocs, DocsAndPositionsEnum reuse, int flags)  {
+        if (!hasPositions()) {
+          return null;
+        }
+        decodeMetaData();
+        return postingsReader.docsAndPositions(fieldInfo, state, liveDocs, reuse, flags);
+      }
+
+      // TODO: this can be achieved by making use of Util.getByOutput()
+      //           and should have related tests
+      @Override
+      public void seekExact(long ord)  {
+        throw new UnsupportedOperationException();
+      }
+
+      @Override
+      public long ord() {
+        throw new UnsupportedOperationException();
+      }
+    }
+
+    // Iterates through all terms in this field
+    private final class SegmentTermsEnum extends BaseTermsEnum {
+      final BytesRefFSTEnum<Long> fstEnum;
+
+      /* True when current term's metadata is decoded */
+      bool decoded;
+
+      /* True when current enum is 'positioned' by seekExact(TermState) */
+      bool seekPending;
+
+      SegmentTermsEnum()  {
+        this.fstEnum = new BytesRefFSTEnum<>(index);
+        this.decoded = false;
+        this.seekPending = false;
+      }
+
+      @Override
+      void decodeMetaData()  {
+        if (!decoded && !seekPending) {
+          super.decodeMetaData();
+          decoded = true;
+        }
+      }
+
+      // Update current enum according to FSTEnum
+      void updateEnum(final InputOutput<Long> pair)  {
+        if (pair == null) {
+          term = null;
+        } else {
+          term = pair.input;
+          ord = pair.output;
+          decodeStats();
+        }
+        decoded = false;
+        seekPending = false;
+      }
+
+      @Override
+      public BytesRef next()  {
+        if (seekPending) {  // previously positioned, but termOutputs not fetched
+          seekPending = false;
+          SeekStatus status = seekCeil(term);
+          Debug.Assert( status == SeekStatus.FOUND;  // must positioned on valid term
+        }
+        updateEnum(fstEnum.next());
+        return term;
+      }
+
+      @Override
+      public bool seekExact(BytesRef target)  {
+        updateEnum(fstEnum.seekExact(target));
+        return term != null;
+      }
+
+      @Override
+      public SeekStatus seekCeil(BytesRef target)  {
+        updateEnum(fstEnum.seekCeil(target));
+        if (term == null) {
+          return SeekStatus.END;
+        } else {
+          return term.equals(target) ? SeekStatus.FOUND : SeekStatus.NOT_FOUND;
+        }
+      }
+
+      @Override
+      public void seekExact(BytesRef target, TermState otherState) {
+        if (!target.equals(term)) {
+          state.copyFrom(otherState);
+          term = BytesRef.deepCopyOf(target);
+          seekPending = true;
+        }
+      }
+    }
+
+    // Iterates intersect result with automaton (cannot seek!)
+    private final class IntersectTermsEnum extends BaseTermsEnum {
+      /* True when current term's metadata is decoded */
+      bool decoded;
+
+      /* True when there is pending term when calling next() */
+      bool pending;
+
+      /* stack to record how current term is constructed, 
+       * used to accumulate metadata or rewind term:
+       *   level == term.length + 1,
+       *         == 0 when term is null */
+      Frame[] stack;
+      int level;
+
+      /* term dict fst */
+      final FST<Long> fst;
+      final FST.BytesReader fstReader;
+      final Outputs<Long> fstOutputs;
+
+      /* query automaton to intersect with */
+      final ByteRunAutomaton fsa;
+
+      private final class Frame {
+        /* fst stats */
+        FST.Arc<Long> arc;
+
+        /* automaton stats */
+        int state;
+
+        Frame() {
+          this.arc = new FST.Arc<>();
+          this.state = -1;
+        }
+
+        public String toString() {
+          return "arc=" + arc + " state=" + state;
+        }
+      }
+
+      IntersectTermsEnum(CompiledAutomaton compiled, BytesRef startTerm)  {
+        //if (TEST) System.out.println("Enum init, startTerm=" + startTerm);
+        this.fst = index;
+        this.fstReader = fst.getBytesReader();
+        this.fstOutputs = index.outputs;
+        this.fsa = compiled.runAutomaton;
+        this.level = -1;
+        this.stack = new Frame[16];
+        for (int i = 0 ; i < stack.length; i++) {
+          this.stack[i] = new Frame();
+        }
+
+        Frame frame;
+        frame = loadVirtualFrame(newFrame());
+        this.level++;
+        frame = loadFirstFrame(newFrame());
+        pushFrame(frame);
+
+        this.decoded = false;
+        this.pending = false;
+
+        if (startTerm == null) {
+          pending = isAccept(topFrame());
+        } else {
+          doSeekCeil(startTerm);
+          pending = !startTerm.equals(term) && isValid(topFrame()) && isAccept(topFrame());
+        }
+      }
+
+      @Override
+      void decodeMetaData()  {
+        if (!decoded) {
+          super.decodeMetaData();
+          decoded = true;
+        }
+      }
+
+      @Override
+      void decodeStats()  {
+        final FST.Arc<Long> arc = topFrame().arc;
+        Debug.Assert( arc.nextFinalOutput == fstOutputs.getNoOutput();
+        ord = arc.output;
+        super.decodeStats();
+      }
+
+      @Override
+      public SeekStatus seekCeil(BytesRef target)  {
+        throw new UnsupportedOperationException();
+      }
+
+      @Override
+      public BytesRef next()  {
+        //if (TEST) System.out.println("Enum next()");
+        if (pending) {
+          pending = false;
+          decodeStats();
+          return term;
+        }
+        decoded = false;
+      DFS:
+        while (level > 0) {
+          Frame frame = newFrame();
+          if (loadExpandFrame(topFrame(), frame) != null) {  // has valid target
+            pushFrame(frame);
+            if (isAccept(frame)) {  // gotcha
+              break;
+            }
+            continue;  // check next target
+          } 
+          frame = popFrame();
+          while(level > 0) {
+            if (loadNextFrame(topFrame(), frame) != null) {  // has valid sibling 
+              pushFrame(frame);
+              if (isAccept(frame)) {  // gotcha
+                break DFS;
+              }
+              continue DFS;   // check next target 
+            }
+            frame = popFrame();
+          }
+          return null;
+        }
+        decodeStats();
+        return term;
+      }
+
+      BytesRef doSeekCeil(BytesRef target)  {
+        //if (TEST) System.out.println("Enum doSeekCeil()");
+        Frame frame= null;
+        int label, upto = 0, limit = target.length;
+        while (upto < limit) {  // to target prefix, or ceil label (rewind prefix)
+          frame = newFrame();
+          label = target.bytes[upto] & 0xff;
+          frame = loadCeilFrame(label, topFrame(), frame);
+          if (frame == null || frame.arc.label != label) {
+            break;
+          }
+          Debug.Assert( isValid(frame);  // target must be fetched from automaton
+          pushFrame(frame);
+          upto++;
+        }
+        if (upto == limit) {  // got target
+          return term;
+        }
+        if (frame != null) {  // got larger term('s prefix)
+          pushFrame(frame);
+          return isAccept(frame) ? term : next();
+        }
+        while (level > 0) {   // got target's prefix, advance to larger term
+          frame = popFrame();
+          while (level > 0 && !canRewind(frame)) {
+            frame = popFrame();
+          }
+          if (loadNextFrame(topFrame(), frame) != null) {
+            pushFrame(frame);
+            return isAccept(frame) ? term : next();
+          }
+        }
+        return null;
+      }
+
+      /** Virtual frame, never pop */
+      Frame loadVirtualFrame(Frame frame)  {
+        frame.arc.output = fstOutputs.getNoOutput();
+        frame.arc.nextFinalOutput = fstOutputs.getNoOutput();
+        frame.state = -1;
+        return frame;
+      }
+
+      /** Load frame for start arc(node) on fst */
+      Frame loadFirstFrame(Frame frame)  {
+        frame.arc = fst.getFirstArc(frame.arc);
+        frame.state = fsa.getInitialState();
+        return frame;
+      }
+
+      /** Load frame for target arc(node) on fst */
+      Frame loadExpandFrame(Frame top, Frame frame)  {
+        if (!canGrow(top)) {
+          return null;
+        }
+        frame.arc = fst.readFirstRealTargetArc(top.arc.target, frame.arc, fstReader);
+        frame.state = fsa.step(top.state, frame.arc.label);
+        //if (TEST) System.out.println(" loadExpand frame="+frame);
+        if (frame.state == -1) {
+          return loadNextFrame(top, frame);
+        }
+        return frame;
+      }
+
+      /** Load frame for sibling arc(node) on fst */
+      Frame loadNextFrame(Frame top, Frame frame)  {
+        if (!canRewind(frame)) {
+          return null;
+        }
+        while (!frame.arc.isLast()) {
+          frame.arc = fst.readNextRealArc(frame.arc, fstReader);
+          frame.state = fsa.step(top.state, frame.arc.label);
+          if (frame.state != -1) {
+            break;
+          }
+        }
+        //if (TEST) System.out.println(" loadNext frame="+frame);
+        if (frame.state == -1) {
+          return null;
+        }
+        return frame;
+      }
+
+      /** Load frame for target arc(node) on fst, so that 
+       *  arc.label >= label and !fsa.reject(arc.label) */
+      Frame loadCeilFrame(int label, Frame top, Frame frame)  {
+        FST.Arc<Long> arc = frame.arc;
+        arc = Util.readCeilArc(label, fst, top.arc, arc, fstReader);
+        if (arc == null) {
+          return null;
+        }
+        frame.state = fsa.step(top.state, arc.label);
+        //if (TEST) System.out.println(" loadCeil frame="+frame);
+        if (frame.state == -1) {
+          return loadNextFrame(top, frame);
+        }
+        return frame;
+      }
+
+      bool isAccept(Frame frame) {  // reach a term both fst&fsa accepts
+        return fsa.isAccept(frame.state) && frame.arc.isFinal();
+      }
+      bool isValid(Frame frame) {   // reach a prefix both fst&fsa won't reject
+        return /*frame != null &&*/ frame.state != -1;
+      }
+      bool canGrow(Frame frame) {   // can walk forward on both fst&fsa
+        return frame.state != -1 && FST.targetHasArcs(frame.arc);
+      }
+      bool canRewind(Frame frame) { // can jump to sibling
+        return !frame.arc.isLast();
+      }
+
+      void pushFrame(Frame frame) {
+        final FST.Arc<Long> arc = frame.arc;
+        arc.output = fstOutputs.add(topFrame().arc.output, arc.output);
+        term = grow(arc.label);
+        level++;
+        Debug.Assert( frame == stack[level];
+      }
+
+      Frame popFrame() {
+        term = shrink();
+        return stack[level--];
+      }
+
+      Frame newFrame() {
+        if (level+1 == stack.length) {
+          final Frame[] temp = new Frame[ArrayUtil.oversize(level+2, RamUsageEstimator.NUM_BYTES_OBJECT_REF)];
+          System.arraycopy(stack, 0, temp, 0, stack.length);
+          for (int i = stack.length; i < temp.length; i++) {
+            temp[i] = new Frame();
+          }
+          stack = temp;
+        }
+        return stack[level+1];
+      }
+
+      Frame topFrame() {
+        return stack[level];
+      }
+
+      BytesRef grow(int label) {
+        if (term == null) {
+          term = new BytesRef(new byte[16], 0, 0);
+        } else {
+          if (term.length == term.bytes.length) {
+            term.grow(term.length+1);
+          }
+          term.bytes[term.length++] = (byte)label;
+        }
+        return term;
+      }
+
+      BytesRef shrink() {
+        if (term.length == 0) {
+          term = null;
+        } else {
+          term.length--;
+        }
+        return term;
+      }
+    }
+  }
+
+  static<T> void walk(FST<T> fst)  {
+    final ArrayList<FST.Arc<T>> queue = new ArrayList<>();
+    final BitSet seen = new BitSet();
+    final FST.BytesReader reader = fst.getBytesReader();
+    final FST.Arc<T> startArc = fst.getFirstArc(new FST.Arc<T>());
+    queue.add(startArc);
+    while (!queue.isEmpty()) {
+      final FST.Arc<T> arc = queue.remove(0);
+      final long node = arc.target;
+      //System.out.println(arc);
+      if (FST.targetHasArcs(arc) && !seen.get((int) node)) {
+        seen.set((int) node);
+        fst.readFirstRealTargetArc(node, arc, reader);
+        while (true) {
+          queue.add(new FST.Arc<T>().copyFrom(arc));
+          if (arc.isLast()) {
+            break;
+          } else {
+            fst.readNextRealArc(arc, reader);
+          }
+        }
+      }
+    }
+  }
+  
+  @Override
+  public long ramBytesUsed() {
+    long ramBytesUsed = 0;
+    for (TermsReader r : fields.values()) {
+      if (r.index != null) {
+        ramBytesUsed += r.index.sizeInBytes();
+        ramBytesUsed += RamUsageEstimator.sizeOf(r.metaBytesBlock);
+        ramBytesUsed += RamUsageEstimator.sizeOf(r.metaLongsBlock);
+        ramBytesUsed += RamUsageEstimator.sizeOf(r.skipInfo);
+        ramBytesUsed += RamUsageEstimator.sizeOf(r.statsBlock);
+      }
+    }
+    return ramBytesUsed;
+  }
+  
+  @Override
+  public void checkIntegrity()  {
+    postingsReader.checkIntegrity();
+  }
+}

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/src/Lucene.Net.Codecs/Memory/FSTOrdTermsWriter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Codecs/Memory/FSTOrdTermsWriter.cs b/src/Lucene.Net.Codecs/Memory/FSTOrdTermsWriter.cs
new file mode 100644
index 0000000..33997fd
--- /dev/null
+++ b/src/Lucene.Net.Codecs/Memory/FSTOrdTermsWriter.cs
@@ -0,0 +1,374 @@
+package org.apache.lucene.codecs.memory;
+
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+import java.io.IOException;
+import java.util.List;
+import java.util.ArrayList;
+import java.util.Comparator;
+
+import org.apache.lucene.index.FieldInfo.IndexOptions;
+import org.apache.lucene.index.FieldInfo;
+import org.apache.lucene.index.FieldInfos;
+import org.apache.lucene.index.IndexFileNames;
+import org.apache.lucene.index.SegmentWriteState;
+import org.apache.lucene.store.DataOutput;
+import org.apache.lucene.store.IndexOutput;
+import org.apache.lucene.store.RAMOutputStream;
+import org.apache.lucene.util.ArrayUtil;
+import org.apache.lucene.util.BytesRef;
+import org.apache.lucene.util.IOUtils;
+import org.apache.lucene.util.IntsRef;
+import org.apache.lucene.util.fst.Builder;
+import org.apache.lucene.util.fst.FST;
+import org.apache.lucene.util.fst.PositiveIntOutputs;
+import org.apache.lucene.util.fst.Util;
+import org.apache.lucene.codecs.BlockTermState;
+import org.apache.lucene.codecs.PostingsWriterBase;
+import org.apache.lucene.codecs.PostingsConsumer;
+import org.apache.lucene.codecs.FieldsConsumer;
+import org.apache.lucene.codecs.TermsConsumer;
+import org.apache.lucene.codecs.TermStats;
+import org.apache.lucene.codecs.CodecUtil;
+
+/** 
+ * FST-based term dict, using ord as FST output.
+ *
+ * The FST holds the mapping between &lt;term, ord&gt;, and 
+ * term's metadata is delta encoded into a single byte block.
+ *
+ * Typically the byte block consists of four parts:
+ * 1. term statistics: docFreq, totalTermFreq;
+ * 2. monotonic long[], e.g. the pointer to the postings list for that term;
+ * 3. generic byte[], e.g. other information customized by postings base.
+ * 4. single-level skip list to speed up metadata decoding by ord.
+ *
+ * <p>
+ * Files:
+ * <ul>
+ *  <li><tt>.tix</tt>: <a href="#Termindex">Term Index</a></li>
+ *  <li><tt>.tbk</tt>: <a href="#Termblock">Term Block</a></li>
+ * </ul>
+ * </p>
+ *
+ * <a name="Termindex" id="Termindex"></a>
+ * <h3>Term Index</h3>
+ * <p>
+ *  The .tix contains a list of FSTs, one for each field.
+ *  The FST maps a term to its corresponding order in current field.
+ * </p>
+ * 
+ * <ul>
+ *  <li>TermIndex(.tix) --&gt; Header, TermFST<sup>NumFields</sup>, Footer</li>
+ *  <li>TermFST --&gt; {@link FST FST&lt;long&gt;}</li>
+ *  <li>Header --&gt; {@link CodecUtil#writeHeader CodecHeader}</li>
+ *  <li>Footer --&gt; {@link CodecUtil#writeFooter CodecFooter}</li>
+ * </ul>
+ *
+ * <p>Notes:</p>
+ * <ul>
+ *  <li>
+ *  Since terms are already sorted before writing to <a href="#Termblock">Term Block</a>, 
+ *  their ords can directly used to seek term metadata from term block.
+ *  </li>
+ * </ul>
+ *
+ * <a name="Termblock" id="Termblock"></a>
+ * <h3>Term Block</h3>
+ * <p>
+ *  The .tbk contains all the statistics and metadata for terms, along with field summary (e.g. 
+ *  per-field data like number of documents in current field). For each field, there are four blocks:
+ *  <ul>
+ *   <li>statistics bytes block: contains term statistics; </li>
+ *   <li>metadata longs block: delta-encodes monotonic part of metadata; </li>
+ *   <li>metadata bytes block: encodes other parts of metadata; </li>
+ *   <li>skip block: contains skip data, to speed up metadata seeking and decoding</li>
+ *  </ul>
+ * </p>
+ *
+ * <p>File Format:</p>
+ * <ul>
+ *  <li>TermBlock(.tbk) --&gt; Header, <i>PostingsHeader</i>, FieldSummary, DirOffset</li>
+ *  <li>FieldSummary --&gt; NumFields, &lt;FieldNumber, NumTerms, SumTotalTermFreq?, SumDocFreq,
+ *                                         DocCount, LongsSize, DataBlock &gt; <sup>NumFields</sup>, Footer</li>
+ *
+ *  <li>DataBlock --&gt; StatsBlockLength, MetaLongsBlockLength, MetaBytesBlockLength, 
+ *                       SkipBlock, StatsBlock, MetaLongsBlock, MetaBytesBlock </li>
+ *  <li>SkipBlock --&gt; &lt; StatsFPDelta, MetaLongsSkipFPDelta, MetaBytesSkipFPDelta, 
+ *                            MetaLongsSkipDelta<sup>LongsSize</sup> &gt;<sup>NumTerms</sup>
+ *  <li>StatsBlock --&gt; &lt; DocFreq[Same?], (TotalTermFreq-DocFreq) ? &gt; <sup>NumTerms</sup>
+ *  <li>MetaLongsBlock --&gt; &lt; LongDelta<sup>LongsSize</sup>, BytesSize &gt; <sup>NumTerms</sup>
+ *  <li>MetaBytesBlock --&gt; Byte <sup>MetaBytesBlockLength</sup>
+ *  <li>Header --&gt; {@link CodecUtil#writeHeader CodecHeader}</li>
+ *  <li>DirOffset --&gt; {@link DataOutput#writeLong Uint64}</li>
+ *  <li>NumFields, FieldNumber, DocCount, DocFreq, LongsSize, 
+ *        FieldNumber, DocCount --&gt; {@link DataOutput#writeVInt VInt}</li>
+ *  <li>NumTerms, SumTotalTermFreq, SumDocFreq, StatsBlockLength, MetaLongsBlockLength, MetaBytesBlockLength,
+ *        StatsFPDelta, MetaLongsSkipFPDelta, MetaBytesSkipFPDelta, MetaLongsSkipStart, TotalTermFreq, 
+ *        LongDelta,--&gt; {@link DataOutput#writeVLong VLong}</li>
+ *  <li>Footer --&gt; {@link CodecUtil#writeFooter CodecFooter}</li>
+ * </ul>
+ * <p>Notes: </p>
+ * <ul>
+ *  <li>
+ *   The format of PostingsHeader and MetaBytes are customized by the specific postings implementation:
+ *   they contain arbitrary per-file data (such as parameters or versioning information), and per-term data 
+ *   (non-monotonic ones like pulsed postings data).
+ *  </li>
+ *  <li>
+ *   During initialization the reader will load all the blocks into memory. SkipBlock will be decoded, so that during seek
+ *   term dict can lookup file pointers directly. StatsFPDelta, MetaLongsSkipFPDelta, etc. are file offset
+ *   for every SkipInterval's term. MetaLongsSkipDelta is the difference from previous one, which indicates
+ *   the value of preceding metadata longs for every SkipInterval's term.
+ *  </li>
+ *  <li>
+ *   DocFreq is the count of documents which contain the term. TotalTermFreq is the total number of occurrences of the term. 
+ *   Usually these two values are the same for long tail terms, therefore one bit is stole from DocFreq to check this case,
+ *   so that encoding of TotalTermFreq may be omitted.
+ *  </li>
+ * </ul>
+ *
+ * @lucene.experimental 
+ */
+
+public class FSTOrdTermsWriter extends FieldsConsumer {
+  static final String TERMS_INDEX_EXTENSION = "tix";
+  static final String TERMS_BLOCK_EXTENSION = "tbk";
+  static final String TERMS_CODEC_NAME = "FST_ORD_TERMS_DICT";
+  public static final int TERMS_VERSION_START = 0;
+  public static final int TERMS_VERSION_CHECKSUM = 1;
+  public static final int TERMS_VERSION_CURRENT = TERMS_VERSION_CHECKSUM;
+  public static final int SKIP_INTERVAL = 8;
+  
+  final PostingsWriterBase postingsWriter;
+  final FieldInfos fieldInfos;
+  final List<FieldMetaData> fields = new ArrayList<>();
+  IndexOutput blockOut = null;
+  IndexOutput indexOut = null;
+
+  public FSTOrdTermsWriter(SegmentWriteState state, PostingsWriterBase postingsWriter)  {
+    final String termsIndexFileName = IndexFileNames.segmentFileName(state.segmentInfo.name, state.segmentSuffix, TERMS_INDEX_EXTENSION);
+    final String termsBlockFileName = IndexFileNames.segmentFileName(state.segmentInfo.name, state.segmentSuffix, TERMS_BLOCK_EXTENSION);
+
+    this.postingsWriter = postingsWriter;
+    this.fieldInfos = state.fieldInfos;
+
+    bool success = false;
+    try {
+      this.indexOut = state.directory.createOutput(termsIndexFileName, state.context);
+      this.blockOut = state.directory.createOutput(termsBlockFileName, state.context);
+      writeHeader(indexOut);
+      writeHeader(blockOut);
+      this.postingsWriter.init(blockOut); 
+      success = true;
+    } finally {
+      if (!success) {
+        IOUtils.closeWhileHandlingException(indexOut, blockOut);
+      }
+    }
+  }
+
+  @Override
+  public TermsConsumer addField(FieldInfo field)  {
+    return new TermsWriter(field);
+  }
+
+  @Override
+  public void close()  {
+    if (blockOut != null) {
+      IOException ioe = null;
+      try {
+        final long blockDirStart = blockOut.getFilePointer();
+        
+        // write field summary
+        blockOut.writeVInt(fields.size());
+        for (FieldMetaData field : fields) {
+          blockOut.writeVInt(field.fieldInfo.number);
+          blockOut.writeVLong(field.numTerms);
+          if (field.fieldInfo.getIndexOptions() != IndexOptions.DOCS_ONLY) {
+            blockOut.writeVLong(field.sumTotalTermFreq);
+          }
+          blockOut.writeVLong(field.sumDocFreq);
+          blockOut.writeVInt(field.docCount);
+          blockOut.writeVInt(field.longsSize);
+          blockOut.writeVLong(field.statsOut.getFilePointer());
+          blockOut.writeVLong(field.metaLongsOut.getFilePointer());
+          blockOut.writeVLong(field.metaBytesOut.getFilePointer());
+          
+          field.skipOut.writeTo(blockOut);
+          field.statsOut.writeTo(blockOut);
+          field.metaLongsOut.writeTo(blockOut);
+          field.metaBytesOut.writeTo(blockOut);
+          field.dict.save(indexOut);
+        }
+        writeTrailer(blockOut, blockDirStart);
+        CodecUtil.writeFooter(indexOut);
+        CodecUtil.writeFooter(blockOut);
+      } catch (IOException ioe2) {
+        ioe = ioe2;
+      } finally {
+        IOUtils.closeWhileHandlingException(ioe, blockOut, indexOut, postingsWriter);
+        blockOut = null;
+      }
+    }
+  }
+
+  private void writeHeader(IndexOutput out)  {
+    CodecUtil.writeHeader(out, TERMS_CODEC_NAME, TERMS_VERSION_CURRENT);   
+  }
+  private void writeTrailer(IndexOutput out, long dirStart)  {
+    out.writeLong(dirStart);
+  }
+
+  private static class FieldMetaData {
+    public FieldInfo fieldInfo;
+    public long numTerms;
+    public long sumTotalTermFreq;
+    public long sumDocFreq;
+    public int docCount;
+    public int longsSize;
+    public FST<Long> dict;
+
+    // TODO: block encode each part 
+
+    // vint encode next skip point (fully decoded when reading)
+    public RAMOutputStream skipOut;
+    // vint encode df, (ttf-df)
+    public RAMOutputStream statsOut;
+    // vint encode monotonic long[] and length for corresponding byte[]
+    public RAMOutputStream metaLongsOut;
+    // generic byte[]
+    public RAMOutputStream metaBytesOut;
+  }
+
+  final class TermsWriter extends TermsConsumer {
+    private final Builder<Long> builder;
+    private final PositiveIntOutputs outputs;
+    private final FieldInfo fieldInfo;
+    private final int longsSize;
+    private long numTerms;
+
+    private final IntsRef scratchTerm = new IntsRef();
+    private final RAMOutputStream statsOut = new RAMOutputStream();
+    private final RAMOutputStream metaLongsOut = new RAMOutputStream();
+    private final RAMOutputStream metaBytesOut = new RAMOutputStream();
+
+    private final RAMOutputStream skipOut = new RAMOutputStream();
+    private long lastBlockStatsFP;
+    private long lastBlockMetaLongsFP;
+    private long lastBlockMetaBytesFP;
+    private long[] lastBlockLongs;
+
+    private long[] lastLongs;
+    private long lastMetaBytesFP;
+
+    TermsWriter(FieldInfo fieldInfo) {
+      this.numTerms = 0;
+      this.fieldInfo = fieldInfo;
+      this.longsSize = postingsWriter.setField(fieldInfo);
+      this.outputs = PositiveIntOutputs.getSingleton();
+      this.builder = new Builder<>(FST.INPUT_TYPE.BYTE1, outputs);
+
+      this.lastBlockStatsFP = 0;
+      this.lastBlockMetaLongsFP = 0;
+      this.lastBlockMetaBytesFP = 0;
+      this.lastBlockLongs = new long[longsSize];
+
+      this.lastLongs = new long[longsSize];
+      this.lastMetaBytesFP = 0;
+    }
+
+    @Override
+    public Comparator<BytesRef> getComparator() {
+      return BytesRef.getUTF8SortedAsUnicodeComparator();
+    }
+
+    @Override
+    public PostingsConsumer startTerm(BytesRef text)  {
+      postingsWriter.startTerm();
+      return postingsWriter;
+    }
+
+    @Override
+    public void finishTerm(BytesRef text, TermStats stats)  {
+      if (numTerms > 0 && numTerms % SKIP_INTERVAL == 0) {
+        bufferSkip();
+      }
+      // write term meta data into fst
+      final long longs[] = new long[longsSize];
+      final long delta = stats.totalTermFreq - stats.docFreq;
+      if (stats.totalTermFreq > 0) {
+        if (delta == 0) {
+          statsOut.writeVInt(stats.docFreq<<1|1);
+        } else {
+          statsOut.writeVInt(stats.docFreq<<1|0);
+          statsOut.writeVLong(stats.totalTermFreq-stats.docFreq);
+        }
+      } else {
+        statsOut.writeVInt(stats.docFreq);
+      }
+      BlockTermState state = postingsWriter.newTermState();
+      state.docFreq = stats.docFreq;
+      state.totalTermFreq = stats.totalTermFreq;
+      postingsWriter.finishTerm(state);
+      postingsWriter.encodeTerm(longs, metaBytesOut, fieldInfo, state, true);
+      for (int i = 0; i < longsSize; i++) {
+        metaLongsOut.writeVLong(longs[i] - lastLongs[i]);
+        lastLongs[i] = longs[i];
+      }
+      metaLongsOut.writeVLong(metaBytesOut.getFilePointer() - lastMetaBytesFP);
+
+      builder.add(Util.toIntsRef(text, scratchTerm), numTerms);
+      numTerms++;
+
+      lastMetaBytesFP = metaBytesOut.getFilePointer();
+    }
+
+    @Override
+    public void finish(long sumTotalTermFreq, long sumDocFreq, int docCount)  {
+      if (numTerms > 0) {
+        final FieldMetaData metadata = new FieldMetaData();
+        metadata.fieldInfo = fieldInfo;
+        metadata.numTerms = numTerms;
+        metadata.sumTotalTermFreq = sumTotalTermFreq;
+        metadata.sumDocFreq = sumDocFreq;
+        metadata.docCount = docCount;
+        metadata.longsSize = longsSize;
+        metadata.skipOut = skipOut;
+        metadata.statsOut = statsOut;
+        metadata.metaLongsOut = metaLongsOut;
+        metadata.metaBytesOut = metaBytesOut;
+        metadata.dict = builder.finish();
+        fields.add(metadata);
+      }
+    }
+
+    private void bufferSkip()  {
+      skipOut.writeVLong(statsOut.getFilePointer() - lastBlockStatsFP);
+      skipOut.writeVLong(metaLongsOut.getFilePointer() - lastBlockMetaLongsFP);
+      skipOut.writeVLong(metaBytesOut.getFilePointer() - lastBlockMetaBytesFP);
+      for (int i = 0; i < longsSize; i++) {
+        skipOut.writeVLong(lastLongs[i] - lastBlockLongs[i]);
+      }
+      lastBlockStatsFP = statsOut.getFilePointer();
+      lastBlockMetaLongsFP = metaLongsOut.getFilePointer();
+      lastBlockMetaBytesFP = metaBytesOut.getFilePointer();
+      System.arraycopy(lastLongs, 0, lastBlockLongs, 0, longsSize);
+    }
+  }
+}

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/src/Lucene.Net.Codecs/Memory/FSTPostingsFormat.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Codecs/Memory/FSTPostingsFormat.cs b/src/Lucene.Net.Codecs/Memory/FSTPostingsFormat.cs
new file mode 100644
index 0000000..5a54abd
--- /dev/null
+++ b/src/Lucene.Net.Codecs/Memory/FSTPostingsFormat.cs
@@ -0,0 +1,83 @@
+package org.apache.lucene.codecs.memory;
+
+
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+import java.io.IOException;
+
+import org.apache.lucene.codecs.FieldsConsumer;
+import org.apache.lucene.codecs.FieldsProducer;
+import org.apache.lucene.codecs.PostingsFormat;
+import org.apache.lucene.codecs.PostingsReaderBase;
+import org.apache.lucene.codecs.PostingsWriterBase;
+import org.apache.lucene.codecs.lucene41.Lucene41PostingsWriter;
+import org.apache.lucene.codecs.lucene41.Lucene41PostingsReader;
+import org.apache.lucene.index.FieldInfo.IndexOptions;
+import org.apache.lucene.index.SegmentReadState;
+import org.apache.lucene.index.SegmentWriteState;
+import org.apache.lucene.util.IOUtils;
+
+/**
+ * FST term dict + Lucene41PBF
+ */
+
+public final class FSTPostingsFormat extends PostingsFormat {
+  public FSTPostingsFormat() {
+    super("FST41");
+  }
+
+  @Override
+  public String toString() {
+    return getName();
+  }
+
+  @Override
+  public FieldsConsumer fieldsConsumer(SegmentWriteState state)  {
+    PostingsWriterBase postingsWriter = new Lucene41PostingsWriter(state);
+
+    bool success = false;
+    try {
+      FieldsConsumer ret = new FSTTermsWriter(state, postingsWriter);
+      success = true;
+      return ret;
+    } finally {
+      if (!success) {
+        IOUtils.closeWhileHandlingException(postingsWriter);
+      }
+    }
+  }
+
+  @Override
+  public FieldsProducer fieldsProducer(SegmentReadState state)  {
+    PostingsReaderBase postingsReader = new Lucene41PostingsReader(state.directory,
+                                                                state.fieldInfos,
+                                                                state.segmentInfo,
+                                                                state.context,
+                                                                state.segmentSuffix);
+    bool success = false;
+    try {
+      FieldsProducer ret = new FSTTermsReader(state, postingsReader);
+      success = true;
+      return ret;
+    } finally {
+      if (!success) {
+        IOUtils.closeWhileHandlingException(postingsReader);
+      }
+    }
+  }
+}

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/src/Lucene.Net.Codecs/Memory/FSTPulsing41PostingsFormat.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Codecs/Memory/FSTPulsing41PostingsFormat.cs b/src/Lucene.Net.Codecs/Memory/FSTPulsing41PostingsFormat.cs
new file mode 100644
index 0000000..74c4296
--- /dev/null
+++ b/src/Lucene.Net.Codecs/Memory/FSTPulsing41PostingsFormat.cs
@@ -0,0 +1,92 @@
+package org.apache.lucene.codecs.memory;
+
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+import java.io.IOException;
+
+import org.apache.lucene.codecs.FieldsConsumer;
+import org.apache.lucene.codecs.FieldsProducer;
+import org.apache.lucene.codecs.PostingsBaseFormat;
+import org.apache.lucene.codecs.PostingsFormat;
+import org.apache.lucene.codecs.PostingsReaderBase;
+import org.apache.lucene.codecs.PostingsWriterBase;
+import org.apache.lucene.codecs.lucene41.Lucene41PostingsWriter;
+import org.apache.lucene.codecs.lucene41.Lucene41PostingsReader;
+import org.apache.lucene.codecs.lucene41.Lucene41PostingsBaseFormat;
+import org.apache.lucene.codecs.lucene41.Lucene41PostingsFormat;
+import org.apache.lucene.codecs.pulsing.PulsingPostingsWriter;
+import org.apache.lucene.codecs.pulsing.PulsingPostingsReader;
+import org.apache.lucene.index.SegmentReadState;
+import org.apache.lucene.index.SegmentWriteState;
+import org.apache.lucene.util.IOUtils;
+
+/** FST + Pulsing41, test only, since
+ *  FST does no delta encoding here!
+ *  @lucene.experimental */
+
+public class FSTPulsing41PostingsFormat extends PostingsFormat {
+  private final PostingsBaseFormat wrappedPostingsBaseFormat;
+  private final int freqCutoff;
+
+  public FSTPulsing41PostingsFormat() {
+    this(1);
+  }
+  
+  public FSTPulsing41PostingsFormat(int freqCutoff) {
+    super("FSTPulsing41");
+    this.wrappedPostingsBaseFormat = new Lucene41PostingsBaseFormat();
+    this.freqCutoff = freqCutoff;
+  }
+
+  @Override
+  public FieldsConsumer fieldsConsumer(SegmentWriteState state)  {
+    PostingsWriterBase docsWriter = null;
+    PostingsWriterBase pulsingWriter = null;
+
+    bool success = false;
+    try {
+      docsWriter = wrappedPostingsBaseFormat.postingsWriterBase(state);
+      pulsingWriter = new PulsingPostingsWriter(state, freqCutoff, docsWriter);
+      FieldsConsumer ret = new FSTTermsWriter(state, pulsingWriter);
+      success = true;
+      return ret;
+    } finally {
+      if (!success) {
+        IOUtils.closeWhileHandlingException(docsWriter, pulsingWriter);
+      }
+    }
+  }
+
+  @Override
+  public FieldsProducer fieldsProducer(SegmentReadState state)  {
+    PostingsReaderBase docsReader = null;
+    PostingsReaderBase pulsingReader = null;
+    bool success = false;
+    try {
+      docsReader = wrappedPostingsBaseFormat.postingsReaderBase(state);
+      pulsingReader = new PulsingPostingsReader(state, docsReader);
+      FieldsProducer ret = new FSTTermsReader(state, pulsingReader);
+      success = true;
+      return ret;
+    } finally {
+      if (!success) {
+        IOUtils.closeWhileHandlingException(docsReader, pulsingReader);
+      }
+    }
+  }
+}

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/src/Lucene.Net.Codecs/Memory/FSTTermOutputs.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Codecs/Memory/FSTTermOutputs.cs b/src/Lucene.Net.Codecs/Memory/FSTTermOutputs.cs
new file mode 100644
index 0000000..e0a91e8
--- /dev/null
+++ b/src/Lucene.Net.Codecs/Memory/FSTTermOutputs.cs
@@ -0,0 +1,331 @@
+package org.apache.lucene.codecs.memory;
+
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+import java.io.IOException;
+import java.util.Arrays;
+
+import org.apache.lucene.index.FieldInfo;
+import org.apache.lucene.index.FieldInfo.IndexOptions;
+import org.apache.lucene.store.DataInput;
+import org.apache.lucene.store.DataOutput;
+import org.apache.lucene.util.fst.Outputs;
+import org.apache.lucene.util.LongsRef;
+
+/**
+ * An FST {@link Outputs} implementation for 
+ * {@link FSTTermsWriter}.
+ *
+ * @lucene.experimental
+ */
+
+// NOTE: outputs should be per-field, since
+// longsSize is fixed for each field
+class FSTTermOutputs extends Outputs<FSTTermOutputs.TermData> {
+  private final static TermData NO_OUTPUT = new TermData();
+  //private static bool TEST = false;
+  private final bool hasPos;
+  private final int longsSize;
+
+  /** 
+   * Represents the metadata for one term.
+   * On an FST, only long[] part is 'shared' and pushed towards root.
+   * byte[] and term stats will be kept on deeper arcs.
+   */
+  static class TermData {
+    long[] longs;
+    byte[] bytes;
+    int docFreq;
+    long totalTermFreq;
+    TermData() {
+      this.longs = null;
+      this.bytes = null;
+      this.docFreq = 0;
+      this.totalTermFreq = -1;
+    }
+    TermData(long[] longs, byte[] bytes, int docFreq, long totalTermFreq) {
+      this.longs = longs;
+      this.bytes = bytes;
+      this.docFreq = docFreq;
+      this.totalTermFreq = totalTermFreq;
+    }
+
+    // NOTE: actually, FST nodes are seldom 
+    // identical when outputs on their arcs 
+    // aren't NO_OUTPUTs.
+    @Override
+    public int hashCode() {
+      int hash = 0;
+      if (longs != null) {
+        final int end = longs.length;
+        for (int i = 0; i < end; i++) {
+          hash -= longs[i];
+        }
+      }
+      if (bytes != null) {
+        hash = -hash;
+        final int end = bytes.length;
+        for (int i = 0; i < end; i++) {
+          hash += bytes[i];
+        }
+      }
+      hash += docFreq + totalTermFreq;
+      return hash;
+    }
+
+    @Override
+    public bool equals(Object other_) {
+      if (other_ == this) {
+        return true;
+      } else if (!(other_ instanceof FSTTermOutputs.TermData)) {
+        return false;
+      }
+      TermData other = (TermData) other_;
+      return statsEqual(this, other) && 
+             longsEqual(this, other) && 
+             bytesEqual(this, other);
+
+    }
+  }
+  
+  protected FSTTermOutputs(FieldInfo fieldInfo, int longsSize) {
+    this.hasPos = (fieldInfo.getIndexOptions() != IndexOptions.DOCS_ONLY);
+    this.longsSize = longsSize;
+  }
+
+  @Override
+  //
+  // The return value will be the smaller one, when these two are 
+  // 'comparable', i.e. 
+  // 1. every value in t1 is not larger than in t2, or
+  // 2. every value in t1 is not smaller than t2.
+  //
+  public TermData common(TermData t1, TermData t2) {
+    //if (TEST) System.out.print("common("+t1+", "+t2+") = ");
+    if (t1 == NO_OUTPUT || t2 == NO_OUTPUT) {
+      //if (TEST) System.out.println("ret:"+NO_OUTPUT);
+      return NO_OUTPUT;
+    }
+    Debug.Assert( t1.longs.length == t2.longs.length;
+
+    long[] min = t1.longs, max = t2.longs;
+    int pos = 0;
+    TermData ret;
+
+    while (pos < longsSize && min[pos] == max[pos]) {
+      pos++;
+    }
+    if (pos < longsSize) {  // unequal long[]
+      if (min[pos] > max[pos]) {
+        min = t2.longs;
+        max = t1.longs;
+      }
+      // check whether strictly smaller
+      while (pos < longsSize && min[pos] <= max[pos]) {
+        pos++;
+      }
+      if (pos < longsSize || allZero(min)) {  // not comparable or all-zero
+        ret = NO_OUTPUT;
+      } else {
+        ret = new TermData(min, null, 0, -1);
+      }
+    } else {  // equal long[]
+      if (statsEqual(t1, t2) && bytesEqual(t1, t2)) {
+        ret = t1;
+      } else if (allZero(min)) {
+        ret = NO_OUTPUT;
+      } else {
+        ret = new TermData(min, null, 0, -1);
+      }
+    }
+    //if (TEST) System.out.println("ret:"+ret);
+    return ret;
+  }
+
+  @Override
+  public TermData subtract(TermData t1, TermData t2) {
+    //if (TEST) System.out.print("subtract("+t1+", "+t2+") = ");
+    if (t2 == NO_OUTPUT) {
+      //if (TEST) System.out.println("ret:"+t1);
+      return t1;
+    }
+    Debug.Assert( t1.longs.length == t2.longs.length;
+
+    int pos = 0;
+    long diff = 0;
+    long[] share = new long[longsSize];
+
+    while (pos < longsSize) {
+      share[pos] = t1.longs[pos] - t2.longs[pos];
+      diff += share[pos];
+      pos++;
+    }
+
+    TermData ret;
+    if (diff == 0 && statsEqual(t1, t2) && bytesEqual(t1, t2)) {
+      ret = NO_OUTPUT;
+    } else {
+      ret = new TermData(share, t1.bytes, t1.docFreq, t1.totalTermFreq);
+    }
+    //if (TEST) System.out.println("ret:"+ret);
+    return ret;
+  }
+
+  // TODO: if we refactor a 'addSelf(TermData other)',
+  // we can gain about 5~7% for fuzzy queries, however this also 
+  // means we are putting too much stress on FST Outputs decoding?
+  @Override
+  public TermData add(TermData t1, TermData t2) {
+    //if (TEST) System.out.print("add("+t1+", "+t2+") = ");
+    if (t1 == NO_OUTPUT) {
+      //if (TEST) System.out.println("ret:"+t2);
+      return t2;
+    } else if (t2 == NO_OUTPUT) {
+      //if (TEST) System.out.println("ret:"+t1);
+      return t1;
+    }
+    Debug.Assert( t1.longs.length == t2.longs.length;
+
+    int pos = 0;
+    long[] accum = new long[longsSize];
+
+    while (pos < longsSize) {
+      accum[pos] = t1.longs[pos] + t2.longs[pos];
+      pos++;
+    }
+
+    TermData ret;
+    if (t2.bytes != null || t2.docFreq > 0) {
+      ret = new TermData(accum, t2.bytes, t2.docFreq, t2.totalTermFreq);
+    } else {
+      ret = new TermData(accum, t1.bytes, t1.docFreq, t1.totalTermFreq);
+    }
+    //if (TEST) System.out.println("ret:"+ret);
+    return ret;
+  }
+
+  @Override
+  public void write(TermData data, DataOutput out)  {
+    int bit0 = allZero(data.longs) ? 0 : 1;
+    int bit1 = ((data.bytes == null || data.bytes.length == 0) ? 0 : 1) << 1;
+    int bit2 = ((data.docFreq == 0)  ? 0 : 1) << 2;
+    int bits = bit0 | bit1 | bit2;
+    if (bit1 > 0) {  // determine extra length
+      if (data.bytes.length < 32) {
+        bits |= (data.bytes.length << 3);
+        out.writeByte((byte)bits);
+      } else {
+        out.writeByte((byte)bits);
+        out.writeVInt(data.bytes.length);
+      }
+    } else {
+      out.writeByte((byte)bits);
+    }
+    if (bit0 > 0) {  // not all-zero case
+      for (int pos = 0; pos < longsSize; pos++) {
+        out.writeVLong(data.longs[pos]);
+      }
+    }
+    if (bit1 > 0) {  // bytes exists
+      out.writeBytes(data.bytes, 0, data.bytes.length);
+    }
+    if (bit2 > 0) {  // stats exist
+      if (hasPos) {
+        if (data.docFreq == data.totalTermFreq) {
+          out.writeVInt((data.docFreq << 1) | 1);
+        } else {
+          out.writeVInt((data.docFreq << 1));
+          out.writeVLong(data.totalTermFreq - data.docFreq);
+        }
+      } else {
+        out.writeVInt(data.docFreq);
+      }
+    }
+  }
+
+  @Override
+  public TermData read(DataInput in)  {
+    long[] longs = new long[longsSize];
+    byte[] bytes = null;
+    int docFreq = 0;
+    long totalTermFreq = -1;
+    int bits = in.readByte() & 0xff;
+    int bit0 = bits & 1;
+    int bit1 = bits & 2;
+    int bit2 = bits & 4;
+    int bytesSize = (bits >>> 3);
+    if (bit1 > 0 && bytesSize == 0) {  // determine extra length
+      bytesSize = in.readVInt();
+    }
+    if (bit0 > 0) {  // not all-zero case
+      for (int pos = 0; pos < longsSize; pos++) {
+        longs[pos] = in.readVLong();
+      }
+    }
+    if (bit1 > 0) {  // bytes exists
+      bytes = new byte[bytesSize];
+      in.readBytes(bytes, 0, bytesSize);
+    }
+    if (bit2 > 0) {  // stats exist
+      int code = in.readVInt();
+      if (hasPos) {
+        totalTermFreq = docFreq = code >>> 1;
+        if ((code & 1) == 0) {
+          totalTermFreq += in.readVLong();
+        }
+      } else {
+        docFreq = code;
+      }
+    }
+    return new TermData(longs, bytes, docFreq, totalTermFreq);
+  }
+
+  @Override
+  public TermData getNoOutput() {
+    return NO_OUTPUT;
+  }
+
+  @Override
+  public String outputToString(TermData data) {
+    return data.toString();
+  }
+
+  static bool statsEqual(final TermData t1, final TermData t2) {
+    return t1.docFreq == t2.docFreq && t1.totalTermFreq == t2.totalTermFreq;
+  }
+  static bool bytesEqual(final TermData t1, final TermData t2) {
+    if (t1.bytes == null && t2.bytes == null) {
+      return true;
+    }
+    return t1.bytes != null && t2.bytes != null && Arrays.equals(t1.bytes, t2.bytes);
+  }
+  static bool longsEqual(final TermData t1, final TermData t2) {
+    if (t1.longs == null && t2.longs == null) {
+      return true;
+    }
+    return t1.longs != null && t2.longs != null && Arrays.equals(t1.longs, t2.longs);
+  }
+  static bool allZero(final long[] l) {
+    for (int i = 0; i < l.length; i++) {
+      if (l[i] != 0) {
+        return false;
+      }
+    }
+    return true;
+  }
+}

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/src/Lucene.Net.Codecs/Memory/FSTTermsReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Codecs/Memory/FSTTermsReader.cs b/src/Lucene.Net.Codecs/Memory/FSTTermsReader.cs
new file mode 100644
index 0000000..e38bb59
--- /dev/null
+++ b/src/Lucene.Net.Codecs/Memory/FSTTermsReader.cs
@@ -0,0 +1,762 @@
+package org.apache.lucene.codecs.memory;
+
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+import java.io.IOException;
+import java.util.ArrayList;
+import java.util.BitSet;
+import java.util.Collections;
+import java.util.Comparator;
+import java.util.Iterator;
+import java.util.TreeMap;
+
+import org.apache.lucene.codecs.BlockTermState;
+import org.apache.lucene.codecs.CodecUtil;
+import org.apache.lucene.codecs.FieldsProducer;
+import org.apache.lucene.codecs.PostingsReaderBase;
+import org.apache.lucene.index.CorruptIndexException;
+import org.apache.lucene.index.DocsAndPositionsEnum;
+import org.apache.lucene.index.DocsEnum;
+import org.apache.lucene.index.FieldInfo.IndexOptions;
+import org.apache.lucene.index.FieldInfo;
+import org.apache.lucene.index.FieldInfos;
+import org.apache.lucene.index.IndexFileNames;
+import org.apache.lucene.index.SegmentInfo;
+import org.apache.lucene.index.SegmentReadState;
+import org.apache.lucene.index.TermState;
+import org.apache.lucene.index.Terms;
+import org.apache.lucene.index.TermsEnum;
+import org.apache.lucene.store.ByteArrayDataInput;
+import org.apache.lucene.store.IndexInput;
+import org.apache.lucene.util.ArrayUtil;
+import org.apache.lucene.util.Bits;
+import org.apache.lucene.util.BytesRef;
+import org.apache.lucene.util.IOUtils;
+import org.apache.lucene.util.RamUsageEstimator;
+import org.apache.lucene.util.automaton.ByteRunAutomaton;
+import org.apache.lucene.util.automaton.CompiledAutomaton;
+import org.apache.lucene.util.fst.BytesRefFSTEnum.InputOutput;
+import org.apache.lucene.util.fst.BytesRefFSTEnum;
+import org.apache.lucene.util.fst.FST;
+import org.apache.lucene.util.fst.Outputs;
+import org.apache.lucene.util.fst.Util;
+
+/**
+ * FST-based terms dictionary reader.
+ *
+ * The FST directly maps each term and its metadata, 
+ * it is memory resident.
+ *
+ * @lucene.experimental
+ */
+
+public class FSTTermsReader extends FieldsProducer {
+  final TreeMap<String, TermsReader> fields = new TreeMap<>();
+  final PostingsReaderBase postingsReader;
+  //static bool TEST = false;
+  final int version;
+
+  public FSTTermsReader(SegmentReadState state, PostingsReaderBase postingsReader)  {
+    final String termsFileName = IndexFileNames.segmentFileName(state.segmentInfo.name, state.segmentSuffix, FSTTermsWriter.TERMS_EXTENSION);
+
+    this.postingsReader = postingsReader;
+    final IndexInput in = state.directory.openInput(termsFileName, state.context);
+
+    bool success = false;
+    try {
+      version = readHeader(in);
+      if (version >= FSTTermsWriter.TERMS_VERSION_CHECKSUM) {
+        CodecUtil.checksumEntireFile(in);
+      }
+      this.postingsReader.init(in);
+      seekDir(in);
+
+      final FieldInfos fieldInfos = state.fieldInfos;
+      final int numFields = in.readVInt();
+      for (int i = 0; i < numFields; i++) {
+        int fieldNumber = in.readVInt();
+        FieldInfo fieldInfo = fieldInfos.fieldInfo(fieldNumber);
+        long numTerms = in.readVLong();
+        long sumTotalTermFreq = fieldInfo.getIndexOptions() == IndexOptions.DOCS_ONLY ? -1 : in.readVLong();
+        long sumDocFreq = in.readVLong();
+        int docCount = in.readVInt();
+        int longsSize = in.readVInt();
+        TermsReader current = new TermsReader(fieldInfo, in, numTerms, sumTotalTermFreq, sumDocFreq, docCount, longsSize);
+        TermsReader previous = fields.put(fieldInfo.name, current);
+        checkFieldSummary(state.segmentInfo, in, current, previous);
+      }
+      success = true;
+    } finally {
+      if (success) {
+        IOUtils.close(in);
+      } else {
+        IOUtils.closeWhileHandlingException(in);
+      }
+    }
+  }
+
+  private int readHeader(IndexInput in)  {
+    return CodecUtil.checkHeader(in, FSTTermsWriter.TERMS_CODEC_NAME,
+                                     FSTTermsWriter.TERMS_VERSION_START,
+                                     FSTTermsWriter.TERMS_VERSION_CURRENT);
+  }
+  private void seekDir(IndexInput in)  {
+    if (version >= FSTTermsWriter.TERMS_VERSION_CHECKSUM) {
+      in.seek(in.length() - CodecUtil.footerLength() - 8);
+    } else {
+      in.seek(in.length() - 8);
+    }
+    in.seek(in.readLong());
+  }
+  private void checkFieldSummary(SegmentInfo info, IndexInput in, TermsReader field, TermsReader previous)  {
+    // #docs with field must be <= #docs
+    if (field.docCount < 0 || field.docCount > info.getDocCount()) {
+      throw new CorruptIndexException("invalid docCount: " + field.docCount + " maxDoc: " + info.getDocCount() + " (resource=" + in + ")");
+    }
+    // #postings must be >= #docs with field
+    if (field.sumDocFreq < field.docCount) {
+      throw new CorruptIndexException("invalid sumDocFreq: " + field.sumDocFreq + " docCount: " + field.docCount + " (resource=" + in + ")");
+    }
+    // #positions must be >= #postings
+    if (field.sumTotalTermFreq != -1 && field.sumTotalTermFreq < field.sumDocFreq) {
+      throw new CorruptIndexException("invalid sumTotalTermFreq: " + field.sumTotalTermFreq + " sumDocFreq: " + field.sumDocFreq + " (resource=" + in + ")");
+    }
+    if (previous != null) {
+      throw new CorruptIndexException("duplicate fields: " + field.fieldInfo.name + " (resource=" + in + ")");
+    }
+  }
+
+  @Override
+  public Iterator<String> iterator() {
+    return Collections.unmodifiableSet(fields.keySet()).iterator();
+  }
+
+  @Override
+  public Terms terms(String field)  {
+    Debug.Assert( field != null;
+    return fields.get(field);
+  }
+
+  @Override
+  public int size() {
+    return fields.size();
+  }
+
+  @Override
+  public void close()  {
+    try {
+      IOUtils.close(postingsReader);
+    } finally {
+      fields.clear();
+    }
+  }
+
+  final class TermsReader extends Terms {
+    final FieldInfo fieldInfo;
+    final long numTerms;
+    final long sumTotalTermFreq;
+    final long sumDocFreq;
+    final int docCount;
+    final int longsSize;
+    final FST<FSTTermOutputs.TermData> dict;
+
+    TermsReader(FieldInfo fieldInfo, IndexInput in, long numTerms, long sumTotalTermFreq, long sumDocFreq, int docCount, int longsSize)  {
+      this.fieldInfo = fieldInfo;
+      this.numTerms = numTerms;
+      this.sumTotalTermFreq = sumTotalTermFreq;
+      this.sumDocFreq = sumDocFreq;
+      this.docCount = docCount;
+      this.longsSize = longsSize;
+      this.dict = new FST<>(in, new FSTTermOutputs(fieldInfo, longsSize));
+    }
+
+    @Override
+    public Comparator<BytesRef> getComparator() {
+      return BytesRef.getUTF8SortedAsUnicodeComparator();
+    }
+
+    @Override
+    public bool hasFreqs() {
+      return fieldInfo.getIndexOptions().compareTo(IndexOptions.DOCS_AND_FREQS) >= 0;
+    }
+
+    @Override
+    public bool hasOffsets() {
+      return fieldInfo.getIndexOptions().compareTo(IndexOptions.DOCS_AND_FREQS_AND_POSITIONS_AND_OFFSETS) >= 0;
+    }
+
+    @Override
+    public bool hasPositions() {
+      return fieldInfo.getIndexOptions().compareTo(IndexOptions.DOCS_AND_FREQS_AND_POSITIONS) >= 0;
+    }
+
+    @Override
+    public bool hasPayloads() {
+      return fieldInfo.hasPayloads();
+    }
+
+    @Override
+    public long size() {
+      return numTerms;
+    }
+
+    @Override
+    public long getSumTotalTermFreq() {
+      return sumTotalTermFreq;
+    }
+
+    @Override
+    public long getSumDocFreq()  {
+      return sumDocFreq;
+    }
+
+    @Override
+    public int getDocCount()  {
+      return docCount;
+    }
+
+    @Override
+    public TermsEnum iterator(TermsEnum reuse)  {
+      return new SegmentTermsEnum();
+    }
+
+    @Override
+    public TermsEnum intersect(CompiledAutomaton compiled, BytesRef startTerm)  {
+      return new IntersectTermsEnum(compiled, startTerm);
+    }
+
+    // Only wraps common operations for PBF interact
+    abstract class BaseTermsEnum extends TermsEnum {
+      /* Current term, null when enum ends or unpositioned */
+      BytesRef term;
+
+      /* Current term stats + decoded metadata (customized by PBF) */
+      final BlockTermState state;
+
+      /* Current term stats + undecoded metadata (long[] & byte[]) */
+      FSTTermOutputs.TermData meta;
+      ByteArrayDataInput bytesReader;
+
+      /** Decodes metadata into customized term state */
+      abstract void decodeMetaData() ;
+
+      BaseTermsEnum()  {
+        this.state = postingsReader.newTermState();
+        this.bytesReader = new ByteArrayDataInput();
+        this.term = null;
+        // NOTE: metadata will only be initialized in child class
+      }
+
+      @Override
+      public TermState termState()  {
+        decodeMetaData();
+        return state.clone();
+      }
+
+      @Override
+      public BytesRef term() {
+        return term;
+      }
+
+      @Override
+      public int docFreq()  {
+        return state.docFreq;
+      }
+
+      @Override
+      public long totalTermFreq()  {
+        return state.totalTermFreq;
+      }
+
+      @Override
+      public DocsEnum docs(Bits liveDocs, DocsEnum reuse, int flags)  {
+        decodeMetaData();
+        return postingsReader.docs(fieldInfo, state, liveDocs, reuse, flags);
+      }
+
+      @Override
+      public DocsAndPositionsEnum docsAndPositions(Bits liveDocs, DocsAndPositionsEnum reuse, int flags)  {
+        if (!hasPositions()) {
+          return null;
+        }
+        decodeMetaData();
+        return postingsReader.docsAndPositions(fieldInfo, state, liveDocs, reuse, flags);
+      }
+
+      @Override
+      public void seekExact(long ord)  {
+        throw new UnsupportedOperationException();
+      }
+
+      @Override
+      public long ord() {
+        throw new UnsupportedOperationException();
+      }
+    }
+
+
+    // Iterates through all terms in this field
+    private final class SegmentTermsEnum extends BaseTermsEnum {
+      final BytesRefFSTEnum<FSTTermOutputs.TermData> fstEnum;
+
+      /* True when current term's metadata is decoded */
+      bool decoded;
+
+      /* True when current enum is 'positioned' by seekExact(TermState) */
+      bool seekPending;
+
+      SegmentTermsEnum()  {
+        super();
+        this.fstEnum = new BytesRefFSTEnum<>(dict);
+        this.decoded = false;
+        this.seekPending = false;
+        this.meta = null;
+      }
+
+      @Override
+      public Comparator<BytesRef> getComparator() {
+        return BytesRef.getUTF8SortedAsUnicodeComparator();
+      }
+
+      // Let PBF decode metadata from long[] and byte[]
+      @Override
+      void decodeMetaData()  {
+        if (!decoded && !seekPending) {
+          if (meta.bytes != null) {
+            bytesReader.reset(meta.bytes, 0, meta.bytes.length);
+          }
+          postingsReader.decodeTerm(meta.longs, bytesReader, fieldInfo, state, true);
+          decoded = true;
+        }
+      }
+
+      // Update current enum according to FSTEnum
+      void updateEnum(final InputOutput<FSTTermOutputs.TermData> pair) {
+        if (pair == null) {
+          term = null;
+        } else {
+          term = pair.input;
+          meta = pair.output;
+          state.docFreq = meta.docFreq;
+          state.totalTermFreq = meta.totalTermFreq;
+        }
+        decoded = false;
+        seekPending = false;
+      }
+
+      @Override
+      public BytesRef next()  {
+        if (seekPending) {  // previously positioned, but termOutputs not fetched
+          seekPending = false;
+          SeekStatus status = seekCeil(term);
+          Debug.Assert( status == SeekStatus.FOUND;  // must positioned on valid term
+        }
+        updateEnum(fstEnum.next());
+        return term;
+      }
+
+      @Override
+      public bool seekExact(BytesRef target)  {
+        updateEnum(fstEnum.seekExact(target));
+        return term != null;
+      }
+
+      @Override
+      public SeekStatus seekCeil(BytesRef target)  {
+        updateEnum(fstEnum.seekCeil(target));
+        if (term == null) {
+          return SeekStatus.END;
+        } else {
+          return term.equals(target) ? SeekStatus.FOUND : SeekStatus.NOT_FOUND;
+        }
+      }
+
+      @Override
+      public void seekExact(BytesRef target, TermState otherState) {
+        if (!target.equals(term)) {
+          state.copyFrom(otherState);
+          term = BytesRef.deepCopyOf(target);
+          seekPending = true;
+        }
+      }
+    }
+
+    // Iterates intersect result with automaton (cannot seek!)
+    private final class IntersectTermsEnum extends BaseTermsEnum {
+      /* True when current term's metadata is decoded */
+      bool decoded;
+
+      /* True when there is pending term when calling next() */
+      bool pending;
+
+      /* stack to record how current term is constructed, 
+       * used to accumulate metadata or rewind term:
+       *   level == term.length + 1,
+       *         == 0 when term is null */
+      Frame[] stack;
+      int level;
+
+      /* to which level the metadata is accumulated 
+       * so that we can accumulate metadata lazily */
+      int metaUpto;
+
+      /* term dict fst */
+      final FST<FSTTermOutputs.TermData> fst;
+      final FST.BytesReader fstReader;
+      final Outputs<FSTTermOutputs.TermData> fstOutputs;
+
+      /* query automaton to intersect with */
+      final ByteRunAutomaton fsa;
+
+      private final class Frame {
+        /* fst stats */
+        FST.Arc<FSTTermOutputs.TermData> fstArc;
+
+        /* automaton stats */
+        int fsaState;
+
+        Frame() {
+          this.fstArc = new FST.Arc<>();
+          this.fsaState = -1;
+        }
+
+        public String toString() {
+          return "arc=" + fstArc + " state=" + fsaState;
+        }
+      }
+
+      IntersectTermsEnum(CompiledAutomaton compiled, BytesRef startTerm)  {
+        super();
+        //if (TEST) System.out.println("Enum init, startTerm=" + startTerm);
+        this.fst = dict;
+        this.fstReader = fst.getBytesReader();
+        this.fstOutputs = dict.outputs;
+        this.fsa = compiled.runAutomaton;
+        this.level = -1;
+        this.stack = new Frame[16];
+        for (int i = 0 ; i < stack.length; i++) {
+          this.stack[i] = new Frame();
+        }
+
+        Frame frame;
+        frame = loadVirtualFrame(newFrame());
+        this.level++;
+        frame = loadFirstFrame(newFrame());
+        pushFrame(frame);
+
+        this.meta = null;
+        this.metaUpto = 1;
+        this.decoded = false;
+        this.pending = false;
+
+        if (startTerm == null) {
+          pending = isAccept(topFrame());
+        } else {
+          doSeekCeil(startTerm);
+          pending = !startTerm.equals(term) && isValid(topFrame()) && isAccept(topFrame());
+        }
+      }
+
+      @Override
+      public Comparator<BytesRef> getComparator() {
+        return BytesRef.getUTF8SortedAsUnicodeComparator();
+      }
+
+      @Override
+      void decodeMetaData()  {
+        Debug.Assert( term != null;
+        if (!decoded) {
+          if (meta.bytes != null) {
+            bytesReader.reset(meta.bytes, 0, meta.bytes.length);
+          }
+          postingsReader.decodeTerm(meta.longs, bytesReader, fieldInfo, state, true);
+          decoded = true;
+        }
+      }
+
+      /** Lazily accumulate meta data, when we got a accepted term */
+      void loadMetaData()  {
+        FST.Arc<FSTTermOutputs.TermData> last, next;
+        last = stack[metaUpto].fstArc;
+        while (metaUpto != level) {
+          metaUpto++;
+          next = stack[metaUpto].fstArc;
+          next.output = fstOutputs.add(next.output, last.output);
+          last = next;
+        }
+        if (last.isFinal()) {
+          meta = fstOutputs.add(last.output, last.nextFinalOutput);
+        } else {
+          meta = last.output;
+        }
+        state.docFreq = meta.docFreq;
+        state.totalTermFreq = meta.totalTermFreq;
+      }
+
+      @Override
+      public SeekStatus seekCeil(BytesRef target)  {
+        decoded = false;
+        term = doSeekCeil(target);
+        loadMetaData();
+        if (term == null) {
+          return SeekStatus.END;
+        } else {
+          return term.equals(target) ? SeekStatus.FOUND : SeekStatus.NOT_FOUND;
+        }
+      }
+
+      @Override
+      public BytesRef next()  {
+        //if (TEST) System.out.println("Enum next()");
+        if (pending) {
+          pending = false;
+          loadMetaData();
+          return term;
+        }
+        decoded = false;
+      DFS:
+        while (level > 0) {
+          Frame frame = newFrame();
+          if (loadExpandFrame(topFrame(), frame) != null) {  // has valid target
+            pushFrame(frame);
+            if (isAccept(frame)) {  // gotcha
+              break;
+            }
+            continue;  // check next target
+          } 
+          frame = popFrame();
+          while(level > 0) {
+            if (loadNextFrame(topFrame(), frame) != null) {  // has valid sibling 
+              pushFrame(frame);
+              if (isAccept(frame)) {  // gotcha
+                break DFS;
+              }
+              continue DFS;   // check next target 
+            }
+            frame = popFrame();
+          }
+          return null;
+        }
+        loadMetaData();
+        return term;
+      }
+
+      private BytesRef doSeekCeil(BytesRef target)  {
+        //if (TEST) System.out.println("Enum doSeekCeil()");
+        Frame frame= null;
+        int label, upto = 0, limit = target.length;
+        while (upto < limit) {  // to target prefix, or ceil label (rewind prefix)
+          frame = newFrame();
+          label = target.bytes[upto] & 0xff;
+          frame = loadCeilFrame(label, topFrame(), frame);
+          if (frame == null || frame.fstArc.label != label) {
+            break;
+          }
+          Debug.Assert( isValid(frame);  // target must be fetched from automaton
+          pushFrame(frame);
+          upto++;
+        }
+        if (upto == limit) {  // got target
+          return term;
+        }
+        if (frame != null) {  // got larger term('s prefix)
+          pushFrame(frame);
+          return isAccept(frame) ? term : next();
+        }
+        while (level > 0) {  // got target's prefix, advance to larger term
+          frame = popFrame();
+          while (level > 0 && !canRewind(frame)) {
+            frame = popFrame();
+          }
+          if (loadNextFrame(topFrame(), frame) != null) {
+            pushFrame(frame);
+            return isAccept(frame) ? term : next();
+          }
+        }
+        return null;
+      }
+
+      /** Virtual frame, never pop */
+      Frame loadVirtualFrame(Frame frame)  {
+        frame.fstArc.output = fstOutputs.getNoOutput();
+        frame.fstArc.nextFinalOutput = fstOutputs.getNoOutput();
+        frame.fsaState = -1;
+        return frame;
+      }
+
+      /** Load frame for start arc(node) on fst */
+      Frame loadFirstFrame(Frame frame)  {
+        frame.fstArc = fst.getFirstArc(frame.fstArc);
+        frame.fsaState = fsa.getInitialState();
+        return frame;
+      }
+
+      /** Load frame for target arc(node) on fst */
+      Frame loadExpandFrame(Frame top, Frame frame)  {
+        if (!canGrow(top)) {
+          return null;
+        }
+        frame.fstArc = fst.readFirstRealTargetArc(top.fstArc.target, frame.fstArc, fstReader);
+        frame.fsaState = fsa.step(top.fsaState, frame.fstArc.label);
+        //if (TEST) System.out.println(" loadExpand frame="+frame);
+        if (frame.fsaState == -1) {
+          return loadNextFrame(top, frame);
+        }
+        return frame;
+      }
+
+      /** Load frame for sibling arc(node) on fst */
+      Frame loadNextFrame(Frame top, Frame frame)  {
+        if (!canRewind(frame)) {
+          return null;
+        }
+        while (!frame.fstArc.isLast()) {
+          frame.fstArc = fst.readNextRealArc(frame.fstArc, fstReader);
+          frame.fsaState = fsa.step(top.fsaState, frame.fstArc.label);
+          if (frame.fsaState != -1) {
+            break;
+          }
+        }
+        //if (TEST) System.out.println(" loadNext frame="+frame);
+        if (frame.fsaState == -1) {
+          return null;
+        }
+        return frame;
+      }
+
+      /** Load frame for target arc(node) on fst, so that 
+       *  arc.label >= label and !fsa.reject(arc.label) */
+      Frame loadCeilFrame(int label, Frame top, Frame frame)  {
+        FST.Arc<FSTTermOutputs.TermData> arc = frame.fstArc;
+        arc = Util.readCeilArc(label, fst, top.fstArc, arc, fstReader);
+        if (arc == null) {
+          return null;
+        }
+        frame.fsaState = fsa.step(top.fsaState, arc.label);
+        //if (TEST) System.out.println(" loadCeil frame="+frame);
+        if (frame.fsaState == -1) {
+          return loadNextFrame(top, frame);
+        }
+        return frame;
+      }
+
+      bool isAccept(Frame frame) {  // reach a term both fst&fsa accepts
+        return fsa.isAccept(frame.fsaState) && frame.fstArc.isFinal();
+      }
+      bool isValid(Frame frame) {   // reach a prefix both fst&fsa won't reject
+        return /*frame != null &&*/ frame.fsaState != -1;
+      }
+      bool canGrow(Frame frame) {   // can walk forward on both fst&fsa
+        return frame.fsaState != -1 && FST.targetHasArcs(frame.fstArc);
+      }
+      bool canRewind(Frame frame) { // can jump to sibling
+        return !frame.fstArc.isLast();
+      }
+
+      void pushFrame(Frame frame) {
+        term = grow(frame.fstArc.label);
+        level++;
+        //if (TEST) System.out.println("  term=" + term + " level=" + level);
+      }
+
+      Frame popFrame() {
+        term = shrink();
+        level--;
+        metaUpto = metaUpto > level ? level : metaUpto;
+        //if (TEST) System.out.println("  term=" + term + " level=" + level);
+        return stack[level+1];
+      }
+
+      Frame newFrame() {
+        if (level+1 == stack.length) {
+          final Frame[] temp = new Frame[ArrayUtil.oversize(level+2, RamUsageEstimator.NUM_BYTES_OBJECT_REF)];
+          System.arraycopy(stack, 0, temp, 0, stack.length);
+          for (int i = stack.length; i < temp.length; i++) {
+            temp[i] = new Frame();
+          }
+          stack = temp;
+        }
+        return stack[level+1];
+      }
+
+      Frame topFrame() {
+        return stack[level];
+      }
+
+      BytesRef grow(int label) {
+        if (term == null) {
+          term = new BytesRef(new byte[16], 0, 0);
+        } else {
+          if (term.length == term.bytes.length) {
+            term.grow(term.length+1);
+          }
+          term.bytes[term.length++] = (byte)label;
+        }
+        return term;
+      }
+
+      BytesRef shrink() {
+        if (term.length == 0) {
+          term = null;
+        } else {
+          term.length--;
+        }
+        return term;
+      }
+    }
+  }
+
+  static<T> void walk(FST<T> fst)  {
+    final ArrayList<FST.Arc<T>> queue = new ArrayList<>();
+    final BitSet seen = new BitSet();
+    final FST.BytesReader reader = fst.getBytesReader();
+    final FST.Arc<T> startArc = fst.getFirstArc(new FST.Arc<T>());
+    queue.add(startArc);
+    while (!queue.isEmpty()) {
+      final FST.Arc<T> arc = queue.remove(0);
+      final long node = arc.target;
+      //System.out.println(arc);
+      if (FST.targetHasArcs(arc) && !seen.get((int) node)) {
+        seen.set((int) node);
+        fst.readFirstRealTargetArc(node, arc, reader);
+        while (true) {
+          queue.add(new FST.Arc<T>().copyFrom(arc));
+          if (arc.isLast()) {
+            break;
+          } else {
+            fst.readNextRealArc(arc, reader);
+          }
+        }
+      }
+    }
+  }
+
+  @Override
+  public long ramBytesUsed() {
+    long ramBytesUsed = 0;
+    for (TermsReader r : fields.values()) {
+      ramBytesUsed += r.dict == null ? 0 : r.dict.sizeInBytes();
+    }
+    return ramBytesUsed;
+  }
+  
+  @Override
+  public void checkIntegrity()  {
+    postingsReader.checkIntegrity();
+  }
+}


[11/51] [abbrv] [partial] Cleaning up and getting ready to development towards v4.8

Posted by sy...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/csharp/failures/AssemblyInfo.cs
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/csharp/failures/AssemblyInfo.cs b/lib/NUnit.org/NUnit/2.5.9/samples/csharp/failures/AssemblyInfo.cs
deleted file mode 100644
index 67e65b0..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/csharp/failures/AssemblyInfo.cs
+++ /dev/null
@@ -1,58 +0,0 @@
-using System.Reflection;
-using System.Runtime.CompilerServices;
-
-//
-// General Information about an assembly is controlled through the following 
-// set of attributes. Change these attribute values to modify the information
-// associated with an assembly.
-//
-[assembly: AssemblyTitle("csharp.sample.dll")]
-[assembly: AssemblyDescription("C# Sample Unit Tests")]
-[assembly: AssemblyConfiguration("")]
-[assembly: AssemblyCompany("NUnit")]
-[assembly: AssemblyProduct("NUnit")]
-[assembly: AssemblyCopyright("Copyright (C) 2002-2003 James W. Newkirk, Michael C. Two, Alexei A. Vorontsov. \nCopyright (C) 2000-2003 Philip Craig.\nAll Rights Reserved.")]
-[assembly: AssemblyTrademark("")]
-[assembly: AssemblyCulture("")]		
-
-//
-// Version information for an assembly consists of the following four values:
-//
-//      Major Version
-//      Minor Version 
-//      Build Number
-//      Revision
-//
-// You can specify all the values or you can default the Revision and Build Numbers 
-// by using the '*' as shown below:
-
-[assembly: AssemblyVersion("2.2.0.0")]
-
-//
-// In order to sign your assembly you must specify a key to use. Refer to the 
-// Microsoft .NET Framework documentation for more information on assembly signing.
-//
-// Use the attributes below to control which key is used for signing. 
-//
-// Notes: 
-//   (*) If no key is specified, the assembly is not signed.
-//   (*) KeyName refers to a key that has been installed in the Crypto Service
-//       Provider (CSP) on your machine. KeyFile refers to a file which contains
-//       a key.
-//   (*) If the KeyFile and the KeyName values are both specified, the 
-//       following processing occurs:
-//       (1) If the KeyName can be found in the CSP, that key is used.
-//       (2) If the KeyName does not exist and the KeyFile does exist, the key 
-//           in the KeyFile is installed into the CSP and used.
-//   (*) In order to create a KeyFile, you can use the sn.exe (Strong Name) utility.
-//       When specifying the KeyFile, the location of the KeyFile should be
-//       relative to the project output directory which is
-//       %Project Directory%\obj\<configuration>. For example, if your KeyFile is
-//       located in the project directory, you would specify the AssemblyKeyFile 
-//       attribute as [assembly: AssemblyKeyFile("..\\..\\mykey.snk")]
-//   (*) Delay Signing is an advanced option - see the Microsoft .NET Framework
-//       documentation for more information on this.
-//
-[assembly: AssemblyDelaySign(false)]
-[assembly: AssemblyKeyFile("")]
-[assembly: AssemblyKeyName("")]

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/csharp/failures/CSharpTest.cs
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/csharp/failures/CSharpTest.cs b/lib/NUnit.org/NUnit/2.5.9/samples/csharp/failures/CSharpTest.cs
deleted file mode 100644
index 0ab0fe6..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/csharp/failures/CSharpTest.cs
+++ /dev/null
@@ -1,85 +0,0 @@
-// ****************************************************************
-// This is free software licensed under the NUnit license. You
-// may obtain a copy of the license as well as information regarding
-// copyright ownership at http://nunit.org/?p=license&r=2.4.
-// ****************************************************************
-
-namespace NUnit.Samples 
-{
-	using System;
-	using NUnit.Framework;
-
-	/// <summary>Some simple Tests.</summary>
-	/// 
-	[TestFixture] 
-	public class SimpleCSharpTest
-	{
-		/// <summary>
-		/// 
-		/// </summary>
-		protected int fValue1;
-		/// <summary>
-		/// 
-		/// </summary>
-		protected int fValue2;
-		
-		/// <summary>
-		/// 
-		/// </summary>
-		[SetUp] public void Init() 
-		{
-			fValue1= 2;
-			fValue2= 3;
-		}
-
-		/// <summary>
-		/// 
-		/// </summary>
-		///
-		[Test] public void Add() 
-		{
-			double result= fValue1 + fValue2;
-			// forced failure result == 5
-			Assert.AreEqual(6, result, "Expected Failure.");
-		}
-
-		/// <summary>
-		/// 
-		/// </summary>
-		/// 
-		[Test] public void DivideByZero() 
-		{
-			int zero= 0;
-			int result= 8/zero;
-		}
-
-		/// <summary>
-		/// 
-		/// </summary>
-		/// 
-		[Test] public void Equals() 
-		{
-			Assert.AreEqual(12, 12, "Integer");
-			Assert.AreEqual(12L, 12L, "Long");
-			Assert.AreEqual('a', 'a', "Char");
-			Assert.AreEqual((object)12, (object)12, "Integer Object Cast");
-            
-			Assert.AreEqual(12, 13, "Expected Failure (Integer)");
-			Assert.AreEqual(12.0, 11.99, 0.0, "Expected Failure (Double).");
-		}
-
-		[Test]
-		[ExpectedException(typeof(InvalidOperationException))]
-		public void ExpectAnException()
-		{
-			throw new InvalidCastException();
-		}
-
-		[Test]
-		[Ignore("ignored test")]
-		public void IgnoredTest()
-		{
-			throw new Exception();
-		}
-	}
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/csharp/failures/cs-failures.build
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/csharp/failures/cs-failures.build b/lib/NUnit.org/NUnit/2.5.9/samples/csharp/failures/cs-failures.build
deleted file mode 100644
index ea71419..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/csharp/failures/cs-failures.build
+++ /dev/null
@@ -1,11 +0,0 @@
-<?xml version="1.0"?>
-<project name="cs-failures" default="build">
-
-  <include buildfile="../../samples.common"/>
-
-  <patternset id="source-files">
-    <include name="AssemblyInfo.cs" />
-    <include name="CSharpTest.cs" />
-  </patternset>
-
-</project>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/csharp/failures/cs-failures.csproj
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/csharp/failures/cs-failures.csproj b/lib/NUnit.org/NUnit/2.5.9/samples/csharp/failures/cs-failures.csproj
deleted file mode 100644
index e66e6d4..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/csharp/failures/cs-failures.csproj
+++ /dev/null
@@ -1,20 +0,0 @@
-<VisualStudioProject>
-  <CSHARP ProjectType="Local" ProductVersion="7.10.3077" SchemaVersion="2.0" ProjectGuid="{15D66EEE-A852-4A52-89C2-83E74ECF3770}">
-    <Build>
-      <Settings ApplicationIcon="" AssemblyKeyContainerName="" AssemblyName="cs-failures" AssemblyOriginatorKeyFile="" DefaultClientScript="JScript" DefaultHTMLPageLayout="Grid" DefaultTargetSchema="IE50" DelaySign="false" OutputType="Library" PreBuildEvent="" PostBuildEvent="" RootNamespace="csharp_sample" RunPostBuildEvent="OnBuildSuccess" StartupObject="">
-        <Config Name="Debug" AllowUnsafeBlocks="false" BaseAddress="285212672" CheckForOverflowUnderflow="false" ConfigurationOverrideFile="" DefineConstants="DEBUG;TRACE" DocumentationFile="" DebugSymbols="true" FileAlignment="4096" IncrementalBuild="true" NoStdLib="false" NoWarn="" Optimize="false" OutputPath="bin\Debug\" RegisterForComInterop="false" RemoveIntegerChecks="false" TreatWarningsAsErrors="false" WarningLevel="4" />
-        <Config Name="Release" AllowUnsafeBlocks="false" BaseAddress="285212672" CheckForOverflowUnderflow="false" ConfigurationOverrideFile="" DefineConstants="TRACE" DocumentationFile="" DebugSymbols="false" FileAlignment="4096" IncrementalBuild="false" NoStdLib="false" NoWarn="" Optimize="true" OutputPath="bin\Release\" RegisterForComInterop="false" RemoveIntegerChecks="false" TreatWarningsAsErrors="false" WarningLevel="4" />
-      </Settings>
-      <References>
-        <Reference Name="System" AssemblyName="System" />
-        <Reference Name="nunit.framework" AssemblyName="nunit.framework, Version=2.5, Culture=neutral, PublicKeyToken=96d09a1eb7f44a77" HintPath="..\..\..\bin\net-1.1\framework\nunit.framework.dll" />
-      </References>
-    </Build>
-    <Files>
-      <Include>
-        <File RelPath="AssemblyInfo.cs" SubType="Code" BuildAction="Compile" />
-        <File RelPath="CSharpTest.cs" SubType="Code" BuildAction="Compile" />
-      </Include>
-    </Files>
-  </CSHARP>
-</VisualStudioProject>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/csharp/money/AssemblyInfo.cs
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/csharp/money/AssemblyInfo.cs b/lib/NUnit.org/NUnit/2.5.9/samples/csharp/money/AssemblyInfo.cs
deleted file mode 100644
index 72a1771..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/csharp/money/AssemblyInfo.cs
+++ /dev/null
@@ -1,58 +0,0 @@
-using System.Reflection;
-using System.Runtime.CompilerServices;
-
-//
-// General Information about an assembly is controlled through the following 
-// set of attributes. Change these attribute values to modify the information
-// associated with an assembly.
-//
-[assembly: AssemblyTitle("")]
-[assembly: AssemblyDescription("")]
-[assembly: AssemblyConfiguration("")]
-[assembly: AssemblyCompany("")]
-[assembly: AssemblyProduct("")]
-[assembly: AssemblyCopyright("")]
-[assembly: AssemblyTrademark("")]
-[assembly: AssemblyCulture("")]		
-
-//
-// Version information for an assembly consists of the following four values:
-//
-//      Major Version
-//      Minor Version 
-//      Build Number
-//      Revision
-//
-// You can specify all the values or you can default the Revision and Build Numbers 
-// by using the '*' as shown below:
-
-[assembly: AssemblyVersion("2.2.0.0")]
-
-//
-// In order to sign your assembly you must specify a key to use. Refer to the 
-// Microsoft .NET Framework documentation for more information on assembly signing.
-//
-// Use the attributes below to control which key is used for signing. 
-//
-// Notes: 
-//   (*) If no key is specified, the assembly is not signed.
-//   (*) KeyName refers to a key that has been installed in the Crypto Service
-//       Provider (CSP) on your machine. KeyFile refers to a file which contains
-//       a key.
-//   (*) If the KeyFile and the KeyName values are both specified, the 
-//       following processing occurs:
-//       (1) If the KeyName can be found in the CSP, that key is used.
-//       (2) If the KeyName does not exist and the KeyFile does exist, the key 
-//           in the KeyFile is installed into the CSP and used.
-//   (*) In order to create a KeyFile, you can use the sn.exe (Strong Name) utility.
-//       When specifying the KeyFile, the location of the KeyFile should be
-//       relative to the project output directory which is
-//       %Project Directory%\obj\<configuration>. For example, if your KeyFile is
-//       located in the project directory, you would specify the AssemblyKeyFile 
-//       attribute as [assembly: AssemblyKeyFile("..\\..\\mykey.snk")]
-//   (*) Delay Signing is an advanced option - see the Microsoft .NET Framework
-//       documentation for more information on this.
-//
-[assembly: AssemblyDelaySign(false)]
-[assembly: AssemblyKeyFile("")]
-[assembly: AssemblyKeyName("")]

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/csharp/money/IMoney.cs
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/csharp/money/IMoney.cs b/lib/NUnit.org/NUnit/2.5.9/samples/csharp/money/IMoney.cs
deleted file mode 100644
index 9b3fd35..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/csharp/money/IMoney.cs
+++ /dev/null
@@ -1,37 +0,0 @@
-// ****************************************************************
-// This is free software licensed under the NUnit license. You
-// may obtain a copy of the license as well as information regarding
-// copyright ownership at http://nunit.org/?p=license&r=2.4.
-// ****************************************************************
-
-namespace NUnit.Samples.Money 
-{
-
-	/// <summary>The common interface for simple Monies and MoneyBags.</summary>
-	interface IMoney 
-	{
-
-		/// <summary>Adds a money to this money.</summary>
-		IMoney Add(IMoney m);
-
-		/// <summary>Adds a simple Money to this money. This is a helper method for
-		/// implementing double dispatch.</summary>
-		IMoney AddMoney(Money m);
-
-		/// <summary>Adds a MoneyBag to this money. This is a helper method for
-		/// implementing double dispatch.</summary>
-		IMoney AddMoneyBag(MoneyBag s);
-
-		/// <value>True if this money is zero.</value>
-		bool IsZero { get; }
-
-		/// <summary>Multiplies a money by the given factor.</summary>
-		IMoney Multiply(int factor);
-
-		/// <summary>Negates this money.</summary>
-		IMoney Negate();
-
-		/// <summary>Subtracts a money from this money.</summary>
-		IMoney Subtract(IMoney m);
-	}
-}

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/csharp/money/Money.cs
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/csharp/money/Money.cs b/lib/NUnit.org/NUnit/2.5.9/samples/csharp/money/Money.cs
deleted file mode 100644
index 2e2de93..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/csharp/money/Money.cs
+++ /dev/null
@@ -1,103 +0,0 @@
-// ****************************************************************
-// This is free software licensed under the NUnit license. You
-// may obtain a copy of the license as well as information regarding
-// copyright ownership at http://nunit.org/?p=license&r=2.4.
-// ****************************************************************
-
-namespace NUnit.Samples.Money 
-{
-
-	using System;
-	using System.Text;
-
-	/// <summary>A simple Money.</summary>
-	class Money: IMoney 
-	{
-
-		private int fAmount;
-		private String fCurrency;
-        
-		/// <summary>Constructs a money from the given amount and
-		/// currency.</summary>
-		public Money(int amount, String currency) 
-		{
-			fAmount= amount;
-			fCurrency= currency;
-		}
-
-		/// <summary>Adds a money to this money. Forwards the request to
-		/// the AddMoney helper.</summary>
-		public IMoney Add(IMoney m) 
-		{
-			return m.AddMoney(this);
-		}
-
-		public IMoney AddMoney(Money m) 
-		{
-			if (m.Currency.Equals(Currency) )
-				return new Money(Amount+m.Amount, Currency);
-			return new MoneyBag(this, m);
-		}
-
-		public IMoney AddMoneyBag(MoneyBag s) 
-		{
-			return s.AddMoney(this);
-		}
-
-		public int Amount 
-		{
-			get { return fAmount; }
-		}
-
-		public String Currency 
-		{
-			get { return fCurrency; }
-		}
-
-		public override bool Equals(Object anObject) 
-		{
-			if (IsZero)
-				if (anObject is IMoney)
-					return ((IMoney)anObject).IsZero;
-			if (anObject is Money) 
-			{
-				Money aMoney= (Money)anObject;
-				return aMoney.Currency.Equals(Currency)
-					&& Amount == aMoney.Amount;
-			}
-			return false;
-		}
-
-		public override int GetHashCode() 
-		{
-			return fCurrency.GetHashCode()+fAmount;
-		}
-
-		public bool IsZero 
-		{
-			get { return Amount == 0; }
-		}
-
-		public IMoney Multiply(int factor) 
-		{
-			return new Money(Amount*factor, Currency);
-		}
-
-		public IMoney Negate() 
-		{
-			return new Money(-Amount, Currency);
-		}
-
-		public IMoney Subtract(IMoney m) 
-		{
-			return Add(m.Negate());
-		}
-
-		public override String ToString() 
-		{
-			StringBuilder buffer = new StringBuilder();
-			buffer.Append("["+Amount+" "+Currency+"]");
-			return buffer.ToString();
-		}
-	}
-}

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/csharp/money/MoneyBag.cs
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/csharp/money/MoneyBag.cs b/lib/NUnit.org/NUnit/2.5.9/samples/csharp/money/MoneyBag.cs
deleted file mode 100644
index 45b9442..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/csharp/money/MoneyBag.cs
+++ /dev/null
@@ -1,174 +0,0 @@
-// ****************************************************************
-// This is free software licensed under the NUnit license. You
-// may obtain a copy of the license as well as information regarding
-// copyright ownership at http://nunit.org/?p=license&r=2.4.
-// ****************************************************************
-
-namespace NUnit.Samples.Money 
-{
-
-	using System;
-	using System.Collections;
-	using System.Text;
-
-	/// <summary>A MoneyBag defers exchange rate conversions.</summary>
-	/// <remarks>For example adding 
-	/// 12 Swiss Francs to 14 US Dollars is represented as a bag 
-	/// containing the two Monies 12 CHF and 14 USD. Adding another
-	/// 10 Swiss francs gives a bag with 22 CHF and 14 USD. Due to 
-	/// the deferred exchange rate conversion we can later value a 
-	/// MoneyBag with different exchange rates.
-	///
-	/// A MoneyBag is represented as a list of Monies and provides 
-	/// different constructors to create a MoneyBag.</remarks>
-	class MoneyBag: IMoney 
-	{
-		private ArrayList fMonies= new ArrayList(5);
-
-		private MoneyBag() 
-		{
-		}
-		public MoneyBag(Money[] bag) 
-		{
-			for (int i= 0; i < bag.Length; i++) 
-			{
-				if (!bag[i].IsZero)
-					AppendMoney(bag[i]);
-			}
-		}
-		public MoneyBag(Money m1, Money m2) 
-		{
-			AppendMoney(m1);
-			AppendMoney(m2);
-		}
-		public MoneyBag(Money m, MoneyBag bag) 
-		{
-			AppendMoney(m);
-			AppendBag(bag);
-		}
-		public MoneyBag(MoneyBag m1, MoneyBag m2) 
-		{
-			AppendBag(m1);
-			AppendBag(m2);
-		}
-		public IMoney Add(IMoney m) 
-		{
-			return m.AddMoneyBag(this);
-		}
-		public IMoney AddMoney(Money m) 
-		{
-			return (new MoneyBag(m, this)).Simplify();
-		}
-		public IMoney AddMoneyBag(MoneyBag s) 
-		{
-			return (new MoneyBag(s, this)).Simplify();
-		}
-		private void AppendBag(MoneyBag aBag) 
-		{
-			foreach (Money m in aBag.fMonies)
-				AppendMoney(m);
-		}
-		private void AppendMoney(Money aMoney) 
-		{
-			IMoney old= FindMoney(aMoney.Currency);
-			if (old == null) 
-			{
-				fMonies.Add(aMoney);
-				return;
-			}
-			fMonies.Remove(old);
-			IMoney sum= old.Add(aMoney);
-			if (sum.IsZero) 
-				return;
-			fMonies.Add(sum);
-		}
-		private bool Contains(Money aMoney) 
-		{
-			Money m= FindMoney(aMoney.Currency);
-			return m.Amount == aMoney.Amount;
-		}
-		public override bool Equals(Object anObject) 
-		{
-			if (IsZero)
-				if (anObject is IMoney)
-					return ((IMoney)anObject).IsZero;
-            
-			if (anObject is MoneyBag) 
-			{
-				MoneyBag aMoneyBag= (MoneyBag)anObject;
-				if (aMoneyBag.fMonies.Count != fMonies.Count)
-					return false;
-                
-				foreach (Money m in fMonies) 
-				{
-					if (!aMoneyBag.Contains(m))
-						return false;
-				}
-				return true;
-			}
-			return false;
-		}
-		private Money FindMoney(String currency) 
-		{
-			foreach (Money m in fMonies) 
-			{
-				if (m.Currency.Equals(currency))
-					return m;
-			}
-			return null;
-		}
-		public override int GetHashCode() 
-		{
-			int hash= 0;
-			foreach (Money m in fMonies) 
-			{
-				hash^= m.GetHashCode();
-			}
-			return hash;
-		}
-		public bool IsZero 
-		{
-			get { return fMonies.Count == 0; }
-		}
-		public IMoney Multiply(int factor) 
-		{
-			MoneyBag result= new MoneyBag();
-			if (factor != 0) 
-			{
-				foreach (Money m in fMonies) 
-				{
-					result.AppendMoney((Money)m.Multiply(factor));
-				}
-			}
-			return result;
-		}
-		public IMoney Negate() 
-		{
-			MoneyBag result= new MoneyBag();
-			foreach (Money m in fMonies) 
-			{
-				result.AppendMoney((Money)m.Negate());
-			}
-			return result;
-		}
-		private IMoney Simplify() 
-		{
-			if (fMonies.Count == 1)
-				return (IMoney)fMonies[0];
-			return this;
-		}
-		public IMoney Subtract(IMoney m) 
-		{
-			return Add(m.Negate());
-		}
-		public override String ToString() 
-		{
-			StringBuilder buffer = new StringBuilder();
-			buffer.Append("{");
-			foreach (Money m in fMonies)
-				buffer.Append(m);
-			buffer.Append("}");
-			return buffer.ToString();
-		}
-	}
-}

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/csharp/money/MoneyTest.cs
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/csharp/money/MoneyTest.cs b/lib/NUnit.org/NUnit/2.5.9/samples/csharp/money/MoneyTest.cs
deleted file mode 100644
index 603dcf8..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/csharp/money/MoneyTest.cs
+++ /dev/null
@@ -1,321 +0,0 @@
-// ****************************************************************
-// This is free software licensed under the NUnit license. You
-// may obtain a copy of the license as well as information regarding
-// copyright ownership at http://nunit.org/?p=license&r=2.4.
-// ****************************************************************
-
-namespace NUnit.Samples.Money 
-{
-	using System;
-	using NUnit.Framework;
-	/// <summary>
-	/// 
-	/// </summary>
-	/// 
-	[TestFixture]
-	public class MoneyTest 
-	{
-		private Money f12CHF;
-		private Money f14CHF;
-		private Money f7USD;
-		private Money f21USD;
-        
-		private MoneyBag fMB1;
-		private MoneyBag fMB2;
-
-		/// <summary>
-		/// 
-		/// </summary>
-		/// 
-		[SetUp]
-		protected void SetUp() 
-		{
-			f12CHF= new Money(12, "CHF");
-			f14CHF= new Money(14, "CHF");
-			f7USD= new Money( 7, "USD");
-			f21USD= new Money(21, "USD");
-
-			fMB1= new MoneyBag(f12CHF, f7USD);
-			fMB2= new MoneyBag(f14CHF, f21USD);
-		}
-
-		/// <summary>
-		/// 
-		/// </summary>
-		/// 
-		[Test]
-		public void BagMultiply() 
-		{
-			// {[12 CHF][7 USD]} *2 == {[24 CHF][14 USD]}
-			Money[] bag = { new Money(24, "CHF"), new Money(14, "USD") };
-			MoneyBag expected= new MoneyBag(bag);
-			Assert.AreEqual(expected, fMB1.Multiply(2));
-			Assert.AreEqual(fMB1, fMB1.Multiply(1));
-			Assert.IsTrue(fMB1.Multiply(0).IsZero);
-		}
-
-		/// <summary>
-		/// 
-		/// </summary>
-		/// 
-		[Test]
-		public void BagNegate() 
-		{
-			// {[12 CHF][7 USD]} negate == {[-12 CHF][-7 USD]}
-			Money[] bag= { new Money(-12, "CHF"), new Money(-7, "USD") };
-			MoneyBag expected= new MoneyBag(bag);
-			Assert.AreEqual(expected, fMB1.Negate());
-		}
-
-		/// <summary>
-		/// 
-		/// </summary>
-		/// 
-		[Test]
-		public void BagSimpleAdd() 
-		{
-			// {[12 CHF][7 USD]} + [14 CHF] == {[26 CHF][7 USD]}
-			Money[] bag= { new Money(26, "CHF"), new Money(7, "USD") };
-			MoneyBag expected= new MoneyBag(bag);
-			Assert.AreEqual(expected, fMB1.Add(f14CHF));
-		}
-
-		/// <summary>
-		/// 
-		/// </summary>
-		/// 
-		[Test]
-		public void BagSubtract() 
-		{
-			// {[12 CHF][7 USD]} - {[14 CHF][21 USD] == {[-2 CHF][-14 USD]}
-			Money[] bag= { new Money(-2, "CHF"), new Money(-14, "USD") };
-			MoneyBag expected= new MoneyBag(bag);
-			Assert.AreEqual(expected, fMB1.Subtract(fMB2));
-		}
-
-		/// <summary>
-		/// 
-		/// </summary>
-		/// 
-		[Test]
-		public void BagSumAdd() 
-		{
-			// {[12 CHF][7 USD]} + {[14 CHF][21 USD]} == {[26 CHF][28 USD]}
-			Money[] bag= { new Money(26, "CHF"), new Money(28, "USD") };
-			MoneyBag expected= new MoneyBag(bag);
-			Assert.AreEqual(expected, fMB1.Add(fMB2));
-		}
-
-		/// <summary>
-		/// 
-		/// </summary>
-		/// 
-		[Test]
-		public void IsZero() 
-		{
-			Assert.IsTrue(fMB1.Subtract(fMB1).IsZero);
-
-			Money[] bag = { new Money(0, "CHF"), new Money(0, "USD") };
-			Assert.IsTrue(new MoneyBag(bag).IsZero);
-		}
-
-		/// <summary>
-		/// 
-		/// </summary>
-		/// 
-		[Test]
-		public void MixedSimpleAdd() 
-		{
-			// [12 CHF] + [7 USD] == {[12 CHF][7 USD]}
-			Money[] bag= { f12CHF, f7USD };
-			MoneyBag expected= new MoneyBag(bag);
-			Assert.AreEqual(expected, f12CHF.Add(f7USD));
-		}
-
-		/// <summary>
-		/// 
-		/// </summary>
-		/// 
-		[Test]
-		public void MoneyBagEquals() 
-		{
-			//NOTE: Normally we use Assert.AreEqual to test whether two
-			// objects are equal. But here we are testing the MoneyBag.Equals()
-			// method itself, so using AreEqual would not serve the purpose.
-			Assert.IsFalse(fMB1.Equals(null)); 
-
-			Assert.IsTrue(fMB1.Equals( fMB1 ));
-			MoneyBag equal= new MoneyBag(new Money(12, "CHF"), new Money(7, "USD"));
-			Assert.IsTrue(fMB1.Equals(equal));
-			Assert.IsTrue(!fMB1.Equals(f12CHF));
-			Assert.IsTrue(!f12CHF.Equals(fMB1));
-			Assert.IsTrue(!fMB1.Equals(fMB2));
-		}
-
-		/// <summary>
-		/// 
-		/// </summary>
-		/// 
-		[Test]
-		public void MoneyBagHash() 
-		{
-			MoneyBag equal= new MoneyBag(new Money(12, "CHF"), new Money(7, "USD"));
-			Assert.AreEqual(fMB1.GetHashCode(), equal.GetHashCode());
-		}
-
-		/// <summary>
-		/// 
-		/// </summary>
-		/// 
-		[Test]
-		public void MoneyEquals() 
-		{
-			//NOTE: Normally we use Assert.AreEqual to test whether two
-			// objects are equal. But here we are testing the MoneyBag.Equals()
-			// method itself, so using AreEqual would not serve the purpose.
-			Assert.IsFalse(f12CHF.Equals(null)); 
-			Money equalMoney= new Money(12, "CHF");
-			Assert.IsTrue(f12CHF.Equals( f12CHF ));
-			Assert.IsTrue(f12CHF.Equals( equalMoney ));
-			Assert.IsFalse(f12CHF.Equals(f14CHF));
-		}
-
-		/// <summary>
-		/// 
-		/// </summary>
-		/// 
-		[Test]
-		public void MoneyHash() 
-		{
-			Assert.IsFalse(f12CHF.Equals(null)); 
-			Money equal= new Money(12, "CHF");
-			Assert.AreEqual(f12CHF.GetHashCode(), equal.GetHashCode());
-		}
-
-		/// <summary>
-		/// 
-		/// </summary>
-		/// 
-		[Test]
-		public void Normalize() 
-		{
-			Money[] bag= { new Money(26, "CHF"), new Money(28, "CHF"), new Money(6, "CHF") };
-			MoneyBag moneyBag= new MoneyBag(bag);
-			Money[] expected = { new Money(60, "CHF") };
-			// note: expected is still a MoneyBag
-			MoneyBag expectedBag= new MoneyBag(expected);
-			Assert.AreEqual(expectedBag, moneyBag);
-		}
-
-		/// <summary>
-		/// 
-		/// </summary>
-		/// 
-		[Test]
-		public void Normalize2() 
-		{
-			// {[12 CHF][7 USD]} - [12 CHF] == [7 USD]
-			Money expected= new Money(7, "USD");
-			Assert.AreEqual(expected, fMB1.Subtract(f12CHF));
-		}
-
-		/// <summary>
-		/// 
-		/// </summary>
-		/// 
-		[Test]
-		public void Normalize3() 
-		{
-			// {[12 CHF][7 USD]} - {[12 CHF][3 USD]} == [4 USD]
-			Money[] s1 = { new Money(12, "CHF"), new Money(3, "USD") };
-			MoneyBag ms1= new MoneyBag(s1);
-			Money expected= new Money(4, "USD");
-			Assert.AreEqual(expected, fMB1.Subtract(ms1));
-		}
-
-		/// <summary>
-		/// 
-		/// </summary>
-		/// 
-		[Test]
-		public void Normalize4() 
-		{
-			// [12 CHF] - {[12 CHF][3 USD]} == [-3 USD]
-			Money[] s1 = { new Money(12, "CHF"), new Money(3, "USD") };
-			MoneyBag ms1= new MoneyBag(s1);
-			Money expected= new Money(-3, "USD");
-			Assert.AreEqual(expected, f12CHF.Subtract(ms1));
-		}
-
-		/// <summary>
-		/// 
-		/// </summary>
-		/// 
-		[Test]
-		public void Print() 
-		{
-			Assert.AreEqual("[12 CHF]", f12CHF.ToString());
-		}
-
-		/// <summary>
-		/// 
-		/// </summary>
-		/// 
-		[Test]
-		public void SimpleAdd() 
-		{
-			// [12 CHF] + [14 CHF] == [26 CHF]
-			Money expected= new Money(26, "CHF");
-			Assert.AreEqual(expected, f12CHF.Add(f14CHF));
-		}
-
-		/// <summary>
-		/// 
-		/// </summary>
-		/// 
-		[Test]
-		public void SimpleBagAdd() 
-		{
-			// [14 CHF] + {[12 CHF][7 USD]} == {[26 CHF][7 USD]}
-			Money[] bag= { new Money(26, "CHF"), new Money(7, "USD") };
-			MoneyBag expected= new MoneyBag(bag);
-			Assert.AreEqual(expected, f14CHF.Add(fMB1));
-		}
-
-		/// <summary>
-		/// 
-		/// </summary>
-		/// 
-		[Test]
-		public void SimpleMultiply() 
-		{
-			// [14 CHF] *2 == [28 CHF]
-			Money expected= new Money(28, "CHF");
-			Assert.AreEqual(expected, f14CHF.Multiply(2));
-		}
-
-		/// <summary>
-		/// 
-		/// </summary>
-		/// 
-		[Test]
-		public void SimpleNegate() 
-		{
-			// [14 CHF] negate == [-14 CHF]
-			Money expected= new Money(-14, "CHF");
-			Assert.AreEqual(expected, f14CHF.Negate());
-		}
-
-		/// <summary>
-		/// 
-		/// </summary>
-		/// 
-		[Test]
-		public void SimpleSubtract() 
-		{
-			// [14 CHF] - [12 CHF] == [2 CHF]
-			Money expected= new Money(2, "CHF");
-			Assert.AreEqual(expected, f14CHF.Subtract(f12CHF));
-		}
-	}
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/csharp/money/cs-money.build
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/csharp/money/cs-money.build b/lib/NUnit.org/NUnit/2.5.9/samples/csharp/money/cs-money.build
deleted file mode 100644
index 917d973..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/csharp/money/cs-money.build
+++ /dev/null
@@ -1,14 +0,0 @@
-<?xml version="1.0"?>
-<project name="cs-money" default="build">
-
-  <include buildfile="../../samples.common" />
-  
-  <patternset id="source-files">
-    <include name="AssemblyInfo.cs" />
-    <include name="IMoney.cs" />
-    <include name="Money.cs" />
-    <include name="MoneyBag.cs" />
-    <include name="MoneyTest.cs" />
-  </patternset>
-
-</project>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/csharp/money/cs-money.csproj
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/csharp/money/cs-money.csproj b/lib/NUnit.org/NUnit/2.5.9/samples/csharp/money/cs-money.csproj
deleted file mode 100644
index 1ccc7c9..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/csharp/money/cs-money.csproj
+++ /dev/null
@@ -1,23 +0,0 @@
-<VisualStudioProject>
-  <CSHARP ProjectType="Local" ProductVersion="7.10.3077" SchemaVersion="2.0" ProjectGuid="{11EDF872-A04D-4F75-A1BF-71168DC86AF3}">
-    <Build>
-      <Settings ApplicationIcon="" AssemblyKeyContainerName="" AssemblyName="cs-money" AssemblyOriginatorKeyFile="" DefaultClientScript="JScript" DefaultHTMLPageLayout="Grid" DefaultTargetSchema="IE50" DelaySign="false" OutputType="Library" PreBuildEvent="" PostBuildEvent="" RootNamespace="money" RunPostBuildEvent="OnBuildSuccess" StartupObject="">
-        <Config Name="Debug" AllowUnsafeBlocks="false" BaseAddress="285212672" CheckForOverflowUnderflow="false" ConfigurationOverrideFile="" DefineConstants="DEBUG;TRACE" DocumentationFile="" DebugSymbols="true" FileAlignment="4096" IncrementalBuild="true" NoStdLib="false" NoWarn="" Optimize="false" OutputPath="bin\Debug\" RegisterForComInterop="false" RemoveIntegerChecks="false" TreatWarningsAsErrors="false" WarningLevel="4" />
-        <Config Name="Release" AllowUnsafeBlocks="false" BaseAddress="285212672" CheckForOverflowUnderflow="false" ConfigurationOverrideFile="" DefineConstants="TRACE" DocumentationFile="" DebugSymbols="false" FileAlignment="4096" IncrementalBuild="false" NoStdLib="false" NoWarn="" Optimize="true" OutputPath="bin\Release\" RegisterForComInterop="false" RemoveIntegerChecks="false" TreatWarningsAsErrors="false" WarningLevel="4" />
-      </Settings>
-      <References>
-        <Reference Name="System" AssemblyName="System" />
-        <Reference Name="nunit.framework" AssemblyName="nunit.framework, Version=2.5, Culture=neutral, PublicKeyToken=96d09a1eb7f44a77" HintPath="..\..\..\bin\net-1.1\framework\nunit.framework.dll" />
-      </References>
-    </Build>
-    <Files>
-      <Include>
-        <File RelPath="AssemblyInfo.cs" SubType="Code" BuildAction="Compile" />
-        <File RelPath="IMoney.cs" SubType="Code" BuildAction="Compile" />
-        <File RelPath="Money.cs" SubType="Code" BuildAction="Compile" />
-        <File RelPath="MoneyBag.cs" SubType="Code" BuildAction="Compile" />
-        <File RelPath="MoneyTest.cs" SubType="Code" BuildAction="Compile" />
-      </Include>
-    </Files>
-  </CSHARP>
-</VisualStudioProject>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/csharp/syntax/AssemblyInfo.cs
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/csharp/syntax/AssemblyInfo.cs b/lib/NUnit.org/NUnit/2.5.9/samples/csharp/syntax/AssemblyInfo.cs
deleted file mode 100644
index 9f89a32..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/csharp/syntax/AssemblyInfo.cs
+++ /dev/null
@@ -1,58 +0,0 @@
-using System.Reflection;
-using System.Runtime.CompilerServices;
-
-//
-// General Information about an assembly is controlled through the following 
-// set of attributes. Change these attribute values to modify the information
-// associated with an assembly.
-//
-[assembly: AssemblyTitle("")]
-[assembly: AssemblyDescription("")]
-[assembly: AssemblyConfiguration("")]
-[assembly: AssemblyCompany("")]
-[assembly: AssemblyProduct("")]
-[assembly: AssemblyCopyright("")]
-[assembly: AssemblyTrademark("")]
-[assembly: AssemblyCulture("")]		
-
-//
-// Version information for an assembly consists of the following four values:
-//
-//      Major Version
-//      Minor Version 
-//      Build Number
-//      Revision
-//
-// You can specify all the values or you can default the Revision and Build Numbers 
-// by using the '*' as shown below:
-
-[assembly: AssemblyVersion("1.0.*")]
-
-//
-// In order to sign your assembly you must specify a key to use. Refer to the 
-// Microsoft .NET Framework documentation for more information on assembly signing.
-//
-// Use the attributes below to control which key is used for signing. 
-//
-// Notes: 
-//   (*) If no key is specified, the assembly is not signed.
-//   (*) KeyName refers to a key that has been installed in the Crypto Service
-//       Provider (CSP) on your machine. KeyFile refers to a file which contains
-//       a key.
-//   (*) If the KeyFile and the KeyName values are both specified, the 
-//       following processing occurs:
-//       (1) If the KeyName can be found in the CSP, that key is used.
-//       (2) If the KeyName does not exist and the KeyFile does exist, the key 
-//           in the KeyFile is installed into the CSP and used.
-//   (*) In order to create a KeyFile, you can use the sn.exe (Strong Name) utility.
-//       When specifying the KeyFile, the location of the KeyFile should be
-//       relative to the project output directory which is
-//       %Project Directory%\obj\<configuration>. For example, if your KeyFile is
-//       located in the project directory, you would specify the AssemblyKeyFile 
-//       attribute as [assembly: AssemblyKeyFile("..\\..\\mykey.snk")]
-//   (*) Delay Signing is an advanced option - see the Microsoft .NET Framework
-//       documentation for more information on this.
-//
-[assembly: AssemblyDelaySign(false)]
-[assembly: AssemblyKeyFile("")]
-[assembly: AssemblyKeyName("")]

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/csharp/syntax/AssertSyntaxTests.cs
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/csharp/syntax/AssertSyntaxTests.cs b/lib/NUnit.org/NUnit/2.5.9/samples/csharp/syntax/AssertSyntaxTests.cs
deleted file mode 100644
index b612580..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/csharp/syntax/AssertSyntaxTests.cs
+++ /dev/null
@@ -1,828 +0,0 @@
-// ****************************************************************
-// Copyright 2007, Charlie Poole
-// This is free software licensed under the NUnit license. You may
-// obtain a copy of the license at http://nunit.org/?p=license&r=2.4
-// ****************************************************************
-
-using System;
-using System.Collections;
-using NUnit.Framework.Constraints;
-
-namespace NUnit.Framework.Tests
-{
-	/// <summary>
-	/// This test fixture attempts to exercise all the syntactic
-	/// variations of Assert without getting into failures, errors 
-	/// or corner cases. Thus, some of the tests may be duplicated 
-	/// in other fixtures.
-	/// 
-	/// Each test performs the same operations using the classic
-	/// syntax (if available) and the new syntax in both the
-	/// helper-based and inherited forms.
-	/// 
-	/// This Fixture will eventually be duplicated in other
-	/// supported languages. 
-	/// </summary>
-	[TestFixture]
-	public class AssertSyntaxTests : AssertionHelper
-	{
-		#region Simple Constraint Tests
-		[Test]
-		public void IsNull()
-		{
-			object nada = null;
-
-			// Classic syntax
-			Assert.IsNull(nada);
-
-			// Helper syntax
-			Assert.That(nada, Is.Null);
-
-			// Inherited syntax
-			Expect(nada, Null);
-		}
-
-		[Test]
-		public void IsNotNull()
-		{
-			// Classic syntax
-			Assert.IsNotNull(42);
-
-			// Helper syntax
-			Assert.That(42, Is.Not.Null);
-
-			// Inherited syntax
-			Expect( 42, Not.Null );
-		}
-
-		[Test]
-		public void IsTrue()
-		{
-			// Classic syntax
-			Assert.IsTrue(2+2==4);
-
-			// Helper syntax
-			Assert.That(2+2==4, Is.True);
-			Assert.That(2+2==4);
-
-			// Inherited syntax
-			Expect(2+2==4, True);
-			Expect(2+2==4);
-		}
-
-		[Test]
-		public void IsFalse()
-		{
-			// Classic syntax
-			Assert.IsFalse(2+2==5);
-
-			// Helper syntax
-			Assert.That(2+2== 5, Is.False);
-			
-			// Inherited syntax
-			Expect(2+2==5, False);
-		}
-
-		[Test]
-		public void IsNaN()
-		{
-			double d = double.NaN;
-			float f = float.NaN;
-
-			// Classic syntax
-			Assert.IsNaN(d);
-			Assert.IsNaN(f);
-
-			// Helper syntax
-			Assert.That(d, Is.NaN);
-			Assert.That(f, Is.NaN);
-			
-			// Inherited syntax
-			Expect(d, NaN);
-			Expect(f, NaN);
-		}
-
-		[Test]
-		public void EmptyStringTests()
-		{
-			// Classic syntax
-			Assert.IsEmpty("");
-			Assert.IsNotEmpty("Hello!");
-
-			// Helper syntax
-			Assert.That("", Is.Empty);
-			Assert.That("Hello!", Is.Not.Empty);
-
-			// Inherited syntax
-			Expect("", Empty);
-			Expect("Hello!", Not.Empty);
-		}
-
-		[Test]
-		public void EmptyCollectionTests()
-		{
-			// Classic syntax
-			Assert.IsEmpty(new bool[0]);
-			Assert.IsNotEmpty(new int[] { 1, 2, 3 });
-
-			// Helper syntax
-			Assert.That(new bool[0], Is.Empty);
-			Assert.That(new int[] { 1, 2, 3 }, Is.Not.Empty);
-
-			// Inherited syntax
-			Expect(new bool[0], Empty);
-			Expect(new int[] { 1, 2, 3 }, Not.Empty);
-		}
-		#endregion
-
-		#region TypeConstraint Tests
-		[Test]
-		public void ExactTypeTests()
-		{
-			// Classic syntax workarounds
-			Assert.AreEqual(typeof(string), "Hello".GetType());
-			Assert.AreEqual("System.String", "Hello".GetType().FullName);
-			Assert.AreNotEqual(typeof(int), "Hello".GetType());
-			Assert.AreNotEqual("System.Int32", "Hello".GetType().FullName);
-
-			// Helper syntax
-			Assert.That("Hello", Is.TypeOf(typeof(string)));
-			Assert.That("Hello", Is.Not.TypeOf(typeof(int)));
-			
-			// Inherited syntax
-			Expect( "Hello", TypeOf(typeof(string)));
-			Expect( "Hello", Not.TypeOf(typeof(int)));
-		}
-
-		[Test]
-		public void InstanceOfTypeTests()
-		{
-			// Classic syntax
-			Assert.IsInstanceOf(typeof(string), "Hello");
-			Assert.IsNotInstanceOf(typeof(string), 5);
-
-			// Helper syntax
-			Assert.That("Hello", Is.InstanceOf(typeof(string)));
-			Assert.That(5, Is.Not.InstanceOf(typeof(string)));
-
-			// Inherited syntax
-			Expect("Hello", InstanceOf(typeof(string)));
-			Expect(5, Not.InstanceOf(typeof(string)));
-		}
-
-		[Test]
-		public void AssignableFromTypeTests()
-		{
-			// Classic syntax
-			Assert.IsAssignableFrom(typeof(string), "Hello");
-			Assert.IsNotAssignableFrom(typeof(string), 5);
-
-			// Helper syntax
-			Assert.That( "Hello", Is.AssignableFrom(typeof(string)));
-			Assert.That( 5, Is.Not.AssignableFrom(typeof(string)));
-			
-			// Inherited syntax
-			Expect( "Hello", AssignableFrom(typeof(string)));
-			Expect( 5, Not.AssignableFrom(typeof(string)));
-		}
-		#endregion
-
-		#region StringConstraint Tests
-		[Test]
-		public void SubstringTests()
-		{
-			string phrase = "Hello World!";
-			string[] array = new string[] { "abc", "bad", "dba" };
-			
-			// Classic Syntax
-			StringAssert.Contains("World", phrase);
-			
-			// Helper syntax
-			Assert.That(phrase, Text.Contains("World"));
-			// Only available using new syntax
-			Assert.That(phrase, Text.DoesNotContain("goodbye"));
-			Assert.That(phrase, Text.Contains("WORLD").IgnoreCase);
-			Assert.That(phrase, Text.DoesNotContain("BYE").IgnoreCase);
-			Assert.That(array, Text.All.Contains( "b" ) );
-
-			// Inherited syntax
-			Expect(phrase, Contains("World"));
-			// Only available using new syntax
-			Expect(phrase, Not.Contains("goodbye"));
-			Expect(phrase, Contains("WORLD").IgnoreCase);
-			Expect(phrase, Not.Contains("BYE").IgnoreCase);
-			Expect(array, All.Contains("b"));
-		}
-
-		[Test]
-		public void StartsWithTests()
-		{
-			string phrase = "Hello World!";
-			string[] greetings = new string[] { "Hello!", "Hi!", "Hola!" };
-
-			// Classic syntax
-			StringAssert.StartsWith("Hello", phrase);
-
-			// Helper syntax
-			Assert.That(phrase, Text.StartsWith("Hello"));
-			// Only available using new syntax
-			Assert.That(phrase, Text.DoesNotStartWith("Hi!"));
-			Assert.That(phrase, Text.StartsWith("HeLLo").IgnoreCase);
-			Assert.That(phrase, Text.DoesNotStartWith("HI").IgnoreCase);
-			Assert.That(greetings, Text.All.StartsWith("h").IgnoreCase);
-
-			// Inherited syntax
-			Expect(phrase, StartsWith("Hello"));
-			// Only available using new syntax
-			Expect(phrase, Not.StartsWith("Hi!"));
-			Expect(phrase, StartsWith("HeLLo").IgnoreCase);
-			Expect(phrase, Not.StartsWith("HI").IgnoreCase);
-			Expect(greetings, All.StartsWith("h").IgnoreCase);
-		}
-
-		[Test]
-		public void EndsWithTests()
-		{
-			string phrase = "Hello World!";
-			string[] greetings = new string[] { "Hello!", "Hi!", "Hola!" };
-
-			// Classic Syntax
-			StringAssert.EndsWith("!", phrase);
-
-			// Helper syntax
-			Assert.That(phrase, Text.EndsWith("!"));
-			// Only available using new syntax
-			Assert.That(phrase, Text.DoesNotEndWith("?"));
-			Assert.That(phrase, Text.EndsWith("WORLD!").IgnoreCase);
-			Assert.That(greetings, Text.All.EndsWith("!"));
-		
-			// Inherited syntax
-			Expect(phrase, EndsWith("!"));
-			// Only available using new syntax
-			Expect(phrase, Not.EndsWith("?"));
-			Expect(phrase, EndsWith("WORLD!").IgnoreCase);
-			Expect(greetings, All.EndsWith("!") );
-		}
-
-		[Test]
-		public void EqualIgnoringCaseTests()
-		{
-			string phrase = "Hello World!";
-
-			// Classic syntax
-			StringAssert.AreEqualIgnoringCase("hello world!",phrase);
-            
-			// Helper syntax
-			Assert.That(phrase, Is.EqualTo("hello world!").IgnoreCase);
-			//Only available using new syntax
-			Assert.That(phrase, Is.Not.EqualTo("goodbye world!").IgnoreCase);
-			Assert.That(new string[] { "Hello", "World" }, 
-				Is.EqualTo(new object[] { "HELLO", "WORLD" }).IgnoreCase);
-			Assert.That(new string[] {"HELLO", "Hello", "hello" },
-				Is.All.EqualTo( "hello" ).IgnoreCase);
-		            
-			// Inherited syntax
-			Expect(phrase, EqualTo("hello world!").IgnoreCase);
-			//Only available using new syntax
-			Expect(phrase, Not.EqualTo("goodbye world!").IgnoreCase);
-			Expect(new string[] { "Hello", "World" }, 
-				EqualTo(new object[] { "HELLO", "WORLD" }).IgnoreCase);
-			Expect(new string[] {"HELLO", "Hello", "hello" },
-				All.EqualTo( "hello" ).IgnoreCase);
-		}
-
-		[Test]
-		public void RegularExpressionTests()
-		{
-			string phrase = "Now is the time for all good men to come to the aid of their country.";
-			string[] quotes = new string[] { "Never say never", "It's never too late", "Nevermore!" };
-
-			// Classic syntax
-			StringAssert.IsMatch( "all good men", phrase );
-			StringAssert.IsMatch( "Now.*come", phrase );
-
-			// Helper syntax
-			Assert.That( phrase, Text.Matches( "all good men" ) );
-			Assert.That( phrase, Text.Matches( "Now.*come" ) );
-			// Only available using new syntax
-			Assert.That(phrase, Text.DoesNotMatch("all.*men.*good"));
-			Assert.That(phrase, Text.Matches("ALL").IgnoreCase);
-			Assert.That(quotes, Text.All.Matches("never").IgnoreCase);
-		
-			// Inherited syntax
-			Expect( phrase, Matches( "all good men" ) );
-			Expect( phrase, Matches( "Now.*come" ) );
-			// Only available using new syntax
-			Expect(phrase, Not.Matches("all.*men.*good"));
-			Expect(phrase, Matches("ALL").IgnoreCase);
-			Expect(quotes, All.Matches("never").IgnoreCase);
-		}
-		#endregion
-
-		#region Equality Tests
-		[Test]
-		public void EqualityTests()
-		{
-			int[] i3 = new int[] { 1, 2, 3 };
-			double[] d3 = new double[] { 1.0, 2.0, 3.0 };
-			int[] iunequal = new int[] { 1, 3, 2 };
-
-			// Classic Syntax
-			Assert.AreEqual(4, 2 + 2);
-			Assert.AreEqual(i3, d3);
-			Assert.AreNotEqual(5, 2 + 2);
-			Assert.AreNotEqual(i3, iunequal);
-
-			// Helper syntax
-			Assert.That(2 + 2, Is.EqualTo(4));
-			Assert.That(2 + 2 == 4);
-			Assert.That(i3, Is.EqualTo(d3));
-			Assert.That(2 + 2, Is.Not.EqualTo(5));
-			Assert.That(i3, Is.Not.EqualTo(iunequal));
-		
-			// Inherited syntax
-			Expect(2 + 2, EqualTo(4));
-			Expect(2 + 2 == 4);
-			Expect(i3, EqualTo(d3));
-			Expect(2 + 2, Not.EqualTo(5));
-			Expect(i3, Not.EqualTo(iunequal));
-		}
-
-		[Test]
-		public void EqualityTestsWithTolerance()
-		{
-			// CLassic syntax
-			Assert.AreEqual(5.0d, 4.99d, 0.05d);
-			Assert.AreEqual(5.0f, 4.99f, 0.05f);
-
-			// Helper syntax
-			Assert.That(4.99d, Is.EqualTo(5.0d).Within(0.05d));
-			Assert.That(4.0d, Is.Not.EqualTo(5.0d).Within(0.5d));
-			Assert.That(4.99f, Is.EqualTo(5.0f).Within(0.05f));
-			Assert.That(4.99m, Is.EqualTo(5.0m).Within(0.05m));
-			Assert.That(3999999999u, Is.EqualTo(4000000000u).Within(5u));
-			Assert.That(499, Is.EqualTo(500).Within(5));
-			Assert.That(4999999999L, Is.EqualTo(5000000000L).Within(5L));
-			Assert.That(5999999999ul, Is.EqualTo(6000000000ul).Within(5ul));
-		
-			// Inherited syntax
-			Expect(4.99d, EqualTo(5.0d).Within(0.05d));
-			Expect(4.0d, Not.EqualTo(5.0d).Within(0.5d));
-			Expect(4.99f, EqualTo(5.0f).Within(0.05f));
-			Expect(4.99m, EqualTo(5.0m).Within(0.05m));
-			Expect(499u, EqualTo(500u).Within(5u));
-			Expect(499, EqualTo(500).Within(5));
-			Expect(4999999999L, EqualTo(5000000000L).Within(5L));
-			Expect(5999999999ul, EqualTo(6000000000ul).Within(5ul));
-		}
-
-		[Test]
-		public void EqualityTestsWithTolerance_MixedFloatAndDouble()
-		{
-			// Bug Fix 1743844
-			Assert.That(2.20492d, Is.EqualTo(2.2d).Within(0.01f),
-				"Double actual, Double expected, Single tolerance");
-			Assert.That(2.20492d, Is.EqualTo(2.2f).Within(0.01d),
-				"Double actual, Single expected, Double tolerance" );
-			Assert.That(2.20492d, Is.EqualTo(2.2f).Within(0.01f),
-				"Double actual, Single expected, Single tolerance" );
-			Assert.That(2.20492f, Is.EqualTo(2.2f).Within(0.01d),
-				"Single actual, Single expected, Double tolerance");
-			Assert.That(2.20492f, Is.EqualTo(2.2d).Within(0.01d),
-				"Single actual, Double expected, Double tolerance");
-			Assert.That(2.20492f, Is.EqualTo(2.2d).Within(0.01f),
-				"Single actual, Double expected, Single tolerance");
-		}
-
-		[Test]
-			public void EqualityTestsWithTolerance_MixingTypesGenerally()
-		{
-			// Extending tolerance to all numeric types
-			Assert.That(202d, Is.EqualTo(200d).Within(2),
-				"Double actual, Double expected, int tolerance");
-			Assert.That( 4.87m, Is.EqualTo(5).Within(.25),
-				"Decimal actual, int expected, Double tolerance" );
-			Assert.That( 4.87m, Is.EqualTo(5ul).Within(1),
-				"Decimal actual, ulong expected, int tolerance" );
-			Assert.That( 487, Is.EqualTo(500).Within(25),
-				"int actual, int expected, int tolerance" );
-			Assert.That( 487u, Is.EqualTo(500).Within(25),
-				"uint actual, int expected, int tolerance" );
-			Assert.That( 487L, Is.EqualTo(500).Within(25),
-				"long actual, int expected, int tolerance" );
-			Assert.That( 487ul, Is.EqualTo(500).Within(25),
-				"ulong actual, int expected, int tolerance" );
-		}
-		#endregion
-
-		#region Comparison Tests
-		[Test]
-		public void ComparisonTests()
-		{
-			// Classic Syntax
-			Assert.Greater(7, 3);
-			Assert.GreaterOrEqual(7, 3);
-			Assert.GreaterOrEqual(7, 7);
-
-			// Helper syntax
-			Assert.That(7, Is.GreaterThan(3));
-			Assert.That(7, Is.GreaterThanOrEqualTo(3));
-			Assert.That(7, Is.AtLeast(3));
-			Assert.That(7, Is.GreaterThanOrEqualTo(7));
-			Assert.That(7, Is.AtLeast(7));
-
-			// Inherited syntax
-			Expect(7, GreaterThan(3));
-			Expect(7, GreaterThanOrEqualTo(3));
-			Expect(7, AtLeast(3));
-			Expect(7, GreaterThanOrEqualTo(7));
-			Expect(7, AtLeast(7));
-
-			// Classic syntax
-			Assert.Less(3, 7);
-			Assert.LessOrEqual(3, 7);
-			Assert.LessOrEqual(3, 3);
-
-			// Helper syntax
-			Assert.That(3, Is.LessThan(7));
-			Assert.That(3, Is.LessThanOrEqualTo(7));
-			Assert.That(3, Is.AtMost(7));
-			Assert.That(3, Is.LessThanOrEqualTo(3));
-			Assert.That(3, Is.AtMost(3));
-		
-			// Inherited syntax
-			Expect(3, LessThan(7));
-			Expect(3, LessThanOrEqualTo(7));
-			Expect(3, AtMost(7));
-			Expect(3, LessThanOrEqualTo(3));
-			Expect(3, AtMost(3));
-		}
-		#endregion
-
-		#region Collection Tests
-		[Test]
-		public void AllItemsTests()
-		{
-			object[] ints = new object[] { 1, 2, 3, 4 };
-			object[] doubles = new object[] { 0.99, 2.1, 3.0, 4.05 };
-			object[] strings = new object[] { "abc", "bad", "cab", "bad", "dad" };
-
-			// Classic syntax
-			CollectionAssert.AllItemsAreNotNull(ints);
-			CollectionAssert.AllItemsAreInstancesOfType(ints, typeof(int));
-			CollectionAssert.AllItemsAreInstancesOfType(strings, typeof(string));
-			CollectionAssert.AllItemsAreUnique(ints);
-
-			// Helper syntax
-			Assert.That(ints, Is.All.Not.Null);
-			Assert.That(ints, Has.None.Null);
-			Assert.That(ints, Is.All.InstanceOfType(typeof(int)));
-			Assert.That(ints, Has.All.InstanceOfType(typeof(int)));
-			Assert.That(strings, Is.All.InstanceOfType(typeof(string)));
-			Assert.That(strings, Has.All.InstanceOfType(typeof(string)));
-			Assert.That(ints, Is.Unique);
-			// Only available using new syntax
-			Assert.That(strings, Is.Not.Unique);
-			Assert.That(ints, Is.All.GreaterThan(0));
-			Assert.That(ints, Has.All.GreaterThan(0));
-			Assert.That(ints, Has.None.LessThanOrEqualTo(0));
-			Assert.That(strings, Text.All.Contains( "a" ) );
-			Assert.That(strings, Has.All.Contains( "a" ) );
-			Assert.That(strings, Has.Some.StartsWith( "ba" ) );
-			Assert.That( strings, Has.Some.Property( "Length" ).EqualTo( 3 ) );
-			Assert.That( strings, Has.Some.StartsWith( "BA" ).IgnoreCase );
-			Assert.That( doubles, Has.Some.EqualTo( 1.0 ).Within( .05 ) );
-		
-			// Inherited syntax
-			Expect(ints, All.Not.Null);
-			Expect(ints, None.Null);
-			Expect(ints, All.InstanceOfType(typeof(int)));
-			Expect(strings, All.InstanceOfType(typeof(string)));
-			Expect(ints, Unique);
-			// Only available using new syntax
-			Expect(strings, Not.Unique);
-			Expect(ints, All.GreaterThan(0));
-			Expect(ints, None.LessThanOrEqualTo(0));
-			Expect(strings, All.Contains( "a" ) );
-			Expect(strings, Some.StartsWith( "ba" ) );
-			Expect(strings, Some.StartsWith( "BA" ).IgnoreCase );
-			Expect(doubles, Some.EqualTo( 1.0 ).Within( .05 ) );
-		}
-
-		[Test]
-		public void SomeItemTests()
-		{
-			object[] mixed = new object[] { 1, 2, "3", null, "four", 100 };
-			object[] strings = new object[] { "abc", "bad", "cab", "bad", "dad" };
-
-			// Not available using the classic syntax
-
-			// Helper syntax
-			Assert.That(mixed, Has.Some.Null);
-			Assert.That(mixed, Has.Some.InstanceOfType(typeof(int)));
-			Assert.That(mixed, Has.Some.InstanceOfType(typeof(string)));
-			Assert.That(strings, Has.Some.StartsWith( "ba" ) );
-			Assert.That(strings, Has.Some.Not.StartsWith( "ba" ) );
-		
-			// Inherited syntax
-			Expect(mixed, Some.Null);
-			Expect(mixed, Some.InstanceOfType(typeof(int)));
-			Expect(mixed, Some.InstanceOfType(typeof(string)));
-			Expect(strings, Some.StartsWith( "ba" ) );
-			Expect(strings, Some.Not.StartsWith( "ba" ) );
-		}
-
-		[Test]
-		public void NoItemTests()
-		{
-			object[] ints = new object[] { 1, 2, 3, 4, 5 };
-			object[] strings = new object[] { "abc", "bad", "cab", "bad", "dad" };
-
-			// Not available using the classic syntax
-
-			// Helper syntax
-			Assert.That(ints, Has.None.Null);
-			Assert.That(ints, Has.None.InstanceOfType(typeof(string)));
-			Assert.That(ints, Has.None.GreaterThan(99));
-			Assert.That(strings, Has.None.StartsWith( "qu" ) );
-		
-			// Inherited syntax
-			Expect(ints, None.Null);
-			Expect(ints, None.InstanceOfType(typeof(string)));
-			Expect(ints, None.GreaterThan(99));
-			Expect(strings, None.StartsWith( "qu" ) );
-		}
-
-		[Test]
-		public void CollectionContainsTests()
-		{
-			int[] iarray = new int[] { 1, 2, 3 };
-			string[] sarray = new string[] { "a", "b", "c" };
-
-			// Classic syntax
-			Assert.Contains(3, iarray);
-			Assert.Contains("b", sarray);
-			CollectionAssert.Contains(iarray, 3);
-			CollectionAssert.Contains(sarray, "b");
-			CollectionAssert.DoesNotContain(sarray, "x");
-			// Showing that Contains uses NUnit equality
-			CollectionAssert.Contains( iarray, 1.0d );
-
-			// Helper syntax
-			Assert.That(iarray, Has.Member(3));
-			Assert.That(sarray, Has.Member("b"));
-			Assert.That(sarray, Has.No.Member("x"));
-			// Showing that Contains uses NUnit equality
-			Assert.That(iarray, Has.Member( 1.0d ));
-
-			// Only available using the new syntax
-			// Note that EqualTo and SameAs do NOT give
-			// identical results to Contains because 
-			// Contains uses Object.Equals()
-			Assert.That(iarray, Has.Some.EqualTo(3));
-			Assert.That(iarray, Has.Member(3));
-			Assert.That(sarray, Has.Some.EqualTo("b"));
-			Assert.That(sarray, Has.None.EqualTo("x"));
-			Assert.That(iarray, Has.None.SameAs( 1.0d ));
-			Assert.That(iarray, Has.All.LessThan(10));
-			Assert.That(sarray, Has.All.Length.EqualTo(1));
-			Assert.That(sarray, Has.None.Property("Length").GreaterThan(3));
-		
-			// Inherited syntax
-			Expect(iarray, Contains(3));
-			Expect(sarray, Contains("b"));
-			Expect(sarray, Not.Contains("x"));
-
-			// Only available using new syntax
-			// Note that EqualTo and SameAs do NOT give
-			// identical results to Contains because 
-			// Contains uses Object.Equals()
-			Expect(iarray, Some.EqualTo(3));
-			Expect(sarray, Some.EqualTo("b"));
-			Expect(sarray, None.EqualTo("x"));
-			Expect(iarray, All.LessThan(10));
-			Expect(sarray, All.Length.EqualTo(1));
-			Expect(sarray, None.Property("Length").GreaterThan(3));
-		}
-
-		[Test]
-		public void CollectionEquivalenceTests()
-		{
-			int[] ints1to5 = new int[] { 1, 2, 3, 4, 5 };
-			int[] twothrees = new int[] { 1, 2, 3, 3, 4, 5 };
-			int[] twofours = new int[] { 1, 2, 3, 4, 4, 5 };
-
-		    // Classic syntax
-		    CollectionAssert.AreEquivalent(new int[] { 2, 1, 4, 3, 5 }, ints1to5);
-			CollectionAssert.AreNotEquivalent(new int[] { 2, 2, 4, 3, 5 }, ints1to5);
-			CollectionAssert.AreNotEquivalent(new int[] { 2, 4, 3, 5 }, ints1to5);
-			CollectionAssert.AreNotEquivalent(new int[] { 2, 2, 1, 1, 4, 3, 5 }, ints1to5);
-            CollectionAssert.AreNotEquivalent(twothrees, twofours); 
-		
-			// Helper syntax
-			Assert.That(new int[] { 2, 1, 4, 3, 5 }, Is.EquivalentTo(ints1to5));
-			Assert.That(new int[] { 2, 2, 4, 3, 5 }, Is.Not.EquivalentTo(ints1to5));
-			Assert.That(new int[] { 2, 4, 3, 5 }, Is.Not.EquivalentTo(ints1to5));
-			Assert.That(new int[] { 2, 2, 1, 1, 4, 3, 5 }, Is.Not.EquivalentTo(ints1to5));
-
-			// Inherited syntax
-			Expect(new int[] { 2, 1, 4, 3, 5 }, EquivalentTo(ints1to5));
-			Expect(new int[] { 2, 2, 4, 3, 5 }, Not.EquivalentTo(ints1to5));
-			Expect(new int[] { 2, 4, 3, 5 }, Not.EquivalentTo(ints1to5));
-			Expect(new int[] { 2, 2, 1, 1, 4, 3, 5 }, Not.EquivalentTo(ints1to5));
-		}
-
-		[Test]
-		public void SubsetTests()
-		{
-			int[] ints1to5 = new int[] { 1, 2, 3, 4, 5 };
-
-			// Classic syntax
-			CollectionAssert.IsSubsetOf(new int[] { 1, 3, 5 }, ints1to5);
-			CollectionAssert.IsSubsetOf(new int[] { 1, 2, 3, 4, 5 }, ints1to5);
-			CollectionAssert.IsNotSubsetOf(new int[] { 2, 4, 6 }, ints1to5);
-			CollectionAssert.IsNotSubsetOf(new int[] { 1, 2, 2, 2, 5 }, ints1to5);
-
-			// Helper syntax
-			Assert.That(new int[] { 1, 3, 5 }, Is.SubsetOf(ints1to5));
-			Assert.That(new int[] { 1, 2, 3, 4, 5 }, Is.SubsetOf(ints1to5));
-			Assert.That(new int[] { 2, 4, 6 }, Is.Not.SubsetOf(ints1to5));
-		
-			// Inherited syntax
-			Expect(new int[] { 1, 3, 5 }, SubsetOf(ints1to5));
-			Expect(new int[] { 1, 2, 3, 4, 5 }, SubsetOf(ints1to5));
-			Expect(new int[] { 2, 4, 6 }, Not.SubsetOf(ints1to5));
-		}
-		#endregion
-
-		#region Property Tests
-		[Test]
-		public void PropertyTests()
-		{
-			string[] array = { "abc", "bca", "xyz", "qrs" };
-			string[] array2 = { "a", "ab", "abc" };
-			ArrayList list = new ArrayList( array );
-
-			// Not available using the classic syntax
-
-			// Helper syntax
-			Assert.That( list, Has.Property( "Count" ) );
-			Assert.That( list, Has.No.Property( "Length" ) );
-
-			Assert.That( "Hello", Has.Length.EqualTo( 5 ) );
-			Assert.That( "Hello", Has.Length.LessThan( 10 ) );
-			Assert.That( "Hello", Has.Property("Length").EqualTo(5) );
-			Assert.That( "Hello", Has.Property("Length").GreaterThan(3) );
-
-			Assert.That( array, Has.Property( "Length" ).EqualTo( 4 ) );
-			Assert.That( array, Has.Length.EqualTo( 4 ) );
-			Assert.That( array, Has.Property( "Length" ).LessThan( 10 ) );
-
-			Assert.That( array, Has.All.Property("Length").EqualTo(3) );
-			Assert.That( array, Has.All.Length.EqualTo( 3 ) );
-			Assert.That( array, Is.All.Length.EqualTo( 3 ) );
-			Assert.That( array, Has.All.Property("Length").EqualTo(3) );
-			Assert.That( array, Is.All.Property("Length").EqualTo(3) );
-			
-			Assert.That( array2, Has.Some.Property("Length").EqualTo(2) );
-			Assert.That( array2, Has.Some.Length.EqualTo(2) );
-			Assert.That( array2, Has.Some.Property("Length").GreaterThan(2) );
-
-			Assert.That( array2, Is.Not.Property("Length").EqualTo(4) );
-			Assert.That( array2, Is.Not.Length.EqualTo( 4 ) );
-			Assert.That( array2, Has.No.Property("Length").GreaterThan(3) );
-
-			Assert.That( List.Map( array2 ).Property("Length"), Is.EqualTo( new int[] { 1, 2, 3 } ) );
-			Assert.That( List.Map( array2 ).Property("Length"), Is.EquivalentTo( new int[] { 3, 2, 1 } ) );
-			Assert.That( List.Map( array2 ).Property("Length"), Is.SubsetOf( new int[] { 1, 2, 3, 4, 5 } ) );
-			Assert.That( List.Map( array2 ).Property("Length"), Is.Unique );
-
-			Assert.That( list, Has.Count.EqualTo( 4 ) );
-			
-			// Inherited syntax
-			Expect( list, Property( "Count" ) );
-			Expect( list, Not.Property( "Nada" ) );
-
-			Expect( "Hello", Length.EqualTo( 5 ) );
-			Expect( "Hello", Property("Length").EqualTo(5) );
-			Expect( "Hello", Property("Length").GreaterThan(0) );
-
-			Expect( array, Property("Length").EqualTo(4) );
-			Expect( array, Length.EqualTo(4) );
-			Expect( array, Property("Length").LessThan(10));
-
-			Expect( array, All.Length.EqualTo( 3 ) );
-			Expect( array, All.Property("Length").EqualTo(3));
-
-			Expect( array2, Some.Property("Length").EqualTo(2) );
-			Expect( array2, Some.Length.EqualTo( 2 ) );
-			Expect( array2, Some.Property("Length").GreaterThan(2));
-
-			Expect( array2, None.Property("Length").EqualTo(4) );
-			Expect( array2, None.Length.EqualTo( 4 ) );
-			Expect( array2, None.Property("Length").GreaterThan(3));
-
-			Expect( Map( array2 ).Property("Length"), EqualTo( new int[] { 1, 2, 3 } ) );
-			Expect( Map( array2 ).Property("Length"), EquivalentTo( new int[] { 3, 2, 1 } ) );
-			Expect( Map( array2 ).Property("Length"), SubsetOf( new int[] { 1, 2, 3, 4, 5 } ) );
-			Expect( Map( array2 ).Property("Length"), Unique );
-
-			Expect( list, Count.EqualTo( 4 ) );
-
-		}
-		#endregion
-
-		#region Not Tests
-		[Test]
-		public void NotTests()
-		{
-			// Not available using the classic syntax
-
-			// Helper syntax
-			Assert.That(42, Is.Not.Null);
-			Assert.That(42, Is.Not.True);
-			Assert.That(42, Is.Not.False);
-			Assert.That(2.5, Is.Not.NaN);
-			Assert.That(2 + 2, Is.Not.EqualTo(3));
-			Assert.That(2 + 2, Is.Not.Not.EqualTo(4));
-			Assert.That(2 + 2, Is.Not.Not.Not.EqualTo(5));
-
-			// Inherited syntax
-			Expect(42, Not.Null);
-			Expect(42, Not.True);
-			Expect(42, Not.False);
-			Expect(2.5, Not.NaN);
-			Expect(2 + 2, Not.EqualTo(3));
-			Expect(2 + 2, Not.Not.EqualTo(4));
-			Expect(2 + 2, Not.Not.Not.EqualTo(5));
-		}
-		#endregion
-
-		#region Operator Tests
-		[Test]
-		public void NotOperator()
-		{
-			// The ! operator is only available in the new syntax
-			Assert.That(42, !Is.Null);
-			// Inherited syntax
-			Expect( 42, !Null );
-		}
-
-		[Test]
-		public void AndOperator()
-		{
-			// The & operator is only available in the new syntax
-			Assert.That(7, Is.GreaterThan(5) & Is.LessThan(10));
-			// Inherited syntax
-			Expect( 7, GreaterThan(5) & LessThan(10));
-		}
-
-		[Test]
-		public void OrOperator()
-		{
-			// The | operator is only available in the new syntax
-			Assert.That(3, Is.LessThan(5) | Is.GreaterThan(10));
-			Expect( 3, LessThan(5) | GreaterThan(10));
-		}
-
-		[Test]
-		public void ComplexTests()
-		{
-			Assert.That(7, Is.Not.Null & Is.Not.LessThan(5) & Is.Not.GreaterThan(10));
-			Expect(7, Not.Null & Not.LessThan(5) & Not.GreaterThan(10));
-
-			Assert.That(7, !Is.Null & !Is.LessThan(5) & !Is.GreaterThan(10));
-			Expect(7, !Null & !LessThan(5) & !GreaterThan(10));
-
-			// TODO: Remove #if when mono compiler can handle null
-#if MONO
-            Constraint x = null;
-            Assert.That(7, !x & !Is.LessThan(5) & !Is.GreaterThan(10));
-			Expect(7, !x & !LessThan(5) & !GreaterThan(10));
-#else
-			Assert.That(7, !(Constraint)null & !Is.LessThan(5) & !Is.GreaterThan(10));
-			Expect(7, !(Constraint)null & !LessThan(5) & !GreaterThan(10));
-#endif
-		}
-		#endregion
- 
-		#region Invalid Code Tests
-		// This method contains assertions that should not compile
-		// You can check by uncommenting it.
-		//public void WillNotCompile()
-		//{
-		//    Assert.That(42, Is.Not);
-		//    Assert.That(42, Is.All);
-		//    Assert.That(42, Is.Null.Not);
-		//    Assert.That(42, Is.Not.Null.GreaterThan(10));
-		//    Assert.That(42, Is.GreaterThan(10).LessThan(99));
-
-		//    object[] c = new object[0];
-		//    Assert.That(c, Is.Null.All);
-		//    Assert.That(c, Is.Not.All);
-		//    Assert.That(c, Is.All.Not);
-		//}
-		#endregion
-	}
-
-}

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/csharp/syntax/cs-syntax.build
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/csharp/syntax/cs-syntax.build b/lib/NUnit.org/NUnit/2.5.9/samples/csharp/syntax/cs-syntax.build
deleted file mode 100644
index c144588..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/csharp/syntax/cs-syntax.build
+++ /dev/null
@@ -1,11 +0,0 @@
-<?xml version="1.0"?>
-<project name="cs-syntax" default="build">
-
-  <include buildfile="../../samples.common" />
-
-  <patternset id="source-files">
-    <include name="AssemblyInfo.cs" />
-    <include name="AssertSyntaxTests.cs" />
-  </patternset>
-
-</project>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/csharp/syntax/cs-syntax.csproj
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/csharp/syntax/cs-syntax.csproj b/lib/NUnit.org/NUnit/2.5.9/samples/csharp/syntax/cs-syntax.csproj
deleted file mode 100644
index b3970c7..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/csharp/syntax/cs-syntax.csproj
+++ /dev/null
@@ -1,20 +0,0 @@
-<VisualStudioProject>
-  <CSHARP ProjectType="Local" ProductVersion="7.10.3077" SchemaVersion="2.0" ProjectGuid="{06F46FA2-687B-4B46-A912-C1B0B4CC1B20}">
-    <Build>
-      <Settings ApplicationIcon="" AssemblyKeyContainerName="" AssemblyName="cs-syntax" AssemblyOriginatorKeyFile="" DefaultClientScript="JScript" DefaultHTMLPageLayout="Grid" DefaultTargetSchema="IE50" DelaySign="false" OutputType="Library" PreBuildEvent="" PostBuildEvent="" RootNamespace="cs_syntax" RunPostBuildEvent="OnBuildSuccess" StartupObject="">
-        <Config Name="Debug" AllowUnsafeBlocks="false" BaseAddress="285212672" CheckForOverflowUnderflow="false" ConfigurationOverrideFile="" DefineConstants="DEBUG;TRACE" DocumentationFile="" DebugSymbols="true" FileAlignment="4096" IncrementalBuild="false" NoStdLib="false" NoWarn="" Optimize="false" OutputPath="bin\Debug\" RegisterForComInterop="false" RemoveIntegerChecks="false" TreatWarningsAsErrors="false" WarningLevel="4" />
-        <Config Name="Release" AllowUnsafeBlocks="false" BaseAddress="285212672" CheckForOverflowUnderflow="false" ConfigurationOverrideFile="" DefineConstants="TRACE" DocumentationFile="" DebugSymbols="false" FileAlignment="4096" IncrementalBuild="false" NoStdLib="false" NoWarn="" Optimize="true" OutputPath="bin\Release\" RegisterForComInterop="false" RemoveIntegerChecks="false" TreatWarningsAsErrors="false" WarningLevel="4" />
-      </Settings>
-      <References>
-        <Reference Name="System" AssemblyName="System" />
-        <Reference Name="nunit.framework" AssemblyName="nunit.framework, Version=2.5, Culture=neutral, PublicKeyToken=96d09a1eb7f44a77" HintPath="..\..\..\bin\net-1.1\framework\nunit.framework.dll" />
-      </References>
-    </Build>
-    <Files>
-      <Include>
-        <File RelPath="AssemblyInfo.cs" SubType="Code" BuildAction="Compile" />
-        <File RelPath="AssertSyntaxTests.cs" SubType="Code" BuildAction="Compile" />
-      </Include>
-    </Files>
-  </CSHARP>
-</VisualStudioProject>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/jsharp/failures/AssemblyInfo.jsl
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/jsharp/failures/AssemblyInfo.jsl b/lib/NUnit.org/NUnit/2.5.9/samples/jsharp/failures/AssemblyInfo.jsl
deleted file mode 100644
index 5e4d026..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/jsharp/failures/AssemblyInfo.jsl
+++ /dev/null
@@ -1,58 +0,0 @@
-import System.Reflection.*;
-import System.Runtime.CompilerServices.*;
-
-//
-// General Information about an assembly is controlled through the following 
-// set of attributes. Change these attribute values to modify the information
-// associated with an assembly.
-//
-/** @assembly AssemblyTitle("") */
-/** @assembly AssemblyDescription("") */
-/** @assembly AssemblyConfiguration("") */
-/** @assembly AssemblyCompany("") */
-/** @assembly AssemblyProduct("") */
-/** @assembly AssemblyCopyright("") */
-/** @assembly AssemblyTrademark("") */
-/** @assembly AssemblyCulture("") */
-
-//
-// Version information for an assembly consists of the following four values:
-//
-//      Major Version
-//      Minor Version 
-//      Build Number
-//      Revision
-//
-// You can specify all the values or you can default the Revision and Build
-// Numbers by using the '*' as shown below:
-
-/** @assembly AssemblyVersion("2.2.0.0") */
-
-//
-// In order to sign your assembly you must specify a key to use. Refer to the 
-// Microsoft .NET Framework documentation for more information on assembly signing.
-//
-// Use the attributes below to control which key is used for signing. 
-//
-// Notes: 
-//   (*) If no key is specified, the assembly is not signed.
-//   (*) KeyName refers to a key that has been installed in the Crypto Service
-//       Provider (CSP) on your machine. KeyFile refers to a file which contains
-//       a key.
-//   (*) If the KeyFile and the KeyName values are both specified, the 
-//       following processing occurs:
-//       (1) If the KeyName can be found in the CSP, that key is used.
-//       (2) If the KeyName does not exist and the KeyFile does exist, the key 
-//           in the KeyFile is installed into the CSP and used.
-//   (*) In order to create a KeyFile, you can use the sn.exe (Strong Name) utility.
-//       When specifying the KeyFile, the location of the KeyFile should be
-//       relative to the project directory. For example, if your KeyFile is
-//       located in the project directory itself, you would specify the
-//       AssemblyKeyFile attribute as @assembly AssemblyKeyFile("mykey.snk")
-//   (*) Delay Signing is an advanced option - see the Microsoft .NET Framework
-//       documentation for more information on this.
-//
-
-/** @assembly AssemblyDelaySign(false) */
-/** @assembly AssemblyKeyFile("") */
-/** @assembly AssemblyKeyName("") */

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/jsharp/failures/JSharpTest.jsl
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/jsharp/failures/JSharpTest.jsl b/lib/NUnit.org/NUnit/2.5.9/samples/jsharp/failures/JSharpTest.jsl
deleted file mode 100644
index 5ae1c47..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/jsharp/failures/JSharpTest.jsl
+++ /dev/null
@@ -1,65 +0,0 @@
-// ****************************************************************
-// This is free software licensed under the NUnit license. You
-// may obtain a copy of the license as well as information regarding
-// copyright ownership at http://nunit.org/?p=license&r=2.4.
-// ****************************************************************
-
-package NUnit.Samples;
-
-import System.*;
-import NUnit.Framework.Assert;
-
-/** @attribute NUnit.Framework.TestFixture() */
-public class SimpleJSharpTest
-{
-	protected int fValue1;
-	protected int fValue2;
-
-	/** @attribute NUnit.Framework.SetUp() */
-	public void Init()
-	{
-		fValue1 = 2;
-		fValue2 = 3;
-	}
-
-	/** @attribute NUnit.Framework.Test() */
-	public void Add() 
-	{
-		int result= fValue1 + fValue2;
-		Assert.AreEqual(6,result, "Expected Failure");
-	}
-
-	/** @attribute NUnit.Framework.Test() */
-	public void DivideByZero() 
-	{
-		int zero= 0;
-		int result = 8/zero;
-		KeepCompilerFromWarning(result); // never executed, here to avoid compiler warning that result is unused.
-	}
-
-	/** @attribute NUnit.Framework.Test() */
-	public void Equals() 
-	{
-		Assert.AreEqual(12, 12, "Integer");
-		Assert.AreEqual(new Long(12), new Long(13), "Long");
-		Assert.AreEqual('a', 'a', "Char");
-		Assert.AreEqual(new Integer(12), new Integer(12), "Integer Object Cast");
-            
-		Assert.AreEqual(12, 13, "Expected Failure (Integer)");
-		Assert.AreEqual(12.0, 11.99, 0.0, "Expected Failure (Double).");
-	}
-
-	/** @attribute NUnit.Framework.Test() */
-	/** @attribute NUnit.Framework.Ignore("ignored test") */
-	public void IgnoredTest()
-	{
-		throw new InvalidCastException();
-	}
-
-	// A useless function, designed to avoid a compiler warning in the the DivideByZero test.
-	private int KeepCompilerFromWarning(int dummy)
-	{
-		return dummy;
-	}
-
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/jsharp/failures/jsharp-failures.build
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/jsharp/failures/jsharp-failures.build b/lib/NUnit.org/NUnit/2.5.9/samples/jsharp/failures/jsharp-failures.build
deleted file mode 100644
index 51f20da..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/jsharp/failures/jsharp-failures.build
+++ /dev/null
@@ -1,11 +0,0 @@
-<?xml version="1.0"?>
-<project name="jsharp-failures" default="build">
-
-  <include buildfile="../../samples.common" />
-  
-  <patternset id="source-files">
-    <include name="AssemblyInfo.jsl" />
-    <include name="JSharpTest.jsl" />
-  </patternset>
-
-</project>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/jsharp/failures/jsharp-failures.vjsproj
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/jsharp/failures/jsharp-failures.vjsproj b/lib/NUnit.org/NUnit/2.5.9/samples/jsharp/failures/jsharp-failures.vjsproj
deleted file mode 100644
index 0baa0ce..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/jsharp/failures/jsharp-failures.vjsproj
+++ /dev/null
@@ -1,21 +0,0 @@
-<VisualStudioProject>
-  <VISUALJSHARP ProjectType="Local" ProductVersion="7.10.3077" SchemaVersion="2.0" ProjectGuid="{B55A6E53-57A9-4205-B396-C9983B3AF46A}">
-    <Build>
-      <Settings AssemblyKeyContainerName="" AssemblyName="jsharp-failures" AssemblyOriginatorKeyFile="" DefaultClientScript="JScript" DefaultHTMLPageLayout="Grid" DefaultTargetSchema="IE50" OutputType="Library" PreBuildEvent="" PostBuildEvent="" RootNamespace="jsharp" RunPostBuildEvent="OnBuildSuccess" StartupObject="">
-        <Config Name="Debug" BaseAddress="285212672" ConfigurationOverrideFile="" DefineConstants="DEBUG;TRACE" DebugSymbols="true" NoWarn="" Optimize="false" OutputPath="bin\Debug\" RegisterForComInterop="false" TreatWarningsAsErrors="false" WarningLevel="4" AdditionalOptions="" />
-        <Config Name="Release" BaseAddress="285212672" ConfigurationOverrideFile="" DefineConstants="TRACE" DebugSymbols="false" NoWarn="" Optimize="true" OutputPath="bin\Release\" RegisterForComInterop="false" TreatWarningsAsErrors="false" WarningLevel="4" AdditionalOptions="" />
-      </Settings>
-      <References>
-        <Reference Name="vjslib" AssemblyName="vjslib" />
-        <Reference Name="System" AssemblyName="System" />
-        <Reference Name="nunit.framework" AssemblyName="nunit.framework, Version=2.5, Culture=neutral, PublicKeyToken=96d09a1eb7f44a77" HintPath="..\..\..\bin\net-1.1\framework\nunit.framework.dll" />
-      </References>
-    </Build>
-    <Files>
-      <Include>
-        <File RelPath="AssemblyInfo.jsl" SubType="Code" BuildAction="Compile" />
-        <File RelPath="JSharpTest.jsl" SubType="Code" BuildAction="Compile" />
-      </Include>
-    </Files>
-  </VISUALJSHARP>
-</VisualStudioProject>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/jsharp/jsharp.sln
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/jsharp/jsharp.sln b/lib/NUnit.org/NUnit/2.5.9/samples/jsharp/jsharp.sln
deleted file mode 100644
index 507fcc8..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/jsharp/jsharp.sln
+++ /dev/null
@@ -1,21 +0,0 @@
-Microsoft Visual Studio Solution File, Format Version 8.00
-Project("{E6FDF86B-F3D1-11D4-8576-0002A516ECE8}") = "jsharp-failures", "failures\jsharp-failures.vjsproj", "{B55A6E53-57A9-4205-B396-C9983B3AF46A}"
-	ProjectSection(ProjectDependencies) = postProject
-	EndProjectSection
-EndProject
-Global
-	GlobalSection(SolutionConfiguration) = preSolution
-		Debug = Debug
-		Release = Release
-	EndGlobalSection
-	GlobalSection(ProjectConfiguration) = postSolution
-		{B55A6E53-57A9-4205-B396-C9983B3AF46A}.Debug.ActiveCfg = Debug|.NET
-		{B55A6E53-57A9-4205-B396-C9983B3AF46A}.Debug.Build.0 = Debug|.NET
-		{B55A6E53-57A9-4205-B396-C9983B3AF46A}.Release.ActiveCfg = Release|.NET
-		{B55A6E53-57A9-4205-B396-C9983B3AF46A}.Release.Build.0 = Release|.NET
-	EndGlobalSection
-	GlobalSection(ExtensibilityGlobals) = postSolution
-	EndGlobalSection
-	GlobalSection(ExtensibilityAddIns) = postSolution
-	EndGlobalSection
-EndGlobal

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/samples.common
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/samples.common b/lib/NUnit.org/NUnit/2.5.9/samples/samples.common
deleted file mode 100644
index c6cbdb1..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/samples.common
+++ /dev/null
@@ -1,308 +0,0 @@
-<?xml version="1.0"?>
-<project>
-
-  <property name="project.base" value="${project::get-base-directory()}" />
-
-  <property name="samples.base" value="${path::get-full-path('../..')}" />
-  <!-- Duplicate the following if more levels are added -->te
-  <property name="samples.base" value="${path::get-full-path('../../..')}"
-            unless="${path::get-file-name(samples.base)=='samples'}" />
-
-  <property name="output.dir" value="${samples.base}/bin" />
-
-  <property name="nunit.bin.dir"
-            value="${path::combine(path::get-directory-name(samples.base), 'bin')}" />
-  <property name="nunit.framework.dll"
-            value="${path::combine(nunit.bin.dir,'net-1.1/framework/nunit.framework.dll')}" />
-  <property name="nunit.core.dll"
-            value="${path::combine(nunit.bin.dir,'net-1.1/nunit.core.dll')}" />
-  <property name="nunit.core.interfaces.dll"
-            value="${path::combine(nunit.bin.dir,'net-1.1/nunit.core.interfaces.dll')}" />
-
-  <property name="sample" value="${project::get-name()}"
-            unless="${property::exists('sample')}"/>
-  <property name="sample.dll" value="${sample}.dll" />
-
-  <property name="sample.type"
-          value="${path::get-file-name(path::get-directory-name(project.base))}" />
-  <property name="sample.type" value="addin" if="${sample.type=='Core'}" />
-
-  <if test="${directory::exists(path::combine(project.base, 'Tests'))}" >
-    <property name="tests" value="${sample}Tests"
-          unless="${property::exists('tests')}" />
-    <property name="test.dll" value="${tests}.dll" />
-  </if>
-  
-  <property name="nunit.build" value="false"
-    unless="${property::exists('project.package.dir')}"/>
-  <property name="nunit.build" value="true" 
-    if="${property::exists('project.package.dir')}"/>
-
-  <property name="build.debug" value="true"
-            unless="${property::exists('build.debug')}" />
-  <property name="build.config" value="Debug"
-            if="${build.debug}" />
-  <property name="build.config" value="Release"
-            unless="${build.debug}" />
-
-
-  <target name="clean" description="Remove files created by build">
-
-    <delete file="${output.dir}/${sample.dll}" />
-    <delete file="${output.dir}/${sample}.pdb" />
-
-    <if test="${property::exists('test.dll')}">
-      <delete file="${output.dir}/${test.dll}" />
-      <delete file="${output.dir}/${path::change-extension(test.dll, '.pdb')}" />
-    </if>
-
-  </target>
-
-  <target name="init">
-
-    <mkdir dir="${output.dir}" unless="${directory::exists(output.dir)}" />
-
-    <copy file="${nunit.framework.dll}" todir="${output.dir}"
-          if="${not nunit.build and file::exists(nunit.framework.dll)}" />
-
-  </target>
-
-  <target name="init-addin">
-
-    <mkdir dir="${output.dir}" unless="${directory::exists(output.dir)}" />
-
-    <copy file="${nunit.core.dll}" todir="${output.dir}"
-          if="${not nunit.build and file::exists(nunit.core.dll)}" />
-    <copy file="${nunit.core.interfaces.dll}" todir="${output.dir}"
-          if="${not nunit.build and file::exists(nunit.core.interfaces.dll)}" />
-
-  </target>
-
-  <target name="build" Description="Build the sample">
-    <call target="build-${sample.type}"/>
-  </target>
-  
-  <target name="build-csharp" depends="init">
-
-    <csc target="library" output="${output.dir}/${sample.dll}" debug="${build.debug}">
-      <sources>
-        <patternset refid="source-files"/>
-      </sources>
-      <references basedir="${output.dir}">
-        <include name="nunit.framework.dll" />
-      </references>
-    </csc>
-
-  </target>
-
-  <target name="build-addin" depends="init-addin">
-
-    <csc target="library" output="${output.dir}/${sample}.dll" debug="${build.debug}">
-      <sources>
-        <patternset refid="source-files"/>
-      </sources>
-      <references basedir="${output.dir}">
-        <include name="nunit.core.interfaces.dll" />
-        <include name="nunit.core.dll" />
-      </references>
-    </csc>
-
-    <call target="build-addin-test" if="${property::exists('test.dll')}" />
-
-  </target>
-
-  <target name="build-addin-test">
-
-    <csc target="library" output="${output.dir}/${test.dll}" debug="${build.debug}">
-      <sources basedir="Tests">
-        <patternset refid="test-files"/>
-      </sources>
-      <references basedir="${output.dir}">
-        <include name="nunit.framework.dll" />
-        <include name="${sample}.dll" />
-      </references>
-    </csc>
-
-  </target>
-
-  <target name="build-vb" depends="init">
-
-    <vbc target="library"
-        output="${output.dir}/${sample.dll}" debug="${build.debug}">
-      <imports>
-        <import namespace="System"/>
-        <import namespace="System.Collections"/>
-      </imports>
-      <sources>
-        <patternset refid="source-files"/>
-      </sources>
-      <references basedir="${output.dir}">
-        <include name="System.dll" />
-        <include name="nunit.framework.dll" />
-      </references>
-    </vbc>
-
-  </target>
-
-  <target name="build-jsharp" depends="init">
-
-    <vjc target="library" output="${output.dir}/${sample.dll}" debug="${build.debug}">
-      <sources>
-        <patternset refid="source-files"/>
-      </sources>
-      <references basedir="${output.dir}">
-        <include name="nunit.framework.dll" />
-      </references>
-    </vjc>
-
-  </target>
-
-  <target name="build-managed" depends="init">
-
-    <readregistry property="vs.2003.path"
-      key="Software\Microsoft\VisualStudio\7.1\InstallDir"
-      hive="LocalMachine" failonerror="false"
-      unless="${property::exists( 'vs.2003.path' )}"/>
-
-    <fail message="VS 2003 must be installed to build this sample"
-      unless="${property::exists( 'vs.2003.path' )}"/>
-
-    <exec program="devenv.exe" basedir="${vs.2003.path}" workingdir="."
-      commandline="${sample}.vcproj /build ${build.config} /out ${output.dir}/${sample.dll}" />
-
-  </target>
-
-  <target name="build-cpp-cli" depends="init">
-
-    <readregistry property="vs.2005.path"
-      key="Software\Microsoft\VisualStudio\8.0\InstallDir"
-      hive="LocalMachine" failonerror="false"
-      unless="${property::exists( 'vs.2005.path' )}"/>
-
-    <fail message="VS 2005 must be installed to build this sample"
-      unless="${property::exists( 'vs.2005.path' )}"/>
-
-    <exec program="devenv.exe"
-      basedir="${vs.2005.path}" workingdir="."
-      commandline="${sample}.vcproj /build ${build.config} /out ${output.dir}/${sample.dll}"/>
-
-  </target>
-
-  <!-- ************************************************************* -->
-  <!-- Package targets are only used by the NUnit build script in    -->
-  <!-- order to package the samples for distribution.                -->
-  <!-- ************************************************************* -->
-  
-  <target name="package">
-
-    <fail message="Can't use package target directly - it must be called from the NUnit build script."
-          unless="${nunit.build}"/>
-
-    <property name="sample.path"
-              value="${string::replace(project.base, samples.base, package.samples.dir)}" />
-
-    <call target="package-${sample.type}" />
-
-  </target>
-
-  <target name="package-csharp">
-
-    <property name="sample.proj" value="${sample}.csproj" />
-
-    <call target="copy-source-files" />
-    <call target="update-framework-ref" />
-
-  </target>
-
-  <target name="package-jsharp">
-    
-    <property name="sample.proj" value="${sample}.vjsproj" />
-
-    <call target="copy-source-files" />
-    <call target="update-framework-ref" />
-
-  </target>
-
-  <target name="update-framework-ref">
-    
-    <xmlpoke
-      file="${sample.path}/${sample.proj}"
-      xpath="/VisualStudioProject/*/Build/References/Reference[@Name='nunit.framework']/@HintPath"
-      value="..\..\..\bin\net-1.1\framework\nunit.framework.dll" />
-
-  </target>
-
-  <target name="package-vb">
-    
-    <property name="sample.proj" value="${sample}.vbproj" />
-
-    <call target="copy-source-files" />
-    <call target="update-framework-ref" />
-
-  </target>
-
-  <target name="package-managed">
-    
-    <property name="sample.proj" value="${sample}.vcproj" />
-
-    <call target="copy-source-files" />
-
-    <copy todir="${package.samples.dir}/cpp/managed/failures"
-        file="./cpp-managed-failures.vcproj">
-      <filterchain>
-        <replacestring from="$(SolutionDir)..\..\..\src\NUnitFramework\framework\bin\Debug\nunit.framework.dll"
-          to="..\..\..\..\bin\nunit.framework.dll"/>
-      </filterchain>
-    </copy>
-
-  </target>
-
-  <target name="package-cpp-cli">
-    
-    <property name="sample.proj" value="${sample}.vcproj" />
-
-    <call target="copy-source-files" />
-
-    <xmlpoke
-      file="${sample.path}/${sample.proj}"
-      xpath="/VisualStudioProject/References/AssemblyReference[@AssemblyName='nunit.framework']/@RelativePath"
-      value="..\..\..\..\bin\net-2.0\framework\nunit.framework.dll" />
-
-  </target>
-
-  <target name="package-addin">
-    
-    <property name="sample.proj" value="${sample}.csproj" />
-
-    <call target="copy-source-files" />
-    <call target="copy-test-files" 
-      if="${property::exists('test.dll')}"/>
-
-  </target>
-
-  <target name="copy-source-files">
-
-    <copy todir="${sample.path}" includeemptydirs="false">
-      <fileset basedir=".">
-        <include name="${sample.proj}" />
-        <include name="${sample}.build" />
-        <include name="Readme.txt" />
-        <patternset refid="source-files" />
-      </fileset>
-    </copy>
-
-  </target>
-
-  <target name="copy-test-files">
-
-    <copy todir="${sample.path}/Tests" includeemptydirs="false">
-      <fileset basedir="Tests">
-        <include name="${sample}Tests.csproj" />
-        <include name="${sample}Tests.build" />
-        <patternset refid="test-files" />
-      </fileset>
-    </copy>
-
-  </target>
-
-</project>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/vb/failures/AssemblyInfo.vb
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/vb/failures/AssemblyInfo.vb b/lib/NUnit.org/NUnit/2.5.9/samples/vb/failures/AssemblyInfo.vb
deleted file mode 100644
index 3e9a34c..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/vb/failures/AssemblyInfo.vb
+++ /dev/null
@@ -1,32 +0,0 @@
-Imports System.Reflection
-Imports System.Runtime.InteropServices
-
-' General Information about an assembly is controlled through the following 
-' set of attributes. Change these attribute values to modify the information
-' associated with an assembly.
-
-' Review the values of the assembly attributes
-
-<Assembly: AssemblyTitle("")> 
-<Assembly: AssemblyDescription("")> 
-<Assembly: AssemblyCompany("")> 
-<Assembly: AssemblyProduct("")> 
-<Assembly: AssemblyCopyright("")> 
-<Assembly: AssemblyTrademark("")> 
-<Assembly: CLSCompliant(True)> 
-
-'The following GUID is for the ID of the typelib if this project is exposed to COM
-<Assembly: Guid("592E12A6-DA65-4E00-BCE6-4AB403604F41")> 
-
-' Version information for an assembly consists of the following four values:
-'
-'      Major Version
-'      Minor Version 
-'      Build Number
-'      Revision
-'
-' You can specify all the values or you can default the Build and Revision Numbers 
-' by using the '*' as shown below:
-
-<Assembly: AssemblyVersion("2.2.0.0")> 
-


[12/51] [abbrv] [partial] Cleaning up and getting ready to development towards v4.8

Posted by sy...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleFixtureExtension/Tests/SampleFixtureExtensionTests.csproj
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleFixtureExtension/Tests/SampleFixtureExtensionTests.csproj b/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleFixtureExtension/Tests/SampleFixtureExtensionTests.csproj
deleted file mode 100644
index cc082b9..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleFixtureExtension/Tests/SampleFixtureExtensionTests.csproj
+++ /dev/null
@@ -1,94 +0,0 @@
-<VisualStudioProject>
-    <CSHARP
-        ProjectType = "Local"
-        ProductVersion = "7.10.3077"
-        SchemaVersion = "2.0"
-        ProjectGuid = "{0DE6C90F-BB74-4BC8-887A-2222DB56D2EB}"
-    >
-        <Build>
-            <Settings
-                ApplicationIcon = ""
-                AssemblyKeyContainerName = ""
-                AssemblyName = "SampleFixtureExtensionTests"
-                AssemblyOriginatorKeyFile = ""
-                DefaultClientScript = "JScript"
-                DefaultHTMLPageLayout = "Grid"
-                DefaultTargetSchema = "IE50"
-                DelaySign = "false"
-                OutputType = "Library"
-                PreBuildEvent = ""
-                PostBuildEvent = ""
-                RootNamespace = "Tests"
-                RunPostBuildEvent = "OnBuildSuccess"
-                StartupObject = ""
-            >
-                <Config
-                    Name = "Debug"
-                    AllowUnsafeBlocks = "false"
-                    BaseAddress = "285212672"
-                    CheckForOverflowUnderflow = "false"
-                    ConfigurationOverrideFile = ""
-                    DefineConstants = "DEBUG;TRACE"
-                    DocumentationFile = ""
-                    DebugSymbols = "true"
-                    FileAlignment = "4096"
-                    IncrementalBuild = "false"
-                    NoStdLib = "false"
-                    NoWarn = ""
-                    Optimize = "false"
-                    OutputPath = "bin\Debug\"
-                    RegisterForComInterop = "false"
-                    RemoveIntegerChecks = "false"
-                    TreatWarningsAsErrors = "false"
-                    WarningLevel = "4"
-                />
-                <Config
-                    Name = "Release"
-                    AllowUnsafeBlocks = "false"
-                    BaseAddress = "285212672"
-                    CheckForOverflowUnderflow = "false"
-                    ConfigurationOverrideFile = ""
-                    DefineConstants = "TRACE"
-                    DocumentationFile = ""
-                    DebugSymbols = "false"
-                    FileAlignment = "4096"
-                    IncrementalBuild = "false"
-                    NoStdLib = "false"
-                    NoWarn = ""
-                    Optimize = "true"
-                    OutputPath = "bin\Release\"
-                    RegisterForComInterop = "false"
-                    RemoveIntegerChecks = "false"
-                    TreatWarningsAsErrors = "false"
-                    WarningLevel = "4"
-                />
-            </Settings>
-            <References>
-                <Reference
-                    Name = "System"
-                    AssemblyName = "System"
-                />
-                <Reference
-                    Name = "SampleFixtureExtension"
-                    Project = "{ED281A23-9579-4A70-B608-1B86DCDEB78C}"
-                    Package = "{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}"
-                />
-                <Reference
-                    Name = "nunit.framework"
-                    AssemblyName = "nunit.framework"
-                    HintPath = "..\..\..\bin\nunit.framework.dll"
-                />
-            </References>
-        </Build>
-        <Files>
-            <Include>
-                <File
-                    RelPath = "SampleFixtureExtensionTests.cs"
-                    SubType = "Code"
-                    BuildAction = "Compile"
-                />
-            </Include>
-        </Files>
-    </CSHARP>
-</VisualStudioProject>
-

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleSuiteExtension/Addin.cs
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleSuiteExtension/Addin.cs b/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleSuiteExtension/Addin.cs
deleted file mode 100644
index 20a359a..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleSuiteExtension/Addin.cs
+++ /dev/null
@@ -1,30 +0,0 @@
-// ****************************************************************
-// Copyright 2007, Charlie Poole
-// This is free software licensed under the NUnit license. You may
-// obtain a copy of the license at http://nunit.org/?p=license&r=2.4
-// ****************************************************************
-
-using System;
-using NUnit.Core.Extensibility;
-
-namespace NUnit.Core.Extensions
-{
-	/// <summary>
-	/// Summary description for Addin.
-	/// </summary>
-	[NUnitAddin(Name="SampleSuiteExtension", Description = "Recognizes Tests starting with SampleTest...")]
-	public class Addin : IAddin
-	{
-		#region IAddin Members
-		public bool Install(IExtensionHost host)
-		{
-			IExtensionPoint builders = host.GetExtensionPoint( "SuiteBuilders" );
-			if ( builders == null )
-				return false;
-
-			builders.Install( new SampleSuiteExtensionBuilder() );
-			return true;
-		}
-		#endregion
-	}
-}

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleSuiteExtension/AssemblyInfo.cs
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleSuiteExtension/AssemblyInfo.cs b/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleSuiteExtension/AssemblyInfo.cs
deleted file mode 100644
index 9f89a32..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleSuiteExtension/AssemblyInfo.cs
+++ /dev/null
@@ -1,58 +0,0 @@
-using System.Reflection;
-using System.Runtime.CompilerServices;
-
-//
-// General Information about an assembly is controlled through the following 
-// set of attributes. Change these attribute values to modify the information
-// associated with an assembly.
-//
-[assembly: AssemblyTitle("")]
-[assembly: AssemblyDescription("")]
-[assembly: AssemblyConfiguration("")]
-[assembly: AssemblyCompany("")]
-[assembly: AssemblyProduct("")]
-[assembly: AssemblyCopyright("")]
-[assembly: AssemblyTrademark("")]
-[assembly: AssemblyCulture("")]		
-
-//
-// Version information for an assembly consists of the following four values:
-//
-//      Major Version
-//      Minor Version 
-//      Build Number
-//      Revision
-//
-// You can specify all the values or you can default the Revision and Build Numbers 
-// by using the '*' as shown below:
-
-[assembly: AssemblyVersion("1.0.*")]
-
-//
-// In order to sign your assembly you must specify a key to use. Refer to the 
-// Microsoft .NET Framework documentation for more information on assembly signing.
-//
-// Use the attributes below to control which key is used for signing. 
-//
-// Notes: 
-//   (*) If no key is specified, the assembly is not signed.
-//   (*) KeyName refers to a key that has been installed in the Crypto Service
-//       Provider (CSP) on your machine. KeyFile refers to a file which contains
-//       a key.
-//   (*) If the KeyFile and the KeyName values are both specified, the 
-//       following processing occurs:
-//       (1) If the KeyName can be found in the CSP, that key is used.
-//       (2) If the KeyName does not exist and the KeyFile does exist, the key 
-//           in the KeyFile is installed into the CSP and used.
-//   (*) In order to create a KeyFile, you can use the sn.exe (Strong Name) utility.
-//       When specifying the KeyFile, the location of the KeyFile should be
-//       relative to the project output directory which is
-//       %Project Directory%\obj\<configuration>. For example, if your KeyFile is
-//       located in the project directory, you would specify the AssemblyKeyFile 
-//       attribute as [assembly: AssemblyKeyFile("..\\..\\mykey.snk")]
-//   (*) Delay Signing is an advanced option - see the Microsoft .NET Framework
-//       documentation for more information on this.
-//
-[assembly: AssemblyDelaySign(false)]
-[assembly: AssemblyKeyFile("")]
-[assembly: AssemblyKeyName("")]

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleSuiteExtension/ReadMe.txt
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleSuiteExtension/ReadMe.txt b/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleSuiteExtension/ReadMe.txt
deleted file mode 100644
index 11fb204..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleSuiteExtension/ReadMe.txt
+++ /dev/null
@@ -1,43 +0,0 @@
-SampleSuiteExtension Example
-
-This is a minimal example of a SuiteBuilder extension. It extends 
-NUnit.Core.TestSuite test suite and creates a fixture that runs every 
-test starting with "SampleTest..." It packages both the core extension
-and the attribute used in the tests in the same assembly.
-
-SampleSuiteExtension Class
-
-This class derives from NUnit.Framework.TestSuite and represents the
-extended suite within NUnit. Because it inherits from TestSuite,
-rather than TestFixture, it has to construct its own fixture object and 
-find its own tests. Everything is done in the constructor for simplicity.
-
-SampleSuiteExtensionBuilder
-
-This class is the actual SuiteBuilder loaded by NUnit as an add-in.
-It recognizes the SampleSuiteExtensionAttribute and invokes the
-SampleSuiteExtension constructor to build the suite.
-
-SampleSuiteExtensionAttribute
-
-This is the special attribute used to mark tests to be constructed
-using this add-in. It is the only class referenced from the user tests.
-
-Note on Building this Extension
-
-If you use the Visual Studio solution, the NUnit references in both
-included projects must be changed so that they refer to the copy of 
-NUnit in which you want to install the extension. The post-build step 
-for the SampleSuiteExtension project must be changed to copy the 
-extension into the addins directory for your NUnit install.
-
-NOTE:
-
-The references to nunit.core and nunit.common in the 
-SampleSuiteExtension project have their Copy Local property set to 
-false, rather than the Visual Studio default of true. In developing
-extensions, it is essential there be no extra copies of these assemblies
-be created. Once the extension is complete, those who install it in
-binary form will not need to deal with this issue.
-
-

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleSuiteExtension/SampleSuiteExtension.build
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleSuiteExtension/SampleSuiteExtension.build b/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleSuiteExtension/SampleSuiteExtension.build
deleted file mode 100644
index 0dda8cc..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleSuiteExtension/SampleSuiteExtension.build
+++ /dev/null
@@ -1,18 +0,0 @@
-<?xml version="1.0"?>
-<project name="SampleSuiteExtension" default="build" basedir=".">
-
-  <include buildfile="../../../samples.common" />
-
-  <patternset id="source-files">
-    <include name="Addin.cs" />
-    <include name="AssemblyInfo.cs" />
-    <include name="SampleSuiteExtension.cs" />
-    <include name="SampleSuiteExtensionAttribute.cs" />
-    <include name="SampleSuiteExtensionBuilder.cs" />
-  </patternset>
-
-  <patternset id="test-files">
-    <include name="SampleSuiteExtensionTests.cs" />
-  </patternset>
-
-</project>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleSuiteExtension/SampleSuiteExtension.cs
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleSuiteExtension/SampleSuiteExtension.cs b/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleSuiteExtension/SampleSuiteExtension.cs
deleted file mode 100644
index 7abfa2c..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleSuiteExtension/SampleSuiteExtension.cs
+++ /dev/null
@@ -1,39 +0,0 @@
-// ****************************************************************
-// Copyright 2007, Charlie Poole
-// This is free software licensed under the NUnit license. You may
-// obtain a copy of the license at http://nunit.org/?p=license&r=2.4
-// ****************************************************************
-
-using System;
-using System.Reflection;
-
-namespace NUnit.Core.Extensions
-{
-	/// <summary>
-	/// SampleSuiteExtension is a minimal example of a suite extension. It 
-	/// extends test suite and creates a fixture that runs every test starting 
-	/// with "SampleTest..." Because it inherits from TestSuite, rather than
-	/// TestFixture, it has to construct its own fixture object and find its 
-	/// own tests. Everything is done in the constructor for simplicity.
-	/// </summary>
-	class SampleSuiteExtension : TestSuite
-	{
-		public SampleSuiteExtension( Type fixtureType ) 
-			: base( fixtureType )
-		{
-			// Create the fixture object. We could wait to do this when
-			// it is needed, but we do it here for simplicity.
-			this.Fixture = Reflect.Construct( fixtureType );
-
-			// Locate our test methods and add them to the suite using
-			// the Add method of TestSuite. Note that we don't do a simple
-			// Tests.Add, because that wouldn't set the parent of the tests.
-			foreach( MethodInfo method in fixtureType.GetMethods( 
-				BindingFlags.Public | BindingFlags.Instance | BindingFlags.DeclaredOnly ) )
-			{
-				if ( method.Name.StartsWith( "SampleTest" ) )
-					this.Add( new NUnitTestMethod( method ) );
-			}
-		}
-	}
-}

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleSuiteExtension/SampleSuiteExtension.csproj
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleSuiteExtension/SampleSuiteExtension.csproj b/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleSuiteExtension/SampleSuiteExtension.csproj
deleted file mode 100644
index c7d0a70..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleSuiteExtension/SampleSuiteExtension.csproj
+++ /dev/null
@@ -1,114 +0,0 @@
-<VisualStudioProject>
-    <CSHARP
-        ProjectType = "Local"
-        ProductVersion = "7.10.3077"
-        SchemaVersion = "2.0"
-        ProjectGuid = "{0C4269EE-3266-45DD-9062-E356C067FBEF}"
-    >
-        <Build>
-            <Settings
-                ApplicationIcon = ""
-                AssemblyKeyContainerName = ""
-                AssemblyName = "SampleSuiteExtension"
-                AssemblyOriginatorKeyFile = ""
-                DefaultClientScript = "JScript"
-                DefaultHTMLPageLayout = "Grid"
-                DefaultTargetSchema = "IE50"
-                DelaySign = "false"
-                OutputType = "Library"
-                PreBuildEvent = ""
-                PostBuildEvent = ""
-                RootNamespace = "SampleSuiteExtension"
-                RunPostBuildEvent = "OnBuildSuccess"
-                StartupObject = ""
-            >
-                <Config
-                    Name = "Debug"
-                    AllowUnsafeBlocks = "false"
-                    BaseAddress = "285212672"
-                    CheckForOverflowUnderflow = "false"
-                    ConfigurationOverrideFile = ""
-                    DefineConstants = "DEBUG;TRACE"
-                    DocumentationFile = ""
-                    DebugSymbols = "true"
-                    FileAlignment = "4096"
-                    IncrementalBuild = "false"
-                    NoStdLib = "false"
-                    NoWarn = ""
-                    Optimize = "false"
-                    OutputPath = "bin\Debug\"
-                    RegisterForComInterop = "false"
-                    RemoveIntegerChecks = "false"
-                    TreatWarningsAsErrors = "false"
-                    WarningLevel = "4"
-                />
-                <Config
-                    Name = "Release"
-                    AllowUnsafeBlocks = "false"
-                    BaseAddress = "285212672"
-                    CheckForOverflowUnderflow = "false"
-                    ConfigurationOverrideFile = ""
-                    DefineConstants = "TRACE"
-                    DocumentationFile = ""
-                    DebugSymbols = "false"
-                    FileAlignment = "4096"
-                    IncrementalBuild = "false"
-                    NoStdLib = "false"
-                    NoWarn = ""
-                    Optimize = "true"
-                    OutputPath = "bin\Release\"
-                    RegisterForComInterop = "false"
-                    RemoveIntegerChecks = "false"
-                    TreatWarningsAsErrors = "false"
-                    WarningLevel = "4"
-                />
-            </Settings>
-            <References>
-                <Reference
-                    Name = "System"
-                    AssemblyName = "System"
-                />
-                <Reference
-                    Name = "nunit.core.interfaces"
-                    AssemblyName = "nunit.core.interfaces"
-                    HintPath = "..\..\..\bin\nunit.core.interfaces.dll"
-                />
-                <Reference
-                    Name = "nunit.core"
-                    AssemblyName = "nunit.core"
-                    HintPath = "..\..\..\bin\nunit.core.dll"
-                />
-            </References>
-        </Build>
-        <Files>
-            <Include>
-                <File
-                    RelPath = "Addin.cs"
-                    SubType = "Code"
-                    BuildAction = "Compile"
-                />
-                <File
-                    RelPath = "AssemblyInfo.cs"
-                    SubType = "Code"
-                    BuildAction = "Compile"
-                />
-                <File
-                    RelPath = "SampleSuiteExtension.cs"
-                    SubType = "Code"
-                    BuildAction = "Compile"
-                />
-                <File
-                    RelPath = "SampleSuiteExtensionAttribute.cs"
-                    SubType = "Code"
-                    BuildAction = "Compile"
-                />
-                <File
-                    RelPath = "SampleSuiteExtensionBuilder.cs"
-                    SubType = "Code"
-                    BuildAction = "Compile"
-                />
-            </Include>
-        </Files>
-    </CSHARP>
-</VisualStudioProject>
-

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleSuiteExtension/SampleSuiteExtensionAttribute.cs
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleSuiteExtension/SampleSuiteExtensionAttribute.cs b/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleSuiteExtension/SampleSuiteExtensionAttribute.cs
deleted file mode 100644
index 7194ea5..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleSuiteExtension/SampleSuiteExtensionAttribute.cs
+++ /dev/null
@@ -1,18 +0,0 @@
-// ****************************************************************
-// Copyright 2007, Charlie Poole
-// This is free software licensed under the NUnit license. You may
-// obtain a copy of the license at http://nunit.org/?p=license&r=2.4
-// ****************************************************************
-
-using System;
-
-namespace NUnit.Core.Extensions
-{
-	/// <summary>
-	/// SampleSuiteExtensionAttribute is used to identify a SampleSuiteExtension fixture
-	/// </summary>
-	[AttributeUsage(AttributeTargets.Class, AllowMultiple=false)]
-	public sealed class SampleSuiteExtensionAttribute : Attribute
-	{
-	}
-}

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleSuiteExtension/SampleSuiteExtensionBuilder.cs
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleSuiteExtension/SampleSuiteExtensionBuilder.cs b/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleSuiteExtension/SampleSuiteExtensionBuilder.cs
deleted file mode 100644
index 39b7b49..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleSuiteExtension/SampleSuiteExtensionBuilder.cs
+++ /dev/null
@@ -1,41 +0,0 @@
-// ****************************************************************
-// Copyright 2007, Charlie Poole
-// This is free software licensed under the NUnit license. You may
-// obtain a copy of the license at http://nunit.org/?p=license&r=2.4
-// ****************************************************************
-
-using System;
-using NUnit.Core.Extensibility;
-
-namespace NUnit.Core.Extensions
-{
-	/// <summary>
-	/// SampleSuiteExtensionBuilder knows how to build a SampleSuiteExtension
-	/// </summary>
-	public class SampleSuiteExtensionBuilder : ISuiteBuilder
-	{	
-		#region ISuiteBuilder Members
-
-		// This builder delegates all the work to the constructor of the  
-		// extension suite. Many builders will need to do more work, 
-		// looking for other attributes, setting properties on the 
-		// suite and locating methods for tests, setup and teardown.
-		public Test BuildFrom(Type type)
-		{
-			if ( CanBuildFrom( type ) )
-				return new SampleSuiteExtension( type );
-			return null;
-		}
-		
-		// The builder recognizes the types that it can use by the presense
-		// of SampleSuiteExtensionAttribute. Note that an attribute does not
-		// have to be used. You can use any arbitrary set of rules that can be 
-		// implemented using reflection on the type.
-		public bool CanBuildFrom(Type type)
-		{
-			return Reflect.HasAttribute( type, "NUnit.Core.Extensions.SampleSuiteExtensionAttribute", false );
-		}
-
-		#endregion
-	}
-}

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleSuiteExtension/Tests/SampleSuiteExtensionTests.cs
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleSuiteExtension/Tests/SampleSuiteExtensionTests.cs b/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleSuiteExtension/Tests/SampleSuiteExtensionTests.cs
deleted file mode 100644
index d1a7660..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleSuiteExtension/Tests/SampleSuiteExtensionTests.cs
+++ /dev/null
@@ -1,33 +0,0 @@
-// ****************************************************************
-// Copyright 2007, Charlie Poole
-// This is free software licensed under the NUnit license. You may
-// obtain a copy of the license at http://nunit.org/?p=license&r=2.4
-// ****************************************************************
-
-using System;
-using System.Reflection;
-
-namespace NUnit.Core.Extensions.Tests
-{
-	/// <summary>
-	/// Test class that demonstrates SampleSuiteExtension
-	/// </summary>
-	[SampleSuiteExtension]
-	public class SampleSuiteExtensionTests
-	{
-		public void SampleTest1()
-		{
-			Console.WriteLine( "Hello from sample test 1" );
-		}
-
-		public void SampleTest2()
-		{
-			Console.WriteLine( "Hello from sample test 2" );
-		}
-
-		public void NotATest()
-		{
-			Console.WriteLine( "I shouldn't be called!" );
-		}
-	}
-}

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleSuiteExtension/Tests/SampleSuiteExtensionTests.csproj
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleSuiteExtension/Tests/SampleSuiteExtensionTests.csproj b/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleSuiteExtension/Tests/SampleSuiteExtensionTests.csproj
deleted file mode 100644
index 339d89b..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleSuiteExtension/Tests/SampleSuiteExtensionTests.csproj
+++ /dev/null
@@ -1,94 +0,0 @@
-<VisualStudioProject>
-    <CSHARP
-        ProjectType = "Local"
-        ProductVersion = "7.10.3077"
-        SchemaVersion = "2.0"
-        ProjectGuid = "{9F609A0D-FF7E-4F0C-B2DF-417EBC557CFF}"
-    >
-        <Build>
-            <Settings
-                ApplicationIcon = ""
-                AssemblyKeyContainerName = ""
-                AssemblyName = "SampleSuiteExtensionTests"
-                AssemblyOriginatorKeyFile = ""
-                DefaultClientScript = "JScript"
-                DefaultHTMLPageLayout = "Grid"
-                DefaultTargetSchema = "IE50"
-                DelaySign = "false"
-                OutputType = "Library"
-                PreBuildEvent = ""
-                PostBuildEvent = ""
-                RootNamespace = "Tests"
-                RunPostBuildEvent = "OnBuildSuccess"
-                StartupObject = ""
-            >
-                <Config
-                    Name = "Debug"
-                    AllowUnsafeBlocks = "false"
-                    BaseAddress = "285212672"
-                    CheckForOverflowUnderflow = "false"
-                    ConfigurationOverrideFile = ""
-                    DefineConstants = "DEBUG;TRACE"
-                    DocumentationFile = ""
-                    DebugSymbols = "true"
-                    FileAlignment = "4096"
-                    IncrementalBuild = "false"
-                    NoStdLib = "false"
-                    NoWarn = ""
-                    Optimize = "false"
-                    OutputPath = "bin\Debug\"
-                    RegisterForComInterop = "false"
-                    RemoveIntegerChecks = "false"
-                    TreatWarningsAsErrors = "false"
-                    WarningLevel = "4"
-                />
-                <Config
-                    Name = "Release"
-                    AllowUnsafeBlocks = "false"
-                    BaseAddress = "285212672"
-                    CheckForOverflowUnderflow = "false"
-                    ConfigurationOverrideFile = ""
-                    DefineConstants = "TRACE"
-                    DocumentationFile = ""
-                    DebugSymbols = "false"
-                    FileAlignment = "4096"
-                    IncrementalBuild = "false"
-                    NoStdLib = "false"
-                    NoWarn = ""
-                    Optimize = "true"
-                    OutputPath = "bin\Release\"
-                    RegisterForComInterop = "false"
-                    RemoveIntegerChecks = "false"
-                    TreatWarningsAsErrors = "false"
-                    WarningLevel = "4"
-                />
-            </Settings>
-            <References>
-                <Reference
-                    Name = "System"
-                    AssemblyName = "System"
-                />
-                <Reference
-                    Name = "SampleSuiteExtension"
-                    Project = "{0C4269EE-3266-45DD-9062-E356C067FBEF}"
-                    Package = "{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}"
-                />
-                <Reference
-                    Name = "nunit.framework"
-                    AssemblyName = "nunit.framework"
-                    HintPath = "..\..\..\..\bin\nunit.framework.dll"
-                />
-            </References>
-        </Build>
-        <Files>
-            <Include>
-                <File
-                    RelPath = "SampleSuiteExtensionTests.cs"
-                    SubType = "Code"
-                    BuildAction = "Compile"
-                />
-            </Include>
-        </Files>
-    </CSHARP>
-</VisualStudioProject>
-

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/ReadMe.txt
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/ReadMe.txt b/lib/NUnit.org/NUnit/2.5.9/samples/ReadMe.txt
deleted file mode 100644
index 71e0ee7..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/ReadMe.txt
+++ /dev/null
@@ -1,69 +0,0 @@
-NUnit Samples
-
-This directory contains sample applications demonstrating the use of NUnit and organized as follows...
-
-  CSharp: Samples in C#
-
-    Failures: Demonstrates 4 failing tests and one that is not run.
-
-    Money: This is a C# version of the money example which is found in most xUnit implementations. Thanks to Kent Beck.
-
-    Money-Port: This shows how the Money example can be ported from Version 1 of NUnit with minimal changes.
-
-    Syntax: Illustrates most Assert methods using both the classic and constraint-based syntax.
-
-  JSharp: Samples in J#
-
-    Failures: Demonstrates 4 failing tests and one that is not run.
-
-  CPP: C++ Samples
-
-   MANAGED: Managed C++ Samples (VS 2003 compatible)
-
-    Failures: Demonstrates 4 failing tests and one that is not run.
-
-   CPP-CLI: C++/CLI Samples (VS 2005 only)
-
-    Failures: Demonstrates 4 failing tests and one that is not run.
-
-    Syntax: Illustrates most Assert methods using both the classic and constraint-based syntax.
-
-  VB: Samples in VB.NET
-
-    Failures: Demonstrates 4 failing tests and one that is not run.
-
-    Money: This is a VB.NET version of the money example found in most xUnit implementations. Thanks to Kent Beck.
-
-    Syntax: Illustrates most Assert methods using both the classic and constraint-based syntax.
-
-  Extensibility: Examples of extending NUnit
-
-    Framework:
-
-    Core:
-    
-      TestSuiteExtension
-
-      TestFixtureExtension
-
-
-Building the Samples
-
-A Visual Studio 2003 project is included for most samples. 
-Visual Studio 2005 will convert the format automatically upon
-opening it. The C++/CLI samples, as well as other samples that
-depend on .NET 2.0 features, include Visual Studio 2005 projects.
-
-In most cases, you will need to remove the reference to the
-nunit.framework assembly and replace it with a reference to 
-your installed copy of NUnit.
-
-To build using the Microsoft compiler, use a command similar 
-to the following:
-
-  csc /target:library /r:<path-to-NUnit>/nunit.framework.dll example.cs
-
-To build using the mono compiler, use a command like this:
-
-  msc /target:library /r:<path-to-NUNit>/nunit.framework.dll example.cs  
-

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/cpp/cpp-cli/cpp-cli.sln
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/cpp/cpp-cli/cpp-cli.sln b/lib/NUnit.org/NUnit/2.5.9/samples/cpp/cpp-cli/cpp-cli.sln
deleted file mode 100644
index a30cf36..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/cpp/cpp-cli/cpp-cli.sln
+++ /dev/null
@@ -1,41 +0,0 @@
-Microsoft Visual Studio Solution File, Format Version 9.00
-# Visual Studio 2005
-Project("{8BC9CEB8-8B4A-11D0-8D11-00A0C91BC942}") = "cpp-cli-failures", "failures\cpp-cli-failures.vcproj", "{A0987BCD-AFE6-40E4-95A8-ADA7ADB7E97D}"
-EndProject
-Project("{8BC9CEB8-8B4A-11D0-8D11-00A0C91BC942}") = "cpp-cli-syntax", "syntax\cpp-cli-syntax.vcproj", "{72448C2D-17C9-419E-B28D-3B533E7E0CD5}"
-EndProject
-Global
-	GlobalSection(SolutionConfigurationPlatforms) = preSolution
-		Debug|Any CPU = Debug|Any CPU
-		Debug|Mixed Platforms = Debug|Mixed Platforms
-		Debug|Win32 = Debug|Win32
-		Release|Any CPU = Release|Any CPU
-		Release|Mixed Platforms = Release|Mixed Platforms
-		Release|Win32 = Release|Win32
-	EndGlobalSection
-	GlobalSection(ProjectConfigurationPlatforms) = postSolution
-		{A0987BCD-AFE6-40E4-95A8-ADA7ADB7E97D}.Debug|Any CPU.ActiveCfg = Debug|Win32
-		{A0987BCD-AFE6-40E4-95A8-ADA7ADB7E97D}.Debug|Mixed Platforms.ActiveCfg = Debug|Win32
-		{A0987BCD-AFE6-40E4-95A8-ADA7ADB7E97D}.Debug|Mixed Platforms.Build.0 = Debug|Win32
-		{A0987BCD-AFE6-40E4-95A8-ADA7ADB7E97D}.Debug|Win32.ActiveCfg = Debug|Win32
-		{A0987BCD-AFE6-40E4-95A8-ADA7ADB7E97D}.Debug|Win32.Build.0 = Debug|Win32
-		{A0987BCD-AFE6-40E4-95A8-ADA7ADB7E97D}.Release|Any CPU.ActiveCfg = Release|Win32
-		{A0987BCD-AFE6-40E4-95A8-ADA7ADB7E97D}.Release|Mixed Platforms.ActiveCfg = Release|Win32
-		{A0987BCD-AFE6-40E4-95A8-ADA7ADB7E97D}.Release|Mixed Platforms.Build.0 = Release|Win32
-		{A0987BCD-AFE6-40E4-95A8-ADA7ADB7E97D}.Release|Win32.ActiveCfg = Release|Win32
-		{A0987BCD-AFE6-40E4-95A8-ADA7ADB7E97D}.Release|Win32.Build.0 = Release|Win32
-		{72448C2D-17C9-419E-B28D-3B533E7E0CD5}.Debug|Any CPU.ActiveCfg = Debug|Win32
-		{72448C2D-17C9-419E-B28D-3B533E7E0CD5}.Debug|Mixed Platforms.ActiveCfg = Debug|Win32
-		{72448C2D-17C9-419E-B28D-3B533E7E0CD5}.Debug|Mixed Platforms.Build.0 = Debug|Win32
-		{72448C2D-17C9-419E-B28D-3B533E7E0CD5}.Debug|Win32.ActiveCfg = Debug|Win32
-		{72448C2D-17C9-419E-B28D-3B533E7E0CD5}.Debug|Win32.Build.0 = Debug|Win32
-		{72448C2D-17C9-419E-B28D-3B533E7E0CD5}.Release|Any CPU.ActiveCfg = Release|Win32
-		{72448C2D-17C9-419E-B28D-3B533E7E0CD5}.Release|Mixed Platforms.ActiveCfg = Release|Win32
-		{72448C2D-17C9-419E-B28D-3B533E7E0CD5}.Release|Mixed Platforms.Build.0 = Release|Win32
-		{72448C2D-17C9-419E-B28D-3B533E7E0CD5}.Release|Win32.ActiveCfg = Release|Win32
-		{72448C2D-17C9-419E-B28D-3B533E7E0CD5}.Release|Win32.Build.0 = Release|Win32
-	EndGlobalSection
-	GlobalSection(SolutionProperties) = preSolution
-		HideSolutionNode = FALSE
-	EndGlobalSection
-EndGlobal

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/cpp/cpp-cli/failures/AssemblyInfo.cpp
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/cpp/cpp-cli/failures/AssemblyInfo.cpp b/lib/NUnit.org/NUnit/2.5.9/samples/cpp/cpp-cli/failures/AssemblyInfo.cpp
deleted file mode 100644
index e64d6ee..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/cpp/cpp-cli/failures/AssemblyInfo.cpp
+++ /dev/null
@@ -1,56 +0,0 @@
-using namespace System::Reflection;
-using namespace System::Runtime::CompilerServices;
-
-//
-// General Information about an assembly is controlled through the following 
-// set of attributes. Change these attribute values to modify the information
-// associated with an assembly.
-//
-[assembly:AssemblyTitleAttribute("")];
-[assembly:AssemblyDescriptionAttribute("")];
-[assembly:AssemblyConfigurationAttribute("")];
-[assembly:AssemblyCompanyAttribute("")];
-[assembly:AssemblyProductAttribute("")];
-[assembly:AssemblyCopyrightAttribute("")];
-[assembly:AssemblyTrademarkAttribute("")];
-[assembly:AssemblyCultureAttribute("")];		
-
-//
-// Version information for an assembly consists of the following four values:
-//
-//      Major Version
-//      Minor Version 
-//      Build Number
-//      Revision
-//
-// You can specify all the value or you can default the Revision and Build Numbers 
-// by using the '*' as shown below:
-
-[assembly:AssemblyVersionAttribute("2.2.0.0")];
-
-//
-// In order to sign your assembly you must specify a key to use. Refer to the 
-// Microsoft .NET Framework documentation for more information on assembly signing.
-//
-// Use the attributes below to control which key is used for signing. 
-//
-// Notes: 
-//   (*) If no key is specified, the assembly is not signed.
-//   (*) KeyName refers to a key that has been installed in the Crypto Service
-//       Provider (CSP) on your machine. KeyFile refers to a file which contains
-//       a key.
-//   (*) If the KeyFile and the KeyName values are both specified, the 
-//       following processing occurs:
-//       (1) If the KeyName can be found in the CSP, that key is used.
-//       (2) If the KeyName does not exist and the KeyFile does exist, the key 
-//           in the KeyFile is installed into the CSP and used.
-//   (*) In order to create a KeyFile, you can use the sn.exe (Strong Name) utility.
-//        When specifying the KeyFile, the location of the KeyFile should be
-//        relative to the project directory.
-//   (*) Delay Signing is an advanced option - see the Microsoft .NET Framework
-//       documentation for more information on this.
-//
-[assembly:AssemblyDelaySignAttribute(false)];
-[assembly:AssemblyKeyFileAttribute("")];
-[assembly:AssemblyKeyNameAttribute("")];
-

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/cpp/cpp-cli/failures/cpp-cli-failures.build
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/cpp/cpp-cli/failures/cpp-cli-failures.build b/lib/NUnit.org/NUnit/2.5.9/samples/cpp/cpp-cli/failures/cpp-cli-failures.build
deleted file mode 100644
index 8cf139e..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/cpp/cpp-cli/failures/cpp-cli-failures.build
+++ /dev/null
@@ -1,24 +0,0 @@
-<?xml version="1.0"?>
-<project name="cpp-cli-failures" default="build">
-
-  <include buildfile="../../../samples.common"/>
-
-  <patternset id="source-files">
-    <include name="AssemblyInfo.cpp" />
-    <include name="cppsample.cpp" />
-    <include name="cppsample.h" />
-  </patternset>
-
-  <target name="packagex">
-    <copy todir="${package.samples.dir}/cpp/cpp-cli/failures">
-      <fileset basedir=".">
-        <include name="cpp-cli-failures.vcproj" />
-        <include name="cpp-cli-failures.build" />
-        <include name="AssemblyInfo.cpp" />
-        <include name="cppsample.cpp" />
-        <include name="cppsample.h" />
-      </fileset>
-    </copy>
-  </target>
-
-</project>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/cpp/cpp-cli/failures/cpp-cli-failures.vcproj
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/cpp/cpp-cli/failures/cpp-cli-failures.vcproj b/lib/NUnit.org/NUnit/2.5.9/samples/cpp/cpp-cli/failures/cpp-cli-failures.vcproj
deleted file mode 100644
index 364a6be..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/cpp/cpp-cli/failures/cpp-cli-failures.vcproj
+++ /dev/null
@@ -1,208 +0,0 @@
-<?xml version="1.0" encoding="Windows-1252"?>
-<VisualStudioProject
-	ProjectType="Visual C++"
-	Version="8.00"
-	Name="cpp-cli-failures"
-	ProjectGUID="{A0987BCD-AFE6-40E4-95A8-ADA7ADB7E97D}"
-	RootNamespace="cpp-failures"
-	Keyword="ManagedCProj"
-	>
-	<Platforms>
-		<Platform
-			Name="Win32"
-		/>
-	</Platforms>
-	<ToolFiles>
-	</ToolFiles>
-	<Configurations>
-		<Configuration
-			Name="Debug|Win32"
-			OutputDirectory="Debug"
-			IntermediateDirectory="Debug"
-			ConfigurationType="2"
-			InheritedPropertySheets="$(VCInstallDir)VCProjectDefaults\UpgradeFromVC71.vsprops"
-			CharacterSet="2"
-			ManagedExtensions="1"
-			>
-			<Tool
-				Name="VCPreBuildEventTool"
-			/>
-			<Tool
-				Name="VCCustomBuildTool"
-			/>
-			<Tool
-				Name="VCXMLDataGeneratorTool"
-			/>
-			<Tool
-				Name="VCWebServiceProxyGeneratorTool"
-			/>
-			<Tool
-				Name="VCMIDLTool"
-			/>
-			<Tool
-				Name="VCCLCompilerTool"
-				Optimization="0"
-				AdditionalUsingDirectories=""
-				PreprocessorDefinitions="WIN32;_DEBUG"
-				MinimalRebuild="false"
-				BasicRuntimeChecks="0"
-				RuntimeLibrary="3"
-				UsePrecompiledHeader="0"
-				WarningLevel="3"
-				DebugInformationFormat="3"
-			/>
-			<Tool
-				Name="VCManagedResourceCompilerTool"
-			/>
-			<Tool
-				Name="VCResourceCompilerTool"
-			/>
-			<Tool
-				Name="VCPreLinkEventTool"
-			/>
-			<Tool
-				Name="VCLinkerTool"
-				OutputFile="$(OutDir)/cpp-cli-failures.dll"
-				LinkIncremental="2"
-				GenerateDebugInformation="true"
-				AssemblyDebug="1"
-			/>
-			<Tool
-				Name="VCALinkTool"
-			/>
-			<Tool
-				Name="VCManifestTool"
-			/>
-			<Tool
-				Name="VCXDCMakeTool"
-			/>
-			<Tool
-				Name="VCBscMakeTool"
-			/>
-			<Tool
-				Name="VCFxCopTool"
-			/>
-			<Tool
-				Name="VCAppVerifierTool"
-			/>
-			<Tool
-				Name="VCWebDeploymentTool"
-			/>
-			<Tool
-				Name="VCPostBuildEventTool"
-			/>
-		</Configuration>
-		<Configuration
-			Name="Release|Win32"
-			OutputDirectory="Release"
-			IntermediateDirectory="Release"
-			ConfigurationType="2"
-			InheritedPropertySheets="$(VCInstallDir)VCProjectDefaults\UpgradeFromVC71.vsprops"
-			CharacterSet="2"
-			ManagedExtensions="1"
-			>
-			<Tool
-				Name="VCPreBuildEventTool"
-			/>
-			<Tool
-				Name="VCCustomBuildTool"
-			/>
-			<Tool
-				Name="VCXMLDataGeneratorTool"
-			/>
-			<Tool
-				Name="VCWebServiceProxyGeneratorTool"
-			/>
-			<Tool
-				Name="VCMIDLTool"
-			/>
-			<Tool
-				Name="VCCLCompilerTool"
-				Optimization="2"
-				InlineFunctionExpansion="1"
-				AdditionalUsingDirectories=""
-				PreprocessorDefinitions="WIN32;NDEBUG"
-				MinimalRebuild="false"
-				RuntimeLibrary="2"
-				UsePrecompiledHeader="0"
-				WarningLevel="3"
-			/>
-			<Tool
-				Name="VCManagedResourceCompilerTool"
-			/>
-			<Tool
-				Name="VCResourceCompilerTool"
-			/>
-			<Tool
-				Name="VCPreLinkEventTool"
-			/>
-			<Tool
-				Name="VCLinkerTool"
-				OutputFile="$(OutDir)/cpp-cli-failures.dll"
-				LinkIncremental="1"
-				GenerateDebugInformation="true"
-			/>
-			<Tool
-				Name="VCALinkTool"
-			/>
-			<Tool
-				Name="VCManifestTool"
-			/>
-			<Tool
-				Name="VCXDCMakeTool"
-			/>
-			<Tool
-				Name="VCBscMakeTool"
-			/>
-			<Tool
-				Name="VCFxCopTool"
-			/>
-			<Tool
-				Name="VCAppVerifierTool"
-			/>
-			<Tool
-				Name="VCWebDeploymentTool"
-			/>
-			<Tool
-				Name="VCPostBuildEventTool"
-			/>
-		</Configuration>
-	</Configurations>
-	<References>
-		<AssemblyReference
-			RelativePath="..\..\..\..\solutions\vs2005\NUnitFramework\framework\bin\Debug\nunit.framework.dll"
-			AssemblyName="nunit.framework, Version=2.5.0.0, PublicKeyToken=96d09a1eb7f44a77, processorArchitecture=MSIL"
-		/>
-	</References>
-	<Files>
-		<Filter
-			Name="Source Files"
-			Filter="cpp;c;cxx;def;odl;idl;hpj;bat;asm"
-			>
-			<File
-				RelativePath="AssemblyInfo.cpp"
-				>
-			</File>
-			<File
-				RelativePath="cppsample.cpp"
-				>
-			</File>
-		</Filter>
-		<Filter
-			Name="Header Files"
-			Filter="h;hpp;hxx;hm;inl;inc"
-			>
-			<File
-				RelativePath="cppsample.h"
-				>
-			</File>
-		</Filter>
-		<Filter
-			Name="Resource Files"
-			Filter="rc;ico;cur;bmp;dlg;rc2;rct;bin;rgs;gif;jpg;jpeg;jpe;r"
-			>
-		</Filter>
-	</Files>
-	<Globals>
-	</Globals>
-</VisualStudioProject>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/cpp/cpp-cli/failures/cppsample.cpp
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/cpp/cpp-cli/failures/cppsample.cpp b/lib/NUnit.org/NUnit/2.5.9/samples/cpp/cpp-cli/failures/cppsample.cpp
deleted file mode 100644
index f5aea7c..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/cpp/cpp-cli/failures/cppsample.cpp
+++ /dev/null
@@ -1,48 +0,0 @@
-// ****************************************************************
-// This is free software licensed under the NUnit license. You
-// may obtain a copy of the license as well as information regarding
-// copyright ownership at http://nunit.org/?p=license&r=2.4.
-// ****************************************************************
-
-#include "cppsample.h"
-
-namespace NUnitSamples {
-
-	void SimpleCPPSample::Init() {
-		fValue1 = 2;
-		fValue2 = 3;
-	}
-
-	void SimpleCPPSample::Add() {
-		int result = fValue1 + fValue2;
-		Assert::AreEqual(6,result);
-	}
-
-	void SimpleCPPSample::DivideByZero()
-	{
-		int zero= 0;
-		int result= 8/zero;
-	}
-
-	void SimpleCPPSample::Equals() {
-		Assert::AreEqual(12, 12, "Integer");
-		Assert::AreEqual(12L, 12L, "Long");
-		Assert::AreEqual('a', 'a', "Char");
-
-
-		Assert::AreEqual(12, 13, "Expected Failure (Integer)");
-		Assert::AreEqual(12.0, 11.99, 0.0, "Expected Failure (Double)");
-	}
-
-	void SimpleCPPSample::IgnoredTest()
-	{
-		throw gcnew InvalidCastException();
-	}
-
-	void SimpleCPPSample::ExpectAnException()
-	{
-		throw gcnew InvalidCastException();
-	}
-
-}
-

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/cpp/cpp-cli/failures/cppsample.h
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/cpp/cpp-cli/failures/cppsample.h b/lib/NUnit.org/NUnit/2.5.9/samples/cpp/cpp-cli/failures/cppsample.h
deleted file mode 100644
index 863feb5..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/cpp/cpp-cli/failures/cppsample.h
+++ /dev/null
@@ -1,28 +0,0 @@
-// ****************************************************************
-// This is free software licensed under the NUnit license. You
-// may obtain a copy of the license as well as information regarding
-// copyright ownership at http://nunit.org/?p=license&r=2.4.
-// ****************************************************************
-
-#pragma once
-
-using namespace System;
-using namespace NUnit::Framework;
-
-namespace NUnitSamples
-{
-	[TestFixture]
-	public ref class SimpleCPPSample
-	{
-		int fValue1;
-		int fValue2;
-	public:
-		[SetUp] void Init();
-
-		[Test] void Add();
-		[Test] void DivideByZero();
-		[Test] void Equals();
-		[Test] [Ignore("ignored test")] void IgnoredTest();
-		[Test] [ExpectedException(InvalidOperationException::typeid)] void ExpectAnException();
-	};
-}

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/cpp/cpp-cli/syntax/AssemblyInfo.cpp
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/cpp/cpp-cli/syntax/AssemblyInfo.cpp b/lib/NUnit.org/NUnit/2.5.9/samples/cpp/cpp-cli/syntax/AssemblyInfo.cpp
deleted file mode 100644
index b18cdfa..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/cpp/cpp-cli/syntax/AssemblyInfo.cpp
+++ /dev/null
@@ -1,40 +0,0 @@
-#include "stdafx.h"
-
-using namespace System;
-using namespace System::Reflection;
-using namespace System::Runtime::CompilerServices;
-using namespace System::Runtime::InteropServices;
-using namespace System::Security::Permissions;
-
-//
-// General Information about an assembly is controlled through the following
-// set of attributes. Change these attribute values to modify the information
-// associated with an assembly.
-//
-[assembly:AssemblyTitleAttribute("cppclisyntax")];
-[assembly:AssemblyDescriptionAttribute("")];
-[assembly:AssemblyConfigurationAttribute("")];
-[assembly:AssemblyCompanyAttribute("")];
-[assembly:AssemblyProductAttribute("cppclisyntax")];
-[assembly:AssemblyCopyrightAttribute("Copyright (c)  2007")];
-[assembly:AssemblyTrademarkAttribute("")];
-[assembly:AssemblyCultureAttribute("")];
-
-//
-// Version information for an assembly consists of the following four values:
-//
-//      Major Version
-//      Minor Version
-//      Build Number
-//      Revision
-//
-// You can specify all the value or you can default the Revision and Build Numbers
-// by using the '*' as shown below:
-
-[assembly:AssemblyVersionAttribute("1.0.*")];
-
-[assembly:ComVisible(false)];
-
-[assembly:CLSCompliantAttribute(true)];
-
-[assembly:SecurityPermission(SecurityAction::RequestMinimum, UnmanagedCode = true)];

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/cpp/cpp-cli/syntax/cpp-cli-syntax.build
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/cpp/cpp-cli/syntax/cpp-cli-syntax.build b/lib/NUnit.org/NUnit/2.5.9/samples/cpp/cpp-cli/syntax/cpp-cli-syntax.build
deleted file mode 100644
index f3b6328..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/cpp/cpp-cli/syntax/cpp-cli-syntax.build
+++ /dev/null
@@ -1,11 +0,0 @@
-<?xml version="1.0"?>
-<project name="cpp-cli-syntax" default="build">
-
-  <include buildfile="../../../samples.common"/>
-
-  <patternset id="source-files">
-    <include name="AssemblyInfo.cpp" />
-    <include name="cpp-cli-syntax.cpp" />
-  </patternset>
-  
-</project>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/cpp/cpp-cli/syntax/cpp-cli-syntax.cpp
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/cpp/cpp-cli/syntax/cpp-cli-syntax.cpp b/lib/NUnit.org/NUnit/2.5.9/samples/cpp/cpp-cli/syntax/cpp-cli-syntax.cpp
deleted file mode 100644
index a554e95..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/cpp/cpp-cli/syntax/cpp-cli-syntax.cpp
+++ /dev/null
@@ -1,641 +0,0 @@
-// ****************************************************************
-// This is free software licensed under the NUnit license. You
-// may obtain a copy of the license as well as information regarding
-// copyright ownership at http://nunit.org/?p=license&r=2.4.
-// ****************************************************************
-
-using namespace NUnit::Framework;
-using NUnit::Framework::Is;
-using NUnit::Framework::Text;
-using NUnit::Framework::List;
-using NUnit::Framework::Has;
-using System::String;
-
-namespace NUnitSamples
-{
-	[TestFixture]
-	public ref class AssertSyntaxTests : AssertionHelper
-	{
-	public:
-		[Test]
-		void IsNull()
-		{
-			Object ^nada = nullptr;
-
-			// Classic syntax
-			Assert::IsNull(nada);
-
-			// Helper syntax
-			Assert::That(nada, Is::Null);
-
-			// Inherited syntax
-			Expect(nada, Null);
-		}
-
-		[Test]
-		void IsNotNull()
-		{
-			// Classic syntax
-			Assert::IsNotNull(42);
-
-			// Helper syntax
-			Assert::That(42, Is::Not->Null);
-
-			// Inherited syntax
-			Expect( 42, Not->Null );
-		}
-
-		[Test]
-		void IsTrue()
-		{
-			// Classic syntax
-			Assert::IsTrue(2+2==4);
-
-			// Helper syntax
-			Assert::That(2+2==4, Is::True);
-			Assert::That(2+2==4);
-
-			// Inherited syntax
-			Expect(2+2==4, True);
-			Expect(2+2==4);
-		}
-
-		[Test]
-		void IsFalse()
-		{
-			// Classic syntax
-			Assert::IsFalse(2+2==5);
-
-			// Helper syntax
-			Assert::That(2+2==5, Is::False);
-			
-			// Inherited syntax
-			Expect(2+2==5, False);
-		}
-
-		[Test]
-		void IsNaN()
-		{
-			double d = double::NaN;
-			float f = float::NaN;
-
-			// Classic syntax
-			Assert::IsNaN(d);
-			Assert::IsNaN(f);
-
-			// Helper syntax
-			Assert::That(d, Is::NaN);
-			Assert::That(f, Is::NaN);
-			
-			// Inherited syntax
-			Expect(d, NaN);
-			Expect(f, NaN);
-		}
-
-		[Test]
-		void EmptyStringTests()
-		{
-			// Classic syntax
-			Assert::IsEmpty("");
-			Assert::IsNotEmpty("Hello!");
-
-			// Helper syntax
-			Assert::That("", Is::Empty);
-			Assert::That("Hello!", Is::Not->Empty);
-
-			// Inherited syntax
-			Expect("", Empty);
-			Expect("Hello!", Not->Empty);
-		}
-
-		[Test]
-		void EmptyCollectionTests()
-		{
-			// Classic syntax
-			Assert::IsEmpty(gcnew array<bool>(0));
-			Assert::IsNotEmpty(gcnew array<int>(3));
-
-			// Helper syntax
-			Assert::That(gcnew array<bool>(0), Is::Empty);
-			Assert::That(gcnew array<int>(3), Is::Not->Empty);
-
-			// Inherited syntax
-			Expect(gcnew array<bool>(0), Empty);
-			Expect(gcnew array<int>(3), Not->Empty);
-		}
-
-		[Test]
-		void ExactTypeTests()
-		{
-			// Classic syntax workarounds)
-			String^ greeting = "Hello";
-			Assert::AreEqual(String::typeid, greeting->GetType());
-			Assert::AreEqual("System.String", greeting->GetType()->FullName);
-			Assert::AreNotEqual(int::typeid, greeting->GetType());
-			Assert::AreNotEqual("System.Int32", greeting->GetType()->FullName);
-
-			// Helper syntax
-			Assert::That(greeting, Is::TypeOf(String::typeid));
-			Assert::That(greeting, Is::Not->TypeOf(int::typeid));
-			
-			// Inherited syntax
-			Expect( "Hello", TypeOf(String::typeid));
-			Expect( "Hello", Not->TypeOf(int::typeid));
-		}
-
-		[Test]
-		void InstanceOfTypeTests()
-		{
-			// Classic syntax
-			Assert::IsInstanceOfType(String::typeid, "Hello");
-			Assert::IsNotInstanceOfType(String::typeid, 5);
-
-			// Helper syntax
-			Assert::That("Hello", Is::InstanceOfType(String::typeid));
-			Assert::That(5, Is::Not->InstanceOfType(String::typeid));
-
-			// Inherited syntax
-			Expect("Hello", InstanceOfType(String::typeid));
-			Expect(5, Not->InstanceOfType(String::typeid));
-		}
-
-		[Test]
-		void AssignableFromTypeTests()
-		{
-			// Classic syntax
-			Assert::IsAssignableFrom(String::typeid, "Hello");
-			Assert::IsNotAssignableFrom(String::typeid, 5);
-
-			// Helper syntax
-			Assert::That( "Hello", Is::AssignableFrom(String::typeid));
-			Assert::That( 5, Is::Not->AssignableFrom(String::typeid));
-			
-			// Inherited syntax
-			Expect( "Hello", AssignableFrom(String::typeid));
-			Expect( 5, Not->AssignableFrom(String::typeid));
-		}
-
-		[Test]
-		void SubstringTests()
-		{
-			String^ phrase = "Hello World!";
-			array<String^>^ strings = {"abc", "bad", "dba" };
-			
-			// Classic Syntax
-			StringAssert::Contains("World", phrase);
-			
-			// Helper syntax
-			Assert::That(phrase, Contains("World"));
-			// Only available using new syntax
-			Assert::That(phrase, Text::DoesNotContain("goodbye"));
-			Assert::That(phrase, Text::Contains("WORLD")->IgnoreCase);
-			Assert::That(phrase, Text::DoesNotContain("BYE")->IgnoreCase);
-			Assert::That(strings, Text::All->Contains( "b" ) );
-
-			// Inherited syntax
-			Expect(phrase, Contains("World"));
-			// Only available using new syntax
-			Expect(phrase, Not->Contains("goodbye"));
-			Expect(phrase, Contains("WORLD")->IgnoreCase);
-			Expect(phrase, Not->Contains("BYE")->IgnoreCase);
-			Expect(strings, All->Contains("b"));
-		}
-
-		[Test]
-		void StartsWithTests()
-		{
-			String^ phrase = "Hello World!";
-			array<String^>^ greetings = { "Hello!", "Hi!", "Hola!" };
-
-			// Classic syntax
-			StringAssert::StartsWith("Hello", phrase);
-
-			// Helper syntax
-			Assert::That(phrase, Text::StartsWith("Hello"));
-			// Only available using new syntax
-			Assert::That(phrase, Text::DoesNotStartWith("Hi!"));
-			Assert::That(phrase, Text::StartsWith("HeLLo")->IgnoreCase);
-			Assert::That(phrase, Text::DoesNotStartWith("HI")->IgnoreCase);
-			Assert::That(greetings, Text::All->StartsWith("h")->IgnoreCase);
-
-			// Inherited syntax
-			Expect(phrase, StartsWith("Hello"));
-			// Only available using new syntax
-			Expect(phrase, Not->StartsWith("Hi!"));
-			Expect(phrase, StartsWith("HeLLo")->IgnoreCase);
-			Expect(phrase, Not->StartsWith("HI")->IgnoreCase);
-			Expect(greetings, All->StartsWith("h")->IgnoreCase);
-		}
-
-		[Test]
-		void EndsWithTests()
-		{
-			String^ phrase = "Hello World!";
-			array<String^>^ greetings = { "Hello!", "Hi!", "Hola!" };
-
-			// Classic Syntax
-			StringAssert::EndsWith("!", phrase);
-
-			// Helper syntax
-			Assert::That(phrase, Text::EndsWith("!"));
-			// Only available using new syntax
-			Assert::That(phrase, Text::DoesNotEndWith("?"));
-			Assert::That(phrase, Text::EndsWith("WORLD!")->IgnoreCase);
-			Assert::That(greetings, Text::All->EndsWith("!"));
-		
-			// Inherited syntax
-			Expect(phrase, EndsWith("!"));
-			// Only available using new syntax
-			Expect(phrase, Not->EndsWith("?"));
-			Expect(phrase, EndsWith("WORLD!")->IgnoreCase);
-			Expect(greetings, All->EndsWith("!") );
-		}
-
-		[Test]
-		void EqualIgnoringCaseTests()
-		{
-			String^ phrase = "Hello World!";
-
-			// Classic syntax
-			StringAssert::AreEqualIgnoringCase("hello world!",phrase);
-            
-			// Helper syntax
-			Assert::That(phrase, Is::EqualTo("hello world!")->IgnoreCase);
-			//Only available using new syntax
-			Assert::That(phrase, Is::Not->EqualTo("goodbye world!")->IgnoreCase);
-			Assert::That(gcnew array<String^> { "Hello", "World" }, 
-				Is::EqualTo(gcnew array<Object^> { "HELLO", "WORLD" })->IgnoreCase);
-			Assert::That(gcnew array<String^> {"HELLO", "Hello", "hello" },
-				Is::All->EqualTo( "hello" )->IgnoreCase);
-		            
-			// Inherited syntax
-			Expect(phrase, EqualTo("hello world!")->IgnoreCase);
-			//Only available using new syntax
-			Expect(phrase, Not->EqualTo("goodbye world!")->IgnoreCase);
-			Expect(gcnew array<String^> { "Hello", "World" }, 
-				EqualTo(gcnew array<Object^> { "HELLO", "WORLD" })->IgnoreCase);
-			Expect(gcnew array<String^> {"HELLO", "Hello", "hello" },
-				All->EqualTo( "hello" )->IgnoreCase);
-		}
-
-		[Test]
-		void RegularExpressionTests()
-		{
-			String^ phrase = "Now is the time for all good men to come to the aid of their country.";
-			array<String^>^ quotes = { "Never say never", "It's never too late", "Nevermore!" };
-
-			// Classic syntax
-			StringAssert::IsMatch( "all good men", phrase );
-			StringAssert::IsMatch( "Now.*come", phrase );
-
-			// Helper syntax
-			Assert::That( phrase, Text::Matches( "all good men" ) );
-			Assert::That( phrase, Text::Matches( "Now.*come" ) );
-			// Only available using new syntax
-			Assert::That(phrase, Text::DoesNotMatch("all.*men.*good"));
-			Assert::That(phrase, Text::Matches("ALL")->IgnoreCase);
-			Assert::That(quotes, Text::All->Matches("never")->IgnoreCase);
-		
-			// Inherited syntax
-			Expect( phrase, Matches( "all good men" ) );
-			Expect( phrase, Matches( "Now.*come" ) );
-			// Only available using new syntax
-			Expect(phrase, Not->Matches("all.*men.*good"));
-			Expect(phrase, Matches("ALL")->IgnoreCase);
-			Expect(quotes, All->Matches("never")->IgnoreCase);
-		}
-
-		[Test]
-		void EqualityTests()
-		{
-			array<int>^ i3 = { 1, 2, 3 };
-			array<double>^ d3 = { 1.0, 2.0, 3.0 };
-			array<int>^ iunequal = { 1, 3, 2 };
-
-			// Classic Syntax
-			Assert::AreEqual(4, 2 + 2);
-			Assert::AreEqual(i3, d3);
-			Assert::AreNotEqual(5, 2 + 2);
-			Assert::AreNotEqual(i3, iunequal);
-
-			// Helper syntax
-			Assert::That(2 + 2, Is::EqualTo(4));
-			Assert::That(2 + 2 == 4);
-			Assert::That(i3, Is::EqualTo(d3));
-			Assert::That(2 + 2, Is::Not->EqualTo(5));
-			Assert::That(i3, Is::Not->EqualTo(iunequal));
-		
-			// Inherited syntax
-			Expect(2 + 2, EqualTo(4));
-			Expect(2 + 2 == 4);
-			Expect(i3, EqualTo(d3));
-			Expect(2 + 2, Not->EqualTo(5));
-			Expect(i3, Not->EqualTo(iunequal));
-		}
-
-		[Test]
-		void EqualityTestsWithTolerance()
-		{
-			// CLassic syntax
-			Assert::AreEqual(5.0, 4.99, 0.05);
-			Assert::AreEqual(5.0F, 4.99F, 0.05F);
-
-			// Helper syntax
-			Assert::That(4.99L, Is::EqualTo(5.0L)->Within(0.05L));
-			Assert::That(4.99f, Is::EqualTo(5.0f)->Within(0.05f));
-		
-			// Inherited syntax
-			Expect(4.99L, EqualTo(5.0L)->Within(0.05L));
-			Expect(4.99f, EqualTo(5.0f)->Within(0.05f));
-		}
-
-		[Test]
-		void ComparisonTests()
-		{
-			// Classic Syntax
-			Assert::Greater(7, 3);
-			Assert::GreaterOrEqual(7, 3);
-			Assert::GreaterOrEqual(7, 7);
-
-			// Helper syntax
-			Assert::That(7, Is::GreaterThan(3));
-			Assert::That(7, Is::GreaterThanOrEqualTo(3));
-			Assert::That(7, Is::AtLeast(3));
-			Assert::That(7, Is::GreaterThanOrEqualTo(7));
-			Assert::That(7, Is::AtLeast(7));
-
-			// Inherited syntax
-			Expect(7, GreaterThan(3));
-			Expect(7, GreaterThanOrEqualTo(3));
-			Expect(7, AtLeast(3));
-			Expect(7, GreaterThanOrEqualTo(7));
-			Expect(7, AtLeast(7));
-
-			// Classic syntax
-			Assert::Less(3, 7);
-			Assert::LessOrEqual(3, 7);
-			Assert::LessOrEqual(3, 3);
-
-			// Helper syntax
-			Assert::That(3, Is::LessThan(7));
-			Assert::That(3, Is::LessThanOrEqualTo(7));
-			Assert::That(3, Is::AtMost(7));
-			Assert::That(3, Is::LessThanOrEqualTo(3));
-			Assert::That(3, Is::AtMost(3));
-		
-			// Inherited syntax
-			Expect(3, LessThan(7));
-			Expect(3, LessThanOrEqualTo(7));
-			Expect(3, AtMost(7));
-			Expect(3, LessThanOrEqualTo(3));
-			Expect(3, AtMost(3));
-		}
-
-		[Test]
-		void AllItemsTests()
-		{
-			array<Object^>^ ints = { 1, 2, 3, 4 };
-			array<Object^>^ strings = { "abc", "bad", "cab", "bad", "dad" };
-
-			// Classic syntax
-			CollectionAssert::AllItemsAreNotNull(ints);
-			CollectionAssert::AllItemsAreInstancesOfType(ints, int::typeid);
-			CollectionAssert::AllItemsAreInstancesOfType(strings, String::typeid);
-			CollectionAssert::AllItemsAreUnique(ints);
-
-			// Helper syntax
-			Assert::That(ints, Is::All->Not->Null);
-			Assert::That(ints, Is::All->InstanceOfType(int::typeid));
-			Assert::That(strings, Is::All->InstanceOfType(String::typeid));
-			Assert::That(ints, Is::Unique);
-			// Only available using new syntax
-			Assert::That(strings, Is::Not->Unique);
-			Assert::That(ints, Is::All->GreaterThan(0));
-			Assert::That(strings, Text::All->Contains( "a" ) );
-			Assert::That(strings, Has::Some->StartsWith( "ba" ) );
-		
-			// Inherited syntax
-			Expect(ints, All->Not->Null);
-			Expect(ints, All->InstanceOfType(int::typeid));
-			Expect(strings, All->InstanceOfType(String::typeid));
-			Expect(ints, Unique);
-			// Only available using new syntax
-			Expect(strings, Not->Unique);
-			Expect(ints, All->GreaterThan(0));
-			Expect(strings, All->Contains( "a" ) );
-			Expect(strings, Some->StartsWith( "ba" ) );
-		}
-
-		[Test]
-		void SomeItemsTests()
-		{
-			array<Object^>^ mixed = { 1, 2, "3", nullptr, "four", 100 };
-			array<Object^>^ strings = { "abc", "bad", "cab", "bad", "dad" };
-
-			// Not available using the classic syntax
-
-			// Helper syntax
-			Assert::That(mixed, Has::Some->Null);
-			Assert::That(mixed, Has::Some->InstanceOfType(int::typeid));
-			Assert::That(mixed, Has::Some->InstanceOfType(String::typeid));
-			Assert::That(strings, Has::Some->StartsWith( "ba" ) );
-			Assert::That(strings, Has::Some->Not->StartsWith( "ba" ) );
-		
-			// Inherited syntax
-			Expect(mixed, Some->Null);
-			Expect(mixed, Some->InstanceOfType(int::typeid));
-			Expect(mixed, Some->InstanceOfType(String::typeid));
-			Expect(strings, Some->StartsWith( "ba" ) );
-			Expect(strings, Some->Not->StartsWith( "ba" ) );
-		}
-
-		[Test]
-		void NoItemsTests()
-		{
-			array<Object^>^ ints = { 1, 2, 3, 4, 5 };
-			array<Object^>^ strings = { "abc", "bad", "cab", "bad", "dad" };
-
-			// Not available using the classic syntax
-
-			// Helper syntax
-			Assert::That(ints, Has::None->Null);
-			Assert::That(ints, Has::None->InstanceOfType(String::typeid));
-			Assert::That(ints, Has::None->GreaterThan(99));
-			Assert::That(strings, Has::None->StartsWith( "qu" ) );
-		
-			// Inherited syntax
-			Expect(ints, None->Null);
-			Expect(ints, None->InstanceOfType(String::typeid));
-			Expect(ints, None->GreaterThan(99));
-			Expect(strings, None->StartsWith( "qu" ) );
-		}
-
-		[Test]
-		void CollectionContainsTests()
-		{
-			array<int>^ iarray = { 1, 2, 3 };
-			array<String^>^ sarray = { "a", "b", "c" };
-
-			// Classic syntax
-			Assert::Contains(3, iarray);
-			Assert::Contains("b", sarray);
-			CollectionAssert::Contains(iarray, 3);
-			CollectionAssert::Contains(sarray, "b");
-			CollectionAssert::DoesNotContain(sarray, "x");
-
-			// Helper syntax
-			Assert::That(iarray, Has::Member(3));
-			Assert::That(sarray, Has::Member("b"));
-			Assert::That(sarray, Has::No->Member("x")); // Yuck!
-			Assert::That(sarray, !Has::Member("x"));
-		
-			// Inherited syntax
-			Expect(iarray, Contains(3));
-			Expect(sarray, Contains("b"));
-			Expect(sarray, Not->Contains("x"));
-			Expect(sarray, !Contains("x"));
-		}
-
-		[Test]
-		void CollectionEquivalenceTests()
-		{
-			array<int>^ ints1to5 = { 1, 2, 3, 4, 5 };
-
-			// Classic syntax
-			CollectionAssert::AreEquivalent(gcnew array<int> { 2, 1, 4, 3, 5 }, ints1to5);
-			CollectionAssert::AreNotEquivalent(gcnew array<int> { 2, 2, 4, 3, 5 }, ints1to5);
-			CollectionAssert::AreNotEquivalent(gcnew array<int> { 2, 4, 3, 5 }, ints1to5);
-			CollectionAssert::AreNotEquivalent(gcnew array<int> { 2, 2, 1, 1, 4, 3, 5 }, ints1to5);
-		
-			// Helper syntax
-			Assert::That(gcnew array<int> { 2, 1, 4, 3, 5 }, Is::EquivalentTo(ints1to5));
-			Assert::That(gcnew array<int> { 2, 2, 4, 3, 5 }, Is::Not->EquivalentTo(ints1to5));
-			Assert::That(gcnew array<int> { 2, 4, 3, 5 }, Is::Not->EquivalentTo(ints1to5));
-			Assert::That(gcnew array<int> { 2, 2, 1, 1, 4, 3, 5 }, Is::Not->EquivalentTo(ints1to5));
-
-			// Inherited syntax
-			Expect(gcnew array<int> { 2, 1, 4, 3, 5 }, EquivalentTo(ints1to5));
-			Expect(gcnew array<int> { 2, 2, 4, 3, 5 }, Not->EquivalentTo(ints1to5));
-			Expect(gcnew array<int> { 2, 4, 3, 5 }, Not->EquivalentTo(ints1to5));
-			Expect(gcnew array<int> { 2, 2, 1, 1, 4, 3, 5 }, Not->EquivalentTo(ints1to5));
-		}
-
-		[Test]
-		void SubsetTests()
-		{
-			array<int>^ ints1to5 = { 1, 2, 3, 4, 5 };
-
-			// Classic syntax
-			CollectionAssert::IsSubsetOf(gcnew array<int> { 1, 3, 5 }, ints1to5);
-			CollectionAssert::IsSubsetOf(gcnew array<int> { 1, 2, 3, 4, 5 }, ints1to5);
-			CollectionAssert::IsNotSubsetOf(gcnew array<int> { 2, 4, 6 }, ints1to5);
-			CollectionAssert::IsNotSubsetOf(gcnew array<int> { 1, 2, 2, 2, 5 }, ints1to5);
-
-			// Helper syntax
-			Assert::That(gcnew array<int> { 1, 3, 5 }, Is::SubsetOf(ints1to5));
-			Assert::That(gcnew array<int> { 1, 2, 3, 4, 5 }, Is::SubsetOf(ints1to5));
-			Assert::That(gcnew array<int> { 2, 4, 6 }, Is::Not->SubsetOf(ints1to5));
-			Assert::That(gcnew array<int> { 1, 2, 2, 2, 5 }, Is::Not->SubsetOf(ints1to5));
-		
-			// Inherited syntax
-			Expect(gcnew array<int> { 1, 3, 5 }, SubsetOf(ints1to5));
-			Expect(gcnew array<int> { 1, 2, 3, 4, 5 }, SubsetOf(ints1to5));
-			Expect(gcnew array<int> { 2, 4, 6 }, Not->SubsetOf(ints1to5));
-			Expect(gcnew array<int> { 1, 2, 2, 2, 5 }, Not->SubsetOf(ints1to5));
-		}
-
-		[Test]
-		void PropertyTests()
-		{
-			array<String^>^ strings = { "abc", "bca", "xyz" };
-
-			// Helper syntax
-			Assert::That( "Hello", Has::Property("Length")->EqualTo(5) );
-			Assert::That( "Hello", Has::Length->EqualTo( 5 ) );
-			Assert::That( strings , Has::All->Property( "Length")->EqualTo(3) );
-			Assert::That( strings, Has::All->Length->EqualTo( 3 ) );
-
-			// Inherited syntax
-			Expect( "Hello", Property("Length")->EqualTo(5) );
-			Expect( "Hello", Length->EqualTo( 5 ) );
-			Expect( strings, All->Property("Length")->EqualTo(3) );
-			Expect( strings, All->Length->EqualTo( 3 ) );
-		}
-
-		[Test]
-		void NotTests()
-		{
-			// Not available using the classic syntax
-
-			// Helper syntax
-			Assert::That(42, Is::Not->Null);
-			Assert::That(42, Is::Not->True);
-			Assert::That(42, Is::Not->False);
-			Assert::That(2.5, Is::Not->NaN);
-			Assert::That(2 + 2, Is::Not->EqualTo(3));
-			Assert::That(2 + 2, Is::Not->Not->EqualTo(4));
-			Assert::That(2 + 2, Is::Not->Not->Not->EqualTo(5));
-
-			// Inherited syntax
-			Expect(42, Not->Null);
-			Expect(42, Not->True);
-			Expect(42, Not->False);
-			Expect(2.5, Not->NaN);
-			Expect(2 + 2, Not->EqualTo(3));
-			Expect(2 + 2, Not->Not->EqualTo(4));
-			Expect(2 + 2, Not->Not->Not->EqualTo(5));
-		}
-
-		[Test]
-		void NotOperator()
-		{
-			// The ! operator is only available in the new syntax
-			Assert::That(42, !Is::Null);
-			// Inherited syntax
-			Expect( 42, !Null );
-		}
-
-		[Test]
-		void AndOperator()
-		{
-			// The & operator is only available in the new syntax
-			Assert::That(7, Is::GreaterThan(5) & Is::LessThan(10));
-			// Inherited syntax
-			Expect( 7, GreaterThan(5) & LessThan(10));
-		}
-
-		[Test]
-		void OrOperator()
-		{
-			// The | operator is only available in the new syntax
-			Assert::That(3, Is::LessThan(5) | Is::GreaterThan(10));
-			Expect( 3, LessThan(5) | GreaterThan(10));
-		}
-
-		[Test]
-		void ComplexTests()
-		{
-			Assert::That(7, Is::Not->Null & Is::Not->LessThan(5) & Is::Not->GreaterThan(10));
-			Expect(7, Not->Null & Not->LessThan(5) & Not->GreaterThan(10));
-
-			Assert::That(7, !Is::Null & !Is::LessThan(5) & !Is::GreaterThan(10));
-			Expect(7, !Null & !LessThan(5) & !GreaterThan(10));
-		}
-
-		// This method contains assertions that should not compile
-		// You can check by uncommenting it.
-		//void WillNotCompile()
-		//{
-		//    Assert::That(42, Is::Not);
-		//    Assert::That(42, Is::All);
-		//    Assert::That(42, Is::Null->Not);
-		//    Assert::That(42, Is::Not->Null->GreaterThan(10));
-		//    Assert::That(42, Is::GreaterThan(10)->LessThan(99));
-
-		//    object[] c = new object[0];
-		//    Assert::That(c, Is::Null->All);
-		//    Assert::That(c, Is::Not->All);
-		//    Assert::That(c, Is::All->Not);
-		//}
-	};
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/cpp/cpp-cli/syntax/cpp-cli-syntax.vcproj
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/cpp/cpp-cli/syntax/cpp-cli-syntax.vcproj b/lib/NUnit.org/NUnit/2.5.9/samples/cpp/cpp-cli/syntax/cpp-cli-syntax.vcproj
deleted file mode 100644
index ff1efe8..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/cpp/cpp-cli/syntax/cpp-cli-syntax.vcproj
+++ /dev/null
@@ -1,200 +0,0 @@
-<?xml version="1.0" encoding="Windows-1252"?>
-<VisualStudioProject
-	ProjectType="Visual C++"
-	Version="8.00"
-	Name="cpp-cli-syntax"
-	ProjectGUID="{72448C2D-17C9-419E-B28D-3B533E7E0CD5}"
-	RootNamespace="cppclisyntax"
-	Keyword="ManagedCProj"
-	>
-	<Platforms>
-		<Platform
-			Name="Win32"
-		/>
-	</Platforms>
-	<ToolFiles>
-	</ToolFiles>
-	<Configurations>
-		<Configuration
-			Name="Debug|Win32"
-			OutputDirectory="$(SolutionDir)$(ConfigurationName)"
-			IntermediateDirectory="$(ConfigurationName)"
-			ConfigurationType="2"
-			CharacterSet="1"
-			ManagedExtensions="1"
-			>
-			<Tool
-				Name="VCPreBuildEventTool"
-			/>
-			<Tool
-				Name="VCCustomBuildTool"
-			/>
-			<Tool
-				Name="VCXMLDataGeneratorTool"
-			/>
-			<Tool
-				Name="VCWebServiceProxyGeneratorTool"
-			/>
-			<Tool
-				Name="VCMIDLTool"
-			/>
-			<Tool
-				Name="VCCLCompilerTool"
-				Optimization="0"
-				PreprocessorDefinitions="WIN32;_DEBUG"
-				RuntimeLibrary="3"
-				WarningLevel="3"
-				DebugInformationFormat="3"
-			/>
-			<Tool
-				Name="VCManagedResourceCompilerTool"
-			/>
-			<Tool
-				Name="VCResourceCompilerTool"
-			/>
-			<Tool
-				Name="VCPreLinkEventTool"
-			/>
-			<Tool
-				Name="VCLinkerTool"
-				AdditionalDependencies="$(NoInherit)"
-				LinkIncremental="2"
-				GenerateDebugInformation="true"
-				AssemblyDebug="1"
-				TargetMachine="1"
-			/>
-			<Tool
-				Name="VCALinkTool"
-			/>
-			<Tool
-				Name="VCManifestTool"
-			/>
-			<Tool
-				Name="VCXDCMakeTool"
-			/>
-			<Tool
-				Name="VCBscMakeTool"
-			/>
-			<Tool
-				Name="VCFxCopTool"
-			/>
-			<Tool
-				Name="VCAppVerifierTool"
-			/>
-			<Tool
-				Name="VCWebDeploymentTool"
-			/>
-			<Tool
-				Name="VCPostBuildEventTool"
-			/>
-		</Configuration>
-		<Configuration
-			Name="Release|Win32"
-			OutputDirectory="$(SolutionDir)$(ConfigurationName)"
-			IntermediateDirectory="$(ConfigurationName)"
-			ConfigurationType="2"
-			CharacterSet="1"
-			ManagedExtensions="1"
-			WholeProgramOptimization="1"
-			>
-			<Tool
-				Name="VCPreBuildEventTool"
-			/>
-			<Tool
-				Name="VCCustomBuildTool"
-			/>
-			<Tool
-				Name="VCXMLDataGeneratorTool"
-			/>
-			<Tool
-				Name="VCWebServiceProxyGeneratorTool"
-			/>
-			<Tool
-				Name="VCMIDLTool"
-			/>
-			<Tool
-				Name="VCCLCompilerTool"
-				PreprocessorDefinitions="WIN32;NDEBUG"
-				RuntimeLibrary="2"
-				WarningLevel="3"
-				DebugInformationFormat="3"
-			/>
-			<Tool
-				Name="VCManagedResourceCompilerTool"
-			/>
-			<Tool
-				Name="VCResourceCompilerTool"
-			/>
-			<Tool
-				Name="VCPreLinkEventTool"
-			/>
-			<Tool
-				Name="VCLinkerTool"
-				AdditionalDependencies="$(NoInherit)"
-				LinkIncremental="1"
-				GenerateDebugInformation="true"
-				TargetMachine="1"
-			/>
-			<Tool
-				Name="VCALinkTool"
-			/>
-			<Tool
-				Name="VCManifestTool"
-			/>
-			<Tool
-				Name="VCXDCMakeTool"
-			/>
-			<Tool
-				Name="VCBscMakeTool"
-			/>
-			<Tool
-				Name="VCFxCopTool"
-			/>
-			<Tool
-				Name="VCAppVerifierTool"
-			/>
-			<Tool
-				Name="VCWebDeploymentTool"
-			/>
-			<Tool
-				Name="VCPostBuildEventTool"
-			/>
-		</Configuration>
-	</Configurations>
-	<References>
-		<AssemblyReference
-			RelativePath="System.dll"
-			AssemblyName="System, Version=2.0.0.0, PublicKeyToken=b77a5c561934e089, processorArchitecture=MSIL"
-		/>
-		<AssemblyReference
-			RelativePath="..\..\..\..\solutions\vs2005\NUnitFramework\framework\bin\Debug\nunit.framework.dll"
-			AssemblyName="nunit.framework, Version=2.5.0.0, PublicKeyToken=96d09a1eb7f44a77, processorArchitecture=MSIL"
-		/>
-	</References>
-	<Files>
-		<Filter
-			Name="Source Files"
-			Filter="cpp;c;cc;cxx;def;odl;idl;hpj;bat;asm;asmx"
-			UniqueIdentifier="{4FC737F1-C7A5-4376-A066-2A32D752A2FF}"
-			>
-			<File
-				RelativePath=".\cpp-cli-syntax.cpp"
-				>
-			</File>
-		</Filter>
-		<Filter
-			Name="Header Files"
-			Filter="h;hpp;hxx;hm;inl;inc;xsd"
-			UniqueIdentifier="{93995380-89BD-4b04-88EB-625FBE52EBFB}"
-			>
-		</Filter>
-		<Filter
-			Name="Resource Files"
-			Filter="rc;ico;cur;bmp;dlg;rc2;rct;bin;rgs;gif;jpg;jpeg;jpe;resx;tiff;tif;png;wav"
-			UniqueIdentifier="{67DA6AB6-F800-4c08-8B7A-83BB121AAD01}"
-			>
-		</Filter>
-	</Files>
-	<Globals>
-	</Globals>
-</VisualStudioProject>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/cpp/managed/failures/AssemblyInfo.cpp
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/cpp/managed/failures/AssemblyInfo.cpp b/lib/NUnit.org/NUnit/2.5.9/samples/cpp/managed/failures/AssemblyInfo.cpp
deleted file mode 100644
index e64d6ee..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/cpp/managed/failures/AssemblyInfo.cpp
+++ /dev/null
@@ -1,56 +0,0 @@
-using namespace System::Reflection;
-using namespace System::Runtime::CompilerServices;
-
-//
-// General Information about an assembly is controlled through the following 
-// set of attributes. Change these attribute values to modify the information
-// associated with an assembly.
-//
-[assembly:AssemblyTitleAttribute("")];
-[assembly:AssemblyDescriptionAttribute("")];
-[assembly:AssemblyConfigurationAttribute("")];
-[assembly:AssemblyCompanyAttribute("")];
-[assembly:AssemblyProductAttribute("")];
-[assembly:AssemblyCopyrightAttribute("")];
-[assembly:AssemblyTrademarkAttribute("")];
-[assembly:AssemblyCultureAttribute("")];		
-
-//
-// Version information for an assembly consists of the following four values:
-//
-//      Major Version
-//      Minor Version 
-//      Build Number
-//      Revision
-//
-// You can specify all the value or you can default the Revision and Build Numbers 
-// by using the '*' as shown below:
-
-[assembly:AssemblyVersionAttribute("2.2.0.0")];
-
-//
-// In order to sign your assembly you must specify a key to use. Refer to the 
-// Microsoft .NET Framework documentation for more information on assembly signing.
-//
-// Use the attributes below to control which key is used for signing. 
-//
-// Notes: 
-//   (*) If no key is specified, the assembly is not signed.
-//   (*) KeyName refers to a key that has been installed in the Crypto Service
-//       Provider (CSP) on your machine. KeyFile refers to a file which contains
-//       a key.
-//   (*) If the KeyFile and the KeyName values are both specified, the 
-//       following processing occurs:
-//       (1) If the KeyName can be found in the CSP, that key is used.
-//       (2) If the KeyName does not exist and the KeyFile does exist, the key 
-//           in the KeyFile is installed into the CSP and used.
-//   (*) In order to create a KeyFile, you can use the sn.exe (Strong Name) utility.
-//        When specifying the KeyFile, the location of the KeyFile should be
-//        relative to the project directory.
-//   (*) Delay Signing is an advanced option - see the Microsoft .NET Framework
-//       documentation for more information on this.
-//
-[assembly:AssemblyDelaySignAttribute(false)];
-[assembly:AssemblyKeyFileAttribute("")];
-[assembly:AssemblyKeyNameAttribute("")];
-

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/cpp/managed/failures/cpp-managed-failures.build
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/cpp/managed/failures/cpp-managed-failures.build b/lib/NUnit.org/NUnit/2.5.9/samples/cpp/managed/failures/cpp-managed-failures.build
deleted file mode 100644
index 5bf96a1..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/cpp/managed/failures/cpp-managed-failures.build
+++ /dev/null
@@ -1,31 +0,0 @@
-<?xml version="1.0"?>
-<project name="cpp-managed-failures" default="build">
-
-  <include buildfile="../../../samples.common" />
-
-  <patternset id="source-files">
-    <include name="AssemblyInfo.cpp" />
-    <include name="cppsample.cpp" />
-    <include name="cppsample.h" />
-  </patternset>
-
-  <target name="packagex">
-    <copy todir="${package.samples.dir}/cpp/managed/failures">
-      <fileset basedir=".">
-        <include name="cpp-managed-failures.build" />
-        <include name="AssemblyInfo.cpp" />
-        <include name="cppsample.cpp" />
-        <include name="cppsample.h" />
-      </fileset>
-    </copy>
-
-    <copy todir="${package.samples.dir}/cpp/managed/failures"
-        file="./cpp-managed-failures.vcproj">
-      <filterchain>
-        <replacestring from="$(SolutionDir)..\..\..\src\NUnitFramework\framework\bin\Debug\nunit.framework.dll"
-          to="..\..\..\..\bin\nunit.framework.dll"/>
-      </filterchain>
-    </copy>
-  </target>
-
-</project>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/cpp/managed/failures/cpp-managed-failures.vcproj
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/cpp/managed/failures/cpp-managed-failures.vcproj b/lib/NUnit.org/NUnit/2.5.9/samples/cpp/managed/failures/cpp-managed-failures.vcproj
deleted file mode 100644
index ec3e599..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/cpp/managed/failures/cpp-managed-failures.vcproj
+++ /dev/null
@@ -1,139 +0,0 @@
-<?xml version="1.0" encoding="Windows-1252"?>
-<VisualStudioProject
-	ProjectType="Visual C++"
-	Version="7.10"
-	Name="cpp-managed-failures"
-	ProjectGUID="{7E5849C7-0469-4AD2-91B9-C87203934254}"
-	Keyword="ManagedCProj">
-	<Platforms>
-		<Platform
-			Name="Win32"/>
-	</Platforms>
-	<Configurations>
-		<Configuration
-			Name="Debug|Win32"
-			OutputDirectory="Debug"
-			IntermediateDirectory="Debug"
-			ConfigurationType="2"
-			CharacterSet="2"
-			ManagedExtensions="TRUE"
-			ReferencesPath="&quot;D:\Dev\NUnit\nunit-2.5\solutions\vs2005\NUnitFramework\framework\bin\Release&quot;">
-			<Tool
-				Name="VCCLCompilerTool"
-				Optimization="0"
-				AdditionalUsingDirectories=""
-				PreprocessorDefinitions="WIN32;_DEBUG"
-				MinimalRebuild="FALSE"
-				BasicRuntimeChecks="0"
-				RuntimeLibrary="1"
-				UsePrecompiledHeader="0"
-				WarningLevel="3"
-				DebugInformationFormat="3"/>
-			<Tool
-				Name="VCCustomBuildTool"/>
-			<Tool
-				Name="VCLinkerTool"
-				OutputFile="$(OutDir)/managed-cpp-failures.dll"
-				LinkIncremental="2"
-				GenerateDebugInformation="TRUE"/>
-			<Tool
-				Name="VCMIDLTool"/>
-			<Tool
-				Name="VCPostBuildEventTool"/>
-			<Tool
-				Name="VCPreBuildEventTool"/>
-			<Tool
-				Name="VCPreLinkEventTool"/>
-			<Tool
-				Name="VCResourceCompilerTool"/>
-			<Tool
-				Name="VCWebServiceProxyGeneratorTool"/>
-			<Tool
-				Name="VCXMLDataGeneratorTool"/>
-			<Tool
-				Name="VCWebDeploymentTool"/>
-			<Tool
-				Name="VCManagedWrapperGeneratorTool"/>
-			<Tool
-				Name="VCAuxiliaryManagedWrapperGeneratorTool"/>
-		</Configuration>
-		<Configuration
-			Name="Release|Win32"
-			OutputDirectory="Release"
-			IntermediateDirectory="Release"
-			ConfigurationType="2"
-			CharacterSet="2"
-			ManagedExtensions="TRUE"
-			ReferencesPath="&quot;D:\Dev\NUnit\nunit-2.5\solutions\vs2005\NUnitFramework\framework\bin\Release&quot;">
-			<Tool
-				Name="VCCLCompilerTool"
-				Optimization="2"
-				InlineFunctionExpansion="1"
-				AdditionalUsingDirectories="..\..\src\NUnitFramework\framework\bin\Release;..\..\src\NUnitFramework\framework\bin\Debug"
-				PreprocessorDefinitions="WIN32;NDEBUG"
-				MinimalRebuild="FALSE"
-				UsePrecompiledHeader="0"
-				WarningLevel="3"/>
-			<Tool
-				Name="VCCustomBuildTool"/>
-			<Tool
-				Name="VCLinkerTool"
-				OutputFile="$(OutDir)/managed-cpp-failures.dll"
-				LinkIncremental="1"
-				GenerateDebugInformation="TRUE"/>
-			<Tool
-				Name="VCMIDLTool"/>
-			<Tool
-				Name="VCPostBuildEventTool"/>
-			<Tool
-				Name="VCPreBuildEventTool"/>
-			<Tool
-				Name="VCPreLinkEventTool"/>
-			<Tool
-				Name="VCResourceCompilerTool"/>
-			<Tool
-				Name="VCWebServiceProxyGeneratorTool"/>
-			<Tool
-				Name="VCXMLDataGeneratorTool"/>
-			<Tool
-				Name="VCWebDeploymentTool"/>
-			<Tool
-				Name="VCManagedWrapperGeneratorTool"/>
-			<Tool
-				Name="VCAuxiliaryManagedWrapperGeneratorTool"/>
-		</Configuration>
-	</Configurations>
-	<References>
-		<AssemblyReference
-			RelativePath="mscorlib.dll"/>
-		<AssemblyReference
-			RelativePath="$(SolutionDir)..\..\bin\nunit.framework.dll"/>
-		<AssemblyReference
-			RelativePath="System.dll"/>
-	</References>
-	<Files>
-		<Filter
-			Name="Source Files"
-			Filter="cpp;c;cxx;def;odl;idl;hpj;bat;asm">
-			<File
-				RelativePath="AssemblyInfo.cpp">
-			</File>
-			<File
-				RelativePath="cppsample.cpp">
-			</File>
-		</Filter>
-		<Filter
-			Name="Header Files"
-			Filter="h;hpp;hxx;hm;inl;inc">
-			<File
-				RelativePath="cppsample.h">
-			</File>
-		</Filter>
-		<Filter
-			Name="Resource Files"
-			Filter="rc;ico;cur;bmp;dlg;rc2;rct;bin;rgs;gif;jpg;jpeg;jpe;r">
-		</Filter>
-	</Files>
-	<Globals>
-	</Globals>
-</VisualStudioProject>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/cpp/managed/failures/cppsample.cpp
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/cpp/managed/failures/cppsample.cpp b/lib/NUnit.org/NUnit/2.5.9/samples/cpp/managed/failures/cppsample.cpp
deleted file mode 100644
index dac7156..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/cpp/managed/failures/cppsample.cpp
+++ /dev/null
@@ -1,48 +0,0 @@
-// ****************************************************************
-// This is free software licensed under the NUnit license. You
-// may obtain a copy of the license as well as information regarding
-// copyright ownership at http://nunit.org/?p=license&r=2.4.
-// ****************************************************************
-
-#include "cppsample.h"
-
-namespace NUnitSamples {
-
-	void SimpleCPPSample::Init() {
-		fValue1 = 2;
-		fValue2 = 3;
-	}
-
-	void SimpleCPPSample::Add() {
-		int result = fValue1 + fValue2;
-		Assert::AreEqual(6,result);
-	}
-
-	void SimpleCPPSample::DivideByZero()
-	{
-		int zero= 0;
-		int result= 8/zero;
-	}
-
-	void SimpleCPPSample::Equals() {
-		Assert::AreEqual(12, 12, "Integer");
-		Assert::AreEqual(12L, 12L, "Long");
-		Assert::AreEqual('a', 'a', "Char");
-
-
-		Assert::AreEqual(12, 13, "Expected Failure (Integer)");
-		Assert::AreEqual(12.0, 11.99, 0.0, "Expected Failure (Double)");
-	}
-
-	void SimpleCPPSample::IgnoredTest()
-	{
-		throw new InvalidCastException();
-	}
-
-	void SimpleCPPSample::ExpectAnException()
-	{
-		throw new InvalidCastException();
-	}
-
-}
-

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/cpp/managed/failures/cppsample.h
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/cpp/managed/failures/cppsample.h b/lib/NUnit.org/NUnit/2.5.9/samples/cpp/managed/failures/cppsample.h
deleted file mode 100644
index 4e47439..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/cpp/managed/failures/cppsample.h
+++ /dev/null
@@ -1,28 +0,0 @@
-// ****************************************************************
-// This is free software licensed under the NUnit license. You
-// may obtain a copy of the license as well as information regarding
-// copyright ownership at http://nunit.org/?p=license&r=2.4.
-// ****************************************************************
-
-#pragma once
-
-using namespace System;
-using namespace NUnit::Framework;
-
-namespace NUnitSamples
-{
-	[TestFixture]
-	public __gc class SimpleCPPSample
-	{
-		int fValue1;
-		int fValue2;
-	public:
-		[SetUp] void Init();
-
-		[Test] void Add();
-		[Test] void DivideByZero();
-		[Test] void Equals();
-		[Test] [Ignore("ignored test")] void IgnoredTest();
-		[Test] [ExpectedException(__typeof(InvalidOperationException))] void ExpectAnException();
-	};
-}

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/cpp/managed/managed-cpp.sln
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/cpp/managed/managed-cpp.sln b/lib/NUnit.org/NUnit/2.5.9/samples/cpp/managed/managed-cpp.sln
deleted file mode 100644
index 4462fb0..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/cpp/managed/managed-cpp.sln
+++ /dev/null
@@ -1,21 +0,0 @@
-Microsoft Visual Studio Solution File, Format Version 8.00
-Project("{8BC9CEB8-8B4A-11D0-8D11-00A0C91BC942}") = "cpp-managed-failures", "failures\cpp-managed-failures.vcproj", "{7E5849C7-0469-4AD2-91B9-C87203934254}"
-	ProjectSection(ProjectDependencies) = postProject
-	EndProjectSection
-EndProject
-Global
-	GlobalSection(SolutionConfiguration) = preSolution
-		Debug = Debug
-		Release = Release
-	EndGlobalSection
-	GlobalSection(ProjectConfiguration) = postSolution
-		{7E5849C7-0469-4AD2-91B9-C87203934254}.Debug.ActiveCfg = Debug|Win32
-		{7E5849C7-0469-4AD2-91B9-C87203934254}.Debug.Build.0 = Debug|Win32
-		{7E5849C7-0469-4AD2-91B9-C87203934254}.Release.ActiveCfg = Release|Win32
-		{7E5849C7-0469-4AD2-91B9-C87203934254}.Release.Build.0 = Release|Win32
-	EndGlobalSection
-	GlobalSection(ExtensibilityGlobals) = postSolution
-	EndGlobalSection
-	GlobalSection(ExtensibilityAddIns) = postSolution
-	EndGlobalSection
-EndGlobal

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/csharp/CSharp.sln
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/csharp/CSharp.sln b/lib/NUnit.org/NUnit/2.5.9/samples/csharp/CSharp.sln
deleted file mode 100644
index ed95f8a..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/csharp/CSharp.sln
+++ /dev/null
@@ -1,37 +0,0 @@
-Microsoft Visual Studio Solution File, Format Version 8.00
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "cs-failures", "failures\cs-failures.csproj", "{15D66EEE-A852-4A52-89C2-83E74ECF3770}"
-	ProjectSection(ProjectDependencies) = postProject
-	EndProjectSection
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "cs-money", "money\cs-money.csproj", "{11EDF872-A04D-4F75-A1BF-71168DC86AF3}"
-	ProjectSection(ProjectDependencies) = postProject
-	EndProjectSection
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "cs-syntax", "syntax\cs-syntax.csproj", "{06F46FA2-687B-4B46-A912-C1B0B4CC1B20}"
-	ProjectSection(ProjectDependencies) = postProject
-	EndProjectSection
-EndProject
-Global
-	GlobalSection(SolutionConfiguration) = preSolution
-		Debug = Debug
-		Release = Release
-	EndGlobalSection
-	GlobalSection(ProjectConfiguration) = postSolution
-		{15D66EEE-A852-4A52-89C2-83E74ECF3770}.Debug.ActiveCfg = Debug|.NET
-		{15D66EEE-A852-4A52-89C2-83E74ECF3770}.Debug.Build.0 = Debug|.NET
-		{15D66EEE-A852-4A52-89C2-83E74ECF3770}.Release.ActiveCfg = Release|.NET
-		{15D66EEE-A852-4A52-89C2-83E74ECF3770}.Release.Build.0 = Release|.NET
-		{11EDF872-A04D-4F75-A1BF-71168DC86AF3}.Debug.ActiveCfg = Debug|.NET
-		{11EDF872-A04D-4F75-A1BF-71168DC86AF3}.Debug.Build.0 = Debug|.NET
-		{11EDF872-A04D-4F75-A1BF-71168DC86AF3}.Release.ActiveCfg = Release|.NET
-		{11EDF872-A04D-4F75-A1BF-71168DC86AF3}.Release.Build.0 = Release|.NET
-		{06F46FA2-687B-4B46-A912-C1B0B4CC1B20}.Debug.ActiveCfg = Debug|.NET
-		{06F46FA2-687B-4B46-A912-C1B0B4CC1B20}.Debug.Build.0 = Debug|.NET
-		{06F46FA2-687B-4B46-A912-C1B0B4CC1B20}.Release.ActiveCfg = Release|.NET
-		{06F46FA2-687B-4B46-A912-C1B0B4CC1B20}.Release.Build.0 = Release|.NET
-	EndGlobalSection
-	GlobalSection(ExtensibilityGlobals) = postSolution
-	EndGlobalSection
-	GlobalSection(ExtensibilityAddIns) = postSolution
-	EndGlobalSection
-EndGlobal


[30/51] [abbrv] [partial] Cleaning up and getting ready to development towards v4.8

Posted by sy...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/MbUnit35.pdb
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/MbUnit35.pdb b/lib/Gallio.3.2.750/tools/MbUnit35.pdb
deleted file mode 100644
index 6f0bf1c..0000000
Binary files a/lib/Gallio.3.2.750/tools/MbUnit35.pdb and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/MbUnit35.plugin
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/MbUnit35.plugin b/lib/Gallio.3.2.750/tools/MbUnit35.plugin
deleted file mode 100644
index 543f2c0..0000000
--- a/lib/Gallio.3.2.750/tools/MbUnit35.plugin
+++ /dev/null
@@ -1,30 +0,0 @@
-<?xml version="1.0" encoding="utf-8" ?>
-<plugin pluginId="MbUnit35"
-        recommendedInstallationPath=""
-        enableCondition="${minFramework:NET35}"
-        xmlns="http://www.gallio.org/">
-  <traits>
-    <name>MbUnit v3 Extensions for .Net 3.5</name>
-    <version>3.2.0.0</version>
-    <description>Provides additional MbUnit v3 features for use with .Net 3.5.</description>
-    <icon>plugin://MbUnit/Resources/MbUnit.ico</icon>
-  </traits>
-
-  <dependencies>
-    <dependency pluginId="Gallio35" />
-    <dependency pluginId="MbUnit" />
-  </dependencies>
-
-  <files>
-    <file path="MbUnit35.plugin" />
-    <file path="MbUnit35.dll" />
-    <file path="MbUnit35.pdb" />
-    <file path="MbUnit35.xml" />
-  </files>
-
-  <assemblies>
-    <assembly fullName="MbUnit35, Version=3.2.0.0, Culture=neutral, PublicKeyToken=eb9cfa67ee6ab36e"
-              codeBase="MbUnit35.dll"
-              qualifyPartialName="true" />
-  </assemblies>
-</plugin>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/MbUnit35.xml
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/MbUnit35.xml b/lib/Gallio.3.2.750/tools/MbUnit35.xml
deleted file mode 100644
index 4fc0b5d..0000000
--- a/lib/Gallio.3.2.750/tools/MbUnit35.xml
+++ /dev/null
@@ -1,47 +0,0 @@
-<?xml version="1.0"?>
-<doc>
-    <assembly>
-        <name>MbUnit35</name>
-    </assembly>
-    <members>
-        <member name="T:MbUnit.Framework.AssertEx">
-            <summary>
-            Provides extended assertions for .Net 3.5.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.AssertEx.That(System.Linq.Expressions.Expression{System.Func{System.Boolean}})">
-            <summary>
-            Verifies that a particular condition holds true.
-            </summary>
-            <remarks>
-            <para>
-            If the condition evaluates to false, the assertion failure message will
-            describe in detail the intermediate value of relevant sub-expressions within
-            the condition.  Consequently the assertion failure will include more diagnostic
-            information than if <see cref="M:MbUnit.Framework.Assert.IsTrue(System.Boolean)"/> were used instead.
-            </para>
-            </remarks>
-            <param name="condition">The conditional expression to evaluate.</param>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="condition"/> is null.</exception>
-            <exception cref="T:Gallio.Framework.Assertions.AssertionException">Thrown if the verification failed unless the current <see cref="P:Gallio.Framework.Assertions.AssertionContext.AssertionFailureBehavior"/> indicates otherwise.</exception>
-        </member>
-        <member name="M:MbUnit.Framework.AssertEx.That(System.Linq.Expressions.Expression{System.Func{System.Boolean}},System.String,System.Object[])">
-            <summary>
-            Verifies that a particular condition holds true.
-            </summary>
-            <remarks>
-            <para>
-            If the condition evaluates to false, the assertion failure message will
-            describe in detail the intermediate value of relevant sub-expressions within
-            the condition.  Consequently the assertion failure will include more diagnostic
-            information than if <see cref="M:MbUnit.Framework.Assert.IsTrue(System.Boolean,System.String,System.Object[])"/> were used instead.
-            </para>
-            </remarks>
-            <param name="condition">The conditional expression to evaluate.</param>
-            <param name="messageFormat">The custom assertion message format, or null if none.</param>
-            <param name="messageArgs">The custom assertion message arguments, or null if none.</param>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="condition"/> is null.</exception>
-            <exception cref="T:Gallio.Framework.Assertions.AssertionException">Thrown if the verification failed unless the current <see cref="P:Gallio.Framework.Assertions.AssertionContext.AssertionFailureBehavior"/> indicates otherwise.</exception>
-        </member>
-    </members>
-</doc>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/MbUnit40.dll
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/MbUnit40.dll b/lib/Gallio.3.2.750/tools/MbUnit40.dll
deleted file mode 100644
index 816cee0..0000000
Binary files a/lib/Gallio.3.2.750/tools/MbUnit40.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/MbUnit40.pdb
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/MbUnit40.pdb b/lib/Gallio.3.2.750/tools/MbUnit40.pdb
deleted file mode 100644
index 55aee11..0000000
Binary files a/lib/Gallio.3.2.750/tools/MbUnit40.pdb and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/MbUnit40.plugin
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/MbUnit40.plugin b/lib/Gallio.3.2.750/tools/MbUnit40.plugin
deleted file mode 100644
index 0d5bfc7..0000000
--- a/lib/Gallio.3.2.750/tools/MbUnit40.plugin
+++ /dev/null
@@ -1,30 +0,0 @@
-<?xml version="1.0" encoding="utf-8" ?>
-<plugin pluginId="MbUnit40"
-        recommendedInstallationPath=""
-        enableCondition="${minFramework:NET40}"
-        xmlns="http://www.gallio.org/">
-  <traits>
-    <name>MbUnit v3 Extensions for .Net 4.0</name>
-    <version>3.2.0.0</version>
-    <description>Provides additional MbUnit v3 features for use with .Net 4.0.</description>
-    <icon>plugin://MbUnit/Resources/MbUnit.ico</icon>
-  </traits>
-
-  <dependencies>
-    <dependency pluginId="Gallio40" />
-    <dependency pluginId="MbUnit35" />
-  </dependencies>
-
-  <files>
-    <file path="MbUnit40.plugin" />
-    <file path="MbUnit40.dll" />
-    <file path="MbUnit40.pdb" />
-    <file path="MbUnit40.xml" />
-  </files>
-
-  <assemblies>
-    <assembly fullName="MbUnit40, Version=3.2.0.0, Culture=neutral, PublicKeyToken=eb9cfa67ee6ab36e"
-              codeBase="MbUnit40.dll"
-              qualifyPartialName="true" />
-  </assemblies>
-</plugin>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/MbUnit40.xml
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/MbUnit40.xml b/lib/Gallio.3.2.750/tools/MbUnit40.xml
deleted file mode 100644
index eab3f0f..0000000
--- a/lib/Gallio.3.2.750/tools/MbUnit40.xml
+++ /dev/null
@@ -1,8 +0,0 @@
-<?xml version="1.0"?>
-<doc>
-    <assembly>
-        <name>MbUnit40</name>
-    </assembly>
-    <members>
-    </members>
-</doc>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/NCover/Gallio.NCoverIntegration.dll
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/NCover/Gallio.NCoverIntegration.dll b/lib/Gallio.3.2.750/tools/NCover/Gallio.NCoverIntegration.dll
deleted file mode 100644
index a42aa47..0000000
Binary files a/lib/Gallio.3.2.750/tools/NCover/Gallio.NCoverIntegration.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/NCover/Gallio.NCoverIntegration.plugin
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/NCover/Gallio.NCoverIntegration.plugin b/lib/Gallio.3.2.750/tools/NCover/Gallio.NCoverIntegration.plugin
deleted file mode 100644
index 8b09dc4..0000000
--- a/lib/Gallio.3.2.750/tools/NCover/Gallio.NCoverIntegration.plugin
+++ /dev/null
@@ -1,143 +0,0 @@
-<?xml version="1.0" encoding="utf-8" ?>
-<plugin pluginId="Gallio.NCoverIntegration"
-        recommendedInstallationPath="NCover"
-        xmlns="http://www.gallio.org/">
-  <traits>
-    <name>NCover Integration Plugin</name>
-    <version>3.2.0.0</version>
-    <description>Provides support for running tests with NCover code coverage.</description>
-	<icon>plugin://Gallio.NCoverIntegration/Resources/ncover.ico</icon>
-  </traits>
-
-  <dependencies>
-    <dependency pluginId="Gallio" />
-  </dependencies>
-
-  <files>
-    <file path="Gallio.NCoverIntegration.plugin" />
-    <file path="Gallio.NCoverIntegration.dll" />
-
-    <file path="libs\NCover Readme.txt"/>
-
-    <file path="libs\NCover\Coverage.xsl" />
-    <file path="libs\NCover\CoverLib.dll" />
-    <file path="libs\NCover\Microsoft.VC80.CRT.manifest" />
-    <file path="libs\NCover\MSVCP80.dll" />
-    <file path="libs\NCover\MSVCR80.dll" />
-    <file path="libs\NCover\NCover.Console.exe" />
-    <file path="libs\NCover\NCover.Console.exe.config" />
-    <file path="libs\NCover\NCover.Framework.dll" />
-    <file path="libs\NCover\NCoverFAQ.html" />
-
-    <file path="libs\NCoverExplorer Readme.txt"/>
-
-    <file path="libs\NCoverExplorer\CommandBars.dll"/>
-    <file path="libs\NCoverExplorer\ConsoleConfig.xsd"/>
-    <file path="libs\NCoverExplorer\ConsoleExample.config"/>
-    <file path="libs\NCoverExplorer\CoverageReport.xsl"/>
-    <file path="libs\NCoverExplorer\ICSharpCode.TextEditor.dll"/>
-    <file path="libs\NCoverExplorer\license.txt"/>
-    <file path="libs\NCoverExplorer\NCoverExplorer.Console.exe"/>
-    <file path="libs\NCoverExplorer\NCoverExplorer.Core.dll"/>
-    <file path="libs\NCoverExplorer\NCoverExplorer.exe"/>
-    <file path="libs\NCoverExplorer\NCoverExplorer.exe.config"/>
-    <file path="libs\NCoverExplorer\NCoverExplorer.NCoverRunner.dll"/>
-    <file path="libs\NCoverExplorer\NCoverExplorerFAQ.html"/>
-    <file path="libs\NCoverExplorer\NCoverExplorerReleaseNotes.html"/>
-	
-	<file path="Resources\ncover.ico" />
-  </files>
-
-  <assemblies>
-    <assembly fullName="Gallio.NCoverIntegration, Version=3.2.0.0, Culture=neutral, PublicKeyToken=null"
-              codeBase="Gallio.NCoverIntegration.dll"
-              qualifyPartialName="true" />
-  </assemblies>
-
-  <components>
-
-    <!-- v1.5.8 -->
-
-    <component componentId="NCoverIntegration.NCoverTestRunnerFactory.v1.5.8"
-               serviceId="Gallio.TestRunnerFactory"
-               componentType="Gallio.Runner.DefaultTestRunnerFactory, Gallio">
-      <parameters>
-        <testIsolationProvider>${NCoverIntegration.NCoverTestIsolationProvider.v1.5.8}</testIsolationProvider>
-      </parameters>
-      <traits>
-        <name>NCover</name>
-        <description>
-          Runs tests in an external process with NCover v1.5.8.  NCover v1.5.8 is included and does not need to be installed.
-
-          Supported test runner properties:
-          - NCoverArguments: Specifies additional command-line arguments for NCover.  eg. "//eas Gallio"
-          - NCoverCoverageFile: Specifies the path of the coverage file to write.  The default is 'Coverage.xml' in the current working directory.
-        </description>
-      </traits>
-    </component>
-
-    <component componentId="NCoverIntegration.NCoverTestIsolationProvider.v1.5.8"
-               serviceId="Gallio.TestIsolationProvider"
-               componentType="Gallio.NCoverIntegration.NCoverTestIsolationProvider, Gallio.NCoverIntegration">
-      <parameters>
-        <version>V1</version>
-      </parameters>
-    </component>
-
-    <!-- v2 -->
-
-    <component componentId="NCoverIntegration.NCoverTestRunnerFactory.v2"
-               serviceId="Gallio.TestRunnerFactory"
-               componentType="Gallio.Runner.DefaultTestRunnerFactory, Gallio">
-      <parameters>
-        <testIsolationProvider>${NCoverIntegration.NCoverTestIsolationProvider.v2}</testIsolationProvider>
-      </parameters>
-      <traits>
-        <name>NCover2</name>
-        <description>
-          Runs tests in an external process with NCover v2.  NCover v2 must be installed separately.
-
-          Supported test runner properties:
-          - NCoverArguments: Specifies additional command-line arguments for NCover.  eg. "//eas Gallio"
-          - NCoverCoverageFile: Specifies the path of the coverage file to write.  The default is 'Coverage.xml'.
-        </description>
-      </traits>
-    </component>
-
-    <component componentId="NCoverIntegration.NCoverTestIsolationProvider.v2"
-               serviceId="Gallio.TestIsolationProvider"
-               componentType="Gallio.NCoverIntegration.NCoverTestIsolationProvider, Gallio.NCoverIntegration">
-      <parameters>
-        <version>V2</version>
-      </parameters>
-    </component>
-
-    <!-- v3 -->
-
-    <component componentId="NCoverIntegration.NCoverTestRunnerFactory.v3"
-               serviceId="Gallio.TestRunnerFactory"
-               componentType="Gallio.Runner.DefaultTestRunnerFactory, Gallio">
-      <parameters>
-        <testIsolationProvider>${NCoverIntegration.NCoverTestIsolationProvider.v3}</testIsolationProvider>
-      </parameters>
-      <traits>
-        <name>NCover3</name>
-        <description>
-          Runs tests in an external process with NCover v3.  NCover v3 must be installed separately.
-
-          Supported test runner properties:
-          - NCoverArguments: Specifies additional command-line arguments for NCover.  eg. "//eas Gallio"
-          - NCoverCoverageFile: Specifies the path of the coverage file to write.  The default is 'Coverage.xml'.
-        </description>
-      </traits>
-    </component>
-
-    <component componentId="NCoverIntegration.NCoverTestIsolationProvider.v3"
-               serviceId="Gallio.TestIsolationProvider"
-               componentType="Gallio.NCoverIntegration.NCoverTestIsolationProvider, Gallio.NCoverIntegration">
-      <parameters>
-        <version>V3</version>
-      </parameters>
-    </component>
-  </components>
-</plugin>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/NCover/Resources/ncover.ico
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/NCover/Resources/ncover.ico b/lib/Gallio.3.2.750/tools/NCover/Resources/ncover.ico
deleted file mode 100644
index 4825382..0000000
Binary files a/lib/Gallio.3.2.750/tools/NCover/Resources/ncover.ico and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/NCover3.lic
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/NCover3.lic b/lib/Gallio.3.2.750/tools/NCover3.lic
deleted file mode 100644
index e69de29..0000000

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/NHamcrest.dll
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/NHamcrest.dll b/lib/Gallio.3.2.750/tools/NHamcrest.dll
deleted file mode 100644
index f6f4d02..0000000
Binary files a/lib/Gallio.3.2.750/tools/NHamcrest.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/NHamcrest.pdb
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/NHamcrest.pdb b/lib/Gallio.3.2.750/tools/NHamcrest.pdb
deleted file mode 100644
index c37e673..0000000
Binary files a/lib/Gallio.3.2.750/tools/NHamcrest.pdb and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/NUnit/Latest/Gallio.NUnitAdapterLatest.dll
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/NUnit/Latest/Gallio.NUnitAdapterLatest.dll b/lib/Gallio.3.2.750/tools/NUnit/Latest/Gallio.NUnitAdapterLatest.dll
deleted file mode 100644
index 81e7567..0000000
Binary files a/lib/Gallio.3.2.750/tools/NUnit/Latest/Gallio.NUnitAdapterLatest.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/NUnit/Latest/Gallio.NUnitAdapterLatest.plugin
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/NUnit/Latest/Gallio.NUnitAdapterLatest.plugin b/lib/Gallio.3.2.750/tools/NUnit/Latest/Gallio.NUnitAdapterLatest.plugin
deleted file mode 100644
index bd3db1a..0000000
--- a/lib/Gallio.3.2.750/tools/NUnit/Latest/Gallio.NUnitAdapterLatest.plugin
+++ /dev/null
@@ -1,85 +0,0 @@
-<?xml version="1.0" encoding="utf-8" ?>
-<plugin pluginId="Gallio.NUnitAdapterLatest"
-        recommendedInstallationPath="NUnit\Latest"
-        xmlns="http://www.gallio.org/">
-  <traits>
-    <name>NUnit v2.5.4+ Adapter Plugin</name>
-    <version>3.2.0.0</version>
-    <description>Provides support for running NUnit v2.5.4+ tests.</description>
-    <icon>plugin://Gallio.NUnitAdapterLatest/Resources/NUnit.ico</icon>
-  </traits>
-
-  <dependencies>
-    <dependency pluginId="Gallio" />
-  </dependencies>
-
-  <files>
-    <file path="Gallio.NUnitAdapterLatest.plugin" />
-    <file path="Gallio.NUnitAdapterLatest.dll" />
-    <file path="license.txt" />
-    <file path="Readme.txt" />
-    <file path="nunit.core.dll" />
-    <file path="nunit.core.interfaces.dll" />
-    <file path="nunit.framework.dll" />
-    <file path="nunit.framework.dll.tdnet" />
-    <file path="nunit.framework.xml" />
-    <file path="nunit.mocks.dll" />
-    <file path="nunit.util.dll" />
-    <file path="addins\NUnit Addins Readme.txt" />
-    <file path="Resources\NUnit.ico" />
-  </files>
-
-  <assemblies>
-    <assembly fullName="Gallio.NUnitAdapterLatest, Version=3.2.0.0, Culture=neutral, PublicKeyToken=null"
-              codeBase="Gallio.NUnitAdapterLatest.dll"
-              qualifyPartialName="true" />
-
-    <assembly fullName="nunit.core, Version=2.5.9.10348, Culture=neutral, PublicKeyToken=96d09a1eb7f44a77"
-              codeBase="nunit.core.dll">
-      <bindingRedirects>
-        <bindingRedirect oldVersion="2.5.4.0-2.5.65535.65535" />
-      </bindingRedirects>
-    </assembly>
-
-    <assembly fullName="nunit.core.interfaces, Version=2.5.9.10348, Culture=neutral, PublicKeyToken=96d09a1eb7f44a77"
-              codeBase="nunit.core.interfaces.dll">
-      <bindingRedirects>
-        <bindingRedirect oldVersion="2.5.4.0-2.5.65535.65535" />
-      </bindingRedirects>
-    </assembly>
-
-    <assembly fullName="nunit.util, Version=2.5.9.10348, Culture=neutral, PublicKeyToken=96d09a1eb7f44a77"
-              codeBase="nunit.util.dll">
-      <bindingRedirects>
-        <bindingRedirect oldVersion="2.5.4.0-2.5.65535.65535" />
-      </bindingRedirects>
-    </assembly>
-  </assemblies>
-
-  <probingPaths>
-    <probingPath>Latest</probingPath>
-  </probingPaths>
-
-  <components>
-    <component componentId="NUnitAdapterLatest.TestFramework"
-               serviceId="Gallio.TestFramework"
-               componentType="Gallio.NUnitAdapter.Model.NUnitTestFramework, Gallio.NUnitAdapterLatest">
-      <traits>
-        <name>NUnit v2.5.4+</name>
-        <frameworkAssemblies>nunit.framework, Version=2.5.4.0-2.5.65535.65535</frameworkAssemblies>
-        <version>2.5.9.10348</version>
-        <fileTypes>Assembly</fileTypes>
-        <icon>plugin://Gallio.NUnitAdapterLatest/Resources/NUnit.ico</icon>
-      </traits>
-    </component>
-
-    <component componentId="NUnitAdapterLatest.TestKinds.NUnitTestAssembly"
-               serviceId="Gallio.TestKind">
-      <traits>
-        <name>NUnit v2.5.4+ Assembly</name>
-        <description>NUnit v2.5.4+ Test Assembly</description>
-        <icon>plugin://Gallio.NUnitAdapterLatest/Resources/NUnit.ico</icon>
-      </traits>
-    </component>
-  </components>
-</plugin>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/NUnit/Latest/Readme.txt
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/NUnit/Latest/Readme.txt b/lib/Gallio.3.2.750/tools/NUnit/Latest/Readme.txt
deleted file mode 100644
index 4396cc3..0000000
--- a/lib/Gallio.3.2.750/tools/NUnit/Latest/Readme.txt
+++ /dev/null
@@ -1,12 +0,0 @@
-NUnit Adapter Plugin
-====================
-
-This plugin uses the NUnit test runner to adapt NUnit tests so that
-they can run within Gallio and be manipulated by Gallio-based tools.
-
-The plugin assembly is deliberately NOT signed using a strong name.
-You can replace the underlying test framework with newer versions as
-long as they are binary compatible with the originally distributed version.
-
-However, it may be necessary to update the version numbers that
-appear in the plugin files.
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/NUnit/Latest/Resources/NUnit.ico
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/NUnit/Latest/Resources/NUnit.ico b/lib/Gallio.3.2.750/tools/NUnit/Latest/Resources/NUnit.ico
deleted file mode 100644
index 13c4ff9..0000000
Binary files a/lib/Gallio.3.2.750/tools/NUnit/Latest/Resources/NUnit.ico and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/NUnit/Latest/addins/NUnit Addins Readme.txt
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/NUnit/Latest/addins/NUnit Addins Readme.txt b/lib/Gallio.3.2.750/tools/NUnit/Latest/addins/NUnit Addins Readme.txt
deleted file mode 100644
index 63e9a2b..0000000
--- a/lib/Gallio.3.2.750/tools/NUnit/Latest/addins/NUnit Addins Readme.txt	
+++ /dev/null
@@ -1 +0,0 @@
-Put your Addins in this folder so that Gallio can find them.
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/NUnit/Latest/license.txt
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/NUnit/Latest/license.txt b/lib/Gallio.3.2.750/tools/NUnit/Latest/license.txt
deleted file mode 100644
index ab91df4..0000000
--- a/lib/Gallio.3.2.750/tools/NUnit/Latest/license.txt
+++ /dev/null
@@ -1,15 +0,0 @@
-Copyright � 2002-2008 Charlie Poole
-Copyright � 2002-2004 James W. Newkirk, Michael C. Two, Alexei A. Vorontsov
-Copyright � 2000-2002 Philip A. Craig
-
-This software is provided 'as-is', without any express or implied warranty. In no event will the authors be held liable for any damages arising from the use of this software.
-
-Permission is granted to anyone to use this software for any purpose, including commercial applications, and to alter it and redistribute it freely, subject to the following restrictions:
-
-1. The origin of this software must not be misrepresented; you must not claim that you wrote the original software. If you use this software in a product, an acknowledgment (see the following) in the product documentation is required.
-
-Portions Copyright � 2002-2008 Charlie Poole or Copyright � 2002-2004 James W. Newkirk, Michael C. Two, Alexei A. Vorontsov or Copyright � 2000-2002 Philip A. Craig
-
-2. Altered source versions must be plainly marked as such, and must not be misrepresented as being the original software.
-
-3. This notice may not be removed or altered from any source distribution.

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/NUnit/Latest/nunit.core.dll
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/NUnit/Latest/nunit.core.dll b/lib/Gallio.3.2.750/tools/NUnit/Latest/nunit.core.dll
deleted file mode 100644
index 5e9fcc0..0000000
Binary files a/lib/Gallio.3.2.750/tools/NUnit/Latest/nunit.core.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/NUnit/Latest/nunit.core.interfaces.dll
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/NUnit/Latest/nunit.core.interfaces.dll b/lib/Gallio.3.2.750/tools/NUnit/Latest/nunit.core.interfaces.dll
deleted file mode 100644
index 3152dd2..0000000
Binary files a/lib/Gallio.3.2.750/tools/NUnit/Latest/nunit.core.interfaces.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/NUnit/Latest/nunit.framework.dll
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/NUnit/Latest/nunit.framework.dll b/lib/Gallio.3.2.750/tools/NUnit/Latest/nunit.framework.dll
deleted file mode 100644
index 875e098..0000000
Binary files a/lib/Gallio.3.2.750/tools/NUnit/Latest/nunit.framework.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/NUnit/Latest/nunit.framework.dll.tdnet
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/NUnit/Latest/nunit.framework.dll.tdnet b/lib/Gallio.3.2.750/tools/NUnit/Latest/nunit.framework.dll.tdnet
deleted file mode 100644
index 379488e..0000000
--- a/lib/Gallio.3.2.750/tools/NUnit/Latest/nunit.framework.dll.tdnet
+++ /dev/null
@@ -1,6 +0,0 @@
-<TestRunner>
-	<FriendlyName>NUnit v{0}.{1}.{2}</FriendlyName>
-	<AssemblyPath>..\..\TDNet\Gallio.TDNetRunner.dll</AssemblyPath>
-	<TypeName>Gallio.TDNetRunner.GallioResidentTestRunner</TypeName>
-	<TestRunnerType>Resident</TestRunnerType>
-</TestRunner>


[47/51] [abbrv] [partial] Cleaning up and getting ready to development towards v4.8

Posted by sy...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/scripts/Snowball/project.targets
----------------------------------------------------------------------
diff --git a/build/scripts/Snowball/project.targets b/build/scripts/Snowball/project.targets
deleted file mode 100644
index f13e277..0000000
--- a/build/scripts/Snowball/project.targets
+++ /dev/null
@@ -1,66 +0,0 @@
-<?xml version="1.0" encoding="UTF-8" standalone="no" ?>
-<!--
- 
- Licensed to the Apache Software Foundation (ASF) under one or more
- contributor license agreements.  See the NOTICE file distributed with
- this work for additional information regarding copyright ownership.
- The ASF licenses this file to You under the Apache License, Version 2.0
- (the "License"); you may not use this file except in compliance with
- the License.  You may obtain a copy of the License at
-  
- http://www.apache.org/licenses/LICENSE-2.0
-  
- Unless required by applicable law or agreed to in writing, software
- distributed under the License is distributed on an "AS IS" BASIS,
- WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- See the License for the specific language governing permissions and
- limitations under the License.
- 
--->
-<Project xmlns="http://schemas.microsoft.com/developer/msbuild/2003" ToolsVersion="4.0">
-	<!-- 
-		Core Projects Are:
-			Lucene.Net, 
-			Lucene.Net.Test, 
-	-->
-	<PropertyGroup>
-		<SnowballFolder>$(BinFolder)\contrib\Snowball\$(Configuration)</SnowballFolder>
-	</PropertyGroup>
-	<PropertyGroup  Condition="'$(Area)' == 'snowball'">
-		<LocalBinFolder>$(BinFolder)\contrib\Snowball\$(Configuration)</LocalBinFolder>
-		<ArtifactsFolder>$(BuildFolder)\artifacts\Snowball</ArtifactsFolder>
-	</PropertyGroup>
-		
-	<Target Name="_snowball_build">
-		<ItemGroup>
-			<SnowballProjectFiles Include="$(SourceFolder)\Contrib\Snowball\*.csproj" />
-			<SnowballProjectFiles Include="$(TestFolder)\Contrib\Snowball\*.csproj" />
-		</ItemGroup>
-
-		<MSBuild Projects="@(SnowballProjectFiles)" Properties="Configuration=$(Configuration);ExternalConstants=$(ExternalConstants)" />
-		<!-- Add "35" to the end of configuration to build .NET35 projects -->
-		<MSBuild Projects="@(SnowballProjectFiles)" Properties="Configuration=$(Configuration)35;ExternalConstants=$(ExternalConstants)" />
-	</Target>
-
-	<Target Name="_snowball_properties">
-		<ItemGroup>
-			<!-- Binaries To Copy in case we which to store all build items -->
-			<BuildItems Include="$(SnowballFolder)\**\*.*" /> 
-			
-			<!-- Assemblies To Test -->
-			<TestFiles Include="$(SnowballFolder)\**\Lucene.Net.Contrib.Snowball.Test.dll" />
-			
-			<!-- Files To Release -->
-			<ReleaseFiles Include="$(SnowballFolder)\**\Lucene.Net.Contrib.Snowball.dll" />
-			<ReleaseFiles Include="$(SnowballFolder)\**\Lucene.Net.Contrib.Snowball.XML" />
-		
-			<!-- Files to Analysis -->
-			<AnalysisFiles Include="$(SnowballFolder)\**\Lucene.Net.Contrib.Snowball.dll" />	
-		</ItemGroup>
-	</Target>
-
-	<Target Name="BuildSnowball">
-		<CallTarget Targets="_snowball_build" />
-		<CallTarget Targets="_snowball_properties" />
-	</Target>
-</Project>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/scripts/Spatial.NTS/Lucene.Net.Spatial.NTS.nuspec
----------------------------------------------------------------------
diff --git a/build/scripts/Spatial.NTS/Lucene.Net.Spatial.NTS.nuspec b/build/scripts/Spatial.NTS/Lucene.Net.Spatial.NTS.nuspec
deleted file mode 100644
index 21a3ee9..0000000
--- a/build/scripts/Spatial.NTS/Lucene.Net.Spatial.NTS.nuspec
+++ /dev/null
@@ -1,43 +0,0 @@
-<?xml version="1.0"?>
-<!--
- 
- Licensed to the Apache Software Foundation (ASF) under one or more
- contributor license agreements.  See the NOTICE file distributed with
- this work for additional information regarding copyright ownership.
- The ASF licenses this file to You under the Apache License, Version 2.0
- (the "License"); you may not use this file except in compliance with
- the License.  You may obtain a copy of the License at
-  
- http://www.apache.org/licenses/LICENSE-2.0
-  
- Unless required by applicable law or agreed to in writing, software
- distributed under the License is distributed on an "AS IS" BASIS,
- WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- See the License for the specific language governing permissions and
- limitations under the License.
- 
--->
-<package xmlns="http://schemas.microsoft.com/packaging/2010/07/nuspec.xsd">
-  <metadata>
-    <id>Lucene.Net.Spatial.NTS</id>
-    <version>$version$</version>
-    <title>Lucene.Net Spatial Contrib with NTS support</title>
-    <authors>Lucene.Net Community</authors>
-    <owners>The Apache Software Foundation</owners>
-    <iconUrl>http://incubator.apache.org/lucene.net/media/lucene-net-ico-128x128.png</iconUrl>
-    <licenseUrl>http://www.apache.org/licenses/LICENSE-2.0.html</licenseUrl>
-    <projectUrl>http://lucenenet.apache.org/</projectUrl>
-    <requireLicenseAcceptance>false</requireLicenseAcceptance>
-    <description>Adds support for advanced geo-spatial searches to Lucene.Net 3.0.3, including polygon searches and other WKT shapes. Bundled with NetTopologySuite for performing advanced geometry operations.</description>
-    <summary>Lucene.Net is a port of the Lucene search engine library, written in C# and targeted at .NET runtime users.</summary>
-    <tags>lucene.net core search information retrieval lucene apache spatial spatial4n spatial4j nts nettopologysuite WKT polygon</tags>
-     <dependencies>
-      <dependency id="Lucene.Net" version="3.0.3" />
-      <dependency id="Spatial4n.Core.NTS" version="0.3" />
-     </dependencies>  
-  </metadata>
-  <files>
-        <file src="..\..\bin\contrib\Spatial.NTS\Release\**\Lucene.Net.Contrib.Spatial.NTS.dll" target="lib" />
-        <file src="..\..\bin\contrib\Spatial.NTS\Release\**\Lucene.Net.Contrib.Spatial.NTS.XML" target="lib" />
-  </files>
-</package>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/scripts/Spatial.NTS/document.targets
----------------------------------------------------------------------
diff --git a/build/scripts/Spatial.NTS/document.targets b/build/scripts/Spatial.NTS/document.targets
deleted file mode 100644
index 510591d..0000000
--- a/build/scripts/Spatial.NTS/document.targets
+++ /dev/null
@@ -1,31 +0,0 @@
-<?xml version="1.0" encoding="UTF-8" standalone="no" ?>
-<!--
- 
- Licensed to the Apache Software Foundation (ASF) under one or more
- contributor license agreements.  See the NOTICE file distributed with
- this work for additional information regarding copyright ownership.
- The ASF licenses this file to You under the Apache License, Version 2.0
- (the "License"); you may not use this file except in compliance with
- the License.  You may obtain a copy of the License at
-  
- http://www.apache.org/licenses/LICENSE-2.0
-  
- Unless required by applicable law or agreed to in writing, software
- distributed under the License is distributed on an "AS IS" BASIS,
- WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- See the License for the specific language governing permissions and
- limitations under the License.
- 
--->
-<Project xmlns="http://schemas.microsoft.com/developer/msbuild/2003" ToolsVersion="4.0">
-	<PropertyGroup>
-		 <DocumentationSources>
-      		<DocumentationSource sourceFile="..\bin\contrib\Spatial.NTS\Release\NET40\Lucene.Net.Contrib.Spatial.dll" />
-      		<DocumentationSource sourceFile="..\bin\contrib\Spatial.NTS\Release\NET40\Lucene.Net.Contrib.Spatial.XML" />
-    	</DocumentationSources>
-    	<HtmlHelpName>Lucene.Net.Contrib.Spatial.NTS</HtmlHelpName>
-    	<HelpTitle>Spatial.NTS Class Library</HelpTitle>
-    	<WorkingPath>..\artifacts\Spatial.NTS\working\</WorkingPath>
-	    <OutputPath>..\artifacts\Spatial.NTS\docs\</OutputPath>
-	</PropertyGroup>
-</Project>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/scripts/Spatial.NTS/project.targets
----------------------------------------------------------------------
diff --git a/build/scripts/Spatial.NTS/project.targets b/build/scripts/Spatial.NTS/project.targets
deleted file mode 100644
index b73ba78..0000000
--- a/build/scripts/Spatial.NTS/project.targets
+++ /dev/null
@@ -1,66 +0,0 @@
-<?xml version="1.0" encoding="UTF-8" standalone="no" ?>
-<!--
- 
- Licensed to the Apache Software Foundation (ASF) under one or more
- contributor license agreements.  See the NOTICE file distributed with
- this work for additional information regarding copyright ownership.
- The ASF licenses this file to You under the Apache License, Version 2.0
- (the "License"); you may not use this file except in compliance with
- the License.  You may obtain a copy of the License at
-  
- http://www.apache.org/licenses/LICENSE-2.0
-  
- Unless required by applicable law or agreed to in writing, software
- distributed under the License is distributed on an "AS IS" BASIS,
- WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- See the License for the specific language governing permissions and
- limitations under the License.
- 
--->
-<Project xmlns="http://schemas.microsoft.com/developer/msbuild/2003" ToolsVersion="4.0">
-	<!-- 
-		Core Projects Are:
-			Lucene.Net, 
-			Lucene.Net.Test, 
-	-->
-	<PropertyGroup>
-    <SpatialNTSFolder>$(BinFolder)\contrib\Spatial.NTS\$(Configuration)</SpatialNTSFolder>
-	</PropertyGroup>
-	<PropertyGroup  Condition="'$(Area)' == 'spatialnts'">
-		<LocalBinFolder>$(BinFolder)\contrib\Spatial.NTS\$(Configuration)</LocalBinFolder>
-		<ArtifactsFolder>$(BuildFolder)\artifacts\Spatial.NTS</ArtifactsFolder>
-	</PropertyGroup>
-
-	<Target Name="_spatial_nts_build">
-		<ItemGroup>
-			<SpatialProjectFiles Include="$(SourceFolder)\Contrib\Spatial\*.csproj" />
-			<SpatialProjectFiles Include="$(TestFolder)\Contrib\Spatial\*.csproj" />
-		</ItemGroup>
-
-		<MSBuild Projects="@(SpatialProjectFiles)" Properties="Configuration=$(Configuration);ExternalConstants=$(ExternalConstants)" />
-		<!-- Add "35" to the end of configuration to build .NET35 projects -->
-		<MSBuild Projects="@(SpatialProjectFiles)" Properties="Configuration=$(Configuration)35;ExternalConstants=$(ExternalConstants)" />
-	</Target>
-
-  <Target Name="_spatial_nts_properties">
-    <ItemGroup>
-      <!-- Binaries To Copy in case we which to store all build items -->
-      <BuildItems Include="$(SpatialNTSFolder)\**\*.*" />
-
-      <!-- Assemblies To Test -->
-      <TestFiles Include="$(SpatialNTSFolder)\**\Lucene.Net.Contrib.Spatial.NTS.Test.dll" />
-
-      <!-- Files To Release -->
-      <ReleaseFiles Include="$(SpatialNTSFolder)\**\Lucene.Net.Contrib.Spatial.NTS.dll" />
-      <ReleaseFiles Include="$(SpatialNTSFolder)\**\Lucene.Net.Contrib.Spatial.NTS.XML" />
-
-      <!-- Files to Analysis -->
-      <AnalysisFiles Include="$(SpatialNTSFolder)\**\Lucene.Net.Contrib.Spatial.NTS.dll" />
-    </ItemGroup>
-  </Target>
-
-  <Target Name="BuildSpatialNTS">
-    <CallTarget Targets="_spatial_nts_build" />
-    <CallTarget Targets="_spatial_nts_properties" />
-  </Target>
-</Project>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/scripts/Spatial/Lucene.Net.Spatial.nuspec
----------------------------------------------------------------------
diff --git a/build/scripts/Spatial/Lucene.Net.Spatial.nuspec b/build/scripts/Spatial/Lucene.Net.Spatial.nuspec
deleted file mode 100644
index bc6d4f0..0000000
--- a/build/scripts/Spatial/Lucene.Net.Spatial.nuspec
+++ /dev/null
@@ -1,43 +0,0 @@
-<?xml version="1.0"?>
-<!--
- 
- Licensed to the Apache Software Foundation (ASF) under one or more
- contributor license agreements.  See the NOTICE file distributed with
- this work for additional information regarding copyright ownership.
- The ASF licenses this file to You under the Apache License, Version 2.0
- (the "License"); you may not use this file except in compliance with
- the License.  You may obtain a copy of the License at
-  
- http://www.apache.org/licenses/LICENSE-2.0
-  
- Unless required by applicable law or agreed to in writing, software
- distributed under the License is distributed on an "AS IS" BASIS,
- WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- See the License for the specific language governing permissions and
- limitations under the License.
- 
--->
-<package xmlns="http://schemas.microsoft.com/packaging/2010/07/nuspec.xsd">
-  <metadata>
-    <id>Lucene.Net.Spatial</id>
-    <version>$version$</version>
-    <title>Lucene.Net Spatial Contrib</title>
-    <authors>Lucene.Net Community</authors>
-    <owners>The Apache Software Foundation</owners>
-    <iconUrl>http://incubator.apache.org/lucene.net/media/lucene-net-ico-128x128.png</iconUrl>
-    <licenseUrl>http://www.apache.org/licenses/LICENSE-2.0.html</licenseUrl>
-    <projectUrl>http://lucenenet.apache.org/</projectUrl>
-    <requireLicenseAcceptance>false</requireLicenseAcceptance>
-    <description>Adds support for geo-spatial searches to Lucene.Net 3.0.3</description>
-    <summary>Lucene.Net is a port of the Lucene search engine library, written in C# and targeted at .NET runtime users.</summary>
-    <tags>lucene.net core search information retrieval lucene apache spatial spatial4n spatial4j</tags>
-     <dependencies>
-      <dependency id="Lucene.Net" version="3.0.3" />
-      <dependency id="Spatial4n.Core" version="0.3" />
-     </dependencies>
-  </metadata>
-  <files>
-        <file src="..\..\bin\contrib\Spatial\Release\**\Lucene.Net.Contrib.Spatial.dll" target="lib" />
-        <file src="..\..\bin\contrib\Spatial\Release\**\Lucene.Net.Contrib.Spatial.XML" target="lib" />
-  </files>
-</package>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/scripts/Spatial/document.targets
----------------------------------------------------------------------
diff --git a/build/scripts/Spatial/document.targets b/build/scripts/Spatial/document.targets
deleted file mode 100644
index da98b93..0000000
--- a/build/scripts/Spatial/document.targets
+++ /dev/null
@@ -1,31 +0,0 @@
-<?xml version="1.0" encoding="UTF-8" standalone="no" ?>
-<!--
- 
- Licensed to the Apache Software Foundation (ASF) under one or more
- contributor license agreements.  See the NOTICE file distributed with
- this work for additional information regarding copyright ownership.
- The ASF licenses this file to You under the Apache License, Version 2.0
- (the "License"); you may not use this file except in compliance with
- the License.  You may obtain a copy of the License at
-  
- http://www.apache.org/licenses/LICENSE-2.0
-  
- Unless required by applicable law or agreed to in writing, software
- distributed under the License is distributed on an "AS IS" BASIS,
- WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- See the License for the specific language governing permissions and
- limitations under the License.
- 
--->
-<Project xmlns="http://schemas.microsoft.com/developer/msbuild/2003" ToolsVersion="4.0">
-	<PropertyGroup>
-		 <DocumentationSources>
-      		<DocumentationSource sourceFile="..\bin\contrib\Spatial\Release\NET40\Lucene.Net.Contrib.Spatial.dll" />
-      		<DocumentationSource sourceFile="..\bin\contrib\Spatial\Release\NET40\Lucene.Net.Contrib.Spatial.XML" />
-    	</DocumentationSources>
-    	<HtmlHelpName>Lucene.Net.Contrib.Spatial</HtmlHelpName>
-    	<HelpTitle>Spatial Class Library</HelpTitle>
-    	<WorkingPath>..\artifacts\Spatial\working\</WorkingPath>
-	    <OutputPath>..\artifacts\Spatial\docs\</OutputPath>
-	</PropertyGroup>
-</Project>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/scripts/Spatial/project.targets
----------------------------------------------------------------------
diff --git a/build/scripts/Spatial/project.targets b/build/scripts/Spatial/project.targets
deleted file mode 100644
index 63b40b3..0000000
--- a/build/scripts/Spatial/project.targets
+++ /dev/null
@@ -1,66 +0,0 @@
-<?xml version="1.0" encoding="UTF-8" standalone="no" ?>
-<!--
- 
- Licensed to the Apache Software Foundation (ASF) under one or more
- contributor license agreements.  See the NOTICE file distributed with
- this work for additional information regarding copyright ownership.
- The ASF licenses this file to You under the Apache License, Version 2.0
- (the "License"); you may not use this file except in compliance with
- the License.  You may obtain a copy of the License at
-  
- http://www.apache.org/licenses/LICENSE-2.0
-  
- Unless required by applicable law or agreed to in writing, software
- distributed under the License is distributed on an "AS IS" BASIS,
- WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- See the License for the specific language governing permissions and
- limitations under the License.
- 
--->
-<Project xmlns="http://schemas.microsoft.com/developer/msbuild/2003" ToolsVersion="4.0">
-	<!-- 
-		Core Projects Are:
-			Lucene.Net, 
-			Lucene.Net.Test, 
-	-->
-	<PropertyGroup>
-		<SpatialFolder>$(BinFolder)\contrib\Spatial\$(Configuration)</SpatialFolder>
-	</PropertyGroup>
-	<PropertyGroup  Condition="'$(Area)' == 'spatial'">
-		<LocalBinFolder>$(BinFolder)\contrib\Spatial\$(Configuration)</LocalBinFolder>
-		<ArtifactsFolder>$(BuildFolder)\artifacts\Spatial</ArtifactsFolder>
-	</PropertyGroup>
-
-	<Target Name="_spatial_build">
-		<ItemGroup>
-			<SpatialProjectFiles Include="$(SourceFolder)\Contrib\Spatial\*.csproj" />
-			<SpatialProjectFiles Include="$(TestFolder)\Contrib\Spatial\*.csproj" />
-		</ItemGroup>
-
-		<MSBuild Projects="@(SpatialProjectFiles)" Properties="Configuration=$(Configuration);ExternalConstants=$(ExternalConstants)" />
-		<!-- Add "35" to the end of configuration to build .NET35 projects -->
-		<MSBuild Projects="@(SpatialProjectFiles)" Properties="Configuration=$(Configuration)35;ExternalConstants=$(ExternalConstants)" />
-	</Target>
-
-	<Target Name="_spatial_properties">
-		<ItemGroup>
-			<!-- Binaries To Copy in case we which to store all build items -->
-			<BuildItems Include="$(SpatialFolder)\**\*.*" /> 
-			
-			<!-- Assemblies To Test -->
-			<TestFiles Include="$(SpatialFolder)\**\Lucene.Net.Contrib.Spatial.Test.dll" />
-			
-			<!-- Files To Release -->
-			<ReleaseFiles Include="$(SpatialFolder)\**\Lucene.Net.Contrib.Spatial.dll" />
-			<ReleaseFiles Include="$(SpatialFolder)\**\Lucene.Net.Contrib.Spatial.XML" />
-		
-			<!-- Files to Analysis -->
-			<AnalysisFiles Include="$(SpatialFolder)\**\Lucene.Net.Contrib.Spatial.dll" />	
-		</ItemGroup>
-	</Target>
-
-	<Target Name="BuildSpatial">
-		<CallTarget Targets="_spatial_build" />
-		<CallTarget Targets="_spatial_properties" />
-	</Target>
-</Project>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/scripts/SpellChecker/document.targets
----------------------------------------------------------------------
diff --git a/build/scripts/SpellChecker/document.targets b/build/scripts/SpellChecker/document.targets
deleted file mode 100644
index 1dff4fd..0000000
--- a/build/scripts/SpellChecker/document.targets
+++ /dev/null
@@ -1,31 +0,0 @@
-<?xml version="1.0" encoding="UTF-8" standalone="no" ?>
-<!--
- 
- Licensed to the Apache Software Foundation (ASF) under one or more
- contributor license agreements.  See the NOTICE file distributed with
- this work for additional information regarding copyright ownership.
- The ASF licenses this file to You under the Apache License, Version 2.0
- (the "License"); you may not use this file except in compliance with
- the License.  You may obtain a copy of the License at
-  
- http://www.apache.org/licenses/LICENSE-2.0
-  
- Unless required by applicable law or agreed to in writing, software
- distributed under the License is distributed on an "AS IS" BASIS,
- WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- See the License for the specific language governing permissions and
- limitations under the License.
- 
--->
-<Project xmlns="http://schemas.microsoft.com/developer/msbuild/2003" ToolsVersion="4.0">
-	<PropertyGroup>
-		 <DocumentationSources>
-      		<DocumentationSource sourceFile="..\bin\contrib\SpellChecker\Release\NET40\Lucene.Net.Contrib.SpellChecker.dll" />
-      		<DocumentationSource sourceFile="..\bin\contrib\SpellChecker\Release\NET40\Lucene.Net.Contrib.SpellChecker.XML" />
-    	</DocumentationSources>
-    	<HtmlHelpName>Lucene.Net.Contrib.SpellChecker</HtmlHelpName>
-    	<HelpTitle>SpellChecker Class Library</HelpTitle>
-    	<WorkingPath>..\artifacts\SpellChecker\working\</WorkingPath>
-	    <OutputPath>..\artifacts\SpellChecker\docs\</OutputPath>
-	</PropertyGroup>
-</Project>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/scripts/SpellChecker/project.targets
----------------------------------------------------------------------
diff --git a/build/scripts/SpellChecker/project.targets b/build/scripts/SpellChecker/project.targets
deleted file mode 100644
index ebff0d4..0000000
--- a/build/scripts/SpellChecker/project.targets
+++ /dev/null
@@ -1,66 +0,0 @@
-<?xml version="1.0" encoding="UTF-8" standalone="no" ?>
-<!--
- 
- Licensed to the Apache Software Foundation (ASF) under one or more
- contributor license agreements.  See the NOTICE file distributed with
- this work for additional information regarding copyright ownership.
- The ASF licenses this file to You under the Apache License, Version 2.0
- (the "License"); you may not use this file except in compliance with
- the License.  You may obtain a copy of the License at
-  
- http://www.apache.org/licenses/LICENSE-2.0
-  
- Unless required by applicable law or agreed to in writing, software
- distributed under the License is distributed on an "AS IS" BASIS,
- WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- See the License for the specific language governing permissions and
- limitations under the License.
- 
--->
-<Project xmlns="http://schemas.microsoft.com/developer/msbuild/2003" ToolsVersion="4.0">
-	<!-- 
-		Core Projects Are:
-			Lucene.Net, 
-			Lucene.Net.Test, 
-	-->
-	<PropertyGroup>
-		<SpellCheckerFolder>$(BinFolder)\contrib\SpellChecker\$(Configuration)</SpellCheckerFolder>
-	</PropertyGroup>
-	<PropertyGroup  Condition="'$(Area)' == 'spellchecker'">
-		<LocalBinFolder>$(BinFolder)\contrib\SpellChecker\$(Configuration)</LocalBinFolder>
-		<ArtifactsFolder>$(BuildFolder)\artifacts\SpellChecker</ArtifactsFolder>
-	</PropertyGroup>
-		
-	<Target Name="_spellchecker_build">
-		<ItemGroup>
-			<SpellCheckerProjectFiles Include="$(SourceFolder)\Contrib\SpellChecker\*.csproj" />
-			<SpellCheckerProjectFiles Include="$(TestFolder)\Contrib\SpellChecker\*.csproj" />
-		</ItemGroup>
-
-		<MSBuild Projects="@(SpellCheckerProjectFiles)" Properties="Configuration=$(Configuration);ExternalConstants=$(ExternalConstants)" />
-		<!-- Add "35" to the end of configuration to build .NET35 projects -->
-		<MSBuild Projects="@(SpellCheckerProjectFiles)" Properties="Configuration=$(Configuration)35;ExternalConstants=$(ExternalConstants)" />
-	</Target>
-
-	<Target Name="_spellchecker_properties">
-		<ItemGroup>
-			<!-- Binaries To Copy in case we which to store all build items -->
-			<BuildItems Include="$(SpellCheckerFolder)\**\*.*" /> 
-			
-			<!-- Assemblies To Test -->
-			<TestFiles Include="$(SpellCheckerFolder)\**\Lucene.Net.Contrib.SpellChecker.Test.dll" />
-			
-			<!-- Files To Release -->
-			<ReleaseFiles Include="$(SpellCheckerFolder)\**\Lucene.Net.Contrib.SpellChecker.dll" />
-			<ReleaseFiles Include="$(SpellCheckerFolder)\**\Lucene.Net.Contrib.SpellChecker.XML" />
-		
-			<!-- Files to Analysis -->
-			<AnalysisFiles Include="$(SpellCheckerFolder)\**\Lucene.Net.Contrib.SpellChecker.dll" />	
-		</ItemGroup>
-	</Target>
-
-	<Target Name="BuildSpellChecker">
-		<CallTarget Targets="_spellchecker_build" />
-		<CallTarget Targets="_spellchecker_properties" />
-	</Target>
-</Project>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/scripts/build.cmd
----------------------------------------------------------------------
diff --git a/build/scripts/build.cmd b/build/scripts/build.cmd
deleted file mode 100644
index b6010b9..0000000
--- a/build/scripts/build.cmd
+++ /dev/null
@@ -1,25 +0,0 @@
-@echo off
-REM License Block
-GOTO LicenseEnd
- Licensed to the Apache Software Foundation (ASF) under one or more
- contributor license agreements.  See the NOTICE file distributed with
- this work for additional information regarding copyright ownership.
- The ASF licenses this file to You under the Apache License, Version 2.0
- (the "License"); you may not use this file except in compliance with
- the License.  You may obtain a copy of the License at
-  
- http://www.apache.org/licenses/LICENSE-2.0
-  
- Unless required by applicable law or agreed to in writing, software
- distributed under the License is distributed on an "AS IS" BASIS,
- WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- See the License for the specific language governing permissions and
- limitations under the License.
-:LicenseEnd
-
-SET TARGETS=all
-SET AREA=all
-IF [%1] NEQ [] SET TARGETS=%1
-IF [%2] NEQ [] SET AREA=%2
-
-%windir%\Microsoft.NET\Framework\v4.0.30319\MSBuild.exe build.targets /t:%TARGETS% /p:BuildArea=%AREA%  /nologo 
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/scripts/build.sh
----------------------------------------------------------------------
diff --git a/build/scripts/build.sh b/build/scripts/build.sh
deleted file mode 100644
index 6edacfd..0000000
--- a/build/scripts/build.sh
+++ /dev/null
@@ -1,47 +0,0 @@
-#!/bin/bash
-# Licensed to the Apache Software Foundation (ASF) under one or more
-# contributor license agreements.  See the NOTICE file distributed with
-# this work for additional information regarding copyright ownership.
-# The ASF licenses this file to You under the Apache License, Version 2.0
-# (the "License"); you may not use this file except in compliance with
-# the License.  You may obtain a copy of the License at
-#  
-# http://www.apache.org/licenses/LICENSE-2.0
-#  
-# Unless required by applicable law or agreed to in writing, software
-# distributed under the License is distributed on an "AS IS" BASIS,
-# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-# See the License for the specific language governing permissions and
-# limitations under the License.
-
-TARGETS="all"
-BuildArea="all"
-Configuration="debug"
-if [ -n "$1" ] 
-		then 
-			TARGETS=$1
-fi
-if [ "$#" -gt "1" ]
-		then
-			TARGETS=${!#}
-fi
-if [ $# -eq 2 ]
-		then
-			BuildArea="$1"
-fi 
-if [ $# -eq 3 ]
-		then
-			BuildArea="$1"
-			Configuration="$2"
-fi
-
-echo "commands will target projects: $BuildArea"
-echo "commands will target the configuration: $Configuration"
-export $BuildArea
-export $Configuration
-
-ROOT=$(dirname $0)
-export NETFRAMEWORK="mono"
-export TEMP=$ROOT/tmp
-
-MONO_IOMAP=case xbuild $ROOT/build.xml /t:$TARGETS
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/scripts/build.targets
----------------------------------------------------------------------
diff --git a/build/scripts/build.targets b/build/scripts/build.targets
deleted file mode 100644
index c808703..0000000
--- a/build/scripts/build.targets
+++ /dev/null
@@ -1,160 +0,0 @@
-<?xml version="1.0" encoding="UTF-8" standalone="no" ?>
-<!--
- 
- Licensed to the Apache Software Foundation (ASF) under one or more
- contributor license agreements.  See the NOTICE file distributed with
- this work for additional information regarding copyright ownership.
- The ASF licenses this file to You under the Apache License, Version 2.0
- (the "License"); you may not use this file except in compliance with
- the License.  You may obtain a copy of the License at
-  
- http://www.apache.org/licenses/LICENSE-2.0
-  
- Unless required by applicable law or agreed to in writing, software
- distributed under the License is distributed on an "AS IS" BASIS,
- WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- See the License for the specific language governing permissions and
- limitations under the License.
- 
--->
-<Project xmlns="http://schemas.microsoft.com/developer/msbuild/2003" ToolsVersion="4.0">
-	
-	<Import Project="version.targets"  />
-  	<PropertyGroup>
-		<Configuration Condition="'$(Configuration)' == 'debug'">Debug</Configuration>
-		<Configuration Condition="'$(Configuration)' == '' Or '$(Configuration)' == 'release'">Release</Configuration>
-		<Area Condition="'$(Area)' == ''">all</Area>
-
-		<!-- This path is a bit redundant -->
-		<TempFolder>$(TEMP)</TempFolder>
-		<BuildFolder>$(MSBuildProjectDirectory)\..</BuildFolder>
-		<ScriptsFolder>$(MSBuildProjectDirectory)</ScriptsFolder>
-		<RootFolder>$(MSBuildProjectDirectory)\..\..\</RootFolder>
-		<Executable></Executable>
-	 </PropertyGroup>
-	 
-	 <PropertyGroup>
-	 	<BinFolder>$(BuildFolder)\bin</BinFolder>
-	 	<SourceFolder>$(RootFolder)src</SourceFolder>
-		<TestFolder>$(RootFolder)test</TestFolder>
-		<LibFolder>$(RootFolder)lib</LibFolder>
-		<PackagesFolder>$(RootFolder)lib</PackagesFolder>
- 	</PropertyGroup>
- 	<PropertyGroup>
- 		<PackageManager>$(LibFolder)\Nuget\NuGet.exe pack </PackageManager>
- 		<PackageManagerOptions>-Version $(Version) -OutputDirectory</PackageManagerOptions>
- 	</PropertyGroup>
- 	
-	<!-- To Execute commands on mono like running nunit, it requires running through the program mono.exe -->
-	<PropertyGroup Condition="'$(NETFRAMEWORK)' == 'mono'">
-		<Executable>mono</Executable>
-	</PropertyGroup>
-
-	<Import Project="All/project.targets" Condition="'$(Area)' == 'all'" />
-	<Import Project="Analyzers/project.targets" Condition="'$(Area)' == 'analyzers'" />
-	<Import Project="Contrib/project.targets" Condition="'$(Area)' == 'contrib'" />
-	<Import Project="Contrib-Core/project.targets" Condition="'$(Area)' == 'contrib-core'" />
-	<Import Project="Core/project.targets" Condition="'$(Area)' == 'core'" />
-	<Import Project="FastVectorHighlighter/project.targets" Condition="'$(Area)' == 'fastvectorhighlighter'" />
-	<Import Project="Highlighter/project.targets" Condition="'$(Area)' == 'highlighter'" />
-	<Import Project="Queries/project.targets" Condition="'$(Area)' == 'queries'" />
-	<Import Project="Regex/project.targets" Condition="'$(Area)' == 'regex'" />
-	<Import Project="SimpleFacetedSearch/project.targets" Condition="'$(Area)' == 'simplefacetedsearch'" />
-	<Import Project="Snowball/project.targets" Condition="'$(Area)' == 'snowball'" />
-	<Import Project="Spatial/project.targets" Condition="'$(Area)' == 'spatial'" />
-	<Import Project="Spatial/project.targets" Condition="'$(Area)' == 'spatialnts'" />
-	<Import Project="SpellChecker/project.targets" Condition="'$(Area)' == 'spellchecker'" />
-	
-	<ItemGroup Condition="'$(ArtifactsFolder)' != ''">
-		<CleanFiles Include="$(ArtifactsFolder)\**\*.*" />
-		<CleanFiles Include="$(RootFolder)\bin\**\*" Exclude="$(RootFolder)\**\.svn\*; $(RootFolder)\.svn\*" />
-		<CleanFiles Include="$(RootFolder)\build\bin\**\*.*" />
-	</ItemGroup>	
-	
-    <Target Name="diag">
-        <Message Text="TempFolder=$(TempFolder)" />
-        <Message Text="BuildFolder=$(BuildFolder)" />
-        <Message Text="ScriptsFolder=$(ScriptsFolder)" />
-        <Message Text="RootFolder=$(RootFolder)" />
-        <Message Text="Area=$(Area)" />
-        <Message Text="ArtifactsFolder=$(ArtifactsFolder)" />
-    </Target>
-    
-	<Target Name="paths">
-		<CallTarget Targets="@(PathsTarget)" />
-	</Target>
-	
-  
-	<Target Name="artifacts">
-		<MakeDir Condition="!Exists('$(ArtifactsFolder)')" Directories="$(ArtifactsFolder)" />
-	</Target>
-	
-	<Target Name="clean">
-        <Error Condition="'$(ArtifactsFolder)' == ''" Text="ArtifactsFolder is empty!  'Area' may be empty or invalid." />
-		<Message Text="Files To Clean: @(CleanFiles)" />
-		<Delete Files="@(CleanFiles)" />
-	</Target>
-	
-  
- 	<Target Name="build">
- 		<Message Text="External Constants$(ExternalConstants)" />
- 		<CallTarget Targets="artifacts" />
- 		<CallTarget Targets="paths" />
- 		<Warning 
-  	 		Condition="!Exists('$(MSBuildExtensionsPath32)\StyleCop\v4.5\StyleCop.targets')"
-  	 		Text="StyleCop is not installed at its expected location: $(MSBuildExtensionsPath32)\StyleCop\v4.5\StyleCop.targets" />
- 		<Message Text="Project Files: @(ProjectFiles)" />
- 		<CallTarget Targets="Build$(Area)" />
-	</Target>
-	
-	<Target Name="copy-release">
-		<MakeDir Condition="!Exists('$(RootFolder)\bin')" Directories="$(RootFolder)\bin" />
-		<Copy SourceFiles="@(ReleaseFiles)" DestinationFolder="$(RootFolder)\bin\%(RecursiveDir)" />
-		<CallTarget Targets="@(CopyTargets)" />
-	</Target>
-	
-	<Target Name="apache-release">
-		<CallTarget Targets="clean;build;apachecopy" />
-    </Target>
-	
-	<Target Name="apachecopy">
-		<ItemGroup>
-			<dllFiles Include="@(ReleaseFiles)" Condition="'%(Extension)' == '.dll'"  />
-			<xmlFiles Include="@(ReleaseFiles)" Condition="'%(Extension)' == '.xml'" />
-			<pdbFiles Include="@(BuildItems)" Condition="'%(Extension)' == '.pdb'" />
-		</ItemGroup>
-		<MakeDir Condition="!Exists('$(RootFolder)\apacherelease')" Directories="$(RootFolder)\apacherelease" />
-		<MakeDir Condition="!Exists('$(RootFolder)\apacherelease\NET35')" Directories="$(RootFolder)\apacherelease\NET35" />
-		<MakeDir Condition="!Exists('$(RootFolder)\apacherelease\NET35\bin')" Directories="$(RootFolder)\apacherelease\NET35\bin" />
-		<MakeDir Condition="!Exists('$(RootFolder)\apacherelease\NET35\doc')" Directories="$(RootFolder)\apacherelease\NET35\doc" />
-		<MakeDir Condition="!Exists('$(RootFolder)\apacherelease\NET40')" Directories="$(RootFolder)\apacherelease\NET40" />
-		<MakeDir Condition="!Exists('$(RootFolder)\apacherelease\NET40\bin')" Directories="$(RootFolder)\apacherelease\NET40\bin" />
-		<MakeDir Condition="!Exists('$(RootFolder)\apacherelease\NET40\doc')" Directories="$(RootFolder)\apacherelease\NET40\doc" />
-		
-		<Copy SourceFiles="@(xmlFiles)" DestinationFolder="$(RootFolder)\apacherelease\%(RecursiveDir)\doc" />
-		<Copy SourceFiles="@(dllFiles)" DestinationFolder="$(RootFolder)\apacherelease\%(RecursiveDir)\bin" />
-		<Copy SourceFiles="@(pdbFiles)" DestinationFolder="$(RootFolder)\apacherelease\%(RecursiveDir)\bin" />
-
-	</Target>
-	
-	<Target Name="simple">
-		<CallTarget Targets="clean;build;test-report-html;" />
-	</Target>
-
-	<Target Name="nightly">
-		<CallTarget Targets="clean;build;test-report-html;package;copy-release" />
-	</Target>
-	
-	<!-- 
-	<Target Name="nightly">
-		<CallTarget Targets="clean;build;coverage;rules;package;document;copy-release" />
-	</Target> -->
-  
-	<Target Name="commit">
-		<CallTarget Targets="clean;build;coverage;rules;" />
-	</Target>
-	
-	
-	<Import Condition="'$(NETFRAMEWORK)' != 'mono'" Project="dot-net-tools.targets" />
-	<Import Condition="'$(NETFRAMEWORK)' == 'mono'" Project="mono-tools.targets" />
-</Project>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/scripts/docs.shfbproj
----------------------------------------------------------------------
diff --git a/build/scripts/docs.shfbproj b/build/scripts/docs.shfbproj
deleted file mode 100644
index 967057d..0000000
--- a/build/scripts/docs.shfbproj
+++ /dev/null
@@ -1,90 +0,0 @@
-<?xml version="1.0" encoding="utf-8"?>
-<!--
- 
- Licensed to the Apache Software Foundation (ASF) under one or more
- contributor license agreements.  See the NOTICE file distributed with
- this work for additional information regarding copyright ownership.
- The ASF licenses this file to You under the Apache License, Version 2.0
- (the "License"); you may not use this file except in compliance with
- the License.  You may obtain a copy of the License at
-  
- http://www.apache.org/licenses/LICENSE-2.0
-  
- Unless required by applicable law or agreed to in writing, software
- distributed under the License is distributed on an "AS IS" BASIS,
- WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- See the License for the specific language governing permissions and
- limitations under the License.
- 
--->
-<Project DefaultTargets="Build" xmlns="http://schemas.microsoft.com/developer/msbuild/2003" ToolsVersion="4.0">
-  <Import Project="All/document.targets" Condition="'$(area)' == 'all'" />
-  <Import Project="Analyzers/document.targets" Condition="'$(area)' == 'analyzers'" />
-  <Import Project="Contrib/document.targets" Condition="'$(area)' == 'contrib'" />
-  <Import Project="Contrib-Core/document.targets" Condition="'$(area)' == 'contrib-core'" />
-  <Import Project="Core/document.targets" Condition="'$(area)' == 'core'" />
-  <Import Project="FastVectorHighlighter/document.targets" Condition="'$(area)' == 'fastvectorhighlighter'" />
-  <Import Project="Highlighter/document.targets" Condition="'$(area)' == 'highlighter'" />
-  <Import Project="Queries/document.targets" Condition="'$(area)' == 'queries'" />
-  <Import Project="Regex/document.targets" Condition="'$(area)' == 'regex'" />
-  <Import Project="Similarity/document.targets" Condition="'$(area)' == 'similarity'" />
-  <Import Project="SimpleFacetedSearch/document.targets" Condition="'$(area)' == 'simplefacetedsearch'" />
-  <Import Project="Snowball/document.targets" Condition="'$(area)' == 'snowball'" />
-  <Import Project="Spatial/document.targets" Condition="'$(area)' == 'spatial'" />
-  <Import Project="SpellChecker/document.targets" Condition="'$(area)' == 'spellchecker'" />
-  
-  <!-- Hudkins restarts are out of our control.... thus you never know when it will be rebooted
-       in order to find the SHFBROOT path variable. so here is our best guess. -->
-  <PropertyGroup>
-  	<ProgramFiles32>$(MSBuildProgramFiles32)</ProgramFiles32>
-  </PropertyGroup>
-  <PropertyGroup>
-  	<SHFBROOT Condition="'$(SHFBROOT)' == ''">$(ProgramFiles32)\EWSoftware\Sandcastle Help File Builder</SHFBROOT>
-  </PropertyGroup>
-  <PropertyGroup>
-    <!-- The configuration and platform will be used to determine which
-         assemblies to include from solution and project documentation
-         sources -->
-    <Configuration Condition=" '$(Configuration)' == '' ">Debug</Configuration>
-    <Platform Condition=" '$(Platform)' == '' ">AnyCPU</Platform>
-    <SchemaVersion>2.0</SchemaVersion>
-    <ProjectGuid>{f57dd4a8-d22e-43fd-87de-2ba22a54564d}</ProjectGuid>
-    <SHFBSchemaVersion>1.9.3.0</SHFBSchemaVersion>
-    <!-- AssemblyName, Name, and RootNamespace are not used by SHFB but Visual
-         Studio adds them anyway -->
-    <AssemblyName>Documentation</AssemblyName>
-    <RootNamespace>Documentation</RootNamespace>
-    <Name>Documentation</Name>
-    <!-- SHFB properties -->
-    
-    <Language>en-US</Language>
-    <SandcastlePath>C:\Program Files (x86)\Sandcastle\</SandcastlePath>
-    <BuildLogFile />
-    <HtmlHelp1xCompilerPath />
-    <HtmlHelp2xCompilerPath />
-    <HelpFileFormat>HtmlHelp1, Website</HelpFileFormat>
-    <BinaryTOC>False</BinaryTOC>
-    <IncludeStopWordList>False</IncludeStopWordList>
-  </PropertyGroup>
-  <!-- There are no properties for these groups.  AnyCPU needs to appear in
-       order for Visual Studio to perform the build.  The others are optional
-       common platform types that may appear. -->
-  <PropertyGroup Condition=" '$(Configuration)|$(Platform)' == 'Debug|AnyCPU' ">
-  </PropertyGroup>
-  <PropertyGroup Condition=" '$(Configuration)|$(Platform)' == 'Release|AnyCPU' ">
-  </PropertyGroup>
-  <PropertyGroup Condition=" '$(Configuration)|$(Platform)' == 'Debug|x86' ">
-  </PropertyGroup>
-  <PropertyGroup Condition=" '$(Configuration)|$(Platform)' == 'Release|x86' ">
-  </PropertyGroup>
-  <PropertyGroup Condition=" '$(Configuration)|$(Platform)' == 'Debug|x64' ">
-  </PropertyGroup>
-  <PropertyGroup Condition=" '$(Configuration)|$(Platform)' == 'Release|x64' ">
-  </PropertyGroup>
-  <PropertyGroup Condition=" '$(Configuration)|$(Platform)' == 'Debug|Win32' ">
-  </PropertyGroup>
-  <PropertyGroup Condition=" '$(Configuration)|$(Platform)' == 'Release|Win32' ">
-  </PropertyGroup>
-  <!-- Import the SHFB build targets -->
-  <Import Project="$(SHFBROOT)\SandcastleHelpFileBuilder.targets" />
-</Project>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/scripts/dot-net-tools.targets
----------------------------------------------------------------------
diff --git a/build/scripts/dot-net-tools.targets b/build/scripts/dot-net-tools.targets
deleted file mode 100644
index 45ccca1..0000000
--- a/build/scripts/dot-net-tools.targets
+++ /dev/null
@@ -1,192 +0,0 @@
-<?xml version="1.0" encoding="UTF-8" standalone="no" ?>
-<!--
- 
- Licensed to the Apache Software Foundation (ASF) under one or more
- contributor license agreements.  See the NOTICE file distributed with
- this work for additional information regarding copyright ownership.
- The ASF licenses this file to You under the Apache License, Version 2.0
- (the "License"); you may not use this file except in compliance with
- the License.  You may obtain a copy of the License at
-  
- http://www.apache.org/licenses/LICENSE-2.0
-  
- Unless required by applicable law or agreed to in writing, software
- distributed under the License is distributed on an "AS IS" BASIS,
- WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- See the License for the specific language governing permissions and
- limitations under the License.
- 
--->
-<Project xmlns="http://schemas.microsoft.com/developer/msbuild/2003" ToolsVersion="4.0">
-	
-	<PropertyGroup>
-		<NUnitVersionFolder>NUnit.org/NUnit/2.5.9/bin/net-2.0</NUnitVersionFolder>
-		<GallioVersionFolder>Gallio.3.2.750</GallioVersionFolder>
-	</PropertyGroup>
-	
-	<PropertyGroup>
-    	<!--MSBuild 4.0 property-->
-    	<ProgramFiles32>$(MSBuildProgramFiles32)</ProgramFiles32>
-    	<DefineConstants></DefineConstants>
-    	<ExternalConstants>GALLIO</ExternalConstants>
-    	<!--Use OS env vars as a fallback-->
-    	<!-- 
-    	<ProgramFiles32 Condition=" '' == '$(ProgramFiles32)'">$(ProgramFiles%28x86%29)</ProgramFiles32>
-    	<ProgramFiles32 Condition=" '' == '$(ProgramFiles32)' ">$(ProgramFiles)</ProgramFiles32>-->
-
-	</PropertyGroup>
-	
-  	<ItemGroup>
-  		<NUnitFolder Include="$(PackagesFolder)\$(NUnitVersionFolder)" />
-  		<FxCopFolder Include="$(ProgramFiles32)\Microsoft Fxcop 10.0" />
-  		<NCoverFolder Include="$(ProgramFiles)\NCover" />
-  		<GallioFolder Include="$(PackagesFolder)\$(GallioVersionFolder)\tools\" />
-  		<FxCopCommands Include="@(AnalysisFiles-> ' /file:%(rootdir)%(directory)%(filename)%(extension)', ' ')" />
-  		
-  		<FxCopReferences Include="@(ReferenceFiles-> ' /reference:%(rootdir)%(directory)%(filename)%(extension)', ' ')" />
-  		
-  		<SHFBFolder Include="$(ProgramFiles32)\EWSoftware\Sand Castle Help File Builder" />
-  		<SandCastleFolder Include="$(ProgramFiles32)\Sandcastle" />
-  		
-  		
-  		<CopyTargets Include="copy-doc" />
-  		<CopyTargets Include="copy-packages" />
-  		<NCoverFiles Include="@(TestFiles-> '%(rootdir)%(directory)%(filename)%(extension)', ' ')" />
-  		<ChmFiles Include="$(ArtifactsFolder)\docs\*.chm" />
-  		<DocStyles Include="$(ArtifactsFolder)\docs\styles\*" />
-  		<DocHtml Include="$(ArtifactsFolder)\docs\html\*" />
-  		<DocIcons Include="$(ArtifactsFolder)\docs\icons\*" />
-  		<DocScripts Include="$(ArtifactsFolder)\docs\scripts\*" />
-  		<DocCore Include="$(ArtifactsFolder)\docs\*"
-  			Exclude="$(ArtifactsFolder)\docs\Web.Config; $(ArtifactsFolder)\docs\WebKI.xml; $(ArtifactsFolder)\docs\WebTOC.xml; $(ArtifactsFolder)\docs\SearchHelp.aspx; $(ArtifactsFolder)\docs\LoadIndexKeywords.aspx; $(ArtifactsFolder)\docs\Index.aspx; $(ArtifactsFolder)\docs\FillNode.aspx; $(ArtifactsFolder)\docs\LastBuild.log; $(ArtifactsFolder)\docs\*.chm" /> 
-  		<NugetPackages Include="$(ArtifactsFolder)\*.nupkg" />
-  	</ItemGroup>
-  	
-  
- 
-	
-  	<Target Name="coverage" DependsOnTargets="build">
-  		<MakeDir Condition="!Exists('$(ArtifactsFolder)\ncover')" Directories="$(ArtifactsFolder)\ncover" />
-  		
-  		<Exec Command='%(GallioFolder.FullPath)Gallio.Echo.exe  @(NCoverFiles) /rd:$(ArtifactsFolder)\html-test-reports /rt:Xml  /rt:Html /rnf:test-report /hd:$(PackagesFolder)\$(NUnitVersionFolder) /runner:ncover3 /runner-property:NCoverArguments="//html $(ArtifactsFolder)\ncover //at ncover3.trend"'    /> 
-  		
-  		<!-- Notify user if code coverage tool is not found -->
-  		<Warning
-  			Condition="!Exists('%(NCoverFolder.FullPath)')"
-            Text="NCover is not installed under its expected location: %(NCoverFolder.FullPath)"
-            />
-  		<Warning
-  			Condition="!Exists('%(GallioFolder.FullPath)')"
-            Text="Gallio is not installed under its expected location: %(GallioFolder.FullPath)"
-             />
-  		 <Copy Condition="Exists('$(BuildFolder)/scripts/Coverage.xml')" SourceFiles="$(BuildFolder)/scripts/Coverage.xml" DestinationFolder="$(ArtifactsFolder)/ncover/Coverage.xml" /> 
-  		 <Delete Files="$(BuildFolder)/scripts/Coverage.xml" />
-  	</Target>
-  	
-  	
-  	<Target Name="test-report-xml"  DependsOnTargets="build">
-		<MakeDir Condition="!Exists('$(TEMP)')" Directories="$(TEMP)" />
-		<Copy SourceFiles="@(Compile)" DestinationFolder="c:\foocopy\%(RecursiveDir)" />
-		<Exec Condition="Exists('%(GallioFolder.FullPath)')" Command="%(GallioFolder.FullPath)Gallio.Echo.exe@(TestFiles-> '%(rootdir)%(directory)%(filename)%(extension)', ' ') /hd:$(PackagesFolder)\$(NUnitVersionFolder) /nl /rd:$(ArtifactsFolder)\xml-test-reports /rt:Xml /rnf:test-reports" />
-		
-		
-		<!-- Notify user if Gallio is not found -->
-		<Warning 
-			Condition="!Exists('%(GallioFolder.FullPath)')" 
-			Text="Gallio is not installed under its expected location: %(Gallio.FullPath)"  />
-		
-		<!-- Notify user if NUnit is not found -->
-		<Warning 
-			Condition="!Exists('%(NUnitFolder.FullPath)')" 
-			Text="NUnit is not installed under its expected location: %(NUnit.FullPath)"  />
-	</Target>
-	
-	<Target Name="test-report-html"  DependsOnTargets="build">
-		<MakeDir 
-			Condition="!Exists('$(TEMP)')" 
-			Directories="$(TEMP)" />
-		
-		<Exec 
-			Condition="Exists('%(GallioFolder.FullPath)')" 
-			Command="%(GallioFolder.FullPath)Gallio.Echo.exe @(TestFiles-> '%(rootdir)%(directory)%(filename)%(extension)', ' ')  /hd:$(PackagesFolder)\$(NUnitVersionFolder) /nl /rd:$(ArtifactsFolder)\html-test-reports /rt:Html /rnf:test-reports" />
-		
-		<!-- Notify user if Gallio is not found -->
-		<Warning 
-			Condition="!Exists('%(GallioFolder.FullPath)')" 
-			Text="Gallio is not installed under its expected location: %(Gallio.FullPath)"  />
-		
-		<!-- Notify user if NUnit is not found -->
-		<Warning 
-			Condition="!Exists('%(NUnitFolder.FullPath)')" 
-			Text="NUnit is not installed under its expected location: %(NUnit.FullPath)"  />
-	</Target>
-		
-	<Target Name="document"  DependsOnTargets="build">
-		<Copy SourceFiles="@(CoverageFiles)" DestinationFolder="$(BinFolder)\core\$(Configuration)" />
-   			
-      	<MSBuild 
-   			Condition="Exists('%(SandCastleFolder.FullPath)') And '$(Configuration)' == 'Release'" 
-   			Projects="$(BuildFolder)\scripts\docs.shfbproj"
-   			Properties='Configuration=Release;Platform=AnyCPU;OutDir=$(ArtifactsFolder)\docs\;area=
-   			$(Area)' />
-
-		
-
-		<!-- Notify user if Sand Castle is not found -->
-		<Warning
-			Condition="!Exists('%(SandCastleFolder.FullPath)')" 
-			Text="Sand Castle is not installed under its expected location: %(SandCastleFolder.FullPath)" />
-	</Target>
-  
-	<Target Name="copy-doc">
-		<MakeDir Condition="!Exists('$(RootFolder)\bin\docs')" Directories="$(RootFolder)\bin\docs" />
-		<MakeDir Condition="!Exists('$(RootFolder)\bin\docs\site\styles')" Directories="$(RootFolder)\bin\docs\site\styles" />
-		<MakeDir Condition="!Exists('$(RootFolder)\bin\docs\site\scripts')" Directories="$(RootFolder)\bin\docs\site\scripts" />
-		<MakeDir Condition="!Exists('$(RootFolder)\bin\docs\site\icons')" Directories="$(RootFolder)\bin\docs\site\icons" />
-		<MakeDir Condition="!Exists('$(RootFolder)\bin\docs\site\html')" Directories="$(RootFolder)\bin\docs\site\html" />
-		
-		<Copy SourceFiles="@(DocStyles)"   	    DestinationFolder="$(RootFolder)\bin\docs\site\styles" />
-		<Copy SourceFiles="@(DocHtml)"          DestinationFolder="$(RootFolder)\bin\docs\site\html" />
-		<Copy SourceFiles="@(DocIcons)"         DestinationFolder="$(RootFolder)\bin\docs\site\icons" />
-		<Copy SourceFiles="@(DocScripts)"       DestinationFolder="$(RootFolder)\bin\docs\site\scripts" />
-		<Copy SourceFiles="@(DocCore)"          DestinationFolder="$(RootFolder)\bin\docs\site\" />
-		<Copy SourceFiles="@(ChmFiles)"         DestinationFolder="$(RootFolder)\bin\docs\" />
-	</Target>
-	
-	<Target Name="copy-packages">
-		<Copy SourceFiles="@(NugetPackages)"    DestinationFolder="$(RootFolder)\bin\packages"/>
-	</Target>
-	
-	<Target Name="test" DependsOnTargets="build">
-		<MakeDir Condition="!Exists('$(TEMP)')" Directories="$(TEMP)" />
-		
-		<Exec Condition="Exists('%(GallioFolder.FullPath)') " Command="%(GallioFolder.FullPath)Gallio.Echo.exe @(TestFiles-> '%(rootdir)%(directory)%(filename)%(extension)', ' ') /hd:$(PackagesFolder)\$(NUnitVersionFolder) /nl /rd:$(ArtifactsFolder)/tests " />
-		
-		<!-- Notify user if Gallio is not found -->
-		<Warning 
-			Condition="!Exists('%(GallioFolder.FullPath)')" 
-			Text="Gallio is not installed under its expected location: %(Gallio.FullPath)"  />
-		
-		<!-- Notify user if NUnit is not found -->
-		<Warning 
-			Condition="!Exists('%(NUnitFolder.FullPath)')" 
-			Text="NUnit is not installed under its expected location: %(NUnit.FullPath)"  />
-	</Target>
-	
-	<Target Name="rules" DependsOnTargets="build">
-		<Exec Condition="Exists('%(FxCopFolder.FullPath)')" Command='"%(FxCopFolder.FullPath)\FxCopCmd.exe" @(FxCopCommands) @(FxCopReferences) /project:$(RootFolder)build\scripts\rules.fxcop /out:$(ArtifactsFolder)\fxcop.xml ' ContinueOnError="true">
-			<Output TaskParameter="ExitCode" PropertyName="ErrorCode"/>
-		</Exec>
-		
-		<!-- Notify user if fxcop is not found -->
-		<Warning 
-			Condition="!Exists('%(FxCopFolder.FullPath)')" 
-			Text="FxCop is not installed under its expected location: %(FxCopFolder.FullPath)" />
-		
-	</Target>
-	
-	<Target Name="package" DependsOnTargets="build">
-		<Delete Files="@(CleanPackages)" />
-		<CallTarget Targets="@(PackageTargets)" />
-	</Target>
-</Project>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/scripts/mono-tools.targets
----------------------------------------------------------------------
diff --git a/build/scripts/mono-tools.targets b/build/scripts/mono-tools.targets
deleted file mode 100644
index a46447f..0000000
--- a/build/scripts/mono-tools.targets
+++ /dev/null
@@ -1,46 +0,0 @@
-<?xml version="1.0" encoding="UTF-8" standalone="no" ?>
-<!--
- 
- Licensed to the Apache Software Foundation (ASF) under one or more
- contributor license agreements.  See the NOTICE file distributed with
- this work for additional information regarding copyright ownership.
- The ASF licenses this file to You under the Apache License, Version 2.0
- (the "License"); you may not use this file except in compliance with
- the License.  You may obtain a copy of the License at
-  
- http://www.apache.org/licenses/LICENSE-2.0
-  
- Unless required by applicable law or agreed to in writing, software
- distributed under the License is distributed on an "AS IS" BASIS,
- WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- See the License for the specific language governing permissions and
- limitations under the License.
- 
--->
-<Project xmlns="http://schemas.microsoft.com/developer/msbuild/2003" ToolsVersion="4.0">
-	
-	<PropertyGroup>
-		<NUnitVersionFolder>NUnit.2.5.10.11092</NUnitVersionFolder>
-	</PropertyGroup>
-	
-	
-	
-  	<ItemGroup>
-  		<NUnitFolder Include="\$(PackagesFolder)\$(NUnitVersionFolder)\tools\" />
-  	</ItemGroup>
-	
-  	<Target Name="coverage">
-  		
-  	</Target>
-	
-	<Target Name="test">
-		<MakeDir Condition="!Exists('$(TEMP)')" Directories="$(TEMP)" />
-		<Exec Condition="Exists('%(NUnitFolder.FullPath)')" Command="%(NUnitFolder.FullPath)nunit-console.exe -nologo @(TestFiles) /xml:$(ArtifactsFolder)\test-results.xml  " />
-		<Message Condition="!Exists('%(NUnitFolder.FullPath)')" Text="The Nunit folder does not exist: %(NUnitFolder.FullPath)"  />
-	</Target>
-	
-	<Target Name="rules">
-		
-	</Target>
-
-</Project>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/scripts/rules.fxcop
----------------------------------------------------------------------
diff --git a/build/scripts/rules.fxcop b/build/scripts/rules.fxcop
deleted file mode 100644
index 6b237a7..0000000
--- a/build/scripts/rules.fxcop
+++ /dev/null
@@ -1,143 +0,0 @@
-<?xml version="1.0" encoding="utf-8"?>
-<!--
- 
- Licensed to the Apache Software Foundation (ASF) under one or more
- contributor license agreements.  See the NOTICE file distributed with
- this work for additional information regarding copyright ownership.
- The ASF licenses this file to You under the Apache License, Version 2.0
- (the "License"); you may not use this file except in compliance with
- the License.  You may obtain a copy of the License at
-  
- http://www.apache.org/licenses/LICENSE-2.0
-  
- Unless required by applicable law or agreed to in writing, software
- distributed under the License is distributed on an "AS IS" BASIS,
- WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- See the License for the specific language governing permissions and
- limitations under the License.
- 
--->
-<FxCopProject Version="10.0" Name="My FxCop Project">
- <ProjectOptions>
-  <SharedProject>True</SharedProject>
-  <Stylesheet Apply="False">$(FxCopDir)\Xml\FxCopReport.xsl</Stylesheet>
-  <SaveMessages>
-   <Project Status="Active, Excluded" NewOnly="False" />
-   <Report Status="Active" NewOnly="False" />
-  </SaveMessages>
-  <ProjectFile Compress="True" DefaultTargetCheck="True" DefaultRuleCheck="True" SaveByRuleGroup="" Deterministic="True" />
-  <EnableMultithreadedLoad>True</EnableMultithreadedLoad>
-  <EnableMultithreadedAnalysis>True</EnableMultithreadedAnalysis>
-  <SourceLookup>True</SourceLookup>
-  <AnalysisExceptionsThreshold>40</AnalysisExceptionsThreshold>
-  <RuleExceptionsThreshold>40</RuleExceptionsThreshold>
-  <Spelling Locale="en-US" />
-  <OverrideRuleVisibilities>False</OverrideRuleVisibilities>
-  <CustomDictionaries SearchFxCopDir="True" SearchUserProfile="True" SearchProjectDir="True" />
-  <SearchGlobalAssemblyCache>False</SearchGlobalAssemblyCache>
-  <DeadlockDetectionTimeout>120</DeadlockDetectionTimeout>
-  <IgnoreGeneratedCode>True</IgnoreGeneratedCode>
- </ProjectOptions>
- <Targets>
-  <AssemblyReferenceDirectories>
-   <Directory>$(ProjectDir)/../bin/core/Debug/</Directory>
-   <Directory>$(ProjectDir)/../bin/core/Debug/</Directory>
-   <Directory>$(ProjectDir)/../../packages/PortableLibrary/</Directory>
-   <Directory>$(ProjectDir)/../../PortableLibrary/</Directory>
-  </AssemblyReferenceDirectories>
- </Targets>
- <Rules>
-  <RuleFiles>
-   <RuleFile Name="$(FxCopDir)\Rules\DesignRules.dll" Enabled="True" AllRulesEnabled="False">
-    <Rule Name="AbstractTypesShouldNotHaveConstructors" Enabled="True" />
-    <Rule Name="AssembliesShouldHaveValidStrongNames" Enabled="True" />
-    <Rule Name="AvoidEmptyInterfaces" Enabled="True" />
-    <Rule Name="AvoidExcessiveParametersOnGenericTypes" Enabled="True" />
-    <Rule Name="AvoidNamespacesWithFewTypes" Enabled="True" />
-    <Rule Name="AvoidOutParameters" Enabled="True" />
-    <Rule Name="CollectionsShouldImplementGenericInterface" Enabled="True" />
-    <Rule Name="ConsiderPassingBaseTypesAsParameters" Enabled="True" />
-    <Rule Name="DeclareEventHandlersCorrectly" Enabled="True" />
-    <Rule Name="DeclareTypesInNamespaces" Enabled="True" />
-    <Rule Name="DefineAccessorsForAttributeArguments" Enabled="True" />
-    <Rule Name="DoNotCatchGeneralExceptionTypes" Enabled="True" />
-    <Rule Name="DoNotDeclareProtectedMembersInSealedTypes" Enabled="True" />
-    <Rule Name="DoNotDeclareStaticMembersOnGenericTypes" Enabled="True" />
-    <Rule Name="DoNotDeclareVirtualMembersInSealedTypes" Enabled="True" />
-    <Rule Name="DoNotDeclareVisibleInstanceFields" Enabled="True" />
-    <Rule Name="DoNotExposeGenericLists" Enabled="True" />
-    <Rule Name="DoNotHideBaseClassMethods" Enabled="True" />
-    <Rule Name="DoNotNestGenericTypesInMemberSignatures" Enabled="True" />
-    <Rule Name="DoNotOverloadOperatorEqualsOnReferenceTypes" Enabled="True" />
-    <Rule Name="DoNotPassTypesByReference" Enabled="True" />
-    <Rule Name="DoNotRaiseExceptionsInUnexpectedLocations" Enabled="True" />
-    <Rule Name="EnumeratorsShouldBeStronglyTyped" Enabled="True" />
-    <Rule Name="EnumsShouldHaveZeroValue" Enabled="True" />
-    <Rule Name="EnumStorageShouldBeInt32" Enabled="True" />
-    <Rule Name="ExceptionsShouldBePublic" Enabled="True" />
-    <Rule Name="GenericMethodsShouldProvideTypeParameter" Enabled="True" />
-    <Rule Name="ICollectionImplementationsHaveStronglyTypedMembers" Enabled="True" />
-    <Rule Name="ImplementIDisposableCorrectly" Enabled="True" />
-    <Rule Name="ImplementStandardExceptionConstructors" Enabled="True" />
-    <Rule Name="IndexersShouldNotBeMultidimensional" Enabled="True" />
-    <Rule Name="InterfaceMethodsShouldBeCallableByChildTypes" Enabled="True" />
-    <Rule Name="ListsAreStronglyTyped" Enabled="True" />
-    <Rule Name="MarkAssembliesWithAssemblyVersion" Enabled="True" />
-    <Rule Name="MarkAssembliesWithClsCompliant" Enabled="True" />
-    <Rule Name="MarkAssembliesWithComVisible" Enabled="True" />
-    <Rule Name="MarkAttributesWithAttributeUsage" Enabled="True" />
-    <Rule Name="MarkEnumsWithFlags" Enabled="True" />
-    <Rule Name="MembersShouldNotExposeCertainConcreteTypes" Enabled="True" />
-    <Rule Name="MovePInvokesToNativeMethodsClass" Enabled="True" />
-    <Rule Name="NestedTypesShouldNotBeVisible" Enabled="True" />
-    <Rule Name="OverloadOperatorEqualsOnOverloadingAddAndSubtract" Enabled="True" />
-    <Rule Name="OverrideMethodsOnComparableTypes" Enabled="True" />
-    <Rule Name="PropertiesShouldNotBeWriteOnly" Enabled="True" />
-    <Rule Name="ProvideObsoleteAttributeMessage" Enabled="True" />
-    <Rule Name="ReplaceRepetitiveArgumentsWithParamsArray" Enabled="True" />
-    <Rule Name="StaticHolderTypesShouldBeSealed" Enabled="True" />
-    <Rule Name="StaticHolderTypesShouldNotHaveConstructors" Enabled="True" />
-    <Rule Name="StringUriOverloadsCallSystemUriOverloads" Enabled="True" />
-    <Rule Name="TypesShouldNotExtendCertainBaseTypes" Enabled="True" />
-    <Rule Name="TypesThatOwnDisposableFieldsShouldBeDisposable" Enabled="True" />
-    <Rule Name="TypesThatOwnNativeResourcesShouldBeDisposable" Enabled="True" />
-    <Rule Name="UriParametersShouldNotBeStrings" Enabled="True" />
-    <Rule Name="UriPropertiesShouldNotBeStrings" Enabled="True" />
-    <Rule Name="UriReturnValuesShouldNotBeStrings" Enabled="True" />
-    <Rule Name="UseEventsWhereAppropriate" Enabled="True" />
-    <Rule Name="UseGenericEventHandlerInstances" Enabled="True" />
-    <Rule Name="UseGenericsWhereAppropriate" Enabled="True" />
-    <Rule Name="UseIntegralOrStringArgumentForIndexers" Enabled="True" />
-    <Rule Name="UsePropertiesWhereAppropriate" Enabled="True" />
-   </RuleFile>
-   <RuleFile Name="$(FxCopDir)\Rules\GlobalizationRules.dll" Enabled="True" AllRulesEnabled="True" />
-   <RuleFile Name="$(FxCopDir)\Rules\InteroperabilityRules.dll" Enabled="True" AllRulesEnabled="False">
-    <Rule Name="AutoLayoutTypesShouldNotBeComVisible" Enabled="True" />
-    <Rule Name="AvoidInt64ArgumentsForVB6Clients" Enabled="True" />
-    <Rule Name="AvoidOverloadsInComVisibleInterfaces" Enabled="True" />
-    <Rule Name="AvoidStaticMembersInComVisibleTypes" Enabled="True" />
-    <Rule Name="CallGetLastErrorImmediatelyAfterPInvoke" Enabled="True" />
-    <Rule Name="ComRegistrationMethodsShouldBeMatched" Enabled="True" />
-    <Rule Name="ComRegistrationMethodsShouldNotBeVisible" Enabled="True" />
-    <Rule Name="ComVisibleTypeBaseTypesShouldBeComVisible" Enabled="True" />
-    <Rule Name="ComVisibleTypesShouldBeCreatable" Enabled="True" />
-    <Rule Name="DeclarePInvokesCorrectly" Enabled="True" />
-    <Rule Name="DoNotUseAutoDualClassInterfaceType" Enabled="True" />
-    <Rule Name="MarkBooleanPInvokeArgumentsWithMarshalAs" Enabled="True" />
-    <Rule Name="MarkComSourceInterfacesAsIDispatch" Enabled="True" />
-    <Rule Name="PInvokeEntryPointsShouldExist" Enabled="True" />
-    <Rule Name="PInvokesShouldNotBeVisible" Enabled="True" />
-   </RuleFile>
-   <RuleFile Name="$(FxCopDir)\Rules\MobilityRules.dll" Enabled="True" AllRulesEnabled="True" />
-   <RuleFile Name="$(FxCopDir)\Rules\NamingRules.dll" Enabled="True" AllRulesEnabled="True" />
-   <RuleFile Name="$(FxCopDir)\Rules\PerformanceRules.dll" Enabled="True" AllRulesEnabled="True" />
-   <RuleFile Name="$(FxCopDir)\Rules\PortabilityRules.dll" Enabled="True" AllRulesEnabled="True" />
-   <RuleFile Name="$(FxCopDir)\Rules\SecurityRules.dll" Enabled="True" AllRulesEnabled="True" />
-   <RuleFile Name="$(FxCopDir)\Rules\SecurityTransparencyRules.dll" Enabled="True" AllRulesEnabled="True" />
-   <RuleFile Name="$(FxCopDir)\Rules\UsageRules.dll" Enabled="True" AllRulesEnabled="True" />
-  </RuleFiles>
-  <Groups />
-  <Settings />
- </Rules>
- <FxCopReport Version="10.0" />
-</FxCopProject>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/scripts/rules.stylecop
----------------------------------------------------------------------
diff --git a/build/scripts/rules.stylecop b/build/scripts/rules.stylecop
deleted file mode 100644
index 7f0da4a..0000000
--- a/build/scripts/rules.stylecop
+++ /dev/null
@@ -1,48 +0,0 @@
-<?xml version='1.0'?>
-<!--
-
- Licensed under the Apache License, Version 2.0 (the "License");
- you may not use this file except in compliance with the License.
- You may obtain a copy of the License at
- 
-      http://www.apache.org/licenses/LICENSE-2.0
- 
- Unless required by applicable law or agreed to in writing, software
- distributed under the License is distributed on an "AS IS" BASIS,
- WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- See the License for the specific language governing permissions and
- limitations under the License.
-
--->
-<StyleCopSettings Version="4.3">
-  <Parsers>
-    <Parser ParserId="StyleCop.CSharp.CsParser">
-      <ParserSettings>
-        <CollectionProperty Name="GeneratedFileFilters">
-          <Value>\.g\.cs$</Value>
-          <Value>\.generated\.cs$</Value>
-          <Value>\.g\.i\.cs$</Value>
-        </CollectionProperty>
-      </ParserSettings>
-    </Parser>
-  </Parsers>
-  <Analyzers>
-    <Analyzer AnalyzerId="StyleCop.CSharp.NamingRules">
-      <AnalyzerSettings>
-        <CollectionProperty Name="Hungarian">
-          <Value>as</Value>
-          <Value>do</Value>
-          <Value>id</Value>
-          <Value>if</Value>
-          <Value>in</Value>
-          <Value>is</Value>
-          <Value>my</Value>
-          <Value>no</Value>
-          <Value>on</Value>
-          <Value>to</Value>
-          <Value>ui</Value>
-        </CollectionProperty>
-      </AnalyzerSettings>
-    </Analyzer>
-  </Analyzers>
-</StyleCopSettings>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/scripts/template.shfbproj
----------------------------------------------------------------------
diff --git a/build/scripts/template.shfbproj b/build/scripts/template.shfbproj
deleted file mode 100644
index c27a3b6..0000000
--- a/build/scripts/template.shfbproj
+++ /dev/null
@@ -1,93 +0,0 @@
-<?xml version="1.0" encoding="utf-8"?>
-<!--
- 
- Licensed to the Apache Software Foundation (ASF) under one or more
- contributor license agreements.  See the NOTICE file distributed with
- this work for additional information regarding copyright ownership.
- The ASF licenses this file to You under the Apache License, Version 2.0
- (the "License"); you may not use this file except in compliance with
- the License.  You may obtain a copy of the License at
-  
- http://www.apache.org/licenses/LICENSE-2.0
-  
- Unless required by applicable law or agreed to in writing, software
- distributed under the License is distributed on an "AS IS" BASIS,
- WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- See the License for the specific language governing permissions and
- limitations under the License.
- 
--->
-<Project DefaultTargets="Build" xmlns="http://schemas.microsoft.com/developer/msbuild/2003" ToolsVersion="4.0">
-	<Import Project="core/documentation.targets" Condition="'$(BuildArea)' == 'core'" />
-	
-  <PropertyGroup>
-    <!-- The configuration and platform will be used to determine which
-         assemblies to include from solution and project documentation
-         sources -->
-    <Configuration Condition=" '$(Configuration)' == '' ">Debug</Configuration>
-    <Platform Condition=" '$(Platform)' == '' ">AnyCPU</Platform>
-    <SchemaVersion>2.0</SchemaVersion>
-    <ProjectGuid>{f57dd4a8-d22e-43fd-87de-2ba22a54564d}</ProjectGuid>
-    <SHFBSchemaVersion>1.9.3.0</SHFBSchemaVersion>
-    <!-- AssemblyName, Name, and RootNamespace are not used by SHFB but Visual
-         Studio adds them anyway -->
-    <AssemblyName>Documentation</AssemblyName>
-    <RootNamespace>Documentation</RootNamespace>
-    <Name>Documentation</Name>
-    <!-- SHFB properties -->
-    <OutputPath>..\artifacts\docs\</OutputPath>
-    <HtmlHelpName>Lucene.Net</HtmlHelpName>
-    <Language>en-US</Language>
-    <DocumentationSources>
-      <DocumentationSource sourceFile="..\bin\core\Debug\Lucene.Net.dll" />
-      <DocumentationSource sourceFile="..\bin\core\Debug\Lucene.Net.XML" />
-    </DocumentationSources>
-    <SandcastlePath>C:\Program Files (x86)\Sandcastle\</SandcastlePath>
-    <BuildLogFile />
-    <HtmlHelp1xCompilerPath />
-    <HtmlHelp2xCompilerPath />
-    <WorkingPath>..\artifacts\working\</WorkingPath>
-    <HelpFileFormat>HtmlHelp1, Website</HelpFileFormat>
-    <HelpTitle>Lucene.Net Class Library</HelpTitle>
-    <BinaryTOC>False</BinaryTOC>
-    <IncludeStopWordList>False</IncludeStopWordList>
-  </PropertyGroup>
-  <!-- There are no properties for these groups.  AnyCPU needs to appear in
-       order for Visual Studio to perform the build.  The others are optional
-       common platform types that may appear. -->
-  <PropertyGroup Condition=" '$(Configuration)|$(Platform)' == 'Debug|AnyCPU' ">
-  </PropertyGroup>
-  <PropertyGroup Condition=" '$(Configuration)|$(Platform)' == 'Release|AnyCPU' ">
-  </PropertyGroup>
-  <PropertyGroup Condition=" '$(Configuration)|$(Platform)' == 'Debug|x86' ">
-  </PropertyGroup>
-  <PropertyGroup Condition=" '$(Configuration)|$(Platform)' == 'Release|x86' ">
-  </PropertyGroup>
-  <PropertyGroup Condition=" '$(Configuration)|$(Platform)' == 'Debug|x64' ">
-  </PropertyGroup>
-  <PropertyGroup Condition=" '$(Configuration)|$(Platform)' == 'Release|x64' ">
-  </PropertyGroup>
-  <PropertyGroup Condition=" '$(Configuration)|$(Platform)' == 'Debug|Win32' ">
-  </PropertyGroup>
-  <PropertyGroup Condition=" '$(Configuration)|$(Platform)' == 'Release|Win32' ">
-  </PropertyGroup>
-  <ItemGroup>
-    <Reference Include="mscorlib">
-      <HintPath>..\..\packages\PortableLibrary\mscorlib.dll</HintPath>
-    </Reference>
-    <Reference Include="System">
-      <HintPath>..\..\packages\PortableLibrary\System.dll</HintPath>
-    </Reference>
-    <Reference Include="System.Core">
-      <HintPath>..\..\packages\PortableLibrary\System.Core.dll</HintPath>
-    </Reference>
-    <Reference Include="System.Net">
-      <HintPath>..\..\packages\PortableLibrary\System.Net.dll</HintPath>
-    </Reference>
-    <Reference Include="System.Xml">
-      <HintPath>..\..\packages\PortableLibrary\System.Xml.dll</HintPath>
-    </Reference>
-  </ItemGroup>
-  <!-- Import the SHFB build targets -->
-  <Import Project="$(SHFBROOT)\SandcastleHelpFileBuilder.targets" />
-</Project>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/scripts/user.targets
----------------------------------------------------------------------
diff --git a/build/scripts/user.targets b/build/scripts/user.targets
deleted file mode 100644
index 501f912..0000000
--- a/build/scripts/user.targets
+++ /dev/null
@@ -1,92 +0,0 @@
-<?xml version="1.0" encoding="UTF-8" standalone="no" ?>
-<!--
- 
- Licensed to the Apache Software Foundation (ASF) under one or more
- contributor license agreements.  See the NOTICE file distributed with
- this work for additional information regarding copyright ownership.
- The ASF licenses this file to You under the Apache License, Version 2.0
- (the "License"); you may not use this file except in compliance with
- the License.  You may obtain a copy of the License at
-  
- http://www.apache.org/licenses/LICENSE-2.0
-  
- Unless required by applicable law or agreed to in writing, software
- distributed under the License is distributed on an "AS IS" BASIS,
- WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- See the License for the specific language governing permissions and
- limitations under the License.
- 
--->
-<Project xmlns="http://schemas.microsoft.com/developer/msbuild/2003" ToolsVersion="4.0">
-	
-	
-  	<PropertyGroup>
-		<Configuration Condition="'$(Configuration)' == '' Or '$(Configuration)' == 'debug'">Debug</Configuration>
-		<Configuration Condition="'$(Configuration)' == 'release'">Release</Configuration>
-		<BuildArea Condition="'$(BuildArea)' == ''">all</BuildArea>
-		<LuceneFolder>core</LuceneFolder>
-		<ContribFolder>contrib</ContribFolder>
-		<BinFolder>bin</BinFolder>
-		<SourceFolder>src</SourceFolder>
-		<TestFolder>test</TestFolder>
-		<LibFolder>lib</LibFolder>
-		<!-- This path is a bit redundant -->
-		<NUnitBinFolder>lib\NUnit.org\NUnit\2.5.9\bin\net-2.0\</NUnitBinFolder>
-		<TempFolder>$(TEMP)</TempFolder>
-		<BuildFolder>$(MSBuildProjectDirectory)</BuildFolder>
-		<RootFolder>$(MSBuildProjectDirectory)\..\..\</RootFolder>
-		<Executable></Executable>
-	 </PropertyGroup>
-	
-	<!-- To Execute commands on mono like running nunit, it requires running through the program mono.exe -->
-	<PropertyGroup Condition="'$(NETFRAMEWORK)' == 'mono'">
-		<Executable>mono</Executable>
-	</PropertyGroup>
-
-	<PropertyGroup>
-		<LuceneSourceFolder>$(RootFolder)$(SourceFolder)\$(LuceneFolder)\</LuceneSourceFolder>
-		<LuceneTestFolder>$(RootFolder)$(TestFolder)\$(LuceneFolder)\</LuceneTestFolder>
-		<LuceneBinFolder>$(RootFolder)$(BinFolder)\$(LuceneFolder)\</LuceneBinFolder>
-		<ContribSourceFolder>$(RootFolder)$(SourceFolder)\$(ContribFolder)\</ContribSourceFolder>
-		<ContribTestFolder>$(RootFolder)$(TestFolder)\$(ContribFolder)\</ContribTestFolder>
-		<ContribBinFolder>$(RootFolder)$(BinFolder)\$(ContribFolder)\</ContribBinFolder>
-	</PropertyGroup>
-
-
-
-  	<ItemGroup Condition="'$(BuildArea)' == 'lucene' Or '$(BuildArea)' == 'all'">
-		<BuildFiles Include="\$(LuceneBinFolder)**\*" />
-		<TestFiles Include="\$(LuceneBinFolder)**\*.Test.dll" />
-		<SubFiles Include="\$(LuceneBinFolder)$(Configuration)\**\*.*" Exclude="\$(LuceneBinFolder)$(Configuration)\*.*" />
-		<ProjectFiles Include="\$(LuceneSourceFolder)\**\*.csproj" />
-		<ProjectFiles Include="\$(LuceneTestFolder)\**\*.csproj" />
-	</ItemGroup>
-	
-	<ItemGroup>
-	    <SubFolders Include="@(SubFiles->'%(RootDir)%(Directory)')" />
-		<NUnitFolder Include="\$(RootFolder)$(NunitBinFolder)" />
-	</ItemGroup>
-
-	<ItemGroup>
-	    <BuildFolders Include="@(SubFolders->'%(RootDir)%(Directory)')" Exclude="\$(LuceneBinFolder)" />
-	</ItemGroup>
-  
-	<Target Name="clean">
-		<Exec Command="echo %(BuildFolders.FullPath)" WorkingDirectory="/" />
-		<Delete Files="@(BuildFiles)" /> 
-		<!-- 
-		TODO: fix this
-		<RemoveDir Directories="@(BuildFolders)" /> -->
-	</Target>
-  
- 	<Target Name="build">
-		<MSBuild Projects="@(ProjectFiles)" Properties="Configuration=$(Configuration)" />
-	</Target>
-  
-	<Target Name="test">
-		<MakeDir Condition="!Exists('$(TEMP)')" Directories="$(TEMP)" />
-		
-		<Exec Command="$(Executable) %(NUnitFolder.FullPath)nunit-console.exe -nologo @(TestFiles).FullPath" />
-	</Target>
-
-</Project>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/scripts/validate-tool-chain.ps1
----------------------------------------------------------------------
diff --git a/build/scripts/validate-tool-chain.ps1 b/build/scripts/validate-tool-chain.ps1
deleted file mode 100644
index 940fc35..0000000
--- a/build/scripts/validate-tool-chain.ps1
+++ /dev/null
@@ -1,304 +0,0 @@
-#
-# Licensed to the Apache Software Foundation (ASF) under one or more
-# contributor license agreements.  See the NOTICE file distributed with
-# this work for additional information regarding copyright ownership.
-# The ASF licenses this file to You under the Apache License, Version 2.0
-# (the "License"); you may not use this file except in compliance with
-# the License.  You may obtain a copy of the License at
-#  
-# http://www.apache.org/licenses/LICENSE-2.0
-#  
-# Unless required by applicable law or agreed to in writing, software
-# distributed under the License is distributed on an "AS IS" BASIS,
-# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-# See the License for the specific language governing permissions and
-# limitations under the License.
-#
-#
-#
-# NOTICE: This script could mess up your development box. Use with extreme 
-# caution. Better yet, test this on a non-production env vm before attempting
-# to use it on any box you consider important.
-#
-#
-# This is essentially a devopts script for installing tools that are needed for
-# the Lucene.NEt build scripts to run CI on windows. 
-#
-# The script could use some refactoring and has the need to 
-# increase its functionality for version & better error checking.
-# 
-# However it is a good alternative to having to remember where to 
-# certain download software packages from or what to execute after the install. 
-#
-# This could also be handy for setting up new dev machines on windows 8 previews. 
-#
-# When Co-App is finally released and is considered stable, we could potentially 
-# replace this script with that. 
-# http://coapp.org/
-
-function Get-ScriptDirectory
-{
-	$script = (Get-Variable MyInvocation -Scope 1).Value
-	Split-Path $script.MyCommand.Path
-}
-
-$cd = Get-ScriptDirectory;
-
-$Folder64 = $Env:ProgramFiles;
-$Folder32 = ${Env:ProgramFiles(x86)};
-
-$RequireWin7_1 = $false;
-$RequireFxCop10 = $false;
-$RequireSHFB = $false;
-$RequireNCover = $false;
-
-echo $Folder32;
-
-$FindWin7_1 = Test-Path ($Folder64 + "\Microsoft SDKs\Windows\v7.1");
-if($FindWin7_1 -eq $false) {
-	$FindWin7_1 = Test-Path ($Folder32 + "\Microsoft SDKs\Windows\v7.1");
-}
-
-if($FindWin7_1 -eq $false) {
-	echo "Windows 7.1 SDK               ..Not installed in its expected location."; 
-	$RequireWin7_1 = $true;
-} else {
-	echo "Windows 7.1 SDK               ..Found."; 
-}
-
-$FindFxCop10 = Test-Path($Folder32 + "\Microsoft Fxcop 10.0");
-
-if($FindFxCop10 -eq $false) {
-	echo "Fx Cop 10 is not installed in its expected location."; 
-	$RequireFxCop10 = $true;
-} else {
-	echo "Fx Cop 10                     ..Found."; 
-}
-
-$FindNCover = Test-Path ($Folder32 + "\NCover\NCover.Console.exe");
-if($FindNCover -eq $false) {
-	echo "NCover is not installed in its expected location.";
-	$RequireNCover = $true;
-} else {
-	echo "NCover                        ..Found."; 
-}
-
-$FindSHFB = Test-Path ($Folder32 + "\EWSoftware\Sandcastle Help File Builder");
-
-if($FindSHFB -eq $false) {
-	echo "Sandcastle Help File Builder is not installed in its expected location."; 
-	$RequireSFHB = $true;
-} else {
-	echo "Sandcastle Help File Builder  ..Found.";     
-}
-
-Function PromptForSHFBInstall
-{
-	$process = read-host "Do you want to download and install SandCastle Help File Builder ? (Y) or (N)";
-	if($process -eq "Y")
-	{
-		
-		$license = Read-Host "Do you agree to reading and accepting the ms-pl license http://www.opensource.org/licenses/MS-PL ? (Y) or (N)";
-		
-		if($license -eq "Y")
-		{
-			[System.Reflection.Assembly]::LoadFrom((Join-Path ($cd) "..\..\lib\ICSharpCode\SharpZipLib\0.85\ICSharpCode.SharpZipLib.dll"));
-			$zip = New-Object ICSharpCode.SharpZipLib.Zip.FastZip
-			$client = new-object System.Net.WebClient;
-			$SHFBUrl = "http://download.codeplex.com/Download?ProjectName=shfb&DownloadId=214182&FileTime=129456589216470000&Build=18101";
-			$SHFBFileName = Join-Path $home Downloads\SHFBGuidedInstallation.zip;
-			$SHFBFileNameExtract = Join-Path $home Downloads\SHFBGuidedInstallation;
-			[System.Net.GlobalProxySelection]::Select = [System.Net.GlobalProxySelection]::GetEmptyWebProxy();
-			trap { $error[0].Exception.ToString() } 
-			
-			$exists = Test-Path $SHFBFileName;
-			if($exists -eq $false)
-			{
-				echo ("Downloading SHFB to " + $SHFBFileName);
-				$client.DownloadFile($SHFBUrl,$SHFBFileName);
-			}
-			
-			$exists = Test-Path $SHFBFileNameExtract;
-			if($exists -eq $false)
-			{
-				echo ("Extracting SHFB to " + $SHFBFileNameExtract);
-				$zip.ExtractZip($SHFBFileName, $SHFBFileNameExtract, $null);
-			}
-
-			
-			echo ("Installing SHFB...");
-			$installer = Join-Path $HOME Downloads\SHFBGuidedInstallation\SandCastleInstaller.exe
-			
-			
-			trap [Exception] {
-				echo $_.Exception.Message;
-				return;
-			}
-		    & $installer | Out-Null
-			
-			if($LASTEXITCODE -eq 0) 
-			{ 
-				echo "SHFB was installed" ;
-			} else {
-				echo "SHFB installation failed.";
-				return;
-			}
-			
-			echo ("Deleting SHFB Zip");
-			del $SHFBFileName;
-			
-			echo ("Deleteing Extracted Files...");
-			del $SHFBFileNameExtract;
-		} 
-		else 
-		{
-			echo "SandCastle Help File Builder install aborted.";
-		}
-	}
-}
-
-Function PromptForWinSdk7_1Install 
-{
-	$process = read-host "Do you want to download and install Windows Sdk 7.1 ? (Y) or (N)";
-	if($process -eq "Y")
-	{	
-		$client = new-object System.Net.WebClient;
-		$WinSdk7_1Url = "http://download.microsoft.com/download/A/6/A/A6AC035D-DA3F-4F0C-ADA4-37C8E5D34E3D/winsdk_web.exe";
-		$WinSdk7_1FileName = Join-Path $home Downloads\winsdk_web.exe;
-		[System.Net.GlobalProxySelection]::Select = [System.Net.GlobalProxySelection]::GetEmptyWebProxy();
-		trap { $error[0].Exception.ToString() } 
-		
-		$exists = Test-Path $WinSdk7_1FileName;
-		if($exists -eq $false)
-		{
-			echo ("Downloading Win Sdk 7.1 to " + $WinSdk7_1FileName);
-			$client.DownloadFile($WinSdk7_1Url,$WinSdk7_1FileName);
-		}
-		
-		
-		echo ("Installing Win Sdk 7.1  ...");
-		$installer = $WinSdk7_1FileName;
-		trap [Exception] {
-			echo $_.Exception.Message;
-			return;
-		}
-		
-	    & $installer
-		
-		echo "Attempting to setup Win Sdk Version...";
-		$verExe = "C:\Program Files\Microsoft SDKs\Windows\v7.1\Setup\WindowsSdkVer.exe";
-		$verExeExists = Test-Path $verExe;
-		
-		
-		echo "Say yes to the next next two prompts if you wish to set WindowsSdkVer to -version:v7.1 ...";
-		if($verExeExists)
-		{
-			$p = [diagnostics.process]::Start($verExe, " -version:v7.1");
-			
-			trap [Exception] {
-				echo ("Most likely this action was cancelled by you.: " + $_.Exception.Message);
-				return;
-			}
-			
-			$p.WaitForExit()  | out-null
-			if($LASTEXITCODE -eq 0) 
-			{ 
-				echo "Win Sdk 7.1 was installed" ;
-			} else {
-				echo "Win Sdk 7.1 failed.";
-				return;
-			}
-			
-			
-		} else {
-			echo ($verExe + "was not found.")
-		}
-		
-		echo ("Deleteing installer...");
-		del $WinSdk7_1FileName;
-		$RequireWin7_1 = $false;
-			
-	} 
-	else 
-	{
-		echo "Win Sdk 7.1 install aborted.";
-	}
-	
-}
-
-Function PromptForFxCop10Install()
-{
-	$process = read-host "Do you want to install FxCop 10.0 (WinSdk 7.1 is required)? (Y) or (N)";
-	if($process -eq "Y")
-	{
-		$fxCopExe = "C:\Program Files\Microsoft SDKs\Windows\v7.1\Bin\FXCop\FxCopSetup.exe";
-		$fxCopExeExists = Test-Path $fxCopExe;
-		
-		if($fxCopExeExists -eq $true)
-		{
-			trap [Exception] {
-				echo $_.Exception.Message;
-				return;
-			}
-			& $fxCopExe;
-		
-		} else {
-			echo ("The installer for fxcop 10 was not found at its expected location: " + $fxCopExe);
-			return;
-		}
-	}
-}
-
-Function PromptForNCoverInstall()
-{
-	$process = read-host "NCover is not free, you are responsible for obtaining your own license. Do you want to install NCover ? (Y) or (N)";
-	
-	
-	if($process -eq "Y")
-	{
-		$client = new-object System.Net.WebClient;
-		$download = "http://downloads.ncover.com/NCover-x64-3.4.18.6937.msi";
-		$downloadFileName = Join-Path ($home + "Downloads\NCover-x64-3.4.18.6937.msi");
-		[System.Net.GlobalProxySelection]::Select = [System.Net.GlobalProxySelection]::GetEmptyWebProxy();
-		trap { $error[0].Exception.ToString() } 
-			
-		
-		$exists = Test-Path $downloadFileName;
-		if($exists -eq $false)
-		{
-			echo ("Downloading NCover to " + $downloadFileName);
-			$client.DownloadFile($download,$downloadFileName);
-		}
-	
-		echo "Installing NCover...";
-		trap [Exception] {
-				echo $_.Exception.Message;
-				return;
-			}
-		& $fxCopExe;
-		
-		echo "Deleting installer....";
-		del $downloadFileName;
-	}
-}
-
-
-if($RequireSFHB -eq $true)
-{
-	PromptForSHFBInstall;
-}
-
-if($RequireWin7_1 -eq $true)
-{
-	PromptForWinSdk7_1Install
-}
-
-if($RequireWin7_1 -eq $false -and $RequireFxCop10 -eq $true)
-{
-	PromptForFxCop10Install
-}
-
-if($RequireNCover -eq $true)
-{
-	PromptForNCoverInstall
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/scripts/version.targets
----------------------------------------------------------------------
diff --git a/build/scripts/version.targets b/build/scripts/version.targets
deleted file mode 100644
index 2f8ba49..0000000
--- a/build/scripts/version.targets
+++ /dev/null
@@ -1,25 +0,0 @@
-<?xml version="1.0" encoding="UTF-8" standalone="no" ?>
-<!--
- 
- Licensed to the Apache Software Foundation (ASF) under one or more
- contributor license agreements.  See the NOTICE file distributed with
- this work for additional information regarding copyright ownership.
- The ASF licenses this file to You under the Apache License, Version 2.0
- (the "License"); you may not use this file except in compliance with
- the License.  You may obtain a copy of the License at
-  
- http://www.apache.org/licenses/LICENSE-2.0
-  
- Unless required by applicable law or agreed to in writing, software
- distributed under the License is distributed on an "AS IS" BASIS,
- WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- See the License for the specific language governing permissions and
- limitations under the License.
- 
--->
-<Project xmlns="http://schemas.microsoft.com/developer/msbuild/2003" ToolsVersion="4.0">
-	<!-- This file can be overwritten -->
-	<PropertyGroup>
-		<Version>3.0.3</Version>
-	</PropertyGroup>
-</Project>
\ No newline at end of file


[35/51] [abbrv] [partial] Cleaning up and getting ready to development towards v4.8

Posted by sy...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Gallio.xml
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Gallio.xml b/lib/Gallio.3.2.750/tools/Gallio.xml
deleted file mode 100644
index 604b65c..0000000
--- a/lib/Gallio.3.2.750/tools/Gallio.xml
+++ /dev/null
@@ -1,44449 +0,0 @@
-<?xml version="1.0"?>
-<doc>
-    <assembly>
-        <name>Gallio</name>
-    </assembly>
-    <members>
-        <member name="T:Gallio.Common.Accessor`2">
-            <summary>
-            Represents a method that returns a value of a specified type from the instance of an object.
-            </summary>
-            <remarks>
-            <para>
-            It is usually used to represent the invocation of a type property.
-            </para>
-            </remarks>
-            <typeparam name="T">The type of the object to get the value from.</typeparam>
-            <typeparam name="TValue">The type of the returned value.</typeparam>
-            <param name="obj">The object to get the value from.</param>
-            <returns>The returned value.</returns>
-        </member>
-        <member name="T:Gallio.Common.Action">
-            <summary>
-            An action with no arguments.
-            </summary>
-        </member>
-        <member name="T:Gallio.Common.Action`2">
-            <summary>
-            An action with two arguments.
-            </summary>
-            <typeparam name="T1">The first argument type.</typeparam>
-            <typeparam name="T2">The second argument type.</typeparam>
-            <param name="arg1">The first argument.</param>
-            <param name="arg2">The second argument.</param>
-        </member>
-        <member name="T:Gallio.Common.Action`3">
-            <summary>
-            An action with three arguments.
-            </summary>
-            <typeparam name="T1">The first argument type.</typeparam>
-            <typeparam name="T2">The second argument type.</typeparam>
-            <typeparam name="T3">The third argument type.</typeparam>
-            <param name="arg1">The first argument.</param>
-            <param name="arg2">The second argument.</param>
-            <param name="arg3">The third argument.</param>
-        </member>
-        <member name="T:Gallio.Common.Action`4">
-            <summary>
-            An action with four arguments.
-            </summary>
-            <typeparam name="T1">The first argument type.</typeparam>
-            <typeparam name="T2">The second argument type.</typeparam>
-            <typeparam name="T3">The third argument type.</typeparam>
-            <typeparam name="T4">The fourth argument type.</typeparam>
-            <param name="arg1">The first argument.</param>
-            <param name="arg2">The second argument.</param>
-            <param name="arg3">The third argument.</param>
-            <param name="arg4">The fourth argument.</param>
-        </member>
-        <member name="T:Gallio.Common.Action`5">
-            <summary>
-            An action with five arguments.
-            </summary>
-            <typeparam name="T1">The first argument type.</typeparam>
-            <typeparam name="T2">The second argument type.</typeparam>
-            <typeparam name="T3">The third argument type.</typeparam>
-            <typeparam name="T4">The fourth argument type.</typeparam>
-            <typeparam name="T5">The fifth argument type.</typeparam>
-            <param name="arg1">The first argument.</param>
-            <param name="arg2">The second argument.</param>
-            <param name="arg3">The third argument.</param>
-            <param name="arg4">The fourth argument.</param>
-            <param name="arg5">The fifth argument.</param>
-        </member>
-        <member name="T:Gallio.Common.Collections.EnumerableCounter">
-            <summary>
-            Encapsulates various strategies for counting the number of elements in a collection, an array, or
-            a simple enumerable type.
-            </summary>
-        </member>
-        <member name="M:Gallio.Common.Collections.EnumerableCounter.#ctor(System.Collections.IEnumerable)">
-            <summary>
-            Constructor.
-            </summary>
-            <param name="values">The collection, the array, or the simple enumerable object to count elements.</param>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="values"/> is null.</exception>
-        </member>
-        <member name="M:Gallio.Common.Collections.EnumerableCounter.Count">
-            <summary>
-            Counts the number of elements in a collection, an array, or any other enumerable type, by
-            using the most appropriate strategies.
-            </summary>
-            <returns>An enumeration of counting strategies applicable to the specified enumerable values.</returns>
-        </member>
-        <member name="T:Gallio.Common.Collections.ICountingStrategy">
-            <summary>
-            Represents a strategy for counting the number of elements in a collection, an array, or a simple enumerable type.
-            </summary>
-        </member>
-        <member name="P:Gallio.Common.Collections.ICountingStrategy.Name">
-            <summary>
-            Gets the name of the counting strategy.
-            </summary>
-        </member>
-        <member name="P:Gallio.Common.Collections.ICountingStrategy.Description">
-            <summary>
-            Gets a displayable description of the counting strategy.
-            </summary>
-        </member>
-        <member name="P:Gallio.Common.Collections.ICountingStrategy.Count">
-            <summary>
-            Returns the number of elements found by applying the current counting strategy.
-            </summary>
-            <returns>The number of elements found.</returns>
-        </member>
-        <member name="T:Gallio.Common.Collections.CountingStrategyName">
-            <summary>
-            Name of the existing counting strategies.
-            </summary>
-        </member>
-        <member name="F:Gallio.Common.Collections.CountingStrategyName.ByLengthGetter">
-            <summary>
-            Counts by getting the value returned by the <see cref="P:System.Array.Length"/> property getter.
-            </summary>
-        </member>
-        <member name="F:Gallio.Common.Collections.CountingStrategyName.ByCountGetter">
-            <summary>
-            Counts by getting the value returned by the <see cref="P:System.Collections.ICollection.Count"/> or <see cref="P:System.Collections.Generic.ICollection`1.Count"/> property getter.
-            </summary>
-        </member>
-        <member name="F:Gallio.Common.Collections.CountingStrategyName.ByEnumeratingElements">
-            <summary>
-            Counts by enumerating the elements returned by <see cref="M:System.Collections.IEnumerable.GetEnumerator"/>.
-            </summary>
-        </member>
-        <member name="F:Gallio.Common.Collections.CountingStrategyName.ByReflectedCountGetter">
-            <summary>
-            Counts by getting the value returned by an existing public "Count" property getter.
-            </summary>
-        </member>
-        <member name="T:Gallio.Common.Collections.IPropertySetContainer">
-            <summary>
-            Contains a <see cref="T:Gallio.Common.Collections.PropertySet"/>
-            </summary>
-        </member>
-        <member name="M:Gallio.Common.Collections.IPropertySetContainer.AddProperty(System.String,System.String)">
-            <summary>
-            Adds a property key/value pair.
-            </summary>
-            <param name="key">The property key.</param>
-            <param name="value">The property value.</param>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="key"/> or <paramref name="value"/> is null.</exception>
-            <exception cref="T:System.InvalidOperationException">Thrown if <paramref name="key"/> is already in the property set.</exception>
-        </member>
-        <member name="P:Gallio.Common.Collections.IPropertySetContainer.Properties">
-            <summary>
-            Gets a read-only collection of configuration properties.
-            </summary>
-        </member>
-        <member name="T:Gallio.Common.Comparison">
-            <summary>
-            Represents the method that compares two objects of the same type.
-            </summary>
-            <remarks>
-            <para>
-            This is a non-generic version of <see cref="T:System.Comparison`1"/>.
-            </para>
-            </remarks>
-            <param name="x">The first object to compare.</param>
-            <param name="y">The second object to compare.</param>
-            <returns>a negative value if x is less than y, zero if x equals y, or a positive value if x is greater than y.</returns>
-        </member>
-        <member name="T:Gallio.Common.Concurrency.DegreeOfParallelismProvider">
-            <summary>
-            A function that returns the maximum number of threads that a work scheduler 
-            may use to perform work.  The value may change over time and cause the
-            scheduler to adapt to changing degrees of parallelism.
-            </summary>
-            <returns>The degree of parallelism which must be at least 1.</returns>
-            <seealso cref="T:Gallio.Common.Concurrency.WorkScheduler"/>
-        </member>
-        <member name="T:Gallio.Common.Concurrency.IProcess">
-            <summary>
-            Wrapper for <see cref="T:System.Diagnostics.Process"/> to allow testing.
-            </summary>
-            <seealso cref="T:System.Diagnostics.Process"/>
-        </member>
-        <member name="M:Gallio.Common.Concurrency.IProcess.IsModuleLoaded(System.String)">
-            <summary>
-            Checks whether a module with the specified file name is
-            loaded in the process.
-            </summary>
-            <param name="fileName">The file name.</param>
-            <returns>true if the module is loaded; otherwise, false.</returns>
-        </member>
-        <member name="M:Gallio.Common.Concurrency.IProcess.Kill">
-            <summary>
-            Immediately stops the associated process.
-            </summary>
-            <seealso cref="M:System.Diagnostics.Process.Kill"/>
-        </member>
-        <member name="M:Gallio.Common.Concurrency.IProcess.Refresh">
-            <summary>
-            Discards any information about the associated process
-            that has been cached inside the process object.
-            </summary>
-        </member>
-        <member name="M:Gallio.Common.Concurrency.IProcess.WaitForInputIdle">
-            <summary>
-            Causes the <see cref="T:Gallio.Common.Concurrency.IProcess"/> object to wait indefinitely for
-            the associated process to enter an idle state. This overload applies
-            only to processes with a user interface and, therefore, a message loop.
-            </summary>
-            <returns>true if the associated process has reached an idle state.</returns>
-        </member>
-        <member name="M:Gallio.Common.Concurrency.IProcess.WaitForInputIdle(System.Int32)">
-            <summary>
-            Causes the <see cref="T:Gallio.Common.Concurrency.IProcess"/> object to wait the specified number
-            of milliseconds for the associated process to enter an idle state. This
-            overload applies only to processes with a user interface and, therefore,
-            a message loop.
-            </summary>
-            <param name="milliseconds">
-            A value of 1 to <see cref="F:System.Int32.MaxValue"/> that specifies the amount of
-            time, in milliseconds, to wait for the associated process to become idle.
-            A value of 0 specifies an immediate return, and a value of -1 specifies
-            an infinite wait.
-            </param>
-            <returns>
-            true if the associated process has reached an idle state; otherwise, false.
-            </returns>
-        </member>
-        <member name="P:Gallio.Common.Concurrency.IProcess.HasExited">
-            <summary>
-            Gets a value indicating whether the associated process has been terminated.
-            </summary>
-        </member>
-        <member name="P:Gallio.Common.Concurrency.IProcess.StartInfo">
-            <summary>
-            Gets or sets the properties to passed to the <see cref="M:System.Diagnostics.Process.Start"/>
-            method of the underlying <see cref="T:System.Diagnostics.Process"/>.
-            </summary>
-        </member>
-        <member name="P:Gallio.Common.Concurrency.IProcess.Id">
-            <summary>
-            Gets the unique identifier for the associated process.
-            </summary>
-        </member>
-        <member name="T:Gallio.Common.Concurrency.IProcessCreator">
-            <summary>
-            Wraps the static process creation methods on <see cref="T:System.Diagnostics.Process"/> to allow testing.
-            </summary>
-        </member>
-        <member name="M:Gallio.Common.Concurrency.IProcessCreator.Start(System.Diagnostics.ProcessStartInfo)">
-            <summary>
-            Starts the process and associates it with a new <see cref="T:Gallio.Common.Concurrency.IProcess"/> object.
-            </summary>
-            <param name="startInfo">The process start info.</param>
-            <returns>The new process.</returns>
-        </member>
-        <member name="T:Gallio.Common.Concurrency.IProcessFinder">
-            <summary>
-            Wraps the static process query methods on <see cref="T:System.Diagnostics.Process"/> to allow testing.
-            </summary>
-        </member>
-        <member name="M:Gallio.Common.Concurrency.IProcessFinder.GetProcessesByName(System.String)">
-            <summary>
-            Creates an array of <see cref="T:Gallio.Common.Concurrency.IProcess"/> objects for all
-            processes on the local compuer that share the specified name.
-            </summary>
-            <param name="processName">The friendly name of he process.</param>
-            <returns>An array of <see cref="T:Gallio.Common.Concurrency.IProcess"/> objects.</returns>
-            <seealso cref="M:System.Diagnostics.Process.GetProcessesByName(System.String)"/>
-        </member>
-        <member name="T:Gallio.Common.Concurrency.ProcessCreator">
-            <summary>
-            Default implementation of <see cref="T:Gallio.Common.Concurrency.IProcessCreator"/> using <see cref="T:System.Diagnostics.Process"/>.
-            </summary>
-        </member>
-        <member name="M:Gallio.Common.Concurrency.ProcessCreator.Start(System.Diagnostics.ProcessStartInfo)">
-            <inheritdoc/>
-        </member>
-        <member name="T:Gallio.Common.Concurrency.ProcessFinder">
-            <summary>
-            Default implementation of <see cref="T:Gallio.Common.Concurrency.IProcessFinder"/> using <see cref="T:System.Diagnostics.Process"/>.
-            </summary>
-        </member>
-        <member name="M:Gallio.Common.Concurrency.ProcessFinder.GetProcessesByName(System.String)">
-            <inheritdoc/>
-        </member>
-        <member name="T:Gallio.Common.Concurrency.ProcessWrapper">
-            <summary>
-            Default implementation of <see cref="T:Gallio.Common.Concurrency.IProcess"/> using <see cref="T:System.Diagnostics.Process"/>.
-            </summary>
-        </member>
-        <member name="M:Gallio.Common.Concurrency.ProcessWrapper.#ctor(System.Diagnostics.Process)">
-            <summary>
-            Creates a new process wrapper.
-            </summary>
-            <param name="process">A process.</param>
-            <exception cref="T:System.ArgumentNullException">If <paramref name="process"/> is null.</exception>
-        </member>
-        <member name="M:Gallio.Common.Concurrency.ProcessWrapper.Dispose">
-            <inheritdoc/>
-        </member>
-        <member name="M:Gallio.Common.Concurrency.ProcessWrapper.Dispose(System.Boolean)">
-            <summary>
-            Releases the resources used by the <see cref="T:Gallio.Common.Concurrency.ProcessWrapper"/>.
-            </summary>
-        </member>
-        <member name="M:Gallio.Common.Concurrency.ProcessWrapper.IsModuleLoaded(System.String)">
-            <inheritdoc/>
-        </member>
-        <member name="M:Gallio.Common.Concurrency.ProcessWrapper.Kill">
-            <inheritdoc/>
-        </member>
-        <member name="M:Gallio.Common.Concurrency.ProcessWrapper.Refresh">
-            <inheritdoc/>
-        </member>
-        <member name="M:Gallio.Common.Concurrency.ProcessWrapper.WaitForInputIdle">
-            <inheritdoc/>
-        </member>
-        <member name="M:Gallio.Common.Concurrency.ProcessWrapper.WaitForInputIdle(System.Int32)">
-            <inheritdoc/>
-        </member>
-        <member name="P:Gallio.Common.Concurrency.ProcessWrapper.HasExited">
-            <inheritdoc/>
-        </member>
-        <member name="P:Gallio.Common.Concurrency.ProcessWrapper.StartInfo">
-            <inheritdoc/>
-        </member>
-        <member name="P:Gallio.Common.Concurrency.ProcessWrapper.Id">
-            <inheritdoc/>
-        </member>
-        <member name="T:Gallio.Common.Concurrency.WorkScheduler">
-            <summary>
-            Schedules actions to be run in parallel up to a specified (variable)
-            maximum number of threads.
-            </summary>
-            <remarks>
-            <para>
-            The implementation is designed to support re-entrance while still maintaining an
-            upper bound on active thread count.  To avoid blowing the limit on thread count
-            due to re-entrance the caller's thread is also used to schedule work.
-            </para>
-            <para>
-            The work scheduler supports dynamically adjusting the degree of parallelism
-            as new work is added.
-            </para>
-            </remarks>
-        </member>
-        <member name="M:Gallio.Common.Concurrency.WorkScheduler.#ctor(Gallio.Common.Concurrency.DegreeOfParallelismProvider)">
-            <summary>
-            Creates a work scheduler.
-            </summary>
-            <param name="degreeOfParallelismProvider">A function that determines
-            the current degree of parallelism which may change over time.</param>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="degreeOfParallelismProvider"/>
-            is null.</exception>
-        </member>
-        <member name="M:Gallio.Common.Concurrency.WorkScheduler.Run(System.Collections.Generic.IEnumerable{Gallio.Common.Action})">
-            <summary>
-            Runs a set of actions in parallel up to the current degree of parallelism.
-            </summary>
-            <remarks>
-            <para>
-            The implementation guarantees that the current thread will only be used to
-            run actions from the provided work set; it will not be used to run actions
-            from other concurrently executing work sets.  Other threads will be used
-            to run actions from this work set and from other work sets in the order in
-            which they were enqueued.  Thus this function will return as soon as all
-            of the specified actions have completed even if other work sets have
-            pending work.
-            </para>
-            </remarks>
-            <param name="actions">The actions to run.</param>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="actions"/> is null
-            or contains null.</exception>
-        </member>
-        <member name="T:Gallio.Common.Concurrency.TaskResult">
-            <summary>
-            Holds the value or exception produced by a task.
-            </summary>
-        </member>
-        <member name="M:Gallio.Common.Concurrency.TaskResult.ToString">
-            <inheritdoc />
-        </member>
-        <member name="P:Gallio.Common.Concurrency.TaskResult.HasValue">
-            <summary>
-            Returns true if the task ran to completion and returned a value,
-            or false if an exception was thrown.
-            </summary>
-        </member>
-        <member name="P:Gallio.Common.Concurrency.TaskResult.Value">
-            <summary>
-            Gets the value that was returned by the task.
-            </summary>
-            <exception cref="T:System.InvalidOperationException">Thrown if <see cref="P:Gallio.Common.Concurrency.TaskResult.HasValue"/> is false.</exception>
-        </member>
-        <member name="P:Gallio.Common.Concurrency.TaskResult.Exception">
-            <summary>
-            Gets the exception that was thrown by the task.
-            </summary>
-            <exception cref="T:System.InvalidOperationException">Thrown if <see cref="P:Gallio.Common.Concurrency.TaskResult.HasValue"/> is true.</exception>
-        </member>
-        <member name="T:Gallio.Common.Concurrency.TaskResult`1">
-            <summary>
-            Holds the value or exception produced by a task.
-            </summary>
-        </member>
-        <member name="M:Gallio.Common.Concurrency.TaskResult`1.CreateFromValue(`0)">
-            <summary>
-            Creates a result object containing the value returned by the task.
-            </summary>
-            <returns>The new task result.</returns>
-            <param name="value">The value.</param>
-        </member>
-        <member name="M:Gallio.Common.Concurrency.TaskResult`1.CreateFromException(System.Exception)">
-            <summary>
-            Creates a result object containing the exception thrown by the task.
-            </summary>
-            <param name="exception">The exception.</param>
-            <returns>The new task result.</returns>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="exception"/> is null.</exception>
-        </member>
-        <member name="P:Gallio.Common.Concurrency.TaskResult`1.Value">
-            <summary>
-            Gets the value that was returned by the task.
-            </summary>
-            <exception cref="T:System.InvalidOperationException">Thrown if <see cref="P:Gallio.Common.Concurrency.TaskResult.HasValue"/> is false.</exception>
-        </member>
-        <member name="T:Gallio.Common.IO.ConsoleRedirection">
-            <summary>
-            Redirects the console streams.
-            </summary>
-        </member>
-        <member name="M:Gallio.Common.IO.ConsoleRedirection.#ctor(System.IO.TextWriter,System.IO.TextWriter)">
-            <summary>
-            Redirect console output and error stream and disables the console input stream.
-            </summary>
-            <param name="consoleOut">The new console output writer.</param>
-            <param name="consoleError">The new console error writer.</param>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="consoleOut"/>
-            or <paramref name="consoleError"/> is null.</exception>
-        </member>
-        <member name="M:Gallio.Common.IO.ConsoleRedirection.Dispose">
-            <summary>
-            Resets the console streams as they were initially.
-            </summary>
-        </member>
-        <member name="M:Gallio.Common.IO.ConsoleRedirection.Dispose(System.Boolean)">
-            <summary>
-            Resets the console streams as they were initially.
-            </summary>
-            <param name="disposing">True if <see cref="M:Gallio.Common.IO.ConsoleRedirection.Dispose"/> was called directly.</param>
-        </member>
-        <member name="T:Gallio.Common.IO.Content">
-            <summary>
-            Abstract representation of a binary or text resource.
-            </summary>
-            <remarks>
-            <para>
-            Different kind of resources are supported:
-            <list type="bullet">
-            <item>Inline resources from a storage in memory.</item>
-            <item>Embedded resources from an assembly manifest.</item>
-            <item>File resources.</item>
-            </list>
-            </para>
-            </remarks>
-        </member>
-        <member name="M:Gallio.Common.IO.Content.OpenStream">
-            <summary>
-            Opens the current resource as a <see cref="T:System.IO.Stream"/>.
-            </summary>
-            <returns>The stream.</returns>
-        </member>
-        <member name="M:Gallio.Common.IO.Content.OpenTextReader">
-            <summary>
-            Opens the current resource as a <see cref="T:System.IO.TextReader"/>.
-            </summary>
-            <returns>The text reader.</returns>
-        </member>
-        <member name="P:Gallio.Common.IO.Content.IsDynamic">
-            <summary>
-            Returns true if the contents are dynamic, or false if they are static.
-            </summary>
-            <remarks>
-            <para>
-            Static contents can only change if the test assembly is recompiled.
-            </para>
-            </remarks>
-        </member>
-        <member name="P:Gallio.Common.IO.Content.CodeElementInfo">
-            <summary>
-            Gets or sets a <see cref="T:Gallio.Common.Reflection.ICodeElementInfo"/> that is used to locate the assembly and namespace within which to resolve a manifest resource.
-            </summary>
-        </member>
-        <member name="T:Gallio.Common.IO.ContentEmbeddedResource">
-            <summary>
-            Represents a resource embedded in an assembly file.
-            </summary>
-        </member>
-        <member name="M:Gallio.Common.IO.ContentEmbeddedResource.#ctor(System.String,System.Type)">
-            <summary>
-            Constructs the representation of an embedded resource.
-            </summary>
-            <param name="name">The qualified or unqualified name of the resource.</param>
-            <param name="typeScope">When <paramref name="name"/> is unqualified, a type used to locate the assembly and namespace within which to resolve the manifest resource.</param>
-        </member>
-        <member name="M:Gallio.Common.IO.ContentEmbeddedResource.OpenStream">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.Common.IO.ContentEmbeddedResource.OpenTextReader">
-            <inheritdoc />
-        </member>
-        <member name="P:Gallio.Common.IO.ContentEmbeddedResource.IsDynamic">
-            <inheritdoc />
-        </member>
-        <member name="T:Gallio.Common.IO.ContentFile">
-            <summary>
-            Representation of a file resource.
-            </summary>
-        </member>
-        <member name="M:Gallio.Common.IO.ContentFile.#ctor(System.String)">
-            <summary>
-            Constructs the representation of a file resource.
-            </summary>
-            <param name="filePath">The path of the file.</param>
-        </member>
-        <member name="M:Gallio.Common.IO.ContentFile.#ctor(System.String,Gallio.Common.IO.IFileSystem)">
-            <summary>
-            Constructs the representation of a file resource.
-            </summary>
-            <param name="filePath">The path of the file.</param>
-            <param name="fileSystem">A file system wrapper</param>
-        </member>
-        <member name="M:Gallio.Common.IO.ContentFile.OpenStream">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.Common.IO.ContentFile.OpenTextReader">
-            <inheritdoc />
-        </member>
-        <member name="P:Gallio.Common.IO.ContentFile.IsDynamic">
-            <inheritdoc />
-        </member>
-        <member name="T:Gallio.Common.IO.ContentInline">
-            <summary>
-            Represents an inline memory resource.
-            </summary>
-        </member>
-        <member name="M:Gallio.Common.IO.ContentInline.#ctor(System.String)">
-            <summary>
-            Constructs the representation of an inline memory resource.
-            </summary>
-            <param name="contents">The content of the resource as a string.</param>
-        </member>
-        <member name="M:Gallio.Common.IO.ContentInline.OpenStream">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.Common.IO.ContentInline.OpenTextReader">
-            <inheritdoc />
-        </member>
-        <member name="P:Gallio.Common.IO.ContentInline.IsDynamic">
-            <inheritdoc />
-        </member>
-        <member name="T:Gallio.Common.Lazy`1">
-            <summary>
-            Lazy computation type.
-            </summary>
-            <typeparam name="T">The encapsulated type.</typeparam>
-        </member>
-        <member name="M:Gallio.Common.Lazy`1.#ctor(Gallio.Common.Func{`0})">
-            <summary>
-            Constructor.
-            </summary>
-            <param name="func">A function which computes the value on first request.</param>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="func"/> is null.</exception>
-        </member>
-        <member name="P:Gallio.Common.Lazy`1.Value">
-            <summary>
-            Gets the value.
-            </summary>
-        </member>
-        <member name="T:Gallio.Common.Markup.AttachmentType">
-            <summary>
-            Specifies the type of the contents of an embedded attachment.
-            </summary>
-        </member>
-        <member name="F:Gallio.Common.Markup.AttachmentType.Text">
-            <summary>
-            The attachment is encoded as a text string.
-            </summary>
-        </member>
-        <member name="F:Gallio.Common.Markup.AttachmentType.Binary">
-            <summary>
-            The attachment is a binary file either directly available as a file, or encoded as base 64 text string.
-            </summary>
-        </member>
-        <member name="T:Gallio.Common.Markup.MarkupNormalizationUtils">
-            <summary>
-            Utilities for normalizing markup contents.
-            </summary>
-        </member>
-        <member name="M:Gallio.Common.Markup.MarkupNormalizationUtils.NormalizeContentType(System.String)">
-            <summary>
-            Normalizes a content type.
-            </summary>
-            <param name="contentType">The content type, or null if none.</param>
-            <returns>The normalized content type, or null if none.  May be the same instance if <paramref name="contentType"/>
-            was already normalized.</returns>
-        </member>
-        <member name="M:Gallio.Common.Markup.MarkupNormalizationUtils.NormalizeAttachmentName(System.String)">
-            <summary>
-            Normalizes an attachment name.
-            </summary>
-            <param name="attachmentName">The attachment name, or null if none.</param>
-            <returns>The normalized attachment name, or null if none.  May be the same instance if <paramref name="attachmentName"/>
-            was already normalized.</returns>
-        </member>
-        <member name="M:Gallio.Common.Markup.MarkupNormalizationUtils.NormalizeStreamName(System.String)">
-            <summary>
-            Normalizes a stream name.
-            </summary>
-            <param name="streamName">The stream name, or null if none.</param>
-            <returns>The normalized stream name, or null if none.  May be the same instance if <paramref name="streamName"/>
-            was already normalized.</returns>
-        </member>
-        <member name="M:Gallio.Common.Markup.MarkupNormalizationUtils.NormalizeSectionName(System.String)">
-            <summary>
-            Normalizes a section name.
-            </summary>
-            <param name="sectionName">The section name, or null if none.</param>
-            <returns>The normalized section name, or null if none.  May be the same instance if <paramref name="sectionName"/>
-            was already normalized.</returns>
-        </member>
-        <member name="M:Gallio.Common.Markup.MarkupNormalizationUtils.NormalizeText(System.String)">
-            <summary>
-            Normalizes markup text.
-            </summary>
-            <param name="text">The text, or null if none.</param>
-            <returns>The normalized text, or null if none.  May be the same instance if <paramref name="text"/>
-            was already normalized.</returns>
-        </member>
-        <member name="T:Gallio.Common.Mathematics.ChiSquareTest">
-            <summary>
-            Implementation of a Chi-square test (http://en.wikipedia.org/wiki/Chi_square_test)
-            that calculates the "difference" between an expected and an actual statistical distribution.
-            </summary>
-        </member>
-        <member name="M:Gallio.Common.Mathematics.ChiSquareTest.#ctor(System.Double,System.Collections.Generic.ICollection{System.Double},System.Int32)">
-            <summary>
-            Runs a Chi-square test.
-            </summary>
-            <remarks>
-            <para>
-            Given the observed events (<paramref name="actual"/>) and the expected events (<paramref name="expected"/>), 
-            calculates the number of degrees of freedom, the chi-square value, and the significance probability.
-            </para>
-            <para>
-            A small value of the significance probability indicates a significant difference between the distributions.
-            </para>
-            </remarks>
-            <param name="expected"></param>
-            <param name="actual"></param>
-            <param name="numberOfConstraints"></param>
-        </member>
-        <member name="P:Gallio.Common.Mathematics.ChiSquareTest.DegreesOfFreedom">
-            <summary>
-            Gets the resulting number of degrees of freedom.
-            </summary>
-        </member>
-        <member name="P:Gallio.Common.Mathematics.ChiSquareTest.ChiSquareValue">
-            <summary>
-            Gets the resulting Chi-square value.
-            </summary>
-        </member>
-        <member name="P:Gallio.Common.Mathematics.ChiSquareTest.TwoTailedPValue">
-            <summary>
-            Gets the resulting significance probability.
-            </summary>
-        </member>
-        <member name="T:Gallio.Common.Mathematics.Gamma">
-            <summary>
-            Helper methods to calculate the Gamma function (http://en.wikipedia.org/wiki/Gamma_function).
-            </summary>
-        </member>
-        <member name="M:Gallio.Common.Mathematics.Gamma.IncompleteGamma(System.Double,System.Double)">
-            <summary>
-            Returns the incomplete Gamma function Q(a,x).
-            </summary>
-            <param name="a"></param>
-            <param name="x"></param>
-            <returns></returns>
-        </member>
-        <member name="T:Gallio.Common.Mathematics.NamespaceDoc">
-            <summary>
-            The Gallio.Common.Math namespace provides advanced mathematical 
-            functions and helper classes not found in <see cref="T:System.Math"/>.
-            </summary>
-        </member>
-        <member name="T:Gallio.Common.Messaging.IMessageExchangeLink">
-            <summary>
-            An interface implemented by the server and registered on the server remoting channel
-            to allow message exchange with the client.
-            </summary>
-            <remarks>
-            <para>
-            This is interim API to be used until the new message broker is ready.
-            </para>
-            </remarks>
-        </member>
-        <member name="M:Gallio.Common.Messaging.IMessageExchangeLink.Receive(System.TimeSpan)">
-            <summary>
-            Gets the next message.
-            </summary>
-            <param name="timeout">The maximum amount of time to wait for a message.</param>
-            <returns>The next message, or null if a timeout occurred.</returns>
-        </member>
-        <member name="M:Gallio.Common.Messaging.IMessageExchangeLink.Send(Gallio.Common.Messaging.Message)">
-            <summary>
-            Sends a message.
-            </summary>
-            <param name="message">The message to send.</param>
-        </member>
-        <member name="T:Gallio.Common.Messaging.MessageConsumer">
-            <summary>
-            A message consumer provides a simple pattern for handling messages based on their type.
-            </summary>
-            <remarks>
-            <para>
-            A message consumer consists of a series of typed handler clauses which are traversed in
-            order until a handler which matches the message type is found.
-            </para>
-            </remarks>
-            <example>
-            <code>
-            <![CDATA[
-            MessageConsumer consumer = new MessageConsumer()
-                .Handle<FooMessage>(message => DoSomethingWithFooMessage(message))
-                .Handle<BarMessage>(message => DoSomethingWithBarMessage(message))
-                .Otherwise(message => throw new NotSupportedException());
-                
-            consumer.Consume(new FooMessage());
-            consumer.Consume(new BarMessage());
-            ]]>
-            </code>
-            </example>
-        </member>
-        <member name="T:Gallio.Common.Messaging.IMessageSink">
-            <summary>
-            Publishes messages directly to a subscriber.
-            </summary>
-        </member>
-        <member name="M:Gallio.Common.Messaging.IMessageSink.Publish(Gallio.Common.Messaging.Message)">
-            <summary>
-            Publishes a message.
-            </summary>
-            <param name="message">The message.</param>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="message"/> is null.</exception>
-            <exception cref="T:Gallio.Common.Validation.ValidationException">Thrown if <paramref name="message"/> is not valid.</exception>
-        </member>
-        <member name="M:Gallio.Common.Messaging.MessageConsumer.#ctor">
-            <summary>
-            Creates a new message consumer with no handler clauses.
-            </summary>
-        </member>
-        <member name="M:Gallio.Common.Messaging.MessageConsumer.Consume(Gallio.Common.Messaging.Message)">
-            <summary>
-            Consumes a message.
-            </summary>
-            <param name="message">The message to consume.</param>
-            <returns>True if the message was consumed by a handler, false if no handler could consume it.</returns>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="message"/> is null.</exception>
-            <exception cref="T:Gallio.Common.Validation.ValidationException">Thrown if <paramref name="message"/> is not valid.</exception>
-        </member>
-        <member name="M:Gallio.Common.Messaging.MessageConsumer.Handle``1(System.Action{``0})">
-            <summary>
-            Adds a handler for a particular message type.
-            </summary>
-            <typeparam name="TMessage">The message type.</typeparam>
-            <param name="handlerAction">The message handler action.</param>
-            <returns>The message consumer.</returns>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="handlerAction"/> is null.</exception>
-        </member>
-        <member name="M:Gallio.Common.Messaging.MessageConsumer.Otherwise(System.Action{Gallio.Common.Messaging.Message})">
-            <summary>
-            Adds a catch-all handler.
-            </summary>
-            <param name="handlerAction">The message handler action.</param>
-            <returns>The message consumer.</returns>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="handlerAction"/> is null.</exception>
-        </member>
-        <member name="T:Gallio.Common.Messaging.NamespaceDoc">
-            <summary>
-            The Gallio.Common.Messaging namespace provides an abstraction for
-            sending messages between components.
-            </summary>
-        </member>
-        <member name="T:Gallio.Common.Caching.DiskCacheException">
-            <summary>
-            The type of exception thrown when an error occurs while manipulating the disk cache.
-            </summary>
-        </member>
-        <member name="M:Gallio.Common.Caching.DiskCacheException.#ctor">
-            <summary>
-            Creates an exception.
-            </summary>
-        </member>
-        <member name="M:Gallio.Common.Caching.DiskCacheException.#ctor(System.String)">
-            <summary>
-            Creates an exception.
-            </summary>
-            <param name="message">The message.</param>
-        </member>
-        <member name="M:Gallio.Common.Caching.DiskCacheException.#ctor(System.String,System.Exception)">
-            <summary>
-            Creates an exception.
-            </summary>
-            <param name="message">The message.</param>
-            <param name="innerException">The inner exception.</param>
-        </member>
-        <member name="M:Gallio.Common.Caching.DiskCacheException.#ctor(System.Runtime.Serialization.SerializationInfo,System.Runtime.Serialization.StreamingContext)">
-            <summary>
-            Creates an exception from serialization info.
-            </summary>
-            <param name="info">The serialization info.</param>
-            <param name="context">The streaming context.</param>
-        </member>
-        <member name="T:Gallio.Common.Caching.IDiskCache">
-            <summary>
-            A disk cache manages temporary files and directories stored on disk and
-            arranged into groups associated with arbitrary string keys.
-            </summary>
-            <remarks>
-            <para>
-            The files and directories within each group are assumed to have the same lifetime.
-            </para>
-            </remarks>
-            <example>
-            Write a file to the cache:
-            <code><![CDATA[
-            IDiskCache cache = ... // Get the cache.
-            
-            using (var writer = new StreamWriter(cache.Groups["SomeKey"].OpenFile("Foo",
-                FileMode.OpenOrCreate, FileAccess.Write, FileShare.Exclusive)))
-            {
-                writer.WriteLine("Contents...");
-            }
-            ]]></code>
-            </example>
-        </member>
-        <member name="M:Gallio.Common.Caching.IDiskCache.Purge">
-            <summary>
-            Deletes all items in the cache.
-            </summary>
-            <exception cref="T:Gallio.Common.Caching.DiskCacheException">Thrown if an error occurs.</exception>
-        </member>
-        <member name="P:Gallio.Common.Caching.IDiskCache.Groups">
-            <summary>
-            Gets the collection of disk cache groups.
-            </summary>
-        </member>
-        <member name="T:Gallio.Common.Caching.IDiskCacheGroup">
-            <summary>
-            A disk cache group represents an indexed partition of the disk cache.
-            </summary>
-            <remarks>
-            <para>
-            It is physically manifested as a directory on disk and may contain any
-            number of related files or directories with the same lifetime.
-            </para>
-            </remarks>
-        </member>
-        <member name="M:Gallio.Common.Caching.IDiskCacheGroup.Create">
-            <summary>
-            Creates the group if it does not exist.
-            </summary>
-            <exception cref="T:Gallio.Common.Caching.DiskCacheException">Thrown if an error occurs.</exception>
-        </member>
-        <member name="M:Gallio.Common.Caching.IDiskCacheGroup.Delete">
-            <summary>
-            Deletes the group and all of its contents if any.
-            </summary>
-            <exception cref="T:Gallio.Common.Caching.DiskCacheException">Thrown if an error occurs.</exception>
-        </member>
-        <member name="M:Gallio.Common.Caching.IDiskCacheGroup.GetFileInfo(System.String)">
-            <summary>
-            Gets information about a file within the group.
-            </summary>
-            <remarks>
-            <para>
-            This method will succeed even if the file or the group does not exist.
-            </para>
-            </remarks>
-            <param name="relativeFilePath">The relative path of the file within the group.</param>
-            <returns>The file info.</returns>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="relativeFilePath"/> is null.</exception>
-            <exception cref="T:Gallio.Common.Caching.DiskCacheException">Thrown if an error occurs.</exception>
-        </member>
-        <member name="M:Gallio.Common.Caching.IDiskCacheGroup.GetSubdirectoryInfo(System.String)">
-            <summary>
-            Gets information about a directory within the group.
-            </summary>
-            <remarks>
-            <para>
-            This method will succeed even if the directory or the group does not exist.
-            </para>
-            </remarks>
-            <param name="relativeDirectoryPath">The relative path of the directory within the group.</param>
-            <returns>The directory info.</returns>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="relativeDirectoryPath"/> is null.</exception>
-            <exception cref="T:Gallio.Common.Caching.DiskCacheException">Thrown if an error occurs.</exception>
-        </member>
-        <member name="M:Gallio.Common.Caching.IDiskCacheGroup.OpenFile(System.String,System.IO.FileMode,System.IO.FileAccess,System.IO.FileShare)">
-            <summary>
-            Opens a file within the group.
-            </summary>
-            <remarks>
-            <para>
-            If a new file is being created, automatically create the group and the
-            containing directory for the file.
-            </para>
-            </remarks>
-            <param name="relativeFilePath">The relative path of the file to open within the group.</param>
-            <param name="mode">The file open mode.</param>
-            <param name="access">The file access mode.</param>
-            <param name="share">The file sharing mode.</param>
-            <returns>The file stream.</returns>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="relativeFilePath"/> is null.</exception>
-            <exception cref="T:Gallio.Common.Caching.DiskCacheException">Thrown if an error occurs.</exception>
-        </member>
-        <member name="M:Gallio.Common.Caching.IDiskCacheGroup.CreateSubdirectory(System.String)">
-            <summary>
-            Creates a directory within the group.
-            </summary>
-            <param name="relativeDirectoryPath">The relative path of the directory to create within the group.</param>
-            <returns>Directory information for the directory that was created.</returns>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="relativeDirectoryPath"/> is null.</exception>
-            <exception cref="T:Gallio.Common.Caching.DiskCacheException">Thrown if an error occurs.</exception>
-        </member>
-        <member name="P:Gallio.Common.Caching.IDiskCacheGroup.Cache">
-            <summary>
-            Gets the disk cache that contains the group.
-            </summary>
-        </member>
-        <member name="P:Gallio.Common.Caching.IDiskCacheGroup.Key">
-            <summary>
-            Gets the key of the group.
-            </summary>
-        </member>
-        <member name="P:Gallio.Common.Caching.IDiskCacheGroup.Location">
-            <summary>
-            Gets the <see cref="T:System.IO.DirectoryInfo"/> that represents the physical
-            storage location of the disk cache group in the filesystem.
-            </summary>
-        </member>
-        <member name="P:Gallio.Common.Caching.IDiskCacheGroup.Exists">
-            <summary>
-            Returns true if the group exists on disk.
-            </summary>
-            <exception cref="T:Gallio.Common.Caching.DiskCacheException">Thrown if an error occurs.</exception>
-        </member>
-        <member name="T:Gallio.Common.Caching.IDiskCacheGroupCollection">
-            <summary>
-            Represents a collection of groups in a disk cache indexed by an aritrary key string.
-            </summary>
-        </member>
-        <member name="P:Gallio.Common.Caching.IDiskCacheGroupCollection.Item(System.String)">
-            <summary>
-            Gets the group with the specified key.
-            </summary>
-            <param name="key">The key.</param>
-            <returns>The group.</returns>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="key"/> is null.</exception>
-        </member>
-        <member name="T:Gallio.Common.Caching.NamespaceDoc">
-            <summary>
-            The Gallio.Common.Caching namespace contains types related to caching.
-            </summary>
-        </member>
-        <member name="T:Gallio.Common.Caching.SimpleDiskCache">
-            <summary>
-            A simple disk cache that stores its contents in a particular directory using hashes
-            of the key values to ensure uniqueness.
-            </summary>
-        </member>
-        <member name="M:Gallio.Common.Caching.SimpleDiskCache.#ctor(System.String)">
-            <summary>
-            Creates a simple disk cache.
-            </summary>
-            <param name="cacheDirectoryPath">The path of the cache directory.</param>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="cacheDirectoryPath"/> is null.</exception>
-        </member>
-        <member name="M:Gallio.Common.Caching.SimpleDiskCache.Purge">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.Common.Caching.SimpleDiskCache.GetGroup(System.String)">
-            <summary>
-            Gets the group with the given key.
-            </summary>
-            <param name="key">The key, nor null.</param>
-            <returns>The cache group.</returns>
-        </member>
-        <member name="P:Gallio.Common.Caching.SimpleDiskCache.CacheDirectoryPath">
-            <summary>
-            Gets the path of the cache directory.
-            </summary>
-        </member>
-        <member name="P:Gallio.Common.Caching.SimpleDiskCache.Groups">
-            <inheritdoc />
-        </member>
-        <member name="T:Gallio.Common.Caching.SimpleDiskCache.Group">
-            <summary>
-            Represents a disk cache group.
-            </summary>
-        </member>
-        <member name="M:Gallio.Common.Caching.SimpleDiskCache.Group.#ctor(Gallio.Common.Caching.IDiskCache,System.String,System.IO.DirectoryInfo)">
-            <summary>
-            Creates a group.
-            </summary>
-            <param name="cache">The cache.</param>
-            <param name="key">The cache group key.</param>
-            <param name="location">The location of the cache group.</param>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="cache"/>,
-            <paramref name="key"/> or <paramref name="location"/> is null.</exception>
-        </member>
-        <member name="M:Gallio.Common.Caching.SimpleDiskCache.Group.Create">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.Common.Caching.SimpleDiskCache.Group.Delete">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.Common.Caching.SimpleDiskCache.Group.GetFileInfo(System.String)">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.Common.Caching.SimpleDiskCache.Group.GetSubdirectoryInfo(System.String)">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.Common.Caching.SimpleDiskCache.Group.OpenFile(System.String,System.IO.FileMode,System.IO.FileAccess,System.IO.FileShare)">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.Common.Caching.SimpleDiskCache.Group.CreateSubdirectory(System.String)">
-            <inheritdoc />
-        </member>
-        <member name="P:Gallio.Common.Caching.SimpleDiskCache.Group.Cache">
-            <inheritdoc />
-        </member>
-        <member name="P:Gallio.Common.Caching.SimpleDiskCache.Group.Key">
-            <inheritdoc />
-        </member>
-        <member name="P:Gallio.Common.Caching.SimpleDiskCache.Group.Location">
-            <inheritdoc />
-        </member>
-        <member name="P:Gallio.Common.Caching.SimpleDiskCache.Group.Exists">
-            <inheritdoc />
-        </member>
-        <member name="T:Gallio.Common.Caching.TemporaryDiskCache">
-            <summary>
-            A disk cache that stores its contents in the user's temporary directory.
-            </summary>
-            <seealso cref="M:System.IO.Path.GetTempPath"/>
-        </member>
-        <member name="F:Gallio.Common.Caching.TemporaryDiskCache.DefaultCacheDirectoryName">
-            <summary>
-            The default cache directory name.
-            </summary>
-        </member>
-        <member name="M:Gallio.Common.Caching.TemporaryDiskCache.#ctor(System.String)">
-            <summary>
-            Creates a temporary disk cache within the specified subdirectory of the user's temporary directory.
-            </summary>
-            <param name="cacheDirectoryName">The name of the cache subdirectory.</param>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="cacheDirectoryName"/> is null.</exception>
-        </member>
-        <member name="M:Gallio.Common.Caching.TemporaryDiskCache.#ctor">
-            <summary>
-            Creates a temporary disk cache within the <see cref="F:Gallio.Common.Caching.TemporaryDiskCache.DefaultCacheDirectoryName"/> 
-            subdirectory of the user's temporary directory.
-            </summary>
-        </member>
-        <member name="T:Gallio.Common.Collections.ArrayEqualityComparer`1">
-            <summary>
-            Compares arrays for equality by element.
-            </summary>
-        </member>
-        <member name="F:Gallio.Common.Collections.ArrayEqualityComparer`1.Default">
-            <summary>
-            Gets a default instance of the array equality comparer.
-            </summary>
-        </member>
-        <member name="M:Gallio.Common.Collections.ArrayEqualityComparer`1.#ctor">
-            <summary>
-            Creates a default array equality comparer.
-            </summary>
-        </member>
-        <member name="M:Gallio.Common.Collections.ArrayEqualityComparer`1.#ctor(System.Collections.Generic.IEqualityComparer{`0})">
-            <summary>
-            Creates an array equality comparer using the specified element comparer.
-            </summary>
-            <param name="elementComparer">The comparer to use to compare individual elements,
-            or null to use <see cref="P:System.Collections.Generic.EqualityComparer`1.Default"/>.</param>
-        </member>
-        <member name="M:Gallio.Common.Collections.ArrayEqualityComparer`1.Equals(`0[],`0[])">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.Common.Collections.ArrayEqualityComparer`1.GetHashCode(`0[])">
-            <inheritdoc />
-        </member>
-        <member name="T:Gallio.Common.Collections.CollectionUtils">
-            <summary>
-            Utility functions for manipulating collections.
-            </summary>
-        </member>
-        <member name="M:Gallio.Common.Collections.CollectionUtils.ConvertAllToArray``2(System.Collections.ICollection,System.Converter{``0,``1})">
-            <summary>
-            Converts all elements of the input collection and returns the collected results as an array
-            of the same size.
-            </summary>
-            <typeparam name="TInput">The input type.</typeparam>
-            <typeparam name="TOutput">The output type.</typeparam>
-            <param name="input">The input collection.</param>
-            <param name="converter">The conversion function to apply to each element.</param>
-            <returns>The output array.</returns>
-        </member>
-        <member name="M:Gallio.Common.Collections.CollectionUtils.ToArray``1(System.Collections.ICollection)">
-            <summary>
-            Copies all of the elements of the input collection to an array.
-            </summary>
-            <typeparam name="T">The element type.</typeparam>
-            <param name="collection">The input collection.</param>
-            <returns>The output array.</returns>
-        </member>
-        <member name="M:Gallio.Common.Collections.CollectionUtils.Find``1(System.Collections.IEnumerable,System.Predicate{``0})">
-            <summary>
-            Returns the first element of the input enumeration for which the specified
-            predicate returns true.
-            </summary>
-            <typeparam name="T">The element type.</typeparam>
-            <param name="enumeration">The input enumeration.</param>
-            <param name="predicate">The predicate.</param>
-            <returns>The first matching value or the default for the type if not found.</returns>
-        </member>
-        <member name="M:Gallio.Common.Collections.CollectionUtils.ConstantArray``1(``0,System.Int32)">
-            <summary>
-            Returns an array of the specified length, filled with the specifed constant value.
-            </summary>
-            <typeparam name="T">The type of the array.</typeparam>
-            <param name="value">The constant value.</param>
-            <param name="length">The length of the array.</param>
-            <returns>The resulting array.</returns>
-        </member>
-        <member name="T:Gallio.Common.Collections.CovariantList`2">
-            <summary>
-            A covariant list converts a list of the input type to a
-            read-only list of the more generic output type.  The wrapped
-            list can be used to mimic covariance in method return types.
-            </summary>
-            <typeparam name="TInput">The input list type.</typeparam>
-            <typeparam name="TOutput">The output list type.</typeparam>
-        </member>
-        <member name="M:Gallio.Common.Collections.CovariantList`2.#ctor(System.Collections.Generic.IList{`0})">
-            <summary>
-            Creates a wrapper for the specified list.
-            </summary>
-            <param name="inputList">The input list.</param>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="inputList"/> is null.</exception>
-        </member>
-        <member name="M:Gallio.Common.Collections.CovariantList`2.CopyTo(`1[],System.Int32)">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.Common.Collections.CovariantList`2.Contains(`1)">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.Common.Collections.CovariantList`2.IndexOf(`1)">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.Common.Collections.CovariantList`2.GetEnumerator">
-            <inheritdoc />
-        </member>
-        <member name="P:Gallio.Common.Collections.CovariantList`2.Count">
-            <inheritdoc />
-        </member>
-        <member name="P:Gallio.Common.Collections.CovariantList`2.Item(System.Int32)">
-            <summary>
-            Gets an item from the list with the specified index.
-            </summary>
-            <param name="index">The index.</param>
-            <returns>The item.</returns>
-            <exception cref="T:System.ArgumentOutOfRangeException">Thrown if <paramref name="index"/> is out of range.</exception>
-        </member>
-        <member name="P:Gallio.Common.Collections.CovariantList`2.IsReadOnly">
-            <inheritdoc />
-        </member>
-        <member name="T:Gallio.Common.Collections.EmptyArray`1">
-            <summary>
-            Provides a singleton empty array instance.
-            </summary>
-            <typeparam name="T">The type of array to provide.</typeparam>
-        </member>
-        <member name="F:Gallio.Common.Collections.EmptyArray`1.Instance">
-            <summary>
-            An empty array of type <typeparamref name="T"/>.
-            </summary>
-        </member>
-        <member name="T:Gallio.Common.Collections.EmptyDictionary`2">
-            <summary>
-            A read-only empty dictionary.
-            </summary>
-            <typeparam name="TKey">The dictionary key type.</typeparam>
-            <typeparam name="TValue">The dictionary value type.</typeparam>
-        </member>
-        <member name="F:Gallio.Common.Collections.EmptyDictionary`2.Instance">
-            <summary>
-            A read-only empty dictionary instance.
-            </summary>
-        </member>
-        <member name="M:Gallio.Common.Collections.EmptyDictionary`2.ContainsKey(`0)">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.Common.Collections.EmptyDictionary`2.Add(`0,`1)">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.Common.Collections.EmptyDictionary`2.Remove(`0)">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.Common.Collections.EmptyDictionary`2.TryGetValue(`0,`1@)">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.Common.Collections.EmptyDictionary`2.Add(System.Collections.Generic.KeyValuePair{`0,`1})">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.Common.Collections.EmptyDictionary`2.Clear">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.Common.Collections.EmptyDictionary`2.Contains(System.Collections.Generic.KeyValuePair{`0,`1})">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.Common.Collections.EmptyDictionary`2.CopyTo(System.Collections.Generic.KeyValuePair{`0,`1}[],System.Int32)">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.Common.Collections.EmptyDictionary`2.Remove(System.Collections.Generic.KeyValuePair{`0,`1})">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.Common.Collections.EmptyDictionary`2.GetEnumerator">
-            <inheritdoc cref="M:System.Collections.Generic.IEnumerable`1.GetEnumerator"/>
-        </member>
-        <member name="P:Gallio.Common.Collections.EmptyDictionary`2.Item(`0)">
-            <inheritdoc />
-        </member>
-        <member name="P:Gallio.Common.Collections.EmptyDictionary`2.Keys">
-            <inheritdoc />
-        </member>
-        <member name="P:Gallio.Common.Collections.EmptyDictionary`2.Values">
-            <inheritdoc />
-        </member>
-        <member name="P:Gallio.Common.Collections.EmptyDictionary`2.Count">
-            <inheritdoc />
-        </member>
-        <member name="P:Gallio.Common.Collections.EmptyDictionary`2.IsReadOnly">
-            <inheritdoc />
-        </member>
-        <member name="T:Gallio.Common.Collections.GenericCollectionUtils">
-            <summary>
-            Utility functions for manipulating generic collections.
-            </summary>
-        </member>
-        <member name="M:Gallio.Common.Collections.GenericCollectionUtils.ConvertInPlace``1(System.Collections.Generic.IList{``0},System.Converter{``0,``0})">
-            <summary>
-            Converts each element of the input collection and stores the result in place.
-            </summary>
-            <typeparam name="T">The item type.</typeparam>
-            <param name="list">The list to mutate.</param>
-            <param name="converter">The conversion function to apply to each element.</param>
-        </member>
-        <member name="M:Gallio.Common.Collections.GenericCollectionUtils.ConvertAndCopyAll``2(System.Collections.Generic.ICollection{``0},System.Collections.Generic.IList{``1},System.Converter{``0,``1})">
-            <summary>
-            Converts each element of the input collection and stores the result in the
-            output list using the same index.  The output list must be at least as
-            large as the input list.
-            </summary>
-            <typeparam name="TInput">The input type.</typeparam>
-            <typeparam name="TOutput">The output type.</typeparam>
-            <param name="input">The input list.</param>
-            <param name="output">The output list.</param>
-            <param name="converter">The conversion function to apply to each element.</param>
-        </member>
-        <member name="M:Gallio.Common.Collections.GenericCollectionUtils.ConvertAndAddAll``2(System.Collections.Generic.ICollection{``0},System.Collections.Generic.ICollection{``1},System.Converter{``0,``1})">
-            <summary>
-            Converts each element of the input collection and adds the result to the
-            output collection succession in the same order.
-            </summary>
-            <typeparam name="TInput">The input type.</typeparam>
-            <typeparam name="TOutput">The output type.</typeparam>
-            <param name="input">The input list.</param>
-            <param name="output">The output list.</param>
-            <param name="converter">The conversion function to apply to each element.</param>
-        </member>
-        <member name="M:Gallio.Common.Collections.GenericCollectionUtils.ConvertAllToArray``2(System.Collections.Generic.ICollection{``0},System.Converter{``0,``1})">
-            <summary>
-            Converts each element of the input collection and returns the collected results as an array
-            of the same size.
-            </summary>
-            <typeparam name="TInput">The input type.</typeparam>
-            <typeparam name="TOutput">The output type.</typeparam>
-            <param name="input">The input collection.</param>
-            <param name="converter">The conversion function to apply to each element.</param>
-            <returns>The output array.</returns>
-        </member>
-        <member name="M:Gallio.Common.Collections.GenericCollectionUtils.ToArray``1(System.Collections.Generic.IEnumerable{``0})">
-            <summary>
-            Copies all of the elements of the input enumerable to an array.
-            </summary>
-            <typeparam name="T">The element type.</typeparam>
-            <param name="enumerable">The input enumerable.</param>
-            <returns>The output array.</returns>
-        </member>
-        <member name="M:Gallio.Common.Collections.GenericCollectionUtils.ToArray``1(System.Collections.Generic.ICollection{``0})">
-            <summary>
-            Copies all of the elements of the input collection to an array.
-            </summary>
-            <typeparam name="T">The element type.</typeparam>
-            <param name="collection">The input collection.</param>
-            <returns>The output array.</returns>
-        </member>
-        <member name="M:Gallio.Common.Collections.GenericCollectionUtils.Find``1(System.Collections.Generic.IEnumerable{``0},System.Predicate{``0})">
-            <summary>
-            Returns the first element of the input enumeration for which the specified
-            predicate returns true.
-            </summary>
-            <typeparam name="T">The element type.</typeparam>
-            <param name="enumeration">The input enumeration.</param>
-            <param name="predicate">The predicate.</param>
-            <returns>The first matching value or the default for the type if not found.</returns>
-        </member>
-        <member name="M:Gallio.Common.Collections.GenericCollectionUtils.Exists``1(System.Collections.Generic.IEnumerable{``0},System.Predicate{``0})">
-            <summary>
-            Returns true if the input enumeration contains an element for which the predicate returns true.
-            </summary>
-            <typeparam name="T">The element type.</typeparam>
-            <param name="enumeration">The input enumeration.</param>
-            <param name="predicate">The predicate.</param>
-            <returns>True if a matching element exists.</returns>
-        </member>
-        <member name="M:Gallio.Common.Collections.GenericCollectionUtils.ForEach``1(System.Collections.Generic.IEnumerable{``0},System.Action{``0})">
-            <summary>
-            Performs an action for each element in an enumeration.
-            </summary>
-            <typeparam name="T">The element type.</typeparam>
-            <param name="enumeration">The input enumeration.</param>
-            <param name="action">The action to perform.</param>
-        </member>
-        <member name="M:Gallio.Common.Collections.GenericCollectionUtils.AddAll``1(System.Collections.Generic.IEnumerable{``0},System.Collections.Generic.ICollection{``0})">
-            <summary>
-            Adds all elements of the input enumeration to the output collection.
-            </summary>
-            <typeparam name="T">The element type.</typeparam>
-            <param name="input">The input enumeration.</param>
-            <param name="output">The output collection.</param>
-        </member>
-        <member name="M:Gallio.Common.Collections.GenericCollectionUtils.AddAllIfNotAlreadyPresent``1(System.Collections.Generic.IEnumerable{``0},System.Collections.Generic.ICollection{``0})">
-            <summary>
-            Adds elements of the input enumeration to the output collection, 
-            if not already present.
-            </summary>
-            <typeparam name="T">The element type.</typeparam>
-            <param name="input">The input enumeration.</param>
-            <param name="output">The output collection.</param>
-        </member>
-        <member name="M:Gallio.Common.Collections.GenericCollectionUtils.ElementsEqual``1(System.Collections.Generic.IList{``0},System.Collections.Generic.IList{``0})">
-            <summary>
-            Returns true if the elements of both lists are equal.
-            </summary>
-            <param name="a">The first collection.</param>
-            <param name="b">The second collection.</param>
-            <returns>True if the elements are equal.</returns>
-        </member>
-        <member name="M:Gallio.Common.Collections.GenericCollectionUtils.ElementsEqual``1(System.Collections.Generic.IList{``0},System.Collections.Generic.IList{``0},Gallio.Common.EqualityComparison{``0})">
-            <summary>
-            Returns true if the elements of both lists are equal.
-            </summary>
-            <param name="a">The first collection.</param>
-            <param name="b">The second collection.</param>
-            <param name="comparer">The comparison strategy to use.</param>
-            <returns>True if the elements are equal.</returns>
-        </member>
-        <member name="M:Gallio.Common.Collections.GenericCollectionUtils.KeyValuePairsEqual``2(System.Collections.Generic.IDictionary{``0,``1},System.Collections.Generic.IDictionary{``0,``1})">
-            <summary>
-            Returns true if both dictionaries have equal key/value pairs.
-            </summary>
-            <param name="a">The first collection.</param>
-            <param name="b">The second collection.</param>
-            <returns>True if the elements are equal.</returns>
-        </member>
-        <member name="M:Gallio.Common.Collections.GenericCollectionUtils.ElementsEqualOrderIndependent``1(System.Collections.Generic.IList{``0},System.Collections.Generic.IList{``0})">
-            <summary>
-            Returns true if the elements of both lists are equal but possibly appear in a different order.
-            Handles elements that appear multiple times and ensures that they appear the same
-            number of times in each list.
-            </summary>
-            <param name="a">The first collection.</param>
-            <param name="b">The second collection.</param>
-            <returns>True if the elements are equal.</returns>
-        </member>
-        <member name="M:Gallio.Common.Collections.GenericCollectionUtils.Select``2(System.Collections.Generic.IEnumerable{``0},Gallio.Common.Func{``0,``1})">
-            <summary>
-            Projects each element of a sequence into a new form.
-            </summary>
-            <typeparam name="TInput">The type of the elements of the input sequence.</typeparam>
-            <typeparam name="TOutput">The type of the elements of the output sequence.</typeparam>
-            <param name="enumeration">The input sequence.</param>
-            <param name="filter"></param>
-            <returns>The output sequence</returns>
-            <exception cref="T:System.ArgumentNullException">Thrown if any argument is null.</exception>
-        </member>
-        <member name="T:Gallio.Common.Collections.HashSet`1">
-            <summary>
-            A hashtable-based set implementation.
-            </summary>
-            <remarks>
-            <para>
-            This will probably be replaced by the new HashSet{T} class in
-            the new System.Core of .Net 3.5.
-            </para>
-            </remarks>
-        </member>
-        <member name="M:Gallio.Common.Collections.HashSet`1.#ctor">
-            <summary>
-            Creates an empty set.
-            </summary>
-        </member>
-        <member name="M:Gallio.Common.Collections.HashSet`1.#ctor(System.Collections.Generic.IEqualityComparer{`0})">
-            <summary>
-            Creates an empty set using the specified comparer.
-            </summary>
-            <param name="comparer">The comparer, or null to use the default comparer.</param>
-        </member>
-        <member name="M:Gallio.Common.Collections.HashSet`1.Add(`0)">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.Common.Collections.HashSet`1.Clear">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.Common.Collections.HashSet`1.Contains(`0)">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.Common.Collections.HashSet`1.CopyTo(`0[],System.Int32)">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.Common.Collections.HashSet`1.Remove(`0)">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.Common.Collections.HashSet`1.GetEnumerator">
-            <inheritdoc />
-        </member>
-        <member name="P:Gallio.Common.Collections.HashSet`1.Count">
-            <inheritdoc />
-        </member>
-        <member name="P:Gallio.Common.Collections.HashSet`1.IsReadOnly">
-            <inheritdoc />
-        </member>
-        <member name="T:Gallio.Common.Collections.IMultiMap`2">
-            <summary>
-            A multi-map allows a list of values to be associated with a single key.
-            </summary>
-            <remarks>
-            <para>
-            The value collections provided by the multi-map are always read-only.
-            They can only be modified by calling the appropriate methods of the multi-map
-            to add or remove items.  This behavior helps multi-map implementations
-            better maintain their invariants.
-            </para>
-            </remarks>
-        </member>
-        <member name="M:Gallio.Common.Collections.IMultiMap`2.Add(`0,`1)">
-            <summary>
-            Adds a value to the list of those associated with a key.
-            </summary>
-            <param name="key">The key.</param>
-            <param name="value">The value to associate.</param>
-        </member>
-        <member name="M:Gallio.Common.Collections.IMultiMap`2.AddAll(System.Collections.Generic.IEnumerable{System.Collections.Generic.KeyValuePair{`0,System.Collections.Generic.IList{`1}}})">
-            <summary>
-            Adds all of the values from the specified map.
-            </summary>
-            <param name="map">The map.</param>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="map"/> is null.</exception>
-        </member>
-        <member name="M:Gallio.Common.Collections.IMultiMap`2.AddAll(System.Collections.Generic.IEnumerable{System.Collections.Generic.KeyValuePair{`0,`1}})">
-            <summary>
-            Adds all of the values from the specified enumeration of key-value pairs.
-            </summary>
-            <param name="pairs">The key-value pairs.</param>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="pairs"/> is null.</exception>
-        </member>
-        <member name="M:Gallio.Common.Collections.IMultiMap`2.Contains(`0,`1)">
-            <summary>
-            Returns true if the map contains an entry with the specified key and value.
-            </summary>
-            <param name="key">The key.</param>
-            <param name="value">The value to find.</param>
-            <returns>True if the map contains an entry with the specified key and value.</returns>
-        </member>
-        <member name="M:Gallio.Common.Collections.IMultiMap`2.Remove(`0,`1)">
-            <summary>
-            Removes a value from the list of those associated with a key.
-            </summary>
-            <param name="key">The key.</param>
-            <param name="value">The value to remove from the key.</param>
-            <returns>True if the value was removed.</returns>
-        </member>
-        <member name="P:Gallio.Common.Collections.IMultiMap`2.Pairs">
-            <summary>
-            Gets the contents of the multi-map as an enumeration of pairs of keys and lists of values.
-            </summary>
-        </member>
-        <member name="T:Gallio.Common.Collections.Key`1">
-            <summary>
-            A strongly-typed key to be used together with an associative array to help the
-            compiler perform better type checking of the value associated with the key.
-            </summary>
-            <typeparam name="TValue">The type of value associated with the key.</typeparam>
-        </member>
-        <member name="M:Gallio.Common.Collections.Key`1.#ctor(System.String)">
-            <summary>
-            Creates a new key.
-            </summary>
-            <param name="name">The unique name of the key.</param>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="name"/> is null.</exception>
-        </member>
-        <member name="M:Gallio.Common.Collections.Key`1.ToString">
-            <inheritdoc />
-        </member>
-        <member name="P:Gallio.Common.Collections.Key`1.Name">
-            <summary>
-            Gets the unique name of the key.
-            </summary>
-        </member>
-        <member name="T:Gallio.Common.Collections.LazyCache`2">
-            <summary>
-            Lazily populates and caches values associated with a particular key.
-            </summary>
-            <remarks>
-            <para>
-            Instances of this type are safe for use by multiple concurrent threads.
-            In the case of a race occurs between two threads that result in the population of the
-            same key, the populator function may be called concurrently with two requests for the same
-            key.  The winner of the race gets to store its value in the cache for later use.
-            However, the loser of the race will discard its value and use the newly cached instead.
-            </para>
-            </remarks>
-        </member>
-        <member name="M:Gallio.Common.Collections.LazyCache`2.#ctor(Gallio.Common.Func{`0,`1})">
-            <summary>
-            Creates a cache with the specified populator function.
-            </summary>
-            <param name="populator">A function that provides a value given a key.</param>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="populator"/> is null.</exception>
-        </member>
-        <member name="P:Gallio.Common.Collections.LazyCache`2.Item(`0)">
-            <summary>
-            Gets the value associated with the specified key.
-            Populates it on demand if not already cached.
-            </summary>
-            <param name="key">The key.</param>
-            <returns>The associated value.</returns>
-        </member>
-        <member name="T:Gallio.Common.Collections.MultiMap`2">
-            <summary>
-            A multi-map allows a list of values to be associated with a single key.
-            </summary>
-        </member>
-        <member name="M:Gallio.Common.Collections.MultiMap`2.#ctor">
-            <summary>
-            Creates an empty multi-map.
-            </summary>
-        </member>
-        <member name="M:Gallio.Common.Collections.MultiMap`2.Add(`0,`1)">
-            <summary>
-            Adds a value to the list of those associated with a key.
-            </summary>
-            <param name="key">The key.</param>
-            <param name="value">The value to associate.</param>
-        </member>
-        <member name="M:Gallio.Common.Collections.MultiMap`2.Add(System.Collections.Generic.KeyValuePair{`0,System.Collections.Generic.IList{`1}})">
-            <summary>
-            Adds all values in the pair to the specified key.
-            </summary>
-            <param name="item">The key and values pair.</param>
-        </member>
-        <member name="M:Gallio.Common.Collections.MultiMap`2.Add(`0,System.Collections.Generic.IList{`1})">
-            <summary>
-            Adds all values in the pair to the specified key.
-            </summary>
-            <param name="key">The key.</param>
-            <param name="values">The values.</param>
-        </member>
-        <member name="M:Gallio.Common.Collections.MultiMap`2.AddAll(System.Collections.Generic.IEnumerable{System.Collections.Generic.KeyValuePair{`0,System.Collections.Generic.IList{`1}}})">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.Common.Collections.MultiMap`2.AddAll(System.Collections.Generic.IEnumerable{System.Collections.Generic.KeyValuePair{`0,`1}})">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.Common.Collections.MultiMap`2.Clear">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.Common.Collections.MultiMap`2.Contains(`0,`1)">
-            <summary>
-            Returns true if the map contains an entry with the specified key and value.
-            </summary>
-            <param name="key">The key.</param>
-            <param name="value">The value to find.</param>
-            <returns>True if the map contains an entry with the specified key and value.</returns>
-        </member>
-        <member name="M:Gallio.Common.Collections.MultiMap`2.Contains(System.Collections.Generic.KeyValuePair{`0,System.Collections.Generic.IList{`1}})">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.Common.Collections.MultiMap`2.ContainsKey(`0)">
-            <summary>
-            Returns true if the map contains at least one value associated with
-            the specified key.
-            </summary>
-            <param name="key">The key.</param>
-            <returns>True if there is at least one value associated with the key.</returns>
-        </member>
-        <member name="M:Gallio.Common.Collections.MultiMap`2.CopyTo(System.Collections.Generic.KeyValuePair{`0,System.Collections.Generic.IList{`1}}[],System.Int32)">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.Common.Collections.MultiMap`2.Remove(`0)">
-            <summary>
-            Removes all values associated with the specified key.
-            </summary>
-            <param name="key">The key.</param>
-            <returns>True if the key existed and was removed.</returns>
-        </member>
-        <member name="M:Gallio.Common.Collections.MultiMap`2.Remove(`0,`1)">
-            <summary>
-            Removes a value from the list of those associated with a key.
-            </summary>
-            <param name="key">The key.</param>
-            <param name="value">The value to remove from the key.</param>
-            <returns>True if the value was removed.</returns>
-        </member>
-        <member name="M:Gallio.Common.Collections.MultiMap`2.Remove(System.Collections.Generic.KeyValuePair{`0,System.Collections.Generic.IList{`1}})">
-            <summary>
-            Removes all values in the pair from the specified key.
-            </summary>
-            <param name="item">The key and values pair.</param>
-            <returns>True if at least one value was removed.</returns>
-        </member>
-        <member name="M:Gallio.Common.Collections.MultiMap`2.TryGetValue(`0,System.Collections.Generic.IList{`1}@)">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.Common.Collections.MultiMap`2.GetEnumerator">
-            <inheritdoc cref="M:System.Collections.Generic.IEnumerable`1.GetEnumerator"/>
-        </member>
-        <member name="M:Gallio.Common.Collections.MultiMap`2.ReadOnly(Gallio.Common.Collections.IMultiMap{`0,`1})">
-            <summary>
-            Obtains a read-only view of another multi-map.
-            </summary>
-            <param name="map">The multi-map.</param>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="map"/> is null.</exception>
-        </member>
-        <member name="P:Gallio.Common.Collections.MultiMap`2.Count">
-            <summary>
-            Gets the number of distinct keys in the map.
-            </summary>
-        </member>
-        <member name="P:Gallio.Common.Collections.MultiMap`2.IsReadOnly">
-            <inheritdoc />
-        </member>
-        <member name="P:Gallio.Common.Collections.MultiMap`2.Keys">
-            <summary>
-            Gets the collection of keys in the multi-map.
-            </summary>
-        </member>
-        <member name="P:Gallio.Common.Collections.MultiMap`2.Values">
-            <summary>
-            Gets the collection of lists of values in the multi-map.
-            </summary>
-        </member>
-        <member name="P:Gallio.Common.Collections.MultiMap`2.Pairs">
-            <inheritdoc />
-        </member>
-        <member name="P:Gallio.Common.Collections.MultiMap`2.Item(`0)">
-            <summary>
-            Gets or sets the list of values associated with the specified key.
-            Returns an empty list if there are none.
-            </summary>
-            <param name="key">The key.</param>
-            <returns>The list of values.</returns>
-        </member>
-        <member name="T:Gallio.Common.Collections.NamespaceDoc">
-            <summary>
-            The Gallio.Common.Collections namespace contains specialized collection types and
-            collection utilities.
-            </summary>
-        </member>
-        <member name="T:Gallio.Common.Collections.PropertyBag">
-            <summary>
-            A property bag associates keys with values where each key may have one or more associated value.
-            All keys and values must be non-null strings.


<TRUNCATED>
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Gallio35.dll
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Gallio35.dll b/lib/Gallio.3.2.750/tools/Gallio35.dll
deleted file mode 100644
index 55d026f..0000000
Binary files a/lib/Gallio.3.2.750/tools/Gallio35.dll and /dev/null differ


[32/51] [abbrv] [partial] Cleaning up and getting ready to development towards v4.8

Posted by sy...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/MbUnit.dll.tdnet
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/MbUnit.dll.tdnet b/lib/Gallio.3.2.750/tools/MbUnit.dll.tdnet
deleted file mode 100644
index 0a935d6..0000000
--- a/lib/Gallio.3.2.750/tools/MbUnit.dll.tdnet
+++ /dev/null
@@ -1,6 +0,0 @@
-<TestRunner>
-	<FriendlyName>MbUnit v{0}.{1}</FriendlyName>
-	<AssemblyPath>TDNet\Gallio.TDNetRunner.dll</AssemblyPath>
-	<TypeName>Gallio.TDNetRunner.GallioResidentTestRunner</TypeName>
-	<TestRunnerType>Resident</TestRunnerType>
-</TestRunner>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/MbUnit.pdb
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/MbUnit.pdb b/lib/Gallio.3.2.750/tools/MbUnit.pdb
deleted file mode 100644
index 9b21b2a..0000000
Binary files a/lib/Gallio.3.2.750/tools/MbUnit.pdb and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/MbUnit.plugin
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/MbUnit.plugin b/lib/Gallio.3.2.750/tools/MbUnit.plugin
deleted file mode 100644
index 7320eae..0000000
--- a/lib/Gallio.3.2.750/tools/MbUnit.plugin
+++ /dev/null
@@ -1,56 +0,0 @@
-<?xml version="1.0" encoding="utf-8" ?>
-<plugin pluginId="MbUnit"
-        recommendedInstallationPath=""
-        xmlns="http://www.gallio.org/">
-  <traits>
-    <name>MbUnit v3</name>
-    <version>3.2.0.0</version>
-    <description>Provides support for running MbUnit v3 tests.</description>
-    <icon>plugin://MbUnit/Resources/MbUnit.ico</icon>
-  </traits>
-
-  <dependencies>
-    <dependency pluginId="Gallio" />
-  </dependencies>
-
-  <files>
-    <file path="MbUnit.plugin" />
-    <file path="MbUnit.dll" />
-    <file path="MbUnit.dll.tdnet" />
-    <file path="MbUnit.pdb" />
-    <file path="MbUnit.xml" />
-
-    <file path="NHamcrest.dll" />
-    
-    <file path="Resources\MbUnit.ico" />
-  </files>
-
-  <assemblies>
-    <assembly fullName="MbUnit, Version=3.2.0.0, Culture=neutral, PublicKeyToken=eb9cfa67ee6ab36e"
-              codeBase="MbUnit.dll"
-              qualifyPartialName="true" />
-  </assemblies>
-
-  <components>
-    <component componentId="MbUnit.TestFramework"
-               serviceId="Gallio.TestFramework"
-               componentType="MbUnit.Core.MbUnitTestFramework, MbUnit">
-      <traits>
-        <name>MbUnit v3</name>
-        <frameworkAssemblies>MbUnit, Version=3.2.0.0</frameworkAssemblies>
-        <icon>plugin://MbUnit/Resources/MbUnit.ico</icon>
-        <version>3.2.0.0</version>
-        <fileTypes>Assembly</fileTypes>
-      </traits>
-    </component>
-
-    <component componentId="MbUnit.TestKinds.MbUnitTestAssembly"
-               serviceId="Gallio.TestKind">
-      <traits>
-        <name>MbUnit v3 Assembly</name>
-        <description>MbUnit v3 Test Assembly</description>
-        <icon>plugin://MbUnit/Resources/MbUnit.ico</icon>
-      </traits>
-    </component>
-  </components>
-</plugin>
\ No newline at end of file


[21/51] [abbrv] [partial] Cleaning up and getting ready to development towards v4.8

Posted by sy...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/collectionConstraints.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/collectionConstraints.html b/lib/NUnit.org/NUnit/2.5.9/doc/collectionConstraints.html
deleted file mode 100644
index 86b01bd..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/collectionConstraints.html
+++ /dev/null
@@ -1,333 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - CollectionConstraints</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h2>Collection Constraints (NUnit 2.4 / 2.5)</h2>
-
-<p>Collection constraints perform tests that are specific to collections.
-   The following collection constraints are provided. Before NUnit 2.4.6,
-   these constraints only operated on true Collections. Beginning with 2.4.6,
-   they can work with any object that implements IEnumerable.
-   
-<p>Beginning with NUnit 2.4.2, use of an improper argument type caused tests
-   to fail. Later releases give an error rather than a failure, so that negated
-   constraints will not appear to succeed. 
-   
-<p>For example, both of the following statements give an error in later releases, 
-   but the second would have succeeded in earlier versions of NUnit.
-   
-<div class="code"><pre>
-int[] iarray = new int[] { 1, 2, 3 };
-
-Assert.That( 5, Is.SubsetOf( iarray ) );  // Fails in early releases
-Assert.That( 5, Is.Not.SubsetOf( iarray ) ); /
-</pre></div>
-
-<h3>AllItemsConstraint</h3>
-
-<h4>Action</h4>
-<p>Applies a constraint to each item in a collection, succeeding only if all of them succeed.
-
-<h4>Constructor</h4>
-<div class="code"><pre>
-AllItemsConstraint(Constraint itemConstraint)
-</pre></div>
-
-<h4>Syntax</h4>
-<div class="code"><pre>
-Is.All...
-Has.All...
-</pre></div>
-
-<h4>Examples of Use</h4>
-<div class="code"><pre>
-int[] iarray = new int[] { 1, 2, 3 };
-string[] sarray = new string[] { "a", "b", "c" };
-
-Assert.That( iarray, Is.All.Not.Null );
-Assert.That( sarray, Is.All.InstanceOf<string>() );
-Assert.That( iarray, Is.All.GreaterThan(0) );
-Assert.That( iarray, Has.All.GreaterThan(0) );
-</pre></div>
-
-<h3>SomeItemsConstraint</h3>
-
-<h4>Action</h4>
-<p>Applies a constraint to each item in a collection, succeeding if at least one of them succeeds.
-
-<h4>Constructor</h4>
-<div class="code"><pre>
-SomeItemsConstraint(Constraint itemConstraint)
-</pre></div>
-
-<h4>Syntax</h4>
-<div class="code"><pre>
-Has.Some...
-</pre></div>
-
-<h4>Examples of Use</h4>
-<div class="code"><pre>
-int[] iarray = new int[] { 1, 2, 3 };
-string[] sarray = new string[] { "a", "b", "c" };
-
-Assert.That( iarray, Has.Some.GreaterThan(2) );
-Assert.That( sarray, Has.Some.Length(1) );
-</pre></div>
-
-<h3>NoItemConstraint</h3>
-
-<h4>Action</h4>
-<p>Applies a constraint to each item in a collection, succeeding only if all of them fail.
-
-<h4>Constructor</h4>
-<div class="code"><pre>
-NoItemConstraint(Constraint itemConstraint)
-</pre></div>
-
-<h4>Syntax</h4>
-<div class="code"><pre>
-Has.None...
-Has.No...
-</pre></div>
-
-<h4>Examples of Use</h4>
-<div class="code"><pre>
-int[] iarray = new int[] { 1, 2, 3 };
-string[] sarray = new string[] { "a", "b", "c" };
-
-Assert.That( iarray, Has.None.Null );
-Assert.That( iarray, Has.No.Null );
-Assert.That( sarray, Has.None.EqualTo("d") );
-Assert.That( iarray, Has.None.LessThan(0) );
-</pre></div>
-
-<h3>UniqueItemsConstraint</h3>
-
-<h4>Action</h4>
-<p>Tests that a collection contains only unique items.
-
-<h4>Constructor</h4>
-<div class="code"><pre>
-UniqueItemsConstraint()
-</pre></div>
-
-<h4>Syntax</h4>
-<div class="code"><pre>
-Is.Unique
-</pre></div>
-
-<h4>Example of Use</h4>
-<div class="code"><pre>
-string[] sarray = new string[] { "a", "b", "c" };
-
-Assert.That( sarray, Is.Unique );
-</pre></div>
-
-<h4>Notes</h4>
-<ol>
-<li>??
-</ol>
-
-<h3>CollectionContainsConstraint</h3>
-
-<h4>Action</h4>
-<p>Tests that a collection contains an object. 
-
-<h4>Constructor</h4>
-<div class="code"><pre>
-CollectionContainsConstraint( object )
-</pre></div>
-
-<h4>Syntax</h4>
-<div class="code"><pre>
-Has.Member( object )
-Contains.Item( object )
-</pre></div>
-
-<h4>Modifiers</h4>
-<div class="code"><pre>
-...Using(IComparer comparer)
-...Using<T>(IComparer&lt;T&gt; comparer)
-...Using<T>(Comparison&lt;T&gt; comparer)
-</pre></div>
-
-<h4>Examples of Use</h4>
-<div class="code"><pre>
-int[] iarray = new int[] { 1, 2, 3 };
-string[] sarray = new string[] { "a", "b", "c" };
-
-Assert.That( iarray, Has.Member(3) );
-Assert.That( sarray, Has.Member("b") );
-Assert.That( sarray, Contains.Item("c") );
-Assert.That( sarray, Has.No.Member("x") );
-</pre></div>
-
-<h4>Notes</h4>
-<ol>
-<li>For references, <b>Has.Member</b> uses object equality to find a member in a 
-collection. To check for an object equal to an item the collection, use 
-<b>Has.Some.EqualTo(...)</b>.
-</ol>
-
-<h3>CollectionEquivalentConstraint</h3>
-
-<h4>Action</h4>
-<p>Tests that two collections are equivalent - that they contain 
-the same items, in any order.
-
-<h4>Constructor</h4>
-<div class="code"><pre>
-CollectionEquivalentConstraint( IEnumerable other )
-</pre></div>
-
-<h4>Syntax</h4>
-<div class="code"><pre>
-Is.EquivalentTo( IEnumerable other )
-</pre></div>
-
-<h4>Examples of Use</h4>
-<div class="code"><pre>
-int[] iarray = new int[] { 1, 2, 3 };
-string[] sarray = new string[] { "a", "b", "c" };
-
-Assert.That( new string[] { "c", "a", "b" }, Is.EquivalentTo( sarray ) );
-Assert.That( new int[] { 1, 2, 2 }, Is.Not.EquivalentTo( iarray ) );
-</pre></div>
-
-<h4>Notes</h4>
-<ol>
-<li>To compare collections for equality, use Is.EqualTo().
-</ol>
-
-<h3>CollectionSubsetConstraint</h3>
-
-<h4>Action</h4>
-<p>Tests that one collection is a subset of another.
-
-<h4>Constructor</h4>
-<div class="code"><pre>
-CollectionSubsetConstraint( ICollection )
-</pre></div>
-
-<h4>Syntax</h4>
-<div class="code"><pre>
-Is.SubsetOf( IEnumerable )
-</pre></div>
-
-<h4>Example of Use</h4>
-<div class="code"><pre>
-int[] iarray = new int[] { 1, 2, 3 };
-
-Assert.That( new int[] { 1, 3 }, Is.SubsetOf( iarray ) );
-</pre></div>
-
-<h3>CollectionOrderedConstraint (NUnit 2.5)</h3>
-
-<h4>Action</h4>
-<p>Tests that a collection is ordered.
-
-<h4>Constructor</h4>
-<div class="code"><pre>
-CollectionOrderedConstraint()
-</pre></div>
-
-<h4>Syntax</h4>
-<div class="code"><pre>
-Is.Ordered
-</pre></div>
-
-<h4>Modifiers</h4>
-<div class="code"><pre>
-...Descending
-...By(string propertyName)
-...Using(IComparer comparer)
-...Using<T>(IComparer&lt;T&gt; comparer)
-...Using<T>(Comparison&lt;T&gt; comparer)
-</pre></div>
-
-<h4>Examples of Use</h4>
-<div class="code"><pre>
-int[] iarray = new int[] { 1, 2, 3 };
-string[] sarray = new string[] { "c", "b", "a" };
-string[] sarray2 = new string[] ( "a", "aa", "aaa" );
-
-Assert.That( iarray, Is.Ordered );
-Assert.That( sarray, Is.Ordered.Descending );
-Assert.That( sarray2, Is.Ordered.By("Length");
-</pre></div>
-
-<h4>Notes</h4>
-<ol>
-<li>Modifiers may be combined and may appear in any order. If the
-same modifier is used more than once, the result is undefined.
-<li>The syntax of Is.Ordered has changed from earlier betas.
-</ol>
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<ul>
-<li><a href="equalConstraint.html">Equal&nbsp;Constraint</a></li>
-<li><a href="sameasConstraint.html">SameAs&nbsp;Constraint</a></li>
-<li><a href="conditionConstraints.html">Condition&nbsp;Constraints</a></li>
-<li><a href="comparisonConstraints.html">Comparison&nbsp;Constrants</a></li>
-<li><a href="pathConstraints.html">Path&nbsp;Constraints</a></li>
-<li><a href="typeConstraints.html">Type&nbsp;Constraints</a></li>
-<li><a href="stringConstraints.html">String&nbsp;Constraints</a></li>
-<li id="current"><a href="collectionConstraints.html">Collection&nbsp;Constraints</a></li>
-<li><a href="propertyConstraint.html">Property&nbsp;Constraint</a></li>
-<li><a href="throwsConstraint.html">Throws&nbsp;Constraint</a></li>
-<li><a href="compoundConstraints.html">Compound&nbsp;Constraints</a></li>
-<li><a href="delayedConstraint.html">Delayed&nbsp;Constraint</a></li>
-<li><a href="listMapper.html">List&nbsp;Mapper</a></li>
-<li><a href="reusableConstraint.html">Reusable&nbsp;Constraint</a></li>
-</ul>
-<li><a href="attributes.html">Attributes</a></li>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/combinatorial.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/combinatorial.html b/lib/NUnit.org/NUnit/2.5.9/doc/combinatorial.html
deleted file mode 100644
index 1d12da4..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/combinatorial.html
+++ /dev/null
@@ -1,125 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - Combinatorial</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h3>CombinatorialAttribute (NUnit 2.5)</h3>
-
-<p>The <b>CombinatorialAttribute</b> is used on a test to specify that NUnit should
-   generate test cases for all possible combinations of the individual
-   data items provided for the parameters of a test. Since this is the
-   default, use of this attribute is optional.
-   
-<h4>Example</h4>
-
-<p>The following test will be executed six times, as follows:
-<pre>
-	MyTest(1, "A")
-	MyTest(1, "B")
-	MyTest(2, "A")
-	MyTest(2, "B")
-	MyTest(3, "A")
-	MyTest(3, "B")
-</pre>
-<div class="code"><pre>
-[Test, Combinatorial]
-public void MyTest(
-    [Values(1,2,3)] int x,
-    [Values("A","B")] string s)
-{
-    ...
-}
-</pre></div>
-
-<h4>See also...</h4>
-<ul>
-<li><a href="sequential.html">SequentialAttribute</a><li><a href="pairwise.html">PairwiseAttribute</a></ul>
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<ul>
-<li><a href="category.html">Category</a></li>
-<li id="current"><a href="combinatorial.html">Combinatorial</a></li>
-<li><a href="culture.html">Culture</a></li>
-<li><a href="datapoint.html">Datapoint(s)</a></li>
-<li><a href="description.html">Description</a></li>
-<li><a href="exception.html">Exception</a></li>
-<li><a href="explicit.html">Explicit</a></li>
-<li><a href="ignore.html">Ignore</a></li>
-<li><a href="maxtime.html">Maxtime</a></li>
-<li><a href="pairwise.html">Pairwise</a></li>
-<li><a href="platform.html">Platform</a></li>
-<li><a href="property.html">Property</a></li>
-<li><a href="random.html">Random</a></li>
-<li><a href="range.html">Range</a></li>
-<li><a href="repeat.html">Repeat</a></li>
-<li><a href="requiredAddin.html">RequiredAddin</a></li>
-<li><a href="requiresMTA.html">Requires&nbsp;MTA</a></li>
-<li><a href="requiresSTA.html">Requires&nbsp;STA</a></li>
-<li><a href="requiresThread.html">Requires&nbsp;Thread</a></li>
-<li><a href="sequential.html">Sequential</a></li>
-<li><a href="setCulture.html">SetCulture</a></li>
-<li><a href="setup.html">Setup</a></li>
-<li><a href="setupFixture.html">SetupFixture</a></li>
-<li><a href="suite.html">Suite</a></li>
-<li><a href="teardown.html">Teardown</a></li>
-<li><a href="test.html">Test</a></li>
-<li><a href="testCase.html">TestCase</a></li>
-<li><a href="testCaseSource.html">TestCaseSource</a></li>
-<li><a href="testFixture.html">TestFixture</a></li>
-<li><a href="fixtureSetup.html">TestFixtureSetUp</a></li>
-<li><a href="fixtureTeardown.html">TestFixtureTearDown</a></li>
-<li><a href="theory.html">Theory</a></li>
-<li><a href="timeout.html">Timeout</a></li>
-<li><a href="values.html">Values</a></li>
-<li><a href="valueSource.html">ValueSource</a></li>
-</ul>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/comparisonAsserts.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/comparisonAsserts.html b/lib/NUnit.org/NUnit/2.5.9/doc/comparisonAsserts.html
deleted file mode 100644
index 4396ff7..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/comparisonAsserts.html
+++ /dev/null
@@ -1,269 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - ComparisonAsserts</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h2>Comparisons (NUnit 2.2.4)</h2>
-
-<p>The following methods test whether one object is greater than than another.
-   Contrary to the normal order of Asserts, these methods are designed to be
-   read in the "natural" English-language or mathematical order. Thus 
-   <b>Assert.Greater( x, y )</b> asserts that x is greater than y ( x &gt; y ). </p>
-   
-<div class="code" style="width: 36em" >
-<pre>Assert.Greater( int arg1, int arg2 );
-Assert.Greater( int arg1, int arg2, string message );
-Assert.Greater( int arg1, int arg2, string message, 
-                object[] parms );
-
-Assert.Greater( uint arg1, uint arg2 );
-Assert.Greater( uint arg1, uint arg2, string message );
-Assert.Greater( uint arg1, uint arg2, string message, 
-                object[] parms );
-
-Assert.Greater( long arg1, long arg2 );
-Assert.Greater( long arg1, long arg2, string message );
-Assert.Greater( long arg1, long arg2, string message, 
-                object[] parms );
-
-Assert.Greater( ulong arg1, ulong arg2 );
-Assert.Greater( ulong arg1, ulong arg2, string message );
-Assert.Greater( ulong arg1, ulong arg2, string message, 
-                object[] parms );
-
-Assert.Greater( decimal arg1, decimal arg2 );
-Assert.Greater( decimal arg1, decimal arg2, string message );
-Assert.Greater( decimal arg1, decimal arg2, string message, 
-                object[] parms );
-
-Assert.Greater( double arg1, double arg2 );
-Assert.Greater( double arg1, double arg2, string message );
-Assert.Greater( double arg1, double arg2, string message, 
-                object[] parms );
-
-Assert.Greater( double arg1, double arg2 );
-Assert.Greater( double arg1, double arg2, string message );
-Assert.Greater( double arg1, double arg2, string message, 
-                object[] parms );
-
-Assert.Greater( float arg1, float arg2 );
-Assert.Greater( float arg1, float arg2, string message );
-Assert.Greater( float arg1, float arg2, string message, 
-                object[] parms );
-
-Assert.Greater( IComparable arg1, IComparable arg2 );
-Assert.Greater( IComparable arg1, IComparable arg2, string message );
-Assert.Greater( IComparable arg1, IComparable arg2, string message, 
-                object[] parms );</pre>
-</div>
-				
-<p>The following methods test whether one object is greater than or equal to another.
-   Contrary to the normal order of Asserts, these methods are designed to be
-   read in the "natural" English-language or mathematical order. Thus 
-   <b>Assert.GreaterOrEqual( x, y )</b> asserts that x is greater than or equal to y ( x &gt;= y ). </p>
-   
-<div class="code" style="width: 36em" >
-<pre>Assert.GreaterOrEqual( int arg1, int arg2 );
-Assert.GreaterOrEqual( int arg1, int arg2, string message );
-Assert.GreaterOrEqual( int arg1, int arg2, string message, 
-                object[] parms );
-
-Assert.GreaterOrEqual( uint arg1, uint arg2 );
-Assert.GreaterOrEqual( uint arg1, uint arg2, string message );
-Assert.GreaterOrEqual( uint arg1, uint arg2, string message, 
-                object[] parms );
-
-Assert.GreaterOrEqual( long arg1, long arg2 );
-Assert.GreaterOrEqual( long arg1, long arg2, string message );
-Assert.GreaterOrEqual( long arg1, long arg2, string message, 
-                object[] parms );
-
-Assert.GreaterOrEqual( ulong arg1, ulong arg2 );
-Assert.GreaterOrEqual( ulong arg1, ulong arg2, string message );
-Assert.GreaterOrEqual( ulong arg1, ulong arg2, string message, 
-                object[] parms );
-
-Assert.GreaterOrEqual( decimal arg1, decimal arg2 );
-Assert.GreaterOrEqual( decimal arg1, decimal arg2, string message );
-Assert.GreaterOrEqual( decimal arg1, decimal arg2, string message, 
-                object[] parms );
-
-Assert.GreaterOrEqual( double arg1, double arg2 );
-Assert.GreaterOrEqual( double arg1, double arg2, string message );
-Assert.GreaterOrEqual( double arg1, double arg2, string message, 
-                object[] parms );
-
-Assert.GreaterOrEqual( double arg1, double arg2 );
-Assert.GreaterOrEqual( double arg1, double arg2, string message );
-Assert.GreaterOrEqual( double arg1, double arg2, string message, 
-                object[] parms );
-
-Assert.GreaterOrEqual( float arg1, float arg2 );
-Assert.GreaterOrEqual( float arg1, float arg2, string message );
-Assert.GreaterOrEqual( float arg1, float arg2, string message, 
-                object[] parms );
-
-Assert.GreaterOrEqual( IComparable arg1, IComparable arg2 );
-Assert.GreaterOrEqual( IComparable arg1, IComparable arg2, string message );
-Assert.GreaterOrEqual( IComparable arg1, IComparable arg2, string message, 
-                object[] parms );</pre>
-</div>
-				
-<p>The following methods test whether one object is less than than another.
-   Contrary to the normal order of Asserts, these methods are designed to be
-   read in the "natural" English-language or mathematical order. Thus 
-   <b>Assert.Less( x, y )</b> asserts that x is less than y ( x &lt; y ). </p>
-   
-<div class="code" style="width: 36em" >
-<pre>Assert.Less( int arg1, int arg2 );
-Assert.Less( int arg1, int arg2, string message );
-Assert.Less( int arg1, int arg2, string message, 
-                object[] parms );
-				
-Assert.Less( uint arg1, uint arg2 );
-Assert.Less( uint arg1, uint arg2, string message );
-Assert.Less( uint arg1, uint arg2, string message, 
-                object[] parms );
-				
-Assert.Less( long arg1, long arg2 );
-Assert.Less( long arg1, long arg2, string message );
-Assert.Less( long arg1, long arg2, string message, 
-                object[] parms );
-
-Assert.Less( ulong arg1, ulong arg2 );
-Assert.Less( ulong arg1, ulong arg2, string message );
-Assert.Less( ulong arg1, ulong arg2, string message, 
-                object[] parms );
-
-Assert.Less( decimal arg1, decimal arg2 );
-Assert.Less( decimal arg1, decimal arg2, string message );
-Assert.Less( decimal arg1, decimal arg2, string message, 
-                object[] parms );
-				
-Assert.Less( double arg1, double arg2 );
-Assert.Less( double arg1, double arg2, string message );
-Assert.Less( double arg1, double arg2, string message, 
-                object[] parms );
-				
-Assert.Less( float arg1, float arg2 );
-Assert.Less( float arg1, float arg2, string message );
-Assert.Less( float arg1, float arg2, string message, 
-                object[] parms );
-				
-Assert.Less( IComparable arg1, IComparable arg2 );
-Assert.Less( IComparable arg1, IComparable arg2, string message );
-Assert.Less( IComparable arg1, IComparable arg2, string message, 
-                object[] parms );</pre>
-</div>
-
-<p>The following methods test whether one object is less than or equal to another.
-   Contrary to the normal order of Asserts, these methods are designed to be
-   read in the "natural" English-language or mathematical order. Thus 
-   <b>Assert.LessOrEqual( x, y )</b> asserts that x is less than or equal to y ( x &lt;= y ). </p>
-   
-<div class="code" style="width: 36em" >
-<pre>Assert.LessOrEqual( int arg1, int arg2 );
-Assert.LessOrEqual( int arg1, int arg2, string message );
-Assert.LessOrEqual( int arg1, int arg2, string message, 
-                object[] parms );
-				
-Assert.LessOrEqual( uint arg1, uint arg2 );
-Assert.LessOrEqual( uint arg1, uint arg2, string message );
-Assert.LessOrEqual( uint arg1, uint arg2, string message, 
-                object[] parms );
-				
-Assert.LessOrEqual( long arg1, long arg2 );
-Assert.LessOrEqual( long arg1, long arg2, string message );
-Assert.LessOrEqual( long arg1, long arg2, string message, 
-                object[] parms );
-
-Assert.LessOrEqual( ulong arg1, ulong arg2 );
-Assert.LessOrEqual( ulong arg1, ulong arg2, string message );
-Assert.LessOrEqual( ulong arg1, ulong arg2, string message, 
-                object[] parms );
-
-Assert.LessOrEqual( decimal arg1, decimal arg2 );
-Assert.LessOrEqual( decimal arg1, decimal arg2, string message );
-Assert.LessOrEqual( decimal arg1, decimal arg2, string message, 
-                object[] parms );
-				
-Assert.LessOrEqual( double arg1, double arg2 );
-Assert.LessOrEqual( double arg1, double arg2, string message );
-Assert.LessOrEqual( double arg1, double arg2, string message, 
-                object[] parms );
-				
-Assert.LessOrEqual( float arg1, float arg2 );
-Assert.LessOrEqual( float arg1, float arg2, string message );
-Assert.LessOrEqual( float arg1, float arg2, string message, 
-                object[] parms );
-				
-Assert.LessOrEqual( IComparable arg1, IComparable arg2 );
-Assert.LessOrEqual( IComparable arg1, IComparable arg2, string message );
-Assert.LessOrEqual( IComparable arg1, IComparable arg2, string message, 
-                object[] parms );</pre>
-</div>
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<ul>
-<li><a href="equalityAsserts.html">Equality&nbsp;Asserts</a></li>
-<li><a href="identityAsserts.html">Identity&nbsp;Asserts</a></li>
-<li><a href="conditionAsserts.html">Condition&nbsp;Asserts</a></li>
-<li id="current"><a href="comparisonAsserts.html">Comparison&nbsp;Asserts</a></li>
-<li><a href="typeAsserts.html">Type&nbsp;Asserts</a></li>
-<li><a href="exceptionAsserts.html">Exception&nbsp;Asserts</a></li>
-<li><a href="utilityAsserts.html">Utility&nbsp;Methods</a></li>
-<li><a href="stringAssert.html">String&nbsp;Assert</a></li>
-<li><a href="collectionAssert.html">Collection&nbsp;Assert</a></li>
-<li><a href="fileAssert.html">File&nbsp;Assert</a></li>
-<li><a href="directoryAssert.html">Directory&nbsp;Assert</a></li>
-</ul>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/comparisonConstraints.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/comparisonConstraints.html b/lib/NUnit.org/NUnit/2.5.9/doc/comparisonConstraints.html
deleted file mode 100644
index 85c5893..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/comparisonConstraints.html
+++ /dev/null
@@ -1,239 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - ComparisonConstraints</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h2>Comparison Constraints (NUnit 2.4 / 2.5)</h2>
-
-<p>Comparison constraints are able to test whether one value
-is greater or less than another. Comparison constraints work
-on numeric values, as well as other objects that implement the
-<b>IComparable</b> interface or - beginning with NUnit 2.5 - 
-<b>IComparable&lt;T&gt;</b>.
-
-<p>Beginning with NUnit 2.5, you may supply your own comparison
-algorithm through the <b>Using</b> modifier.
-
-<h3>GreaterThanConstraint</h3>
-
-<h4>Action</h4>
-<p>Tests that one value is greater than another.
-
-<h4>Constructor</h4>
-<div class="code"><pre>
-GreaterThanConstraint(object expected)
-</pre></div>
-
-<h4>Syntax</h4>
-<div class="code"><pre>
-Is.GreaterThan(object expected)
-</pre></div>
-
-<h4>Modifiers</h4>
-<div class="code"><pre>
-...Using(IComparer comparer)
-...Using<T>(IComparer&lt;T&gt; comparer)
-...Using<T>(Comparison&lt;T&gt; comparer)
-</pre></div>
-
-<h4>Examples of Use</h4>
-<div class="code"><pre>
-Assert.That(7, Is.GreaterThan(3));
-Assert.That(myOwnObject, 
-    Is.GreaterThan(theExpected).Using(myComparer));
-</pre></div>
-
-<h3>GreaterThanOrEqualConstraint</h3>
-
-<h4>Action</h4>
-<p>Tests that one value is greater than or equal to another.
-
-<h4>Constructor</h4>
-<div class="code"><pre>
-GreaterThanOrEqualConstraint(object expected)
-</pre></div>
-
-<h4>Syntax</h4>
-<div class="code"><pre>
-Is.GreaterThanOrEqualTo(object expected)
-Is.AtLeast(object expected)
-</pre></div>
-
-<h4>Modifiers</h4>
-<div class="code"><pre>
-...Using(IComparer comparer)
-...Using<T>(IComparer&lt;T&gt; comparer)
-...Using<T>(Comparison&lt;T&gt; comparer)
-</pre></div>
-
-<h4>Examples of Use</h4>
-<div class="code"><pre>
-Assert.That(7, Is.GreaterThanOrEqualTo(3));
-Assert.That(7, Is.AtLeast(3));
-Assert.That(7, Is.GreaterThanOrEqualTo(7));
-Assert.That(7, Is.AtLeast(7));
-Assert.That(myOwnObject, 
-    Is.GreaterThanOrEqualTo(theExpected).Using(myComparer));
-</pre></div>
-
-<h3>LessThanConstraint</h3>
-
-<h4>Action</h4>
-<p>Tests that one value is less than another.
-
-<h4>Constructor</h4>
-<div class="code"><pre>
-LessThanConstraint(object expected)
-</pre></div>
-
-<h4>Syntax</h4>
-<div class="code"><pre>
-Is.LessThan(object expected)
-</pre></div>
-
-<h4>Modifiers</h4>
-<div class="code"><pre>
-...Using(IComparer comparer)
-...Using<T>(IComparer&lt;T&gt; comparer)
-...Using<T>(Comparison&lt;T&gt; comparer)
-</pre></div>
-
-<h4>Examples of Use</h4>
-<div class="code"><pre>
-Assert.That(3, Is.LessThan(7));
-Assert.That(myOwnObject, 
-    Is.LessThan(theExpected).Using(myComparer));
-</pre></div>
-
-<h3>LessThanOrEqualConstraint</h3>
-
-<h4>Action</h4>
-<p>Tests that one value is less than or equal to another.
-
-<h4>Constructor</h4>
-<div class="code"><pre>
-LessThanOrEqualConstraint(object expected)
-</pre></div>
-
-<h4>Syntax</h4>
-<div class="code"><pre>
-Is.LessThanOrEqualTo(object expected)
-Is.AtMost(object expected)
-</pre></div>
-
-<h4>Modifiers</h4>
-<div class="code"><pre>
-...Using(IComparer comparer)
-...Using<T>(IComparer&lt;T&gt; comparer)
-...Using<T>(Comparison&lt;T&gt; comparer)
-</pre></div>
-
-<h4>Examples of Use</h4>
-<div class="code"><pre>
-Assert.That(3, Is.LessThanOrEqualTo(7));
-Assert.That(3, Is.AtMost(7));
-Assert.That(3, Is.LessThanOrEqualTo(3));
-Assert.That(3, Is.AtMost(3));
-Assert.That(myOwnObject, 
-    Is.LessThanOrEqualTo(theExpected).Using(myComparer));
-</pre></div>
-
-<h3>RangeConstraint</h3>
-
-<h4>Action</h4>
-<p>
-
-<h4>Constructor</h4>
-<div class="code"><pre>
-RangeConstraint(IComparable from, IComparable to)
-</pre></div>
-
-<h4>Syntax</h4>
-<div class="code"><pre>
-Is.InRange(IComparable from, IComparable to)
-</pre></div>
-
-<h4>Modifiers</h4>
-<div class="code"><pre>
-...Using(IComparer comparer)
-...Using<T>(IComparer&lt;T&gt; comparer)
-...Using<T>(Comparison&lt;T&gt; comparer)
-</pre></div>
-
-<h4>Examples of Use</h4>
-<div class="code"><pre>
-int[] iarray = new int[] { 1, 2, 3 }
-
-Assert.That( 42, Is.InRange(1, 100) );
-Assert.That( iarray, Is.All.InRange(1, 3) );
-Assert.That(myOwnObject, 
-    Is.InRange(lowExpected, highExpected).Using(myComparer));
-</pre></div>
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<ul>
-<li><a href="equalConstraint.html">Equal&nbsp;Constraint</a></li>
-<li><a href="sameasConstraint.html">SameAs&nbsp;Constraint</a></li>
-<li><a href="conditionConstraints.html">Condition&nbsp;Constraints</a></li>
-<li id="current"><a href="comparisonConstraints.html">Comparison&nbsp;Constrants</a></li>
-<li><a href="pathConstraints.html">Path&nbsp;Constraints</a></li>
-<li><a href="typeConstraints.html">Type&nbsp;Constraints</a></li>
-<li><a href="stringConstraints.html">String&nbsp;Constraints</a></li>
-<li><a href="collectionConstraints.html">Collection&nbsp;Constraints</a></li>
-<li><a href="propertyConstraint.html">Property&nbsp;Constraint</a></li>
-<li><a href="throwsConstraint.html">Throws&nbsp;Constraint</a></li>
-<li><a href="compoundConstraints.html">Compound&nbsp;Constraints</a></li>
-<li><a href="delayedConstraint.html">Delayed&nbsp;Constraint</a></li>
-<li><a href="listMapper.html">List&nbsp;Mapper</a></li>
-<li><a href="reusableConstraint.html">Reusable&nbsp;Constraint</a></li>
-</ul>
-<li><a href="attributes.html">Attributes</a></li>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/compoundConstraints.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/compoundConstraints.html b/lib/NUnit.org/NUnit/2.5.9/doc/compoundConstraints.html
deleted file mode 100644
index 462a51f..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/compoundConstraints.html
+++ /dev/null
@@ -1,96 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - CompoundConstraints</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h2>Compound Constraints (NUnit 2.4)</h2>
-
-<p>Compound constraints are used to combine other constraints in various ways.
-
-<table class="constraints">
-<tr><th>Syntax Helper</th><th>Constructor</th><th>Operation</th></tr>
-<tr><td>Is.Not...</td><td>NotConstraint( Constraint )</td><td>Negates or reverses the effect of a constraint</td></tr>
-<tr><td>Is.All...</td><td>AllItemsConstraint( Constraint )</td><td>Tests that all members of a collection match the constraint</td></tr>
-<tr><td>Constraint &amp; Constraint</td><td>AndConstraint( Constraint, Constraint )</td><td>Tests that both of the constraints are met</td></tr>
-<tr><td>Constraint | Constraint</td><td>OrConstraint( Constraint, Constraint )</td><td>Tests that at least one of the constraints is met</td></tr>
-</table>
-
-<h4>Examples of Use</h4>
-
-<div class="code"><pre>
-Assert.That( 2 + 2, Is.Not.EqualTo( 5 );
-Assert.That( new int[] { 1, 2, 3 }, Is.All.GreaterThan( 0 ) );
-Assert.That( 2.3, Is.GreaterThan( 2.0 ) & Is.LessThan( 3.0 ) );
-Assert.That( 3, Is.LessThan( 5 ) | Is.GreaterThan( 10 ) ); 
-
-// Using inheritance
-Expect( 2 + 2, Not.EqualTo( 5 ) );
-Expect( 2.3, GreaterThan( 2.0 ) & LessThan( 3.0 ) );
-</pre></div>
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<ul>
-<li><a href="equalConstraint.html">Equal&nbsp;Constraint</a></li>
-<li><a href="sameasConstraint.html">SameAs&nbsp;Constraint</a></li>
-<li><a href="conditionConstraints.html">Condition&nbsp;Constraints</a></li>
-<li><a href="comparisonConstraints.html">Comparison&nbsp;Constrants</a></li>
-<li><a href="pathConstraints.html">Path&nbsp;Constraints</a></li>
-<li><a href="typeConstraints.html">Type&nbsp;Constraints</a></li>
-<li><a href="stringConstraints.html">String&nbsp;Constraints</a></li>
-<li><a href="collectionConstraints.html">Collection&nbsp;Constraints</a></li>
-<li><a href="propertyConstraint.html">Property&nbsp;Constraint</a></li>
-<li><a href="throwsConstraint.html">Throws&nbsp;Constraint</a></li>
-<li id="current"><a href="compoundConstraints.html">Compound&nbsp;Constraints</a></li>
-<li><a href="delayedConstraint.html">Delayed&nbsp;Constraint</a></li>
-<li><a href="listMapper.html">List&nbsp;Mapper</a></li>
-<li><a href="reusableConstraint.html">Reusable&nbsp;Constraint</a></li>
-</ul>
-<li><a href="attributes.html">Attributes</a></li>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/conditionAsserts.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/conditionAsserts.html b/lib/NUnit.org/NUnit/2.5.9/doc/conditionAsserts.html
deleted file mode 100644
index c537e80..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/conditionAsserts.html
+++ /dev/null
@@ -1,142 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - ConditionAsserts</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h2>Condition Asserts</h2>
-
-<p>Methods that test a specific condition are named for the condition they test and 
-	take the value tested as their first argument and, optionally a message as the 
-	second. The following methods are provided:</p>
-<div class="code" style="width: 36em">
-<pre>Assert.IsTrue( bool condition );
-Assert.IsTrue( bool condition, string message );
-Assert.IsTrue( bool condition, string message, object[] parms );
-
-Assert.True( bool condition );
-Assert.True( bool condition, string message );
-Assert.True( bool condition, string message, object[] parms );
-
-Assert.IsFalse( bool condition);
-Assert.IsFalse( bool condition, string message );
-Assert.IsFalse( bool condition, string message, object[] parms );
-
-Assert.False( bool condition);
-Assert.False( bool condition, string message );
-Assert.False( bool condition, string message, object[] parms );
-
-Assert.IsNull( object anObject );
-Assert.IsNull( object anObject, string message );
-Assert.IsNull( object anObject, string message, object[] parms );
-
-Assert.Null( object anObject );
-Assert.Null( object anObject, string message );
-Assert.Null( object anObject, string message, object[] parms );
-
-Assert.IsNotNull( object anObject );
-Assert.IsNotNull( object anObject, string message );
-Assert.IsNotNull( object anObject, string message, object[] parms );
-
-Assert.NotNull( object anObject );
-Assert.NotNull( object anObject, string message );
-Assert.NotNull( object anObject, string message, object[] parms );
-
-Assert.IsNaN( double aDouble );
-Assert.IsNaN( double aDouble, string message );
-Assert.IsNaN( double aDouble, string message, object[] parms );
-
-Assert.IsEmpty( string aString );
-Assert.IsEmpty( string aString, string message );
-Assert.IsEmpty( string aString, string message,
-          params object[] args );
-
-Assert.IsNotEmpty( string aString );
-Assert.IsNotEmpty( string aString, string message );
-Assert.IsNotEmpty( string aString, string message,
-          params object[] args );
-
-Assert.IsEmpty( ICollection collection );
-Assert.IsEmpty( ICollection collection, string message );
-Assert.IsEmpty( ICollection collection, string message,
-          params object[] args );
-
-Assert.IsNotEmpty( ICollection collection );
-Assert.IsNotEmpty( ICollection collection, string message );
-Assert.IsNotEmpty( ICollection collection, string message,
-          params object[] args );</pre>
-</div>
-
-<p>Two forms are provided for the True, False, Null and NotNull
-conditions. The "Is" forms are compatible with earlier versions
-of the NUnit framework, while those without "Is" are provided
-for compatibility with NUnitLite.
-
-<p>Assert.IsEmpty and Assert.IsNotEmpty may be used to test either a string
-or a collection.</p>
-
-
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<ul>
-<li><a href="equalityAsserts.html">Equality&nbsp;Asserts</a></li>
-<li><a href="identityAsserts.html">Identity&nbsp;Asserts</a></li>
-<li id="current"><a href="conditionAsserts.html">Condition&nbsp;Asserts</a></li>
-<li><a href="comparisonAsserts.html">Comparison&nbsp;Asserts</a></li>
-<li><a href="typeAsserts.html">Type&nbsp;Asserts</a></li>
-<li><a href="exceptionAsserts.html">Exception&nbsp;Asserts</a></li>
-<li><a href="utilityAsserts.html">Utility&nbsp;Methods</a></li>
-<li><a href="stringAssert.html">String&nbsp;Assert</a></li>
-<li><a href="collectionAssert.html">Collection&nbsp;Assert</a></li>
-<li><a href="fileAssert.html">File&nbsp;Assert</a></li>
-<li><a href="directoryAssert.html">Directory&nbsp;Assert</a></li>
-</ul>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/conditionConstraints.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/conditionConstraints.html b/lib/NUnit.org/NUnit/2.5.9/doc/conditionConstraints.html
deleted file mode 100644
index 5939987..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/conditionConstraints.html
+++ /dev/null
@@ -1,213 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - ConditionConstraints</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h2>Condition Constraints (NUnit 2.4)</h2>
-
-<p>ConditionConstraints test a specific condition and are named for the condition 
-   they test. They verify that the actual value satisfies the condition. The
-   following condition helpers are provided.
-   
-<h3>NullConstraint</h3>
-
-<h4>Action</h4>
-<p>Tests that a value is Null.
-
-<h4>Constructor</h4>
-<div class="code"><pre>
-NullConstraint()
-</pre></div>
-
-<h4>Syntax</h4>
-<div class="code"><pre>
-Is.Null
-</pre></div>
-
-<h4>Examples of Use</h4>
-<div class="code"><pre>
-Assert.That( anObject, Is.Null );
-Assert.That( anObject, Is.Not.Null );
-</pre></div>
-
-<h3>TrueConstraint</h3>
-
-<h4>Action</h4>
-<p>Tests that a value is true.
-
-<h4>Constructor</h4>
-<div class="code"><pre>
-TrueConstraint()
-</pre></div>
-
-<h4>Syntax</h4>
-<div class="code"><pre>
-Is.True
-</pre></div>
-
-<h4>Example of Use</h4>
-<div class="code"><pre>
-Assert.That( condition, Is.True );
-</pre></div>
-
-<h3>FalseConstraint</h3>
-
-<h4>Action</h4>
-<p>Tests that a value is false.
-
-<h4>Constructor</h4>
-<div class="code"><pre>
-FalseConstraint()
-</pre></div>
-
-<h4>Syntax</h4>
-<div class="code"><pre>
-Is.False
-</pre></div>
-
-<h4>Example of Use</h4>
-<div class="code"><pre>
-Assert.That( condition, Is.False );
-</pre></div>
-
-<h3>NaNConstraint</h3>
-
-<h4>Action</h4>
-<p>Tests that a value is floating-point NaN.
-
-<h4>Constructor</h4>
-<div class="code"><pre>
-NaNConstraint()
-</pre></div>
-
-<h4>Syntax</h4>
-<div class="code"><pre>
-Is.NaN
-</pre></div>
-
-<h4>Examples of Use</h4>
-<div class="code"><pre>
-Assert.That( aDouble, Is.NaN );
-Assert.That( aDouble, Is.Not.NaN );
-</pre></div>
-
-<h3>EmptyConstraint</h3>
-
-<h4>Action</h4>
-<p>Tests that an object is an empty string, directory or collection.
-
-<h4>Constructor</h4>
-<div class="code"><pre>
-EmptyConstraint()
-</pre></div>
-
-<h4>Syntax</h4>
-<div class="code"><pre>
-Is.Empty
-</pre></div>
-
-<h4>Examples of Use</h4>
-<div class="code"><pre>
-Assert.That( aString, Is.Empty );
-Assert.Thst( dirInfo, Is.Empty );
-Assert.That( collection, Is.Empty );
-</pre></div>
-
-<h4>Notes</h4>
-<ol>
-<li><b>EmptyConstraint</b> creates and uses either an <b>EmptyStringConstraint</b>,
-<b>EmptyDirectoryConstraint</b> or <b>EmptyCollectionConstraint</b> depending on 
-the argument tested.
-<li>A <b>DirectoryInfo</b> argument is required in order to test for an empty directory.
-To test whether a string represents a directory path, you must first construct
-a <b>DirectoryInfo</b>.
-</ol>
-
-<h3>UniqueItemsConstraint</h3>
-
-<h4>Action</h4>
-<p>Tests that an array, collection or other IEnumerable is composed
-of unique items with no duplicates.
-
-<h4>Constructor</h4>
-<div class="code"><pre>
-UniqueItemsConstraint()
-</pre></div>
-
-<h4>Syntax</h4>
-<div class="code"><pre>
-Is.Unique
-</pre></div>
-
-<h4>Example of Use</h4>
-
-<div class="code"><pre>
-Assert.That( collection, Is.Unique );
-</pre></div>
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<ul>
-<li><a href="equalConstraint.html">Equal&nbsp;Constraint</a></li>
-<li><a href="sameasConstraint.html">SameAs&nbsp;Constraint</a></li>
-<li id="current"><a href="conditionConstraints.html">Condition&nbsp;Constraints</a></li>
-<li><a href="comparisonConstraints.html">Comparison&nbsp;Constrants</a></li>
-<li><a href="pathConstraints.html">Path&nbsp;Constraints</a></li>
-<li><a href="typeConstraints.html">Type&nbsp;Constraints</a></li>
-<li><a href="stringConstraints.html">String&nbsp;Constraints</a></li>
-<li><a href="collectionConstraints.html">Collection&nbsp;Constraints</a></li>
-<li><a href="propertyConstraint.html">Property&nbsp;Constraint</a></li>
-<li><a href="throwsConstraint.html">Throws&nbsp;Constraint</a></li>
-<li><a href="compoundConstraints.html">Compound&nbsp;Constraints</a></li>
-<li><a href="delayedConstraint.html">Delayed&nbsp;Constraint</a></li>
-<li><a href="listMapper.html">List&nbsp;Mapper</a></li>
-<li><a href="reusableConstraint.html">Reusable&nbsp;Constraint</a></li>
-</ul>
-<li><a href="attributes.html">Attributes</a></li>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/configEditor.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/configEditor.html b/lib/NUnit.org/NUnit/2.5.9/doc/configEditor.html
deleted file mode 100644
index 221e5ff..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/configEditor.html
+++ /dev/null
@@ -1,103 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - ConfigEditor</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h2>Configuration Editor</h2>
-
-<p>The Configuration Editor is displayed using the Project | Configuration | Edit� menu item and
-supports the following operations:</p>
-
-<div class="screenshot-right">
-   <img src="img/configEditor.jpg"></div>
-
-<h3>Remove</h3>
-<p>Remove the selected configuration. If it was
-the active config, then the next one in the list
-is made active.</p>
-
-<h3>Rename</h3>
-<p>Rename the selected configuration.</p>
-
-<h3>Add�</h3>
-<p>Add a new configuration. The Add
-Configuration dialog allows specifying an
-existing configuration to use as a template.</p>
-
-<h3>Make Active</h3>
-<p>Makes the selected configuration active.</p>
-
-<h3>Close</h3>
-<p>Exits the configuration editor</p>
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<ul>
-<li><a href="nunit-console.html">Console&nbsp;Runner</a></li>
-<li><a href="nunit-gui.html">Gui&nbsp;Runner</a></li>
-<ul>
-<li><a href="guiCommandLine.html">Command-Line</a></li>
-<li><a href="mainMenu.html">Main&nbsp;Menu</a></li>
-<li><a href="contextMenu.html">Context&nbsp;Menu</a></li>
-<li><a href="settingsDialog.html">Settings&nbsp;Dialog</a></li>
-<li><a href="addinsDialog.html">Addins&nbsp;Dialog</a></li>
-<li><a href="testProperties.html">Test&nbsp;Properties</a></li>
-<li id="current"><a href="configEditor.html">Configuration&nbsp;Editor</a></li>
-<li><a href="projectEditor.html">Project&nbsp;Editor</a></li>
-</ul>
-<li><a href="pnunit.html">PNUnit&nbsp;Runner</a></li>
-<li><a href="runtimeSelection.html">Runtime&nbsp;Selection</a></li>
-<li><a href="assemblyIsolation.html">Assembly&nbsp;Isolation</a></li>
-<li><a href="configFiles.html">Configuration&nbsp;Files</a></li>
-<li><a href="multiAssembly.html">Multiple&nbsp;Assemblies</a></li>
-<li><a href="vsSupport.html">Visual&nbsp;Studio&nbsp;Support</a></li>
-</ul>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/configFiles.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/configFiles.html b/lib/NUnit.org/NUnit/2.5.9/doc/configFiles.html
deleted file mode 100644
index 598d5fd..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/configFiles.html
+++ /dev/null
@@ -1,159 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - ConfigFiles</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h2>Configuration Files</h2>
-
-<p>NUnit uses configuration files for the test runner executable � either nunit-console.exe or
-nunitgui.exe � as well as for the tests being run. Only settings that pertain to NUnit itself should be in
-the nunit-console.exe.config and nunit-gui.exe.config, while those that pertain to your own
-application and tests should be in a separate configuration file.</p>
-
-<h3>NUnit Configuration Files</h3>
-
-<p>One main purpose of the nunit-console and nunit-gui config files is to allow 
-NUnit to run with various versions of the .NET framework. NUnit is built using
-versions 1.1 and 2.0 of the framework. The two builds are provided as separate
-downloads and either build can be made to run against other versions of the CLR.</p>
- 
-<p>As delivered, the <startup> section of each config file is commented out,
-causing NUnit to run with the version of .NET used to build it. If you uncomment 
-the <startup> section, the entries there control the order in which alternate 
-framework versions are selected.</p>
-
-<h3>Test Configuration File</h3>
-
-<p>When a configuration file is used to provide settings or to control the environment in which a test
-is run, specific naming conventions must be followed.</p>
-
-<p>If a single assembly is being loaded, then the configuration file is given the name of the assembly
-file with the config extension. For example, the configuration file used to run nunit.tests.dll must
-be named nunit.tests.dll.config and located in the same directory as the dll.</p>
-
-<p>If an NUnit project is being loaded into a single AppDomain, the configuration file uses the 
-name of the project file with the extension <i>changed</i> to config. For example, the project 
-AllTests.nunit would require a configuration file named AllTests.config, located in the same 
-directory as AllTests.nunit. The same rule is followed when loading Visual Studio projects or solutions.</p>
-
-<blockquote>
-<p><b>Note:</b> The above only applies if a single AppDomain is being used. If an NUnit 
-project is loaded using a separate AppDomain for each assembly, then the individual
-configuration files for each of the assemblies are used.
-</blockquote>
-
-<p>Generally, you should be able to simply copy your application config file and rename it as
-described above.</p>
-
-<p>It is also possible to effect the behavior of NUnit by adding special sections
-to the test config file. A config file using these sections might look like this:
-
-<div class="code" style="width: 36em">
-<pre>
-&lt;?xml version="1.0" encoding="utf-8" ?&gt;
-&lt;configuration&gt;
-  &lt;configSections&gt;
-    &lt;sectionGroup name="NUnit"&gt;
-      &lt;section name="TestCaseBuilder"
-	    type="System.Configuration.NameValueSectionHandler"/&gt;
-      &lt;section name="TestRunner"
-	    type="System.Configuration.NameValueSectionHandler"/&gt;
-    &lt;/sectionGroup&gt;
-  &lt;/configSections&gt;
-	
-  &lt;NUnit&gt;
-    &lt;TestCaseBuilder&gt;
-      &lt;add key="OldStyleTestCases" value="false" /&gt;
-    &lt;/TestCaseBuilder&gt;
-    &lt;TestRunner&gt;
-      &lt;add key="ApartmentState" value="MTA" /&gt;
-      &lt;add key="ThreadPriority" value="Normal" /&gt;
-	  &lt;add key="DefaultLogThreshold" value="Error" /&gt;
-	&lt;/TestRunner&gt;
-  &lt;/NUnit&gt;
-	
-  ...
-	
-&lt;/configuration&gt; 
-</pre>
-</div>
-
-<p>The entries in the above file are all 
-set to default values. The meaning of each setting is as follows:
-
-<h4>OldStyleTestCases</h4>
-<p>If set to "true" NUnit will recognize methods beginning 
-"test..." as tests. The prefix is case insensitive.
-
-<h4>ApartmentState</h4>
-<p>Sets the apartment state for the thread used to run tests.
-
-<h4>ThreadPriority</h4>
-<p>Sets the thread priority for the test thread.
-
-<h4>DefaultLogThreshold</h4>
-<p>Sets the level for logging captured by NUnit. In the
-current version only log4net logging is captured, so the
-level must be one that is defined by log4net.
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<ul>
-<li><a href="nunit-console.html">Console&nbsp;Runner</a></li>
-<li><a href="nunit-gui.html">Gui&nbsp;Runner</a></li>
-<li><a href="pnunit.html">PNUnit&nbsp;Runner</a></li>
-<li><a href="runtimeSelection.html">Runtime&nbsp;Selection</a></li>
-<li><a href="assemblyIsolation.html">Assembly&nbsp;Isolation</a></li>
-<li id="current"><a href="configFiles.html">Configuration&nbsp;Files</a></li>
-<li><a href="multiAssembly.html">Multiple&nbsp;Assemblies</a></li>
-<li><a href="vsSupport.html">Visual&nbsp;Studio&nbsp;Support</a></li>
-</ul>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/consoleCommandLine.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/consoleCommandLine.html b/lib/NUnit.org/NUnit/2.5.9/doc/consoleCommandLine.html
deleted file mode 100644
index 4d65495..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/consoleCommandLine.html
+++ /dev/null
@@ -1,314 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - ConsoleCommandLine</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h2>NUnit-Console Command Line Options</h2>
-<p>The console interface has a few additional options compared to the forms 
-	interface. The command line must always specify one or more file names. The 
-	console interface always creates an XML representation of the test results. 
-	This file by default is called TestResult.xml and is placed in the working 
-	directory.</p>
-<p><b>Note:</b> By default the nunit-console program is not added to your path. You 
-	must do this manually if this is the desired behavior.</p>
-<p><b>Note:</b> Under the Windows operating system, options may be prefixed by either
-    a forward slash or a hyphen. Under Linux, a hyphen must be used. Options that
-	take values may use an equal sign, a colon or a space to separate the option 
-	from its value.</p>
-<h4>Specifying an Assembly</h4>
-<p>The console program must always have an assembly or project specified. To run 
-the tests contained in the nunit.tests.dll use the following command:</p>
-<pre class="programtext">        nunit-console nunit.tests.dll</pre>
-
-<p>To run the tests in nunit.tests.dll through the Visual Studio project, use:</p>
-	<pre class="programtext">        nunit-console nunit.tests.csproj</pre>
-
-<p>To run the same tests through an NUnit test project you have defined, use:</p>
-	<pre class="programtext">        nunit-console nunit.tests.nunit</pre>
-
-<h4>Specifying an Assembly and a Test to be Run</h4>
-<p>You may specify a test to be run by providing the full name of the test along
-with the containing assembly. For example to run NUnit.Tests.AssertionTests
-in the nunit.tests assembly use the following command:
-<pre class="programtext">        nunit-console /run:NUnit.Tests.AssertionTests nunit.tests.dll</pre>
-
-<p>The name of the test to be run may be that of a test case, test fixture or
-a namespace. 
-
-<p>You can specify multiple tests by separating names with commas (without spaces). For example:
-<pre class="programtext">        nunit-console /run:NUnit.Tests.AssertionTests,NUnit.Tests.ConstraintTests nunit.tests.dll</pre>
-
-<p>Unlike the <b>/fixture</b> option, this option affects the running
-rather than the loading of the tests. Consequently it supports much broader use,
-including situations involving SetUpFixtures, which are not run if the class
-in question is not loaded. You should use <b>/run</b> in lieu of <b>/fixture</b>
-in most cases.
-
-<h4>Specifying an Assembly and a Fixture to be Loaded</h4>
-<p>When specifying a fixture, you must give the full name of the test fixture 
-	along with the containing assembly. For example, to load the 
-	NUnit.Tests.AssertionTests in the nunit.tests.dll assembly use the following 
-	command:
-	<pre class="programtext">        nunit-console /fixture:NUnit.Tests.AssertionTests nunit.tests.dll</pre>
-</p>
-<p>The name specified after the <b>/fixture</b> option may be that of a TestFixture 
-	class, a legacy suite (using the Suite property ) or a namespace. If a 
-	namespace is given, then all fixtures under that namespace are loaded.</p>
-<p>This option is provided for backward compatibility. In most cases, you will
-be better served by using the <b>/run</b> option.
-	
-<h4>Specifying the .NET Framework Version</h4>
-
-<p>Most applications are written to run under a specific version of the CLR.
-A few are designed to operate correctly under multiple versions. In either case,
-it is important to be able to specify the CLR version to be used for testing.</p>
-
-<p>Prior to version 2.5, it was necessary to run the console program itself using
-the CLR version under which you wanted to run tests. This was done either by 
-editing the nunit-console.exe.config file or by setting the COMPLUS_Version
-environment variable before running the program.
-
-<p>Under NUnit 2.5 and later versions, you may still use either of these approaches, 
-but a simpler method is available.
-
-<p>The <b>/framework</b> option allows you to specify the version of the runtime
-    to be used in executing tests. If that version specified is different from the
-    one being used by NUnit, the tests are run in a separate process. For example,
-    you may enter
-    <pre class="programtext">        nunit-console myassembly.dll /framework:net-1.1</pre>
-</p>
-	
-<p>This command will run tests under .NET 1.1 even if you are running the .NET 2.0
-	build of the nunit-console. Beginning with version 2.5.3, all versions of .NET 
-	through 4.0 as well	as Mono profiles 1.0, 2.0 and 3.5 are supported.
-
-<h4>Specifying Test Categories to Include or Exclude</h4>
-<p>NUnit provides CategoryAttribute for use in marking tests as belonging to 
-	one or more categories. Categories may be included or excluded in a test run 
-	using the <b>/include</b> and <b>/exclude</b> options. The following command 
-	runs only the tests in the BaseLine category:
-	<pre class="programtext">        nunit-console myassembly.dll /include:BaseLine</pre>
-</p>
-<p>The following command runs all tests <b>except</b> those in the Database 
-	category:
-	<pre class="programtext">        nunit-console myassembly.dll /exclude:Database</pre>
-</p>
-<p>
-Multiple categories may be specified on either option, by using commas to 
-separate them.
-<p><b>Notes:</b> Beginning with NUnit 2.4, the /include and /exclude options may
-   be combined on the command line. When both are used, all tests with the included 
-   categories are run except for those with the excluded categories.</p>
-   
-<p>Beginning with NUnit 2.4.6, you may use a <b>Category Expression</b> with either
-of these options:
-<dl>
-	<dt>A|B|C
-	<dd>Selects tests having any of the categories A, B or C.
-	<dt>A,B,C
-	<dd>Selects tests having any of the categories A, B or C.
-	<dt>A+B+C
-	<dd>Selects only tests having all three of the categories assigned
-	<dt>A+B|C
-	<dd>Selects tests with both A and B OR with category C.
-	<dt>A+B-C
-	<dd>Selects tests with both A and B but not C.
-	<dt>-A
-	<dd>Selects tests not having category A assigned
-	<dt>A+(B|C)
-	<dd>Selects tests having both category A and either of B or C
-</dl>
-<p>The comma operator is equivalent to | but has a higher precendence. Order
-of evaluation is as follows:
-<ol>
-<li>Unary exclusion operator (-)
-<li>High-precendence union operator (,)
-<li>Intersection and set subtraction operators (+ and binary -)
-<li>Low-precedence union operator (|)
-</ol>
-
-<p><b>Note:</b> Because the operator characters have special meaning,
-you should avoid creating a category that uses any of them in it's name.
-For example, the category "db-tests" could not be used on the command
-line, since it appears to means "run category db, except for category tests."
-The same limitation applies to characters that have special meaning for
-the shell you are using.
-   
-<p>For a clear understanding of how category 
-	selection works, review the documentation for both the 
-	<a href="category.html">Category Attribute</a> and the 
-	<a href="explicit.html">Explicit Attribute</a>.</p>
-<h4>Redirecting Output</h4>
-<p>Output created by the test, which is normally shown on the console, may be 
-    redirected to a file. The following command redirects standard output to the 
-	file TestResult.txt:
-	<pre class="programtext">        nunit-console nunit.tests.dll /out:TestResult.txt</pre>
-</p>
-<p>The following command redirects standard error output to the StdErr.txt file.
-	<pre class="programtext">        nunit-console nunit.tests.dll /err:StdErr.txt</pre>
-</p>
-
-<p><b>Note:</b>This option only redirects output produced <b>by the tests</b>,
-    together with selected NUnit output that is interspersed with the test output.
-	It does not redirect <b>all</b> console output. If you want to redirect <b>all</b>
-	output to a file, you should use command line redirection as supported by the
-	shell you are using. This option exists for the purpose of separating test
-	output from other output, such as the NUnit summary report.
-
-<h4>Labeling Test Output</h4>
-<p>The output from each test normally follows right after that of the preceding 
-	test. You may use the <b>/labels</b> option to cause an identifying label to be 
-	displayed at the start of each test case.</p>
-<h4>Specifying the XML file name</h4>
-<p>As stated above, the console program always creates an XML representation of the 
-	test results. To change the name of the output file to 
-	&quot;console-test.xml&quot; use the following command line option:
-	<pre class="programtext">        nunit-console /xml:console-test.xml nunit.tests.dll</pre>
-</p>
-<p><b>Note:</b> For additional information see the XML schema for the test results. 
-	This file is in the same directory as the executable and is called
-	<a href="files/Results.xsd">Results.xsd</a>. 
-
-<h4>Specifying which Configuration to run</h4>
-<p>When running tests from a Visual Studio or NUnit project, the first 
-	configuration found will be loaded by default. Usually this is Debug. The 
-	configuration loaded may be controlled by using the <b>/config</b> switch. The 
-	following will load and run tests for the Release configuration of 
-	nunit.tests.dll.
-	<pre class="programtext">        nunit-console nunit.tests.csproj /config:Release</pre>
-</p>
-<p><b>Note:</b> This option has no effect when loading an assembly directly.</p>
-<h4>Specifying Multiple Assemblies</h4>
-<p>You may run tests from multiple assemblies in one run using the console 
-	interface even if you have not defined an NUnit test project file. The 
-	following command would run a suite of tests contained in assembly1.dll, 
-	assembly2.dll and assembly3.dll.
-	<pre class="programtext">        nunit-console assembly1.dll assembly2.dll assembly3.dll</pre>
-</p>
-<p><b>Notes:</b> You may specify multiple assemblies, but not multiple NUnit or 
-	Visual Studio projects on the command line. Further, you may not specify an 
-	NUnit or Visual Studio project together with a list of assemblies.</p>
-<p>Beginning with NUnit 2.4, the console loads multiple assemblies specified
-   in this way into separate AppDomains by default. You may provide a separate
-   config file for each assembly. You may override the default by use of the
-   <b>/domain</b> option.
-<p>Beginning with NUnit 2.4, the <b>/fixture</b>
-	option, when used with multiple assemblies, will run tests matching the 
-	fixture name in all the assemblies. In earlier versions, only the first
-	test found was executed.</p>
-<h4>Controlling the Use of Processes</h4>
-<p>The <b>/process</b> option controls how NUnit loads tests in processes. The
-   following values are recognized.
-   <dl style="margin-left: 2em">
-   <dt><b>Single</b>
-   <dd>All the tests are run in the nunit-console process. This is the default.
-   <dt><b>Separate</b>
-   <dd>A separate process is created to run the tests.
-   <dt><b>Multiple</b>
-   <dd>A separate process is created for each test assembly, whether specified
-   on the command line or listed in an NUnit project file.
-   </dl>
-<h4>Controlling the Use of AppDomains</h4>
-<p>The <b>/domain</b> option controls of the creation of AppDomains for running tests.
-    The following values are recognized:</p>
-	<dl style="margin-left: 2em">
-	<dt><b>None</b>
-	<dd>No domain is created - the tests are run in the primary domain. This normally
-	requires copying the <b>NUnit</b> assemblies into the same directory as your tests.
-	<dt><b>Single</b>
-	<dd>A test domain is created - this is how NUnit worked prior to version 2.4
-	<dt><b>Multiple</b>
-	<dd>A separate test domain is created for each assembly
-	</dl>
-<p>The default is to use multiple domains if multiple assemblies are listed on 
-	the command line. Otherwise a single domain is used.</p>
-	
-<h4>Specifying a Default Timeout Value</h4>
-<p>The <b>/timeout</b> option takes an int value representing the default timeout
-to be used for test cases in this run. If any test exceeds the timeout value,
-it is cancelled and reported as an error. The default value may be overridden
-for selected tests by use of <b>TimeoutAttribute</b>.
-
-<p><b>Note:</b> If you do not use this option, no timeout is set and tests
-may run for any amount of time.
-
-<h4>Other Options</h4>
-<p>The <b>/trace</b> option allows you to control the amount of information that NUnit
-	writes to its internal trace log. Valid values are Off, Error, Warning,Info
-	and Debug. The default is Off.
-<p>The <b>/noshadow</b> option disables shadow copying of the assembly in order to 
-	provide improved performance.</p>
-<p>The <b>/nothread</b> option suppresses use of a separate thread for running the 
-	tests and uses the main thread instead.</p>
-<p>The <b>/wait</b> option causes the program to wait for user input before 
-	exiting. This is useful when running nunit-console from a shortcut.</p>
-<p>The <b>/xmlconsole</b> option displays raw XML output on the console rather than 
-	transforming it. This is useful when debugging problems with the XML format.</p>
-<p>The <b>/nologo</b> option disables display of the copyright information at the 
-	start of the program.</p>
-<p>The <b>/help</b> or <b>/?</b> option displays a brief help message</p>
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<ul>
-<li><a href="nunit-console.html">Console&nbsp;Runner</a></li>
-<ul>
-<li id="current"><a href="consoleCommandLine.html">Command-Line</a></li>
-</ul>
-<li><a href="nunit-gui.html">Gui&nbsp;Runner</a></li>
-<li><a href="pnunit.html">PNUnit&nbsp;Runner</a></li>
-<li><a href="runtimeSelection.html">Runtime&nbsp;Selection</a></li>
-<li><a href="assemblyIsolation.html">Assembly&nbsp;Isolation</a></li>
-<li><a href="configFiles.html">Configuration&nbsp;Files</a></li>
-<li><a href="multiAssembly.html">Multiple&nbsp;Assemblies</a></li>
-<li><a href="vsSupport.html">Visual&nbsp;Studio&nbsp;Support</a></li>
-</ul>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/constraintModel.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/constraintModel.html b/lib/NUnit.org/NUnit/2.5.9/doc/constraintModel.html
deleted file mode 100644
index 97e2870..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/constraintModel.html
+++ /dev/null
@@ -1,167 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - ConstraintModel</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h2>Constraint-Based Assert Model (NUnit 2.4)</h2>
-
-<p>The constraint-based Assert model uses a single method of the Assert class
-   for all assertions. The logic necessary to carry out each assertion is
-   embedded in the constraint object passed as the second parameter to that
-   method.
-   
-<p>Here's a very simple assert using the constraint model:
-<pre>      Assert.That( myString, Is.EqualTo("Hello") );</pre>
-
-<p>The second argument in this assertion uses one of NUnit's <b>syntax helpers</b>
-to create an <b>EqualConstraint</b>. The same assertion could also be made in this form:
-<pre>      Assert.That( myString, new EqualConstraint("Hello") );</pre>
-
-<p>Using this model, all assertions are made using one of the forms of the
-   Assert.That() method, which has a number of overloads...
-   
-<div class="code" style="width: 36em">
-<pre>
-Assert.That( object actual, IResolveConstraint constraint )
-Assert.That( object actual, IResolveConstraint constraint, 
-             string message )
-Assert.That( object actual, IResolveConstraint constraint,
-             string message, object[] parms )
-			 
-Assert.That( ActualValueDelegate del, IResolveConstraint constraint )
-Assert.That( ActualValueDelegate del, IResolveConstraint constraint, 
-             string message )
-Assert.That( ActualValueDelegate del, IResolveConstraint constraint,
-             string message, object[] parms )
-			 
-Assert.That<T>( ref T actual, IResolveConstraint constraint )
-Assert.That<T>( ref T actual, IResolveConstraint constraint, 
-             string message )
-Assert.That<T>( ref T actual, IResolveConstraint constraint,
-             string message, object[] parms )
-			 
-Assert.That( bool condition );
-Assert.That( bool condition, string message );
-Assert.That( bool condition, string message, object[] parms );
-
-Assert.That( TestDelegate del, IResolveConstraint constraint );
-</pre>
-</div>
-
-<p>If you derive your test fixture class from <b>AssertionHelper</b>, the
-Expect() method may be used in place of Assert.That()...
-
-<div class="code" style="width: 36em">
-<pre>
-Expect( object actual, IResolveConstraint constraint )
-Expect( object actual, IResolveConstraint constraint, 
-             string message )
-Expect( object actual, IResolveConstraint constraint, 
-             string message, object[] parms )
-			 
-Expect( ActualValueDelegate del, IResolveConstraint constraint )
-Expect( ActualValueDelegate del, IResolveConstraint constraint, 
-             string message )
-Expect( ActualValueDelegate del, IResolveConstraint constraint,
-             string message, object[] parms )
-			 
-Expect<T>( ref T actual, IResolveConstraint constraint )
-Expect<T>( ref T actual, IResolveConstraint constraint, 
-             string message )
-Expect<T>( ref T actual, IResolveConstraint constraint,
-             string message, object[] parms )
-			 
-Expect( bool condition );
-Expect( bool condition, string message );
-Expect( bool condition, string message, object[] parms );
-
-Expect( TestDelegate del, IResolveConstraint constraint );
-</pre>
-</div>
-
-<p>The overloads that take a bool work exactly like Assert.IsTrue.
-   
-<p>For overloads taking a constraint, the argument must be a object implementing 
-  the <b>IConstraint</b> interface, which supports performing a test
-   on an actual value and generating appropriate messages. This interface
-   is described in more detail under 
-   <a href="customConstraints.html">Custom Constraints</a>.
-   
-<p>NUnit provides a number of constraint classes similar to the <b>EqualConstraint</b>
-   used in the example above. Generally, these classes may be used directly or
-   through a syntax helper. Test fixture classes inheriting from <b>AssertionHelper</b>
-   are able to use shorter forms. The valid forms are described on the pages related to
-   each constraint. Note that the menu items listed to the right generally reflect the
-   names of the syntax helpers.
-   
-<p><b>See also:</b> the 
-<a href="classicModel.html">classic model</a> of assertions.
-   
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li id="current"><a href="constraintModel.html">Constraints</a></li>
-<ul>
-<li><a href="equalConstraint.html">Equal&nbsp;Constraint</a></li>
-<li><a href="sameasConstraint.html">SameAs&nbsp;Constraint</a></li>
-<li><a href="conditionConstraints.html">Condition&nbsp;Constraints</a></li>
-<li><a href="comparisonConstraints.html">Comparison&nbsp;Constrants</a></li>
-<li><a href="pathConstraints.html">Path&nbsp;Constraints</a></li>
-<li><a href="typeConstraints.html">Type&nbsp;Constraints</a></li>
-<li><a href="stringConstraints.html">String&nbsp;Constraints</a></li>
-<li><a href="collectionConstraints.html">Collection&nbsp;Constraints</a></li>
-<li><a href="propertyConstraint.html">Property&nbsp;Constraint</a></li>
-<li><a href="throwsConstraint.html">Throws&nbsp;Constraint</a></li>
-<li><a href="compoundConstraints.html">Compound&nbsp;Constraints</a></li>
-<li><a href="delayedConstraint.html">Delayed&nbsp;Constraint</a></li>
-<li><a href="listMapper.html">List&nbsp;Mapper</a></li>
-<li><a href="reusableConstraint.html">Reusable&nbsp;Constraint</a></li>
-</ul>
-<li><a href="attributes.html">Attributes</a></li>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/contextMenu.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/contextMenu.html b/lib/NUnit.org/NUnit/2.5.9/doc/contextMenu.html
deleted file mode 100644
index 55daca9..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/contextMenu.html
+++ /dev/null
@@ -1,116 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - ContextMenu</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h2>Context Menu</h2>
-
-<p>The context menu is displayed when one of the tree nodes is right-clicked.</p>
-
-<h4>Run</h4>
-<p>Runs the selected test - disabled if a test is running.</p>
-
-<h4>Run All</h4>
-<p>Runs all the tests.</p>
-
-<h4>Run Failed</h4>
-<p>Runs only the tests that failed on the previous run.</p>
-
-<h4>Show Checkboxes</h4>
-<p>Turns the display of checkboxes in the tree on or off. The checkboxes may
-   be used to select multiple tests for running.</p>
-   
-<h4>Expand</h4>
-<p>Expands the selected test node � invisible if the node is expanded or has no children.</p>
-
-<h4>Collapse</h4>
-<p>Collapses the selected test node � invisible if the node is collapsed or has no children.</p>
-
-<h4>Expand All</h4>
-<p>Expands all nodes of the tree.</p>
-
-<h4>Collapse All</h4>
-<p>Collapses all nodes in the tree to the root.</p>
-
-<h4>Load Fixture</h4>
-<p>Reloads only the currently selected fixture or namespace. The fixture,
-once loaded, remains in effect through any subsequent reloads. This generally
-results in substantial reduction in load time.</p>
-
-<h4>Clear Fixture</h4>
-<p>Reloads all the tests, clearing the currently loaded fixture.</p>
-
-<h4>Properties</h4>
-<p>Displays the <a href="testProperties.html">Test Properties</a> for the selected test node.</p>
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<ul>
-<li><a href="nunit-console.html">Console&nbsp;Runner</a></li>
-<li><a href="nunit-gui.html">Gui&nbsp;Runner</a></li>
-<ul>
-<li><a href="guiCommandLine.html">Command-Line</a></li>
-<li><a href="mainMenu.html">Main&nbsp;Menu</a></li>
-<li id="current"><a href="contextMenu.html">Context&nbsp;Menu</a></li>
-<li><a href="settingsDialog.html">Settings&nbsp;Dialog</a></li>
-<li><a href="addinsDialog.html">Addins&nbsp;Dialog</a></li>
-<li><a href="testProperties.html">Test&nbsp;Properties</a></li>
-<li><a href="configEditor.html">Configuration&nbsp;Editor</a></li>
-<li><a href="projectEditor.html">Project&nbsp;Editor</a></li>
-</ul>
-<li><a href="pnunit.html">PNUnit&nbsp;Runner</a></li>
-<li><a href="runtimeSelection.html">Runtime&nbsp;Selection</a></li>
-<li><a href="assemblyIsolation.html">Assembly&nbsp;Isolation</a></li>
-<li><a href="configFiles.html">Configuration&nbsp;Files</a></li>
-<li><a href="multiAssembly.html">Multiple&nbsp;Assemblies</a></li>
-<li><a href="vsSupport.html">Visual&nbsp;Studio&nbsp;Support</a></li>
-</ul>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>


[10/51] [abbrv] [partial] Cleaning up and getting ready to development towards v4.8

Posted by sy...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/vb/failures/SimpleVBTest.vb
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/vb/failures/SimpleVBTest.vb b/lib/NUnit.org/NUnit/2.5.9/samples/vb/failures/SimpleVBTest.vb
deleted file mode 100644
index 14b49a2..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/vb/failures/SimpleVBTest.vb
+++ /dev/null
@@ -1,60 +0,0 @@
-' ****************************************************************
-' This is free software licensed under the NUnit license. You
-' may obtain a copy of the license as well as information regarding
-' copyright ownership at http://nunit.org/?p=license&r=2.4.
-' ****************************************************************
-
-Option Explicit On 
-Imports System
-Imports NUnit.Framework
-
-Namespace NUnit.Samples
-
-    <TestFixture()> Public Class SimpleVBTest
-
-        Private fValue1 As Integer
-        Private fValue2 As Integer
-
-        Public Sub New()
-            MyBase.New()
-        End Sub
-
-        <SetUp()> Public Sub Init()
-            fValue1 = 2
-            fValue2 = 3
-        End Sub
-
-        <Test()> Public Sub Add()
-            Dim result As Double
-
-            result = fValue1 + fValue2
-            Assert.AreEqual(6, result)
-        End Sub
-
-        <Test()> Public Sub DivideByZero()
-            Dim zero As Integer
-            Dim result As Integer
-
-            zero = 0
-            result = 8 / zero
-        End Sub
-
-        <Test()> Public Sub TestEquals()
-            Assert.AreEqual(12, 12)
-            Assert.AreEqual(CLng(12), CLng(12))
-
-            Assert.AreEqual(12, 13, "Size")
-            Assert.AreEqual(12, 11.99, 0, "Capacity")
-        End Sub
-
-        <Test(), ExpectedException(GetType(Exception))> Public Sub ExpectAnException()
-            Throw New InvalidCastException()
-        End Sub
-
-        <Test(), Ignore("sample ignore")> Public Sub IgnoredTest()
-            ' does not matter what we type the test is not run
-            Throw New ArgumentException()
-        End Sub
-
-    End Class
-End Namespace
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/vb/failures/vb-failures.build
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/vb/failures/vb-failures.build b/lib/NUnit.org/NUnit/2.5.9/samples/vb/failures/vb-failures.build
deleted file mode 100644
index 1d89264..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/vb/failures/vb-failures.build
+++ /dev/null
@@ -1,11 +0,0 @@
-<?xml version="1.0"?>
-<project name="vb-failures" default="build">
-
-  <include buildfile="../../samples.common" />
-
-  <patternset id="source-files">
-    <include name="AssemblyInfo.vb" />
-    <include name="SimpleVBTest.vb" />
-  </patternset>
-
-</project>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/vb/failures/vb-failures.vbproj
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/vb/failures/vb-failures.vbproj b/lib/NUnit.org/NUnit/2.5.9/samples/vb/failures/vb-failures.vbproj
deleted file mode 100644
index 4eff16b..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/vb/failures/vb-failures.vbproj
+++ /dev/null
@@ -1,24 +0,0 @@
-<VisualStudioProject>
-  <VisualBasic ProjectType="Local" ProductVersion="7.10.3077" SchemaVersion="2.0" ProjectGuid="{F199991B-6C8E-4AB0-9AAA-703CD4897700}">
-    <Build>
-      <Settings ApplicationIcon="" AssemblyKeyContainerName="" AssemblyName="vb-failures" AssemblyOriginatorKeyFile="" AssemblyOriginatorKeyMode="None" DefaultClientScript="JScript" DefaultHTMLPageLayout="Grid" DefaultTargetSchema="IE50" DelaySign="false" OutputType="Library" OptionCompare="Binary" OptionExplicit="On" OptionStrict="Off" RootNamespace="vb_failures" StartupObject="vb_failures.(None)">
-        <Config Name="Debug" BaseAddress="285212672" ConfigurationOverrideFile="" DefineConstants="" DefineDebug="true" DefineTrace="true" DebugSymbols="true" IncrementalBuild="true" Optimize="false" OutputPath="bin\" RegisterForComInterop="false" RemoveIntegerChecks="false" TreatWarningsAsErrors="false" WarningLevel="1" />
-        <Config Name="Release" BaseAddress="285212672" ConfigurationOverrideFile="" DefineConstants="" DefineDebug="false" DefineTrace="true" DebugSymbols="false" IncrementalBuild="false" Optimize="true" OutputPath="bin\" RegisterForComInterop="false" RemoveIntegerChecks="false" TreatWarningsAsErrors="false" WarningLevel="1" />
-      </Settings>
-      <References>
-        <Reference Name="System" AssemblyName="System" />
-        <Reference Name="nunit.framework" AssemblyName="nunit.framework, Version=2.5, Culture=neutral, PublicKeyToken=96d09a1eb7f44a77" HintPath="..\..\..\bin\net-1.1\framework\nunit.framework.dll" />
-      </References>
-      <Imports>
-        <Import Namespace="Microsoft.VisualBasic" />
-        <Import Namespace="System" />
-      </Imports>
-    </Build>
-    <Files>
-      <Include>
-        <File RelPath="AssemblyInfo.vb" SubType="Code" BuildAction="Compile" />
-        <File RelPath="SimpleVBTest.vb" SubType="Code" BuildAction="Compile" />
-      </Include>
-    </Files>
-  </VisualBasic>
-</VisualStudioProject>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/vb/money/AssemblyInfo.vb
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/vb/money/AssemblyInfo.vb b/lib/NUnit.org/NUnit/2.5.9/samples/vb/money/AssemblyInfo.vb
deleted file mode 100644
index f929cbc..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/vb/money/AssemblyInfo.vb
+++ /dev/null
@@ -1,32 +0,0 @@
-Imports System
-Imports System.Reflection
-Imports System.Runtime.InteropServices
-
-' General Information about an assembly is controlled through the following 
-' set of attributes. Change these attribute values to modify the information
-' associated with an assembly.
-
-' Review the values of the assembly attributes
-
-<Assembly: AssemblyTitle("")> 
-<Assembly: AssemblyDescription("")> 
-<Assembly: AssemblyCompany("")> 
-<Assembly: AssemblyProduct("")> 
-<Assembly: AssemblyCopyright("")> 
-<Assembly: AssemblyTrademark("")> 
-<Assembly: CLSCompliant(True)> 
-
-'The following GUID is for the ID of the typelib if this project is exposed to COM
-<Assembly: Guid("F21BB3B6-0C5E-4AE5-ABC7-4D25FC3F98DB")> 
-
-' Version information for an assembly consists of the following four values:
-'
-'      Major Version
-'      Minor Version 
-'      Build Number
-'      Revision
-'
-' You can specify all the values or you can default the Build and Revision Numbers 
-' by using the '*' as shown below:
-
-<Assembly: AssemblyVersion("1.0.*")> 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/vb/money/IMoney.vb
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/vb/money/IMoney.vb b/lib/NUnit.org/NUnit/2.5.9/samples/vb/money/IMoney.vb
deleted file mode 100644
index ddc8ae6..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/vb/money/IMoney.vb
+++ /dev/null
@@ -1,37 +0,0 @@
-' ****************************************************************
-' This is free software licensed under the NUnit license. You
-' may obtain a copy of the license as well as information regarding
-' copyright ownership at http://nunit.org/?p=license&r=2.4.
-' ****************************************************************
-
-Namespace NUnit.Samples
-
-    'The common interface for simple Monies and MoneyBags.
-    Public Interface IMoney
-
-        'Adds a money to this money
-        Function Add(ByVal m As IMoney) As IMoney
-
-        'Adds a simple Money to this money. This is a helper method for
-        'implementing double dispatch.
-        Function AddMoney(ByVal m As Money) As IMoney
-
-        'Adds a MoneyBag to this money. This is a helper method for
-        'implementing double dispatch.
-        Function AddMoneyBag(ByVal s As MoneyBag) As IMoney
-
-        'True if this money is zero.
-        ReadOnly Property IsZero() As Boolean
-
-        'Multiplies a money by the given factor.
-        Function Multiply(ByVal factor As Int32) As IMoney
-
-        'Negates this money.
-        Function Negate() As IMoney
-
-        'Subtracts a money from this money.
-        Function Subtract(ByVal m As IMoney) As IMoney
-
-    End Interface
-
-End Namespace

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/vb/money/Money.vb
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/vb/money/Money.vb b/lib/NUnit.org/NUnit/2.5.9/samples/vb/money/Money.vb
deleted file mode 100644
index f7699a8..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/vb/money/Money.vb
+++ /dev/null
@@ -1,109 +0,0 @@
-' ****************************************************************
-' This is free software licensed under the NUnit license. You
-' may obtain a copy of the license as well as information regarding
-' copyright ownership at http://nunit.org/?p=license&r=2.4.
-' ****************************************************************
-
-Option Explicit On 
-
-Namespace NUnit.Samples
-
-    ' A Simple Money.
-    Public Class Money
-        Implements IMoney
-
-        Private fAmount As Int32
-        Private fCurrency As String
-
-        ' Constructs a money from a given amount and currency.
-        Public Sub New(ByVal amount As Int32, ByVal currency As String)
-            Me.fAmount = amount
-            Me.fCurrency = currency
-        End Sub
-
-
-        ' Adds a money to this money. Forwards the request
-        ' to the AddMoney helper.
-        Public Overloads Function Add(ByVal m As IMoney) As IMoney Implements IMoney.Add
-            Return m.AddMoney(Me)
-        End Function
-
-        Public Overloads Function AddMoney(ByVal m As Money) As IMoney Implements IMoney.AddMoney
-            If m.Currency.Equals(Currency) Then
-                Return New Money(Amount + m.Amount, Currency)
-            End If
-
-            Return New MoneyBag(Me, m)
-        End Function
-
-        Public Function AddMoneyBag(ByVal s As MoneyBag) As IMoney Implements IMoney.AddMoneyBag
-            Return s.AddMoney(Me)
-        End Function
-
-        Public ReadOnly Property Amount() As Integer
-            Get
-                Return fAmount
-            End Get
-        End Property
-
-        Public ReadOnly Property Currency() As String
-            Get
-                Return fCurrency
-            End Get
-        End Property
-
-        Public Overloads Overrides Function Equals(ByVal anObject As Object) As Boolean
-            If IsZero And TypeOf anObject Is IMoney Then
-                Dim aMoney As IMoney = anObject
-                Return aMoney.IsZero
-            End If
-
-            If TypeOf anObject Is Money Then
-                Dim aMoney As Money = anObject
-                If (IsZero) Then
-                    Return aMoney.IsZero
-                End If
-
-                Return Currency.Equals(aMoney.Currency) And Amount.Equals(aMoney.Amount)
-            End If
-
-            Return False
-        End Function
-
-        Public Overrides Function GetHashCode() As Int32
-            Return fCurrency.GetHashCode() + fAmount
-        End Function
-
-        Public ReadOnly Property IsZero() As Boolean Implements IMoney.IsZero
-            Get
-                Return Amount.Equals(0)
-            End Get
-        End Property
-
-        Public Function Multiply(ByVal factor As Integer) As IMoney Implements IMoney.Multiply
-
-            Return New Money(Amount * factor, Currency)
-
-        End Function
-
-        Public Function Negate() As IMoney Implements IMoney.Negate
-
-            Return New Money(-Amount, Currency)
-
-        End Function
-
-        Public Function Subtract(ByVal m As IMoney) As IMoney Implements IMoney.Subtract
-
-            Return Add(m.Negate())
-
-        End Function
-
-        Public Overrides Function ToString() As String
-
-            Return String.Format("[{0} {1}]", Amount, Currency)
-
-        End Function
-
-    End Class
-
-End Namespace

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/vb/money/MoneyBag.vb
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/vb/money/MoneyBag.vb b/lib/NUnit.org/NUnit/2.5.9/samples/vb/money/MoneyBag.vb
deleted file mode 100644
index 409c1a1..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/vb/money/MoneyBag.vb
+++ /dev/null
@@ -1,164 +0,0 @@
-' ****************************************************************
-' This is free software licensed under the NUnit license. You
-' may obtain a copy of the license as well as information regarding
-' copyright ownership at http://nunit.org/?p=license&r=2.4.
-' ****************************************************************
-
-Option Explicit On 
-
-Namespace NUnit.Samples
-
-    Public Class MoneyBag
-        Implements IMoney
-
-        Private fmonies As ArrayList = New ArrayList(5)
-
-        Private Sub New()
-
-        End Sub
-
-        Public Sub New(ByVal bag As Money())
-            For Each m As Money In bag
-                If Not m.IsZero Then
-                    AppendMoney(m)
-                End If
-            Next
-        End Sub
-
-        Public Sub New(ByVal m1 As Money, ByVal m2 As Money)
-
-            AppendMoney(m1)
-            AppendMoney(m2)
-
-        End Sub
-
-        Public Sub New(ByVal m As Money, ByVal bag As MoneyBag)
-            AppendMoney(m)
-            AppendBag(bag)
-        End Sub
-
-        Public Sub New(ByVal m1 As MoneyBag, ByVal m2 As MoneyBag)
-            AppendBag(m1)
-            AppendBag(m2)
-        End Sub
-
-        Public Function Add(ByVal m As IMoney) As IMoney Implements IMoney.Add
-            Return m.AddMoneyBag(Me)
-        End Function
-
-        Public Function AddMoney(ByVal m As Money) As IMoney Implements IMoney.AddMoney
-            Return New MoneyBag(m, Me).Simplify
-        End Function
-
-        Public Function AddMoneyBag(ByVal s As MoneyBag) As IMoney Implements IMoney.AddMoneyBag
-            Return New MoneyBag(s, Me).Simplify()
-        End Function
-
-        Private Sub AppendBag(ByVal aBag As MoneyBag)
-            For Each m As Money In aBag.fmonies
-                AppendMoney(m)
-            Next
-        End Sub
-
-        Private Sub AppendMoney(ByVal aMoney As Money)
-
-            Dim old As Money = FindMoney(aMoney.Currency)
-            If old Is Nothing Then
-                fmonies.Add(aMoney)
-                Return
-            End If
-            fmonies.Remove(old)
-            Dim sum As IMoney = old.Add(aMoney)
-            If (sum.IsZero) Then
-                Return
-            End If
-            fmonies.Add(sum)
-        End Sub
-
-        Private Function Contains(ByVal aMoney As Money) As Boolean
-            Dim m As Money = FindMoney(aMoney.Currency)
-            Return m.Amount.Equals(aMoney.Amount)
-        End Function
-
-        Public Overloads Overrides Function Equals(ByVal anObject As Object) As Boolean
-            If IsZero Then
-                If TypeOf anObject Is IMoney Then
-                    Dim aMoney As IMoney = anObject
-                    Return aMoney.IsZero
-                End If
-            End If
-
-            If TypeOf anObject Is MoneyBag Then
-                Dim aMoneyBag As MoneyBag = anObject
-                If Not aMoneyBag.fmonies.Count.Equals(fmonies.Count) Then
-                    Return False
-                End If
-
-                For Each m As Money In fmonies
-                    If Not aMoneyBag.Contains(m) Then
-                        Return False
-                    End If
-
-                    Return True
-                Next
-            End If
-
-            Return False
-        End Function
-
-        Private Function FindMoney(ByVal currency As String) As Money
-            For Each m As Money In fmonies
-                If m.Currency.Equals(currency) Then
-                    Return m
-                End If
-            Next
-
-            Return Nothing
-        End Function
-
-        Public Overrides Function GetHashCode() As Int32
-            Dim hash As Int32 = 0
-            For Each m As Money In fmonies
-                hash += m.GetHashCode()
-            Next
-            Return hash
-        End Function
-
-        Public ReadOnly Property IsZero() As Boolean Implements IMoney.IsZero
-            Get
-                Return fmonies.Count.Equals(0)
-            End Get
-        End Property
-
-        Public Function Multiply(ByVal factor As Integer) As IMoney Implements IMoney.Multiply
-            Dim result As New MoneyBag
-            If Not factor.Equals(0) Then
-                For Each m As Money In fmonies
-                    result.AppendMoney(m.Multiply(factor))
-                Next
-            End If
-            Return result
-        End Function
-
-        Public Function Negate() As IMoney Implements IMoney.Negate
-            Dim result As New MoneyBag
-            For Each m As Money In fmonies
-                result.AppendMoney(m.Negate())
-            Next
-            Return result
-        End Function
-
-        Private Function Simplify() As IMoney
-            If fmonies.Count.Equals(1) Then
-                Return fmonies(0)
-            End If
-            Return Me
-        End Function
-
-
-        Public Function Subtract(ByVal m As IMoney) As IMoney Implements IMoney.Subtract
-            Return Add(m.Negate())
-        End Function
-    End Class
-
-End Namespace

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/vb/money/MoneyTest.vb
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/vb/money/MoneyTest.vb b/lib/NUnit.org/NUnit/2.5.9/samples/vb/money/MoneyTest.vb
deleted file mode 100644
index acb2c42..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/vb/money/MoneyTest.vb
+++ /dev/null
@@ -1,216 +0,0 @@
-' ****************************************************************
-' This is free software licensed under the NUnit license. You
-' may obtain a copy of the license as well as information regarding
-' copyright ownership at http://nunit.org/?p=license&r=2.4.
-' ****************************************************************
-
-Option Explicit On 
-
-Imports System
-Imports NUnit.Framework
-
-Namespace NUnit.Samples
-
-    <TestFixture()> _
-    Public Class MoneyTest
-
-        Private f12CHF As Money
-        Private f14CHF As Money
-        Private f7USD As Money
-        Private f21USD As Money
-
-        Private fMB1 As MoneyBag
-        Private fMB2 As MoneyBag
-
-        <SetUp()> _
-        Protected Sub SetUp()
-
-            f12CHF = New Money(12, "CHF")
-            f14CHF = New Money(14, "CHF")
-            f7USD = New Money(7, "USD")
-            f21USD = New Money(21, "USD")
-
-            fMB1 = New MoneyBag(f12CHF, f7USD)
-            fMB2 = New MoneyBag(f14CHF, f21USD)
-
-        End Sub
-
-        <Test()> _
-        Public Sub BagMultiply()
-            ' {[12 CHF][7 USD]} *2 == {[24 CHF][14 USD]}
-            Dim bag() As Money = New Money() {New Money(24, "CHF"), New Money(14, "USD")}
-            Dim expected As New MoneyBag(bag)
-            Assert.AreEqual(expected, fMB1.Multiply(2))
-            Assert.AreEqual(fMB1, fMB1.Multiply(1))
-            Assert.IsTrue(fMB1.Multiply(0).IsZero)
-        End Sub
-
-        <Test()> _
-        Public Sub BagNegate()
-            ' {[12 CHF][7 USD]} negate == {[-12 CHF][-7 USD]}
-            Dim bag() As Money = New Money() {New Money(-12, "CHF"), New Money(-7, "USD")}
-            Dim expected As New MoneyBag(bag)
-            Assert.AreEqual(expected, fMB1.Negate())
-        End Sub
-
-        <Test()> _
-        Public Sub BagSimpleAdd()
-
-            ' {[12 CHF][7 USD]} + [14 CHF] == {[26 CHF][7 USD]}
-            Dim bag() As Money = New Money() {New Money(26, "CHF"), New Money(7, "USD")}
-            Dim expected As New MoneyBag(bag)
-            Assert.AreEqual(expected, fMB1.Add(f14CHF))
-
-        End Sub
-
-        <Test()> _
-        Public Sub BagSubtract()
-            ' {[12 CHF][7 USD]} - {[14 CHF][21 USD] == {[-2 CHF][-14 USD]}
-            Dim bag() As Money = New Money() {New Money(-2, "CHF"), New Money(-14, "USD")}
-            Dim expected As New MoneyBag(bag)
-            Assert.AreEqual(expected, fMB1.Subtract(fMB2))
-        End Sub
-
-        <Test()> _
-        Public Sub BagSumAdd()
-            ' {[12 CHF][7 USD]} + {[14 CHF][21 USD]} == {[26 CHF][28 USD]}
-            Dim bag() As Money = New Money() {New Money(26, "CHF"), New Money(28, "USD")}
-            Dim expected As New MoneyBag(bag)
-            Assert.AreEqual(expected, fMB1.Add(fMB2))
-        End Sub
-
-        <Test()> _
-        Public Sub IsZero()
-            Assert.IsTrue(fMB1.Subtract(fMB1).IsZero)
-
-            Dim bag() As Money = New Money() {New Money(0, "CHF"), New Money(0, "USD")}
-            Assert.IsTrue(New MoneyBag(bag).IsZero)
-        End Sub
-
-        <Test()> _
-        Public Sub MixedSimpleAdd()
-            ' [12 CHF] + [7 USD] == {[12 CHF][7 USD]}
-            Dim bag() As Money = New Money() {f12CHF, f7USD}
-            Dim expected As New MoneyBag(bag)
-            Assert.AreEqual(expected, f12CHF.Add(f7USD))
-        End Sub
-
-        <Test()> _
-        Public Sub MoneyBagEquals()
-            ' NOTE: Normally we use Assert.AreEqual to test whether two
-            ' objects are equal. But here we are testing the MoneyBag.Equals()
-            ' method itself, so using AreEqual would not serve the purpose.
-            Assert.IsFalse(fMB1.Equals(Nothing))
-
-            Assert.IsTrue(fMB1.Equals(fMB1))
-            Dim equal As MoneyBag = New MoneyBag(New Money(12, "CHF"), New Money(7, "USD"))
-            Assert.IsTrue(fMB1.Equals(equal))
-            Assert.IsFalse(fMB1.Equals(f12CHF))
-            Assert.IsFalse(f12CHF.Equals(fMB1))
-            Assert.IsFalse(fMB1.Equals(fMB2))
-        End Sub
-
-        <Test()> _
-        Public Sub MoneyBagHash()
-            Dim equal As MoneyBag = New MoneyBag(New Money(12, "CHF"), New Money(7, "USD"))
-            Assert.AreEqual(fMB1.GetHashCode(), equal.GetHashCode())
-        End Sub
-
-        <Test()> _
-        Public Sub MoneyEquals()
-            ' NOTE: Normally we use Assert.AreEqual to test whether two
-            ' objects are equal. But here we are testing the MoneyBag.Equals()
-            ' method itself, so using AreEqual would not serve the purpose.
-            Assert.IsFalse(f12CHF.Equals(Nothing))
-            Dim equalMoney As Money = New Money(12, "CHF")
-            Assert.IsTrue(f12CHF.Equals(f12CHF))
-            Assert.IsTrue(f12CHF.Equals(equalMoney))
-            Assert.IsFalse(f12CHF.Equals(f14CHF))
-        End Sub
-
-        <Test()> _
-        Public Sub MoneyHash()
-            Assert.IsFalse(f12CHF.Equals(Nothing))
-            Dim equal As Money = New Money(12, "CHF")
-            Assert.AreEqual(f12CHF.GetHashCode(), equal.GetHashCode())
-        End Sub
-
-        <Test()> _
-        Public Sub Normalize()
-            Dim bag() As Money = New Money() {New Money(26, "CHF"), New Money(28, "CHF"), New Money(6, "CHF")}
-            Dim moneyBag As New MoneyBag(bag)
-            Dim expected() As Money = New Money() {New Money(60, "CHF")}
-            '	// note: expected is still a MoneyBag
-            Dim expectedBag As New MoneyBag(expected)
-            Assert.AreEqual(expectedBag, moneyBag)
-        End Sub
-
-        <Test()> _
-        Public Sub Normalize2()
-            ' {[12 CHF][7 USD]} - [12 CHF] == [7 USD]
-            Dim expected As Money = New Money(7, "USD")
-            Assert.AreEqual(expected, fMB1.Subtract(f12CHF))
-        End Sub
-
-        <Test()> _
-        Public Sub Normalize3()
-            ' {[12 CHF][7 USD]} - {[12 CHF][3 USD]} == [4 USD]
-            Dim s1() As Money = New Money() {New Money(12, "CHF"), New Money(3, "USD")}
-            Dim ms1 As New MoneyBag(s1)
-            Dim expected As New Money(4, "USD")
-            Assert.AreEqual(expected, fMB1.Subtract(ms1))
-        End Sub
-
-        <Test()> _
-        Public Sub Normalize4()
-            ' [12 CHF] - {[12 CHF][3 USD]} == [-3 USD]
-            Dim s1() As Money = New Money() {New Money(12, "CHF"), New Money(3, "USD")}
-            Dim ms1 As New MoneyBag(s1)
-            Dim expected As New Money(-3, "USD")
-            Assert.AreEqual(expected, f12CHF.Subtract(ms1))
-        End Sub
-
-        <Test()> _
-        Public Sub Print()
-            Assert.AreEqual("[12 CHF]", f12CHF.ToString())
-        End Sub
-
-        <Test()> _
-        Public Sub SimpleAdd()
-
-            ' [12 CHF] + [14 CHF] == [26 CHF]
-            Dim expected As Money = New Money(26, "CHF")
-            Assert.AreEqual(expected, f12CHF.Add(f14CHF))
-
-        End Sub
-
-        <Test()> _
-        Public Sub SimpleNegate()
-
-            ' [14 CHF] negate == [-14 CHF]
-            Dim expected As New Money(-14, "CHF")
-            Assert.AreEqual(expected, f14CHF.Negate())
-
-        End Sub
-
-        <Test()> _
-        Public Sub SimpleSubtract()
-
-            ' [14 CHF] - [12 CHF] == [2 CHF]
-            Dim expected As New Money(2, "CHF")
-            Assert.AreEqual(expected, f14CHF.Subtract(f12CHF))
-
-        End Sub
-
-        <Test()> _
-        Public Sub SimpleMultiply()
-
-            ' [14 CHF] *2 == [28 CHF]
-            Dim expected As New Money(28, "CHF")
-            Assert.AreEqual(expected, f14CHF.Multiply(2))
-
-        End Sub
-
-    End Class
-
-End Namespace

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/vb/money/vb-money.build
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/vb/money/vb-money.build b/lib/NUnit.org/NUnit/2.5.9/samples/vb/money/vb-money.build
deleted file mode 100644
index 0d3cc04..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/vb/money/vb-money.build
+++ /dev/null
@@ -1,14 +0,0 @@
-<?xml version="1.0"?>
-<project name="vb-money" default="build">
-
-  <include buildfile="../../samples.common" />
-
-  <patternset id="source-files">
-    <include name="AssemblyInfo.vb" />
-    <include name="IMoney.vb" />
-    <include name="Money.vb" />
-    <include name="MoneyBag.vb" />
-    <include name="MoneyTest.vb" />
-  </patternset>
-
-</project>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/vb/money/vb-money.vbproj
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/vb/money/vb-money.vbproj b/lib/NUnit.org/NUnit/2.5.9/samples/vb/money/vb-money.vbproj
deleted file mode 100644
index b98e920..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/vb/money/vb-money.vbproj
+++ /dev/null
@@ -1,28 +0,0 @@
-<VisualStudioProject>
-  <VisualBasic ProjectType="Local" ProductVersion="7.10.3077" SchemaVersion="2.0" ProjectGuid="{95394B96-A794-48EA-9879-0E4EC79C5724}">
-    <Build>
-      <Settings ApplicationIcon="" AssemblyKeyContainerName="" AssemblyName="vb-money" AssemblyOriginatorKeyFile="" AssemblyOriginatorKeyMode="None" DefaultClientScript="JScript" DefaultHTMLPageLayout="Grid" DefaultTargetSchema="IE50" DelaySign="false" OutputType="Library" OptionCompare="Binary" OptionExplicit="On" OptionStrict="Off" RootNamespace="Money" StartupObject="">
-        <Config Name="Debug" BaseAddress="285212672" ConfigurationOverrideFile="" DefineConstants="" DefineDebug="true" DefineTrace="true" DebugSymbols="true" IncrementalBuild="true" Optimize="false" OutputPath="bin\" RegisterForComInterop="false" RemoveIntegerChecks="false" TreatWarningsAsErrors="false" WarningLevel="1" />
-        <Config Name="Release" BaseAddress="285212672" ConfigurationOverrideFile="" DefineConstants="" DefineDebug="false" DefineTrace="true" DebugSymbols="false" IncrementalBuild="false" Optimize="true" OutputPath="bin\" RegisterForComInterop="false" RemoveIntegerChecks="false" TreatWarningsAsErrors="false" WarningLevel="1" />
-      </Settings>
-      <References>
-        <Reference Name="System" AssemblyName="System" />
-        <Reference Name="nunit.framework" AssemblyName="nunit.framework, Version=2.5, Culture=neutral, PublicKeyToken=96d09a1eb7f44a77" HintPath="..\..\..\bin\net-1.1\framework\nunit.framework.dll" />
-      </References>
-      <Imports>
-        <Import Namespace="Microsoft.VisualBasic" />
-        <Import Namespace="System" />
-        <Import Namespace="System.Collections" />
-      </Imports>
-    </Build>
-    <Files>
-      <Include>
-        <File RelPath="AssemblyInfo.vb" SubType="Code" BuildAction="Compile" />
-        <File RelPath="IMoney.vb" SubType="Code" BuildAction="Compile" />
-        <File RelPath="Money.vb" SubType="Code" BuildAction="Compile" />
-        <File RelPath="MoneyBag.vb" SubType="Code" BuildAction="Compile" />
-        <File RelPath="MoneyTest.vb" SubType="Code" BuildAction="Compile" />
-      </Include>
-    </Files>
-  </VisualBasic>
-</VisualStudioProject>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/vb/syntax/AssemblyInfo.vb
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/vb/syntax/AssemblyInfo.vb b/lib/NUnit.org/NUnit/2.5.9/samples/vb/syntax/AssemblyInfo.vb
deleted file mode 100644
index e29c3d4..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/vb/syntax/AssemblyInfo.vb
+++ /dev/null
@@ -1,32 +0,0 @@
-Imports System
-Imports System.Reflection
-Imports System.Runtime.InteropServices
-
-' General Information about an assembly is controlled through the following 
-' set of attributes. Change these attribute values to modify the information
-' associated with an assembly.
-
-' Review the values of the assembly attributes
-
-<Assembly: AssemblyTitle("")> 
-<Assembly: AssemblyDescription("")> 
-<Assembly: AssemblyCompany("")> 
-<Assembly: AssemblyProduct("")> 
-<Assembly: AssemblyCopyright("")> 
-<Assembly: AssemblyTrademark("")> 
-<Assembly: CLSCompliant(True)> 
-
-'The following GUID is for the ID of the typelib if this project is exposed to COM
-<Assembly: Guid("966C964A-3C92-4834-AC3A-9A47BA0A728B")> 
-
-' Version information for an assembly consists of the following four values:
-'
-'      Major Version
-'      Minor Version 
-'      Build Number
-'      Revision
-'
-' You can specify all the values or you can default the Build and Revision Numbers 
-' by using the '*' as shown below:
-
-<Assembly: AssemblyVersion("1.0.*")> 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/vb/syntax/AssertSyntaxTests.vb
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/vb/syntax/AssertSyntaxTests.vb b/lib/NUnit.org/NUnit/2.5.9/samples/vb/syntax/AssertSyntaxTests.vb
deleted file mode 100644
index bec1e0b..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/vb/syntax/AssertSyntaxTests.vb
+++ /dev/null
@@ -1,705 +0,0 @@
-' ****************************************************************
-' Copyright 2007, Charlie Poole
-' This is free software licensed under the NUnit license. You may
-' obtain a copy of the license at http:'nunit.org/?p=license&r=2.4
-' ****************************************************************
-
-Option Explicit On 
-
-Imports System
-Imports NUnit.Framework
-Imports NUnit.Framework.Constraints
-Imports Text = NUnit.Framework.Text
-
-Namespace NUnit.Samples
-
-    ' This test fixture attempts to exercise all the syntactic
-    ' variations of Assert without getting into failures, errors 
-    ' or corner cases. Thus, some of the tests may be duplicated 
-    ' in other fixtures.
-    ' 
-    ' Each test performs the same operations using the classic
-    ' syntax (if available) and the new syntax in both the
-    ' helper-based and inherited forms.
-    ' 
-    ' This Fixture will eventually be duplicated in other
-    ' supported languages. 
-
-    <TestFixture()> _
-    Public Class AssertSyntaxTests
-        Inherits AssertionHelper
-
-#Region "Simple Constraint Tests"
-        <Test()> _
-        Public Sub IsNull()
-            Dim nada As Object = Nothing
-
-            ' Classic syntax
-            Assert.IsNull(nada)
-
-            ' Helper syntax
-            Assert.That(nada, Iz.Null)
-
-            ' Inherited syntax
-            Expect(nada, Null)
-        End Sub
-
-
-        <Test()> _
-        Public Sub IsNotNull()
-            ' Classic syntax
-            Assert.IsNotNull(42)
-
-            ' Helper syntax
-            Assert.That(42, Iz.Not.Null)
-
-            ' Inherited syntax
-            Expect(42, Iz.Not.Null)
-        End Sub
-
-        <Test()> _
-        Public Sub IsTrue()
-            ' Classic syntax
-            Assert.IsTrue(2 + 2 = 4)
-
-            ' Helper syntax
-            Assert.That(2 + 2 = 4, Iz.True)
-            Assert.That(2 + 2 = 4)
-
-            ' Inherited syntax
-            Expect(2 + 2 = 4, Iz.True)
-            Expect(2 + 2 = 4)
-        End Sub
-
-        <Test()> _
-        Public Sub IsFalse()
-            ' Classic syntax
-            Assert.IsFalse(2 + 2 = 5)
-
-            ' Helper syntax
-            Assert.That(2 + 2 = 5, Iz.False)
-
-            ' Inherited syntax
-            Expect(2 + 2 = 5, Iz.False)
-        End Sub
-
-        <Test()> _
-        Public Sub IsNaN()
-            Dim d As Double = Double.NaN
-            Dim f As Single = Single.NaN
-
-            ' Classic syntax
-            Assert.IsNaN(d)
-            Assert.IsNaN(f)
-
-            ' Helper syntax
-            Assert.That(d, Iz.NaN)
-            Assert.That(f, Iz.NaN)
-
-            ' Inherited syntax
-            Expect(d, NaN)
-            Expect(f, NaN)
-        End Sub
-
-        <Test()> _
-        Public Sub EmptyStringTests()
-            ' Classic syntax
-            Assert.IsEmpty("")
-            Assert.IsNotEmpty("Hello!")
-
-            ' Helper syntax
-            Assert.That("", Iz.Empty)
-            Assert.That("Hello!", Iz.Not.Empty)
-
-            ' Inherited syntax
-            Expect("", Empty)
-            Expect("Hello!", Iz.Not.Empty)
-        End Sub
-
-        <Test()> _
-        Public Sub EmptyCollectionTests()
-
-            Dim boolArray As Boolean() = New Boolean() {}
-            Dim nonEmpty As Integer() = New Integer() {1, 2, 3}
-
-            ' Classic syntax
-            Assert.IsEmpty(boolArray)
-            Assert.IsNotEmpty(nonEmpty)
-
-            ' Helper syntax
-            Assert.That(boolArray, Iz.Empty)
-            Assert.That(nonEmpty, Iz.Not.Empty)
-
-            ' Inherited syntax
-            Expect(boolArray, Iz.Empty)
-            Expect(nonEmpty, Iz.Not.Empty)
-        End Sub
-#End Region
-
-#Region "TypeConstraint Tests"
-        <Test()> _
-        Public Sub ExactTypeTests()
-            ' Classic syntax workarounds
-            Assert.AreEqual(GetType(String), "Hello".GetType())
-            Assert.AreEqual("System.String", "Hello".GetType().FullName)
-            Assert.AreNotEqual(GetType(Integer), "Hello".GetType())
-            Assert.AreNotEqual("System.Int32", "Hello".GetType().FullName)
-
-            ' Helper syntax
-            Assert.That("Hello", Iz.TypeOf(GetType(String)))
-            Assert.That("Hello", Iz.Not.TypeOf(GetType(Integer)))
-
-            ' Inherited syntax
-            Expect("Hello", Iz.TypeOf(GetType(String)))
-            Expect("Hello", Iz.Not.TypeOf(GetType(Integer)))
-        End Sub
-
-        <Test()> _
-        Public Sub InstanceOfTypeTests()
-            ' Classic syntax
-            Assert.IsInstanceOf(GetType(String), "Hello")
-            Assert.IsNotInstanceOf(GetType(String), 5)
-
-            ' Helper syntax
-            Assert.That("Hello", Iz.InstanceOf(GetType(String)))
-            Assert.That(5, Iz.Not.InstanceOf(GetType(String)))
-
-            ' Inherited syntax
-            Expect("Hello", InstanceOf(GetType(String)))
-            Expect(5, Iz.Not.InstanceOf(GetType(String)))
-        End Sub
-
-        <Test()> _
-        Public Sub AssignableFromTypeTests()
-            ' Classic syntax
-            Assert.IsAssignableFrom(GetType(String), "Hello")
-            Assert.IsNotAssignableFrom(GetType(String), 5)
-
-            ' Helper syntax
-            Assert.That("Hello", Iz.AssignableFrom(GetType(String)))
-            Assert.That(5, Iz.Not.AssignableFrom(GetType(String)))
-
-            ' Inherited syntax
-            Expect("Hello", AssignableFrom(GetType(String)))
-            Expect(5, Iz.Not.AssignableFrom(GetType(String)))
-        End Sub
-#End Region
-
-#Region "StringConstraintTests"
-        <Test()> _
-        Public Sub SubstringTests()
-            Dim phrase As String = "Hello World!"
-            Dim array As String() = New String() {"abc", "bad", "dba"}
-
-            ' Classic Syntax
-            StringAssert.Contains("World", phrase)
-
-            ' Helper syntax
-            Assert.That(phrase, Text.Contains("World"))
-            ' Only available using new syntax
-            Assert.That(phrase, Text.DoesNotContain("goodbye"))
-            Assert.That(phrase, Text.Contains("WORLD").IgnoreCase)
-            Assert.That(phrase, Text.DoesNotContain("BYE").IgnoreCase)
-            Assert.That(array, Text.All.Contains("b"))
-
-            ' Inherited syntax
-            Expect(phrase, Contains("World"))
-            ' Only available using new syntax
-            Expect(phrase, Text.DoesNotContain("goodbye"))
-            Expect(phrase, Contains("WORLD").IgnoreCase)
-            Expect(phrase, Text.DoesNotContain("BYE").IgnoreCase)
-            Expect(array, All.Contains("b"))
-        End Sub
-
-        <Test()> _
-        Public Sub StartsWithTests()
-            Dim phrase As String = "Hello World!"
-            Dim greetings As String() = New String() {"Hello!", "Hi!", "Hola!"}
-
-            ' Classic syntax
-            StringAssert.StartsWith("Hello", phrase)
-
-            ' Helper syntax
-            Assert.That(phrase, Text.StartsWith("Hello"))
-            ' Only available using new syntax
-            Assert.That(phrase, Text.DoesNotStartWith("Hi!"))
-            Assert.That(phrase, Text.StartsWith("HeLLo").IgnoreCase)
-            Assert.That(phrase, Text.DoesNotStartWith("HI").IgnoreCase)
-            Assert.That(greetings, Text.All.StartsWith("h").IgnoreCase)
-
-            ' Inherited syntax
-            Expect(phrase, StartsWith("Hello"))
-            ' Only available using new syntax
-            Expect(phrase, Text.DoesNotStartWith("Hi!"))
-            Expect(phrase, StartsWith("HeLLo").IgnoreCase)
-            Expect(phrase, Text.DoesNotStartWith("HI").IgnoreCase)
-            Expect(greetings, All.StartsWith("h").IgnoreCase)
-        End Sub
-
-        <Test()> _
-        Public Sub EndsWithTests()
-            Dim phrase As String = "Hello World!"
-            Dim greetings As String() = New String() {"Hello!", "Hi!", "Hola!"}
-
-            ' Classic Syntax
-            StringAssert.EndsWith("!", phrase)
-
-            ' Helper syntax
-            Assert.That(phrase, Text.EndsWith("!"))
-            ' Only available using new syntax
-            Assert.That(phrase, Text.DoesNotEndWith("?"))
-            Assert.That(phrase, Text.EndsWith("WORLD!").IgnoreCase)
-            Assert.That(greetings, Text.All.EndsWith("!"))
-
-            ' Inherited syntax
-            Expect(phrase, EndsWith("!"))
-            ' Only available using new syntax
-            Expect(phrase, Text.DoesNotEndWith("?"))
-            Expect(phrase, EndsWith("WORLD!").IgnoreCase)
-            Expect(greetings, All.EndsWith("!"))
-        End Sub
-
-        <Test()> _
-        Public Sub EqualIgnoringCaseTests()
-
-            Dim phrase As String = "Hello World!"
-            Dim array1 As String() = New String() {"Hello", "World"}
-            Dim array2 As String() = New String() {"HELLO", "WORLD"}
-            Dim array3 As String() = New String() {"HELLO", "Hello", "hello"}
-
-            ' Classic syntax
-            StringAssert.AreEqualIgnoringCase("hello world!", phrase)
-
-            ' Helper syntax
-            Assert.That(phrase, Iz.EqualTo("hello world!").IgnoreCase)
-            'Only available using new syntax
-            Assert.That(phrase, Iz.Not.EqualTo("goodbye world!").IgnoreCase)
-            Assert.That(array1, Iz.EqualTo(array2).IgnoreCase)
-            Assert.That(array3, Iz.All.EqualTo("hello").IgnoreCase)
-
-            ' Inherited syntax
-            Expect(phrase, EqualTo("hello world!").IgnoreCase)
-            'Only available using new syntax
-            Expect(phrase, Iz.Not.EqualTo("goodbye world!").IgnoreCase)
-            Expect(array1, EqualTo(array2).IgnoreCase)
-            Expect(array3, All.EqualTo("hello").IgnoreCase)
-        End Sub
-
-        <Test()> _
-        Public Sub RegularExpressionTests()
-            Dim phrase As String = "Now is the time for all good men to come to the aid of their country."
-            Dim quotes As String() = New String() {"Never say never", "It's never too late", "Nevermore!"}
-
-            ' Classic syntax
-            StringAssert.IsMatch("all good men", phrase)
-            StringAssert.IsMatch("Now.*come", phrase)
-
-            ' Helper syntax
-            Assert.That(phrase, Text.Matches("all good men"))
-            Assert.That(phrase, Text.Matches("Now.*come"))
-            ' Only available using new syntax
-            Assert.That(phrase, Text.DoesNotMatch("all.*men.*good"))
-            Assert.That(phrase, Text.Matches("ALL").IgnoreCase)
-            Assert.That(quotes, Text.All.Matches("never").IgnoreCase)
-
-            ' Inherited syntax
-            Expect(phrase, Matches("all good men"))
-            Expect(phrase, Matches("Now.*come"))
-            ' Only available using new syntax
-            Expect(phrase, Text.DoesNotMatch("all.*men.*good"))
-            Expect(phrase, Matches("ALL").IgnoreCase)
-            Expect(quotes, All.Matches("never").IgnoreCase)
-        End Sub
-#End Region
-
-#Region "Equality Tests"
-        <Test()> _
-        Public Sub EqualityTests()
-
-            Dim i3 As Integer() = {1, 2, 3}
-            Dim d3 As Double() = {1.0, 2.0, 3.0}
-            Dim iunequal As Integer() = {1, 3, 2}
-
-            ' Classic Syntax
-            Assert.AreEqual(4, 2 + 2)
-            Assert.AreEqual(i3, d3)
-            Assert.AreNotEqual(5, 2 + 2)
-            Assert.AreNotEqual(i3, iunequal)
-
-            ' Helper syntax
-            Assert.That(2 + 2, Iz.EqualTo(4))
-            Assert.That(2 + 2 = 4)
-            Assert.That(i3, Iz.EqualTo(d3))
-            Assert.That(2 + 2, Iz.Not.EqualTo(5))
-            Assert.That(i3, Iz.Not.EqualTo(iunequal))
-
-            ' Inherited syntax
-            Expect(2 + 2, EqualTo(4))
-            Expect(2 + 2 = 4)
-            Expect(i3, EqualTo(d3))
-            Expect(2 + 2, Iz.Not.EqualTo(5))
-            Expect(i3, Iz.Not.EqualTo(iunequal))
-        End Sub
-
-        <Test()> _
-        Public Sub EqualityTestsWithTolerance()
-            ' CLassic syntax
-            Assert.AreEqual(5.0R, 4.99R, 0.05R)
-            Assert.AreEqual(5.0F, 4.99F, 0.05F)
-
-            ' Helper syntax
-            Assert.That(4.99R, Iz.EqualTo(5.0R).Within(0.05R))
-            Assert.That(4D, Iz.Not.EqualTo(5D).Within(0.5D))
-            Assert.That(4.99F, Iz.EqualTo(5.0F).Within(0.05F))
-            Assert.That(4.99D, Iz.EqualTo(5D).Within(0.05D))
-            Assert.That(499, Iz.EqualTo(500).Within(5))
-            Assert.That(4999999999L, Iz.EqualTo(5000000000L).Within(5L))
-
-            ' Inherited syntax
-            Expect(4.99R, EqualTo(5.0R).Within(0.05R))
-            Expect(4D, Iz.Not.EqualTo(5D).Within(0.5D))
-            Expect(4.99F, EqualTo(5.0F).Within(0.05F))
-            Expect(4.99D, EqualTo(5D).Within(0.05D))
-            Expect(499, EqualTo(500).Within(5))
-            Expect(4999999999L, EqualTo(5000000000L).Within(5L))
-        End Sub
-
-        <Test()> _
-        Public Sub EqualityTestsWithTolerance_MixedFloatAndDouble()
-            ' Bug Fix 1743844
-            Assert.That(2.20492R, Iz.EqualTo(2.2R).Within(0.01F), _
-                "Double actual, Double expected, Single tolerance")
-            Assert.That(2.20492R, Iz.EqualTo(2.2F).Within(0.01R), _
-                "Double actual, Single expected, Double tolerance")
-            Assert.That(2.20492R, Iz.EqualTo(2.2F).Within(0.01F), _
-                "Double actual, Single expected, Single tolerance")
-            Assert.That(2.20492F, Iz.EqualTo(2.2F).Within(0.01R), _
-                "Single actual, Single expected, Double tolerance")
-            Assert.That(2.20492F, Iz.EqualTo(2.2R).Within(0.01R), _
-                "Single actual, Double expected, Double tolerance")
-            Assert.That(2.20492F, Iz.EqualTo(2.2R).Within(0.01F), _
-                "Single actual, Double expected, Single tolerance")
-        End Sub
-
-        <Test()> _
-        Public Sub EqualityTestsWithTolerance_MixingTypesGenerally()
-            ' Extending tolerance to all numeric types
-            Assert.That(202.0R, Iz.EqualTo(200.0R).Within(2), _
-                "Double actual, Double expected, int tolerance")
-            Assert.That(4.87D, Iz.EqualTo(5).Within(0.25R), _
-                "Decimal actual, int expected, Double tolerance")
-            Assert.That(4.87D, Iz.EqualTo(5L).Within(1), _
-                "Decimal actual, long expected, int tolerance")
-            Assert.That(487, Iz.EqualTo(500).Within(25), _
-                "int actual, int expected, int tolerance")
-            Assert.That(487L, Iz.EqualTo(500).Within(25), _
-                "long actual, int expected, int tolerance")
-        End Sub
-#End Region
-
-#Region "Comparison Tests"
-        <Test()> _
-        Public Sub ComparisonTests()
-            ' Classic Syntax
-            Assert.Greater(7, 3)
-            Assert.GreaterOrEqual(7, 3)
-            Assert.GreaterOrEqual(7, 7)
-
-            ' Helper syntax
-            Assert.That(7, Iz.GreaterThan(3))
-            Assert.That(7, Iz.GreaterThanOrEqualTo(3))
-            Assert.That(7, Iz.AtLeast(3))
-            Assert.That(7, Iz.GreaterThanOrEqualTo(7))
-            Assert.That(7, Iz.AtLeast(7))
-
-            ' Inherited syntax
-            Expect(7, GreaterThan(3))
-            Expect(7, GreaterThanOrEqualTo(3))
-            Expect(7, AtLeast(3))
-            Expect(7, GreaterThanOrEqualTo(7))
-            Expect(7, AtLeast(7))
-
-            ' Classic syntax
-            Assert.Less(3, 7)
-            Assert.LessOrEqual(3, 7)
-            Assert.LessOrEqual(3, 3)
-
-            ' Helper syntax
-            Assert.That(3, Iz.LessThan(7))
-            Assert.That(3, Iz.LessThanOrEqualTo(7))
-            Assert.That(3, Iz.AtMost(7))
-            Assert.That(3, Iz.LessThanOrEqualTo(3))
-            Assert.That(3, Iz.AtMost(3))
-
-            ' Inherited syntax
-            Expect(3, LessThan(7))
-            Expect(3, LessThanOrEqualTo(7))
-            Expect(3, AtMost(7))
-            Expect(3, LessThanOrEqualTo(3))
-            Expect(3, AtMost(3))
-        End Sub
-#End Region
-
-#Region "Collection Tests"
-        <Test()> _
-        Public Sub AllItemsTests()
-
-            Dim ints As Object() = {1, 2, 3, 4}
-            Dim doubles As Object() = {0.99, 2.1, 3.0, 4.05}
-            Dim strings As Object() = {"abc", "bad", "cab", "bad", "dad"}
-
-            ' Classic syntax
-            CollectionAssert.AllItemsAreNotNull(ints)
-            CollectionAssert.AllItemsAreInstancesOfType(ints, GetType(Integer))
-            CollectionAssert.AllItemsAreInstancesOfType(strings, GetType(String))
-            CollectionAssert.AllItemsAreUnique(ints)
-
-            ' Helper syntax
-            Assert.That(ints, Iz.All.Not.Null)
-            Assert.That(ints, Has.None.Null)
-            Assert.That(ints, Iz.All.InstanceOfType(GetType(Integer)))
-            Assert.That(ints, Has.All.InstanceOfType(GetType(Integer)))
-            Assert.That(strings, Iz.All.InstanceOfType(GetType(String)))
-            Assert.That(strings, Has.All.InstanceOfType(GetType(String)))
-            Assert.That(ints, Iz.Unique)
-            ' Only available using new syntax
-            Assert.That(strings, Iz.Not.Unique)
-            Assert.That(ints, Iz.All.GreaterThan(0))
-            Assert.That(ints, Has.All.GreaterThan(0))
-            Assert.That(ints, Has.None.LessThanOrEqualTo(0))
-            Assert.That(strings, Text.All.Contains("a"))
-            Assert.That(strings, Has.All.Contains("a"))
-            Assert.That(strings, Has.Some.StartsWith("ba"))
-            Assert.That(strings, Has.Some.Property("Length").EqualTo(3))
-            Assert.That(strings, Has.Some.StartsWith("BA").IgnoreCase)
-            Assert.That(doubles, Has.Some.EqualTo(1.0).Within(0.05))
-
-            ' Inherited syntax
-            Expect(ints, All.Not.Null)
-            Expect(ints, None.Null)
-            Expect(ints, All.InstanceOfType(GetType(Integer)))
-            Expect(strings, All.InstanceOfType(GetType(String)))
-            Expect(ints, Unique)
-            ' Only available using new syntax
-            Expect(strings, Iz.Not.Unique)
-            Expect(ints, All.GreaterThan(0))
-            Expect(strings, All.Contains("a"))
-            Expect(strings, Some.StartsWith("ba"))
-            Expect(strings, Some.StartsWith("BA").IgnoreCase)
-            Expect(doubles, Some.EqualTo(1.0).Within(0.05))
-        End Sub
-
-        <Test()> _
-       Public Sub SomeItemsTests()
-
-            Dim mixed As Object() = {1, 2, "3", Nothing, "four", 100}
-            Dim strings As Object() = {"abc", "bad", "cab", "bad", "dad"}
-
-            ' Not available using the classic syntax
-
-            ' Helper syntax
-            Assert.That(mixed, Has.Some.Null)
-            Assert.That(mixed, Has.Some.InstanceOfType(GetType(Integer)))
-            Assert.That(mixed, Has.Some.InstanceOfType(GetType(String)))
-            Assert.That(strings, Has.Some.StartsWith("ba"))
-            Assert.That(strings, Has.Some.Not.StartsWith("ba"))
-
-            ' Inherited syntax
-            Expect(mixed, Some.Null)
-            Expect(mixed, Some.InstanceOfType(GetType(Integer)))
-            Expect(mixed, Some.InstanceOfType(GetType(String)))
-            Expect(strings, Some.StartsWith("ba"))
-            Expect(strings, Some.Not.StartsWith("ba"))
-        End Sub
-
-        <Test()> _
-        Public Sub NoItemsTests()
-
-            Dim ints As Object() = {1, 2, 3, 4, 5}
-            Dim strings As Object() = {"abc", "bad", "cab", "bad", "dad"}
-
-            ' Not available using the classic syntax
-
-            ' Helper syntax
-            Assert.That(ints, Has.None.Null)
-            Assert.That(ints, Has.None.InstanceOfType(GetType(String)))
-            Assert.That(ints, Has.None.GreaterThan(99))
-            Assert.That(strings, Has.None.StartsWith("qu"))
-
-            ' Inherited syntax
-            Expect(ints, None.Null)
-            Expect(ints, None.InstanceOfType(GetType(String)))
-            Expect(ints, None.GreaterThan(99))
-            Expect(strings, None.StartsWith("qu"))
-        End Sub
-
-        <Test()> _
-        Public Sub CollectionContainsTests()
-
-            Dim iarray As Integer() = {1, 2, 3}
-            Dim sarray As String() = {"a", "b", "c"}
-
-            ' Classic syntax
-            Assert.Contains(3, iarray)
-            Assert.Contains("b", sarray)
-            CollectionAssert.Contains(iarray, 3)
-            CollectionAssert.Contains(sarray, "b")
-            CollectionAssert.DoesNotContain(sarray, "x")
-            ' Showing that Contains uses NUnit equality
-            CollectionAssert.Contains(iarray, 1.0R)
-
-            ' Helper syntax
-            Assert.That(iarray, Has.Member(3))
-            Assert.That(sarray, Has.Member("b"))
-            Assert.That(sarray, Has.No.Member("x"))
-            ' Showing that Contains uses NUnit equality
-            Assert.That(iarray, Has.Member(1.0R))
-
-            ' Only available using the new syntax
-            ' Note that EqualTo and SameAs do NOT give
-            ' identical results to Contains because 
-            ' Contains uses Object.Equals()
-            Assert.That(iarray, Has.Some.EqualTo(3))
-            Assert.That(iarray, Has.Member(3))
-            Assert.That(sarray, Has.Some.EqualTo("b"))
-            Assert.That(sarray, Has.None.EqualTo("x"))
-            Assert.That(iarray, Has.None.SameAs(1.0R))
-            Assert.That(iarray, Has.All.LessThan(10))
-            Assert.That(sarray, Has.All.Length.EqualTo(1))
-            Assert.That(sarray, Has.None.Property("Length").GreaterThan(3))
-
-            ' Inherited syntax
-            Expect(iarray, Contains(3))
-            Expect(sarray, Contains("b"))
-            Expect(sarray, Has.No.Member("x"))
-
-            ' Only available using new syntax
-            ' Note that EqualTo and SameAs do NOT give
-            ' identical results to Contains because 
-            ' Contains uses Object.Equals()
-            Expect(iarray, Some.EqualTo(3))
-            Expect(sarray, Some.EqualTo("b"))
-            Expect(sarray, None.EqualTo("x"))
-            Expect(iarray, All.LessThan(10))
-            Expect(sarray, All.Length.EqualTo(1))
-            Expect(sarray, None.Property("Length").GreaterThan(3))
-        End Sub
-
-        <Test()> _
-        Public Sub CollectionEquivalenceTests()
-
-            Dim ints1to5 As Integer() = {1, 2, 3, 4, 5}
-            Dim twothrees As Integer() = {1, 2, 3, 3, 4, 5}
-            Dim twofours As Integer() = {1, 2, 3, 4, 4, 5}
-
-            ' Classic syntax
-            CollectionAssert.AreEquivalent(New Integer() {2, 1, 4, 3, 5}, ints1to5)
-            CollectionAssert.AreNotEquivalent(New Integer() {2, 2, 4, 3, 5}, ints1to5)
-            CollectionAssert.AreNotEquivalent(New Integer() {2, 4, 3, 5}, ints1to5)
-            CollectionAssert.AreNotEquivalent(New Integer() {2, 2, 1, 1, 4, 3, 5}, ints1to5)
-            CollectionAssert.AreNotEquivalent(twothrees, twofours)
-
-            ' Helper syntax
-            Assert.That(New Integer() {2, 1, 4, 3, 5}, Iz.EquivalentTo(ints1to5))
-            Assert.That(New Integer() {2, 2, 4, 3, 5}, Iz.Not.EquivalentTo(ints1to5))
-            Assert.That(New Integer() {2, 4, 3, 5}, Iz.Not.EquivalentTo(ints1to5))
-            Assert.That(New Integer() {2, 2, 1, 1, 4, 3, 5}, Iz.Not.EquivalentTo(ints1to5))
-            Assert.That(twothrees, Iz.Not.EquivalentTo(twofours))
-
-            ' Inherited syntax
-            Expect(New Integer() {2, 1, 4, 3, 5}, EquivalentTo(ints1to5))
-        End Sub
-
-        <Test()> _
-        Public Sub SubsetTests()
-
-            Dim ints1to5 As Integer() = {1, 2, 3, 4, 5}
-
-            ' Classic syntax
-            CollectionAssert.IsSubsetOf(New Integer() {1, 3, 5}, ints1to5)
-            CollectionAssert.IsSubsetOf(New Integer() {1, 2, 3, 4, 5}, ints1to5)
-            CollectionAssert.IsNotSubsetOf(New Integer() {2, 4, 6}, ints1to5)
-            CollectionAssert.IsNotSubsetOf(New Integer() {1, 2, 2, 2, 5}, ints1to5)
-
-            ' Helper syntax
-            Assert.That(New Integer() {1, 3, 5}, Iz.SubsetOf(ints1to5))
-            Assert.That(New Integer() {1, 2, 3, 4, 5}, Iz.SubsetOf(ints1to5))
-            Assert.That(New Integer() {2, 4, 6}, Iz.Not.SubsetOf(ints1to5))
-
-            ' Inherited syntax
-            Expect(New Integer() {1, 3, 5}, SubsetOf(ints1to5))
-            Expect(New Integer() {1, 2, 3, 4, 5}, SubsetOf(ints1to5))
-            Expect(New Integer() {2, 4, 6}, Iz.Not.SubsetOf(ints1to5))
-        End Sub
-#End Region
-
-#Region "Property Tests"
-        <Test()> _
-        Public Sub PropertyTests()
-
-            Dim array As String() = {"abc", "bca", "xyz", "qrs"}
-            Dim array2 As String() = {"a", "ab", "abc"}
-            Dim list As New ArrayList(array)
-
-            ' Not available using the classic syntax
-
-            ' Helper syntax
-            ' Assert.That(list, Has.Property("Count"))
-            ' Assert.That(list, Has.No.Property("Length"))
-
-            Assert.That("Hello", Has.Length.EqualTo(5))
-            Assert.That("Hello", Has.Property("Length").EqualTo(5))
-            Assert.That("Hello", Has.Property("Length").GreaterThan(3))
-
-            Assert.That(array, Has.Property("Length").EqualTo(4))
-            Assert.That(array, Has.Length.EqualTo(4))
-            Assert.That(array, Has.Property("Length").LessThan(10))
-
-            Assert.That(array, Has.All.Property("Length").EqualTo(3))
-            Assert.That(array, Has.All.Length.EqualTo(3))
-            Assert.That(array, Iz.All.Length.EqualTo(3))
-            Assert.That(array, Has.All.Property("Length").EqualTo(3))
-            Assert.That(array, Iz.All.Property("Length").EqualTo(3))
-
-            Assert.That(array2, Iz.Not.Property("Length").EqualTo(4))
-            Assert.That(array2, Iz.Not.Length.EqualTo(4))
-            Assert.That(array2, Has.No.Property("Length").GreaterThan(3))
-
-            ' Inherited syntax
-            ' Expect(list, Has.Property("Count"))
-            ' Expect(list, Has.No.Property("Nada"))
-
-            Expect(array, All.Property("Length").EqualTo(3))
-            Expect(array, All.Length.EqualTo(3))
-        End Sub
-#End Region
-
-#Region "Not Tests"
-        <Test()> _
-        Public Sub NotTests()
-            ' Not available using the classic syntax
-
-            ' Helper syntax
-            Assert.That(42, Iz.Not.Null)
-            Assert.That(42, Iz.Not.True)
-            Assert.That(42, Iz.Not.False)
-            Assert.That(2.5, Iz.Not.NaN)
-            Assert.That(2 + 2, Iz.Not.EqualTo(3))
-            Assert.That(2 + 2, Iz.Not.Not.EqualTo(4))
-            Assert.That(2 + 2, Iz.Not.Not.Not.EqualTo(5))
-
-            ' Inherited syntax
-            Expect(42, Iz.Not.Null)
-            Expect(42, Iz.Not.True)
-            Expect(42, Iz.Not.False)
-            Expect(2.5, Iz.Not.NaN)
-            Expect(2 + 2, Iz.Not.EqualTo(3))
-            Expect(2 + 2, Iz.Not.Not.EqualTo(4))
-            Expect(2 + 2, Iz.Not.Not.Not.EqualTo(5))
-        End Sub
-#End Region
-
-    End Class
-
-End Namespace
-

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/vb/syntax/vb-syntax.build
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/vb/syntax/vb-syntax.build b/lib/NUnit.org/NUnit/2.5.9/samples/vb/syntax/vb-syntax.build
deleted file mode 100644
index aa0f584..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/vb/syntax/vb-syntax.build
+++ /dev/null
@@ -1,11 +0,0 @@
-<?xml version="1.0"?>
-<project name="vb-syntax" default="build">
-
-  <include buildfile="../../samples.common" />
-  
-  <patternset id="source-files">
-    <include name="AssemblyInfo.vb" />
-    <include name="AssertSyntaxTests.vb" />
-  </patternset>
-
-</project>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/vb/syntax/vb-syntax.vbproj
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/vb/syntax/vb-syntax.vbproj b/lib/NUnit.org/NUnit/2.5.9/samples/vb/syntax/vb-syntax.vbproj
deleted file mode 100644
index 5dac155..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/vb/syntax/vb-syntax.vbproj
+++ /dev/null
@@ -1,29 +0,0 @@
-<VisualStudioProject>
-  <VisualBasic ProjectType="Local" ProductVersion="7.10.3077" SchemaVersion="2.0" ProjectGuid="{6BEF566A-2691-4EE8-91AF-0390CCCDDAF1}">
-    <Build>
-      <Settings ApplicationIcon="" AssemblyKeyContainerName="" AssemblyName="vb-syntax" AssemblyOriginatorKeyFile="" AssemblyOriginatorKeyMode="None" DefaultClientScript="JScript" DefaultHTMLPageLayout="Grid" DefaultTargetSchema="IE50" DelaySign="false" OutputType="Library" OptionCompare="Binary" OptionExplicit="On" OptionStrict="Off" RootNamespace="NUnit.Samples" StartupObject="NUnit.Samples.(None)">
-        <Config Name="Debug" BaseAddress="285212672" ConfigurationOverrideFile="" DefineConstants="" DefineDebug="true" DefineTrace="true" DebugSymbols="true" IncrementalBuild="true" Optimize="false" OutputPath="bin\" RegisterForComInterop="false" RemoveIntegerChecks="false" TreatWarningsAsErrors="false" WarningLevel="1" />
-        <Config Name="Release" BaseAddress="285212672" ConfigurationOverrideFile="" DefineConstants="" DefineDebug="false" DefineTrace="true" DebugSymbols="false" IncrementalBuild="false" Optimize="true" OutputPath="bin\" RegisterForComInterop="false" RemoveIntegerChecks="false" TreatWarningsAsErrors="false" WarningLevel="1" />
-      </Settings>
-      <References>
-        <Reference Name="System" AssemblyName="System" />
-        <Reference Name="System.Data" AssemblyName="System.Data" />
-        <Reference Name="System.XML" AssemblyName="System.Xml" />
-        <Reference Name="nunit.framework" AssemblyName="nunit.framework, Version=2.5, Culture=neutral, PublicKeyToken=96d09a1eb7f44a77" HintPath="..\..\..\bin\net-1.1\framework\nunit.framework.dll" />
-      </References>
-      <Imports>
-        <Import Namespace="Microsoft.VisualBasic" />
-        <Import Namespace="System" />
-        <Import Namespace="System.Collections" />
-        <Import Namespace="System.Data" />
-        <Import Namespace="System.Diagnostics" />
-      </Imports>
-    </Build>
-    <Files>
-      <Include>
-        <File RelPath="AssemblyInfo.vb" SubType="Code" BuildAction="Compile" />
-        <File RelPath="AssertSyntaxTests.vb" SubType="Code" BuildAction="Compile" />
-      </Include>
-    </Files>
-  </VisualBasic>
-</VisualStudioProject>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/vb/vb-samples.sln
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/vb/vb-samples.sln b/lib/NUnit.org/NUnit/2.5.9/samples/vb/vb-samples.sln
deleted file mode 100644
index 7bf8156..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/vb/vb-samples.sln
+++ /dev/null
@@ -1,37 +0,0 @@
-Microsoft Visual Studio Solution File, Format Version 8.00
-Project("{F184B08F-C81C-45F6-A57F-5ABD9991F28F}") = "vb-failures", "failures\vb-failures.vbproj", "{F199991B-6C8E-4AB0-9AAA-703CD4897700}"
-	ProjectSection(ProjectDependencies) = postProject
-	EndProjectSection
-EndProject
-Project("{F184B08F-C81C-45F6-A57F-5ABD9991F28F}") = "vb-money", "money\vb-money.vbproj", "{95394B96-A794-48EA-9879-0E4EC79C5724}"
-	ProjectSection(ProjectDependencies) = postProject
-	EndProjectSection
-EndProject
-Project("{F184B08F-C81C-45F6-A57F-5ABD9991F28F}") = "vb-syntax", "syntax\vb-syntax.vbproj", "{6BEF566A-2691-4EE8-91AF-0390CCCDDAF1}"
-	ProjectSection(ProjectDependencies) = postProject
-	EndProjectSection
-EndProject
-Global
-	GlobalSection(SolutionConfiguration) = preSolution
-		Debug = Debug
-		Release = Release
-	EndGlobalSection
-	GlobalSection(ProjectConfiguration) = postSolution
-		{F199991B-6C8E-4AB0-9AAA-703CD4897700}.Debug.ActiveCfg = Debug|.NET
-		{F199991B-6C8E-4AB0-9AAA-703CD4897700}.Debug.Build.0 = Debug|.NET
-		{F199991B-6C8E-4AB0-9AAA-703CD4897700}.Release.ActiveCfg = Release|.NET
-		{F199991B-6C8E-4AB0-9AAA-703CD4897700}.Release.Build.0 = Release|.NET
-		{95394B96-A794-48EA-9879-0E4EC79C5724}.Debug.ActiveCfg = Debug|.NET
-		{95394B96-A794-48EA-9879-0E4EC79C5724}.Debug.Build.0 = Debug|.NET
-		{95394B96-A794-48EA-9879-0E4EC79C5724}.Release.ActiveCfg = Release|.NET
-		{95394B96-A794-48EA-9879-0E4EC79C5724}.Release.Build.0 = Release|.NET
-		{6BEF566A-2691-4EE8-91AF-0390CCCDDAF1}.Debug.ActiveCfg = Debug|.NET
-		{6BEF566A-2691-4EE8-91AF-0390CCCDDAF1}.Debug.Build.0 = Debug|.NET
-		{6BEF566A-2691-4EE8-91AF-0390CCCDDAF1}.Release.ActiveCfg = Release|.NET
-		{6BEF566A-2691-4EE8-91AF-0390CCCDDAF1}.Release.Build.0 = Release|.NET
-	EndGlobalSection
-	GlobalSection(ExtensibilityGlobals) = postSolution
-	EndGlobalSection
-	GlobalSection(ExtensibilityAddIns) = postSolution
-	EndGlobalSection
-EndGlobal

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Nuget/Lucene.Net.Core.2.9.4.1.nupkg
----------------------------------------------------------------------
diff --git a/lib/Nuget/Lucene.Net.Core.2.9.4.1.nupkg b/lib/Nuget/Lucene.Net.Core.2.9.4.1.nupkg
deleted file mode 100644
index 5173434..0000000
Binary files a/lib/Nuget/Lucene.Net.Core.2.9.4.1.nupkg and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/StyleCop.4.5/Docs/StyleCop.chm
----------------------------------------------------------------------
diff --git a/lib/StyleCop.4.5/Docs/StyleCop.chm b/lib/StyleCop.4.5/Docs/StyleCop.chm
deleted file mode 100644
index d49473d..0000000
Binary files a/lib/StyleCop.4.5/Docs/StyleCop.chm and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/src/Lucene.Net.Codecs/Appending/AppendingCodec.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Codecs/Appending/AppendingCodec.cs b/src/Lucene.Net.Codecs/Appending/AppendingCodec.cs
new file mode 100644
index 0000000..01248d6
--- /dev/null
+++ b/src/Lucene.Net.Codecs/Appending/AppendingCodec.cs
@@ -0,0 +1,48 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+namespace Lucene.Net.Codecs.Appending
+{
+    using System;
+    using Lucene.Net.Codecs.Lucene40;
+
+    /// <summary>
+    /// This codec uses an index format that is very similar to Lucene40Codec 
+    /// but works on append-only outputs, such as plain output streams and 
+    /// append-only filesystems.
+    ///
+    /// @lucene.experimental
+    /// </summary>
+    [Obsolete(
+        "This codec is read-only: as the functionality has been folded into the default codec. Its only for convenience to read old segments."
+        )]
+    public class AppendingCodec : FilterCodec
+    {
+        private readonly PostingsFormat _postings = new AppendingPostingsFormat();
+
+        public AppendingCodec() : base("Appending", new Lucene40Codec())
+        {
+        }
+
+        public override PostingsFormat PostingsFormat()
+        {
+            return _postings;
+        }
+    }
+
+}
+

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/src/Lucene.Net.Codecs/Appending/AppendingPostingsFormat.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Codecs/Appending/AppendingPostingsFormat.cs b/src/Lucene.Net.Codecs/Appending/AppendingPostingsFormat.cs
new file mode 100644
index 0000000..8e3f770
--- /dev/null
+++ b/src/Lucene.Net.Codecs/Appending/AppendingPostingsFormat.cs
@@ -0,0 +1,64 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+namespace Lucene.Net.Codecs.Appending
+{
+    using System;
+    using Lucene.Net.Codecs.Lucene40;
+    using Lucene.Net.Index;
+
+    /// <summary>
+    /// Appending Postigns Implementation
+    /// </summary>
+    internal class AppendingPostingsFormat : PostingsFormat
+    {
+        public static String CODEC_NAME = "Appending";
+
+        public AppendingPostingsFormat() : base(CODEC_NAME)
+        {}
+
+        public override FieldsConsumer FieldsConsumer(SegmentWriteState state)
+        {
+            throw new NotImplementedException("This codec can only be used for reading");
+        }
+
+        public override FieldsProducer FieldsProducer(SegmentReadState state)
+        {
+            PostingsReaderBase postings = new Lucene40PostingsReader(state.Directory, state.FieldInfos,
+                state.SegmentInfo,
+                state.Context, state.SegmentSuffix);
+
+            var success = false;
+            FieldsProducer ret;
+            using (ret = new AppendingTermsReader(
+                state.Directory,
+                state.FieldInfos,
+                state.SegmentInfo,
+                postings,
+                state.Context,
+                state.SegmentSuffix,
+                state.TermsIndexDivisor))
+            {
+                success = true;
+            }
+
+            return ret;
+            
+        }
+    }
+}
+

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/src/Lucene.Net.Codecs/Appending/AppendingTermsReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Codecs/Appending/AppendingTermsReader.cs b/src/Lucene.Net.Codecs/Appending/AppendingTermsReader.cs
new file mode 100644
index 0000000..da4e33f
--- /dev/null
+++ b/src/Lucene.Net.Codecs/Appending/AppendingTermsReader.cs
@@ -0,0 +1,63 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+namespace Lucene.Net.Codecs.Appending
+{
+    using System;
+    using Lucene.Net.Index;
+    using Lucene.Net.Store;
+
+    /// <summary>
+    /// Reads append-only terms from AppendingTermsWriter.
+    /// 
+    /// @lucene.experimental
+    /// </summary>
+    [Obsolete("Only for reading old Appending segments")]
+    public class AppendingTermsReader : BlockTreeTermsReader
+    {
+        private const String APPENDING_TERMS_CODEC_NAME = "APPENDING_TERMS_DICT";
+        private const String APPENDING_TERMS_INDEX_CODEC_NAME = "APPENDING_TERMS_INDEX";
+
+        public AppendingTermsReader(Directory dir, FieldInfos fieldInfos, SegmentInfo info,
+            PostingsReaderBase postingsReader,
+            IOContext ioContext, String segmentSuffix, int indexDivisor)
+            : base(dir, fieldInfos, info, postingsReader, ioContext, segmentSuffix, indexDivisor)
+        {
+        }
+
+        protected override int ReadHeader(IndexInput input)
+        {
+            return CodecUtil.CheckHeader(input, APPENDING_TERMS_CODEC_NAME,
+                BlockTreeTermsWriter.VERSION_START,
+                BlockTreeTermsWriter.VERSION_CURRENT);
+        }
+
+        protected override int ReadIndexHeader(IndexInput input)
+        {
+            return CodecUtil.CheckHeader(input, APPENDING_TERMS_INDEX_CODEC_NAME,
+                BlockTreeTermsWriter.VERSION_START,
+                BlockTreeTermsWriter.VERSION_CURRENT);
+        }
+
+        protected override void SeekDir(IndexInput input, long dirOffset)
+        {
+            input.Seek(input.Length() - sizeof(long)/8);
+            long offset = input.ReadLong();
+            input.Seek(offset);
+        }
+    }
+}

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/src/Lucene.Net.Codecs/BlockTerms/BlockTermsFieldAndTerm.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Codecs/BlockTerms/BlockTermsFieldAndTerm.cs b/src/Lucene.Net.Codecs/BlockTerms/BlockTermsFieldAndTerm.cs
new file mode 100644
index 0000000..3001bfa
--- /dev/null
+++ b/src/Lucene.Net.Codecs/BlockTerms/BlockTermsFieldAndTerm.cs
@@ -0,0 +1,46 @@
+using System;
+using System.Collections.Generic;
+using System.Linq;
+using System.Text;
+using System.Threading.Tasks;
+using Lucene.Net.Util;
+
+namespace Lucene.Net.Codecs.BlockTerms
+{
+    /// <summary>
+    /// Used as key for the terms cache
+    /// </summary>
+    internal class BlockTermsFieldAndTerm : DoubleBarrelLRUCache.CloneableKey
+    {
+
+        public String Field { get; set; }
+        public BytesRef Term { get; set; }
+
+        public FieldAndTerm()
+        {
+        }
+
+        public FieldAndTerm(FieldAndTerm other)
+        {
+            Field = other.Field;
+            Term = BytesRef.DeepCopyOf(other.Term);
+        }
+
+        public override bool Equals(Object _other)
+        {
+            FieldAndTerm other = (FieldAndTerm) _other;
+            return other.Field.equals(field) && Term.BytesEquals(other.Term);
+        }
+
+        public override FieldAndTerm Clone()
+        {
+            return new FieldAndTerm(this);
+        }
+
+        public override int GetHashCode()
+        {
+            return Field.GetHashCode()*31 + Term.GetHashCode();
+        }
+    }
+}
+


[06/51] [abbrv] [partial] Cleaning up and getting ready to development towards v4.8

Posted by sy...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/src/Lucene.Net.Codecs/Memory/DirectPostingsFormat.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Codecs/Memory/DirectPostingsFormat.cs b/src/Lucene.Net.Codecs/Memory/DirectPostingsFormat.cs
new file mode 100644
index 0000000..5d90e98
--- /dev/null
+++ b/src/Lucene.Net.Codecs/Memory/DirectPostingsFormat.cs
@@ -0,0 +1,2302 @@
+package org.apache.lucene.codecs.memory;
+
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+import java.io.IOException;
+import java.util.Collections;
+import java.util.Comparator;
+import java.util.Iterator;
+import java.util.Map;
+import java.util.TreeMap;
+
+import org.apache.lucene.codecs.FieldsConsumer;
+import org.apache.lucene.codecs.FieldsProducer;
+import org.apache.lucene.codecs.PostingsFormat;
+import org.apache.lucene.codecs.lucene41.Lucene41PostingsFormat; // javadocs
+import org.apache.lucene.index.DocsAndPositionsEnum;
+import org.apache.lucene.index.DocsEnum;
+import org.apache.lucene.index.FieldInfo.IndexOptions;
+import org.apache.lucene.index.FieldInfo;
+import org.apache.lucene.index.Fields;
+import org.apache.lucene.index.OrdTermState;
+import org.apache.lucene.index.SegmentReadState;
+import org.apache.lucene.index.SegmentWriteState;
+import org.apache.lucene.index.TermState;
+import org.apache.lucene.index.Terms;
+import org.apache.lucene.index.TermsEnum;
+import org.apache.lucene.store.IOContext;
+import org.apache.lucene.store.RAMOutputStream;
+import org.apache.lucene.util.ArrayUtil;
+import org.apache.lucene.util.Bits;
+import org.apache.lucene.util.BytesRef;
+import org.apache.lucene.util.RamUsageEstimator;
+import org.apache.lucene.util.automaton.CompiledAutomaton;
+import org.apache.lucene.util.automaton.RunAutomaton;
+import org.apache.lucene.util.automaton.Transition;
+
+// TODO: 
+//   - build depth-N prefix hash?
+//   - or: longer dense skip lists than just next byte?
+
+/** Wraps {@link Lucene41PostingsFormat} format for on-disk
+ *  storage, but then at read time loads and stores all
+ *  terms & postings directly in RAM as byte[], int[].
+ *
+ *  <p><b><font color=red>WARNING</font></b>: This is
+ *  exceptionally RAM intensive: it makes no effort to
+ *  compress the postings data, storing terms as separate
+ *  byte[] and postings as separate int[], but as a result it 
+ *  gives substantial increase in search performance.
+ *
+ *  <p>This postings format supports {@link TermsEnum#ord}
+ *  and {@link TermsEnum#seekExact(long)}.
+
+ *  <p>Because this holds all term bytes as a single
+ *  byte[], you cannot have more than 2.1GB worth of term
+ *  bytes in a single segment.
+ *
+ * @lucene.experimental */
+
+public final class DirectPostingsFormat extends PostingsFormat {
+
+  private final int minSkipCount;
+  private final int lowFreqCutoff;
+
+  private final static int DEFAULT_MIN_SKIP_COUNT = 8;
+  private final static int DEFAULT_LOW_FREQ_CUTOFF = 32;
+
+  //private static final bool DEBUG = true;
+
+  // TODO: allow passing/wrapping arbitrary postings format?
+
+  public DirectPostingsFormat() {
+    this(DEFAULT_MIN_SKIP_COUNT, DEFAULT_LOW_FREQ_CUTOFF);
+  }
+  
+  /** minSkipCount is how many terms in a row must have the
+   *  same prefix before we put a skip pointer down.  Terms
+   *  with docFreq <= lowFreqCutoff will use a single int[]
+   *  to hold all docs, freqs, position and offsets; terms
+   *  with higher docFreq will use separate arrays. */
+  public DirectPostingsFormat(int minSkipCount, int lowFreqCutoff) {
+    super("Direct");
+    this.minSkipCount = minSkipCount;
+    this.lowFreqCutoff = lowFreqCutoff;
+  }
+  
+  @Override
+  public FieldsConsumer fieldsConsumer(SegmentWriteState state)  {
+    return PostingsFormat.forName("Lucene41").fieldsConsumer(state);
+  }
+
+  @Override
+  public FieldsProducer fieldsProducer(SegmentReadState state)  {
+    FieldsProducer postings = PostingsFormat.forName("Lucene41").fieldsProducer(state);
+    if (state.context.context != IOContext.Context.MERGE) {
+      FieldsProducer loadedPostings;
+      try {
+        postings.checkIntegrity();
+        loadedPostings = new DirectFields(state, postings, minSkipCount, lowFreqCutoff);
+      } finally {
+        postings.close();
+      }
+      return loadedPostings;
+    } else {
+      // Don't load postings for merge:
+      return postings;
+    }
+  }
+
+  private static final class DirectFields extends FieldsProducer {
+    private final Map<String,DirectField> fields = new TreeMap<>();
+
+    public DirectFields(SegmentReadState state, Fields fields, int minSkipCount, int lowFreqCutoff)  {
+      for (String field : fields) {
+        this.fields.put(field, new DirectField(state, field, fields.terms(field), minSkipCount, lowFreqCutoff));
+      }
+    }
+
+    @Override
+    public Iterator<String> iterator() {
+      return Collections.unmodifiableSet(fields.keySet()).iterator();
+    }
+
+    @Override
+    public Terms terms(String field) {
+      return fields.get(field);
+    }
+
+    @Override
+    public int size() {
+      return fields.size();
+    }
+
+    @Override
+    public long getUniqueTermCount() {
+      long numTerms = 0;      
+      for(DirectField field : fields.values()) {
+        numTerms += field.terms.length;
+      }
+      return numTerms;
+    }
+
+    @Override
+    public void close() {
+    }
+
+    @Override
+    public long ramBytesUsed() {
+      long sizeInBytes = 0;
+      for(Map.Entry<String,DirectField> entry: fields.entrySet()) {
+        sizeInBytes += entry.getKey().length() * RamUsageEstimator.NUM_BYTES_CHAR;
+        sizeInBytes += entry.getValue().ramBytesUsed();
+      }
+      return sizeInBytes;
+    }
+
+    @Override
+    public void checkIntegrity()  {
+      // if we read entirely into ram, we already validated.
+      // otherwise returned the raw postings reader
+    }
+  }
+
+  private final static class DirectField extends Terms {
+
+    private static abstract class TermAndSkip {
+      public int[] skips;
+
+      /** Returns the approximate number of RAM bytes used */
+      public abstract long ramBytesUsed();
+    }
+
+    private static final class LowFreqTerm extends TermAndSkip {
+      public final int[] postings;
+      public final byte[] payloads;
+      public final int docFreq;
+      public final int totalTermFreq;
+
+      public LowFreqTerm(int[] postings, byte[] payloads, int docFreq, int totalTermFreq) {
+        this.postings = postings;
+        this.payloads = payloads;
+        this.docFreq = docFreq;
+        this.totalTermFreq = totalTermFreq;
+      }
+
+      @Override
+      public long ramBytesUsed() {
+        return ((postings!=null) ? RamUsageEstimator.sizeOf(postings) : 0) + 
+            ((payloads!=null) ? RamUsageEstimator.sizeOf(payloads) : 0);
+      }
+    }
+
+    // TODO: maybe specialize into prx/no-prx/no-frq cases?
+    private static final class HighFreqTerm extends TermAndSkip {
+      public final long totalTermFreq;
+      public final int[] docIDs;
+      public final int[] freqs;
+      public final int[][] positions;
+      public final byte[][][] payloads;
+
+      public HighFreqTerm(int[] docIDs, int[] freqs, int[][] positions, byte[][][] payloads, long totalTermFreq) {
+        this.docIDs = docIDs;
+        this.freqs = freqs;
+        this.positions = positions;
+        this.payloads = payloads;
+        this.totalTermFreq = totalTermFreq;
+      }
+
+      @Override
+      public long ramBytesUsed() {
+         long sizeInBytes = 0;
+         sizeInBytes += (docIDs!=null)? RamUsageEstimator.sizeOf(docIDs) : 0;
+         sizeInBytes += (freqs!=null)? RamUsageEstimator.sizeOf(freqs) : 0;
+         
+         if(positions != null) {
+           for(int[] position : positions) {
+             sizeInBytes += (position!=null) ? RamUsageEstimator.sizeOf(position) : 0;
+           }
+         }
+         
+         if (payloads != null) {
+           for(byte[][] payload : payloads) {
+             if(payload != null) {
+               for(byte[] pload : payload) {
+                 sizeInBytes += (pload!=null) ? RamUsageEstimator.sizeOf(pload) : 0; 
+               }
+             }
+           }
+         }
+         
+         return sizeInBytes;
+      }
+    }
+
+    private final byte[] termBytes;
+    private final int[] termOffsets;
+
+    private final int[] skips;
+    private final int[] skipOffsets;
+
+    private final TermAndSkip[] terms;
+    private final bool hasFreq;
+    private final bool hasPos;
+    private final bool hasOffsets;
+    private final bool hasPayloads;
+    private final long sumTotalTermFreq;
+    private final int docCount;
+    private final long sumDocFreq;
+    private int skipCount;
+
+    // TODO: maybe make a separate builder?  These are only
+    // used during load:
+    private int count;
+    private int[] sameCounts = new int[10];
+    private final int minSkipCount;
+
+    private final static class IntArrayWriter {
+      private int[] ints = new int[10];
+      private int upto;
+
+      public void add(int value) {
+        if (ints.length == upto) {
+          ints = ArrayUtil.grow(ints);
+        }
+        ints[upto++] = value;
+      }
+
+      public int[] get() {
+        final int[] arr = new int[upto];
+        System.arraycopy(ints, 0, arr, 0, upto);
+        upto = 0;
+        return arr;
+      }
+    }
+
+    public DirectField(SegmentReadState state, String field, Terms termsIn, int minSkipCount, int lowFreqCutoff)  {
+      final FieldInfo fieldInfo = state.fieldInfos.fieldInfo(field);
+
+      sumTotalTermFreq = termsIn.getSumTotalTermFreq();
+      sumDocFreq = termsIn.getSumDocFreq();
+      docCount = termsIn.getDocCount();
+
+      final int numTerms = (int) termsIn.size();
+      if (numTerms == -1) {
+        throw new IllegalArgumentException("codec does not provide Terms.size()");
+      }
+      terms = new TermAndSkip[numTerms];
+      termOffsets = new int[1+numTerms];
+      
+      byte[] termBytes = new byte[1024];
+
+      this.minSkipCount = minSkipCount;
+
+      hasFreq = fieldInfo.getIndexOptions().compareTo(IndexOptions.DOCS_ONLY) > 0;
+      hasPos = fieldInfo.getIndexOptions().compareTo(IndexOptions.DOCS_AND_FREQS) > 0;
+      hasOffsets = fieldInfo.getIndexOptions().compareTo(IndexOptions.DOCS_AND_FREQS_AND_POSITIONS) > 0;
+      hasPayloads = fieldInfo.hasPayloads();
+
+      BytesRef term;
+      DocsEnum docsEnum = null;
+      DocsAndPositionsEnum docsAndPositionsEnum = null;
+      final TermsEnum termsEnum = termsIn.iterator(null);
+      int termOffset = 0;
+
+      final IntArrayWriter scratch = new IntArrayWriter();
+
+      // Used for payloads, if any:
+      final RAMOutputStream ros = new RAMOutputStream();
+
+      // if (DEBUG) {
+      //   System.out.println("\nLOAD terms seg=" + state.segmentInfo.name + " field=" + field + " hasOffsets=" + hasOffsets + " hasFreq=" + hasFreq + " hasPos=" + hasPos + " hasPayloads=" + hasPayloads);
+      // }
+
+      while ((term = termsEnum.next()) != null) {
+        final int docFreq = termsEnum.docFreq();
+        final long totalTermFreq = termsEnum.totalTermFreq();
+
+        // if (DEBUG) {
+        //   System.out.println("  term=" + term.utf8ToString());
+        // }
+
+        termOffsets[count] = termOffset;
+
+        if (termBytes.length < (termOffset + term.length)) {
+          termBytes = ArrayUtil.grow(termBytes, termOffset + term.length);
+        }
+        System.arraycopy(term.bytes, term.offset, termBytes, termOffset, term.length);
+        termOffset += term.length;
+        termOffsets[count+1] = termOffset;
+
+        if (hasPos) {
+          docsAndPositionsEnum = termsEnum.docsAndPositions(null, docsAndPositionsEnum);
+        } else {
+          docsEnum = termsEnum.docs(null, docsEnum);
+        }
+
+        final TermAndSkip ent;
+
+        final DocsEnum docsEnum2;
+        if (hasPos) {
+          docsEnum2 = docsAndPositionsEnum;
+        } else {
+          docsEnum2 = docsEnum;
+        }
+
+        int docID;
+
+        if (docFreq <= lowFreqCutoff) {
+
+          ros.reset();
+
+          // Pack postings for low-freq terms into a single int[]:
+          while ((docID = docsEnum2.nextDoc()) != DocsEnum.NO_MORE_DOCS) {
+            scratch.add(docID);
+            if (hasFreq) {
+              final int freq = docsEnum2.freq();
+              scratch.add(freq);
+              if (hasPos) {
+                for(int pos=0;pos<freq;pos++) {
+                  scratch.add(docsAndPositionsEnum.nextPosition());
+                  if (hasOffsets) {
+                    scratch.add(docsAndPositionsEnum.startOffset());
+                    scratch.add(docsAndPositionsEnum.endOffset());
+                  }
+                  if (hasPayloads) {
+                    final BytesRef payload = docsAndPositionsEnum.getPayload();
+                    if (payload != null) {
+                      scratch.add(payload.length);
+                      ros.writeBytes(payload.bytes, payload.offset, payload.length);
+                    } else {
+                      scratch.add(0);
+                    }
+                  }
+                }
+              }
+            }
+          }
+
+          final byte[] payloads;
+          if (hasPayloads) {
+            ros.flush();
+            payloads = new byte[(int) ros.length()];
+            ros.writeTo(payloads, 0);
+          } else {
+            payloads = null;
+          }
+
+          final int[] postings = scratch.get();
+        
+          ent = new LowFreqTerm(postings, payloads, docFreq, (int) totalTermFreq);
+        } else {
+          final int[] docs = new int[docFreq];
+          final int[] freqs;
+          final int[][] positions;
+          final byte[][][] payloads;
+          if (hasFreq) {
+            freqs = new int[docFreq];
+            if (hasPos) {
+              positions = new int[docFreq][];
+              if (hasPayloads) {
+                payloads = new byte[docFreq][][];
+              } else {
+                payloads = null;
+              }
+            } else {
+              positions = null;
+              payloads = null;
+            }
+          } else {
+            freqs = null;
+            positions = null;
+            payloads = null;
+          }
+
+          // Use separate int[] for the postings for high-freq
+          // terms:
+          int upto = 0;
+          while ((docID = docsEnum2.nextDoc()) != DocsEnum.NO_MORE_DOCS) {
+            docs[upto] = docID;
+            if (hasFreq) {
+              final int freq = docsEnum2.freq();
+              freqs[upto] = freq;
+              if (hasPos) {
+                final int mult;
+                if (hasOffsets) {
+                  mult = 3;
+                } else {
+                  mult = 1;
+                }
+                if (hasPayloads) {
+                  payloads[upto] = new byte[freq][];
+                }
+                positions[upto] = new int[mult*freq];
+                int posUpto = 0;
+                for(int pos=0;pos<freq;pos++) {
+                  positions[upto][posUpto] = docsAndPositionsEnum.nextPosition();
+                  if (hasPayloads) {
+                    BytesRef payload = docsAndPositionsEnum.getPayload();
+                    if (payload != null) {
+                      byte[] payloadBytes = new byte[payload.length];
+                      System.arraycopy(payload.bytes, payload.offset, payloadBytes, 0, payload.length);
+                      payloads[upto][pos] = payloadBytes;
+                    }
+                  }
+                  posUpto++;
+                  if (hasOffsets) {
+                    positions[upto][posUpto++] = docsAndPositionsEnum.startOffset();
+                    positions[upto][posUpto++] = docsAndPositionsEnum.endOffset();
+                  }
+                }
+              }
+            }
+
+            upto++;
+          }
+          Debug.Assert( upto == docFreq;
+          ent = new HighFreqTerm(docs, freqs, positions, payloads, totalTermFreq);
+        }
+
+        terms[count] = ent;
+        setSkips(count, termBytes);
+        count++;
+      }
+
+      // End sentinel:
+      termOffsets[count] = termOffset;
+
+      finishSkips();
+
+      //System.out.println(skipCount + " skips: " + field);
+
+      this.termBytes = new byte[termOffset];
+      System.arraycopy(termBytes, 0, this.termBytes, 0, termOffset);
+
+      // Pack skips:
+      this.skips = new int[skipCount];
+      this.skipOffsets = new int[1+numTerms];
+
+      int skipOffset = 0;
+      for(int i=0;i<numTerms;i++) {
+        final int[] termSkips = terms[i].skips;
+        skipOffsets[i] = skipOffset;
+        if (termSkips != null) {
+          System.arraycopy(termSkips, 0, skips, skipOffset, termSkips.length);
+          skipOffset += termSkips.length;
+          terms[i].skips = null;
+        }
+      }
+      this.skipOffsets[numTerms] = skipOffset;
+      Debug.Assert( skipOffset == skipCount;
+    }
+
+    /** Returns approximate RAM bytes used */
+    public long ramBytesUsed() {
+      long sizeInBytes = 0;
+      sizeInBytes += ((termBytes!=null) ? RamUsageEstimator.sizeOf(termBytes) : 0);
+      sizeInBytes += ((termOffsets!=null) ? RamUsageEstimator.sizeOf(termOffsets) : 0);
+      sizeInBytes += ((skips!=null) ? RamUsageEstimator.sizeOf(skips) : 0);
+      sizeInBytes += ((skipOffsets!=null) ? RamUsageEstimator.sizeOf(skipOffsets) : 0);
+      sizeInBytes += ((sameCounts!=null) ? RamUsageEstimator.sizeOf(sameCounts) : 0);
+      
+      if(terms!=null) {
+        for(TermAndSkip termAndSkip : terms) {
+          sizeInBytes += (termAndSkip!=null) ? termAndSkip.ramBytesUsed() : 0;
+        }
+      }
+      
+      return sizeInBytes;
+    }
+
+    // Compares in unicode (UTF8) order:
+    int compare(int ord, BytesRef other) {
+      final byte[] otherBytes = other.bytes;
+
+      int upto = termOffsets[ord];
+      final int termLen = termOffsets[1+ord] - upto;
+      int otherUpto = other.offset;
+      
+      final int stop = upto + Math.min(termLen, other.length);
+      while (upto < stop) {
+        int diff = (termBytes[upto++] & 0xFF) - (otherBytes[otherUpto++] & 0xFF);
+        if (diff != 0) {
+          return diff;
+        }
+      }
+    
+      // One is a prefix of the other, or, they are equal:
+      return termLen - other.length;
+    }
+
+    private void setSkips(int termOrd, byte[] termBytes) {
+
+      final int termLength = termOffsets[termOrd+1] - termOffsets[termOrd];
+
+      if (sameCounts.length < termLength) {
+        sameCounts = ArrayUtil.grow(sameCounts, termLength);
+      }
+
+      // Update skip pointers:
+      if (termOrd > 0) {
+        final int lastTermLength = termOffsets[termOrd] - termOffsets[termOrd-1];
+        final int limit = Math.min(termLength, lastTermLength);
+
+        int lastTermOffset = termOffsets[termOrd-1];
+        int termOffset = termOffsets[termOrd];
+
+        int i = 0;
+        for(;i<limit;i++) {
+          if (termBytes[lastTermOffset++] == termBytes[termOffset++]) {
+            sameCounts[i]++;
+          } else {
+            for(;i<limit;i++) {
+              if (sameCounts[i] >= minSkipCount) {
+                // Go back and add a skip pointer:
+                saveSkip(termOrd, sameCounts[i]);
+              }
+              sameCounts[i] = 1;
+            }
+            break;
+          }
+        }
+
+        for(;i<lastTermLength;i++) {
+          if (sameCounts[i] >= minSkipCount) {
+            // Go back and add a skip pointer:
+            saveSkip(termOrd, sameCounts[i]);
+          }
+          sameCounts[i] = 0;
+        }
+        for(int j=limit;j<termLength;j++) {
+          sameCounts[j] = 1;
+        }
+      } else {
+        for(int i=0;i<termLength;i++) {
+          sameCounts[i]++;
+        }
+      }
+    }
+
+    private void finishSkips() {
+      Debug.Assert( count == terms.length;
+      int lastTermOffset = termOffsets[count-1];
+      int lastTermLength = termOffsets[count] - lastTermOffset;
+
+      for(int i=0;i<lastTermLength;i++) {
+        if (sameCounts[i] >= minSkipCount) {
+          // Go back and add a skip pointer:
+          saveSkip(count, sameCounts[i]);
+        }
+      }
+
+      // Reverse the skip pointers so they are "nested":
+      for(int termID=0;termID<terms.length;termID++) {
+        TermAndSkip term = terms[termID];
+        if (term.skips != null && term.skips.length > 1) {
+          for(int pos=0;pos<term.skips.length/2;pos++) {
+            final int otherPos = term.skips.length-pos-1;
+
+            final int temp = term.skips[pos];
+            term.skips[pos] = term.skips[otherPos];
+            term.skips[otherPos] = temp;
+          }
+        }
+      }
+    }
+
+    private void saveSkip(int ord, int backCount) {
+      final TermAndSkip term = terms[ord - backCount];
+      skipCount++;
+      if (term.skips == null) {
+        term.skips = new int[] {ord};
+      } else {
+        // Normally we'd grow at a slight exponential... but
+        // given that the skips themselves are already log(N)
+        // we can grow by only 1 and still have amortized
+        // linear time:
+        final int[] newSkips = new int[term.skips.length+1];
+        System.arraycopy(term.skips, 0, newSkips, 0, term.skips.length);
+        term.skips = newSkips;
+        term.skips[term.skips.length-1] = ord;
+      }
+    }
+
+    @Override
+    public TermsEnum iterator(TermsEnum reuse) {
+      DirectTermsEnum termsEnum;
+      if (reuse != null && reuse instanceof DirectTermsEnum) {
+        termsEnum = (DirectTermsEnum) reuse;
+        if (!termsEnum.canReuse(terms)) {
+          termsEnum = new DirectTermsEnum();
+        }
+      } else {
+        termsEnum = new DirectTermsEnum();
+      }
+      termsEnum.reset();
+      return termsEnum;
+    }
+
+    @Override
+    public TermsEnum intersect(CompiledAutomaton compiled, final BytesRef startTerm) {
+      return new DirectIntersectTermsEnum(compiled, startTerm);
+    }
+
+    @Override
+    public long size() {
+      return terms.length;
+    }
+
+    @Override
+    public long getSumTotalTermFreq() {
+      return sumTotalTermFreq;
+    }
+
+    @Override
+    public long getSumDocFreq() {
+      return sumDocFreq;
+    }
+
+    @Override
+    public int getDocCount() {
+      return docCount;
+    }
+
+    @Override
+    public Comparator<BytesRef> getComparator() {
+      return BytesRef.getUTF8SortedAsUnicodeComparator();
+    }
+
+    @Override
+    public bool hasFreqs() {
+      return hasFreq;
+    }
+
+    @Override
+    public bool hasOffsets() {
+      return hasOffsets;
+    }
+
+    @Override
+    public bool hasPositions() {
+      return hasPos;
+    }
+    
+    @Override
+    public bool hasPayloads() {
+      return hasPayloads;
+    }
+
+    private final class DirectTermsEnum extends TermsEnum {
+
+      private final BytesRef scratch = new BytesRef();
+      private int termOrd;
+
+      bool canReuse(TermAndSkip[] other) {
+        return DirectField.this.terms == other;
+      }
+
+      private BytesRef setTerm() {
+        scratch.bytes = termBytes;
+        scratch.offset = termOffsets[termOrd];
+        scratch.length = termOffsets[termOrd+1] - termOffsets[termOrd];
+        return scratch;
+      }
+
+      public void reset() {
+        termOrd = -1;
+      }
+
+      @Override
+      public Comparator<BytesRef> getComparator() {
+        return BytesRef.getUTF8SortedAsUnicodeComparator();
+      }
+
+      @Override
+      public BytesRef next() {
+        termOrd++;
+        if (termOrd < terms.length) {
+          return setTerm();
+        } else {
+          return null;
+        }
+      }
+
+      @Override
+      public TermState termState() {
+        OrdTermState state = new OrdTermState();
+        state.ord = termOrd;
+        return state;
+      }
+
+      // If non-negative, exact match; else, -ord-1, where ord
+      // is where you would insert the term.
+      private int findTerm(BytesRef term) {
+
+        // Just do binary search: should be (constant factor)
+        // faster than using the skip list:
+        int low = 0;
+        int high = terms.length-1;
+
+        while (low <= high) {
+          int mid = (low + high) >>> 1;
+          int cmp = compare(mid, term);
+          if (cmp < 0) {
+            low = mid + 1;
+          } else if (cmp > 0) {
+            high = mid - 1;
+          } else {
+            return mid; // key found
+          }
+        }
+
+        return -(low + 1);  // key not found.
+      }
+
+      @Override
+      public SeekStatus seekCeil(BytesRef term) {
+        // TODO: we should use the skip pointers; should be
+        // faster than bin search; we should also hold
+        // & reuse current state so seeking forwards is
+        // faster
+        final int ord = findTerm(term);
+        // if (DEBUG) {
+        //   System.out.println("  find term=" + term.utf8ToString() + " ord=" + ord);
+        // }
+        if (ord >= 0) {
+          termOrd = ord;
+          setTerm();
+          return SeekStatus.FOUND;
+        } else if (ord == -terms.length-1) {
+          return SeekStatus.END;
+        } else {
+          termOrd = -ord - 1;
+          setTerm();
+          return SeekStatus.NOT_FOUND;
+        }
+      }
+
+      @Override
+      public bool seekExact(BytesRef term) {
+        // TODO: we should use the skip pointers; should be
+        // faster than bin search; we should also hold
+        // & reuse current state so seeking forwards is
+        // faster
+        final int ord = findTerm(term);
+        if (ord >= 0) {
+          termOrd = ord;
+          setTerm();
+          return true;
+        } else {
+          return false;
+        }
+      }
+
+      @Override
+      public void seekExact(long ord) {
+        termOrd = (int) ord;
+        setTerm();
+      }
+
+      @Override
+      public void seekExact(BytesRef term, TermState state)  {
+        termOrd = (int) ((OrdTermState) state).ord;
+        setTerm();
+        Debug.Assert( term.equals(scratch);
+      }
+
+      @Override
+      public BytesRef term() {
+        return scratch;
+      }
+
+      @Override
+      public long ord() {
+        return termOrd;
+      }
+
+      @Override
+      public int docFreq() {
+        if (terms[termOrd] instanceof LowFreqTerm) {
+          return ((LowFreqTerm) terms[termOrd]).docFreq;
+        } else {
+          return ((HighFreqTerm) terms[termOrd]).docIDs.length;
+        }
+      }
+
+      @Override
+      public long totalTermFreq() {
+        if (terms[termOrd] instanceof LowFreqTerm) {
+          return ((LowFreqTerm) terms[termOrd]).totalTermFreq;
+        } else {
+          return ((HighFreqTerm) terms[termOrd]).totalTermFreq;
+        }
+      }
+
+      @Override
+      public DocsEnum docs(Bits liveDocs, DocsEnum reuse, int flags) {
+        // TODO: implement reuse, something like Pulsing:
+        // it's hairy!
+
+        if (terms[termOrd] instanceof LowFreqTerm) {
+          final int[] postings = ((LowFreqTerm) terms[termOrd]).postings;
+          if (hasFreq) {
+            if (hasPos) {
+              int posLen;
+              if (hasOffsets) {
+                posLen = 3;
+              } else {
+                posLen = 1;
+              }
+              if (hasPayloads) {
+                posLen++;
+              }
+              LowFreqDocsEnum docsEnum;
+              if (reuse instanceof LowFreqDocsEnum) {
+                docsEnum = (LowFreqDocsEnum) reuse;
+                if (!docsEnum.canReuse(liveDocs, posLen)) {
+                  docsEnum = new LowFreqDocsEnum(liveDocs, posLen);
+                }
+              } else {
+                docsEnum = new LowFreqDocsEnum(liveDocs, posLen);
+              }
+
+              return docsEnum.reset(postings);
+            } else {
+              LowFreqDocsEnumNoPos docsEnum;
+              if (reuse instanceof LowFreqDocsEnumNoPos) {
+                docsEnum = (LowFreqDocsEnumNoPos) reuse;
+                if (!docsEnum.canReuse(liveDocs)) {
+                  docsEnum = new LowFreqDocsEnumNoPos(liveDocs);
+                }
+              } else {
+                docsEnum = new LowFreqDocsEnumNoPos(liveDocs);
+              }
+
+              return docsEnum.reset(postings);
+            }
+          } else {
+            LowFreqDocsEnumNoTF docsEnum;
+            if (reuse instanceof LowFreqDocsEnumNoTF) {
+              docsEnum = (LowFreqDocsEnumNoTF) reuse;
+              if (!docsEnum.canReuse(liveDocs)) {
+                docsEnum = new LowFreqDocsEnumNoTF(liveDocs);
+              }
+            } else {
+              docsEnum = new LowFreqDocsEnumNoTF(liveDocs);
+            }
+
+            return docsEnum.reset(postings);
+          }
+        } else {
+          final HighFreqTerm term = (HighFreqTerm) terms[termOrd];
+
+          HighFreqDocsEnum docsEnum;
+          if (reuse instanceof HighFreqDocsEnum) {
+            docsEnum = (HighFreqDocsEnum) reuse;
+            if (!docsEnum.canReuse(liveDocs)) {
+              docsEnum = new HighFreqDocsEnum(liveDocs);
+            }
+          } else {
+            docsEnum = new HighFreqDocsEnum(liveDocs);
+          }
+
+          //System.out.println("  DE for term=" + new BytesRef(terms[termOrd].term).utf8ToString() + ": " + term.docIDs.length + " docs");
+          return docsEnum.reset(term.docIDs, term.freqs);
+        }
+      }
+
+      @Override
+      public DocsAndPositionsEnum docsAndPositions(Bits liveDocs, DocsAndPositionsEnum reuse, int flags) {
+        if (!hasPos) {
+          return null;
+        }
+
+        // TODO: implement reuse, something like Pulsing:
+        // it's hairy!
+
+        if (terms[termOrd] instanceof LowFreqTerm) {
+          final LowFreqTerm term = ((LowFreqTerm) terms[termOrd]);
+          final int[] postings = term.postings;
+          final byte[] payloads = term.payloads;
+          return new LowFreqDocsAndPositionsEnum(liveDocs, hasOffsets, hasPayloads).reset(postings, payloads);
+        } else {
+          final HighFreqTerm term = (HighFreqTerm) terms[termOrd];
+          return new HighFreqDocsAndPositionsEnum(liveDocs, hasOffsets).reset(term.docIDs, term.freqs, term.positions, term.payloads);
+        }
+      }
+    }
+
+    private final class DirectIntersectTermsEnum extends TermsEnum {
+      private final RunAutomaton runAutomaton;
+      private final CompiledAutomaton compiledAutomaton;
+      private int termOrd;
+      private final BytesRef scratch = new BytesRef();
+
+      private final class State {
+        int changeOrd;
+        int state;
+        Transition[] transitions;
+        int transitionUpto;
+        int transitionMax;
+        int transitionMin;
+      }
+
+      private State[] states;
+      private int stateUpto;
+
+      public DirectIntersectTermsEnum(CompiledAutomaton compiled, BytesRef startTerm) {
+        runAutomaton = compiled.runAutomaton;
+        compiledAutomaton = compiled;
+        termOrd = -1;
+        states = new State[1];
+        states[0] = new State();
+        states[0].changeOrd = terms.length;
+        states[0].state = runAutomaton.getInitialState();
+        states[0].transitions = compiledAutomaton.sortedTransitions[states[0].state];
+        states[0].transitionUpto = -1;
+        states[0].transitionMax = -1;
+
+        //System.out.println("IE.init startTerm=" + startTerm);
+
+        if (startTerm != null) {
+          int skipUpto = 0;
+          if (startTerm.length == 0) {
+            if (terms.length > 0 && termOffsets[1] == 0) {
+              termOrd = 0;
+            }
+          } else {
+            termOrd++;
+
+            nextLabel:
+            for(int i=0;i<startTerm.length;i++) {
+              final int label = startTerm.bytes[startTerm.offset+i] & 0xFF;
+
+              while (label > states[i].transitionMax) {
+                states[i].transitionUpto++;
+                Debug.Assert( states[i].transitionUpto < states[i].transitions.length;
+                states[i].transitionMin = states[i].transitions[states[i].transitionUpto].getMin();
+                states[i].transitionMax = states[i].transitions[states[i].transitionUpto].getMax();
+                Debug.Assert( states[i].transitionMin >= 0;
+                Debug.Assert( states[i].transitionMin <= 255;
+                Debug.Assert( states[i].transitionMax >= 0;
+                Debug.Assert( states[i].transitionMax <= 255;
+              }
+
+              // Skip forwards until we find a term matching
+              // the label at this position:
+              while (termOrd < terms.length) {
+                final int skipOffset = skipOffsets[termOrd];
+                final int numSkips = skipOffsets[termOrd+1] - skipOffset;
+                final int termOffset = termOffsets[termOrd];
+                final int termLength = termOffsets[1+termOrd] - termOffset;
+
+                // if (DEBUG) {
+                //   System.out.println("  check termOrd=" + termOrd + " term=" + new BytesRef(termBytes, termOffset, termLength).utf8ToString() + " skips=" + Arrays.toString(skips) + " i=" + i);
+                // }
+
+                if (termOrd == states[stateUpto].changeOrd) {
+                  // if (DEBUG) {
+                  //   System.out.println("  end push return");
+                  // }
+                  stateUpto--;
+                  termOrd--;
+                  return;
+                }
+
+                if (termLength == i) {
+                  termOrd++;
+                  skipUpto = 0;
+                  // if (DEBUG) {
+                  //   System.out.println("    term too short; next term");
+                  // }
+                } else if (label < (termBytes[termOffset+i] & 0xFF)) {
+                  termOrd--;
+                  // if (DEBUG) {
+                  //   System.out.println("  no match; already beyond; return termOrd=" + termOrd);
+                  // }
+                  stateUpto -= skipUpto;
+                  Debug.Assert( stateUpto >= 0;
+                  return;
+                } else if (label == (termBytes[termOffset+i] & 0xFF)) {
+                  // if (DEBUG) {
+                  //   System.out.println("    label[" + i + "] matches");
+                  // }
+                  if (skipUpto < numSkips) {
+                    grow();
+
+                    final int nextState = runAutomaton.step(states[stateUpto].state, label);
+
+                    // Automaton is required to accept startTerm:
+                    Debug.Assert( nextState != -1;
+
+                    stateUpto++;
+                    states[stateUpto].changeOrd = skips[skipOffset + skipUpto++];
+                    states[stateUpto].state = nextState;
+                    states[stateUpto].transitions = compiledAutomaton.sortedTransitions[nextState];
+                    states[stateUpto].transitionUpto = -1;
+                    states[stateUpto].transitionMax = -1;
+                    //System.out.println("  push " + states[stateUpto].transitions.length + " trans");
+
+                    // if (DEBUG) {
+                    //   System.out.println("    push skip; changeOrd=" + states[stateUpto].changeOrd);
+                    // }
+
+                    // Match next label at this same term:
+                    continue nextLabel;
+                  } else {
+                    // if (DEBUG) {
+                    //   System.out.println("    linear scan");
+                    // }
+                    // Index exhausted: just scan now (the
+                    // number of scans required will be less
+                    // than the minSkipCount):
+                    final int startTermOrd = termOrd;
+                    while (termOrd < terms.length && compare(termOrd, startTerm) <= 0) {
+                      Debug.Assert( termOrd == startTermOrd || skipOffsets[termOrd] == skipOffsets[termOrd+1];
+                      termOrd++;
+                    }
+                    Debug.Assert( termOrd - startTermOrd < minSkipCount;
+                    termOrd--;
+                    stateUpto -= skipUpto;
+                    // if (DEBUG) {
+                    //   System.out.println("  end termOrd=" + termOrd);
+                    // }
+                    return;
+                  }
+                } else {
+                  if (skipUpto < numSkips) {
+                    termOrd = skips[skipOffset + skipUpto];
+                    // if (DEBUG) {
+                    //   System.out.println("  no match; skip to termOrd=" + termOrd);
+                    // }
+                  } else {
+                    // if (DEBUG) {
+                    //   System.out.println("  no match; next term");
+                    // }
+                    termOrd++;
+                  }
+                  skipUpto = 0;
+                }
+              }
+
+              // startTerm is >= last term so enum will not
+              // return any terms:
+              termOrd--;
+              // if (DEBUG) {
+              //   System.out.println("  beyond end; no terms will match");
+              // }
+              return;
+            }
+          }
+
+          final int termOffset = termOffsets[termOrd];
+          final int termLen = termOffsets[1+termOrd] - termOffset;
+
+          if (termOrd >= 0 && !startTerm.equals(new BytesRef(termBytes, termOffset, termLen))) {
+            stateUpto -= skipUpto;
+            termOrd--;
+          }
+          // if (DEBUG) {
+          //   System.out.println("  loop end; return termOrd=" + termOrd + " stateUpto=" + stateUpto);
+          // }
+        }
+      }
+
+      @Override
+      public Comparator<BytesRef> getComparator() {
+        return BytesRef.getUTF8SortedAsUnicodeComparator();
+      }
+
+      private void grow() {
+        if (states.length == 1+stateUpto) {
+          final State[] newStates = new State[states.length+1];
+          System.arraycopy(states, 0, newStates, 0, states.length);
+          newStates[states.length] = new State();
+          states = newStates;
+        }
+      }
+
+      @Override
+      public BytesRef next() {
+        // if (DEBUG) {
+        //   System.out.println("\nIE.next");
+        // }
+
+        termOrd++;
+        int skipUpto = 0;
+
+        if (termOrd == 0 && termOffsets[1] == 0) {
+          // Special-case empty string:
+          Debug.Assert( stateUpto == 0;
+          // if (DEBUG) {
+          //   System.out.println("  visit empty string");
+          // }
+          if (runAutomaton.isAccept(states[0].state)) {
+            scratch.bytes = termBytes;
+            scratch.offset = 0;
+            scratch.length = 0;
+            return scratch;
+          }
+          termOrd++;
+        }
+
+        nextTerm:
+
+        while (true) {
+          // if (DEBUG) {
+          //   System.out.println("  cycle termOrd=" + termOrd + " stateUpto=" + stateUpto + " skipUpto=" + skipUpto);
+          // }
+          if (termOrd == terms.length) {
+            // if (DEBUG) {
+            //   System.out.println("  return END");
+            // }
+            return null;
+          }
+
+          final State state = states[stateUpto];
+          if (termOrd == state.changeOrd) {
+            // Pop:
+            // if (DEBUG) {
+            //   System.out.println("  pop stateUpto=" + stateUpto);
+            // }
+            stateUpto--;
+            /*
+            if (DEBUG) {
+              try {
+                //System.out.println("    prefix pop " + new BytesRef(terms[termOrd].term, 0, Math.min(stateUpto, terms[termOrd].term.length)).utf8ToString());
+                System.out.println("    prefix pop " + new BytesRef(terms[termOrd].term, 0, Math.min(stateUpto, terms[termOrd].term.length)));
+              } catch (ArrayIndexOutOfBoundsException aioobe) {
+                System.out.println("    prefix pop " + new BytesRef(terms[termOrd].term, 0, Math.min(stateUpto, terms[termOrd].term.length)));
+              }
+            }
+            */
+
+            continue;
+          }
+
+          final int termOffset = termOffsets[termOrd];
+          final int termLength = termOffsets[termOrd+1] - termOffset;
+          final int skipOffset = skipOffsets[termOrd];
+          final int numSkips = skipOffsets[termOrd+1] - skipOffset;
+
+          // if (DEBUG) {
+          //   System.out.println("  term=" + new BytesRef(termBytes, termOffset, termLength).utf8ToString() + " skips=" + Arrays.toString(skips));
+          // }
+        
+          Debug.Assert( termOrd < state.changeOrd;
+
+          Debug.Assert( stateUpto <= termLength: "term.length=" + termLength + "; stateUpto=" + stateUpto;
+          final int label = termBytes[termOffset+stateUpto] & 0xFF;
+
+          while (label > state.transitionMax) {
+            //System.out.println("  label=" + label + " vs max=" + state.transitionMax + " transUpto=" + state.transitionUpto + " vs " + state.transitions.length);
+            state.transitionUpto++;
+            if (state.transitionUpto == state.transitions.length) {
+              // We've exhausted transitions leaving this
+              // state; force pop+next/skip now:
+              //System.out.println("forcepop: stateUpto=" + stateUpto);
+              if (stateUpto == 0) {
+                termOrd = terms.length;
+                return null;
+              } else {
+                Debug.Assert( state.changeOrd > termOrd;
+                // if (DEBUG) {
+                //   System.out.println("  jumpend " + (state.changeOrd - termOrd));
+                // }
+                //System.out.println("  jump to termOrd=" + states[stateUpto].changeOrd + " vs " + termOrd);
+                termOrd = states[stateUpto].changeOrd;
+                skipUpto = 0;
+                stateUpto--;
+              }
+              continue nextTerm;
+            }
+            Debug.Assert( state.transitionUpto < state.transitions.length: " state.transitionUpto=" + state.transitionUpto + " vs " + state.transitions.length;
+            state.transitionMin = state.transitions[state.transitionUpto].getMin();
+            state.transitionMax = state.transitions[state.transitionUpto].getMax();
+            Debug.Assert( state.transitionMin >= 0;
+            Debug.Assert( state.transitionMin <= 255;
+            Debug.Assert( state.transitionMax >= 0;
+            Debug.Assert( state.transitionMax <= 255;
+          }
+
+          /*
+          if (DEBUG) {
+            System.out.println("    check ord=" + termOrd + " term[" + stateUpto + "]=" + (char) label + "(" + label + ") term=" + new BytesRef(terms[termOrd].term).utf8ToString() + " trans " +
+                               (char) state.transitionMin + "(" + state.transitionMin + ")" + "-" + (char) state.transitionMax + "(" + state.transitionMax + ") nextChange=+" + (state.changeOrd - termOrd) + " skips=" + (skips == null ? "null" : Arrays.toString(skips)));
+            System.out.println("    check ord=" + termOrd + " term[" + stateUpto + "]=" + Integer.toHexString(label) + "(" + label + ") term=" + new BytesRef(termBytes, termOffset, termLength) + " trans " +
+                               Integer.toHexString(state.transitionMin) + "(" + state.transitionMin + ")" + "-" + Integer.toHexString(state.transitionMax) + "(" + state.transitionMax + ") nextChange=+" + (state.changeOrd - termOrd) + " skips=" + (skips == null ? "null" : Arrays.toString(skips)));
+          }
+          */
+
+          final int targetLabel = state.transitionMin;
+
+          if ((termBytes[termOffset+stateUpto] & 0xFF) < targetLabel) {
+            // if (DEBUG) {
+            //   System.out.println("    do bin search");
+            // }
+            //int startTermOrd = termOrd;
+            int low = termOrd+1;
+            int high = state.changeOrd-1;
+            while (true) {
+              if (low > high) {
+                // Label not found
+                termOrd = low;
+                // if (DEBUG) {
+                //   System.out.println("      advanced by " + (termOrd - startTermOrd));
+                // }
+                //System.out.println("  jump " + (termOrd - startTermOrd));
+                skipUpto = 0;
+                continue nextTerm;
+              }
+              int mid = (low + high) >>> 1;
+              int cmp = (termBytes[termOffsets[mid] + stateUpto] & 0xFF) - targetLabel;
+              // if (DEBUG) {
+              //   System.out.println("      bin: check label=" + (char) (termBytes[termOffsets[low] + stateUpto] & 0xFF) + " ord=" + mid);
+              // }
+              if (cmp < 0) {
+                low = mid+1;
+              } else if (cmp > 0) {
+                high = mid - 1;
+              } else {
+                // Label found; walk backwards to first
+                // occurrence:
+                while (mid > termOrd && (termBytes[termOffsets[mid-1] + stateUpto] & 0xFF) == targetLabel) {
+                  mid--;
+                }
+                termOrd = mid;
+                // if (DEBUG) {
+                //   System.out.println("      advanced by " + (termOrd - startTermOrd));
+                // }
+                //System.out.println("  jump " + (termOrd - startTermOrd));
+                skipUpto = 0;
+                continue nextTerm;
+              }
+            }
+          }
+
+          int nextState = runAutomaton.step(states[stateUpto].state, label);
+
+          if (nextState == -1) {
+            // Skip
+            // if (DEBUG) {
+            //   System.out.println("  automaton doesn't accept; skip");
+            // }
+            if (skipUpto < numSkips) {
+              // if (DEBUG) {
+              //   System.out.println("  jump " + (skips[skipOffset+skipUpto]-1 - termOrd));
+              // }
+              termOrd = skips[skipOffset+skipUpto];
+            } else {
+              termOrd++;
+            }
+            skipUpto = 0;
+          } else if (skipUpto < numSkips) {
+            // Push:
+            // if (DEBUG) {
+            //   System.out.println("  push");
+            // }
+            /*
+            if (DEBUG) {
+              try {
+                //System.out.println("    prefix push " + new BytesRef(term, 0, stateUpto+1).utf8ToString());
+                System.out.println("    prefix push " + new BytesRef(term, 0, stateUpto+1));
+              } catch (ArrayIndexOutOfBoundsException aioobe) {
+                System.out.println("    prefix push " + new BytesRef(term, 0, stateUpto+1));
+              }
+            }
+            */
+
+            grow();
+            stateUpto++;
+            states[stateUpto].state = nextState;
+            states[stateUpto].changeOrd = skips[skipOffset + skipUpto++];
+            states[stateUpto].transitions = compiledAutomaton.sortedTransitions[nextState];
+            states[stateUpto].transitionUpto = -1;
+            states[stateUpto].transitionMax = -1;
+            
+            if (stateUpto == termLength) {
+              // if (DEBUG) {
+              //   System.out.println("  term ends after push");
+              // }
+              if (runAutomaton.isAccept(nextState)) {
+                // if (DEBUG) {
+                //   System.out.println("  automaton accepts: return");
+                // }
+                scratch.bytes = termBytes;
+                scratch.offset = termOffsets[termOrd];
+                scratch.length = termOffsets[1+termOrd] - scratch.offset;
+                // if (DEBUG) {
+                //   System.out.println("  ret " + scratch.utf8ToString());
+                // }
+                return scratch;
+              } else {
+                // if (DEBUG) {
+                //   System.out.println("  automaton rejects: nextTerm");
+                // }
+                termOrd++;
+                skipUpto = 0;
+              }
+            }
+          } else {
+            // Run the non-indexed tail of this term:
+
+            // TODO: add Debug.Assert( that we don't inc too many times
+
+            if (compiledAutomaton.commonSuffixRef != null) {
+              //System.out.println("suffix " + compiledAutomaton.commonSuffixRef.utf8ToString());
+              Debug.Assert( compiledAutomaton.commonSuffixRef.offset == 0;
+              if (termLength < compiledAutomaton.commonSuffixRef.length) {
+                termOrd++;
+                skipUpto = 0;
+                continue nextTerm;
+              }
+              int offset = termOffset + termLength - compiledAutomaton.commonSuffixRef.length;
+              for(int suffix=0;suffix<compiledAutomaton.commonSuffixRef.length;suffix++) {
+                if (termBytes[offset + suffix] != compiledAutomaton.commonSuffixRef.bytes[suffix]) {
+                  termOrd++;
+                  skipUpto = 0;
+                  continue nextTerm;
+                }
+              }
+            }
+
+            int upto = stateUpto+1;
+            while (upto < termLength) {
+              nextState = runAutomaton.step(nextState, termBytes[termOffset+upto] & 0xFF);
+              if (nextState == -1) {
+                termOrd++;
+                skipUpto = 0;
+                // if (DEBUG) {
+                //   System.out.println("  nomatch tail; next term");
+                // }
+                continue nextTerm;
+              }
+              upto++;
+            }
+
+            if (runAutomaton.isAccept(nextState)) {
+              scratch.bytes = termBytes;
+              scratch.offset = termOffsets[termOrd];
+              scratch.length = termOffsets[1+termOrd] - scratch.offset;
+              // if (DEBUG) {
+              //   System.out.println("  match tail; return " + scratch.utf8ToString());
+              //   System.out.println("  ret2 " + scratch.utf8ToString());
+              // }
+              return scratch;
+            } else {
+              termOrd++;
+              skipUpto = 0;
+              // if (DEBUG) {
+              //   System.out.println("  nomatch tail; next term");
+              // }
+            }
+          }
+        }
+      }
+
+      @Override
+      public TermState termState() {
+        OrdTermState state = new OrdTermState();
+        state.ord = termOrd;
+        return state;
+      }
+
+      @Override
+      public BytesRef term() {
+        return scratch;
+      }
+
+      @Override
+      public long ord() {
+        return termOrd;
+      }
+
+      @Override
+      public int docFreq() {
+        if (terms[termOrd] instanceof LowFreqTerm) {
+          return ((LowFreqTerm) terms[termOrd]).docFreq;
+        } else {
+          return ((HighFreqTerm) terms[termOrd]).docIDs.length;
+        }
+      }
+
+      @Override
+      public long totalTermFreq() {
+        if (terms[termOrd] instanceof LowFreqTerm) {
+          return ((LowFreqTerm) terms[termOrd]).totalTermFreq;
+        } else {
+          return ((HighFreqTerm) terms[termOrd]).totalTermFreq;
+        }
+      }
+
+      @Override
+      public DocsEnum docs(Bits liveDocs, DocsEnum reuse, int flags) {
+        // TODO: implement reuse, something like Pulsing:
+        // it's hairy!
+
+        if (terms[termOrd] instanceof LowFreqTerm) {
+          final int[] postings = ((LowFreqTerm) terms[termOrd]).postings;
+          if (hasFreq) {
+            if (hasPos) {
+              int posLen;
+              if (hasOffsets) {
+                posLen = 3;
+              } else {
+                posLen = 1;
+              }
+              if (hasPayloads) {
+                posLen++;
+              }
+              return new LowFreqDocsEnum(liveDocs, posLen).reset(postings);
+            } else {
+              return new LowFreqDocsEnumNoPos(liveDocs).reset(postings);
+            }
+          } else {
+            return new LowFreqDocsEnumNoTF(liveDocs).reset(postings);
+          }
+        } else {
+          final HighFreqTerm term = (HighFreqTerm) terms[termOrd];
+          //  System.out.println("DE for term=" + new BytesRef(terms[termOrd].term).utf8ToString() + ": " + term.docIDs.length + " docs");
+          return new HighFreqDocsEnum(liveDocs).reset(term.docIDs, term.freqs);
+        }
+      }
+
+      @Override
+      public DocsAndPositionsEnum docsAndPositions(Bits liveDocs, DocsAndPositionsEnum reuse, int flags) {
+        if (!hasPos) {
+          return null;
+        }
+
+        // TODO: implement reuse, something like Pulsing:
+        // it's hairy!
+
+        if (terms[termOrd] instanceof LowFreqTerm) {
+          final LowFreqTerm term = ((LowFreqTerm) terms[termOrd]);
+          final int[] postings = term.postings;
+          final byte[] payloads = term.payloads;
+          return new LowFreqDocsAndPositionsEnum(liveDocs, hasOffsets, hasPayloads).reset(postings, payloads);
+        } else {
+          final HighFreqTerm term = (HighFreqTerm) terms[termOrd];
+          return new HighFreqDocsAndPositionsEnum(liveDocs, hasOffsets).reset(term.docIDs, term.freqs, term.positions, term.payloads);
+        }
+      }
+
+      @Override
+      public SeekStatus seekCeil(BytesRef term) {
+        throw new UnsupportedOperationException();
+      }
+
+      @Override
+      public void seekExact(long ord) {
+        throw new UnsupportedOperationException();
+      }
+    }
+  }
+
+  // Docs only:
+  private final static class LowFreqDocsEnumNoTF extends DocsEnum {
+    private int[] postings;
+    private final Bits liveDocs;
+    private int upto;
+
+    public LowFreqDocsEnumNoTF(Bits liveDocs) {
+      this.liveDocs = liveDocs;
+    }
+
+    public bool canReuse(Bits liveDocs) {
+      return liveDocs == this.liveDocs;
+    }
+
+    public DocsEnum reset(int[] postings) {
+      this.postings = postings;
+      upto = -1;
+      return this;
+    }
+
+    // TODO: can do this w/o setting members?
+
+    @Override
+    public int nextDoc() {
+      upto++;
+      if (liveDocs == null) {
+        if (upto < postings.length) {
+          return postings[upto];
+        }
+      } else {
+        while (upto < postings.length) {
+          if (liveDocs.get(postings[upto])) {
+            return postings[upto];
+          }
+          upto++;
+        }
+      }
+      return NO_MORE_DOCS;
+    }
+
+    @Override
+    public int docID() {
+      if (upto < 0) {
+        return -1;
+      } else if (upto < postings.length) {
+        return postings[upto];
+      } else {
+        return NO_MORE_DOCS;
+      }
+    }
+
+    @Override
+    public int freq() {
+      return 1;
+    }
+
+    @Override
+    public int advance(int target)  {
+      // Linear scan, but this is low-freq term so it won't
+      // be costly:
+      return slowAdvance(target);
+    }
+    
+    @Override
+    public long cost() {
+      return postings.length;
+    }
+  }
+
+  // Docs + freqs:
+  private final static class LowFreqDocsEnumNoPos extends DocsEnum {
+    private int[] postings;
+    private final Bits liveDocs;
+    private int upto;
+
+    public LowFreqDocsEnumNoPos(Bits liveDocs) {
+      this.liveDocs = liveDocs;
+    }
+
+    public bool canReuse(Bits liveDocs) {
+      return liveDocs == this.liveDocs;
+    }
+
+    public DocsEnum reset(int[] postings) {
+      this.postings = postings;
+      upto = -2;
+      return this;
+    }
+
+    // TODO: can do this w/o setting members?
+    @Override
+    public int nextDoc() {
+      upto += 2;
+      if (liveDocs == null) {
+        if (upto < postings.length) {
+          return postings[upto];
+        }
+      } else {
+        while (upto < postings.length) {
+          if (liveDocs.get(postings[upto])) {
+            return postings[upto];
+          }
+          upto += 2;
+        }
+      }
+      return NO_MORE_DOCS;
+    }
+
+    @Override
+    public int docID() {
+      if (upto < 0) {
+        return -1;
+      } else if (upto < postings.length) {
+        return postings[upto];
+      } else {
+        return NO_MORE_DOCS;
+      }
+    }
+
+    @Override
+    public int freq() {
+      return postings[upto+1];
+    }
+
+    @Override
+    public int advance(int target)  {
+      // Linear scan, but this is low-freq term so it won't
+      // be costly:
+      return slowAdvance(target);
+    }
+    
+    @Override
+    public long cost() {
+      return postings.length / 2;
+    }
+  }
+
+  // Docs + freqs + positions/offets:
+  private final static class LowFreqDocsEnum extends DocsEnum {
+    private int[] postings;
+    private final Bits liveDocs;
+    private final int posMult;
+    private int upto;
+    private int freq;
+
+    public LowFreqDocsEnum(Bits liveDocs, int posMult) {
+      this.liveDocs = liveDocs;
+      this.posMult = posMult;
+      // if (DEBUG) {
+      //   System.out.println("LowFreqDE: posMult=" + posMult);
+      // }
+    }
+
+    public bool canReuse(Bits liveDocs, int posMult) {
+      return liveDocs == this.liveDocs && posMult == this.posMult;
+    }
+
+    public DocsEnum reset(int[] postings) {
+      this.postings = postings;
+      upto = -2;
+      freq = 0;
+      return this;
+    }
+
+    // TODO: can do this w/o setting members?
+    @Override
+    public int nextDoc() {
+      upto += 2 + freq*posMult;
+      // if (DEBUG) {
+      //   System.out.println("  nextDoc freq=" + freq + " upto=" + upto + " vs " + postings.length);
+      // }
+      if (liveDocs == null) {
+        if (upto < postings.length) {   
+          freq = postings[upto+1];
+          Debug.Assert( freq > 0;
+          return postings[upto];
+        }
+      } else {
+        while (upto < postings.length) {
+          freq = postings[upto+1];
+          Debug.Assert( freq > 0;
+          if (liveDocs.get(postings[upto])) {
+            return postings[upto];
+          }
+          upto += 2 + freq*posMult;
+        }
+      }
+      return NO_MORE_DOCS;
+    }
+
+    @Override
+    public int docID() {
+      // TODO: store docID member?
+      if (upto < 0) {
+        return -1;
+      } else if (upto < postings.length) {
+        return postings[upto];
+      } else {
+        return NO_MORE_DOCS;
+      }
+    }
+
+    @Override
+    public int freq() {
+      // TODO: can I do postings[upto+1]?
+      return freq;
+    }
+
+    @Override
+    public int advance(int target)  {
+      // Linear scan, but this is low-freq term so it won't
+      // be costly:
+      return slowAdvance(target);
+    }
+    
+    @Override
+    public long cost() {
+      // TODO: could do a better estimate
+      return postings.length / 2;
+    }
+  }
+
+  private final static class LowFreqDocsAndPositionsEnum extends DocsAndPositionsEnum {
+    private int[] postings;
+    private final Bits liveDocs;
+    private final int posMult;
+    private final bool hasOffsets;
+    private final bool hasPayloads;
+    private final BytesRef payload = new BytesRef();
+    private int upto;
+    private int docID;
+    private int freq;
+    private int skipPositions;
+    private int startOffset;
+    private int endOffset;
+    private int lastPayloadOffset;
+    private int payloadOffset;
+    private int payloadLength;
+    private byte[] payloadBytes;
+
+    public LowFreqDocsAndPositionsEnum(Bits liveDocs, bool hasOffsets, bool hasPayloads) {
+      this.liveDocs = liveDocs;
+      this.hasOffsets = hasOffsets;
+      this.hasPayloads = hasPayloads;
+      if (hasOffsets) {
+        if (hasPayloads) {
+          posMult = 4;
+        } else {
+          posMult = 3;
+        }
+      } else if (hasPayloads) {
+        posMult = 2;
+      } else {
+        posMult = 1;
+      }
+    }
+
+    public DocsAndPositionsEnum reset(int[] postings, byte[] payloadBytes) {
+      this.postings = postings;
+      upto = 0;
+      skipPositions = 0;
+      startOffset = -1;
+      endOffset = -1;
+      docID = -1;
+      payloadLength = 0;
+      this.payloadBytes = payloadBytes;
+      return this;
+    }
+
+    @Override
+    public int nextDoc() {
+      if (hasPayloads) {
+        for(int i=0;i<skipPositions;i++) {
+          upto++;
+          if (hasOffsets) {
+            upto += 2;
+          }
+          payloadOffset += postings[upto++];
+        }
+      } else {
+        upto += posMult * skipPositions;
+      }
+
+      if (liveDocs == null) {
+        if (upto < postings.length) {
+          docID = postings[upto++];
+          freq = postings[upto++];
+          skipPositions = freq;
+          return docID;
+        }
+      } else {
+        while(upto < postings.length) {
+          docID = postings[upto++];
+          freq = postings[upto++];
+          if (liveDocs.get(docID)) {
+            skipPositions = freq;
+            return docID;
+          }
+          if (hasPayloads) {
+            for(int i=0;i<freq;i++) {
+              upto++;
+              if (hasOffsets) {
+                upto += 2;
+              }
+              payloadOffset += postings[upto++];
+            }
+          } else {
+            upto += posMult * freq;
+          }
+        }
+      }
+
+      return docID = NO_MORE_DOCS;
+    }
+
+    @Override
+    public int docID() {
+      return docID;
+    }
+
+    @Override
+    public int freq() {
+      return freq;
+    }
+
+    @Override
+    public int nextPosition() {
+      Debug.Assert( skipPositions > 0;
+      skipPositions--;
+      final int pos = postings[upto++];
+      if (hasOffsets) {
+        startOffset = postings[upto++];
+        endOffset = postings[upto++];
+      }
+      if (hasPayloads) {
+        payloadLength = postings[upto++];
+        lastPayloadOffset = payloadOffset;
+        payloadOffset += payloadLength;
+      }
+      return pos;
+    }
+
+    @Override
+    public int startOffset() {
+      return startOffset;
+    }
+
+    @Override
+    public int endOffset() {
+      return endOffset;
+    }
+
+    @Override
+    public int advance(int target)  {
+      return slowAdvance(target);
+    }
+
+    @Override
+    public BytesRef getPayload() {
+      if (payloadLength > 0) {
+        payload.bytes = payloadBytes;
+        payload.offset = lastPayloadOffset;
+        payload.length = payloadLength;
+        return payload;
+      } else {
+        return null;
+      }
+    }
+    
+    @Override
+    public long cost() {
+      // TODO: could do a better estimate
+      return postings.length / 2;
+    }
+  }
+
+  // Docs + freqs:
+  private final static class HighFreqDocsEnum extends DocsEnum {
+    private int[] docIDs;
+    private int[] freqs;
+    private final Bits liveDocs;
+    private int upto;
+    private int docID = -1;
+
+    public HighFreqDocsEnum(Bits liveDocs) {
+      this.liveDocs = liveDocs;
+    }
+
+    public bool canReuse(Bits liveDocs) {
+      return liveDocs == this.liveDocs;
+    }
+
+    public int[] getDocIDs() {
+      return docIDs;
+    }
+
+    public int[] getFreqs() {
+      return freqs;
+    }
+
+    public DocsEnum reset(int[] docIDs, int[] freqs) {
+      this.docIDs = docIDs;
+      this.freqs = freqs;
+      docID = upto = -1;
+      return this;
+    }
+
+    @Override
+    public int nextDoc() {
+      upto++;
+      if (liveDocs == null) {
+        try {
+          return docID = docIDs[upto];
+        } catch (ArrayIndexOutOfBoundsException e) {
+        }
+      } else {
+        while (upto < docIDs.length) {
+          if (liveDocs.get(docIDs[upto])) {
+            return docID = docIDs[upto];
+          }
+          upto++;
+        }
+      }
+      return docID = NO_MORE_DOCS;
+    }
+
+    @Override
+    public int docID() {
+      return docID;
+    }
+
+    @Override
+    public int freq() {
+      if (freqs == null) {
+        return 1;
+      } else {
+        return freqs[upto];
+      }
+    }
+
+    @Override
+    public int advance(int target) {
+      /*
+      upto++;
+      if (upto == docIDs.length) {
+        return docID = NO_MORE_DOCS;
+      }
+      final int index = Arrays.binarySearch(docIDs, upto, docIDs.length, target);
+      if (index < 0) {
+        upto = -index - 1;
+      } else {
+        upto = index;
+      }
+      if (liveDocs != null) {
+        while (upto < docIDs.length) {
+          if (liveDocs.get(docIDs[upto])) {
+            break;
+          }
+          upto++;
+        }
+      }
+      if (upto == docIDs.length) {
+        return NO_MORE_DOCS;
+      } else {
+        return docID = docIDs[upto];
+      }
+      */
+
+      //System.out.println("  advance target=" + target + " cur=" + docID() + " upto=" + upto + " of " + docIDs.length);
+      // if (DEBUG) {
+      //   System.out.println("advance target=" + target + " len=" + docIDs.length);
+      // }
+      upto++;
+      if (upto == docIDs.length) {
+        return docID = NO_MORE_DOCS;
+      }
+
+      // First "grow" outwards, since most advances are to
+      // nearby docs:
+      int inc = 10;
+      int nextUpto = upto+10;
+      int low;
+      int high;
+      while (true) {
+        //System.out.println("  grow nextUpto=" + nextUpto + " inc=" + inc);
+        if (nextUpto >= docIDs.length) {
+          low = nextUpto-inc;
+          high = docIDs.length-1;
+          break;
+        }
+        //System.out.println("    docID=" + docIDs[nextUpto]);
+
+        if (target <= docIDs[nextUpto]) {
+          low = nextUpto-inc;
+          high = nextUpto;
+          break;
+        }
+        inc *= 2;
+        nextUpto += inc;
+      }
+
+      // Now do normal binary search
+      //System.out.println("    after fwd: low=" + low + " high=" + high);
+
+      while (true) {
+
+        if (low > high) {
+          // Not exactly found
+          //System.out.println("    break: no match");
+          upto = low;
+          break;
+        }
+
+        int mid = (low + high) >>> 1;
+        int cmp = docIDs[mid] - target;
+        //System.out.println("    bsearch low=" + low + " high=" + high+ ": docIDs[" + mid + "]=" + docIDs[mid]);
+
+        if (cmp < 0) {
+          low = mid + 1;
+        } else if (cmp > 0) {
+          high = mid - 1;
+        } else {
+          // Found target
+          upto = mid;
+          //System.out.println("    break: match");
+          break;
+        }
+      }
+
+      //System.out.println("    end upto=" + upto + " docID=" + (upto >= docIDs.length ? NO_MORE_DOCS : docIDs[upto]));
+
+      if (liveDocs != null) {
+        while (upto < docIDs.length) {
+          if (liveDocs.get(docIDs[upto])) {
+            break;
+          }
+          upto++;
+        }
+      }
+      if (upto == docIDs.length) {
+        //System.out.println("    return END");
+        return docID = NO_MORE_DOCS;
+      } else {
+        //System.out.println("    return docID=" + docIDs[upto] + " upto=" + upto);
+        return docID = docIDs[upto];
+      }
+    }
+    
+    @Override
+    public long cost() {
+      return docIDs.length;
+    }
+  }
+
+  // TODO: specialize offsets and not
+  private final static class HighFreqDocsAndPositionsEnum extends DocsAndPositionsEnum {
+    private int[] docIDs;
+    private int[] freqs;
+    private int[][] positions;
+    private byte[][][] payloads;
+    private final Bits liveDocs;
+    private final bool hasOffsets;
+    private final int posJump;
+    private int upto;
+    private int docID = -1;
+    private int posUpto;
+    private int[] curPositions;
+
+    public HighFreqDocsAndPositionsEnum(Bits liveDocs, bool hasOffsets) {
+      this.liveDocs = liveDocs;
+      this.hasOffsets = hasOffsets;
+      posJump = hasOffsets ? 3 : 1;
+    }
+
+    public int[] getDocIDs() {
+      return docIDs;
+    }
+
+    public int[][] getPositions() {
+      return positions;
+    }
+
+    public int getPosJump() {
+      return posJump;
+    }
+
+    public Bits getLiveDocs() {
+      return liveDocs;
+    }
+
+    public DocsAndPositionsEnum reset(int[] docIDs, int[] freqs, int[][] positions, byte[][][] payloads) {
+      this.docIDs = docIDs;
+      this.freqs = freqs;
+      this.positions = positions;
+      this.payloads = payloads;
+      upto = -1;
+      return this;
+    }
+
+    @Override
+    public int nextDoc() {
+      upto++;
+      if (liveDocs == null) {
+        if (upto < docIDs.length) {
+          posUpto = -posJump;   
+          curPositions = positions[upto];
+          return docID = docIDs[upto];
+        }
+      } else {
+        while (upto < docIDs.length) {
+          if (liveDocs.get(docIDs[upto])) {
+            posUpto = -posJump;
+            curPositions = positions[upto];
+            return docID = docIDs[upto];
+          }
+          upto++;
+        }
+      }
+
+      return docID = NO_MORE_DOCS;
+    }
+
+    @Override
+    public int freq() {
+      return freqs[upto];
+    }
+
+    @Override
+    public int docID() {
+      return docID;
+    }
+
+    @Override
+    public int nextPosition() {
+      posUpto += posJump;
+      return curPositions[posUpto];
+    }
+
+    @Override
+    public int startOffset() {
+      if (hasOffsets) {
+        return curPositions[posUpto+1];
+      } else {
+        return -1;
+      }
+    }
+
+    @Override
+    public int endOffset() {
+      if (hasOffsets) {
+        return curPositions[posUpto+2];
+      } else {
+        return -1;
+      }
+    }
+
+    @Override
+    public int advance(int target) {
+
+      /*
+      upto++;
+      if (upto == docIDs.length) {
+        return NO_MORE_DOCS;
+      }
+      final int index = Arrays.binarySearch(docIDs, upto, docIDs.length, target);
+      if (index < 0) {
+        upto = -index - 1;
+      } else {
+        upto = index;
+      }
+      if (liveDocs != null) {
+        while (upto < docIDs.length) {
+          if (liveDocs.get(docIDs[upto])) {
+            break;
+          }
+          upto++;
+        }
+      }
+      posUpto = hasOffsets ? -3 : -1;
+      if (upto == docIDs.length) {
+        return NO_MORE_DOCS;
+      } else {
+        return docID();
+      }
+      */
+
+      //System.out.println("  advance target=" + target + " cur=" + docID() + " upto=" + upto + " of " + docIDs.length);
+      // if (DEBUG) {
+      //   System.out.println("advance target=" + target + " len=" + docIDs.length);
+      // }
+      upto++;
+      if (upto == docIDs.length) {
+        return docID = NO_MORE_DOCS;
+      }
+
+      // First "grow" outwards, since most advances are to
+      // nearby docs:
+      int inc = 10;
+      int nextUpto = upto+10;
+      int low;
+      int high;
+      while (true) {
+        //System.out.println("  grow nextUpto=" + nextUpto + " inc=" + inc);
+        if (nextUpto >= docIDs.length) {
+          low = nextUpto-inc;
+          high = docIDs.length-1;
+          break;
+        }
+        //System.out.println("    docID=" + docIDs[nextUpto]);
+
+        if (target <= docIDs[nextUpto]) {
+          low = nextUpto-inc;
+          high = nextUpto;
+          break;
+        }
+        inc *= 2;
+        nextUpto += inc;
+      }
+
+      // Now do normal binary search
+      //System.out.println("    after fwd: low=" + low + " high=" + high);
+
+      while (true) {
+
+        if (low > high) {
+          // Not exactly found
+          //System.out.println("    break: no match");
+          upto = low;
+          break;
+        }
+
+        int mid = (low + high) >>> 1;
+        int cmp = docIDs[mid] - target;
+        //System.out.println("    bsearch low=" + low + " high=" + high+ ": docIDs[" + mid + "]=" + docIDs[mid]);
+
+        if (cmp < 0) {
+          low = mid + 1;
+        } else if (cmp > 0) {
+          high = mid - 1;
+        } else {
+          // Found target
+          upto = mid;
+          //System.out.println("    break: match");
+          break;
+        }
+      }
+
+      //System.out.println("    end upto=" + upto + " docID=" + (upto >= docIDs.length ? NO_MORE_DOCS : docIDs[upto]));
+
+      if (liveDocs != null) {
+        while (upto < docIDs.length) {
+          if (liveDocs.get(docIDs[upto])) {
+            break;
+          }
+          upto++;
+        }
+      }
+      if (upto == docIDs.length) {
+        //System.out.println("    return END");
+        return docID = NO_MORE_DOCS;
+      } else {
+        //System.out.println("    return docID=" + docIDs[upto] + " upto=" + upto);
+        posUpto = -posJump;
+        curPositions = positions[upto];
+        return docID = docIDs[upto];
+      }
+    }
+
+    private final BytesRef payload = new BytesRef();
+
+    @Override
+    public BytesRef getPayload() {
+      if (payloads == null) {
+        return null;
+      } else {
+        final byte[] payloadBytes = payloads[upto][posUpto/(hasOffsets ? 3:1)];
+        if (payloadBytes == null) {
+          return null;
+        }
+        payload.bytes = payloadBytes;
+        payload.length = payloadBytes.length;
+        payload.offset = 0;
+        return payload;
+      }
+    }
+    
+    @Override
+    public long cost() {
+      return docIDs.length;
+    }
+  }
+}

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/src/Lucene.Net.Codecs/Memory/FSTOrdPostingsFormat.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Codecs/Memory/FSTOrdPostingsFormat.cs b/src/Lucene.Net.Codecs/Memory/FSTOrdPostingsFormat.cs
new file mode 100644
index 0000000..d8be831
--- /dev/null
+++ b/src/Lucene.Net.Codecs/Memory/FSTOrdPostingsFormat.cs
@@ -0,0 +1,83 @@
+package org.apache.lucene.codecs.memory;
+
+
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+import java.io.IOException;
+
+import org.apache.lucene.codecs.FieldsConsumer;
+import org.apache.lucene.codecs.FieldsProducer;
+import org.apache.lucene.codecs.PostingsFormat;
+import org.apache.lucene.codecs.PostingsReaderBase;
+import org.apache.lucene.codecs.PostingsWriterBase;
+import org.apache.lucene.codecs.lucene41.Lucene41PostingsWriter;
+import org.apache.lucene.codecs.lucene41.Lucene41PostingsReader;
+import org.apache.lucene.index.FieldInfo.IndexOptions;
+import org.apache.lucene.index.SegmentReadState;
+import org.apache.lucene.index.SegmentWriteState;
+import org.apache.lucene.util.IOUtils;
+
+/** 
+ * FSTOrd term dict + Lucene41PBF
+ */
+
+public final class FSTOrdPostingsFormat extends PostingsFormat {
+  public FSTOrdPostingsFormat() {
+    super("FSTOrd41");
+  }
+
+  @Override
+  public String toString() {
+    return getName();
+  }
+
+  @Override
+  public FieldsConsumer fieldsConsumer(SegmentWriteState state)  {
+    PostingsWriterBase postingsWriter = new Lucene41PostingsWriter(state);
+
+    bool success = false;
+    try {
+      FieldsConsumer ret = new FSTOrdTermsWriter(state, postingsWriter);
+      success = true;
+      return ret;
+    } finally {
+      if (!success) {
+        IOUtils.closeWhileHandlingException(postingsWriter);
+      }
+    }
+  }
+
+  @Override
+  public FieldsProducer fieldsProducer(SegmentReadState state)  {
+    PostingsReaderBase postingsReader = new Lucene41PostingsReader(state.directory,
+                                                                state.fieldInfos,
+                                                                state.segmentInfo,
+                                                                state.context,
+                                                                state.segmentSuffix);
+    bool success = false;
+    try {
+      FieldsProducer ret = new FSTOrdTermsReader(state, postingsReader);
+      success = true;
+      return ret;
+    } finally {
+      if (!success) {
+        IOUtils.closeWhileHandlingException(postingsReader);
+      }
+    }
+  }
+}

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/src/Lucene.Net.Codecs/Memory/FSTOrdPulsing41PostingsFormat.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Codecs/Memory/FSTOrdPulsing41PostingsFormat.cs b/src/Lucene.Net.Codecs/Memory/FSTOrdPulsing41PostingsFormat.cs
new file mode 100644
index 0000000..257d2eb
--- /dev/null
+++ b/src/Lucene.Net.Codecs/Memory/FSTOrdPulsing41PostingsFormat.cs
@@ -0,0 +1,91 @@
+package org.apache.lucene.codecs.memory;
+
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+import java.io.IOException;
+
+import org.apache.lucene.codecs.FieldsConsumer;
+import org.apache.lucene.codecs.FieldsProducer;
+import org.apache.lucene.codecs.PostingsBaseFormat;
+import org.apache.lucene.codecs.PostingsFormat;
+import org.apache.lucene.codecs.PostingsReaderBase;
+import org.apache.lucene.codecs.PostingsWriterBase;
+import org.apache.lucene.codecs.lucene41.Lucene41PostingsWriter;
+import org.apache.lucene.codecs.lucene41.Lucene41PostingsReader;
+import org.apache.lucene.codecs.lucene41.Lucene41PostingsBaseFormat;
+import org.apache.lucene.codecs.lucene41.Lucene41PostingsFormat;
+import org.apache.lucene.codecs.pulsing.PulsingPostingsWriter;
+import org.apache.lucene.codecs.pulsing.PulsingPostingsReader;
+import org.apache.lucene.index.SegmentReadState;
+import org.apache.lucene.index.SegmentWriteState;
+import org.apache.lucene.util.IOUtils;
+
+/** FSTOrd + Pulsing41
+ *  @lucene.experimental */
+
+public class FSTOrdPulsing41PostingsFormat extends PostingsFormat {
+  private final PostingsBaseFormat wrappedPostingsBaseFormat;
+  private final int freqCutoff;
+
+  public FSTOrdPulsing41PostingsFormat() {
+    this(1);
+  }
+  
+  public FSTOrdPulsing41PostingsFormat(int freqCutoff) {
+    super("FSTOrdPulsing41");
+    this.wrappedPostingsBaseFormat = new Lucene41PostingsBaseFormat();
+    this.freqCutoff = freqCutoff;
+  }
+
+  @Override
+  public FieldsConsumer fieldsConsumer(SegmentWriteState state)  {
+    PostingsWriterBase docsWriter = null;
+    PostingsWriterBase pulsingWriter = null;
+
+    bool success = false;
+    try {
+      docsWriter = wrappedPostingsBaseFormat.postingsWriterBase(state);
+      pulsingWriter = new PulsingPostingsWriter(state, freqCutoff, docsWriter);
+      FieldsConsumer ret = new FSTOrdTermsWriter(state, pulsingWriter);
+      success = true;
+      return ret;
+    } finally {
+      if (!success) {
+        IOUtils.closeWhileHandlingException(docsWriter, pulsingWriter);
+      }
+    }
+  }
+
+  @Override
+  public FieldsProducer fieldsProducer(SegmentReadState state)  {
+    PostingsReaderBase docsReader = null;
+    PostingsReaderBase pulsingReader = null;
+    bool success = false;
+    try {
+      docsReader = wrappedPostingsBaseFormat.postingsReaderBase(state);
+      pulsingReader = new PulsingPostingsReader(state, docsReader);
+      FieldsProducer ret = new FSTOrdTermsReader(state, pulsingReader);
+      success = true;
+      return ret;
+    } finally {
+      if (!success) {
+        IOUtils.closeWhileHandlingException(docsReader, pulsingReader);
+      }
+    }
+  }
+}


[15/51] [abbrv] [partial] Cleaning up and getting ready to development towards v4.8

Posted by sy...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/runningTests.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/runningTests.html b/lib/NUnit.org/NUnit/2.5.9/doc/runningTests.html
deleted file mode 100644
index 1982cad..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/runningTests.html
+++ /dev/null
@@ -1,108 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - RunningTests</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h2>Running Tests</h2>
-
-<p>Nunit provides three different runners, which may be used to load and
-run your tests.
-
-<ul>
-<li>The <a href="nunit-console.html">console runner</a>, 
-    nunit-console.exe, is used for batch execution.
-<li>The <a href="nunit-gui.html">gui runner</a>, nunit.exe,
-    provides interactive loading and running of tests.
-<li>The <a href="pnunit.html">pNUnit runner</a>, 
-    pnunit-launcher.exe, is used to run parallel, distributed tests under the
-	control of pNUnit.
-</ul>
-
-<h3>NUnit Agent</h3>
-
-<p>When running tests in a separate process, the console and gui runners
-   make use of the <a href="nunit-agent.html">nunit-agent</a>   program, nunit-agent.exe. Although not directly run by users, nunit-agent
-   does load and execute tests and users need to be aware of it, especially
-   when debugging is involved.
-
-<h3>Third-Party Runners</h3>
-
-<p>Various third-party applications are available for loading and running
-   NUnit tests. Some of these actually use NUnit to load the tests, while
-   others provide their own emulation and may not work in the same way 
-   that NUnit does.
-   
-<p>Because the status of such projects may change from time to time, we don't
-   discuss them individually here. For the latest information, consult the 
-   manufacturer of any third-party software or ask other users on our
-   <a href="http://groups.google.com/group/nunit-discuss">discussion list</a>.
-   
-<h3>Additional Information</h3>
-
-<p>For additional general information on how tests are loaded and run, see
-
-<ul>
-<li><a href="runtimeSelection.html">Runtime Selection</a><li><a href="assemblyIsolation.html">Assembly Isolation</a><li><a href="configFiles.html">Configuration Files</a><li><a href="multiAssembly.html">Multiple Assemblies</a><li><a href="vsSupport.html">Visual Studio Support</a></ul>
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<li id="current"><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<ul>
-<li><a href="nunit-console.html">Console&nbsp;Runner</a></li>
-<li><a href="nunit-gui.html">Gui&nbsp;Runner</a></li>
-<li><a href="pnunit.html">PNUnit&nbsp;Runner</a></li>
-<li><a href="nunit-agent.html">NUnit&nbsp;Agent</a></li>
-<li><a href="runtimeSelection.html">Runtime&nbsp;Selection</a></li>
-<li><a href="assemblyIsolation.html">Assembly&nbsp;Isolation</a></li>
-<li><a href="configFiles.html">Configuration&nbsp;Files</a></li>
-<li><a href="multiAssembly.html">Multiple&nbsp;Assemblies</a></li>
-<li><a href="vsSupport.html">Visual&nbsp;Studio&nbsp;Support</a></li>
-</ul>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/runtimeSelection.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/runtimeSelection.html b/lib/NUnit.org/NUnit/2.5.9/doc/runtimeSelection.html
deleted file mode 100644
index 95a8a98..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/runtimeSelection.html
+++ /dev/null
@@ -1,121 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - RuntimeSelection</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h3>Runtime Selection</h3>
-
-<p>Before loading an assembly, NUnit must determine what runtime to use. By default
-(see below for exceptions) the following rules are used:
-
-<ol>
-<li><p>If the assembly was built for the same runtime under which NUnit is currently 
-running, then that runtime is used.
-
-<li><p>If the assembly was built for a different runtime version and that version 
-is available, NUnit uses it, running out of process if necessary. 
-
-<li><p>If the assembly was built for a different runtime version, which is not
-available, then the result depends on whether the build version is earlier or
-later than the current version. If earlier, the test will be run using the
-same runtime version under which NUnit is running. If later, then it is not
-possible to load the test and NUnit gives an error message.
-
-<li><p>If multiple assemblies are being run at the same time, NUnit first
-determines the runtime under which each assembly was built. The highest version 
-is then selected for the entire group, and rules 1 through 3 are applied.
-</ol>
-
-<p><b>Note:</b> For versions 2.5.4 and 2.5.5, automatic runtime selection only
-works in the Gui runner. Use the /framework option to select the appropriate
-runtime under the Console runner.
-
-<h3>Overriding the Defaults</h3>
-
-<p>The default runtime framework may be overridden using command line arguments, 
-   menu items in the Gui or settings in an NUnit project file. Provided that the 
-   requested framework is available, it will be used. If it isn't available, 
-   NUnit will issue an error message.
-   
-<p><b>Note:</b> To use version 1.x runtimes, you must have NUnit's support 
-   for those runtimes installed, in addition to the runtime itself. This
-   support is an option of the NUnit installation.
-
-<h4>Command Line Options</h4>
-
-<p>The <b>/framework</b> option of console runner allows you to specify
-   the framework type and version to be used for a test run. See
-   <a href="consoleCommandLine.html">NUnit-Console Command Line Options</a>   for more information.
-   
-<h4>Gui Menu Selection</h4>
-
-<p>The main menu provides <b>File | Select Runtime</b> sub-items allowing you
-   to reload the tests under a specific runtime. See 
-   <a href="mainMenu.html">Main Menu</a> for more info.
-   
-<h4>Project Settings</h4>
-
-<p>The NUnit project format supports specification of a specific runtime to
-   be used with a project at the configuration level. See
-   <a href="projectEditor.html">Project Editor</a>   for more information.
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<ul>
-<li><a href="nunit-console.html">Console&nbsp;Runner</a></li>
-<li><a href="nunit-gui.html">Gui&nbsp;Runner</a></li>
-<li><a href="pnunit.html">PNUnit&nbsp;Runner</a></li>
-<li id="current"><a href="runtimeSelection.html">Runtime&nbsp;Selection</a></li>
-<li><a href="assemblyIsolation.html">Assembly&nbsp;Isolation</a></li>
-<li><a href="configFiles.html">Configuration&nbsp;Files</a></li>
-<li><a href="multiAssembly.html">Multiple&nbsp;Assemblies</a></li>
-<li><a href="vsSupport.html">Visual&nbsp;Studio&nbsp;Support</a></li>
-</ul>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/sameasConstraint.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/sameasConstraint.html b/lib/NUnit.org/NUnit/2.5.9/doc/sameasConstraint.html
deleted file mode 100644
index 6eed701..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/sameasConstraint.html
+++ /dev/null
@@ -1,100 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - SameasConstraint</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h2>Same As Constraint (NUnit 2.4)</h2>
-
-<p>A SameAsConstraint is used to test whether the object passed
-   as an actual value has the same identity as the object supplied
-   in its constructor.
-
-<h4>Constructor</h4>
-
-<div class="code"><pre>
-SameAsConstraint( object expected )
-</pre></div>
-
-<h4>Syntax</h4>
-
-<div class="code"><pre>
-Is.SameAs( object expected )
-</pre></div>
-
-<h4>Examples of Use</h4>
-
-<div class="code"><pre>
-Exception ex1 = new Exception();
-Exception ex2 = ex1;
-Assert.That( ex2, Is.SameAs( ex1 ) );
-
-Exception ex3 = new Exception();
-Assert.That( ex3, Is.Not.SameAs( ex1 ) );
-</pre></div>
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<ul>
-<li><a href="equalConstraint.html">Equal&nbsp;Constraint</a></li>
-<li id="current"><a href="sameasConstraint.html">SameAs&nbsp;Constraint</a></li>
-<li><a href="conditionConstraints.html">Condition&nbsp;Constraints</a></li>
-<li><a href="comparisonConstraints.html">Comparison&nbsp;Constrants</a></li>
-<li><a href="pathConstraints.html">Path&nbsp;Constraints</a></li>
-<li><a href="typeConstraints.html">Type&nbsp;Constraints</a></li>
-<li><a href="stringConstraints.html">String&nbsp;Constraints</a></li>
-<li><a href="collectionConstraints.html">Collection&nbsp;Constraints</a></li>
-<li><a href="propertyConstraint.html">Property&nbsp;Constraint</a></li>
-<li><a href="throwsConstraint.html">Throws&nbsp;Constraint</a></li>
-<li><a href="compoundConstraints.html">Compound&nbsp;Constraints</a></li>
-<li><a href="delayedConstraint.html">Delayed&nbsp;Constraint</a></li>
-<li><a href="listMapper.html">List&nbsp;Mapper</a></li>
-<li><a href="reusableConstraint.html">Reusable&nbsp;Constraint</a></li>
-</ul>
-<li><a href="attributes.html">Attributes</a></li>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/samples.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/samples.html b/lib/NUnit.org/NUnit/2.5.9/doc/samples.html
deleted file mode 100644
index 24e3aa9..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/samples.html
+++ /dev/null
@@ -1,124 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - Samples</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<style><!--
-dt { font-weight: bold; }
---></style>
-<h2>Samples</h2>
-
-NUnit 2.5 samples continue to be organized by language, with an additional 
-folder for Extensibility examples. The 'money-port' example has been
-removed.
-
-<h3>C# Samples</h3>
-<dl>
-	<dt>Failures
-	<dd>This sample written in C# demonstrates 4 failing unit tests and one test 
-		that is not run.
-	<dt>Money
-	<dd>This is a C# version of the money example which is found in most xUnit 
-		implementations. Thanks to Kent Beck.
-</dl>
-
-<h3>J# Samples</h3>
-<dl>
-	<dt>Failures
-	<dd>This has three failing tests and one ignored test written in J#.
-</dl>
-
-<h3>VB.NET Samples</h3>
-<dl>
-	<dt>Failures
-	<dd>This sample written in VB.NET demonstrates 4 failing unit tests and 
-		one test that is not run.
-	<dt>Money
-	<dd>This is a VB.NET version of the money example which is found in most xUnit 
-		implementations. Thanks to Kent Beck.
-</dl>
-
-<h3>Managed C++ Samples</h3>
-<dl>
-	<dt>Failures
-	<dd>This is the same example as the others with four failing unit 
-		tests and one ignored test.&nbsp;NOTE:&nbsp; The results are as expected when 
-		compiled in Debug mode. In Release mode the divide by zero test succeeds.
-</dl>
-
-<h3>C++/CLI Samples</h3>
-<dl>
-	<dt>Failures
-	<dd>This is the same example as the others with four failing unit 
-		tests and one ignored test.
-</dl>
-
-<h3>Extensibility Examples</h3>
-<dl>
-	<dt>Minimal
-	<dd>The smallest possible Addin: it does nothing but is
-		recognized by NUnit and listed in the Addins dialog.
-	<dt>SampleSuiteExtension
-	<dd>A "toy" SuiteBuilder. It recognizes a special attribute
-	and identifies tests right in the suite extension. This example
-	uses separate objects for the addin and the suite builder.
-	<dt>SampleFixtureExtension
-	<dd>A slightly more involved SuiteBuilder. It recognizes
-	a special attribute and registers a test case builder to
-	identify its tests. It inherits from NUnitTestFixture and
-	so gets all the features of that class as well for free.
-	This example uses the same object to implement both the
-	addin and the suite builder.
-</dl>
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li id="current"><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/sequential.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/sequential.html b/lib/NUnit.org/NUnit/2.5.9/doc/sequential.html
deleted file mode 100644
index 9a322dc..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/sequential.html
+++ /dev/null
@@ -1,127 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - Sequential</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h3>SequentialAttribute (NUnit 2.5)</h3>
-
-<p>The <b>SequentialAttribute</b> is used on a test to specify that NUnit should
-   generate test cases by selecting individual data items provided
-   for the parameters of the test, without generating additional
-   combinations.
-   
-<p><b>Note:</b> If parameter data is provided by multiple attributes,
-the order in which NUnit uses the data items is not guaranteed. However,
-it can be expected to remain constant for a given runtime and operating
-system.
-   
-<h4>Example</h4>
-
-<p>The following test will be executed three times, as follows:
-<pre>
-	MyTest(1, "A")
-	MyTest(2, "B")
-	MyTest(3, null)
-</pre>
-<div class="code"><pre>
-[Test, Sequential]
-public void MyTest(
-    [Values(1,2,3)] int x,
-    [Values("A","B")] string s)
-{
-    ...
-}
-</pre></div>
-
-<h4>See also...</h4>
-<ul>
-<li><a href="combinatorial.html">CombinatorialAttribute</a><li><a href="pairwise.html">PairwiseAttribute</a></ul>
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<ul>
-<li><a href="category.html">Category</a></li>
-<li><a href="combinatorial.html">Combinatorial</a></li>
-<li><a href="culture.html">Culture</a></li>
-<li><a href="datapoint.html">Datapoint(s)</a></li>
-<li><a href="description.html">Description</a></li>
-<li><a href="exception.html">Exception</a></li>
-<li><a href="explicit.html">Explicit</a></li>
-<li><a href="ignore.html">Ignore</a></li>
-<li><a href="maxtime.html">Maxtime</a></li>
-<li><a href="pairwise.html">Pairwise</a></li>
-<li><a href="platform.html">Platform</a></li>
-<li><a href="property.html">Property</a></li>
-<li><a href="random.html">Random</a></li>
-<li><a href="range.html">Range</a></li>
-<li><a href="repeat.html">Repeat</a></li>
-<li><a href="requiredAddin.html">RequiredAddin</a></li>
-<li><a href="requiresMTA.html">Requires&nbsp;MTA</a></li>
-<li><a href="requiresSTA.html">Requires&nbsp;STA</a></li>
-<li><a href="requiresThread.html">Requires&nbsp;Thread</a></li>
-<li id="current"><a href="sequential.html">Sequential</a></li>
-<li><a href="setCulture.html">SetCulture</a></li>
-<li><a href="setup.html">Setup</a></li>
-<li><a href="setupFixture.html">SetupFixture</a></li>
-<li><a href="suite.html">Suite</a></li>
-<li><a href="teardown.html">Teardown</a></li>
-<li><a href="test.html">Test</a></li>
-<li><a href="testCase.html">TestCase</a></li>
-<li><a href="testCaseSource.html">TestCaseSource</a></li>
-<li><a href="testFixture.html">TestFixture</a></li>
-<li><a href="fixtureSetup.html">TestFixtureSetUp</a></li>
-<li><a href="fixtureTeardown.html">TestFixtureTearDown</a></li>
-<li><a href="theory.html">Theory</a></li>
-<li><a href="timeout.html">Timeout</a></li>
-<li><a href="values.html">Values</a></li>
-<li><a href="valueSource.html">ValueSource</a></li>
-</ul>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/setCulture.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/setCulture.html b/lib/NUnit.org/NUnit/2.5.9/doc/setCulture.html
deleted file mode 100644
index b09a3e8..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/setCulture.html
+++ /dev/null
@@ -1,191 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - SetCulture</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<script language="JavaScript" src="codeFuncs.js" ></script> <!-- Do it this way for IE -->
-
-<style><!--
-div.code { width: 34em }
---></style>
-
-<h3>SetCultureAttribute (NUnit 2.4.2)</h3> 
-<p>The SetCulture attribute is used to set the current Culture for the duration
-of a test. It may be specified at the level of a test or a fixture. The culture
-remains set until the test or fixture completes and is then reset to its original
-value. If you wish to use the current culture setting to decide whether to run
-a test, use the Culture attribute instead of this one.</p>
-	
-<p>Only one culture may be specified. Running a test under
-multiple cultures is a planned future enhancement. At this time, you can 
-achieve the same result by factoring out your test code into a private method 
-that is called by each individual test method.</p>
-
-<h4>Examples:</h4>
-
-<div class="code">
-
-<div class="langFilter">
-	<a href="javascript:Show('DD1')" onmouseover="Show('DD1')"><img src="img/langFilter.gif" width="14" height="14" alt="Language Filter"></a>
-	<div id="DD1" class="dropdown" style="display: none;" onclick="Hide('DD1')">
-		<a href="javascript:ShowCS()">C#</a><br>
-		<a href="javascript:ShowVB()">VB</a><br>
-		<a href="javascript:ShowMC()">C++</a><br>
-		<a href="javascript:ShowJS()">J#</a><br>
-	</div>
-</div>
-
-<pre class="cs">namespace NUnit.Tests
-{
-  using System;
-  using NUnit.Framework;
-
-  [TestFixture]
-  [SetCulture(&quot;fr-FR&quot;)]
-  public class FrenchCultureTests
-  {
-    // ...
-  }
-}
-</pre>
-
-<pre class="vb">Imports System
-Imports Nunit.Framework
-
-Namespace Nunit.Tests
-
-  &lt;TestFixture(), SetCulture(&quot;fr-FR&quot;)&gt;
-  Public Class FrenchCultureTests
-    &#39; ...
-  End Class
-End Namespace
-</pre>
-
-<pre class="mc">#using &lt;Nunit.Framework.dll&gt;
-using namespace System;
-using namespace NUnit::Framework;
-
-namespace NUnitTests
-{
-  [TestFixture]
-  [SetCulture(&quot;fr-FR&quot;)]
-  public __gc class FrenchCultureTests
-  {
-    // ...
-  };
-}
-
-#include &quot;cppsample.h&quot;
-
-namespace NUnitTests {
-  // ...
-}
-</pre>
-
-<pre class="js">package NUnit.Tests;
-
-import System.*;
-import NUnit.Framework.TestFixture;
-
-
-/** @attribute NUnit.Framework.TestFixture() */
-/** @attribute NUnit.Framework.SetCulture(&quot;fr-FR&quot;) */
-public class FrenchCultureTests
-{
-  // ...
-}
-</pre>
-</div>
-
-<h4>See also...</h4>
-<ul>
-<li><a href="culture.html">CultureAttribute</a></ul>
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<ul>
-<li><a href="category.html">Category</a></li>
-<li><a href="combinatorial.html">Combinatorial</a></li>
-<li><a href="culture.html">Culture</a></li>
-<li><a href="datapoint.html">Datapoint(s)</a></li>
-<li><a href="description.html">Description</a></li>
-<li><a href="exception.html">Exception</a></li>
-<li><a href="explicit.html">Explicit</a></li>
-<li><a href="ignore.html">Ignore</a></li>
-<li><a href="maxtime.html">Maxtime</a></li>
-<li><a href="pairwise.html">Pairwise</a></li>
-<li><a href="platform.html">Platform</a></li>
-<li><a href="property.html">Property</a></li>
-<li><a href="random.html">Random</a></li>
-<li><a href="range.html">Range</a></li>
-<li><a href="repeat.html">Repeat</a></li>
-<li><a href="requiredAddin.html">RequiredAddin</a></li>
-<li><a href="requiresMTA.html">Requires&nbsp;MTA</a></li>
-<li><a href="requiresSTA.html">Requires&nbsp;STA</a></li>
-<li><a href="requiresThread.html">Requires&nbsp;Thread</a></li>
-<li><a href="sequential.html">Sequential</a></li>
-<li id="current"><a href="setCulture.html">SetCulture</a></li>
-<li><a href="setup.html">Setup</a></li>
-<li><a href="setupFixture.html">SetupFixture</a></li>
-<li><a href="suite.html">Suite</a></li>
-<li><a href="teardown.html">Teardown</a></li>
-<li><a href="test.html">Test</a></li>
-<li><a href="testCase.html">TestCase</a></li>
-<li><a href="testCaseSource.html">TestCaseSource</a></li>
-<li><a href="testFixture.html">TestFixture</a></li>
-<li><a href="fixtureSetup.html">TestFixtureSetUp</a></li>
-<li><a href="fixtureTeardown.html">TestFixtureTearDown</a></li>
-<li><a href="theory.html">Theory</a></li>
-<li><a href="timeout.html">Timeout</a></li>
-<li><a href="values.html">Values</a></li>
-<li><a href="valueSource.html">ValueSource</a></li>
-</ul>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/setUICulture.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/setUICulture.html b/lib/NUnit.org/NUnit/2.5.9/doc/setUICulture.html
deleted file mode 100644
index 87edb20..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/setUICulture.html
+++ /dev/null
@@ -1,192 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - SetUICulture</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<script language="JavaScript" src="codeFuncs.js" ></script> <!-- Do it this way for IE -->
-
-<style><!--
-div.code { width: 34em }
---></style>
-
-<h3>SetUICultureAttribute (NUnit 2.5.2)</h3> 
-<p>The SetUICulture attribute is used to set the current UI Culture for the duration
-of a test. It may be specified at the level of a test or a fixture. The UI culture
-remains set until the test or fixture completes and is then reset to its original
-value. If you wish to use the current culture setting to decide whether to run
-a test, use the Culture attribute instead of this one.</p>
-	
-<p>Only one culture may be specified. Running a test under
-multiple cultures is a planned future enhancement. At this time, you can 
-achieve the same result by factoring out your test code into a private method 
-that is called by each individual test method.</p>
-
-<h4>Examples:</h4>
-
-<div class="code">
-
-<div class="langFilter">
-	<a href="javascript:Show('DD1')" onmouseover="Show('DD1')"><img src="img/langFilter.gif" width="14" height="14" alt="Language Filter"></a>
-	<div id="DD1" class="dropdown" style="display: none;" onclick="Hide('DD1')">
-		<a href="javascript:ShowCS()">C#</a><br>
-		<a href="javascript:ShowVB()">VB</a><br>
-		<a href="javascript:ShowMC()">C++</a><br>
-		<a href="javascript:ShowJS()">J#</a><br>
-	</div>
-</div>
-
-<pre class="cs">namespace NUnit.Tests
-{
-  using System;
-  using NUnit.Framework;
-
-  [TestFixture]
-  [SetUICulture(&quot;fr-FR&quot;)]
-  public class FrenchCultureTests
-  {
-    // ...
-  }
-}
-</pre>
-
-<pre class="vb">Imports System
-Imports Nunit.Framework
-
-Namespace Nunit.Tests
-
-  &lt;TestFixture(), SetUICulture(&quot;fr-FR&quot;)&gt;
-  Public Class FrenchCultureTests
-    &#39; ...
-  End Class
-End Namespace
-</pre>
-
-<pre class="mc">#using &lt;Nunit.Framework.dll&gt;
-using namespace System;
-using namespace NUnit::Framework;
-
-namespace NUnitTests
-{
-  [TestFixture]
-  [SetUICulture(&quot;fr-FR&quot;)]
-  public __gc class FrenchCultureTests
-  {
-    // ...
-  };
-}
-
-#include &quot;cppsample.h&quot;
-
-namespace NUnitTests {
-  // ...
-}
-</pre>
-
-<pre class="js">package NUnit.Tests;
-
-import System.*;
-import NUnit.Framework.TestFixture;
-
-
-/** @attribute NUnit.Framework.TestFixture() */
-/** @attribute NUnit.Framework.SetUICulture(&quot;fr-FR&quot;) */
-public class FrenchCultureTests
-{
-  // ...
-}
-</pre>
-</div>
-
-<h4>See also...</h4>
-<ul>
-<li><a href="culture.html">CultureAttribute</a><li><a href="setCulture.html">SetCultureAttribute</a></ul>
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<ul>
-<li><a href="category.html">Category</a></li>
-<li><a href="combinatorial.html">Combinatorial</a></li>
-<li><a href="culture.html">Culture</a></li>
-<li><a href="datapoint.html">Datapoint(s)</a></li>
-<li><a href="description.html">Description</a></li>
-<li><a href="exception.html">Exception</a></li>
-<li><a href="explicit.html">Explicit</a></li>
-<li><a href="ignore.html">Ignore</a></li>
-<li><a href="maxtime.html">Maxtime</a></li>
-<li><a href="pairwise.html">Pairwise</a></li>
-<li><a href="platform.html">Platform</a></li>
-<li><a href="property.html">Property</a></li>
-<li><a href="random.html">Random</a></li>
-<li><a href="range.html">Range</a></li>
-<li><a href="repeat.html">Repeat</a></li>
-<li><a href="requiredAddin.html">RequiredAddin</a></li>
-<li><a href="requiresMTA.html">Requires&nbsp;MTA</a></li>
-<li><a href="requiresSTA.html">Requires&nbsp;STA</a></li>
-<li><a href="requiresThread.html">Requires&nbsp;Thread</a></li>
-<li><a href="sequential.html">Sequential</a></li>
-<li><a href="setCulture.html">SetCulture</a></li>
-<li id="current"><a href="setUICulture.html">SetUICulture</a></li>
-<li><a href="setup.html">Setup</a></li>
-<li><a href="setupFixture.html">SetupFixture</a></li>
-<li><a href="suite.html">Suite</a></li>
-<li><a href="teardown.html">Teardown</a></li>
-<li><a href="test.html">Test</a></li>
-<li><a href="testCase.html">TestCase</a></li>
-<li><a href="testCaseSource.html">TestCaseSource</a></li>
-<li><a href="testFixture.html">TestFixture</a></li>
-<li><a href="fixtureSetup.html">TestFixtureSetUp</a></li>
-<li><a href="fixtureTeardown.html">TestFixtureTearDown</a></li>
-<li><a href="theory.html">Theory</a></li>
-<li><a href="timeout.html">Timeout</a></li>
-<li><a href="values.html">Values</a></li>
-<li><a href="valueSource.html">ValueSource</a></li>
-</ul>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/settingsDialog.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/settingsDialog.html b/lib/NUnit.org/NUnit/2.5.9/doc/settingsDialog.html
deleted file mode 100644
index 75369ee..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/settingsDialog.html
+++ /dev/null
@@ -1,320 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - SettingsDialog</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h2>Settings Dialog</h2>
-
-<p>The Settings Dialog is displayed using the Tools | Settings menu item and allows the user to
-control some aspects of NUnit�s operation. Beginning with NUnit 2.4.4, a tree-based dialog
-replaced the older tabbed format.</p>
-
-<hr><h3>Gui Settings - General</h3><hr>
-
-<div class="screenshot-right">
-   <img src="img/generalSettings.jpg"></div>
-
-<h3>Gui Display</h3>
-
-<h4>Full Gui</h4>
-<p>Displays the complete gui - as in prior versions of NUnit. This includes the
-   test result tabs and the progress bar.</p>
-   
-<h4>Mini Gui</h4>
-<p>Switches the display to the mini-gui, which consists of the tree display 
-   only.</p>
-<h3>Recent Files</h3>
-
-<p>The <b>Display ... files in list</b> TextBox allows the user to choose the number 
-of entries to display in the recent files list.
-
-<p>Normally, NUnit checks that project files still exist before
-displaying them in the recent files list. This can cause long delays if the
-file is on a network connection that is no longer available. Unchecking 
-<b>Check that files exist before listing</b> will avoid this delay, so 
-long as the missing file is not actually selected.
-
-<p>If <b>Load most recent project at startup</b> is checked, the GUI will load the 
-last file opened unless it is run with a specific filename or with the 
-<code>/noload</code> parameter.</p>
-
-<hr style="clear: both"><h3>Gui Settings - Tree Display</h3><hr>
-
-<div class="screenshot-right">
-   <img src="img/treeDisplaySettings.jpg"></div>
-
-<h3>Tree View</h3>
-
-<p>The list box allows selecting the degree of expansion of the tree when tests are loaded:</p>
-<blockquote>
-<p><b>Auto</b> � selects a setting based on the space available for the tree display.</p>
-<p><b>Expand</b> � expands all tests</p>
-<p><b>Collapse</b> � collapses all tests</p>
-<p><b>Hide Tests</b> � expands all suites except for the fixtures themselves.</p>
-</blockquote>
-
-<p>If <b>Clear results when reloading</b> is checked, an automatic or manual reload will reinitialize all
-test nodes in the tree (grey display) � if it is not checked, result information for tests that do
-not seem to have changed will be retained.</p>
-
-<p>If <b>Save visual state of each project</b> is checked, NUnit saves the state of the tree
-and restores it when the project is next opened. The information saved includes which
-branches of the tree are expanded, the selected node, any checked nodes and any
-category selection.
-
-<p>If <b>Show Checkboxes</b> is checked, the tree includes checkboxes, which may
-   be used to select multiple tests for running. This setting is also available
-   in the <b>View | Tree</b> menu.</p>
-
-<h3>Test Structure</h3>
-
-<p>If <b>Automatic Namespace suites</b> is selected, tests will be
-   shown in a hierarchical listing based on namespaces. This is the
-   standard display as used in versions prior to NUnit 2.4.
-
-<p>If <b>Flat list of TestFixtures</b> is selected, tests will be
-   shown as a sequential list of fixtures.
-
-<hr style="clear: both"><h3>Gui Settings - Test Results</h3><hr>
-
-<div class="screenshot-right">
-   <img src="img/testResultSettings.jpg"></div>
-
-<h3>Errors Tab</h3>
-
-<p>Check <b>Display Errors and Failures Tab</b> to display the 
-<b>Errors and Failures</b> tab, which shows information about failing tests.
-
-<p>Check <b>Enable Failure ToolTips</b> to display the tip window over the
-Errors and Failures display and the stack trace. Clear it if you prefer not
-to see the tip window.</p>
-
-<p>Check <b>Enable Word Wrap</b> to turn on word wrapping
-in the Errors and Failures display. While you can select this item and the
-preceding one at the same time, they do not interact well, so you will 
-normally choose one or the other.</p>
-
-<h3>Not Run Tab</h3>
-
-<p>Check <b>Display Tests Not Run Tab</b> to display the 
-<b>Tests Not Run</b> tab, which shows information about tests that were
-skipped or ignored.
-
-<hr style="clear: both"><h3>Gui Settings - Text Output</h3><hr>
-
-<div class="screenshot-right">
-   <img src="img/textOutputSettings.jpg"></div>
-
-<h3>Select Tab</h3>
-
-<p>The <b>Select Tab</b> dropdown list is used to select one of the output tabs, for which
-settings are to be viewed or changed. It also contains entries that allow
-you to add a new tab or edit the list of tabs.
-
-<p>The <b>Restore Defaults</b> button is used to restore the default
-setting, which is a single tab labeled "Text Output." The default tab
-displays all types of output and includes a label for each test that 
-displays text.
-
-<p>The <b>Title</b> text box is used to modify the title displayed
-for the selected output tab.
-
-<p><b>Enabled</b> is checked by default. If you uncheck it,
-the selected tab will be removed from the tab control. This allows you to temporarily
-suppress output to a tab without actually removing its definition.
-
-<h3>Content</h3>
-
-<p>The four check boxes enable or disable a particular type of output
-on the selected output window. For each type, the display captures
-output produced while your test is running - either by the test
-itself or by the program you are testing.
-
-<h4>Standard Output</h4>
-<p>Captures all output written to Console.Out.
-
-<h4>Error Output</h4>
-<p>Captures all output written to Console.Error.
-
-<h4>Trace Output</h4>
-<p>Captures all output written to Trace or Debug.
-
-<h4>Log Output</h4>
-<p>Captures output written to a log4net log. NUnit captures
-all output at the Error level or above unless another level
-is specified for the DefaultLogThreshold setting in the  
-configuration file for the test assembly or project.
-
-<h3>Test Labels</h3>
-
-<p>Check <b>Display TestCase Labels</b> to precede text in the output window
-with the name of the test that produced it.</p>
-
-<p>Check <b>Suppress label if no output is displayed</b> to eliminate display
-of labels for tests that produce no output in the window.
-
-
-<hr style="clear: both"><h3>Test Loader Settings - Assembly Isolation</h3><hr>
-
-<div class="screenshot-right">
-   <img src="img/testLoadSettings.jpg"></div>
-
-<h3>Default Process Model</h3>
-
-<p>These settings determine NUnit's default use of operating system
-processes and may be overridden by settings in the NUnit project.
-
-<p>If <b>Run tests directly in the NUnit process</b> is selected,
-all tests are run in a test domain in the same process as NUnit.
-This is the way previous versions of NUnit ran tests and is the
-default setting.
-
-<p>If <b>Run tests in a single separate process</b> is selected,
-a separate process is used for all tests.
-
-<p>If <b>Run tests in a separate process per Assembly </b> is selected,
-a separate process is used for each test assembly.
-
-<h3>Default Domain Usage</h3>
-
-<p>If <b>Use a separate AppDomain per Assembly</b> is selected, each assembly
-   in a multiple-assembly test run will be loaded in a separate AppDomain.
-   This setting is not available when <b>Run tests in a separate process
-   per Assembly</b> is selected above.
-
-<p>If <b>Use a single AppDomain for all tests</b> is selected, all assemblies in
-   a multiple-assembly test run will use the same AppDomain. This was
-   the standard behavior of NUnit prior to version 2.4 and is the
-   default setting.
-
-<p>If <b>Merge tests across assemblies</b> is checked, the display of tests
-   will not be divided across assemblies. If automatic namespace suites are
-   used, they will be merged across all assemblies. This option is only
-   available when tests are run in the same appdomain.
-
-<hr style="clear: both"><h3>Test Loader Settings - Assembly Reload</h3><hr>
-
-<div class="screenshot-right">
-   <img src="img/assemblyReloadSettings.jpg"></div>
-
-<h3>Assembly Reload</h3>
-
-<p>If <b>Reload before each test run</b> is checked, a reload will occur whenever the run button is
-pressed whether the assemblies appear to have changed or not.</p>
-
-<p>If <b>Reload when test assembly changes</b> is checked, assemblies are watched for any change and
-an automatic reload is initiated. This item is disabled on Windows 98 or ME.</p>
-
-<p>If <b>Re-run last tests run</b> is checked, tests are re-run whenever a Reload
-   takes place.</p>
-   
-<hr style="clear: both"><h3>Test Loader Settings - Advanced</h3><hr>
-
-<div class="screenshot-right">
-   <img src="img/advancedSettings.jpg"></div>
-
-<h3>Shadow Copy</h3>
-
-<p>NUnit normally uses .Net shadow-copying in order to allow you to edit
-and recompile assemblies while it is running. Uncheck this box to disable
-shadow-copy only if you have a particular problem that requires it.</p>
-
-<p><b>Note:</b> If you are tempted to disable shadow copy in order to access
-files in the same directory as your assembly, you should be aware that there
-are alternatives. Consider using the Assembly.Codebase property rather than
-Assembly.Location.
-
-
-<hr style="clear: both"><h3>IDE Support Settings - Visual Studio</h3><hr>
-
-<div class="screenshot-right">
-   <img src="img/visualStudioSettings.jpg"></div>
-
-<h3>Visual Studio</h3>
-
-<p>If <b>Enable Visual Studio Support</b> is checked, the user will be able to open Visual Studio projects
-and solutions and add Visual Studio projects to existing test projects.</p>
-
-<hr style="clear: both"><h3>Advanced Settings - Internal Trace</h3><hr>
-
-<div class="screenshot-right">
-   <img src="img/internalTraceSettings.jpg"></div>
-
-<h3>Internal Trace</h3>
-
-<p>The <b>Trace Level</b> dropdown controls the level of internal trace output.</p>
-
-
-
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<ul>
-<li><a href="nunit-console.html">Console&nbsp;Runner</a></li>
-<li><a href="nunit-gui.html">Gui&nbsp;Runner</a></li>
-<ul>
-<li><a href="guiCommandLine.html">Command-Line</a></li>
-<li><a href="mainMenu.html">Main&nbsp;Menu</a></li>
-<li><a href="contextMenu.html">Context&nbsp;Menu</a></li>
-<li id="current"><a href="settingsDialog.html">Settings&nbsp;Dialog</a></li>
-<li><a href="addinsDialog.html">Addins&nbsp;Dialog</a></li>
-<li><a href="testProperties.html">Test&nbsp;Properties</a></li>
-<li><a href="configEditor.html">Configuration&nbsp;Editor</a></li>
-<li><a href="projectEditor.html">Project&nbsp;Editor</a></li>
-</ul>
-<li><a href="pnunit.html">PNUnit&nbsp;Runner</a></li>
-<li><a href="runtimeSelection.html">Runtime&nbsp;Selection</a></li>
-<li><a href="assemblyIsolation.html">Assembly&nbsp;Isolation</a></li>
-<li><a href="configFiles.html">Configuration&nbsp;Files</a></li>
-<li><a href="multiAssembly.html">Multiple&nbsp;Assemblies</a></li>
-<li><a href="vsSupport.html">Visual&nbsp;Studio&nbsp;Support</a></li>
-</ul>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/setup.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/setup.html b/lib/NUnit.org/NUnit/2.5.9/doc/setup.html
deleted file mode 100644
index 34cefdf..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/setup.html
+++ /dev/null
@@ -1,239 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - Setup</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<script language="JavaScript" src="codeFuncs.js" ></script> <!-- Do it this way for IE -->
-
-<h3>SetUpAttribute (NUnit 2.0 / 2.5)</h3>
-
-<p>This attribute is used inside a TestFixture to provide a common set of 
-	functions that are performed just before each test method is called.  
-    
-<p><b>Before NUnit 2.5</b>, a TestFixture could have only one SetUp method
-	and it was required to be an instance method. 
-
-<p><b>Beginning with NUnit 2.5</b>, SetUp methods may be either static or
-   instance methods and you may define more than one of them in a fixture.
-   Normally, multiple SetUp methods are only defined at different levels
-   of an inheritance hierarchy, as explained below.
-   
-<p>If a SetUp method fails or throws an exception, the test is not executed
-   and a failure or error is reported.
-   
-
-<h4>Example:</h4>
-
-<div class="code">
-
-<div class="langFilter">
-	<a href="javascript:Show('DD1')" onmouseover="Show('DD1')"><img src="img/langFilter.gif" width="14" height="14" alt="Language Filter"></a>
-	<div id="DD1" class="dropdown" style="display: none" onclick="Hide('DD1')">
-		<a href="javascript:ShowCS()">C#</a><br>
-		<a href="javascript:ShowVB()">VB</a><br>
-		<a href="javascript:ShowMC()">C++</a><br>
-		<a href="javascript:ShowJS()">J#</a><br>
-	</div>
-</div>
-
-<pre class="cs">namespace NUnit.Tests
-{
-  using System;
-  using NUnit.Framework;
-
-  [TestFixture]
-  public class SuccessTests
-  {
-    [SetUp] public void Init()
-    { /* ... */ }
-
-    [TearDown] public void Cleanup()
-    { /* ... */ }
-
-    [Test] public void Add()
-    { /* ... */ }
-  }
-}
-</pre>
-
-<pre class="vb">Imports System
-Imports Nunit.Framework
-
-Namespace Nunit.Tests
-
-  &lt;TestFixture()&gt; Public Class SuccessTests
-    &lt;SetUp()&gt; Public Sub Init()
-    ' ...
-    End Sub
-
-    &lt;TearDown()&gt; Public Sub Cleanup()
-    ' ...
-    End Sub
-
-    &lt;Test()&gt; Public Sub Add()
-    ' ...
-    End Sub
-  End Class
-End Namespace
-</pre>
-
-<pre class="mc">#using &lt;Nunit.Framework.dll&gt;
-using namespace System;
-using namespace NUnit::Framework;
-
-namespace NUnitTests
-{
-  [TestFixture]
-  public __gc class SuccessTests
-  {
-    [SetUp] void Init();
-    [TearDown] void Cleanup();
-
-    [Test] void Add();
-  };
-}
-
-#include "cppsample.h"
-
-namespace NUnitTests {
-  // ...
-}
-</pre>
-
-<pre class="js">package NUnit.Tests;
-
-import System.*;
-import NUnit.Framework.TestFixture;
-
-
-/** @attribute NUnit.Framework.TestFixture() */
-public class SuccessTests
-{
-  /** @attribute NUnit.Framework.SetUp() */
-  public void Init()
-  { /* ... */ }
-
-  /** @attribute NUnit.Framework.TearDown() */
-  public void Cleanup()
-  { /* ... */ }
-
-  /** @attribute NUnit.Framework.Test() */
-  public void Add()
-  { /* ... */ }
-}
-</pre>
-
-</div>
-
-<h3>Inheritance</h3>
-
-<p>The SetUp attribute is inherited from any base class. Therefore, if a base 
-	class has defined a SetUp method, that method will be called 
-	before each test method in the derived class.
-	
-<p>Before NUnit 2.5, you were permitted only one SetUp method. If you wanted to 
-   have some SetUp functionality in the base class and add more in the derived 
-   class you needed to call the base class method yourself.
- 
-<p>With NUnit 2.5, you can achieve the same result by defining a SetUp method
-   in the base class and another in the derived class. NUnit will call base
-   class SetUp methods before those in the derived classes.
-   
-<p><b>Note:</b> Although it is possible to define multiple SetUp methods
-   in the same class, you should rarely do so. Unlike methods defined in
-   separate classes in the inheritance hierarchy, the order in which they
-   are executed is not guaranteed.
-
-<h4>See also...</h4>
-<ul>
-<li><a href="teardown.html">TearDownAttribute</a><li><a href="fixtureSetup.html">TestFixtureSetUpAttribute</a><li><a href="fixtureTeardown.html">TestFixtureTearDownAttribute</a></ul>
-	
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<ul>
-<li><a href="category.html">Category</a></li>
-<li><a href="combinatorial.html">Combinatorial</a></li>
-<li><a href="culture.html">Culture</a></li>
-<li><a href="datapoint.html">Datapoint(s)</a></li>
-<li><a href="description.html">Description</a></li>
-<li><a href="exception.html">Exception</a></li>
-<li><a href="explicit.html">Explicit</a></li>
-<li><a href="ignore.html">Ignore</a></li>
-<li><a href="maxtime.html">Maxtime</a></li>
-<li><a href="pairwise.html">Pairwise</a></li>
-<li><a href="platform.html">Platform</a></li>
-<li><a href="property.html">Property</a></li>
-<li><a href="random.html">Random</a></li>
-<li><a href="range.html">Range</a></li>
-<li><a href="repeat.html">Repeat</a></li>
-<li><a href="requiredAddin.html">RequiredAddin</a></li>
-<li><a href="requiresMTA.html">Requires&nbsp;MTA</a></li>
-<li><a href="requiresSTA.html">Requires&nbsp;STA</a></li>
-<li><a href="requiresThread.html">Requires&nbsp;Thread</a></li>
-<li><a href="sequential.html">Sequential</a></li>
-<li><a href="setCulture.html">SetCulture</a></li>
-<li id="current"><a href="setup.html">Setup</a></li>
-<li><a href="setupFixture.html">SetupFixture</a></li>
-<li><a href="suite.html">Suite</a></li>
-<li><a href="teardown.html">Teardown</a></li>
-<li><a href="test.html">Test</a></li>
-<li><a href="testCase.html">TestCase</a></li>
-<li><a href="testCaseSource.html">TestCaseSource</a></li>
-<li><a href="testFixture.html">TestFixture</a></li>
-<li><a href="fixtureSetup.html">TestFixtureSetUp</a></li>
-<li><a href="fixtureTeardown.html">TestFixtureTearDown</a></li>
-<li><a href="theory.html">Theory</a></li>
-<li><a href="timeout.html">Timeout</a></li>
-<li><a href="values.html">Values</a></li>
-<li><a href="valueSource.html">ValueSource</a></li>
-</ul>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/setupFixture.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/setupFixture.html b/lib/NUnit.org/NUnit/2.5.9/doc/setupFixture.html
deleted file mode 100644
index c2a7f8c..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/setupFixture.html
+++ /dev/null
@@ -1,216 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - SetupFixture</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<script language="JavaScript" src="codeFuncs.js" ></script> <!-- Do it this way for IE -->
-
-<h3>SetUpFixtureAttribute (NUnit 2.4)</h3>
-
-<p>This is the attribute that marks a class that contains the one-time
-	setup or teardown methods for all the test fixtures under a given
-	namespace. The class may contain at most one method marked with the
-	SetUpAttribute and one method marked with the TearDownAttribute.</p>
-	
-<p>There are a few restrictions on a class that is used as a setup fixture.
-	<ul>
-		<li>
-			It must be a publicly exported type or NUnit will not see it.</li>
-		<li>
-			It must have a default constructor or NUnit will not be able to construct it.</li>
-	</ul>
-</p>
-
-<p>The SetUp method in a SetUpFixture is executed once before any of the fixtures
-contained in its namespace. The TearDown method is executed once after all the 
-fixtures have completed execution. In the examples below, the method RunBeforeAnyTests()
-is called before any tests or setup methods in the NUnit.Tests namespace. The method
-RunAfterAnyTests() is called after all the tests in the namespace as well as their
-individual or fixture teardowns have completed exection.</p>
-
-<p>Only one SetUpFixture should be created in a given namespace. A SetUpFixture
-outside of any namespace provides SetUp and TearDown for the entire assembly.
-
-<h4>Example:</h4>
-
-<div class="code">
-
-<div class="langFilter">
-	<a href="javascript:Show('DD1')" onmouseover="Show('DD1')"><img src="img/langFilter.gif" width="14" height="14" alt="Language Filter"></a>
-	<div id="DD1" class="dropdown" style="display: none;" onclick="Hide('DD1')">
-		<a href="javascript:ShowCS()">C#</a><br>
-		<a href="javascript:ShowVB()">VB</a><br>
-		<a href="javascript:ShowMC()">C++</a><br>
-		<a href="javascript:ShowJS()">J#</a><br>
-	</div>
-</div>
-
-<pre class="cs">namespace NUnit.Tests
-{
-  using System;
-  using NUnit.Framework;
-
-  [SetUpFixture]
-  public class MySetUpClass
-  {
-    [SetUp]
-	RunBeforeAnyTests()
-	{
-	  // ...
-	}
-
-    [TearDown]
-	RunAfterAnyTests()
-	{
-	  // ...
-	}
-  }
-}
-</pre>
-
-<pre class="vb">Imports System
-Imports Nunit.Framework
-
-Namespace Nunit.Tests
-
-  &lt;TestFixture()&gt; Public Class MySetUpClass
-    &lt;SetUp()&gt; Public Sub RunBeforeAnyTests()
-	  ' ...
-	End Sub
-	
-	&lt;TearDown()&gt; Public Sub RunAfterAnyTests()
-	  ' ...
-	End Sub
-  End Class
-End Namespace
-</pre>
-
-<pre class="mc">#using &lt;Nunit.Framework.dll&gt;
-using namespace System;
-using namespace NUnit::Framework;
-
-namespace NUnitTests
-{
-  [TestFixture]
-  public __gc class MySetUpClass
-  {
-    [SetUp] public void RunBeforeAnyTests();
-	[TearDown] public void RunAfterAnyTests();
-  };
-}
-
-#include "cppsample.h"
-
-namespace NUnitTests {
-  // ...
-}
-</pre>
-
-<pre class="js">package NUnit.Tests;
-
-import System.*;
-import NUnit.Framework.TestFixture;
-
-
-/** @attribute NUnit.Framework.TestFixture() */
-public class MySetUpClass
-{
-  /** @attribute NUnit.Framework.SetUp() */
-  public void RunBeforeAnyTests()
-  { /* ... */ }
-
-  /** @attribute NUnit.Framework.TearDown() */
-  public void RunAfterAnyTests()
-  { /* ... */ }
-}
-</pre>
-
-</div>
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<ul>
-<li><a href="category.html">Category</a></li>
-<li><a href="combinatorial.html">Combinatorial</a></li>
-<li><a href="culture.html">Culture</a></li>
-<li><a href="datapoint.html">Datapoint(s)</a></li>
-<li><a href="description.html">Description</a></li>
-<li><a href="exception.html">Exception</a></li>
-<li><a href="explicit.html">Explicit</a></li>
-<li><a href="ignore.html">Ignore</a></li>
-<li><a href="maxtime.html">Maxtime</a></li>
-<li><a href="pairwise.html">Pairwise</a></li>
-<li><a href="platform.html">Platform</a></li>
-<li><a href="property.html">Property</a></li>
-<li><a href="random.html">Random</a></li>
-<li><a href="range.html">Range</a></li>
-<li><a href="repeat.html">Repeat</a></li>
-<li><a href="requiredAddin.html">RequiredAddin</a></li>
-<li><a href="requiresMTA.html">Requires&nbsp;MTA</a></li>
-<li><a href="requiresSTA.html">Requires&nbsp;STA</a></li>
-<li><a href="requiresThread.html">Requires&nbsp;Thread</a></li>
-<li><a href="sequential.html">Sequential</a></li>
-<li><a href="setCulture.html">SetCulture</a></li>
-<li><a href="setup.html">Setup</a></li>
-<li id="current"><a href="setupFixture.html">SetupFixture</a></li>
-<li><a href="suite.html">Suite</a></li>
-<li><a href="teardown.html">Teardown</a></li>
-<li><a href="test.html">Test</a></li>
-<li><a href="testCase.html">TestCase</a></li>
-<li><a href="testCaseSource.html">TestCaseSource</a></li>
-<li><a href="testFixture.html">TestFixture</a></li>
-<li><a href="fixtureSetup.html">TestFixtureSetUp</a></li>
-<li><a href="fixtureTeardown.html">TestFixtureTearDown</a></li>
-<li><a href="theory.html">Theory</a></li>
-<li><a href="timeout.html">Timeout</a></li>
-<li><a href="values.html">Values</a></li>
-<li><a href="valueSource.html">ValueSource</a></li>
-</ul>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/stringAssert.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/stringAssert.html b/lib/NUnit.org/NUnit/2.5.9/doc/stringAssert.html
deleted file mode 100644
index e5f3068..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/stringAssert.html
+++ /dev/null
@@ -1,105 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - StringAssert</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h2>StringAssert (NUnit 2.2.3)</h2>
-<p>The StringAssert class provides a number of methods that are useful 
-when examining string values.</p>
-
-<div class="code" style="width: 36em">
-<pre>StringAssert.Contains( string expected, string actual );
-StringAssert.Contains( string expected, string actual, 
-                string message );
-StringAssert.Contains( string expected, string actual,
-                string message, params object[] args );
-
-StringAssert.StartsWith( string expected, string actual );
-StringAssert.StartsWith( string expected, string actual, 
-                string message );
-StringAssert.StartsWith( string expected, string actual,
-                string message, params object[] args );
-
-StringAssert.EndsWith( string expected, string actual );
-StringAssert.EndsWith( string expected, string actual, 
-                string message );
-StringAssert.EndsWith( string expected, string actual,
-                string message, params object[] args );
-
-StringAssert.AreEqualIgnoringCase( string expected, string actual );
-StringAssert.AreEqualIgnoringCase( string expected, string actual, 
-                string message );
-StringAssert.AreEqualIgnoringCase( string expected, string actual,
-                string message params object[] args );
-				
-StringAssert.IsMatch( string regexPattern, string actual );
-StringAssert.IsMatch( string regexPattern, string actual, 
-                string message );
-StringAssert.IsMatch( string regexPattern, string actual,
-                string message, params object[] args );</pre>
-</div>
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<ul>
-<li><a href="equalityAsserts.html">Equality&nbsp;Asserts</a></li>
-<li><a href="identityAsserts.html">Identity&nbsp;Asserts</a></li>
-<li><a href="conditionAsserts.html">Condition&nbsp;Asserts</a></li>
-<li><a href="comparisonAsserts.html">Comparison&nbsp;Asserts</a></li>
-<li><a href="typeAsserts.html">Type&nbsp;Asserts</a></li>
-<li><a href="exceptionAsserts.html">Exception&nbsp;Asserts</a></li>
-<li><a href="utilityAsserts.html">Utility&nbsp;Methods</a></li>
-<li id="current"><a href="stringAssert.html">String&nbsp;Assert</a></li>
-<li><a href="collectionAssert.html">Collection&nbsp;Assert</a></li>
-<li><a href="fileAssert.html">File&nbsp;Assert</a></li>
-<li><a href="directoryAssert.html">Directory&nbsp;Assert</a></li>
-</ul>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/stringConstraints.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/stringConstraints.html b/lib/NUnit.org/NUnit/2.5.9/doc/stringConstraints.html
deleted file mode 100644
index 0b7d535..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/stringConstraints.html
+++ /dev/null
@@ -1,243 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - StringConstraints</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h2>String Constraints (NUnit 2.4)</h2>
-
-<p>String constraints perform tests that are specific to strings.
-   Attempting to test a non-string value with a string constraint
-   is an error and gives an exception.
-   
-<p>The <b>Text</b> prefix is deprecated beginning with NUnit 2.5.1
-   and will be removed in NUnit 3.0.
- 
-<h3>SubstringConstraint</h3>  
-
-<h4>Action</h4>
-<p>Tests for a substring.
-
-<h4>Constructor</h4>
-<div class="code"><pre>
-SubstringConstraint(string expected)
-</pre></div>
-
-<h4>Syntax</h4>
-<div class="code"><pre>
-Is.StringContaining(string expected)
-Contains.Substring(string expected)
-ContainsSubstring(string expected)
-Contains(string expected)
-[Obsolete] Text.Contains(string expected)
-[Obsolete] Text.DoesNotContain(string expected)
-</pre></div>
-
-<h4>Modifiers</h4>
-<div class="code"><pre>
-...IgnoreCase
-</pre></div>
-
-<h4>Examples of Use</h4>
-<div class="code"><pre>
-string phrase = "Make your tests fail before passing!"
-
-Assert.That( phrase, Is.StringContaining( "tests fail" ) );
-Assert.That( phrase, Contains.Substring( "tests fail" ) );
-Assert.That( phrase, Is.Not.StringContaining( "tests pass" ) );
-Assert.That( phrase, Is.StringContaining( "make" ).IgnoreCase );
-Expect (phrase, Contains.Substring( "make" ).IgnoreCase );
-</pre></div>
-
-<h4>Notes</h4>
-<ol>
-<li><b>ContainsSubstring</b> and <b>Contains</b> may appear only in the 
-    body of a constraint expression or when the inherited syntax is used.
-<li><b>Contains</b> is not actually a string constraint but is converted
-    to one when a string is being tested.
-</ol>
-
-<h3>StartsWithConstraint</h3>
-
-<h4>Action</h4>
-<p>Tests for an initial string.
-
-<h4>Constructor</h4>
-<div class="code"><pre>
-StartsWithConstraint(string expected)
-</pre></div>
-
-<h4>Syntax</h4>
-<div class="code"><pre>
-Is.StringStarting(string expected)
-StartsWith(string expected)
-[Obsolete] Text.StartsWith(string expected)
-[Obsolete] Text.DoesNotStartWith(string expected)
-</pre></div>
-
-<h4>Modifiers</h4>
-<div class="code"><pre>
-...IgnoreCase
-</pre></div>
-
-<h4>Examples of Use</h4>
-<div class="code"><pre>
-string phrase = "Make your tests fail before passing!"
-
-Assert.That( phrase, Is.StringStarting( "Make" ) );
-Assert.That( phrase, Is.Not.StringStarting( "Break" ) );
-Assert.That( phrase, Has.Length.GreaterThan(10)
-                .And.Not.StartsWith( "Break" ) );
-Expect( phrase, StartsWith( "Make" ) );
-</pre></div>
-
-<h4>Notes</h4>
-<ol>
-<li><b>StartsWith</b> may appear only in the body of a constraint 
-    expression or when the inherited syntax is used.
-</ol>
-
-<h3>EndsWithConstraint</h3>
-
-<h4>Action</h4>
-<p>Tests for an ending string.
-
-<h4>Constructor</h4>
-<div class="code"><pre>
-EndsWithConstraint(string expected)
-</pre></div>
-
-<h4>Syntax</h4>
-<div class="code"><pre>
-Is.StringEnding(string expected)
-EndsWith(string expected)
-[Obsolete] Text.EndsWith(string expected)
-[Obsolete] Text.DoesNotEndWith(string expected)
-</pre></div>
-
-<h4>Modifiers</h4>
-<div class="code"><pre>
-...IgnoreCase
-</pre></div>
-
-<h4>Examples of Use</h4>
-<div class="code"><pre>
-string phrase = "Make your tests fail before passing!"
-
-Assert.That( phrase, Is.StringEnding( "!" ) );
-Assert.That( phrase, Is.StringEnding( "PASSING!" ).IgnoreCase );
-Expect( phrase, EndsWith( "!" ) );
-</pre></div>
-
-<h4>Notes</h4>
-<ol>
-<li><b>EndsWith</b> may appear only in the body of a constraint 
-    expression or when the inherited syntax is used.
-</ol>
-
-<h3>RegexConstraint</h3>
-
-<h4>Action</h4>
-<p>Tests that a pattern is matched.
-
-<h4>Constructor</h4>
-<div class="code"><pre>
-RegexConstraint(string pattern)
-</pre></div>
-
-<h4>Syntax</h4>
-<div class="code"><pre>
-Is.StringMatching(string pattern)
-Matches(string pattern)
-[Obsolete] Text.Matches(string pattern)
-[Obsolete] Text.DoesNotMatch(string pattern)
-</pre></div>
-
-<h4>Modifiers</h4>
-<div class="code"><pre>
-...IgnoreCase
-</pre></div>
-
-<h4>Examples of Use</h4>
-<div class="code"><pre>
-string phrase = "Make your tests fail before passing!"
-
-Assert.That( phrase, Is.StringMatching( "Make.*tests.*pass" ) );
-Assert.That( phrase, Is.Not.StringMatching( "your.*passing.*tests" ) );
-Assert.That( phrase, Has.Length.GreaterThan(10)
-                .And.Not.Matches( "your.*passing.*tests" ) );
-Expect( phrase, Matches( "Make.*pass" ) );
-</pre></div>
-
-<h4>Notes</h4>
-<ol>
-<li><b>Matches</b> may appear only in the body of a constraint 
-    expression or when the inherited syntax is used.
-</ol>
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<ul>
-<li><a href="equalConstraint.html">Equal&nbsp;Constraint</a></li>
-<li><a href="sameasConstraint.html">SameAs&nbsp;Constraint</a></li>
-<li><a href="conditionConstraints.html">Condition&nbsp;Constraints</a></li>
-<li><a href="comparisonConstraints.html">Comparison&nbsp;Constrants</a></li>
-<li><a href="pathConstraints.html">Path&nbsp;Constraints</a></li>
-<li><a href="typeConstraints.html">Type&nbsp;Constraints</a></li>
-<li id="current"><a href="stringConstraints.html">String&nbsp;Constraints</a></li>
-<li><a href="collectionConstraints.html">Collection&nbsp;Constraints</a></li>
-<li><a href="propertyConstraint.html">Property&nbsp;Constraint</a></li>
-<li><a href="throwsConstraint.html">Throws&nbsp;Constraint</a></li>
-<li><a href="compoundConstraints.html">Compound&nbsp;Constraints</a></li>
-<li><a href="delayedConstraint.html">Delayed&nbsp;Constraint</a></li>
-<li><a href="listMapper.html">List&nbsp;Mapper</a></li>
-<li><a href="reusableConstraint.html">Reusable&nbsp;Constraint</a></li>
-</ul>
-<li><a href="attributes.html">Attributes</a></li>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/suite.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/suite.html b/lib/NUnit.org/NUnit/2.5.9/doc/suite.html
deleted file mode 100644
index 45b5fcf..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/suite.html
+++ /dev/null
@@ -1,238 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - Suite</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<div style="float:right"><b>Update: August 22, 2007</b></div>
-<h3>SuiteAttribute (NUnit 2.0/2.4.4)</h3>
-	
-<p>The Suite Attribute is used to define subsets of test to be run from the
-	command-line, using the <b>/fixture</b> option. It was introduced in NUnit 
-	2.0 to replace the older approach of inheriting from the TestSuite class.</p>
-	
-<p>Originally, the NUnit developers believed that the need for the Suite
-    mechanism would diminish because of the dynamic creation of suites based
-	on namespaces. It was provided for backwards compatibility.</p>
-	
-<p>That has not proven to be true. Suites are still used today by many people,
-    so we are making an effort to revive them in terms of usability. 
-	
-<p>The Suite mechanism depends on a static property marked with the </b>SuiteAttribute</b>.
-	In the clasic implementation, supported by all releases since 2.0, that property
-	returns a TestSuite, populated with the tests that are to be executed.
-	
-<h4>Old Approach</h4>
-
-<div class="code">
-
-<pre>namespace NUnit.Tests
-{
-  using System;
-  using NUnit.Framework;
-  using NUnit.Core;
-
-  public class AllTests
-  {
-    [Suite]
-    public static TestSuite Suite
-    {
-      get
-      {
-        TestSuite suite = new TestSuite("All Tests");
-        suite.Add(new OneTestCase());
-        suite.Add(new Assemblies.AssemblyTests());
-        suite.Add(new AssertionTest());
-        return suite;
-      }
-    }
-  }
-}
-</pre>
-
-</div>
-
-<p>This approach has a serious problem: it requires a reference to the nunit.core assembly,
-	which is not normally referenced by user tests. This means that the tests
-	cannot be ported across versions of NUnit without recompilation. In some cases,
-	introducing more than one version of the core assembly can prevent NUnit
-	from running correctly.
-	
-<p>Beginning with NUnit 2.4.4, a new approach is available. The property marked
-	with the <b>SuiteAttribute</b> may simply return a collection containing test 
-	fixture objects or Types.
-	If a Type is provided, NUnit creates an object of that type for use
-	as a fixture. Any other object is assumed to be a pre-created fixture object.
-	This allows objects with parameterized constructors or settable
-	properties to be used as fixtures.
-
-<p>Test suites created through use of the <b>SuiteAttribute</b> may contain <b>TestFixtureSetUp</b> and 
-	<b>TestFixtureTearDown</b> methods, to perform one-time setup and teardown
-	for the tests included in the suite.
-	
-<h4>New Approach - Fixture Objects</h4>
-
-<div class="code">
-
-<pre>namespace NUnit.Tests
-{
-  using System;
-  using NUnit.Framework;
-
-  private class AllTests
-  {
-    [Suite]
-    public static IEnumerable Suite
-    {
-      get
-      {
-        ArrayList suite = new ArrayList();
-        suite.Add(new OneTestCase());
-        suite.Add(new AssemblyTests());
-        suite.Add(new NoNamespaceTestFixture());
-        return suite;
-      }
-    }
-  }
-}
-</pre>
-
-</div>
-
-<h4>New Approach - Fixture Types</h4>
-
-<div class="code">
-
-<pre>namespace NUnit.Tests
-{
-  using System;
-  using NUnit.Framework;
-
-  private class AllTests
-  {
-    [Suite]
-    public static IEnumerable Suite
-    {
-      get
-      {
-        ArrayList suite = new ArrayList();
-        suite.Add(typeof(OneTestCase));
-        suite.Add(typeof(AssemblyTests));
-        suite.Add(typeof(NoNamespaceTestFixture));
-        return suite;
-      }
-    }
-  }
-}
-</pre>
-
-</div>
-
-<h4>Limitations</h4>
-
-NUnit support for user-defined Suites currently has two limitations:
-
-<ol>
-	<li>It is not possible to include individual test cases directly
-	in a Suite using the new approach. Anyone wanting to do so will 
-	need to use the old approach and create an object derive from
-	NUnit.Core.TestCase. This is not recommended, since it requires
-	a reference to the core assembly.
-	
-	<li>Suites are currently not displayed in the Gui or run automatically
-	by either runner when they are encountered. The historical purpose of 
-	the Suite mechanism was to provide a way of aggregating tests at the
-	top level of each run. Hence, they are only supported when used with 
-	the /fixture option on the console or gui command line.
-</ol>
-
-Approaches to removing these limitations are being investigated as part
-of the planning for future NUnit releases.
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<ul>
-<li><a href="category.html">Category</a></li>
-<li><a href="combinatorial.html">Combinatorial</a></li>
-<li><a href="culture.html">Culture</a></li>
-<li><a href="datapoint.html">Datapoint(s)</a></li>
-<li><a href="description.html">Description</a></li>
-<li><a href="exception.html">Exception</a></li>
-<li><a href="explicit.html">Explicit</a></li>
-<li><a href="ignore.html">Ignore</a></li>
-<li><a href="maxtime.html">Maxtime</a></li>
-<li><a href="pairwise.html">Pairwise</a></li>
-<li><a href="platform.html">Platform</a></li>
-<li><a href="property.html">Property</a></li>
-<li><a href="random.html">Random</a></li>
-<li><a href="range.html">Range</a></li>
-<li><a href="repeat.html">Repeat</a></li>
-<li><a href="requiredAddin.html">RequiredAddin</a></li>
-<li><a href="requiresMTA.html">Requires&nbsp;MTA</a></li>
-<li><a href="requiresSTA.html">Requires&nbsp;STA</a></li>
-<li><a href="requiresThread.html">Requires&nbsp;Thread</a></li>
-<li><a href="sequential.html">Sequential</a></li>
-<li><a href="setCulture.html">SetCulture</a></li>
-<li><a href="setup.html">Setup</a></li>
-<li><a href="setupFixture.html">SetupFixture</a></li>
-<li id="current"><a href="suite.html">Suite</a></li>
-<li><a href="teardown.html">Teardown</a></li>
-<li><a href="test.html">Test</a></li>
-<li><a href="testCase.html">TestCase</a></li>
-<li><a href="testCaseSource.html">TestCaseSource</a></li>
-<li><a href="testFixture.html">TestFixture</a></li>
-<li><a href="fixtureSetup.html">TestFixtureSetUp</a></li>
-<li><a href="fixtureTeardown.html">TestFixtureTearDown</a></li>
-<li><a href="theory.html">Theory</a></li>
-<li><a href="timeout.html">Timeout</a></li>
-<li><a href="values.html">Values</a></li>
-<li><a href="valueSource.html">ValueSource</a></li>
-</ul>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/suiteBuilders.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/suiteBuilders.html b/lib/NUnit.org/NUnit/2.5.9/doc/suiteBuilders.html
deleted file mode 100644
index fa8b8d9..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/suiteBuilders.html
+++ /dev/null
@@ -1,101 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - SuiteBuilders</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h3>SuiteBuilders (NUnit 2.4)</h3>
-
-<h4>Purpose</h4>
-<p>A SuiteBuilder is an addin used to build a test fixture from a type. NUnit itself
-uses a SuiteBuilder to recognize and build TestFixtures. 
-
-<h4>Extension Point</h4>
-<p>An addin may use the host to access this extension point by name:
-
-<pre>
-	IExtensionPoint suiteBuilders = host.GetExtensionPoint( "SuiteBuilders" );</pre>
-
-<h4>Interface</h4>
-<p>The extension object passed to Install must implement the ISuiteBuilder interface:
-
-<pre>
-	public interface ISuiteBuilder
-	{
-		bool CanBuildFrom( Type type );
-		Test BuildFrom( Type type );
-	}
-</pre>
-
-<p>CanBuildFrom should return true if the specified Type is one from which
-the builder is able to create a fixture. This usually involve examining
-the Type and its attriutes.
-
-<p>The BuildFrom method should return a test fixture completely populated
-with its contained test cases. Return null if it is not possible to 
-build a fixture using the provided Type.
-
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<ul>
-<li><a href="customConstraints.html">Custom&nbsp;Constraints</a></li>
-<li><a href="nunitAddins.html">NUnit&nbsp;Addins</a></li>
-<ul>
-<li id="current"><a href="suiteBuilders.html">SuiteBuilders</a></li>
-<li><a href="testcaseBuilders.html">TestcaseBuilders</a></li>
-<li><a href="testDecorators.html">TestDecorators</a></li>
-<li><a href="testcaseProviders.html">TestcaseProviders</a></li>
-<li><a href="datapointProviders.html">DatapointProviders</a></li>
-<li><a href="eventListeners.html">EventListeners</a></li>
-</ul>
-<li><a href="extensionTips.html">Tips&nbsp;for&nbsp;Extenders</a></li>
-</ul>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>


[13/51] [abbrv] [partial] Cleaning up and getting ready to development towards v4.8

Posted by sy...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/typeConstraints.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/typeConstraints.html b/lib/NUnit.org/NUnit/2.5.9/doc/typeConstraints.html
deleted file mode 100644
index 992808e..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/typeConstraints.html
+++ /dev/null
@@ -1,102 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - TypeConstraints</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h2>Type Constraints (NUnit 2.4)</h2>
-
-<p>Type constraints perform tests that are specific to Types.
-The following type constraints are provided:
-
-<table class="constraints">
-<tr><th>Syntax Helper</th><th>Constructor</th><th>Operation</th></tr>
-<tr><td>Is.TypeOf( Type )</td><td>ExactTypeConstraint( Type )</td></td><td>tests that an object is an exact Type</td></tr>
-<tr><td>Is.InstanceOfType( Type )</td><td>InstanceOfTypeConstraint( Type )</td></td><td>tests that an object is an instance of a Type</td></tr>
-<tr><td>Is.AssignableFrom( Type )</td><td>AssignableFromConstraint( Type )</td></td><td>tests that one type is assignable from another</td></tr>
-</table>
-
-<h4>Examples of Use</h4>
-
-<div class="code"><pre>
-Assert.That("Hello", Is.TypeOf(typeof(string)));
-Assert.That("Hello", Is.Not.TypeOf(typeof(int)));
-
-Assert.That("Hello", Is.InstanceOfType(typeof(string)));
-Assert.That(5, Is.Not.InstanceOfType(typeof(string)));
-
-Assert.That( "Hello", Is.AssignableFrom(typeof(string)));
-Assert.That( 5, Is.Not.AssignableFrom(typeof(string)));
-
-// Using inheritance
-Expect( 5, Not.InstanceOfType(typeof(string)));
-Expect( "Hello", AssignableFrom(typeOf(string)));
-</pre></div>
-
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<ul>
-<li><a href="equalConstraint.html">Equal&nbsp;Constraint</a></li>
-<li><a href="sameasConstraint.html">SameAs&nbsp;Constraint</a></li>
-<li><a href="conditionConstraints.html">Condition&nbsp;Constraints</a></li>
-<li><a href="comparisonConstraints.html">Comparison&nbsp;Constrants</a></li>
-<li><a href="pathConstraints.html">Path&nbsp;Constraints</a></li>
-<li id="current"><a href="typeConstraints.html">Type&nbsp;Constraints</a></li>
-<li><a href="stringConstraints.html">String&nbsp;Constraints</a></li>
-<li><a href="collectionConstraints.html">Collection&nbsp;Constraints</a></li>
-<li><a href="propertyConstraint.html">Property&nbsp;Constraint</a></li>
-<li><a href="throwsConstraint.html">Throws&nbsp;Constraint</a></li>
-<li><a href="compoundConstraints.html">Compound&nbsp;Constraints</a></li>
-<li><a href="delayedConstraint.html">Delayed&nbsp;Constraint</a></li>
-<li><a href="listMapper.html">List&nbsp;Mapper</a></li>
-<li><a href="reusableConstraint.html">Reusable&nbsp;Constraint</a></li>
-</ul>
-<li><a href="attributes.html">Attributes</a></li>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/upgrade.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/upgrade.html b/lib/NUnit.org/NUnit/2.5.9/doc/upgrade.html
deleted file mode 100644
index 0f44561..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/upgrade.html
+++ /dev/null
@@ -1,98 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - Upgrade</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h2>From NUnit 2.x</h2>
-
-<p>Beginning with version 2.2.1, old style test cases ("Test....") are no longer 
-recognized by default. We recommend that you convert such test cases to use the
-<a href="test.html">TestAttribute</a>. Alternatively, you may
-specify a setting in the test config file to allow use of old style test cases by
-default.</p>
-
-<p>Beginning with NUnit 2.2.2, NUnit is able to run tests Built with older
-versions of NUnit 2.x without recompilation. Note that you must have an
-available copy of the nunit.framework assembly from the older version
-in order for your tests to load correctly.
-
-<h2>From NUnit 1.x</h2>
-
-<p>NUnit 2.5 no longer supports inheriting from TestCase when defining a test.
-   If you need to run such tests, you may continue to do so using the
-   a 2.4.x or earlier version of the nunit.framework assembly. Of course, you
-   will not be able to use new features introduced in 2.5 if you follow this
-   course.
-   
-<p>For a complete conversion to 2.5, you should modify and recompile your tests
-   using the new version of NUnit.
-
-<h3>Suite property</h3>
-<p>The NUnit 1.x Suite property will not be found by the new program. These must be 
-	changed to the &quot;Suite&quot; attribute for the test runners to find them. 
-	Another alternative is that these suites are no longer needed due to the 
-	automatic capability that is built in to the new version.</p>
-	
-<h3>AssertionFailedError</h3>
-<p>If you have written code expecting the exception AssertionFailedError, this must 
-	be changed to AssertionException.</p>
-
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<ul>
-<li><a href="quickStart.html">Quick&nbsp;Start</a></li>
-<li><a href="installation.html">Installation</a></li>
-<ul>
-<li id="current"><a href="upgrade.html">Upgrading</a></li>
-</ul>
-</ul>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/utilityAsserts.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/utilityAsserts.html b/lib/NUnit.org/NUnit/2.5.9/doc/utilityAsserts.html
deleted file mode 100644
index 3940db4..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/utilityAsserts.html
+++ /dev/null
@@ -1,125 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - UtilityAsserts</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h2>Utility Methods</h2>
-<p>Four utility methods, <b>Pass()</b>, <b>Fail()</b>, <b>Ignore()</b> and <b>Inconclusive()</b> are provided 
-   in order to allow more direct control of the test process:</p>
-<div class="code" style="width: 36em"><pre>
-Assert.Pass();
-Assert.Pass( string message );
-Assert.Pass( string message, object[] parms );
-
-Assert.Fail();
-Assert.Fail( string message );
-Assert.Fail( string message, object[] parms );
-
-Assert.Ignore();
-Assert.Ignore( string message );
-Assert.Ignore( string message, object[] parms );
-
-Assert.Inconclusive();
-Assert.Inconclusive( string message );
-Assert.Inconclusive( string message, object[] parms );</pre>
-</div>
-<p>The <b>Assert.Pass</b> method allows you to immediately end the test, recording
-	it as successful. Since it causes an exception to be thrown, it is more
-	efficient to simply allow the test to return. However, Assert.Pass allows 
-	you to record a message in the test result and may also make the test
-	easier to read in some situations. Additionally, like the other methods
-	on this page, it can be invoked from a nested method call with the
-	result of immediately terminating test execution.</p>
-<p>The <b>Assert.Fail</b> method provides you with the ability to generate a failure based 
-	on tests that are not encapsulated by the other methods. It is also useful in 
-	developing your own project-specific assertions.</p>
-<p>Here's an example of its use to create a private assertion that tests whether a 
-	string contains an expected value.</p>
-<div class="code" style="width: 36em">
-	<pre>public void AssertStringContains( string expected, string actual )
-{
-    AssertStringContains( expected, actual, string.Empty );
-}
-
-public void AssertStringContains( string expected, string actual,
-    string message )
-{
-    if ( actual.IndexOf( expected ) < 0 )
-        Assert.Fail( message );
-}</pre>
-</div>
-<p>The <b>Assert.Ignore</b> method provides you with the ability to dynamically cause a 
-	test or suite to be ignored at runtime. It may be called in a test, setup or 
-	fixture setup method. We recommend that you use this only in isolated cases. 
-	The category facility is provided for more extensive inclusion or exclusion of 
-	tests or you may elect to simply divide tests run on different occasions into 
-	different assemblies.</p>
-<p>The <b>Assert.Inconclusive</b> method indicates that the test could not be
-   completed with the data available. It should be used in situations where 
-   another run with different data might run to completion, with either a
-   success or failure outcome.
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<ul>
-<li><a href="equalityAsserts.html">Equality&nbsp;Asserts</a></li>
-<li><a href="identityAsserts.html">Identity&nbsp;Asserts</a></li>
-<li><a href="conditionAsserts.html">Condition&nbsp;Asserts</a></li>
-<li><a href="comparisonAsserts.html">Comparison&nbsp;Asserts</a></li>
-<li><a href="typeAsserts.html">Type&nbsp;Asserts</a></li>
-<li><a href="exceptionAsserts.html">Exception&nbsp;Asserts</a></li>
-<li id="current"><a href="utilityAsserts.html">Utility&nbsp;Methods</a></li>
-<li><a href="stringAssert.html">String&nbsp;Assert</a></li>
-<li><a href="collectionAssert.html">Collection&nbsp;Assert</a></li>
-<li><a href="fileAssert.html">File&nbsp;Assert</a></li>
-<li><a href="directoryAssert.html">Directory&nbsp;Assert</a></li>
-</ul>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/valueSource.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/valueSource.html b/lib/NUnit.org/NUnit/2.5.9/doc/valueSource.html
deleted file mode 100644
index e93c0f9..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/valueSource.html
+++ /dev/null
@@ -1,157 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - ValueSource</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<script language="JavaScript" src="codeFuncs.js" ></script> <!-- Do it this way for IE -->
-
-<h3>ValueSourceAttribute (NUnit 2.5)</h3>
-
-<p><b>ValueSourceAttribute</b> is used on individual parameters of a test method to
-identify a named source for the argument values to be supplied. The attribute has 
-two public constructors.
-
-<div class="code">
-<pre>
-ValueSourceAttribute(Type sourceType, string sourceName);
-ValueSourceAttribute(string sourceName);
-</pre>
-</div>
-
-<p>If <b>sourceType</b> is specified, it represents the class that provides
-the data. It must have a default constructor.
-
-<p>If <b>sourceType</b> is not specified, the class containing the test
-method is used. NUnit will construct it using either the default constructor
-or - if arguments are provided - the appropriate constructor for those 
-arguments.
-
-<p>The <b>sourceName</b>, represents the name of the source that will 
-provide the arguments. It should have the following characteristics:
-<ul>
-<li>It may be a field, a non-indexed property or a method taking no arguments.
-<li>It may be either an instance or a static member.
-<li>It must return an IEnumerable or a type that implements IEnumerable.
-<li>The individual items returned from the enumerator must be compatible
-    with the type of the parameter on which the attribute appears.
-</ul>
-
-<h3>Order of Execution</h3>
-
-<p>In NUnit 2.5, individual test cases are sorted alphabetically and executed in
-   that order. With NUnit 2.5.1, the individual cases are not sorted, but are
-   executed in the order in which NUnit discovers them. This order does <b>not</b>
-   follow the lexical order of the attributes and will often vary between different
-   compilers or different versions of the CLR.
-   
-<p>As a result, when <b>ValueSourceAttribute</b> appears multiple times on a 
-   parameter or when other data-providing attributes are used in combination with 
-   <b>ValueSourceAttribute</b>, the order of the arguments is undefined.
-
-<p>However, when a single <b>ValueSourceAttribute</b> is used by itself, 
-   the order of the arguments follows exactly the order in which the data 
-   is returned from the source.
-   
-<h3>Note on Object Construction</h3>
-
-<p>NUnit locates the test cases at the time the tests are loaded, creates
-instances of each class with non-static sources and builds a list of 
-tests to be executed. Each source object is only created once at this
-time and is destroyed after all tests are loaded. 
-
-<p>If the data source is in the test fixture itself, the object is created
-using the appropriate constructor for the fixture parameters provided on
-the <b>TestFixtureAttribute</b>, or
-the default constructor if no parameters were specified. Since this object
-is destroyed before the tests are run, no communication is possible between
-these two phases - or between different runs - except through the parameters
-themselves.
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<ul>
-<li><a href="category.html">Category</a></li>
-<li><a href="combinatorial.html">Combinatorial</a></li>
-<li><a href="culture.html">Culture</a></li>
-<li><a href="datapoint.html">Datapoint(s)</a></li>
-<li><a href="description.html">Description</a></li>
-<li><a href="exception.html">Exception</a></li>
-<li><a href="explicit.html">Explicit</a></li>
-<li><a href="ignore.html">Ignore</a></li>
-<li><a href="maxtime.html">Maxtime</a></li>
-<li><a href="pairwise.html">Pairwise</a></li>
-<li><a href="platform.html">Platform</a></li>
-<li><a href="property.html">Property</a></li>
-<li><a href="random.html">Random</a></li>
-<li><a href="range.html">Range</a></li>
-<li><a href="repeat.html">Repeat</a></li>
-<li><a href="requiredAddin.html">RequiredAddin</a></li>
-<li><a href="requiresMTA.html">Requires&nbsp;MTA</a></li>
-<li><a href="requiresSTA.html">Requires&nbsp;STA</a></li>
-<li><a href="requiresThread.html">Requires&nbsp;Thread</a></li>
-<li><a href="sequential.html">Sequential</a></li>
-<li><a href="setCulture.html">SetCulture</a></li>
-<li><a href="setup.html">Setup</a></li>
-<li><a href="setupFixture.html">SetupFixture</a></li>
-<li><a href="suite.html">Suite</a></li>
-<li><a href="teardown.html">Teardown</a></li>
-<li><a href="test.html">Test</a></li>
-<li><a href="testCase.html">TestCase</a></li>
-<li><a href="testCaseSource.html">TestCaseSource</a></li>
-<li><a href="testFixture.html">TestFixture</a></li>
-<li><a href="fixtureSetup.html">TestFixtureSetUp</a></li>
-<li><a href="fixtureTeardown.html">TestFixtureTearDown</a></li>
-<li><a href="theory.html">Theory</a></li>
-<li><a href="timeout.html">Timeout</a></li>
-<li><a href="values.html">Values</a></li>
-<li id="current"><a href="valueSource.html">ValueSource</a></li>
-</ul>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/values.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/values.html b/lib/NUnit.org/NUnit/2.5.9/doc/values.html
deleted file mode 100644
index 8bcc5d5..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/values.html
+++ /dev/null
@@ -1,131 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - Values</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h3>ValuesAttribute (NUnit 2.5)</h3>
-
-<p>The <b>ValuesAttribute</b> is used to specify a set of values to be provided
-   for an individual parameter of a parameterized test method. Since
-   NUnit combines the data provided for each parameter into a set of
-   test cases, data must be provided for all parameters if it is
-   provided for any of them.
-   
-<p>By default, NUnit creates test cases from all possible combinations
-   of the datapoints provided on parameters - the combinatorial approach.
-   This default may be modified by use of specific attributes on the
-   test method itself.
-   
-<h4>Example</h4>
-
-<p>The following test will be executed six times, as follows:
-<pre>
-	MyTest(1, "A")
-	MyTest(1, "B")
-	MyTest(2, "A")
-	MyTest(2, "B")
-	MyTest(3, "A")
-	MyTest(3, "B")
-</pre>
-<div class="code"><pre>
-[Test]
-public void MyTest(
-    [Values(1,2,3)] int x,
-    [Values("A","B")] string s)
-{
-    ...
-}
-</pre></div>
-
-<h4>See also...</h4>
-<ul>
-<li><a href="range.html">RangeAttribute</a><li><a href="random.html">RandomAttribute</a><li><a href="sequential.html">SequentialAttribute</a><li><a href="combinatorial.html">CombinatorialAttribute</a><li><a href="pairwise.html">PairwiseAttribute</a></ul>
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<ul>
-<li><a href="category.html">Category</a></li>
-<li><a href="combinatorial.html">Combinatorial</a></li>
-<li><a href="culture.html">Culture</a></li>
-<li><a href="datapoint.html">Datapoint(s)</a></li>
-<li><a href="description.html">Description</a></li>
-<li><a href="exception.html">Exception</a></li>
-<li><a href="explicit.html">Explicit</a></li>
-<li><a href="ignore.html">Ignore</a></li>
-<li><a href="maxtime.html">Maxtime</a></li>
-<li><a href="pairwise.html">Pairwise</a></li>
-<li><a href="platform.html">Platform</a></li>
-<li><a href="property.html">Property</a></li>
-<li><a href="random.html">Random</a></li>
-<li><a href="range.html">Range</a></li>
-<li><a href="repeat.html">Repeat</a></li>
-<li><a href="requiredAddin.html">RequiredAddin</a></li>
-<li><a href="requiresMTA.html">Requires&nbsp;MTA</a></li>
-<li><a href="requiresSTA.html">Requires&nbsp;STA</a></li>
-<li><a href="requiresThread.html">Requires&nbsp;Thread</a></li>
-<li><a href="sequential.html">Sequential</a></li>
-<li><a href="setCulture.html">SetCulture</a></li>
-<li><a href="setup.html">Setup</a></li>
-<li><a href="setupFixture.html">SetupFixture</a></li>
-<li><a href="suite.html">Suite</a></li>
-<li><a href="teardown.html">Teardown</a></li>
-<li><a href="test.html">Test</a></li>
-<li><a href="testCase.html">TestCase</a></li>
-<li><a href="testCaseSource.html">TestCaseSource</a></li>
-<li><a href="testFixture.html">TestFixture</a></li>
-<li><a href="fixtureSetup.html">TestFixtureSetUp</a></li>
-<li><a href="fixtureTeardown.html">TestFixtureTearDown</a></li>
-<li><a href="theory.html">Theory</a></li>
-<li><a href="timeout.html">Timeout</a></li>
-<li id="current"><a href="values.html">Values</a></li>
-<li><a href="valueSource.html">ValueSource</a></li>
-</ul>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/vsSupport.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/vsSupport.html b/lib/NUnit.org/NUnit/2.5.9/doc/vsSupport.html
deleted file mode 100644
index 7ee28e3..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/vsSupport.html
+++ /dev/null
@@ -1,144 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - VsSupport</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h2>Visual Studio Support</h2>
-
-<p>Visual Studio support in this release is a sort of �poor man�s integration.� We have implemented
-a number of features while avoiding any that would require using an Addin or otherwise
-interacting with the Visual Studio extensibility model.</p>
-
-<h3>Running From Within Visual Studio</h3>
-
-<p>The most convenient way to do this is to set up a custom tool entry specifying the path to 
-NUnit as the command. For a VS2003 C# project, you can use $(TargetPath) for the arguments and
-$(TargetDir) for the initial directory. 
-
-<p>With Visual Studio VS2005 this becomes a bit harder, because that release changed the
-meaning of the 'Target' macros so they now point to the intermediate 'obj' directories rather
-than the final output in one of the 'bin' directories. Here are some alternatives that
-work in both versions:
-
-<ul>
-<li><b>$(ProjectDir)$(ProjectFileName)</b> to open the VS Project rather than the assembly.
-    If you use this approach, be sure to rename your config file accordingly and put it
-	in the same directory as the VS project file.
-<li><b>$(ProjectDir)bin/Debug/$(TargetName)$(TargetExt)</b> to run the assembly directly.
-    Note that this requires hard-coding part of the path, including the configuration.
-</ul>
-
-<p>If you would like to debug your tests, use the Visual Studio
-Debug | Processes� menu item to attach to NUnit after starting it and set breakpoints in
-your test code as desired before running the tests.</p>
-
-<h3>Using Console Interface to Debug Applications</h3>
-
-<p>When the nunit-console program is run in debug mode under Visual Studio, it detects that it is
-running in this mode and sends output to the Visual Studio output window. Output is formatted so
-that double clicking any error or failure entries opens the appropriate test file at the location
-where the failure was detected.</p>
-
-<h3>Opening Visual Studio Projects</h3>
-
-<p>When Visual Studio support is enabled, the File Open dialog displays the following supported
-Visual Studio project types: C#, VB.Net, J# and C++. The project file is read and the
-configurations and output assembly locations are identified. Since the project files do not contain
-information about the most recently opened configuration, the output assembly for the first
-configuration found (usually Debug) is loaded in the GUI. The tree shows the project as the toplevel
-node with the assembly shown as its descendant.</p>
-
-<p>Beginning with NUnit 2.2.2, you may also open a Visual Studio project by dragging it to the gui tree control.</p>
-
-<p>When tests are run for a Visual studio project, they run just as if the output assembly had been
-loaded with one exception. The default location for the config file is the directory containing the
-project file and it�s default name is the same as the project file with an extension of .config.
-For example, the following command would load the tests in the nunit.tests assembly using the
-configuration file nunit.tests.dll.config located in the same directory as the dll.
-	<pre class="programtext">        nunit.exe nunit.tests.dll</pre>
-On the other hand, the following command would load the tests using the configuration file
-nunit.tests.config located in the same directory as the csproj file.
-      <pre class="programtext">        nunit.exe nunit.tests.csproj</pre>
-The same consideration applies to running tests using the console runner.</p>
-
-<h3>Opening Visual Studio Solutions</h3>
-
-<p>When Visual Studio support is enabled, solution files may be opened as well. All the output
-assemblies from contained projects of the types supported will be loaded in the tree. In the case
-where all contained projects are located in the subdirectories beneath the solution, it will be
-possible to load and run tests using this method directly.</p>
-
-<p>Beginning with NUnit 2.2.2, you may also open a Visual Studio solution by dragging it to the gui tree control.</p>
-
-<p>When a solution contains projects located elsewhere in the file system, it may not be possible to
-run the tests � although the solution will generally load without problem. In this case, the Project
-Editor should be use to modify and save the NUnit test project so that there is all referenced
-assemblies are located in or beneath the application base directory.</p>
-
-<h3>Adding Visual Studio Projects to the Open Test Project</h3>
-
-<p>When Visual Studio support is enabled, the Project menu contains an active entry to add a VS
-project to the loaded project. The output assembly will be added for each of the configurations
-specified in the VS project.</p>
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<ul>
-<li><a href="nunit-console.html">Console&nbsp;Runner</a></li>
-<li><a href="nunit-gui.html">Gui&nbsp;Runner</a></li>
-<li><a href="pnunit.html">PNUnit&nbsp;Runner</a></li>
-<li><a href="runtimeSelection.html">Runtime&nbsp;Selection</a></li>
-<li><a href="assemblyIsolation.html">Assembly&nbsp;Isolation</a></li>
-<li><a href="configFiles.html">Configuration&nbsp;Files</a></li>
-<li><a href="multiAssembly.html">Multiple&nbsp;Assemblies</a></li>
-<li id="current"><a href="vsSupport.html">Visual&nbsp;Studio&nbsp;Support</a></li>
-</ul>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/fit-license.txt
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/fit-license.txt b/lib/NUnit.org/NUnit/2.5.9/fit-license.txt
deleted file mode 100644
index d5bdfa2..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/fit-license.txt
+++ /dev/null
@@ -1,342 +0,0 @@
-
-
-		    GNU GENERAL PUBLIC LICENSE
-		       Version 2, June 1991
-
- Copyright (C) 1989, 1991 Free Software Foundation, Inc.
-                       59 Temple Place, Suite 330, Boston, MA  02111-1307  USA
- Everyone is permitted to copy and distribute verbatim copies
- of this license document, but changing it is not allowed.
-
-			    Preamble
-
-  The licenses for most software are designed to take away your
-freedom to share and change it.  By contrast, the GNU General Public
-License is intended to guarantee your freedom to share and change free
-software--to make sure the software is free for all its users.  This
-General Public License applies to most of the Free Software
-Foundation's software and to any other program whose authors commit to
-using it.  (Some other Free Software Foundation software is covered by
-the GNU Library General Public License instead.)  You can apply it to
-your programs, too.
-
-  When we speak of free software, we are referring to freedom, not
-price.  Our General Public Licenses are designed to make sure that you
-have the freedom to distribute copies of free software (and charge for
-this service if you wish), that you receive source code or can get it
-if you want it, that you can change the software or use pieces of it
-in new free programs; and that you know you can do these things.
-
-  To protect your rights, we need to make restrictions that forbid
-anyone to deny you these rights or to ask you to surrender the rights.
-These restrictions translate to certain responsibilities for you if you
-distribute copies of the software, or if you modify it.
-
-  For example, if you distribute copies of such a program, whether
-gratis or for a fee, you must give the recipients all the rights that
-you have.  You must make sure that they, too, receive or can get the
-source code.  And you must show them these terms so they know their
-rights.
-
-  We protect your rights with two steps: (1) copyright the software, and
-(2) offer you this license which gives you legal permission to copy,
-distribute and/or modify the software.
-
-  Also, for each author's protection and ours, we want to make certain
-that everyone understands that there is no warranty for this free
-software.  If the software is modified by someone else and passed on, we
-want its recipients to know that what they have is not the original, so
-that any problems introduced by others will not reflect on the original
-authors' reputations.
-
-  Finally, any free program is threatened constantly by software
-patents.  We wish to avoid the danger that redistributors of a free
-program will individually obtain patent licenses, in effect making the
-program proprietary.  To prevent this, we have made it clear that any
-patent must be licensed for everyone's free use or not licensed at all.
-
-  The precise terms and conditions for copying, distribution and
-modification follow.
-
-		    GNU GENERAL PUBLIC LICENSE
-   TERMS AND CONDITIONS FOR COPYING, DISTRIBUTION AND MODIFICATION
-
-  0. This License applies to any program or other work which contains
-a notice placed by the copyright holder saying it may be distributed
-under the terms of this General Public License.  The "Program", below,
-refers to any such program or work, and a "work based on the Program"
-means either the Program or any derivative work under copyright law:
-that is to say, a work containing the Program or a portion of it,
-either verbatim or with modifications and/or translated into another
-language.  (Hereinafter, translation is included without limitation in
-the term "modification".)  Each licensee is addressed as "you".
-
-Activities other than copying, distribution and modification are not
-covered by this License; they are outside its scope.  The act of
-running the Program is not restricted, and the output from the Program
-is covered only if its contents constitute a work based on the
-Program (independent of having been made by running the Program).
-Whether that is true depends on what the Program does.
-
-  1. You may copy and distribute verbatim copies of the Program's
-source code as you receive it, in any medium, provided that you
-conspicuously and appropriately publish on each copy an appropriate
-copyright notice and disclaimer of warranty; keep intact all the
-notices that refer to this License and to the absence of any warranty;
-and give any other recipients of the Program a copy of this License
-along with the Program.
-
-You may charge a fee for the physical act of transferring a copy, and
-you may at your option offer warranty protection in exchange for a fee.
-
-  2. You may modify your copy or copies of the Program or any portion
-of it, thus forming a work based on the Program, and copy and
-distribute such modifications or work under the terms of Section 1
-above, provided that you also meet all of these conditions:
-
-    a) You must cause the modified files to carry prominent notices
-    stating that you changed the files and the date of any change.
-
-    b) You must cause any work that you distribute or publish, that in
-    whole or in part contains or is derived from the Program or any
-    part thereof, to be licensed as a whole at no charge to all third
-    parties under the terms of this License.
-
-    c) If the modified program normally reads commands interactively
-    when run, you must cause it, when started running for such
-    interactive use in the most ordinary way, to print or display an
-    announcement including an appropriate copyright notice and a
-    notice that there is no warranty (or else, saying that you provide
-    a warranty) and that users may redistribute the program under
-    these conditions, and telling the user how to view a copy of this
-    License.  (Exception: if the Program itself is interactive but
-    does not normally print such an announcement, your work based on
-    the Program is not required to print an announcement.)
-
-These requirements apply to the modified work as a whole.  If
-identifiable sections of that work are not derived from the Program,
-and can be reasonably considered independent and separate works in
-themselves, then this License, and its terms, do not apply to those
-sections when you distribute them as separate works.  But when you
-distribute the same sections as part of a whole which is a work based
-on the Program, the distribution of the whole must be on the terms of
-this License, whose permissions for other licensees extend to the
-entire whole, and thus to each and every part regardless of who wrote it.
-
-Thus, it is not the intent of this section to claim rights or contest
-your rights to work written entirely by you; rather, the intent is to
-exercise the right to control the distribution of derivative or
-collective works based on the Program.
-
-In addition, mere aggregation of another work not based on the Program
-with the Program (or with a work based on the Program) on a volume of
-a storage or distribution medium does not bring the other work under
-the scope of this License.
-
-  3. You may copy and distribute the Program (or a work based on it,
-under Section 2) in object code or executable form under the terms of
-Sections 1 and 2 above provided that you also do one of the following:
-
-    a) Accompany it with the complete corresponding machine-readable
-    source code, which must be distributed under the terms of Sections
-    1 and 2 above on a medium customarily used for software interchange; or,
-
-    b) Accompany it with a written offer, valid for at least three
-    years, to give any third party, for a charge no more than your
-    cost of physically performing source distribution, a complete
-    machine-readable copy of the corresponding source code, to be
-    distributed under the terms of Sections 1 and 2 above on a medium
-    customarily used for software interchange; or,
-
-    c) Accompany it with the information you received as to the offer
-    to distribute corresponding source code.  (This alternative is
-    allowed only for noncommercial distribution and only if you
-    received the program in object code or executable form with such
-    an offer, in accord with Subsection b above.)
-
-The source code for a work means the preferred form of the work for
-making modifications to it.  For an executable work, complete source
-code means all the source code for all modules it contains, plus any
-associated interface definition files, plus the scripts used to
-control compilation and installation of the executable.  However, as a
-special exception, the source code distributed need not include
-anything that is normally distributed (in either source or binary
-form) with the major components (compiler, kernel, and so on) of the
-operating system on which the executable runs, unless that component
-itself accompanies the executable.
-
-If distribution of executable or object code is made by offering
-access to copy from a designated place, then offering equivalent
-access to copy the source code from the same place counts as
-distribution of the source code, even though third parties are not
-compelled to copy the source along with the object code.
-
-  4. You may not copy, modify, sublicense, or distribute the Program
-except as expressly provided under this License.  Any attempt
-otherwise to copy, modify, sublicense or distribute the Program is
-void, and will automatically terminate your rights under this License.
-However, parties who have received copies, or rights, from you under
-this License will not have their licenses terminated so long as such
-parties remain in full compliance.
-
-  5. You are not required to accept this License, since you have not
-signed it.  However, nothing else grants you permission to modify or
-distribute the Program or its derivative works.  These actions are
-prohibited by law if you do not accept this License.  Therefore, by
-modifying or distributing the Program (or any work based on the
-Program), you indicate your acceptance of this License to do so, and
-all its terms and conditions for copying, distributing or modifying
-the Program or works based on it.
-
-  6. Each time you redistribute the Program (or any work based on the
-Program), the recipient automatically receives a license from the
-original licensor to copy, distribute or modify the Program subject to
-these terms and conditions.  You may not impose any further
-restrictions on the recipients' exercise of the rights granted herein.
-You are not responsible for enforcing compliance by third parties to
-this License.
-
-  7. If, as a consequence of a court judgment or allegation of patent
-infringement or for any other reason (not limited to patent issues),
-conditions are imposed on you (whether by court order, agreement or
-otherwise) that contradict the conditions of this License, they do not
-excuse you from the conditions of this License.  If you cannot
-distribute so as to satisfy simultaneously your obligations under this
-License and any other pertinent obligations, then as a consequence you
-may not distribute the Program at all.  For example, if a patent
-license would not permit royalty-free redistribution of the Program by
-all those who receive copies directly or indirectly through you, then
-the only way you could satisfy both it and this License would be to
-refrain entirely from distribution of the Program.
-
-If any portion of this section is held invalid or unenforceable under
-any particular circumstance, the balance of the section is intended to
-apply and the section as a whole is intended to apply in other
-circumstances.
-
-It is not the purpose of this section to induce you to infringe any
-patents or other property right claims or to contest validity of any
-such claims; this section has the sole purpose of protecting the
-integrity of the free software distribution system, which is
-implemented by public license practices.  Many people have made
-generous contributions to the wide range of software distributed
-through that system in reliance on consistent application of that
-system; it is up to the author/donor to decide if he or she is willing
-to distribute software through any other system and a licensee cannot
-impose that choice.
-
-This section is intended to make thoroughly clear what is believed to
-be a consequence of the rest of this License.
-
-  8. If the distribution and/or use of the Program is restricted in
-certain countries either by patents or by copyrighted interfaces, the
-original copyright holder who places the Program under this License
-may add an explicit geographical distribution limitation excluding
-those countries, so that distribution is permitted only in or among
-countries not thus excluded.  In such case, this License incorporates
-the limitation as if written in the body of this License.
-
-  9. The Free Software Foundation may publish revised and/or new versions
-of the General Public License from time to time.  Such new versions will
-be similar in spirit to the present version, but may differ in detail to
-address new problems or concerns.
-
-Each version is given a distinguishing version number.  If the Program
-specifies a version number of this License which applies to it and "any
-later version", you have the option of following the terms and conditions
-either of that version or of any later version published by the Free
-Software Foundation.  If the Program does not specify a version number of
-this License, you may choose any version ever published by the Free Software
-Foundation.
-
-  10. If you wish to incorporate parts of the Program into other free
-programs whose distribution conditions are different, write to the author
-to ask for permission.  For software which is copyrighted by the Free
-Software Foundation, write to the Free Software Foundation; we sometimes
-make exceptions for this.  Our decision will be guided by the two goals
-of preserving the free status of all derivatives of our free software and
-of promoting the sharing and reuse of software generally.
-
-			    NO WARRANTY
-
-  11. BECAUSE THE PROGRAM IS LICENSED FREE OF CHARGE, THERE IS NO WARRANTY
-FOR THE PROGRAM, TO THE EXTENT PERMITTED BY APPLICABLE LAW.  EXCEPT WHEN
-OTHERWISE STATED IN WRITING THE COPYRIGHT HOLDERS AND/OR OTHER PARTIES
-PROVIDE THE PROGRAM "AS IS" WITHOUT WARRANTY OF ANY KIND, EITHER EXPRESSED
-OR IMPLIED, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED WARRANTIES OF
-MERCHANTABILITY AND FITNESS FOR A PARTICULAR PURPOSE.  THE ENTIRE RISK AS
-TO THE QUALITY AND PERFORMANCE OF THE PROGRAM IS WITH YOU.  SHOULD THE
-PROGRAM PROVE DEFECTIVE, YOU ASSUME THE COST OF ALL NECESSARY SERVICING,
-REPAIR OR CORRECTION.
-
-  12. IN NO EVENT UNLESS REQUIRED BY APPLICABLE LAW OR AGREED TO IN WRITING
-WILL ANY COPYRIGHT HOLDER, OR ANY OTHER PARTY WHO MAY MODIFY AND/OR
-REDISTRIBUTE THE PROGRAM AS PERMITTED ABOVE, BE LIABLE TO YOU FOR DAMAGES,
-INCLUDING ANY GENERAL, SPECIAL, INCIDENTAL OR CONSEQUENTIAL DAMAGES ARISING
-OUT OF THE USE OR INABILITY TO USE THE PROGRAM (INCLUDING BUT NOT LIMITED
-TO LOSS OF DATA OR DATA BEING RENDERED INACCURATE OR LOSSES SUSTAINED BY
-YOU OR THIRD PARTIES OR A FAILURE OF THE PROGRAM TO OPERATE WITH ANY OTHER
-PROGRAMS), EVEN IF SUCH HOLDER OR OTHER PARTY HAS BEEN ADVISED OF THE
-POSSIBILITY OF SUCH DAMAGES.
-
-		     END OF TERMS AND CONDITIONS
-
-	    How to Apply These Terms to Your New Programs
-
-  If you develop a new program, and you want it to be of the greatest
-possible use to the public, the best way to achieve this is to make it
-free software which everyone can redistribute and change under these terms.
-
-  To do so, attach the following notices to the program.  It is safest
-to attach them to the start of each source file to most effectively
-convey the exclusion of warranty; and each file should have at least
-the "copyright" line and a pointer to where the full notice is found.
-
-    <one line to give the program's name and a brief idea of what it does.>
-    Copyright (C) <year>  <name of author>
-
-    This program is free software; you can redistribute it and/or modify
-    it under the terms of the GNU General Public License as published by
-    the Free Software Foundation; either version 2 of the License, or
-    (at your option) any later version.
-
-    This program is distributed in the hope that it will be useful,
-    but WITHOUT ANY WARRANTY; without even the implied warranty of
-    MERCHANTABILITY or FITNESS FOR A PARTICULAR PURPOSE.  See the
-    GNU General Public License for more details.
-
-    You should have received a copy of the GNU General Public License
-    along with this program; if not, write to the Free Software
-    Foundation, Inc., 59 Temple Place, Suite 330, Boston, MA  02111-1307  USA
-
-
-Also add information on how to contact you by electronic and paper mail.
-
-If the program is interactive, make it output a short notice like this
-when it starts in an interactive mode:
-
-    Gnomovision version 69, Copyright (C) year name of author
-    Gnomovision comes with ABSOLUTELY NO WARRANTY; for details type `show w'.
-    This is free software, and you are welcome to redistribute it
-    under certain conditions; type `show c' for details.
-
-The hypothetical commands `show w' and `show c' should show the appropriate
-parts of the General Public License.  Of course, the commands you use may
-be called something other than `show w' and `show c'; they could even be
-mouse-clicks or menu items--whatever suits your program.
-
-You should also get your employer (if you work as a programmer) or your
-school, if any, to sign a "copyright disclaimer" for the program, if
-necessary.  Here is a sample; alter the names:
-
-  Yoyodyne, Inc., hereby disclaims all copyright interest in the program
-  `Gnomovision' (which makes passes at compilers) written by James Hacker.
-
-  <signature of Ty Coon>, 1 April 1989
-  Ty Coon, President of Vice
-
-This General Public License does not permit incorporating your program into
-proprietary programs.  If your program is a subroutine library, you may
-consider it more useful to permit linking proprietary applications with the
-library.  If this is what you want to do, use the GNU Library General
-Public License instead of this License.

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/license.txt
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/license.txt b/lib/NUnit.org/NUnit/2.5.9/license.txt
deleted file mode 100644
index 66a5ebf..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/license.txt
+++ /dev/null
@@ -1,15 +0,0 @@
-Copyright � 2002-2008 Charlie Poole
-Copyright � 2002-2004 James W. Newkirk, Michael C. Two, Alexei A. Vorontsov
-Copyright � 2000-2002 Philip A. Craig
-
-This software is provided 'as-is', without any express or implied warranty. In no event will the authors be held liable for any damages arising from the use of this software.
-
-Permission is granted to anyone to use this software for any purpose, including commercial applications, and to alter it and redistribute it freely, subject to the following restrictions:
-
-1. The origin of this software must not be misrepresented; you must not claim that you wrote the original software. If you use this software in a product, an acknowledgment (see the following) in the product documentation is required.
-
-Portions Copyright � 2002-2008 Charlie Poole or Copyright � 2002-2004 James W. Newkirk, Michael C. Two, Alexei A. Vorontsov or Copyright � 2000-2002 Philip A. Craig
-
-2. Altered source versions must be plainly marked as such, and must not be misrepresented as being the original software.
-
-3. This notice may not be removed or altered from any source distribution.

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/CoreExtensibility.sln
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/CoreExtensibility.sln b/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/CoreExtensibility.sln
deleted file mode 100644
index 6e5ae57..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/CoreExtensibility.sln
+++ /dev/null
@@ -1,53 +0,0 @@
-Microsoft Visual Studio Solution File, Format Version 8.00
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Minimal", "Minimal\Minimal.csproj", "{EF428E5B-B3E7-4C2F-B005-98DE7D6E7CDB}"
-	ProjectSection(ProjectDependencies) = postProject
-	EndProjectSection
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "SampleFixtureExtension", "SampleFixtureExtension\SampleFixtureExtension.csproj", "{ED281A23-9579-4A70-B608-1B86DCDEB78C}"
-	ProjectSection(ProjectDependencies) = postProject
-	EndProjectSection
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "SampleFixtureExtensionTests", "SampleFixtureExtension\Tests\SampleFixtureExtensionTests.csproj", "{0DE6C90F-BB74-4BC8-887A-2222DB56D2EB}"
-	ProjectSection(ProjectDependencies) = postProject
-	EndProjectSection
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "SampleSuiteExtension", "SampleSuiteExtension\SampleSuiteExtension.csproj", "{0C4269EE-3266-45DD-9062-E356C067FBEF}"
-	ProjectSection(ProjectDependencies) = postProject
-	EndProjectSection
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "SampleSuiteExtensionTests", "SampleSuiteExtension\Tests\SampleSuiteExtensionTests.csproj", "{9F609A0D-FF7E-4F0C-B2DF-417EBC557CFF}"
-	ProjectSection(ProjectDependencies) = postProject
-	EndProjectSection
-EndProject
-Global
-	GlobalSection(SolutionConfiguration) = preSolution
-		Debug = Debug
-		Release = Release
-	EndGlobalSection
-	GlobalSection(ProjectConfiguration) = postSolution
-		{EF428E5B-B3E7-4C2F-B005-98DE7D6E7CDB}.Debug.ActiveCfg = Debug|.NET
-		{EF428E5B-B3E7-4C2F-B005-98DE7D6E7CDB}.Debug.Build.0 = Debug|.NET
-		{EF428E5B-B3E7-4C2F-B005-98DE7D6E7CDB}.Release.ActiveCfg = Release|.NET
-		{EF428E5B-B3E7-4C2F-B005-98DE7D6E7CDB}.Release.Build.0 = Release|.NET
-		{ED281A23-9579-4A70-B608-1B86DCDEB78C}.Debug.ActiveCfg = Debug|.NET
-		{ED281A23-9579-4A70-B608-1B86DCDEB78C}.Debug.Build.0 = Debug|.NET
-		{ED281A23-9579-4A70-B608-1B86DCDEB78C}.Release.ActiveCfg = Release|.NET
-		{ED281A23-9579-4A70-B608-1B86DCDEB78C}.Release.Build.0 = Release|.NET
-		{0DE6C90F-BB74-4BC8-887A-2222DB56D2EB}.Debug.ActiveCfg = Debug|.NET
-		{0DE6C90F-BB74-4BC8-887A-2222DB56D2EB}.Debug.Build.0 = Debug|.NET
-		{0DE6C90F-BB74-4BC8-887A-2222DB56D2EB}.Release.ActiveCfg = Release|.NET
-		{0DE6C90F-BB74-4BC8-887A-2222DB56D2EB}.Release.Build.0 = Release|.NET
-		{0C4269EE-3266-45DD-9062-E356C067FBEF}.Debug.ActiveCfg = Debug|.NET
-		{0C4269EE-3266-45DD-9062-E356C067FBEF}.Debug.Build.0 = Debug|.NET
-		{0C4269EE-3266-45DD-9062-E356C067FBEF}.Release.ActiveCfg = Release|.NET
-		{0C4269EE-3266-45DD-9062-E356C067FBEF}.Release.Build.0 = Release|.NET
-		{9F609A0D-FF7E-4F0C-B2DF-417EBC557CFF}.Debug.ActiveCfg = Debug|.NET
-		{9F609A0D-FF7E-4F0C-B2DF-417EBC557CFF}.Debug.Build.0 = Debug|.NET
-		{9F609A0D-FF7E-4F0C-B2DF-417EBC557CFF}.Release.ActiveCfg = Release|.NET
-		{9F609A0D-FF7E-4F0C-B2DF-417EBC557CFF}.Release.Build.0 = Release|.NET
-	EndGlobalSection
-	GlobalSection(ExtensibilityGlobals) = postSolution
-	EndGlobalSection
-	GlobalSection(ExtensibilityAddIns) = postSolution
-	EndGlobalSection
-EndGlobal

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/Minimal/Minimal.build
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/Minimal/Minimal.build b/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/Minimal/Minimal.build
deleted file mode 100644
index f92d521..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/Minimal/Minimal.build
+++ /dev/null
@@ -1,21 +0,0 @@
-<?xml version="1.0"?>
-<project name="Minimal" default="build" basedir=".">
-
-  <include buildfile="../../../samples.common" />
-
-  <patternset id="source-files">
-    <include name="Minimal.cs" />
-  </patternset>
-
-  <target name="packagex">
-    <copy todir="${package.samples.dir}/Extensibility/Core/Minimal">
-      <fileset basedir=".">
-        <include name="Minimal.csproj" />
-        <include name="Minimal.build" />
-        <include name="Readme.txt" />
-        <patternset refid="source-files" />
-      </fileset>
-    </copy>
-  </target>
-
-</project>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/Minimal/Minimal.cs
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/Minimal/Minimal.cs b/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/Minimal/Minimal.cs
deleted file mode 100644
index 17b4bdb..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/Minimal/Minimal.cs
+++ /dev/null
@@ -1,36 +0,0 @@
-// ****************************************************************
-// Copyright 2007, Charlie Poole
-// This is free software licensed under the NUnit license. You may
-// obtain a copy of the license at http://nunit.org/?p=license&r=2.4
-// ****************************************************************
-
-using System;
-using NUnit.Core.Extensibility;
-
-namespace NUnit.Samples.Extensibility
-{
-	/// <summary>
-	/// This is the smallest possible Addin, which does nothing 
-	/// but is recognized by NUnit and listed in the Addins dialog.
-	/// 
-	/// The Addin class is marked by the NUnitAddin attribute and
-	/// implements IAddin, as required. Optional property syntax
-	/// is used here to override the default name of the addin and
-	/// to provide a description. Both are displayed by NUnit in the
-	/// Addin Dialog.
-	/// 
-	/// The addin doesn't actually install anything, but simply
-	/// returns false in its Install method.
-	/// </summary>
-	[NUnitAddin(Name="Minimal Addin", Description="This Addin doesn't do anything")]
-	public class Minimal : IAddin
-	{
-		#region IAddin Members
-		public bool Install(IExtensionHost host)
-		{
-			// TODO:  Add Minimal.Install implementation
-			return true;
-		}
-		#endregion
-	}
-}

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/Minimal/Minimal.csproj
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/Minimal/Minimal.csproj b/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/Minimal/Minimal.csproj
deleted file mode 100644
index f6677e1..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/Minimal/Minimal.csproj
+++ /dev/null
@@ -1,89 +0,0 @@
-<VisualStudioProject>
-    <CSHARP
-        ProjectType = "Local"
-        ProductVersion = "7.10.3077"
-        SchemaVersion = "2.0"
-        ProjectGuid = "{EF428E5B-B3E7-4C2F-B005-98DE7D6E7CDB}"
-    >
-        <Build>
-            <Settings
-                ApplicationIcon = ""
-                AssemblyKeyContainerName = ""
-                AssemblyName = "Minimal"
-                AssemblyOriginatorKeyFile = ""
-                DefaultClientScript = "JScript"
-                DefaultHTMLPageLayout = "Grid"
-                DefaultTargetSchema = "IE50"
-                DelaySign = "false"
-                OutputType = "Library"
-                PreBuildEvent = ""
-                PostBuildEvent = ""
-                RootNamespace = "NUnit.Samples.Extensibility"
-                RunPostBuildEvent = "OnBuildSuccess"
-                StartupObject = ""
-            >
-                <Config
-                    Name = "Debug"
-                    AllowUnsafeBlocks = "false"
-                    BaseAddress = "285212672"
-                    CheckForOverflowUnderflow = "false"
-                    ConfigurationOverrideFile = ""
-                    DefineConstants = "DEBUG;TRACE"
-                    DocumentationFile = ""
-                    DebugSymbols = "true"
-                    FileAlignment = "4096"
-                    IncrementalBuild = "false"
-                    NoStdLib = "false"
-                    NoWarn = ""
-                    Optimize = "false"
-                    OutputPath = "bin\Debug\"
-                    RegisterForComInterop = "false"
-                    RemoveIntegerChecks = "false"
-                    TreatWarningsAsErrors = "false"
-                    WarningLevel = "4"
-                />
-                <Config
-                    Name = "Release"
-                    AllowUnsafeBlocks = "false"
-                    BaseAddress = "285212672"
-                    CheckForOverflowUnderflow = "false"
-                    ConfigurationOverrideFile = ""
-                    DefineConstants = "TRACE"
-                    DocumentationFile = ""
-                    DebugSymbols = "false"
-                    FileAlignment = "4096"
-                    IncrementalBuild = "false"
-                    NoStdLib = "false"
-                    NoWarn = ""
-                    Optimize = "true"
-                    OutputPath = "bin\Release\"
-                    RegisterForComInterop = "false"
-                    RemoveIntegerChecks = "false"
-                    TreatWarningsAsErrors = "false"
-                    WarningLevel = "4"
-                />
-            </Settings>
-            <References>
-                <Reference
-                    Name = "System"
-                    AssemblyName = "System"
-                />
-                <Reference
-                    Name = "nunit.core.interfaces"
-                    AssemblyName = "nunit.core.interfaces"
-                    HintPath = "..\..\..\..\solutions\vs2003\NUnitCore\interfaces\bin\Debug\nunit.core.interfaces.dll"
-                />
-            </References>
-        </Build>
-        <Files>
-            <Include>
-                <File
-                    RelPath = "Minimal.cs"
-                    SubType = "Code"
-                    BuildAction = "Compile"
-                />
-            </Include>
-        </Files>
-    </CSHARP>
-</VisualStudioProject>
-

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/Minimal/ReadMe.txt
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/Minimal/ReadMe.txt b/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/Minimal/ReadMe.txt
deleted file mode 100644
index 901df80..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/Minimal/ReadMe.txt
+++ /dev/null
@@ -1,27 +0,0 @@
-Minimal Addin Example
-
-
-MinimalAddin Class
-
-This class represents the addin. It is marked by the NUnitAddinAttribute
-and implements the required IAddin interface. When called by NUnit to
-install itself, it simply returns false.
-
-Note on Building this Extension
-
-If you use the Visual Studio solution, the NUnit references in both
-included projects must be changed so that they refer to the copy of 
-NUnit in which you want to install the extension. The post-build step 
-for the SampleSuiteExtension project must be changed to copy the 
-extension into the addins directory for your NUnit install.
-
-NOTE:
-
-The references to nunit.core and nunit.common in the 
-SampleSuiteExtension project have their Copy Local property set to 
-false, rather than the Visual Studio default of true. In developing
-extensions, it is essential there be no extra copies of these assemblies
-be created. Once the extension is complete, those who install it in
-binary form will not need to deal with this issue.
-
-

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleFixtureExtension/AssemblyInfo.cs
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleFixtureExtension/AssemblyInfo.cs b/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleFixtureExtension/AssemblyInfo.cs
deleted file mode 100644
index 9f89a32..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleFixtureExtension/AssemblyInfo.cs
+++ /dev/null
@@ -1,58 +0,0 @@
-using System.Reflection;
-using System.Runtime.CompilerServices;
-
-//
-// General Information about an assembly is controlled through the following 
-// set of attributes. Change these attribute values to modify the information
-// associated with an assembly.
-//
-[assembly: AssemblyTitle("")]
-[assembly: AssemblyDescription("")]
-[assembly: AssemblyConfiguration("")]
-[assembly: AssemblyCompany("")]
-[assembly: AssemblyProduct("")]
-[assembly: AssemblyCopyright("")]
-[assembly: AssemblyTrademark("")]
-[assembly: AssemblyCulture("")]		
-
-//
-// Version information for an assembly consists of the following four values:
-//
-//      Major Version
-//      Minor Version 
-//      Build Number
-//      Revision
-//
-// You can specify all the values or you can default the Revision and Build Numbers 
-// by using the '*' as shown below:
-
-[assembly: AssemblyVersion("1.0.*")]
-
-//
-// In order to sign your assembly you must specify a key to use. Refer to the 
-// Microsoft .NET Framework documentation for more information on assembly signing.
-//
-// Use the attributes below to control which key is used for signing. 
-//
-// Notes: 
-//   (*) If no key is specified, the assembly is not signed.
-//   (*) KeyName refers to a key that has been installed in the Crypto Service
-//       Provider (CSP) on your machine. KeyFile refers to a file which contains
-//       a key.
-//   (*) If the KeyFile and the KeyName values are both specified, the 
-//       following processing occurs:
-//       (1) If the KeyName can be found in the CSP, that key is used.
-//       (2) If the KeyName does not exist and the KeyFile does exist, the key 
-//           in the KeyFile is installed into the CSP and used.
-//   (*) In order to create a KeyFile, you can use the sn.exe (Strong Name) utility.
-//       When specifying the KeyFile, the location of the KeyFile should be
-//       relative to the project output directory which is
-//       %Project Directory%\obj\<configuration>. For example, if your KeyFile is
-//       located in the project directory, you would specify the AssemblyKeyFile 
-//       attribute as [assembly: AssemblyKeyFile("..\\..\\mykey.snk")]
-//   (*) Delay Signing is an advanced option - see the Microsoft .NET Framework
-//       documentation for more information on this.
-//
-[assembly: AssemblyDelaySign(false)]
-[assembly: AssemblyKeyFile("")]
-[assembly: AssemblyKeyName("")]

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleFixtureExtension/ReadMe.txt
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleFixtureExtension/ReadMe.txt b/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleFixtureExtension/ReadMe.txt
deleted file mode 100644
index 11fb204..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleFixtureExtension/ReadMe.txt
+++ /dev/null
@@ -1,43 +0,0 @@
-SampleSuiteExtension Example
-
-This is a minimal example of a SuiteBuilder extension. It extends 
-NUnit.Core.TestSuite test suite and creates a fixture that runs every 
-test starting with "SampleTest..." It packages both the core extension
-and the attribute used in the tests in the same assembly.
-
-SampleSuiteExtension Class
-
-This class derives from NUnit.Framework.TestSuite and represents the
-extended suite within NUnit. Because it inherits from TestSuite,
-rather than TestFixture, it has to construct its own fixture object and 
-find its own tests. Everything is done in the constructor for simplicity.
-
-SampleSuiteExtensionBuilder
-
-This class is the actual SuiteBuilder loaded by NUnit as an add-in.
-It recognizes the SampleSuiteExtensionAttribute and invokes the
-SampleSuiteExtension constructor to build the suite.
-
-SampleSuiteExtensionAttribute
-
-This is the special attribute used to mark tests to be constructed
-using this add-in. It is the only class referenced from the user tests.
-
-Note on Building this Extension
-
-If you use the Visual Studio solution, the NUnit references in both
-included projects must be changed so that they refer to the copy of 
-NUnit in which you want to install the extension. The post-build step 
-for the SampleSuiteExtension project must be changed to copy the 
-extension into the addins directory for your NUnit install.
-
-NOTE:
-
-The references to nunit.core and nunit.common in the 
-SampleSuiteExtension project have their Copy Local property set to 
-false, rather than the Visual Studio default of true. In developing
-extensions, it is essential there be no extra copies of these assemblies
-be created. Once the extension is complete, those who install it in
-binary form will not need to deal with this issue.
-
-

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleFixtureExtension/SampleFixtureExtension.build
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleFixtureExtension/SampleFixtureExtension.build b/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleFixtureExtension/SampleFixtureExtension.build
deleted file mode 100644
index 474d4aa..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleFixtureExtension/SampleFixtureExtension.build
+++ /dev/null
@@ -1,18 +0,0 @@
-<?xml version="1.0"?>
-<project name="SampleFixtureExtension" default="build" basedir=".">
-
-  <include buildfile="../../../samples.common" />
-
-  <patternset id="source-files">
-    <include name="AssemblyInfo.cs" />
-    <include name="SampleFixtureExtension.cs" />
-    <include name="SampleFixtureExtensionAttribute.cs" />
-    <include name="SampleFixtureExtensionBuilder.cs" />
-  </patternset>
-
-  <patternset id="test-files">
-    <include name="AssemblyInfo.cs" />
-    <include name="SampleFixtureExtensionTests.cs" />
-  </patternset>
-  
-</project>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleFixtureExtension/SampleFixtureExtension.cs
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleFixtureExtension/SampleFixtureExtension.cs b/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleFixtureExtension/SampleFixtureExtension.cs
deleted file mode 100644
index 8359d2f..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleFixtureExtension/SampleFixtureExtension.cs
+++ /dev/null
@@ -1,44 +0,0 @@
-// ****************************************************************
-// Copyright 2007, Charlie Poole
-// This is free software licensed under the NUnit license. You may
-// obtain a copy of the license at http://nunit.org/?p=license&r=2.4
-// ****************************************************************
-
-using System;
-
-namespace NUnit.Core.Extensions
-{
-	/// <summary>
-	/// SampleFixtureExtension extends NUnitTestFixture and adds a custom setup
-	/// before running TestFixtureSetUp and after running TestFixtureTearDown.
-	/// Because it inherits from NUnitTestFixture, a lot of work is done for it.
-	/// </summary>
-	class SampleFixtureExtension : NUnitTestFixture
-	{
-		public SampleFixtureExtension( Type fixtureType ) 
-			: base( fixtureType )
-		{
-			// NOTE: Since we are inheriting from NUnitTestFixture we don't 
-			// have to do anything if we don't want to. All the attributes
-			// that are normally used with an NUnitTestFixture will be
-			// recognized.
-			//
-			// Just to have something to do, we override DoOneTimeSetUp and 
-			// DoOneTimeTearDown below to do some special processing before 
-			// and after the normal TestFixtureSetUp and TestFixtureTearDown.
-			// In this example, we simply display a message.
-		}
-
-		protected override void DoOneTimeSetUp(TestResult suiteResult)
-		{
-			Console.WriteLine( "Extended Fixture SetUp called" );
-			base.DoOneTimeSetUp (suiteResult);
-		}
-
-		protected override void DoOneTimeTearDown(TestResult suiteResult)
-		{
-			base.DoOneTimeTearDown (suiteResult);
-			Console.WriteLine( "Extended Fixture TearDown called" );
-		}
-	}
-}

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleFixtureExtension/SampleFixtureExtension.csproj
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleFixtureExtension/SampleFixtureExtension.csproj b/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleFixtureExtension/SampleFixtureExtension.csproj
deleted file mode 100644
index 1fb245b..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleFixtureExtension/SampleFixtureExtension.csproj
+++ /dev/null
@@ -1,109 +0,0 @@
-<VisualStudioProject>
-    <CSHARP
-        ProjectType = "Local"
-        ProductVersion = "7.10.3077"
-        SchemaVersion = "2.0"
-        ProjectGuid = "{ED281A23-9579-4A70-B608-1B86DCDEB78C}"
-    >
-        <Build>
-            <Settings
-                ApplicationIcon = ""
-                AssemblyKeyContainerName = ""
-                AssemblyName = "SampleFixtureExtension"
-                AssemblyOriginatorKeyFile = ""
-                DefaultClientScript = "JScript"
-                DefaultHTMLPageLayout = "Grid"
-                DefaultTargetSchema = "IE50"
-                DelaySign = "false"
-                OutputType = "Library"
-                PreBuildEvent = ""
-                PostBuildEvent = ""
-                RootNamespace = "SampleFixtureExtension"
-                RunPostBuildEvent = "OnBuildSuccess"
-                StartupObject = ""
-            >
-                <Config
-                    Name = "Debug"
-                    AllowUnsafeBlocks = "false"
-                    BaseAddress = "285212672"
-                    CheckForOverflowUnderflow = "false"
-                    ConfigurationOverrideFile = ""
-                    DefineConstants = "DEBUG;TRACE"
-                    DocumentationFile = ""
-                    DebugSymbols = "true"
-                    FileAlignment = "4096"
-                    IncrementalBuild = "false"
-                    NoStdLib = "false"
-                    NoWarn = ""
-                    Optimize = "false"
-                    OutputPath = "bin\Debug\"
-                    RegisterForComInterop = "false"
-                    RemoveIntegerChecks = "false"
-                    TreatWarningsAsErrors = "false"
-                    WarningLevel = "4"
-                />
-                <Config
-                    Name = "Release"
-                    AllowUnsafeBlocks = "false"
-                    BaseAddress = "285212672"
-                    CheckForOverflowUnderflow = "false"
-                    ConfigurationOverrideFile = ""
-                    DefineConstants = "TRACE"
-                    DocumentationFile = ""
-                    DebugSymbols = "false"
-                    FileAlignment = "4096"
-                    IncrementalBuild = "false"
-                    NoStdLib = "false"
-                    NoWarn = ""
-                    Optimize = "true"
-                    OutputPath = "bin\Release\"
-                    RegisterForComInterop = "false"
-                    RemoveIntegerChecks = "false"
-                    TreatWarningsAsErrors = "false"
-                    WarningLevel = "4"
-                />
-            </Settings>
-            <References>
-                <Reference
-                    Name = "System"
-                    AssemblyName = "System"
-                />
-                <Reference
-                    Name = "nunit.core.interfaces"
-                    AssemblyName = "nunit.core.interfaces"
-                    HintPath = "..\..\..\..\solutions\vs2003\NUnitCore\interfaces\bin\Debug\nunit.core.interfaces.dll"
-                />
-                <Reference
-                    Name = "nunit.core"
-                    AssemblyName = "nunit.core"
-                    HintPath = "..\..\..\..\solutions\vs2003\NUnitCore\core\bin\Debug\nunit.core.dll"
-                />
-            </References>
-        </Build>
-        <Files>
-            <Include>
-                <File
-                    RelPath = "AssemblyInfo.cs"
-                    SubType = "Code"
-                    BuildAction = "Compile"
-                />
-                <File
-                    RelPath = "SampleFixtureExtension.cs"
-                    SubType = "Code"
-                    BuildAction = "Compile"
-                />
-                <File
-                    RelPath = "SampleFixtureExtensionAttribute.cs"
-                    SubType = "Code"
-                    BuildAction = "Compile"
-                />
-                <File
-                    RelPath = "SampleFixtureExtensionBuilder.cs"
-                    SubType = "Code"
-                    BuildAction = "Compile"
-                />
-            </Include>
-        </Files>
-    </CSHARP>
-</VisualStudioProject>
-

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleFixtureExtension/SampleFixtureExtensionAttribute.cs
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleFixtureExtension/SampleFixtureExtensionAttribute.cs b/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleFixtureExtension/SampleFixtureExtensionAttribute.cs
deleted file mode 100644
index 2d9737c..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleFixtureExtension/SampleFixtureExtensionAttribute.cs
+++ /dev/null
@@ -1,18 +0,0 @@
-// ****************************************************************
-// Copyright 2007, Charlie Poole
-// This is free software licensed under the NUnit license. You may
-// obtain a copy of the license at http://nunit.org/?p=license&r=2.4
-// ****************************************************************
-
-using System;
-
-namespace NUnit.Core.Extensions
-{
-	/// <summary>
-	/// SampleFixtureExtensionAttribute is used to identify a SampleFixtureExtension class
-	/// </summary>
-	[AttributeUsage(AttributeTargets.Class, AllowMultiple=false)]
-	public sealed class SampleFixtureExtensionAttribute : Attribute
-	{
-	}
-}

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleFixtureExtension/SampleFixtureExtensionBuilder.cs
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleFixtureExtension/SampleFixtureExtensionBuilder.cs b/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleFixtureExtension/SampleFixtureExtensionBuilder.cs
deleted file mode 100644
index 3713a7e..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleFixtureExtension/SampleFixtureExtensionBuilder.cs
+++ /dev/null
@@ -1,58 +0,0 @@
-// ****************************************************************
-// Copyright 2007, Charlie Poole
-// This is free software licensed under the NUnit license. You may
-// obtain a copy of the license at http://nunit.org/?p=license&r=2.4
-// ****************************************************************
-
-using System;
-using NUnit.Core.Builders;
-using NUnit.Core.Extensibility;
-
-namespace NUnit.Core.Extensions
-{
-	/// <summary>
-	/// MockFixtureExtensionBuilder knows how to build
-	/// a MockFixtureExtension.
-	/// </summary>
-	[NUnitAddin(Description="Wraps an NUnitTestFixture with an additional level of SetUp and TearDown")]
-	public class SampleFixtureExtensionBuilder : ISuiteBuilder, IAddin
-	{	
-		#region NUnitTestFixtureBuilder Overrides
-		/// <summary>
-		/// Makes a SampleFixtureExtension instance
-		/// </summary>
-		/// <param name="type">The type to be used</param>
-		/// <returns>A SampleFixtureExtension as a TestSuite</returns>
-//		protected override TestSuite MakeSuite(Type type)
-//		{
-//			return new SampleFixtureExtension( type );
-//		}
-
-		// The builder recognizes the types that it can use by the presense
-		// of SampleFixtureExtensionAttribute. Note that an attribute does not
-		// have to be used. You can use any arbitrary set of rules that can be 
-		// implemented using reflection on the type.
-		public bool CanBuildFrom(Type type)
-		{
-			return Reflect.HasAttribute( type, "NUnit.Core.Extensions.SampleFixtureExtensionAttribute", false );
-		}
-
-		public Test BuildFrom(Type type)
-		{
-			return null;
-		}
-		#endregion
-
-		#region IAddin Members
-		public bool Install(IExtensionHost host)
-		{
-			IExtensionPoint suiteBuilders = host.GetExtensionPoint( "SuiteBuilders" );
-			if ( suiteBuilders == null )
-				return false;
-
-			suiteBuilders.Install( this );
-			return true;
-		}
-		#endregion
-	}
-}

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleFixtureExtension/Tests/AssemblyInfo.cs
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleFixtureExtension/Tests/AssemblyInfo.cs b/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleFixtureExtension/Tests/AssemblyInfo.cs
deleted file mode 100644
index 9f89a32..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleFixtureExtension/Tests/AssemblyInfo.cs
+++ /dev/null
@@ -1,58 +0,0 @@
-using System.Reflection;
-using System.Runtime.CompilerServices;
-
-//
-// General Information about an assembly is controlled through the following 
-// set of attributes. Change these attribute values to modify the information
-// associated with an assembly.
-//
-[assembly: AssemblyTitle("")]
-[assembly: AssemblyDescription("")]
-[assembly: AssemblyConfiguration("")]
-[assembly: AssemblyCompany("")]
-[assembly: AssemblyProduct("")]
-[assembly: AssemblyCopyright("")]
-[assembly: AssemblyTrademark("")]
-[assembly: AssemblyCulture("")]		
-
-//
-// Version information for an assembly consists of the following four values:
-//
-//      Major Version
-//      Minor Version 
-//      Build Number
-//      Revision
-//
-// You can specify all the values or you can default the Revision and Build Numbers 
-// by using the '*' as shown below:
-
-[assembly: AssemblyVersion("1.0.*")]
-
-//
-// In order to sign your assembly you must specify a key to use. Refer to the 
-// Microsoft .NET Framework documentation for more information on assembly signing.
-//
-// Use the attributes below to control which key is used for signing. 
-//
-// Notes: 
-//   (*) If no key is specified, the assembly is not signed.
-//   (*) KeyName refers to a key that has been installed in the Crypto Service
-//       Provider (CSP) on your machine. KeyFile refers to a file which contains
-//       a key.
-//   (*) If the KeyFile and the KeyName values are both specified, the 
-//       following processing occurs:
-//       (1) If the KeyName can be found in the CSP, that key is used.
-//       (2) If the KeyName does not exist and the KeyFile does exist, the key 
-//           in the KeyFile is installed into the CSP and used.
-//   (*) In order to create a KeyFile, you can use the sn.exe (Strong Name) utility.
-//       When specifying the KeyFile, the location of the KeyFile should be
-//       relative to the project output directory which is
-//       %Project Directory%\obj\<configuration>. For example, if your KeyFile is
-//       located in the project directory, you would specify the AssemblyKeyFile 
-//       attribute as [assembly: AssemblyKeyFile("..\\..\\mykey.snk")]
-//   (*) Delay Signing is an advanced option - see the Microsoft .NET Framework
-//       documentation for more information on this.
-//
-[assembly: AssemblyDelaySign(false)]
-[assembly: AssemblyKeyFile("")]
-[assembly: AssemblyKeyName("")]

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleFixtureExtension/Tests/SampleFixtureExtensionTests.cs
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleFixtureExtension/Tests/SampleFixtureExtensionTests.cs b/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleFixtureExtension/Tests/SampleFixtureExtensionTests.cs
deleted file mode 100644
index 671fca9..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/samples/Extensibility/Core/SampleFixtureExtension/Tests/SampleFixtureExtensionTests.cs
+++ /dev/null
@@ -1,48 +0,0 @@
-// ****************************************************************
-// Copyright 2007, Charlie Poole
-// This is free software licensed under the NUnit license. You may
-// obtain a copy of the license at http://nunit.org/?p=license&r=2.4
-// ****************************************************************
-
-using System;
-using NUnit.Framework;
-using NUnit.Core.Extensions;
-
-namespace NUnit.Extensions.Tests
-{
-	/// <summary>
-	/// Test class that demonstrates SampleFixtureExtension
-	/// </summary>
-	[SampleFixtureExtension]
-	public class SampleFixtureExtensionTests
-	{
-		[TestFixtureSetUp]
-		public void SetUpTests()
-		{
-			Console.WriteLine( "TestFixtureSetUp called" );
-		}
-
-		[TestFixtureTearDown]
-		public void FixtureTearDown()
-		{
-			Console.WriteLine( "TestFixtureTearDown called" );
-		}
-
-		[Test]
-		public void SomeTest()
-		{
-			Console.WriteLine( "Hello from some test" );
-		}
-
-		[Test]
-		public void AnotherTest()
-		{
-			Console.WriteLine( "Hello from another test" );
-		}
-
-		public void NotATest()
-		{
-			Console.WriteLine( "I shouldn't be called!" );
-		}
-	}
-}


[17/51] [abbrv] [partial] Cleaning up and getting ready to development towards v4.8

Posted by sy...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/platform.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/platform.html b/lib/NUnit.org/NUnit/2.5.9/doc/platform.html
deleted file mode 100644
index a8b078e..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/platform.html
+++ /dev/null
@@ -1,311 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - Platform</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<script language="JavaScript" src="codeFuncs.js" ></script> <!-- Do it this way for IE -->
-
-<style><!--
-div.code { width: 34em }
---></style>
-
-<h3>PlatformAttribute (NUnit 2.2.2)</h3> 
-<p>The Platform attribute is used to specify platforms for which a test or fixture
-	should be run. Platforms are specified using case-insensitive string values
-	and may be either included or excluded from the run by use of the Include or 
-	Exclude properties respectively. Platforms to be included may alternatively
-	be specified as an argument to the PlatformAttribute constructor. In either
-	case, multiple comma-separated values may be specified.
-
-<p>If a test or fixture with the Platform attribute does not satisfy the specified
-   platform requirements it is skipped. The test does not affect the outcome of 
-   the run at all: it is not considered as ignored and is not even counted in 
-   the total number of tests. In the gui, the tree node for the test remains 
-   gray and the	status bar color is not affected.</p>
-
-<blockquote><i><b>Note:</b> In versions of NUnit prior to 2.4, these tests were
-    shown as ignored.</i></blockquote>
-
-<h4>Test Fixture Syntax</h4>
-
-<div class="code">
-
-<div class="langFilter">
-	<a href="javascript:Show('DD1')" onmouseover="Show('DD1')"><img src="img/langFilter.gif" width="14" height="14" alt="Language Filter"></a>
-	<div id="DD1" class="dropdown" style="display: none;" onclick="Hide('DD1')">
-		<a href="javascript:ShowCS()">C#</a><br>
-		<a href="javascript:ShowVB()">VB</a><br>
-		<a href="javascript:ShowMC()">C++</a><br>
-		<a href="javascript:ShowJS()">J#</a><br>
-	</div>
-</div>
-
-<pre class="cs">namespace NUnit.Tests
-{
-  using System;
-  using NUnit.Framework;
-
-  [TestFixture]
-  [Platform(&quot;NET-2.0&quot;)]
-  public class DotNetTwoTests
-  {
-    // ...
-  }
-}
-</pre>
-
-<pre class="vb">Imports System
-Imports Nunit.Framework
-
-Namespace Nunit.Tests
-
-  &lt;TestFixture(), Platform(&quot;NET-2.0&quot;)&gt;
-  Public Class DotNetTwoTests
-    &#39; ...
-  End Class
-End Namespace
-</pre>
-
-<pre class="mc">#using &lt;Nunit.Framework.dll&gt;
-using namespace System;
-using namespace NUnit::Framework;
-
-namespace NUnitTests
-{
-  [TestFixture]
-  [Platform(&quot;NET-2.0&quot;)]
-  public __gc class DotNetTwoTests
-  {
-    // ...
-  };
-}
-
-#include &quot;cppsample.h&quot;
-
-namespace NUnitTests {
-  // ...
-}
-</pre>
-
-<pre class="js">package NUnit.Tests;
-
-import System.*;
-import NUnit.Framework.TestFixture;
-
-
-/** @attribute NUnit.Framework.TestFixture() */
-/** @attribute NUnit.Framework.Platform(&quot;NET-2.0&quot;) */
-public class DotNetTwoTests
-{
-  // ...
-}
-</pre>
-</div>
-<h4>Test Syntax</h4>
-<div class="code">
-	
-<div class="langFilter">
-	<a href="javascript:Show('DD2')" onmouseover="Show('DD2')"><img src="img/langFilter.gif" width="14" height="14" alt="Language Filter"></a>
-	<div id="DD2" class="dropdown" style="display: none;" onclick="Hide('DD2')">
-		<a href="javascript:ShowCS()">C#</a><br>
-		<a href="javascript:ShowVB()">VB</a><br>
-		<a href="javascript:ShowMC()">C++</a><br>
-		<a href="javascript:ShowJS()">J#</a><br>
-	</div>
-</div>
-
-<pre class="cs">namespace NUnit.Tests
-{
-  using System;
-  using NUnit.Framework;
-
-  [TestFixture]
-  public class SuccessTests
-  {
-    [Test]
-    [Platform(Exclude=&quot;Win98,WinME&quot;)]
-    public void SomeTest()
-    { /* ... */ }
-}
-</pre>
-
-<pre class="vb">Imports System
-Imports Nunit.Framework
-
-Namespace Nunit.Tests
-
-  &lt;TestFixture()&gt;
-  Public Class SuccessTests
-    &lt;Test(), Platform(Exclude=&quot;Win98,WinME&quot;)&gt; Public Sub SomeTest()
-      &#39; ...
-    End Sub
-  End Class
-End Namespace
-</pre>
-
-<pre class="mc">#using &lt;Nunit.Framework.dll&gt;
-using namespace System;
-using namespace NUnit::Framework;
-
-namespace NUnitTests
-{
-  [TestFixture]
-  public __gc class SuccessTests
-  {
-    [Test][Platform(Exclude=&quot;Win98,WinME&quot;)] void SomeTest();
-  };
-}
-
-#include &quot;cppsample.h&quot;
-
-namespace NUnitTests {
-  // ...
-}
-</pre>
-
-<pre class="js">package NUnit.Tests;
-
-import System.*;
-import NUnit.Framework.TestFixture;
-
-
-/** @attribute NUnit.Framework.TestFixture() */
-public class SuccessTests
-{
-  /** @attribute NUnit.Framework.Test() */
-  /** @attribute NUnit.Framework.Platform(Exclude=&quot;Win98,WinME&quot;) */
-  public void SomeTest()
-  { /* ... */ }
-}
-</pre>
-
-</div>
-
-<h3>Platform Specifiers</h3>
-<p>The following values are recognized as platform specifiers.
-   They may be expressed in upper, lower or mixed case.</p>
-
-<ul class="across">
-<li>Win</li>
-<li>Win32</li>
-<li>Win32S</li>
-<li>Win32Windows</li>
-<li>Win32NT</li>
-<li>WinCE</li>
-<li>Win95</li>
-<li>Win98</li>
-<li>WinMe</li>
-<li>NT3</li>
-<li>NT4</li>
-<li>NT5</li>
-<li>NT6</li>
-<li>Win2K</li>
-<li>WinXP</li>
-<li>Win2003Server</li>
-<li>Vista</li>
-<li>Win2008Server</li>
-<li>Win2008ServerR2</li>
-<li>Windows7</li>
-<li>Unix</li>
-<li>Linux</li>
-<li>Net</li>
-<li>Net-1.0</li>
-<li>Net-1.1</li>
-<li>Net-2.0</li>
-<li>Net-4.0</li>
-<li>NetCF</li>
-<li>SSCLI</li>
-<li>Rotor</li>
-<li>Mono</li>
-<li>Mono-1.0</li>
-<li>Mono-2.0</li>
-</ul>
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<ul>
-<li><a href="category.html">Category</a></li>
-<li><a href="combinatorial.html">Combinatorial</a></li>
-<li><a href="culture.html">Culture</a></li>
-<li><a href="datapoint.html">Datapoint(s)</a></li>
-<li><a href="description.html">Description</a></li>
-<li><a href="exception.html">Exception</a></li>
-<li><a href="explicit.html">Explicit</a></li>
-<li><a href="ignore.html">Ignore</a></li>
-<li><a href="maxtime.html">Maxtime</a></li>
-<li><a href="pairwise.html">Pairwise</a></li>
-<li id="current"><a href="platform.html">Platform</a></li>
-<li><a href="property.html">Property</a></li>
-<li><a href="random.html">Random</a></li>
-<li><a href="range.html">Range</a></li>
-<li><a href="repeat.html">Repeat</a></li>
-<li><a href="requiredAddin.html">RequiredAddin</a></li>
-<li><a href="requiresMTA.html">Requires&nbsp;MTA</a></li>
-<li><a href="requiresSTA.html">Requires&nbsp;STA</a></li>
-<li><a href="requiresThread.html">Requires&nbsp;Thread</a></li>
-<li><a href="sequential.html">Sequential</a></li>
-<li><a href="setCulture.html">SetCulture</a></li>
-<li><a href="setup.html">Setup</a></li>
-<li><a href="setupFixture.html">SetupFixture</a></li>
-<li><a href="suite.html">Suite</a></li>
-<li><a href="teardown.html">Teardown</a></li>
-<li><a href="test.html">Test</a></li>
-<li><a href="testCase.html">TestCase</a></li>
-<li><a href="testCaseSource.html">TestCaseSource</a></li>
-<li><a href="testFixture.html">TestFixture</a></li>
-<li><a href="fixtureSetup.html">TestFixtureSetUp</a></li>
-<li><a href="fixtureTeardown.html">TestFixtureTearDown</a></li>
-<li><a href="theory.html">Theory</a></li>
-<li><a href="timeout.html">Timeout</a></li>
-<li><a href="values.html">Values</a></li>
-<li><a href="valueSource.html">ValueSource</a></li>
-</ul>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/pnunit.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/pnunit.html b/lib/NUnit.org/NUnit/2.5.9/doc/pnunit.html
deleted file mode 100644
index 2b789c6..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/pnunit.html
+++ /dev/null
@@ -1,99 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - Pnunit</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h2>PNUnit</h2>
-
-<p><b>PNUnit</b> stands for "Parallel NUnit." It is an extension of NUNit
-developed by Pablo Santos Luaces and his team at Codice Software for
-their internal use in testing the Plastic (TM) Software Configuration
-Management System. Codice released PNUnit to the community in 2007.
-
-<p>As part of the NUnit 2.5 release, we worked with the NUnit and PNUnit
-teams worked together to make PNUnit work with NUnit without any modifications.
-PNUnit is now included in the NUnit distribution.
-
-<h3>How it Works</h3>
-
-<p><b>PNUnit</b> is not intended for "casual" parallelism merely to
-make the tests run faster. Rather, it's intended as a way to test
-applications composed of distributed, communicating components. Tests
-of each component run in parallel and use memory barriers to synchronize
-their operation. 
-
-<p>PNUnit uses a special executable to launch its tests. 
-The launcher reads an xml file that specifies the tests to be 
-executed and where they should run, whether on the same machine or
-on another machine on the network.
-
-<p>For more information about using PNUnit, consult the
-<a href="http://www.codicesoftware.com/infocenter/technical-articles/pnunit.aspx">documentation</a>
-at <a href="http://www.codicesoftware.com">www.codicesoftware.com</a>
-
-<h3>Future Plans</h3>
-
-<p>PNUnit will be integrated with NUnit so that parallel, distributed tests
-may be used through the normal NUnit console or gui runners.
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<ul>
-<li><a href="nunit-console.html">Console&nbsp;Runner</a></li>
-<li><a href="nunit-gui.html">Gui&nbsp;Runner</a></li>
-<li id="current"><a href="pnunit.html">PNUnit&nbsp;Runner</a></li>
-<li><a href="runtimeSelection.html">Runtime&nbsp;Selection</a></li>
-<li><a href="assemblyIsolation.html">Assembly&nbsp;Isolation</a></li>
-<li><a href="configFiles.html">Configuration&nbsp;Files</a></li>
-<li><a href="multiAssembly.html">Multiple&nbsp;Assemblies</a></li>
-<li><a href="vsSupport.html">Visual&nbsp;Studio&nbsp;Support</a></li>
-</ul>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/projectEditor.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/projectEditor.html b/lib/NUnit.org/NUnit/2.5.9/doc/projectEditor.html
deleted file mode 100644
index e3d5235..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/projectEditor.html
+++ /dev/null
@@ -1,219 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - ProjectEditor</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h2>Project Editor</h2>
-
-<p>The Project Editor is displayed through the Project | Edit menu item and allows creating or
-modifying NUnit test projects. It should be noted that a Test Project is active whenever any tests
-have been loaded, even if no project was explicitly created or referenced. In the case of an
-assembly being loaded, an internal wrapper project is created. This allows the user to change
-settings and save the project directly without needing to perform any extra steps. The editor
-consists of a common area and two tabs, as seen in the image below.</p>
-
-<h3>Common Area</h3>
-
-<p>The common area of the Project Editor contains information pertaining to
-   the project as a whole. Information that applies to a particular configuration
-   is displayed in the General and Assemblies tabs.
-   
-<h4>Project Path</h4>
-<p>This label shows the full path to the project file. In the case of a 
-   wrapper project, the path is set to the same directory as the assembly
-   that was initially opened.
-   
-<h4>Application Base</h4> 
-<p>This TextBox allows the user to change the project AppBase, which defaults to 
-   the directory of the project file. The button to the right of the TextBox
-   allows the user to browse and select a directory.
-   
-<h4>Process Model</h4>
-<p>This dropdown list allows you to specify how operating system processes are
-   used in loading and running the tests in this project. Four settings are
-   defined:
-   <ul>
-   <li>The <b>Default</b> setting refers to the option selected by the user
-       on the Assembly Isolation page of the NUnit Settings Dialog.
-   <li><b>Single</b> means that tests are run in a test domain in the
-   	   same process as NUnit. This is the way previous versions of NUnit
-	   ran tests.
-   <li><b>Separate</b> means that all the tests are run in a separate process 
-       that NUnit creates.
-   <li><b>Multiple</b> means that NUnit will create a separate process for
-       each test assembly in the project and run its tests there.
-   </ul>
-   
-<h4>Domain Usage</h4>
-<p>This dropdown list allows you to specify how tests are loaded into
-   AppDomains by NUnit. Three settings are defined:
-   <ul>
-   <li>The <b>Default</b> setting refers to the option selected by the user
-       on the Assembly Isolation page of the NUnit Settings Dialog.
-   <li><b>Single</b> means that all tests will run in a single test domain
-       created by NUnit. This was the way versions of NUnit prior to 2.4
-	   ran tests.
-   <li><b>Multiple</b> means that each test assembly is loaded into a
-       separate AppDomain. This setting is not available when Multiple
-	   processes are selected in the Process Model dropown.
-   </ul>
-   
-<h4>Configuration</h4>
-<p>This dropdown list allows you to select the particular configuration
-   within a project that is displayed in the bottom part of the dialog.
-   
-<h4>Edit Configs...</h4>
-<p>This button opens the  
-   <a href="configEditor.html">Configuration Editor</a>,
-   which allows you to add, delete or rename configs and set the
-   active configuration.
-
-<div class="screenshot-left">
-<img src="img/generalTab.jpg"></div>
-
-<h3>General Tab</h3>
-
-<p>The General tab allows setting a number of options pertaining to the selected configuration, all of
-which will be stored in the NUnit project file as attributes of the <config> xml node.</p>
-
-<h4>Runtime</h4>
-<p>This dropdown allows you to select a particular runtime framework to be used
-   for loading and running tests under the current configuration. Currently,
-   only Microsoft .NET and Mono are supported. If <b>Any</b> is selected, the 
-   tests will be run under the same runtime that NUnit itself is currently using.
-
-<h4>Version</h4>
-<p>This ComboBox allows you to select the particular version of the runtime framework
-   to be used for loading and running tests under the current configuration. The
-   dropdown list contains entries for
-   <ul>
-   <li>Default
-   <li>1.0
-   <li>1.1
-   <li>2.0
-   <li>4.0
-   </ul>
-   
-<p>If you select "Default" the assemblies in the project are examined to determine  
-   the version that is required.
-   See <a href="runtimeSelection.html">Runtime Selection</a> for 
-   more information on how NUnit selects the version to be used.
-
-<p>In special cases, you may wish to enter a version number that is not listed
-   in the list box. You may specify the version using two, three or four
-   components. The version you provide will be saved as you enter it. Leaving
-   the text box blank is equivalent to selecting "Default." 
-   
-<p><b>Note:</b> Running tests under a different runtime or version from the one that NUnit
-   is currently using will force them to run in a separate process.
-   
-<p><b>Note:</b> To conform with normal usage, specifying Mono as the runtime
-   with "1.0" as the version results in use of the Mono 1.0 profile, equating
-   to version 1.1.4322.
-   
-<h4>ApplicationBase</h4>
-<p>The ApplicationBase defaults to the directory containing the project file. Beginning
-with NUnit 2.2.3, it may be set to any location that is desired.</p>
-
-<h4>Configuration File Name</h4>
-<p>The configuration file defaults to the name of the test project with the extension changed
-from .nunit to .config. The user may substitute another name.</p>
-
-<h4>PrivateBinPath</h4>
-<p>By default, the PrivateBinPath is generated from the assembly locations specified on the
-Assemblies Tab. For those applications requiring a different level of control, it may be
-specified manually or using this editor or placed in the configuration file.</p>
-
-<h3>Assemblies Tab</h3>
-
-<p>The assemblies tab contains the list of assemblies that form part of this test project.</p>
-
-<p>Note: Although the dialog shows the location of assemblies as absolute paths, they are always
-persisted in the NUnit project file as paths relative to the application base. This allows moving
-projects as a whole to a different directory location.</p>
-
-<div class="screenshot-left">
-<img src="img/assembliesTab.jpg"></div>
-
-<h4>Add...</h4>
-<p>Opens a dialog allowing adding an assembly to this configuration. If Visual
-Stuio support is enabled, you may also select and add a VS project.</p>
-
-<h4>Remove</h4>
-<p>After confirmation, removes the selected assembly from this configuration.</p>
-
-<h4>Assembly Path</h4>
-<p>This text box displays the full path to the selected assembly. You may edit
-the contents to change the path to the assembly.
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<ul>
-<li><a href="nunit-console.html">Console&nbsp;Runner</a></li>
-<li><a href="nunit-gui.html">Gui&nbsp;Runner</a></li>
-<ul>
-<li><a href="guiCommandLine.html">Command-Line</a></li>
-<li><a href="mainMenu.html">Main&nbsp;Menu</a></li>
-<li><a href="contextMenu.html">Context&nbsp;Menu</a></li>
-<li><a href="settingsDialog.html">Settings&nbsp;Dialog</a></li>
-<li><a href="addinsDialog.html">Addins&nbsp;Dialog</a></li>
-<li><a href="testProperties.html">Test&nbsp;Properties</a></li>
-<li><a href="configEditor.html">Configuration&nbsp;Editor</a></li>
-<li id="current"><a href="projectEditor.html">Project&nbsp;Editor</a></li>
-</ul>
-<li><a href="pnunit.html">PNUnit&nbsp;Runner</a></li>
-<li><a href="runtimeSelection.html">Runtime&nbsp;Selection</a></li>
-<li><a href="assemblyIsolation.html">Assembly&nbsp;Isolation</a></li>
-<li><a href="configFiles.html">Configuration&nbsp;Files</a></li>
-<li><a href="multiAssembly.html">Multiple&nbsp;Assemblies</a></li>
-<li><a href="vsSupport.html">Visual&nbsp;Studio&nbsp;Support</a></li>
-</ul>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/property.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/property.html b/lib/NUnit.org/NUnit/2.5.9/doc/property.html
deleted file mode 100644
index cb386a8..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/property.html
+++ /dev/null
@@ -1,243 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - Property</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<script language="JavaScript" src="codeFuncs.js" ></script> <!-- Do it this way for IE -->
-
-<h3>PropertyAttribute (NUnit 2.4)</h3>
-
-<p>The Property attribute provides a generalized approach to setting named
-   properties on any test case or fixture, using a name/value pair.</p>
-   
-<p>In the example below, the fixture class MathTests is given a Location
-   value of 723 while the test case AdditionTest is given a Severity
-   of "Critical"</p>
-
-<h4>Example:</h4>
-
-<div class="code">
-
-<div class="langFilter">
-	<a href="javascript:Show('DD1')" onmouseover="Show('DD1')"><img src="img/langFilter.gif" width="14" height="14" alt="Language Filter"></a>
-	<div id="DD1" class="dropdown" style="display: none" onclick="Hide('DD1')">
-		<a href="javascript:ShowCS()">C#</a><br>
-		<a href="javascript:ShowVB()">VB</a><br>
-		<a href="javascript:ShowMC()">C++</a><br>
-		<a href="javascript:ShowJS()">J#</a><br>
-	</div>
-</div>
-
-<pre class="cs">namespace NUnit.Tests
-{
-  using System;
-  using NUnit.Framework;
-
-  [TestFixture, Property("Location",723)]
-  public class MathTests
-  {
-    [Test, Property("Severity", "Critical")]
-	public void AdditionTest()
-    { /* ... */ }
-  }
-}
-</pre>
-
-<pre class="vb">Imports System
-Imports Nunit.Framework
-
-Namespace Nunit.Tests
-
-  &lt;TestFixture(), Property("Location",723)&gt;
-    Public Class MathTests
-	
-    &lt;Test(), Property("Severity","Critical")&gt;
-	  Public Sub AdditionTest()
-    ' ...
-    End Sub
-	
-  End Class
-  
-End Namespace
-</pre>
-
-<pre class="mc">#using &lt;Nunit.Framework.dll&gt;
-using namespace System;
-using namespace NUnit::Framework;
-
-namespace NUnitTests
-{
-  [TestFixture, Property("Location",723)]
-  public __gc class MathTests
-  {
-    [Test, Property("Severity","Critical")] void AdditionTest();
-  };
-}
-
-#include "cppsample.h"
-
-namespace NUnitTests {
-  // ...
-}
-</pre>
-
-<pre class="js">package NUnit.Tests;
-
-import System.*;
-import NUnit.Framework.TestFixture;
-
-
-/** @attribute NUnit.Framework.TestFixture() */
-/** @attribute NUnit.Framework.Property("Location",723) */
-public class MathTests
-{
-  /** @attribute NUnit.Framework.Test() */
-  /** @attribute NUnit.Framework.Property("Severity","Critical") */
-  public void AdditionTest()
-  { /* ... */ }
-}
-</pre>
-
-</div>
-
-<h4>Usage Note</h4>
-
-<p>The PropertyAttribute is not used for any purpose by NUnit itself, but
-it does display them in the XML output file and in the Test Properties
-dialog of the gui.</p>
-
-<p>It is
-   possible to write extensions that access the value of specific properties.
-   It is also possible to access the value of properties from within a test
-   using reflection.</p>
-   
-<h3>Custom Property Attributes</h3>
-
-<p>Users can define custom
-attributes that derive from <b>PropertyAttribute</b> and have them
-recognized by NUnit. PropertyAttribute provides a protected constructor
-that takes the value of the property and sets the property name to the
-name of the derived class. NUnit itself uses this facility: some of
-it's specialized attributes are actually specializations of <b>PropertyAttribute</b>.
-
-<p>Here's an example that creates a Severity property. It works
-just like any other property, but has a simpler syntax and is type-safe.
-A test reporting system might make use of the property to provide special reports.
-
-<div class=code><pre>
-public enum SeverityLevel
-{
-    Critical,
-    Major,
-    Normal,
-    Minor
-}
-
-[AttributeUsage(AttributeTargets.Method, AllowMultiple=false)]
-public class SeverityAttribute : PropertyAttribute
-{
-    public SeverityAttribute( SeverityLevel level )
-	    : base( level ); 
-}
-
-...
-
-[Test, Severity( SeverityLevel.Critical)]
-public void MyTest()
-{ /*...*/ }
-</pre></div>
-
-<p>Beginning with NUnit 2.5, a property attribute is able to contain
-multiple name/value pairs. This capability is not exposed publicly
-but may be used by derived property classes. NUnit uses this
-feature itself for certain attributes. See, for example, 
-<a href="requiresThread.html">RequiresThreadAttribute</a>.
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<ul>
-<li><a href="category.html">Category</a></li>
-<li><a href="combinatorial.html">Combinatorial</a></li>
-<li><a href="culture.html">Culture</a></li>
-<li><a href="datapoint.html">Datapoint(s)</a></li>
-<li><a href="description.html">Description</a></li>
-<li><a href="exception.html">Exception</a></li>
-<li><a href="explicit.html">Explicit</a></li>
-<li><a href="ignore.html">Ignore</a></li>
-<li><a href="maxtime.html">Maxtime</a></li>
-<li><a href="pairwise.html">Pairwise</a></li>
-<li><a href="platform.html">Platform</a></li>
-<li id="current"><a href="property.html">Property</a></li>
-<li><a href="random.html">Random</a></li>
-<li><a href="range.html">Range</a></li>
-<li><a href="repeat.html">Repeat</a></li>
-<li><a href="requiredAddin.html">RequiredAddin</a></li>
-<li><a href="requiresMTA.html">Requires&nbsp;MTA</a></li>
-<li><a href="requiresSTA.html">Requires&nbsp;STA</a></li>
-<li><a href="requiresThread.html">Requires&nbsp;Thread</a></li>
-<li><a href="sequential.html">Sequential</a></li>
-<li><a href="setCulture.html">SetCulture</a></li>
-<li><a href="setup.html">Setup</a></li>
-<li><a href="setupFixture.html">SetupFixture</a></li>
-<li><a href="suite.html">Suite</a></li>
-<li><a href="teardown.html">Teardown</a></li>
-<li><a href="test.html">Test</a></li>
-<li><a href="testCase.html">TestCase</a></li>
-<li><a href="testCaseSource.html">TestCaseSource</a></li>
-<li><a href="testFixture.html">TestFixture</a></li>
-<li><a href="fixtureSetup.html">TestFixtureSetUp</a></li>
-<li><a href="fixtureTeardown.html">TestFixtureTearDown</a></li>
-<li><a href="theory.html">Theory</a></li>
-<li><a href="timeout.html">Timeout</a></li>
-<li><a href="values.html">Values</a></li>
-<li><a href="valueSource.html">ValueSource</a></li>
-</ul>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/propertyConstraint.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/propertyConstraint.html b/lib/NUnit.org/NUnit/2.5.9/doc/propertyConstraint.html
deleted file mode 100644
index 977e976..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/propertyConstraint.html
+++ /dev/null
@@ -1,88 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - PropertyConstraint</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h2>Property Constraint (NUnit 2.4.2)</h2>
-
-<p>PropertyConstraint is used to test for existence of a named property and
-optionally tests its value. It may also be used as a prefix for other constraints
-to be applied to the property.
-
-<table class="constraints">
-<tr><th>Syntax Helper</th><th>Constructor</th><th>Operation</th></tr>
-<tr><td>Has.Property( string )</td><td>PropertyConstraint( string )</td></td><td>tests that a specific property exists</td></tr>
-<tr><td>Has.Property( string, object )</td><td>PropertyConstraint( string, object )</td></td><td>tests that the value of a property is equal to the value provided</td></tr>
-<tr><td>Has.Property( string, Constraint)...</td><td>PropertyConstraint</td></td><td>applies the following constraint to the value of a named property</td></tr>
-<tr><td>Has.Length( int )</td><td>PropertyConstraint</td></td><td>tests that the object's Length property is equal to the value given</td></tr>
-<tr><td>Has.Count( int )</td><td>PropertyConstraint</td></td><td>tests that the object's Count property is equal to the value given</td></tr>
-</table>
-
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<ul>
-<li><a href="equalConstraint.html">Equal&nbsp;Constraint</a></li>
-<li><a href="sameasConstraint.html">SameAs&nbsp;Constraint</a></li>
-<li><a href="conditionConstraints.html">Condition&nbsp;Constraints</a></li>
-<li><a href="comparisonConstraints.html">Comparison&nbsp;Constrants</a></li>
-<li><a href="pathConstraints.html">Path&nbsp;Constraints</a></li>
-<li><a href="typeConstraints.html">Type&nbsp;Constraints</a></li>
-<li><a href="stringConstraints.html">String&nbsp;Constraints</a></li>
-<li><a href="collectionConstraints.html">Collection&nbsp;Constraints</a></li>
-<li id="current"><a href="propertyConstraint.html">Property&nbsp;Constraint</a></li>
-<li><a href="throwsConstraint.html">Throws&nbsp;Constraint</a></li>
-<li><a href="compoundConstraints.html">Compound&nbsp;Constraints</a></li>
-<li><a href="delayedConstraint.html">Delayed&nbsp;Constraint</a></li>
-<li><a href="listMapper.html">List&nbsp;Mapper</a></li>
-<li><a href="reusableConstraint.html">Reusable&nbsp;Constraint</a></li>
-</ul>
-<li><a href="attributes.html">Attributes</a></li>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/quickStart.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/quickStart.html b/lib/NUnit.org/NUnit/2.5.9/doc/quickStart.html
deleted file mode 100644
index 1efafba..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/quickStart.html
+++ /dev/null
@@ -1,314 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - QuickStart</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<style><!--
-  div.code { width: 34em }
---></style>
-
-<h2>NUnit Quick Start</h2>
-
-<p><b>Note:</b> This page is based on the original QuickStart.doc, found in
-earlier releases of NUnit. It has been pointed out that it isn't a good 
-example of Test-Driven Development. However, we're keeping it in the docs
-because it does illustrate the basics of using NUnit. We'll revise or replace
-it in a future release.</p>
-
-<p>Let�s start with a simple example. Suppose we are writing a bank application and we have a basic domain class � Account. Account supports operations to deposit, withdraw, and transfer funds. The Account class may look like this:</p>
-
-<div class="code">
-<pre>namespace bank
-{
-  public class Account
-  {
-    private float balance;
-    public void Deposit(float amount)
-    {
-      balance+=amount;
-    }
-
-    public void Withdraw(float amount)
-    {
-      balance-=amount;
-    }
-
-    public void TransferFunds(Account destination, float amount)
-    {
-    }
-
-    public float Balance
-    {
-      get{ return balance;}
-    }
-  }
-}</pre>
-</div>
-
-<p>Now let�s write a test for this class � AccountTest. The first method we will test is TransferFunds.</p>
-
-<div class="code">
-<pre>namespace bank
-{
-  using NUnit.Framework;
-
-  [TestFixture]
-  public class AccountTest
-  {
-    [Test]
-    public void TransferFunds()
-    {
-      Account source = new Account();
-      source.Deposit(200.00F);
-      Account destination = new Account();
-      destination.Deposit(150.00F);
-
-      source.TransferFunds(destination, 100.00F);
-      Assert.AreEqual(250.00F, destination.Balance);
-      Assert.AreEqual(100.00F, source.Balance);
-	
-    }
-  }
-}</pre>
-</div>
-
-<p>The first thing to notice about this class is that it has a [TestFixture] attribute associated with it � this is the way to indicate that the class contains test code (this attribute can be inherited). The class has to be public and there are no restrictions on its superclass. The class also has to have a default constructor.</p>
-
-<p>The only method in the class � TransferFunds, has a [Test] attribute associated with it � this is an indication that it is a test method. Test methods have to return void and take no parameters. In our test method we do the usual initialization of the required test objects, execute the tested business method and check the state of the business objects. The Assert class defines a collection of methods used to check the post-conditions and in our example we use the AreEqual method to make sure that after the transfer both accounts have the correct balances (there are several overloadings of this method, the version that was used in this example has the following parameters : the first parameter is an expected value and the second parameter is the actual value).</p>
-
-<p>Compile and run this example. Assume that you have compiled your test code into a bank.dll. Start the NUnit Gui (the installer will have created a shortcut on your desktop and in the �Program Files� folder), after the GUI starts, select the File->Open menu item, navigate to the location of your bank.dll and select it in the �Open� dialog box. When the bank.dll is loaded you will see a test tree structure in the left panel and a collection of status panels on the right. Click the Run button, the status bar and the TransferFunds node in the test tree turn red � our test has failed. The �Errors and Failures� panel displayed the following message:
-
-<pre>    TransferFunds : expected &lt;250&gt; but was &lt;150&gt;</pre>
-
-and the stack trace panel right below it reported where in the test code the failure has occurred � 
-
-<pre>    at bank.AccountTest.TransferFunds() in C:\nunit\BankSampleTests\AccountTest.cs:line 17</pre></p>
-
-<p>That is expected behavior; the test has failed because we have not implemented the TransferFunds method yet. Now let�s get it to work. Don�t close the GUI and go back to your IDE and fix the code, make your TransferFunds method look like this:</p>
-
-<div class="code">
-<pre>public void TransferFunds(Account destination, float amount)
-{
-	destination.Deposit(amount);
-	Withdraw(amount);
-}</pre>
-</div>
-
-
-<p>Now recompile your code and click the run button in GUI again � the status bar and the test tree turn green. (Note how the GUI has reloaded the assembly automatically for you; we will keep the GUI open all the time and continue working with our code in IDE and write more tests).</p>
-
-<p>Let�s add some error checking to our Account code. We are adding the minimum balance requirement for the account to make sure that banks continue to make their money by charging your minimal overdraft protection fee. Let�s add the minimum balance property to our Account class:</p>
-
-<div class="code">
-<pre>private float minimumBalance = 10.00F;
-public float MinimumBalance
-{
-	get{ return minimumBalance;}
-}</pre>
-</div>
-
-<p>We will use an exception to indicate an overdraft:</p>
-
-<div class="code">
-<pre>namespace bank
-{
-  using System;
-  public class InsufficientFundsException : ApplicationException
-  {
-  }
-}</pre>
-</div>
-
-<p>Add a new test method to our AccountTest class:</p>
-
-<div class="code">
-<pre>[Test]
-[ExpectedException(typeof(InsufficientFundsException))]
-public void TransferWithInsufficientFunds()
-{
-	Account source = new Account();
-	source.Deposit(200.00F);
-	Account destination = new Account();
-	destination.Deposit(150.00F);
-	source.TransferFunds(destination, 300.00F);
-}</pre>
-</div>
-
-<p>This test method in addition to [Test] attribute has an [ExpectedException] attribute associated with it � this is the way to indicate that the test code is expecting an exception of a certain type; if such an exception is not thrown during the execution � the test will fail. Compile your code and go back to the GUI. As you compiled your test code, the GUI has grayed out and collapsed the test tree as if the tests were not run yet (GUI watches for the changes made to the test assemblies and updates itself when the structure of the test tree has changed � e.g. new test is added). Click the �Run� button � we have a red status bar again. We got the following Failure :
-
-<pre>    TransferWithInsufficentFunds : InsufficientFundsException was expected</pre>
-
-Let�s fix our Account code again, modify the TransferFunds method this way:</p>
-
-<div class="code">
-<pre>public void TransferFunds(Account destination, float amount)
-{
-	destination.Deposit(amount);
-	if(balance-amount&lt;minimumBalance)
-		throw new InsufficientFundsException();
-	Withdraw(amount);
-}</pre>
-</div>
-
-<p>Compile and run the tests � green bar. Success! But wait, looking at the code we�ve just written we can see that the bank may be loosing money on every unsuccessful funds Transfer operation. Let�s write a test to confirm our suspicions. Add this test method:</p>
-	
-<div class="code">
-<pre>[Test]
-public void TransferWithInsufficientFundsAtomicity()
-{
-	Account source = new Account();
-	source.Deposit(200.00F);
-	Account destination = new Account();
-	destination.Deposit(150.00F);
-	try
-	{
-		source.TransferFunds(destination, 300.00F);
-	}
-	catch(InsufficientFundsException expected)
-	{
-	}
-
-	Assert.AreEqual(200.00F,source.Balance);
-	Assert.AreEqual(150.00F,destination.Balance);
-}</pre>
-</div>
-
-<p>We are testing the transactional property of our business method � all operations are successful or none. Compile and run � red bar. OK, we�ve made $300.00 out of a thin air (1999.com d�j� vu?) � the source account has the correct balance of 200.00 but the destination account shows : $450.00. How do we fix this? Can we just move the minimum balance check call in front of the updates:</p>
-
-<div class="code">
-<pre>public void TransferFunds(Account destination, float amount)
-{
-	if(balance-amount&lt;minimumBalance) 
-		throw new InsufficientFundsException();
-	destination.Deposit(amount);
-	Withdraw(amount);
-}</pre>
-</div>
-
-<p>What if the Withdraw() method throws another exception? Should we execute a compensating transaction in the catch block or rely on our transaction manager to restore the state of the objects? We need to answer those questions at some point, but not now; but what do we do with the failing test in the meantime � remove it? A better way is to temporarily ignore it, add the following attribute to your test method</p>
-	
-<div class="code">
-<pre>[Test]
-[Ignore("Decide how to implement transaction management")]
-public void TransferWithInsufficientFundsAtomicity()
-{
-	// code is the same
-}</pre>
-</div>
-
-<p>Compile and run � yellow bar. Click on �Tests Not Run� tab and you will see bank.AccountTest.TransferWithInsufficientFundsAtomicity() in the list along with the Reason this test is ignored.</p>
-
-<p>Looking at our test code we can see that some refactoring is in order. All test methods share a common set of test objects. Let�s extract this initialization code into a setup method and reuse it in all of our tests. The refactored version of our test class looks like this:</p>
-
-<div class="code">
-<pre>namespace bank
-{
-  using System;
-  using NUnit.Framework;
-
-  [TestFixture]
-  public class AccountTest
-  {
-    Account source;
-    Account destination;
-
-    [SetUp]
-    public void Init()
-    {
-      source = new Account();
-      source.Deposit(200.00F);
-      destination = new Account();
-      destination.Deposit(150.00F);
-    }
-
-    [Test]
-    public void TransferFunds()
-    {
-      source.TransferFunds(destination, 100.00f);
-      Assert.AreEqual(250.00F, destination.Balance);
-      Assert.AreEqual(100.00F, source.Balance);
-    }
-
-    [Test]
-    [ExpectedException(typeof(InsufficientFundsException))]
-    public void TransferWithInsufficientFunds()
-    {
-      source.TransferFunds(destination, 300.00F);
-    }
-
-    [Test]
-    [Ignore("Decide how to implement transaction management")]
-    public void TransferWithInsufficientFundsAtomicity()
-    {
-      try
-      {
-        source.TransferFunds(destination, 300.00F);
-      }
-      catch(InsufficientFundsException expected)
-      {
-      }
-
-      Assert.AreEqual(200.00F,source.Balance);
-      Assert.AreEqual(150.00F,destination.Balance);
-    }
-  }
-}</pre>
-</div>
-
-<p>Note that Init method has the common initialization code, it has void return type, no parameters, and it is marked with [SetUp] attribute. Compile and run � same yellow bar!</p>
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<ul>
-<li id="current"><a href="quickStart.html">Quick&nbsp;Start</a></li>
-<li><a href="installation.html">Installation</a></li>
-</ul>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/random.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/random.html b/lib/NUnit.org/NUnit/2.5.9/doc/random.html
deleted file mode 100644
index e605402..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/random.html
+++ /dev/null
@@ -1,133 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - Random</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h3>RandomAttribute (NUnit 2.5)</h3>
-
-<p>The <b>RandomAttribute</b> is used to specify a set of random values to be provided
-   for an individual parameter of a parameterized test method. Since
-   NUnit combines the data provided for each parameter into a set of
-   test cases, data must be provided for all parameters if it is
-   provided for any of them.
-   
-<p>By default, NUnit creates test cases from all possible combinations
-   of the datapoints provided on parameters - the combinatorial approach.
-   This default may be modified by use of specific attributes on the
-   test method itself.
-   
-<p>RandomAttribute supports the following constructors:
-
-<div class="code"><pre>
-public Random( int count );
-public Random( double min, double max, int count );
-public Random( int min, int max, int count );
-</pre></div>
-   
-<h4>Example</h4>
-
-<p>The following test will be executed fifteen times, three times
-for each value of x, each combined with 5 random doubles from -1.0 to +1.0.
-
-<div class="code"><pre>
-[Test]
-public void MyTest(
-    [Values(1,2,3)] int x,
-    [Random(-1.0, 1.0, 5)] double d)
-{
-    ...
-}
-</pre></div>
-
-<h4>See also...</h4>
-<ul>
-<li><a href="values.html">ValuesAttribute</a><li><a href="range.html">RangeAttribute</a><li><a href="sequential.html">SequentialAttribute</a><li><a href="combinatorial.html">CombinatorialAttribute</a><li><a href="pairwise.html">PairwiseAttribute</a></ul>
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<ul>
-<li><a href="category.html">Category</a></li>
-<li><a href="combinatorial.html">Combinatorial</a></li>
-<li><a href="culture.html">Culture</a></li>
-<li><a href="datapoint.html">Datapoint(s)</a></li>
-<li><a href="description.html">Description</a></li>
-<li><a href="exception.html">Exception</a></li>
-<li><a href="explicit.html">Explicit</a></li>
-<li><a href="ignore.html">Ignore</a></li>
-<li><a href="maxtime.html">Maxtime</a></li>
-<li><a href="pairwise.html">Pairwise</a></li>
-<li><a href="platform.html">Platform</a></li>
-<li><a href="property.html">Property</a></li>
-<li id="current"><a href="random.html">Random</a></li>
-<li><a href="range.html">Range</a></li>
-<li><a href="repeat.html">Repeat</a></li>
-<li><a href="requiredAddin.html">RequiredAddin</a></li>
-<li><a href="requiresMTA.html">Requires&nbsp;MTA</a></li>
-<li><a href="requiresSTA.html">Requires&nbsp;STA</a></li>
-<li><a href="requiresThread.html">Requires&nbsp;Thread</a></li>
-<li><a href="sequential.html">Sequential</a></li>
-<li><a href="setCulture.html">SetCulture</a></li>
-<li><a href="setup.html">Setup</a></li>
-<li><a href="setupFixture.html">SetupFixture</a></li>
-<li><a href="suite.html">Suite</a></li>
-<li><a href="teardown.html">Teardown</a></li>
-<li><a href="test.html">Test</a></li>
-<li><a href="testCase.html">TestCase</a></li>
-<li><a href="testCaseSource.html">TestCaseSource</a></li>
-<li><a href="testFixture.html">TestFixture</a></li>
-<li><a href="fixtureSetup.html">TestFixtureSetUp</a></li>
-<li><a href="fixtureTeardown.html">TestFixtureTearDown</a></li>
-<li><a href="theory.html">Theory</a></li>
-<li><a href="timeout.html">Timeout</a></li>
-<li><a href="values.html">Values</a></li>
-<li><a href="valueSource.html">ValueSource</a></li>
-</ul>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/range.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/range.html b/lib/NUnit.org/NUnit/2.5.9/doc/range.html
deleted file mode 100644
index d8c1f44..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/range.html
+++ /dev/null
@@ -1,144 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - Range</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h3>RangeAttribute (NUnit 2.5)</h3>
-
-<p>The <b>RangeAttribute</b> is used to specify a range of values to be provided
-   for an individual parameter of a parameterized test method. Since
-   NUnit combines the data provided for each parameter into a set of
-   test cases, data must be provided for all parameters if it is
-   provided for any of them.
-   
-<p>By default, NUnit creates test cases from all possible combinations
-   of the datapoints provided on parameters - the combinatorial approach.
-   This default may be modified by use of specific attributes on the
-   test method itself.
-   
-<p>RangeAttribute supports the following constructors:
-
-<div class="code"><pre>
-public RangeAttribute( int from, int to );
-public RangeAttribute( int from, int to, int step );
-public RangeAttribute( long from, long to, long step );
-public RangeAttribute( float from, float to, float step );
-public RangeAttribute( double from, double to, double step );
-</pre></div>
-   
-<h4>Example</h4>
-
-<p>The following test will be executed nine times, as follows:
-<pre>
-	MyTest(1, 0.2)
-	MyTest(1, 0.4)
-	MyTest(1, 0.6)
-	MyTest(2, 0.2)
-	MyTest(2, 0.4)
-	MyTest(2, 0.6)
-	MyTest(3, 0.2)
-	MyTest(3, 0.4)
-	MyTest(3, 0.6)
-</pre>
-<div class="code"><pre>
-[Test]
-public void MyTest(
-    [Values(1,2,3) int x,
-    [Range(0.2,0.6,0.2] double d)
-{
-    ...
-}
-</pre></div>
-
-<h4>See also...</h4>
-<ul>
-<li><a href="values.html">ValuesAttribute</a><li><a href="random.html">RandomAttribute</a><li><a href="sequential.html">SequentialAttribute</a><li><a href="combinatorial.html">CombinatorialAttribute</a><li><a href="pairwise.html">PairwiseAttribute</a></ul>
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<ul>
-<li><a href="category.html">Category</a></li>
-<li><a href="combinatorial.html">Combinatorial</a></li>
-<li><a href="culture.html">Culture</a></li>
-<li><a href="datapoint.html">Datapoint(s)</a></li>
-<li><a href="description.html">Description</a></li>
-<li><a href="exception.html">Exception</a></li>
-<li><a href="explicit.html">Explicit</a></li>
-<li><a href="ignore.html">Ignore</a></li>
-<li><a href="maxtime.html">Maxtime</a></li>
-<li><a href="pairwise.html">Pairwise</a></li>
-<li><a href="platform.html">Platform</a></li>
-<li><a href="property.html">Property</a></li>
-<li><a href="random.html">Random</a></li>
-<li id="current"><a href="range.html">Range</a></li>
-<li><a href="repeat.html">Repeat</a></li>
-<li><a href="requiredAddin.html">RequiredAddin</a></li>
-<li><a href="requiresMTA.html">Requires&nbsp;MTA</a></li>
-<li><a href="requiresSTA.html">Requires&nbsp;STA</a></li>
-<li><a href="requiresThread.html">Requires&nbsp;Thread</a></li>
-<li><a href="sequential.html">Sequential</a></li>
-<li><a href="setCulture.html">SetCulture</a></li>
-<li><a href="setup.html">Setup</a></li>
-<li><a href="setupFixture.html">SetupFixture</a></li>
-<li><a href="suite.html">Suite</a></li>
-<li><a href="teardown.html">Teardown</a></li>
-<li><a href="test.html">Test</a></li>
-<li><a href="testCase.html">TestCase</a></li>
-<li><a href="testCaseSource.html">TestCaseSource</a></li>
-<li><a href="testFixture.html">TestFixture</a></li>
-<li><a href="fixtureSetup.html">TestFixtureSetUp</a></li>
-<li><a href="fixtureTeardown.html">TestFixtureTearDown</a></li>
-<li><a href="theory.html">Theory</a></li>
-<li><a href="timeout.html">Timeout</a></li>
-<li><a href="values.html">Values</a></li>
-<li><a href="valueSource.html">ValueSource</a></li>
-</ul>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>


[40/51] [abbrv] [partial] Cleaning up and getting ready to development towards v4.8

Posted by sy...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Gallio.Common.Splash.xml
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Gallio.Common.Splash.xml b/lib/Gallio.3.2.750/tools/Gallio.Common.Splash.xml
deleted file mode 100644
index 4c220b6..0000000
--- a/lib/Gallio.3.2.750/tools/Gallio.Common.Splash.xml
+++ /dev/null
@@ -1,1346 +0,0 @@
-<?xml version="1.0"?>
-<doc>
-    <assembly>
-        <name>Gallio.Common.Splash</name>
-    </assembly>
-    <members>
-        <member name="T:Gallio.Common.Splash.DisposableCookie">
-            <summary>
-            Invokes a delegate when disposed.
-            </summary>
-            <remarks>
-            <para>
-            This type is useful for creating APIs that leverage the C# "using" syntax for scoping.
-            </para>
-            <example>
-            <code>
-            using (document.BeginStyle(Style.Default)) // returns a DisposableCookie
-            {
-                document.AppendText("Hello world");
-            }
-            </code>
-            </example>
-            </remarks>
-        </member>
-        <member name="M:Gallio.Common.Splash.DisposableCookie.#ctor(Gallio.Common.Splash.DisposableCookie.Action)">
-            <summary>
-            Creates a disposable cookie.
-            </summary>
-            <param name="action">The action to perform when <see cref="M:Gallio.Common.Splash.DisposableCookie.Dispose"/> is called.</param>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="action"/> is null.</exception>
-        </member>
-        <member name="M:Gallio.Common.Splash.DisposableCookie.Dispose">
-            <summary>
-            Invokes the dispose action.
-            </summary>
-        </member>
-        <member name="T:Gallio.Common.Splash.DisposableCookie.Action">
-            <summary>
-            Specifies the action to perform when <see cref="M:Gallio.Common.Splash.DisposableCookie.Dispose"/> is called.
-            </summary>
-        </member>
-        <member name="T:Gallio.Common.Splash.EmbeddedImage">
-            <summary>
-            An embedded image wraps an <see cref="P:Gallio.Common.Splash.EmbeddedImage.Image"/> so that it can be embedded in
-            a Splash document.
-            </summary>
-        </member>
-        <member name="T:Gallio.Common.Splash.EmbeddedObject">
-            <summary>
-            An embedded object that can be drawn into a <see cref="T:Gallio.Common.Splash.SplashView"/>.
-            </summary>
-        </member>
-        <member name="M:Gallio.Common.Splash.EmbeddedObject.CreateClient(Gallio.Common.Splash.IEmbeddedObjectSite)">
-            <summary>
-            Creates an instance of an embedded object client attached to the specified site.
-            </summary>
-            <param name="site">The site.</param>
-            <returns>The client.</returns>
-        </member>
-        <member name="M:Gallio.Common.Splash.EmbeddedImage.#ctor(System.Drawing.Image)">
-            <summary>
-            Creates an embedded image.
-            </summary>
-            <param name="image">The image to draw into the client area.</param>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="image"/> is null.</exception>
-        </member>
-        <member name="M:Gallio.Common.Splash.EmbeddedImage.CreateClient(Gallio.Common.Splash.IEmbeddedObjectSite)">
-            <inheritdoc />
-        </member>
-        <member name="P:Gallio.Common.Splash.EmbeddedImage.Image">
-            <summary>
-            Gets the image.
-            </summary>
-        </member>
-        <member name="P:Gallio.Common.Splash.EmbeddedImage.Margin">
-            <summary>
-            Gets or sets the margin around the image.
-            </summary>
-        </member>
-        <member name="P:Gallio.Common.Splash.EmbeddedImage.Baseline">
-            <summary>
-            Gets or sets the baseline of the image.
-            </summary>
-            <remarks>
-            The default value is 0 which positions the bottom of the image in line with the
-            baseline of surrounding text.  Use a positive value to raise the image above the
-            text baseline or a negative value to lower it below the text baseline.
-            </remarks>
-        </member>
-        <member name="T:Gallio.Common.Splash.IEmbeddedObjectClient">
-            <summary>
-            Represents an instance of an embedded object that has been attached to a particular site.
-            </summary>
-            <remarks>
-            <para>
-            When the client is disposed, it should release all attachments to its site.
-            </para>
-            </remarks>
-        </member>
-        <member name="M:Gallio.Common.Splash.IEmbeddedObjectClient.Measure">
-            <summary>
-            Measure the client.
-            </summary>
-            <returns>The embedded object measurements.</returns>
-        </member>
-        <member name="M:Gallio.Common.Splash.IEmbeddedObjectClient.Show(System.Drawing.Rectangle,System.Boolean)">
-            <summary>
-            Shows the embedded object and sets its bounds.
-            </summary>
-            <param name="bounds">The bounds of the embedded object.</param>
-            <param name="rightToLeft">True if the current reading order is right to left.</param>
-        </member>
-        <member name="M:Gallio.Common.Splash.IEmbeddedObjectClient.Hide">
-            <summary>
-            Hides the embedded object.
-            </summary>
-        </member>
-        <member name="M:Gallio.Common.Splash.IEmbeddedObjectClient.Paint(System.Drawing.Graphics,Gallio.Common.Splash.PaintOptions,System.Drawing.Rectangle,System.Boolean)">
-            <summary>
-            Paints the embedded object.
-            </summary>
-            <param name="g">The graphics context.  Not null.</param>
-            <param name="paintOptions">The paint options.  Not null.</param>
-            <param name="bounds">The bounds of the embedded object.</param>
-            <param name="rightToLeft">True if the current reading order is right to left.</param>
-        </member>
-        <member name="P:Gallio.Common.Splash.IEmbeddedObjectClient.RequiresPaint">
-            <summary>
-            Returns true if the <see cref="M:Gallio.Common.Splash.IEmbeddedObjectClient.Paint(System.Drawing.Graphics,Gallio.Common.Splash.PaintOptions,System.Drawing.Rectangle,System.Boolean)"/> method should be called or false if the
-            client paints itself by other means.
-            </summary>
-        </member>
-        <member name="T:Gallio.Common.Splash.EmbeddedControl">
-            <summary>
-            An embedded image wraps a <see cref="P:Gallio.Common.Splash.EmbeddedControl.Control"/> so that it can be embedded in
-            a Splash document.
-            </summary>
-        </member>
-        <member name="M:Gallio.Common.Splash.EmbeddedControl.#ctor(System.Windows.Forms.Control)">
-            <summary>
-            Creates an embedded control.
-            </summary>
-            <param name="control">The control to draw into the client area.</param>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="control"/> is null.</exception>
-        </member>
-        <member name="M:Gallio.Common.Splash.EmbeddedControl.CreateClient(Gallio.Common.Splash.IEmbeddedObjectSite)">
-            <inheritdoc />
-        </member>
-        <member name="P:Gallio.Common.Splash.EmbeddedControl.Control">
-            <summary>
-            Gets the control.
-            </summary>
-        </member>
-        <member name="P:Gallio.Common.Splash.EmbeddedControl.Margin">
-            <summary>
-            Gets or sets the margin around the control.
-            </summary>
-        </member>
-        <member name="P:Gallio.Common.Splash.EmbeddedControl.Baseline">
-            <summary>
-            Gets or sets the baseline of the control.
-            </summary>
-            <remarks>
-            The default value is 0 which positions the bottom of the control in line with the
-            baseline of surrounding text.  Use a positive value to raise the control above the
-            text baseline or a negative value to lower it below the text baseline.
-            </remarks>
-        </member>
-        <member name="T:Gallio.Common.Splash.EmbeddedObjectMeasurements">
-            <summary>
-            Describes the measurements of an embedded object.
-            </summary>
-        </member>
-        <member name="M:Gallio.Common.Splash.EmbeddedObjectMeasurements.#ctor(System.Drawing.Size)">
-            <summary>
-            Initializes the measurements.
-            </summary>
-            <param name="size">The size of the embedded object.</param>
-        </member>
-        <member name="P:Gallio.Common.Splash.EmbeddedObjectMeasurements.Size">
-            <summary>
-            Gets or sets the size of the embedded object.
-            </summary>
-        </member>
-        <member name="P:Gallio.Common.Splash.EmbeddedObjectMeasurements.Margin">
-            <summary>
-            Gets or sets the margin around the embedded object.
-            </summary>
-        </member>
-        <member name="P:Gallio.Common.Splash.EmbeddedObjectMeasurements.Descent">
-            <summary>
-            Gets or sets the descent height of the object in pixels.
-            </summary>
-            <remarks>
-            The descent is the number of pixels from the baseline of the object
-            to its bottom.  It used to align the baseline of the object with the baseline
-            of the text that surrounds it on the line.
-            </remarks>
-        </member>
-        <member name="T:Gallio.Common.Splash.IEmbeddedObjectSite">
-            <summary>
-            Describes the environment of an embedded object.
-            </summary>
-        </member>
-        <member name="P:Gallio.Common.Splash.IEmbeddedObjectSite.CharIndex">
-            <summary>
-            Gets the index of the character that represents the embedded object
-            for selection and hit testing in the document.
-            </summary>
-        </member>
-        <member name="P:Gallio.Common.Splash.IEmbeddedObjectSite.ParentControl">
-            <summary>
-            Gets the control of the containing view.
-            </summary>
-        </member>
-        <member name="P:Gallio.Common.Splash.IEmbeddedObjectSite.ParagraphStyle">
-            <summary>
-            Gets the style of the paragraph that contains the embedded object.
-            </summary>
-        </member>
-        <member name="P:Gallio.Common.Splash.IEmbeddedObjectSite.InlineStyle">
-            <summary>
-            Gets the style of the inline run that contains the embedded object.
-            </summary>
-        </member>
-        <member name="T:Gallio.Common.Splash.Internal.DeviceContext">
-            <summary>
-            A low-level wrapper for a graphics context.
-            </summary>
-        </member>
-        <member name="P:Gallio.Common.Splash.Internal.EmbeddedObjectHost.LayoutBounds">
-            <summary>
-            Gets or sets the layout bounds relative to the layout origin.
-            This is set during the main layout operation and cached until relayout occurs.
-            </summary>
-        </member>
-        <member name="T:Gallio.Common.Splash.Internal.Paragraph">
-            <summary>
-            Internal structure describing a paragraph in the document.
-            Each paragraph consists of a number of characters subdivided into runs that have
-            the same style or that represent embedded objects.
-            </summary>
-            <remarks>
-            Packed into 16 bytes per Paragraph.  Keep it that way or make it smaller.
-            </remarks>
-        </member>
-        <member name="T:Gallio.Common.Splash.Internal.Run">
-            <summary>
-            Internal structure describing a run of text or an embedded object in the document.
-            </summary>
-            <remarks>
-            Packed into 4 bytes per Run.  Keep it that way.
-            </remarks>
-        </member>
-        <member name="T:Gallio.Common.Splash.Internal.ScriptLine">
-            <summary>
-            Internal structure that maps a visual line onto a particular range of runs
-            within a paragraph and includes the character position of required line breaks.
-            </summary>
-        </member>
-        <member name="F:Gallio.Common.Splash.Internal.ScriptLine.Y">
-            <summary>
-            The absolute vertical offset of the line in the document when rendered.
-            </summary>
-        </member>
-        <member name="F:Gallio.Common.Splash.Internal.ScriptLine.X">
-            <summary>
-            The absolute horizontal offset of the line in the document when rendered.
-            </summary>
-        </member>
-        <member name="F:Gallio.Common.Splash.Internal.ScriptLine.Height">
-            <summary>
-            The height of the line.
-            </summary>
-        </member>
-        <member name="F:Gallio.Common.Splash.Internal.ScriptLine.Descent">
-            <summary>
-            The descent height of the line (below text baseline).
-            </summary>
-        </member>
-        <member name="F:Gallio.Common.Splash.Internal.ScriptLine.ParagraphIndex">
-            <summary>
-            The index of the paragraph that appears on the line.
-            </summary>
-        </member>
-        <member name="F:Gallio.Common.Splash.Internal.ScriptLine.ScriptRunIndex">
-            <summary>
-            The index of the paragraph's first script run that appears on the line.
-            </summary>
-        </member>
-        <member name="F:Gallio.Common.Splash.Internal.ScriptLine.ScriptRunCount">
-            <summary>
-            The number of script runs that appear on the line.
-            </summary>
-        </member>
-        <member name="F:Gallio.Common.Splash.Internal.ScriptLine.TruncatedLeadingCharsCount">
-            <summary>
-            The number of leading chars in the first script run to truncate due to word wrap.
-            </summary>
-        </member>
-        <member name="F:Gallio.Common.Splash.Internal.ScriptLine.TruncatedTrailingCharsCount">
-            <summary>
-            The number of trailing chars in the last script run to truncate due to word wrap.
-            </summary>
-        </member>
-        <member name="P:Gallio.Common.Splash.Internal.ScriptLine.Ascent">
-            <summary>
-            The ascent height of the line (above text baseline).
-            </summary>
-        </member>
-        <member name="T:Gallio.Common.Splash.Internal.ScriptParagraph">
-            <summary>
-            Internal structure with script information necessary for layout and display of a paragraph.
-            Includes script information for each run in the paragraph.
-            </summary>
-            <remarks>
-            We pool allocated script paragraph structures and cache them to improve performance
-            and reduce the number of memory allocations.
-            </remarks>
-        </member>
-        <member name="T:Gallio.Common.Splash.Internal.ScriptRun">
-            <summary>
-            Internal structure with script information necessary for layout and display of a run.
-            A single run may be subdivided into multiple script runs.
-            </summary>
-            <remarks>
-            Since a script paragraph can contain many script runs and each one uses a variable amount
-            of storage for buffers of various kinds, this structure contains indices into shared
-            buffers managed by the containing script paragraph.  This reduces the number of required
-            memory allocations per paragraph.
-            </remarks>
-        </member>
-        <member name="F:Gallio.Common.Splash.Internal.ScriptRun.ScriptAnalysis">
-            <summary>
-            The script analysis for the run produced during itemization.
-            </summary>
-        </member>
-        <member name="F:Gallio.Common.Splash.Internal.ScriptRun.CharIndexInParagraph">
-            <summary>
-            The index of the first character of the run relative to the first character of its containing paragraph.
-            </summary>
-        </member>
-        <member name="F:Gallio.Common.Splash.Internal.ScriptRun.GlyphIndexInParagraph">
-            <summary>
-            The index of the first glyph of the run relative to the first glyph of its containing paragraph.
-            </summary>
-        </member>
-        <member name="F:Gallio.Common.Splash.Internal.ScriptRun.GlyphCount">
-            <summary>
-            The number of glyphs in the run.
-            </summary>
-        </member>
-        <member name="F:Gallio.Common.Splash.Internal.ScriptRun.Height">
-            <summary>
-            The height of the run excluding its margins.
-            </summary>
-        </member>
-        <member name="F:Gallio.Common.Splash.Internal.ScriptRun.Descent">
-            <summary>
-            The descent height of the run (below text baseline).
-            </summary>
-        </member>
-        <member name="F:Gallio.Common.Splash.Internal.ScriptRun.TopMargin">
-            <summary>
-            The top margin of the run.
-            </summary>
-        </member>
-        <member name="F:Gallio.Common.Splash.Internal.ScriptRun.BottomMargin">
-            <summary>
-            The bottom margin of the run.
-            </summary>
-        </member>
-        <member name="F:Gallio.Common.Splash.Internal.ScriptRun.ABC">
-            <summary>
-            The advance width spacing of the run.
-            </summary>
-        </member>
-        <member name="P:Gallio.Common.Splash.Internal.ScriptRun.Ascent">
-            <summary>
-            The ascent height of the run (above text baseline).
-            </summary>
-        </member>
-        <member name="T:Gallio.Common.Splash.Key`1">
-            <summary>
-            A strongly-typed key to be used together with an associative array to help the
-            compiler perform better type checking of the value associated with the key.
-            </summary>
-            <typeparam name="TValue">The type of value associated with the key.</typeparam>
-        </member>
-        <member name="M:Gallio.Common.Splash.Key`1.#ctor(System.String)">
-            <summary>
-            Creates a new key.
-            </summary>
-            <param name="name">The unique name of the key.</param>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="name"/> is null.</exception>
-        </member>
-        <member name="M:Gallio.Common.Splash.Key`1.ToString">
-            <inheritdoc />
-        </member>
-        <member name="P:Gallio.Common.Splash.Key`1.Name">
-            <summary>
-            Gets the unique name of the key.
-            </summary>
-        </member>
-        <member name="T:Gallio.Common.Splash.PaintOptions">
-            <summary>
-            Provides style parameters for painting.
-            </summary>
-        </member>
-        <member name="M:Gallio.Common.Splash.PaintOptions.#ctor">
-            <summary>
-            Initializes paint options to system defaults.
-            </summary>
-        </member>
-        <member name="P:Gallio.Common.Splash.PaintOptions.BackgroundColor">
-            <summary>
-            Gets or sets the background color.
-            </summary>
-        </member>
-        <member name="P:Gallio.Common.Splash.PaintOptions.SelectedTextColor">
-            <summary>
-            Gets or sets the selected text color.
-            </summary>
-        </member>
-        <member name="P:Gallio.Common.Splash.PaintOptions.SelectedBackgroundColor">
-            <summary>
-            Gets or sets the selected background color.
-            </summary>
-        </member>
-        <member name="T:Gallio.Common.Splash.ParagraphChangedEventArgs">
-            <summary>
-            Arguments for the event raised when a paragraph is changed.
-            </summary>
-        </member>
-        <member name="M:Gallio.Common.Splash.ParagraphChangedEventArgs.#ctor(System.Int32)">
-            <summary>
-            Creates event arguments for paragraph changed.
-            </summary>
-            <param name="paragraphIndex">The index of the paragraph that was changed.</param>
-        </member>
-        <member name="P:Gallio.Common.Splash.ParagraphChangedEventArgs.ParagraphIndex">
-            <summary>
-            Gets the index of the paragraph that was changed.
-            </summary>
-        </member>
-        <member name="T:Gallio.Common.Splash.PixelTabStopRuler">
-            <summary>
-            A tab stop ruler based on per-pixel offsets.
-            </summary>
-        </member>
-        <member name="T:Gallio.Common.Splash.TabStopRuler">
-            <summary>
-            Describes the strategy for advancing to tab stops.
-            </summary>
-        </member>
-        <member name="M:Gallio.Common.Splash.TabStopRuler.AdvanceToNextTabStop(System.Int32)">
-            <summary>
-            Advances the X position to the next tab stop.
-            </summary>
-            <param name="xPosition">The X position to advance.</param>
-            <returns>The advanced X position.</returns>
-        </member>
-        <member name="M:Gallio.Common.Splash.TabStopRuler.Equals(Gallio.Common.Splash.TabStopRuler)">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.Common.Splash.PixelTabStopRuler.#ctor(System.Int32,System.Int32)">
-            <summary>
-            Creates a tab stop ruler based on per-pixel offsets.
-            </summary>
-            <param name="pixelsPerTabStop">The number of pixels per tab stop, or 0 to always advance the minimum tab width.</param>
-            <param name="minimumTabWidth">The minimum tab width, or 0 if there is no minimum.</param>
-            <exception cref="T:System.ArgumentOutOfRangeException">Thrown if <paramref name="pixelsPerTabStop"/> or
-            <paramref name="minimumTabWidth"/> is less than 0.</exception>
-        </member>
-        <member name="M:Gallio.Common.Splash.PixelTabStopRuler.AdvanceToNextTabStop(System.Int32)">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.Common.Splash.PixelTabStopRuler.Equals(System.Object)">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.Common.Splash.PixelTabStopRuler.Equals(Gallio.Common.Splash.TabStopRuler)">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.Common.Splash.PixelTabStopRuler.Equals(Gallio.Common.Splash.PixelTabStopRuler)">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.Common.Splash.PixelTabStopRuler.GetHashCode">
-            <inheritdoc />
-        </member>
-        <member name="P:Gallio.Common.Splash.PixelTabStopRuler.PixelsPerTabStop">
-            <summary>
-            Gets the number of pixels per tab stop, or 0 to always advance the minimum tab width.
-            </summary>
-        </member>
-        <member name="P:Gallio.Common.Splash.PixelTabStopRuler.MinimumTabWidth">
-            <summary>
-            Gets the minimum tab width.
-            </summary>
-        </member>
-        <member name="T:Gallio.Common.Splash.SnapPosition">
-            <summary>
-            Provides the result of mapping a screen position to a character index.
-            </summary>
-        </member>
-        <member name="M:Gallio.Common.Splash.SnapPosition.#ctor(Gallio.Common.Splash.SnapKind,System.Int32)">
-            <summary>
-            Initializes a snap result.
-            </summary>
-            <param name="kind">The snap kind.</param>
-            <param name="charIndex">The character index of the snap, or -1 if no snap.</param>
-        </member>
-        <member name="P:Gallio.Common.Splash.SnapPosition.Kind">
-            <summary>
-            Gets the snap kind.
-            </summary>
-        </member>
-        <member name="P:Gallio.Common.Splash.SnapPosition.CharIndex">
-            <summary>
-            Gets the character index of the snap, or -1 if no snap.
-            </summary>
-        </member>
-        <member name="T:Gallio.Common.Splash.SnapKind">
-            <summary>
-            Describes the kind of snap.
-            </summary>
-        </member>
-        <member name="F:Gallio.Common.Splash.SnapKind.None">
-            <summary>
-            The character snap did not succeed.  The position was outside the bounds of the document.
-            </summary>
-        </member>
-        <member name="F:Gallio.Common.Splash.SnapKind.Exact">
-            <summary>
-            The character snap was exact.
-            </summary>
-        </member>
-        <member name="F:Gallio.Common.Splash.SnapKind.Leading">
-            <summary>
-            The character snap was before the actual character or at a position above
-            the start of the document.  (eg. To the left of the character if the reading order is left-to-right.)
-            </summary>
-        </member>
-        <member name="F:Gallio.Common.Splash.SnapKind.Trailing">
-            <summary>
-            The character snap was after the actual character or at a position above
-            the start of the document.  (eg. To the right of the character if the reading order is left-to-right.)
-            </summary>
-        </member>
-        <member name="T:Gallio.Common.Splash.SplashDocument">
-            <summary>
-            A splash document contains styled text and embedded objects and retains layout information
-            for presentation.
-            </summary>
-        </member>
-        <member name="F:Gallio.Common.Splash.SplashDocument.ObjectRunPlaceholderChar">
-            <summary>
-            The character used as a placeholder for text itemizing when a paragraph contains an object run.
-            </summary>
-        </member>
-        <member name="F:Gallio.Common.Splash.SplashDocument.MaxCharsPerRun">
-            <summary>
-            The maximum number of characters that a text run can contain.
-            </summary>
-        </member>
-        <member name="F:Gallio.Common.Splash.SplashDocument.MaxObjects">
-            <summary>
-            The maximum number of distinct objects supported by the implementation.
-            </summary>
-        </member>
-        <member name="F:Gallio.Common.Splash.SplashDocument.MaxStyles">
-            <summary>
-            The maximum number of distinct styles supported by the implementation.
-            </summary>
-            <value>256</value>
-        </member>
-        <member name="M:Gallio.Common.Splash.SplashDocument.#ctor">
-            <summary>
-            Creates an empty splash document.
-            </summary>
-        </member>
-        <member name="M:Gallio.Common.Splash.SplashDocument.Clear">
-            <summary>
-            Clears the text in the document.
-            </summary>
-        </member>
-        <member name="M:Gallio.Common.Splash.SplashDocument.GetTextRange(System.Int32,System.Int32)">
-            <summary>
-            Gets a range of the document text.
-            </summary>
-            <param name="start">The start character index.</param>
-            <param name="length">The length of the range.</param>
-            <returns>The text in the specified range.</returns>
-            <exception cref="T:System.ArgumentOutOfRangeException">Thrown if <paramref name="start"/>
-            or <paramref name="length"/> are negative or refer to a range that exceeds the document length.</exception>
-        </member>
-        <member name="M:Gallio.Common.Splash.SplashDocument.GetStyleAtIndex(System.Int32)">
-            <summary>
-            Gets the style of the text at the specified character index.
-            </summary>
-            <param name="index">The character index.</param>
-            <returns>The style.</returns>
-            <exception cref="T:System.ArgumentOutOfRangeException">Thrown if <paramref name="index"/> is
-            outside of the bounds of the document.</exception>
-        </member>
-        <member name="M:Gallio.Common.Splash.SplashDocument.GetObjectAtIndex(System.Int32)">
-            <summary>
-            Gets the embedded object at the specified character index, or null if none.
-            </summary>
-            <param name="index">The character index.</param>
-            <returns>The embedded object, or null if none.</returns>
-            <exception cref="T:System.ArgumentOutOfRangeException">Thrown if <paramref name="index"/> is
-            outside of the bounds of the document.</exception>
-        </member>
-        <member name="M:Gallio.Common.Splash.SplashDocument.TryGetAnnotationAtIndex``1(Gallio.Common.Splash.Key{``0},System.Int32,``0@)">
-            <summary>
-            Gets the annotation with the specified key at the specified character index.
-            </summary>
-            <param name="key">The annotation key.</param>
-            <param name="index">The character index.</param>
-            <param name="value">Set to the annotation value, or default if none.</param>
-            <returns>True if an annotation was found.</returns>
-            <exception cref="T:System.ArgumentOutOfRangeException">Thrown if <paramref name="index"/> is
-            outside of the bounds of the document.</exception>
-        </member>
-        <member name="M:Gallio.Common.Splash.SplashDocument.TryGetCurrentAnnotation``1(Gallio.Common.Splash.Key{``0},``0@)">
-            <summary>
-            Gets the current annotation with the specified key.
-            </summary>
-            <param name="key">The annotation key.</param>
-            <param name="value">Set to the annotation value, or default if none.</param>
-            <returns>True if there is a current annotation.</returns>
-        </member>
-        <member name="M:Gallio.Common.Splash.SplashDocument.AppendText(System.String)">
-            <summary>
-            Appends text to the document.
-            </summary>
-            <param name="text">The text to append.</param>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="text"/> is null.</exception>
-        </member>
-        <member name="M:Gallio.Common.Splash.SplashDocument.AppendLine">
-            <summary>
-            Appends a new line to the document.
-            </summary>
-        </member>
-        <member name="M:Gallio.Common.Splash.SplashDocument.AppendObject(Gallio.Common.Splash.EmbeddedObject)">
-            <summary>
-            Appends an object to the document.
-            </summary>
-            <param name="obj">The object to append.</param>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="obj"/> is null.</exception>
-        </member>
-        <member name="M:Gallio.Common.Splash.SplashDocument.BeginStyle(Gallio.Common.Splash.Style)">
-            <summary>
-            Pushes a new style onto the style stack.
-            Subsequently appended content will use the new style.
-            </summary>
-            <example>
-            <code>
-            using (document.BeginStyle(linkStyle))
-            {
-                using (document.BeginAnnotation("href", "http://www.gallio.org"))
-                {
-                    document.AppendText("Gallio");
-                }
-            }
-            </code>
-            </example>
-            <param name="style">The style to use.</param>
-            <returns>A value that when disposed automatically calls <see cref="M:Gallio.Common.Splash.SplashDocument.EndStyle"/>.
-            Used with the C# "using" syntax to end the style at the end of a block scope.</returns>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="style"/> is null.</exception>
-            <exception cref="T:System.InvalidOperationException">Thrown if more than <see cref="F:Gallio.Common.Splash.SplashDocument.MaxStyles"/> distinct styles are used.</exception>
-            <seealso cref="M:Gallio.Common.Splash.SplashDocument.EndStyle"/>
-        </member>
-        <member name="M:Gallio.Common.Splash.SplashDocument.EndStyle">
-            <summary>
-            Pops the current style off the style stack.
-            Subsequently appended content will use the previous style.
-            </summary>
-            <exception cref="T:System.InvalidOperationException">Thrown if the style stack only contains the default style.</exception>
-            <seealso cref="M:Gallio.Common.Splash.SplashDocument.BeginStyle(Gallio.Common.Splash.Style)"/>
-        </member>
-        <member name="M:Gallio.Common.Splash.SplashDocument.BeginAnnotation``1(Gallio.Common.Splash.Key{``0},``0)">
-            <summary>
-            Pushes an annotation value onto the keyed annotation stack.
-            Subsequently appended content will acquire the new annotation value.
-            </summary>
-            <remarks>
-            <para>
-            Each annotation key has its own separate stack.
-            </para>
-            </remarks>
-            <example>
-            <code>
-            using (document.BeginStyle(linkStyle))
-            {
-                using (document.BeginAnnotation("href", "http://www.gallio.org"))
-                {
-                    document.AppendText("Gallio");
-                }
-            }
-            </code>
-            </example>
-            <param name="key">The annotation key.</param>
-            <param name="value">The annotation value.</param>
-            <returns>A value that when disposed automatically calls <see cref="M:Gallio.Common.Splash.SplashDocument.EndAnnotation``1(Gallio.Common.Splash.Key{``0})"/>.
-            Used with the C# "using" syntax to end the annotation at the end of a block scope.</returns>
-            <seealso cref="M:Gallio.Common.Splash.SplashDocument.EndAnnotation``1(Gallio.Common.Splash.Key{``0})"/>
-        </member>
-        <member name="M:Gallio.Common.Splash.SplashDocument.EndAnnotation``1(Gallio.Common.Splash.Key{``0})">
-            <summary>
-            Pushes an annotation value onto the keyed annotation stack.
-            Subsequently appended content will acquire the new annotation value.
-            </summary>
-            <remarks>
-            <para>
-            Each annotation key has its own separate stack.
-            </para>
-            </remarks>
-            <param name="key">The annotation key.</param>
-            <exception cref="T:System.InvalidOperationException">Thrown if there is no current annotation with the
-            specified key.</exception>
-            <seealso cref="M:Gallio.Common.Splash.SplashDocument.BeginAnnotation``1(Gallio.Common.Splash.Key{``0},``0)"/>
-        </member>
-        <member name="M:Gallio.Common.Splash.SplashDocument.ToString">
-            <summary>
-            Returns the plain text content of the document as a string.
-            </summary>
-            <returns></returns>
-        </member>
-        <member name="E:Gallio.Common.Splash.SplashDocument.DocumentCleared">
-            <summary>
-            Event raised when the document is cleared.
-            </summary>
-        </member>
-        <member name="E:Gallio.Common.Splash.SplashDocument.ParagraphChanged">
-            <summary>
-            Event raised when a paragraph is changed.
-            </summary>
-        </member>
-        <member name="P:Gallio.Common.Splash.SplashDocument.ParagraphCount">
-            <summary>
-            Gets the number of paragraphs in the document.
-            </summary>
-            <remarks>
-            This number is guaranteed to always be at least 1 even in an empty document.
-            </remarks>
-        </member>
-        <member name="P:Gallio.Common.Splash.SplashDocument.CharCount">
-            <summary>
-            Gets the number of characters in the document.
-            </summary>
-        </member>
-        <member name="P:Gallio.Common.Splash.SplashDocument.CurrentStyle">
-            <summary>
-            Gets the current style.
-            </summary>
-        </member>
-        <member name="F:Gallio.Common.Splash.Native.ABC.abcA">
-            <summary>
-            The A spacing of the character. The A spacing is the distance to add to the current position before drawing the character glyph.
-            </summary>
-        </member>
-        <member name="F:Gallio.Common.Splash.Native.ABC.abcB">
-            <summary>
-            The B spacing of the character. The B spacing is the width of the drawn portion of the character glyph.
-            </summary>
-        </member>
-        <member name="F:Gallio.Common.Splash.Native.ABC.abcC">
-            <summary>
-            The C spacing of the character. The C spacing is the distance to add to the current position to provide white space to the right of the character glyph.
-            </summary>
-        </member>
-        <member name="T:Gallio.Common.Splash.SplashLayout">
-            <summary>
-            Describes the layout of a splash document.
-            </summary>
-            <remarks>
-            <para>
-            Much of this implementation is based on information from the amazing Neatpad tutorial by James Brown.
-            http://www.catch22.net/tuts/neatpad
-            </para>
-            </remarks>
-        </member>
-        <member name="M:Gallio.Common.Splash.SplashLayout.#ctor(Gallio.Common.Splash.SplashDocument,System.Windows.Forms.Control)">
-            <summary>
-            Creates a layout for a document.
-            </summary>
-            <param name="document">The document.</param>
-            <param name="parentControl">The parent control to which embedded objects can
-            attach themselves.</param>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="document"/>
-            or <paramref name="parentControl"/> is null.</exception>
-        </member>
-        <member name="M:Gallio.Common.Splash.SplashLayout.Dispose">
-            <summary>
-            Disposes the layout.
-            </summary>
-        </member>
-        <member name="M:Gallio.Common.Splash.SplashLayout.Dispose(System.Boolean)">
-            <summary>
-            Disposes the layout.
-            </summary>
-            <param name="disposing">True if <see cref="M:Gallio.Common.Splash.SplashLayout.Dispose"/> was called explicitly.</param>
-        </member>
-        <member name="M:Gallio.Common.Splash.SplashLayout.Reset">
-            <summary>
-            Resets all layout information and frees internal buffers.
-            </summary>
-        </member>
-        <member name="M:Gallio.Common.Splash.SplashLayout.Update(System.Drawing.Point)">
-            <summary>
-            Updates the layout.
-            </summary>
-            <remarks>
-            <para>
-            Call this method some time after UpdateRequired is raised or whenever the layout origin changes.
-            </para>
-            </remarks>
-            <param name="layoutOrigin">The origin of the document layout area in the parent control.</param>
-        </member>
-        <member name="M:Gallio.Common.Splash.SplashLayout.GetSnapPositionAtPoint(System.Drawing.Point,System.Drawing.Point)">
-            <summary>
-            Gets the snap position that corresponds to a point in the control.
-            </summary>
-            <param name="point">The point to check.</param>
-            <param name="layoutOrigin">The origin of the document layout area in the parent control.</param>
-            <returns>The character snap.</returns>
-        </member>
-        <member name="M:Gallio.Common.Splash.SplashLayout.Paint(System.Drawing.Graphics,System.Drawing.Point,System.Drawing.Rectangle,Gallio.Common.Splash.PaintOptions,System.Int32,System.Int32)">
-            <summary>
-            Paints a region of text.
-            </summary>
-            <remarks>
-            Be sure to update the layout before calling this method.
-            </remarks>
-            <param name="graphics">The graphics context.</param>
-            <param name="layoutOrigin">The origin of the document layout area in the parent control.</param>
-            <param name="clipRect">The clip rectangle of the region to paint in the device context.</param>
-            <param name="paintOptions">The paint options.</param>
-            <param name="selectedCharIndex">The index of the first selected character.  Ignored if
-            the number of selected characters is 0.</param>
-            <param name="selectedCharCount">The number of selected characters or 0 if none.
-            May be negative if the selection is reversed.</param>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="graphics"/> or
-            <paramref name="paintOptions"/> is null.</exception>
-        </member>
-        <member name="M:Gallio.Common.Splash.SplashLayout.AppendScriptLinesForScriptParagraph(Gallio.Common.Splash.Internal.DeviceContext,System.Int32)">
-            <summary>
-            Computes the layout of a <see cref="T:Gallio.Common.Splash.Internal.ScriptParagraph"/> and appends one or
-            more <see cref="T:Gallio.Common.Splash.Internal.ScriptLine"/>s to the <see cref="F:Gallio.Common.Splash.SplashLayout.scriptLineBuffer"/>.
-            </summary>
-            <param name="deviceContext">The HDC state.</param>
-            <param name="paragraphIndex">The paragraph index to layout.</param>
-        </member>
-        <member name="M:Gallio.Common.Splash.SplashLayout.GetScriptParagraph(Gallio.Common.Splash.Internal.DeviceContext,System.Int32)">
-            <summary>
-            Gets a fully analyzed <see cref="T:Gallio.Common.Splash.Internal.ScriptParagraph"/> by paragraph index.
-            </summary>
-        </member>
-        <member name="M:Gallio.Common.Splash.SplashLayout.AnalyzeParagraph(Gallio.Common.Splash.Internal.DeviceContext,Gallio.Common.Splash.Internal.Paragraph*,Gallio.Common.Splash.Internal.ScriptParagraph*)">
-            <summary>
-            Analyzes a <see cref="T:Gallio.Common.Splash.Internal.Paragraph"/> to populate a <see cref="T:Gallio.Common.Splash.Internal.ScriptParagraph"/>.
-            </summary>
-        </member>
-        <member name="E:Gallio.Common.Splash.SplashLayout.UpdateRequired">
-            <summary>
-            Event raised when a layout property changes and requires an update.
-            </summary>
-        </member>
-        <member name="P:Gallio.Common.Splash.SplashLayout.Document">
-            <summary>
-            Gets the document this layout is for.
-            </summary>
-        </member>
-        <member name="P:Gallio.Common.Splash.SplashLayout.ParentControl">
-            <summary>
-            Gets the parent control to which embedded objects can attach themselves.
-            </summary>
-        </member>
-        <member name="P:Gallio.Common.Splash.SplashLayout.DesiredLayoutWidth">
-            <summary>
-            Gets or sets the desired layout width.
-            </summary>
-        </member>
-        <member name="P:Gallio.Common.Splash.SplashLayout.DesiredLayoutRightToLeft">
-            <summary>
-            Gets or sets the desired reading order for the layout.
-            </summary>
-        </member>
-        <member name="P:Gallio.Common.Splash.SplashLayout.CurrentLayoutWidth">
-            <summary>
-            Gets or sets the current layout width which may differ from the desired layout width
-            if a relayout is pending.
-            </summary>
-        </member>
-        <member name="P:Gallio.Common.Splash.SplashLayout.CurrentLayoutHeight">
-            <summary>
-            Gets or sets the current layout height which may differ from the expected layout height
-            if a relayout is pending.
-            </summary>
-        </member>
-        <member name="P:Gallio.Common.Splash.SplashLayout.CurrentLayoutRightToLeft">
-            <summary>
-            Gets or sets the current reading order which may differ from the desired reading order
-            if a relayout is pending.
-            </summary>
-        </member>
-        <member name="T:Gallio.Common.Splash.Style">
-            <summary>
-            Describes the style of a text run.
-            </summary>
-            <remarks>
-            <para>
-            A style is immutable once created and can be compared for equality with other styles.
-            </para>
-            </remarks>
-        </member>
-        <member name="M:Gallio.Common.Splash.Style.Equals(Gallio.Common.Splash.Style)">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.Common.Splash.Style.Equals(System.Object)">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.Common.Splash.Style.GetHashCode">
-            <inheritdoc />
-        </member>
-        <member name="P:Gallio.Common.Splash.Style.Default">
-            <summary>
-            Gets a default style based on current system font and color settings.
-            </summary>
-            <value>The style.</value>
-        </member>
-        <member name="P:Gallio.Common.Splash.Style.Font">
-            <summary>
-            Gets the font.
-            </summary>
-            <remarks>
-            This is an inline style property.
-            </remarks>
-        </member>
-        <member name="P:Gallio.Common.Splash.Style.Color">
-            <summary>
-            Gets the color.
-            </summary>
-            <remarks>
-            This is an inline style property.
-            </remarks>
-        </member>
-        <member name="P:Gallio.Common.Splash.Style.TabStopRuler">
-            <summary>
-            Gets the tab stop ruler.
-            </summary>
-            <remarks>
-            This is a paragraph style property.
-            </remarks>
-        </member>
-        <member name="P:Gallio.Common.Splash.Style.WordWrap">
-            <summary>
-            Gets whether to perform word-wrapping.
-            </summary>
-            <remarks>
-            This is a paragraph style property.
-            </remarks>
-        </member>
-        <member name="P:Gallio.Common.Splash.Style.LeftMargin">
-            <summary>
-            Gets the left margin width in pixels.
-            </summary>
-            <remarks>
-            This is a paragraph style property.
-            </remarks>
-        </member>
-        <member name="P:Gallio.Common.Splash.Style.RightMargin">
-            <summary>
-            Gets the right margin width in pixels.
-            </summary>
-            <remarks>
-            This is a paragraph style property.
-            </remarks>
-        </member>
-        <member name="P:Gallio.Common.Splash.Style.FirstLineIndent">
-            <summary>
-            Gets the first line indent in pixels.
-            </summary>
-            <remarks>
-            This is a paragraph style property.
-            </remarks>
-        </member>
-        <member name="T:Gallio.Common.Splash.StyleBuilder">
-            <summary>
-            Builds <see cref="T:Gallio.Common.Splash.Style"/> objects.
-            </summary>
-        </member>
-        <member name="M:Gallio.Common.Splash.StyleBuilder.#ctor">
-            <summary>
-            Creates a builder with all style properties inherited.
-            </summary>
-        </member>
-        <member name="M:Gallio.Common.Splash.StyleBuilder.#ctor(Gallio.Common.Splash.Style)">
-            <summary>
-            Creates a builder initialized as a copy of an existing style.
-            </summary>
-            <param name="style">The style to copy.</param>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="style"/> is null.</exception>
-        </member>
-        <member name="M:Gallio.Common.Splash.StyleBuilder.#ctor(Gallio.Common.Splash.StyleBuilder)">
-            <summary>
-            Creates a builder initialized as a copy of an existing style builder.
-            </summary>
-            <param name="styleBuilder">The style builder to copy.</param>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="styleBuilder"/> is null.</exception>
-        </member>
-        <member name="M:Gallio.Common.Splash.StyleBuilder.ToStyle(Gallio.Common.Splash.Style)">
-            <summary>
-            Creates an immutable style object from the builder's properties.
-            </summary>
-            <param name="inheritedStyle">The style to inherit.</param>
-            <returns>The new style object.</returns>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="inheritedStyle"/> is null.</exception>
-        </member>
-        <member name="M:Gallio.Common.Splash.StyleBuilder.ToStyle">
-            <summary>
-            Creates an immutable style object from the builder's properties and supplies
-            any inherited properties from <see cref="P:Gallio.Common.Splash.Style.Default"/>.
-            </summary>
-            <returns>The new style object.</returns>
-        </member>
-        <member name="P:Gallio.Common.Splash.StyleBuilder.Font">
-            <summary>
-            Gets or sets the font.
-            </summary>
-            <remarks>
-            This is an inline style property.
-            </remarks>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="value"/> contains null.</exception>
-        </member>
-        <member name="P:Gallio.Common.Splash.StyleBuilder.Color">
-            <summary>
-            Gets or sets the color.
-            </summary>
-            <remarks>
-            This is an inline style property.
-            </remarks>
-        </member>
-        <member name="P:Gallio.Common.Splash.StyleBuilder.TabStopRuler">
-            <summary>
-            Gets or sets the tab stop ruler.
-            </summary>
-            <remarks>
-            This is a paragraph style property.
-            </remarks>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="value"/> contains null.</exception>
-        </member>
-        <member name="P:Gallio.Common.Splash.StyleBuilder.WordWrap">
-            <summary>
-            Gets or sets whether to perform word-wrapping.
-            </summary>
-            <remarks>
-            This is a paragraph style property.
-            </remarks>
-        </member>
-        <member name="P:Gallio.Common.Splash.StyleBuilder.LeftMargin">
-            <summary>
-            Gets or sets the left margin width in pixels.
-            </summary>
-            <remarks>
-            This is a paragraph style property.
-            </remarks>
-        </member>
-        <member name="P:Gallio.Common.Splash.StyleBuilder.RightMargin">
-            <summary>
-            Gets or sets the right margin width in pixels.
-            </summary>
-            <remarks>
-            This is a paragraph style property.
-            </remarks>
-        </member>
-        <member name="P:Gallio.Common.Splash.StyleBuilder.FirstLineIndent">
-            <summary>
-            Gets or sets the first line indent in pixels.
-            </summary>
-            <remarks>
-            This is a paragraph style property.
-            </remarks>
-        </member>
-        <member name="T:Gallio.Common.Splash.StyleProperty`1">
-            <summary>
-            Specifies a style property that may either be set explicitly or inherited from
-            another style.
-            </summary>
-            <typeparam name="T">The type of value held by the property.</typeparam>
-        </member>
-        <member name="F:Gallio.Common.Splash.StyleProperty`1.Inherit">
-            <summary>
-            Gets a special value that indicates that a style property value is inherited.
-            </summary>
-        </member>
-        <member name="M:Gallio.Common.Splash.StyleProperty`1.#ctor(`0)">
-            <summary>
-            Creates a style property with the specified value.
-            </summary>
-            <param name="value">The value.</param>
-        </member>
-        <member name="M:Gallio.Common.Splash.StyleProperty`1.GetValueOrInherit(`0)">
-            <summary>
-            Gets the value of the property if it is not inherited
-            otherwise returns the inherited value.
-            </summary>
-            <param name="inheritedValue">The inherited value.</param>
-            <returns>The value.</returns>
-        </member>
-        <member name="M:Gallio.Common.Splash.StyleProperty`1.op_Implicit(`0)~Gallio.Common.Splash.StyleProperty{`0}">
-            <summary>
-            Creates a style property with the specified value.
-            </summary>
-            <param name="value">The value.</param>
-            <returns>The style property.</returns>
-        </member>
-        <member name="M:Gallio.Common.Splash.StyleProperty`1.op_Equality(Gallio.Common.Splash.StyleProperty{`0},Gallio.Common.Splash.StyleProperty{`0})">
-            <summary>
-            Returns true if the properties are equal.
-            </summary>
-        </member>
-        <member name="M:Gallio.Common.Splash.StyleProperty`1.op_Inequality(Gallio.Common.Splash.StyleProperty{`0},Gallio.Common.Splash.StyleProperty{`0})">
-            <summary>
-            Returns true if the properties are not equal.
-            </summary>
-        </member>
-        <member name="M:Gallio.Common.Splash.StyleProperty`1.Equals(System.Object)">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.Common.Splash.StyleProperty`1.GetHashCode">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.Common.Splash.StyleProperty`1.Equals(Gallio.Common.Splash.StyleProperty{`0})">
-            <inheritdoc />
-        </member>
-        <member name="P:Gallio.Common.Splash.StyleProperty`1.Inherited">
-            <summary>
-            Returns true if the property value is inherited.
-            </summary>
-        </member>
-        <member name="P:Gallio.Common.Splash.StyleProperty`1.Value">
-            <summary>
-            Gets the value of the property if it is not inherited.
-            </summary>
-            <exception cref="T:System.InvalidOperationException">Thrown if the property is inherited.</exception>
-        </member>
-        <member name="T:Gallio.Common.Splash.Stylesheet">
-            <summary>
-            Manages a collection of styles.
-            </summary>
-        </member>
-        <member name="M:Gallio.Common.Splash.Stylesheet.#ctor">
-            <summary>
-            Creates an empty stylesheet.
-            </summary>
-        </member>
-        <member name="M:Gallio.Common.Splash.Stylesheet.AddStyle(System.String,Gallio.Common.Splash.Style)">
-            <summary>
-            Adds a style to the stylesheet.
-            </summary>
-            <param name="name">The style name.</param>
-            <param name="style">The style to add.</param>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="name"/> or <paramref name="style"/> is null.</exception>
-            <exception cref="T:System.InvalidOperationException">Thrown if there is already a style with name <paramref name="name"/>.</exception>
-        </member>
-        <member name="M:Gallio.Common.Splash.Stylesheet.GetStyle(System.String,Gallio.Common.Splash.Style)">
-            <summary>
-            Gets a style by name.
-            </summary>
-            <param name="name">The style name.</param>
-            <param name="defaultStyle">The default style to return if no style
-            is present with the specified name.</param>
-            <returns>The style.</returns>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="name"/> is null.</exception>
-        </member>
-        <member name="T:Gallio.Common.Splash.SplashView">
-            <summary>
-            A SplashView is a custom control to display styled text intermixed with
-            embedded content such as images.
-            </summary>
-            <remarks>
-            <para>
-            This control is optimized for high-performance append-only text output such as
-            scrolling consoles.  Consequently, the control does not support editing or
-            modifications to currently displayed content (besides clearing it).
-            </para>
-            <para>
-            Display updates are performed asynchronously in batches.
-            </para>
-            </remarks>
-        </member>
-        <member name="M:Gallio.Common.Splash.SplashView.#ctor">
-            <summary>
-            Creates an empty SplashView.
-            </summary>
-        </member>
-        <member name="M:Gallio.Common.Splash.SplashView.Dispose(System.Boolean)">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.Common.Splash.SplashView.GetSnapPositionAtPoint(System.Drawing.Point)">
-            <summary>
-            Gets the snap position that corresponds to a point in the control.
-            </summary>
-            <param name="point">The point relative to the layout origin.</param>
-            <returns>The character snap.</returns>
-        </member>
-        <member name="M:Gallio.Common.Splash.SplashView.Select(System.Int32,System.Int32)">
-            <summary>
-            Sets the selection.
-            </summary>
-            <param name="selectionStart">The selection start character index.</param>
-            <param name="selectionLength">The selection length or 0 if none.</param>
-            <exception cref="T:System.ArgumentOutOfRangeException">Thrown if <paramref name="selectionStart"/>
-            or <paramref name="selectionLength"/> is less than 0.</exception>
-        </member>
-        <member name="M:Gallio.Common.Splash.SplashView.SelectAll">
-            <summary>
-            Sets the selection to include all text in the document.
-            </summary>
-        </member>
-        <member name="M:Gallio.Common.Splash.SplashView.SelectNone">
-            <summary>
-            Clears the selection.
-            </summary>
-        </member>
-        <member name="M:Gallio.Common.Splash.SplashView.GetSelectedText">
-            <summary>
-            Gets the currently selected text in the document, or an empty string
-            if there is no selection.
-            </summary>
-            <returns>The selected text.</returns>
-        </member>
-        <member name="M:Gallio.Common.Splash.SplashView.CopySelectedTextToClipboard">
-            <summary>
-            Copies the selected text to the clipboard.
-            Does nothing if there is no current selection.
-            </summary>
-            <returns>True if some text was copied, false if there was no current selection.</returns>
-        </member>
-        <member name="M:Gallio.Common.Splash.SplashView.OnHandleCreated(System.EventArgs)">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.Common.Splash.SplashView.OnPaint(System.Windows.Forms.PaintEventArgs)">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.Common.Splash.SplashView.OnPaddingChanged(System.EventArgs)">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.Common.Splash.SplashView.OnResize(System.EventArgs)">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.Common.Splash.SplashView.OnRightToLeftChanged(System.EventArgs)">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.Common.Splash.SplashView.OnMouseDown(System.Windows.Forms.MouseEventArgs)">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.Common.Splash.SplashView.OnMouseUp(System.Windows.Forms.MouseEventArgs)">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.Common.Splash.SplashView.OnMouseMove(System.Windows.Forms.MouseEventArgs)">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.Common.Splash.SplashView.OnSelectionChanged(System.EventArgs)">
-            <summary>
-            Called when the selection changes.
-            </summary>
-            <param name="e">The event arguments.</param>
-        </member>
-        <member name="M:Gallio.Common.Splash.SplashView.MousePositionToLayout(System.Drawing.Point)">
-            <summary>
-            Maps a mouse position to a layout point.
-            </summary>
-            <param name="mousePosition">The mouse position.</param>
-            <returns>The layout point.</returns>
-        </member>
-        <member name="M:Gallio.Common.Splash.SplashView.ProcessCmdKey(System.Windows.Forms.Message@,System.Windows.Forms.Keys)">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.Common.Splash.SplashView.UpdateContextMenu">
-            <summary>
-            Updates the context menu in time for pop-up.
-            </summary>
-        </member>
-        <member name="M:Gallio.Common.Splash.SplashView.IsInputChar(System.Char)">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.Common.Splash.SplashView.IsInputKey(System.Windows.Forms.Keys)">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.Common.Splash.SplashView.OnKeyDown(System.Windows.Forms.KeyEventArgs)">
-            <inheritdoc />
-        </member>
-        <member name="E:Gallio.Common.Splash.SplashView.SelectionChanged">
-            <summary>
-            Event raised when the selection has changed.
-            </summary>
-        </member>
-        <member name="P:Gallio.Common.Splash.SplashView.BackColor">
-            <inheritdoc />
-        </member>
-        <member name="P:Gallio.Common.Splash.SplashView.SelectedTextColor">
-            <summary>
-            Gets or sets the selected text color.
-            </summary>
-        </member>
-        <member name="P:Gallio.Common.Splash.SplashView.SelectedBackgroundColor">
-            <summary>
-            Gets or sets the selected text color.
-            </summary>
-        </member>
-        <member name="P:Gallio.Common.Splash.SplashView.SelectionStart">
-            <summary>
-            Gets the selection start character index.
-            </summary>
-        </member>
-        <member name="P:Gallio.Common.Splash.SplashView.SelectionLength">
-            <summary>
-            Gets the selection length, or 0 if none.
-            </summary>
-        </member>
-        <member name="P:Gallio.Common.Splash.SplashView.MinimumTextLayoutWidth">
-            <summary>
-            Gets or sets the minimum width of the text area.
-            </summary>
-            <remarks>
-            If the control is resized to less than this width, then the control will automatically
-            display a horizontal scrollbar.
-            </remarks>
-        </member>
-        <member name="P:Gallio.Common.Splash.SplashView.Document">
-            <summary>
-            Gets the document displayed in the view.
-            </summary>
-        </member>
-        <member name="P:Gallio.Common.Splash.SplashView.DefaultCursor">
-            <inheritdoc />
-        </member>
-        <member name="P:Gallio.Common.Splash.SplashView.DefaultSize">
-            <inheritdoc />
-        </member>
-    </members>
-</doc>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Gallio.ControlPanel.exe
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Gallio.ControlPanel.exe b/lib/Gallio.3.2.750/tools/Gallio.ControlPanel.exe
deleted file mode 100644
index c32be44..0000000
Binary files a/lib/Gallio.3.2.750/tools/Gallio.ControlPanel.exe and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Gallio.ControlPanel.exe.config
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Gallio.ControlPanel.exe.config b/lib/Gallio.3.2.750/tools/Gallio.ControlPanel.exe.config
deleted file mode 100644
index 9fc34dc..0000000
--- a/lib/Gallio.3.2.750/tools/Gallio.ControlPanel.exe.config
+++ /dev/null
@@ -1,18 +0,0 @@
-<?xml version="1.0" encoding="utf-8" ?>
-<configuration>
-  <configSections>
-    <section name="gallio" type="Gallio.Runtime.GallioSectionHandler, Gallio" />
-  </configSections>
-
-  <runtime>
-    <legacyUnhandledExceptionPolicy enabled="1" />
-
-    <!-- Enable loading assemblies over the network in .Net 4.0 -->
-    <loadFromRemoteSources enabled="true" />
-  </runtime>
-
-  <startup>
-    <supportedRuntime version="v4.0.30319" />
-    <supportedRuntime version="v2.0.50727" />
-  </startup>
-</configuration>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Gallio.ControlPanel.plugin
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Gallio.ControlPanel.plugin b/lib/Gallio.3.2.750/tools/Gallio.ControlPanel.plugin
deleted file mode 100644
index 9668323..0000000
--- a/lib/Gallio.3.2.750/tools/Gallio.ControlPanel.plugin
+++ /dev/null
@@ -1,18 +0,0 @@
-<?xml version="1.0" encoding="utf-8" ?>
-<plugin pluginId="Gallio.ControlPanel"
-        recommendedInstallationPath=""
-        xmlns="http://www.gallio.org/">
-  <traits>
-    <name>Gallio Control Panel</name>
-    <version>3.2.0.0</version>
-    <description>An application for configuring preferences and managing the Gallio installation.</description>
-    <icon>plugin://Gallio.ControlPanel/Resources/Gallio.ControlPanel.ico</icon>
-  </traits>
-
-  <files>
-    <file path="Gallio.ControlPanel.plugin" />
-    <file path="Gallio.ControlPanel.exe" />
-    <file path="Gallio.ControlPanel.exe.config" />
-    <file path="Resources\Gallio.ControlPanel.ico" />
-  </files>
-</plugin>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Gallio.Copy.exe
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Gallio.Copy.exe b/lib/Gallio.3.2.750/tools/Gallio.Copy.exe
deleted file mode 100644
index 0a54a97..0000000
Binary files a/lib/Gallio.3.2.750/tools/Gallio.Copy.exe and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Gallio.Copy.exe.config
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Gallio.Copy.exe.config b/lib/Gallio.3.2.750/tools/Gallio.Copy.exe.config
deleted file mode 100644
index 88bf4f5..0000000
--- a/lib/Gallio.3.2.750/tools/Gallio.Copy.exe.config
+++ /dev/null
@@ -1,30 +0,0 @@
-<?xml version="1.0" encoding="utf-8" ?>
-<configuration>
-  <configSections>
-    <section name="gallio" type="Gallio.Runtime.GallioSectionHandler, Gallio" />
-  </configSections>
-
-  <appSettings>
-    <add key="TaskManager.DefaultQueueId" value="Gallio.Copy.MainWorker" />
-  </appSettings>
-
-  <runtime>
-    <legacyUnhandledExceptionPolicy enabled="1" />
-
-    <!-- Enable loading assemblies over the network in .Net 4.0 -->
-    <loadFromRemoteSources enabled="true" />
-  </runtime>
-
-  <system.runtime.remoting>
-    <customErrors mode="off"/>
-  </system.runtime.remoting>
-
-  <system.diagnostics>
-    <assert assertuienabled="false" />
-  </system.diagnostics>
-
-  <startup>
-    <supportedRuntime version="v4.0.30319" />
-    <supportedRuntime version="v2.0.50727" />
-  </startup>
-</configuration>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Gallio.Copy.plugin
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Gallio.Copy.plugin b/lib/Gallio.3.2.750/tools/Gallio.Copy.plugin
deleted file mode 100644
index ed74b23..0000000
--- a/lib/Gallio.3.2.750/tools/Gallio.Copy.plugin
+++ /dev/null
@@ -1,24 +0,0 @@
-<?xml version="1.0" encoding="utf-8" ?>
-<plugin pluginId="Gallio.Copy"
-        recommendedInstallationPath=""
-        xmlns="http://www.gallio.org/">
-  <traits>
-    <name>Gallio Copy Program</name>
-    <version>3.2.0.0</version>
-    <description>Creates and maintains partial copies of a Gallio installation.</description>
-    <icon>plugin://Gallio.Copy/Resources/Gallio.Copy.ico</icon>
-  </traits>
-
-  <dependencies>
-    <dependency pluginId="Gallio" />
-    <dependency pluginId="Gallio.UI" />
-  </dependencies>
-
-  <files>
-    <file path="Gallio.Copy.plugin" />
-    <file path="Gallio.Copy.exe" />
-    <file path="Gallio.Copy.exe.config" />
-    
-    <file path="Resources\Gallio.Copy.ico" />
-  </files>
-</plugin>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Gallio.Echo.exe
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Gallio.Echo.exe b/lib/Gallio.3.2.750/tools/Gallio.Echo.exe
deleted file mode 100644
index 77d563f..0000000
Binary files a/lib/Gallio.3.2.750/tools/Gallio.Echo.exe and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Gallio.Echo.exe.config
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Gallio.Echo.exe.config b/lib/Gallio.3.2.750/tools/Gallio.Echo.exe.config
deleted file mode 100644
index 1e44702..0000000
--- a/lib/Gallio.3.2.750/tools/Gallio.Echo.exe.config
+++ /dev/null
@@ -1,29 +0,0 @@
-<?xml version="1.0" encoding="utf-8" ?>
-<configuration>
-  <configSections>
-    <section name="gallio" type="Gallio.Runtime.GallioSectionHandler, Gallio" />
-  </configSections>
-
-  <runtime>
-    <!-- Don't kill application on first uncaught exception.
-         We don't want the test runner to terminate itself unexpectedly
-         without reporting the test failure associated with that exception. -->
-    <legacyUnhandledExceptionPolicy enabled="1" />
-
-    <!-- Enable loading assemblies over the network in .Net 4.0 -->
-    <loadFromRemoteSources enabled="true" />
-  </runtime>
-
-  <system.runtime.remoting>
-    <customErrors mode="off"/>
-  </system.runtime.remoting>
-  
-  <system.diagnostics>
-    <assert assertuienabled="false" />
-  </system.diagnostics>
-
-  <startup>
-    <supportedRuntime version="v4.0.30319" />
-    <supportedRuntime version="v2.0.50727" />
-  </startup>
-</configuration>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Gallio.Echo.plugin
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Gallio.Echo.plugin b/lib/Gallio.3.2.750/tools/Gallio.Echo.plugin
deleted file mode 100644
index a0d15e4..0000000
--- a/lib/Gallio.3.2.750/tools/Gallio.Echo.plugin
+++ /dev/null
@@ -1,18 +0,0 @@
-<?xml version="1.0" encoding="utf-8" ?>
-<plugin pluginId="Gallio.Echo"
-        recommendedInstallationPath=""
-        xmlns="http://www.gallio.org/">
-  <traits>
-    <name>Gallio Echo</name>
-    <version>3.2.0.0</version>
-    <description>A command-line test runner.</description>
-    <icon>plugin://Gallio.Echo/Resources/Gallio.Echo.ico</icon>
-  </traits>
-
-  <files>
-    <file path="Gallio.Echo.plugin" />
-    <file path="Gallio.Echo.exe" />
-    <file path="Gallio.Echo.exe.config" />
-    <file path="Resources\Gallio.Echo.ico" />
-  </files>
-</plugin>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Gallio.Host.Elevated.exe
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Gallio.Host.Elevated.exe b/lib/Gallio.3.2.750/tools/Gallio.Host.Elevated.exe
deleted file mode 100644
index a51b8fe..0000000
Binary files a/lib/Gallio.3.2.750/tools/Gallio.Host.Elevated.exe and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Gallio.Host.Elevated.exe.config
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Gallio.Host.Elevated.exe.config b/lib/Gallio.3.2.750/tools/Gallio.Host.Elevated.exe.config
deleted file mode 100644
index 888c068..0000000
--- a/lib/Gallio.3.2.750/tools/Gallio.Host.Elevated.exe.config
+++ /dev/null
@@ -1,26 +0,0 @@
-<?xml version="1.0" encoding="utf-8" ?>
-<configuration>
-  <runtime>
-    <legacyUnhandledExceptionPolicy enabled="1" />
-
-    <!-- Enable loading assemblies over the network in .Net 4.0 -->
-    <loadFromRemoteSources enabled="true" />
-  </runtime>
-
-  <system.runtime.remoting>
-    <customErrors mode="off"/>
-  </system.runtime.remoting>
-
-  <system.diagnostics>
-    <assert assertuienabled="false" />
-  </system.diagnostics>
-
-  <!-- We select the runtime version by setting the COMPLUS_Version environment variable.
-       Unfortunately, these settings will override the contents of that variable, so
-       we cannot use them for the host application.
-  <startup>
-    <supportedRuntime version="v4.0.30319" />
-    <supportedRuntime version="v2.0.50727" />
-  </startup>
-  -->
-</configuration>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Gallio.Host.Elevated.x86.exe
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Gallio.Host.Elevated.x86.exe b/lib/Gallio.3.2.750/tools/Gallio.Host.Elevated.x86.exe
deleted file mode 100644
index 812e9b5..0000000
Binary files a/lib/Gallio.3.2.750/tools/Gallio.Host.Elevated.x86.exe and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Gallio.Host.Elevated.x86.exe.config
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Gallio.Host.Elevated.x86.exe.config b/lib/Gallio.3.2.750/tools/Gallio.Host.Elevated.x86.exe.config
deleted file mode 100644
index 888c068..0000000
--- a/lib/Gallio.3.2.750/tools/Gallio.Host.Elevated.x86.exe.config
+++ /dev/null
@@ -1,26 +0,0 @@
-<?xml version="1.0" encoding="utf-8" ?>
-<configuration>
-  <runtime>
-    <legacyUnhandledExceptionPolicy enabled="1" />
-
-    <!-- Enable loading assemblies over the network in .Net 4.0 -->
-    <loadFromRemoteSources enabled="true" />
-  </runtime>
-
-  <system.runtime.remoting>
-    <customErrors mode="off"/>
-  </system.runtime.remoting>
-
-  <system.diagnostics>
-    <assert assertuienabled="false" />
-  </system.diagnostics>
-
-  <!-- We select the runtime version by setting the COMPLUS_Version environment variable.
-       Unfortunately, these settings will override the contents of that variable, so
-       we cannot use them for the host application.
-  <startup>
-    <supportedRuntime version="v4.0.30319" />
-    <supportedRuntime version="v2.0.50727" />
-  </startup>
-  -->
-</configuration>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Gallio.Host.exe
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Gallio.Host.exe b/lib/Gallio.3.2.750/tools/Gallio.Host.exe
deleted file mode 100644
index 3eb7f50..0000000
Binary files a/lib/Gallio.3.2.750/tools/Gallio.Host.exe and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Gallio.Host.exe.config
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Gallio.Host.exe.config b/lib/Gallio.3.2.750/tools/Gallio.Host.exe.config
deleted file mode 100644
index 888c068..0000000
--- a/lib/Gallio.3.2.750/tools/Gallio.Host.exe.config
+++ /dev/null
@@ -1,26 +0,0 @@
-<?xml version="1.0" encoding="utf-8" ?>
-<configuration>
-  <runtime>
-    <legacyUnhandledExceptionPolicy enabled="1" />
-
-    <!-- Enable loading assemblies over the network in .Net 4.0 -->
-    <loadFromRemoteSources enabled="true" />
-  </runtime>
-
-  <system.runtime.remoting>
-    <customErrors mode="off"/>
-  </system.runtime.remoting>
-
-  <system.diagnostics>
-    <assert assertuienabled="false" />
-  </system.diagnostics>
-
-  <!-- We select the runtime version by setting the COMPLUS_Version environment variable.
-       Unfortunately, these settings will override the contents of that variable, so
-       we cannot use them for the host application.
-  <startup>
-    <supportedRuntime version="v4.0.30319" />
-    <supportedRuntime version="v2.0.50727" />
-  </startup>
-  -->
-</configuration>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Gallio.Host.x86.exe
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Gallio.Host.x86.exe b/lib/Gallio.3.2.750/tools/Gallio.Host.x86.exe
deleted file mode 100644
index 1963670..0000000
Binary files a/lib/Gallio.3.2.750/tools/Gallio.Host.x86.exe and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Gallio.Host.x86.exe.config
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Gallio.Host.x86.exe.config b/lib/Gallio.3.2.750/tools/Gallio.Host.x86.exe.config
deleted file mode 100644
index 888c068..0000000
--- a/lib/Gallio.3.2.750/tools/Gallio.Host.x86.exe.config
+++ /dev/null
@@ -1,26 +0,0 @@
-<?xml version="1.0" encoding="utf-8" ?>
-<configuration>
-  <runtime>
-    <legacyUnhandledExceptionPolicy enabled="1" />
-
-    <!-- Enable loading assemblies over the network in .Net 4.0 -->
-    <loadFromRemoteSources enabled="true" />
-  </runtime>
-
-  <system.runtime.remoting>
-    <customErrors mode="off"/>
-  </system.runtime.remoting>
-
-  <system.diagnostics>
-    <assert assertuienabled="false" />
-  </system.diagnostics>
-
-  <!-- We select the runtime version by setting the COMPLUS_Version environment variable.
-       Unfortunately, these settings will override the contents of that variable, so
-       we cannot use them for the host application.
-  <startup>
-    <supportedRuntime version="v4.0.30319" />
-    <supportedRuntime version="v2.0.50727" />
-  </startup>
-  -->
-</configuration>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Gallio.Icarus.XmlSerializers.dll
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Gallio.Icarus.XmlSerializers.dll b/lib/Gallio.3.2.750/tools/Gallio.Icarus.XmlSerializers.dll
deleted file mode 100644
index c6a342e..0000000
Binary files a/lib/Gallio.3.2.750/tools/Gallio.Icarus.XmlSerializers.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Gallio.Icarus.exe
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Gallio.Icarus.exe b/lib/Gallio.3.2.750/tools/Gallio.Icarus.exe
deleted file mode 100644
index 6f431b8..0000000
Binary files a/lib/Gallio.3.2.750/tools/Gallio.Icarus.exe and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Gallio.Icarus.exe.config
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Gallio.Icarus.exe.config b/lib/Gallio.3.2.750/tools/Gallio.Icarus.exe.config
deleted file mode 100644
index 61f254a..0000000
--- a/lib/Gallio.3.2.750/tools/Gallio.Icarus.exe.config
+++ /dev/null
@@ -1,31 +0,0 @@
-<?xml version="1.0" encoding="utf-8" ?>
-<configuration>
-  <appSettings>
-    <add key="OnlineHelpURL" value="http://www.gallio.org/Docs.aspx" />
-    <add key="GallioWebsiteURL" value="http://www.gallio.org" />
-    <add key="TaskManager.DefaultQueueId" value="Gallio.Icarus.MainWorker" />
-  </appSettings>
-  
-  <runtime>
-    <!-- Don't kill application on first uncaught exception.
-         We don't want the test runner to terminate itself unexpectedly
-         without reporting the test failure associated with that exception. -->
-    <legacyUnhandledExceptionPolicy enabled="1" />
-
-    <!-- Enable loading assemblies over the network in .Net 4.0 -->
-    <loadFromRemoteSources enabled="true" />
-  </runtime>
-
-  <system.runtime.remoting>
-    <customErrors mode="off"/>
-  </system.runtime.remoting>
-
-  <system.diagnostics>
-    <assert assertuienabled="false" />
-  </system.diagnostics>
-
-  <startup>
-    <supportedRuntime version="v4.0.30319" />
-    <supportedRuntime version="v2.0.50727" />
-  </startup>
-</configuration>


[18/51] [abbrv] [partial] Cleaning up and getting ready to development towards v4.8

Posted by sy...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/installation.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/installation.html b/lib/NUnit.org/NUnit/2.5.9/doc/installation.html
deleted file mode 100644
index 9e72d37..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/installation.html
+++ /dev/null
@@ -1,126 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - Installation</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h2>Installation</h2>
-<p>By default the <b>NUnit</b> installation program places all of the files into the 
-	<b>C:\Program&nbsp;Files\NUnit&nbsp;2.5.9</b> directory. 
-	In the installation directory there are up to four sub-directories: net-1.1,
-	  net-2.0, doc, and samples. The actual number depends on what the user has
-	  chosen to install. Source code is no
-      longer provided with the binary installation package. Download the source
-	  package if source is needed.
-<h3>Running NUnit</h3>
-<p>The installation program places a number of shortcuts in the start menu, which 
-	run NUnit under .NET or Mono, depending on what is installed on your system.
-    For NUnit 2.5, the gui only runs under version 2.0 of the CLR, although tests
-	may be executed under other versions using a separate process.
-
-<h3>Configuration</h3>
-<p>When running NUnit from the command line or through the desktop shortcut, the
-	configuration files files nunit.exe.config and nunit-console.exe.config control 
-	the operation of NUnit itself.
-    Settings that you place in these files are not available to your tests or to the 
-	production code you are testing. 
-<p>A separate config file is used for your tests themselves. 
-    If you are running tests from the test.dll assembly, the config file 
-	should be named test.dll.config. If you are running tests from the NUnit test 
-	project MyTests.nunit, the config file should be named MyTests.config. In 
-	either case the config file must reside in the same directory as the file from 
-	which it takes its name.</p>
-<p>In addition to settings of your own, the config file for a set of tests may 
-	contain information used by NUnit in loading your tests. In particular, this 
-	allows you to control the apartment state and priority of the thread that NUnit 
-	uses to run your tests. Other settings may be added in the future.</p>
-<p>See the <a href="configFiles.html">Configuration Files</a> 
-    page for further information on configuration.</p>
-	
-<h3>Installation Verification</h3>
-<p>NUnit's own tests are available as an installation option. If you installed
-the tests, you may verify that the installation has worked successfully by
-running the NUnit gui and loading and running NUnitTests.nunit. All tests should pass.
-<div class="screenshot-left">
-    <img src="img/gui-verify.jpg"></div>
-<p>
-<p><b>Note:</b> Although the NUnit installation has been modified to allow non-admin
-    users to install, there are still a large number of tests which can only run
-	successfully under an administrative id. This is a problem with the code in
-	the tests themselves, not with NUnit.</p>
-<h3>Timing Tests</h3>
-<p>The assembly timing-tests.dll contains several tests that measure the performance of
-    NUnit in loading tests. In addition, it contains some long-running tests that are used 
-	to verify that all remoting timeout problems have been fixed. The test cases 
-	all run for six to 12 minutes and give no indication whatsoever that they are 
-	working! This is required since correct handling of a non-communicative user 
-	test is what these tests are all about.</p>
-<h3>Additional Tests</h3>
-<p>Additional tests are included with the samples and in separate assemblies used 
-	as data by the verification tests themselves. Failures or not run conditions in 
-	these tests are intentional.</p>
-
-<h3>Manual Installation</h3>
-
-<p>You may build NUnit from source using one of the Visual Studio solutions or
-    the NAnt script. In either case, an output directory is created, which
-	contains all files needed in the proper relative location. Just copy this
-	directory to a permanent location and create shortcuts if desired.
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<ul>
-<li><a href="quickStart.html">Quick&nbsp;Start</a></li>
-<li id="current"><a href="installation.html">Installation</a></li>
-<ul>
-<li><a href="upgrade.html">Upgrading</a></li>
-</ul>
-</ul>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/license.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/license.html b/lib/NUnit.org/NUnit/2.5.9/doc/license.html
deleted file mode 100644
index 472606c..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/license.html
+++ /dev/null
@@ -1,88 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - License</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h2>NUnit License</h2>
-
-<p>
-Copyright &copy; 2002-2009 Charlie Poole<br>
-Copyright &copy; 2002-2004 James W. Newkirk, Michael C. Two, Alexei A. Vorontsov<br>
-Copyright &copy; 2000-2002 Philip A. Craig</p>
-<p>	This software is provided 'as-is', without any express or implied warranty. In 
-	no event will the authors be held liable for any damages arising from the use 
-	of this software.</p>
-<p>Permission is granted to anyone to use this software for any purpose, including 
-	commercial applications, and to alter it and redistribute it freely, subject to 
-	the following restrictions:</p>
-<p>1. The origin of this software must not be misrepresented; you must not claim 
-	that you wrote the original software. If you use this software in a product, an 
-	acknowledgment (see the following) in the product documentation is required.</p>
-<p>Portions Copyright &copy; 2002-2009 Charlie Poole or 
-    Copyright&nbsp;&copy; 2002-2004 James W. Newkirk, Michael C. Two, Alexei A. 
-	Vorontsov or Copyright&nbsp;&copy; 2000-2002 Philip A. Craig</p>
-<p>2. Altered source versions must be plainly marked as such, and must not be 
-	misrepresented as being the original software.</p>
-<p>3. This notice may not be removed or altered from any source distribution.</p>
-
-<h4>License Note</h4>
-<p>This license is based on <A href="http://www.opensource.org/licenses/zlib-license.html">
-the open source zlib/libpng license</A>. The idea was to keep the license 
-as simple as possible to encourage use of NUnit in free and commercial 
-applications and libraries, but to keep the source code together and to give 
-credit to the NUnit contributors for their efforts. While this license allows 
-shipping NUnit in source and binary form, if shipping a NUnit variant is the 
-sole purpose of your product, please <a href="mailto:cpoole@pooleconsulting.com">let 
-us know</a>.</p>
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li id="current"><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/listMapper.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/listMapper.html b/lib/NUnit.org/NUnit/2.5.9/doc/listMapper.html
deleted file mode 100644
index 7685b30..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/listMapper.html
+++ /dev/null
@@ -1,99 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - ListMapper</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h2>List Mapper (NUnit 2.4.2)</h2>
-
-<p>Unlike Constraint classes, <b>ListMapper</b> is used to modify the actual
-value argument to Assert.That(). It transforms the actual value, which
-must be a collection, creating a new collection to be tested against the
-supplied constraint. Currently, ListMapper supports one transformation: creating
-a collection of property values.
-
-<p>Normally, ListMapper will be used through the <b>List.Map()</b> syntax helper
-or the inherited syntax equivalent, <b>Map()</b>. The following example
-shows three forms of the same assert:
-
-<div class="code"><pre>
-string[] strings = new string[] { "a", "ab", "abc" };
-int[] lengths = new int[] { 1, 2, 3 };
-
-Assert.That(List.Map(strings).Property("Length"), 
-       Is.EqualTo(lengths));
-	   
-Assert.That(new ListMapper(strings).Property("Length"),
-       Is.EqualTo(lengths));
-
-// Assuming inheritance from AssertionHelper
-Expect(Map(strings).Property("Length"), EqualTo(lengths));
-</pre></div>
-
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<ul>
-<li><a href="equalConstraint.html">Equal&nbsp;Constraint</a></li>
-<li><a href="sameasConstraint.html">SameAs&nbsp;Constraint</a></li>
-<li><a href="conditionConstraints.html">Condition&nbsp;Constraints</a></li>
-<li><a href="comparisonConstraints.html">Comparison&nbsp;Constrants</a></li>
-<li><a href="pathConstraints.html">Path&nbsp;Constraints</a></li>
-<li><a href="typeConstraints.html">Type&nbsp;Constraints</a></li>
-<li><a href="stringConstraints.html">String&nbsp;Constraints</a></li>
-<li><a href="collectionConstraints.html">Collection&nbsp;Constraints</a></li>
-<li><a href="propertyConstraint.html">Property&nbsp;Constraint</a></li>
-<li><a href="throwsConstraint.html">Throws&nbsp;Constraint</a></li>
-<li><a href="compoundConstraints.html">Compound&nbsp;Constraints</a></li>
-<li><a href="delayedConstraint.html">Delayed&nbsp;Constraint</a></li>
-<li id="current"><a href="listMapper.html">List&nbsp;Mapper</a></li>
-<li><a href="reusableConstraint.html">Reusable&nbsp;Constraint</a></li>
-</ul>
-<li><a href="attributes.html">Attributes</a></li>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/mainMenu.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/mainMenu.html b/lib/NUnit.org/NUnit/2.5.9/doc/mainMenu.html
deleted file mode 100644
index 023accc..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/mainMenu.html
+++ /dev/null
@@ -1,276 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - MainMenu</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h2>Main Menu</h2>
-
-<hr><h3>File Menu</h3><hr>
-
-<h4>New Project�</h4>
-<p>Closes any open project, prompting the user to save it if it has been changed and then opens a
-FileSave dialog to allow selecting the name and location of the new project.</p>
-
-<h4>Open Project�</h4>
-<p>Closes any open project, prompting the user to save it if it has been changed and then opens a
-FileOpen dialog to allow selecting the name and location of an assembly, a test project or (if
-Visual Studio support is enabled) a Visual Studio project.</p>
-
-<h4>Close</h4>
-<p>Closes any open project, prompting the user to save it if it has been changed.</p>
-
-
-<h4>Save</h4>
-<p>Saves the currently open project. Opens the Save As dialog if this is the first time the project
-is being saved.</p>
-
-<h4>Save As�</h4>
-<p>Opens a FileSave dialog to allow specifying the name and location to which the project
-should be saved.</p>
-
-<h4>Reload Project</h4>
-<p>Completely reloads the current project by closing and re-opening it.</p>
-
-<h4>Reload Tests</h4>
-<p>Reloads the tests, merging any changes into the tree.</p>
-
-<h4>Select Runtime</h4>
-<p>Displays a list of runtime versions you may select in order to reload
-the tests using that runtime. This submenu is only present if you have
-more than one runtime version available. Any framework versions not supported
-by your NUnit installation will be disabled until you install the
-necessary NUnit components.
-
-<h4>Recent Projects�</h4>
-<p>Displays a list of recently opened projects and assemblies from which the user is able to select one for opening.</p>
-
-<h4>Exit</h4>
-<p>Closes and exits the application. If a test is running, the user is given the opportunity to
-cancel it and or to allow it to continue. If the open project has any pending changes, the user
-is given the opportunity to save it.</p>
-
-<hr><h3>View Menu</h3><hr>
-
-<h4>Full Gui</h4>
-<p>Displays the complete gui - as in prior versions of NUnit. This includes the
-   errors and failures and other tabs and the progress bar.</p>
-   
-<h4>Mini Gui</h4>
-<p>Switches the display to the mini-gui, which consists of the tree display 
-   only.</p>
-
-<h4>Result Tabs</h4>
-<p>Displays a submenu that allows showing or hiding the tabs on the right
-   hand side of the display.</p>
-
-<blockquote>
-<h5>Errors &amp; Failures, Tests Not Run, etc.</h5>
-<p>Selects the individual tabs to display.</p>
-</blockquote>
-
-<h4>Tree</h4>
-<p>Displays the Tree submenu.</p>
-
-<blockquote>
-<h5>Show Checkboxes</h5>
-<p>Turns the display of checkboxes in the tree on or off. The checkboxes may
-   be used to select multiple tests for running.</p>
-   
-<h5>Expand</h5>
-<p>Expands the currently selected tree node.</p>
-
-<h5>Collapse</h5>
-<p>Collapses the currently selected tree node.</p>
-
-<h5>Expand All</h5>
-<p>Expands all nodes of the tree.</p>
-
-<h5>Collapse All</h5>
-<p>Collapses all nodes in the tree to the root.</p>
-
-<h5>Hide Tests</h5>
-<p>Collapses all fixture nodes, hiding the test cases.</p>
-
-<h5>Properties�</h5>
-<p>Displays the Properties Dialog for the currently selected test.</p>
-</blockquote>
-
-<h4>GUI Font</h4>
-<p>Displays a submenu that allows changing the general font used by NUnit.</p>
-
-<blockquote>
-<h5>Increase</h5>
-<p>Increases the size of the font.</p>
-
-<h5>Decrease</h5>
-<p>Decreases the size of the font.</p>
-
-<h5>Change...</h5>
-<p>Displays the Font Change dialog.</p>
-
-<h5>Restore</h5>
-<p>Restores the default font.</p>
-</blockquote>
-
-<h4>Fixed Font</h4>
-<p>Displays a submenu that allows changing the fixed font used to display
-console output from the tests.</p>
-
-<blockquote>
-<h5>Increase</h5>
-<p>Increases the size of the fixed font.</p>
-
-<h5>Decrease</h5>
-<p>Decreases the size of the fixed font.</p>
-
-<h5>Restore</h5>
-<p>Restores the default fixed font.</p>
-</blockquote>
-
-<h4>Assembly Details...</h4>
-<p>Displays information about loaded test assemblies.</p>
-
-<h4>Status Bar</h4>
-<p>Displays or hides the status bar.</p>
-
-<hr><h3>Project Menu</h3><hr>
-
-<h4>Configurations</h4>
-<p>Displays a submenu allowing selecting, adding or editing a configuration.
-
-<blockquote>
-<h5>Debug, Release, etc.</h5>
-<p>Loads the specified configuration for testing.</p>
-
-<h5>Add�</h5>
-<p>Opens the Add Configuration Dialog, which allows entry of the name of the new
-configuration and specifying an existing configuration to use as a template.</p>
-
-<h5>Edit�</h5>
-<p>Opens the <a href="configEditor.html">Configuration Editor</a>.</p>
-</blockquote>
-
-<h4>Add Assembly�</h4>
-<p>Displays a FileOpen dialog to allow selecting an assembly to be added to the active
-configuration of the currently open project.</p>
-
-<h4>Add VS Project�</h4>
-<p>Only available if Visual Studio Support is enabled. Displays a FileOpen dialog to allows
-selecting a Visual Studio project to be added to the currently open project. Entries are added
-for each configuration specified in the VS project, creating new configurations in the test
-project if necessary.</p>
-
-<h4>Edit�</h4>
-<p>Opens the <a href="projectEditor.html">Project Editor</a>.</p>
-
-<hr><h3>Test Menu</h3><hr>
-
-<h4>Run All</h4>
-<p>Runs all the tests.</p>
-
-<h4>Run Selected</h4>
-<p>Runs the test or tests that are selected in the tree. If checkboxes are visible,
-any checked tests are run by preference. This is the same function provided by
-the Run button.</p>
-
-<h4>Run Failed</h4>
-<p>Runs only the tests that failed on the previous run.</p>
-
-<h4>Stop Run</h4>
-<p>Stops the test run. This is the same function provided by the Stop button.</p>
-
-<hr><h3>Tools Menu</h3><hr>
-
-<h4>Save Results as XML�</h4>
-<p>Opens a FileSave Dialog for saving the test results as an XML file.</p>
-
-<h4>Exception Details�</h4>
-<p>Displays detailed information about the last exception.</p>
-
-<h4>Options...</h4>
-<p>Displays the <a href="optionsDialog.html">Options Dialog</a>.</p>
-
-<h4>Addins...</h4>
-<p>Displays the <a href="addinsDialog.html">Addins Dialog</a>.</p>
-
-<hr><h3>Help Menu</h3><hr>
-
-<h4>NUnit Help</h4>
-<p>Displays the NUnit documentation, if installed. Otherwise, attempts to 
-connect to the NUnit web site.</p>
-
-<h4>About NUnit�</h4>
-<p>Displays info about your version of NUnit and a link to the nunit.org site.</p>
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<ul>
-<li><a href="nunit-console.html">Console&nbsp;Runner</a></li>
-<li><a href="nunit-gui.html">Gui&nbsp;Runner</a></li>
-<ul>
-<li><a href="guiCommandLine.html">Command-Line</a></li>
-<li id="current"><a href="mainMenu.html">Main&nbsp;Menu</a></li>
-<li><a href="contextMenu.html">Context&nbsp;Menu</a></li>
-<li><a href="settingsDialog.html">Settings&nbsp;Dialog</a></li>
-<li><a href="addinsDialog.html">Addins&nbsp;Dialog</a></li>
-<li><a href="testProperties.html">Test&nbsp;Properties</a></li>
-<li><a href="configEditor.html">Configuration&nbsp;Editor</a></li>
-<li><a href="projectEditor.html">Project&nbsp;Editor</a></li>
-</ul>
-<li><a href="pnunit.html">PNUnit&nbsp;Runner</a></li>
-<li><a href="nunit-agent.html">NUnit&nbsp;Agent</a></li>
-<li><a href="runtimeSelection.html">Runtime&nbsp;Selection</a></li>
-<li><a href="assemblyIsolation.html">Assembly&nbsp;Isolation</a></li>
-<li><a href="configFiles.html">Configuration&nbsp;Files</a></li>
-<li><a href="multiAssembly.html">Multiple&nbsp;Assemblies</a></li>
-<li><a href="vsSupport.html">Visual&nbsp;Studio&nbsp;Support</a></li>
-</ul>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/maxtime.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/maxtime.html b/lib/NUnit.org/NUnit/2.5.9/doc/maxtime.html
deleted file mode 100644
index 2984070..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/maxtime.html
+++ /dev/null
@@ -1,119 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - Maxtime</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h3>MaxtimeAttribute (NUnit 2.5)</h3>
-
-<p>The <b>MaxtimeAttribute</b> is used on test methods to specify a maximum time 
-   in milliseconds for a test case. If the test case takes longer than the 
-   specified time to complete, it is reported as a failure.
-   
-<h4>Example</h4>
-
-<div class="code"><pre>
-[Test, Maxtime(2000)]
-public void TimedTest()
-{
-    ...
-}
-</pre></div>
-
-<h4>Notes:</h4>
-
-<ol>
-<li>Any assertion failures take precedence over the elapsed time check.
-<li>This attribute does not cancel the test if the time
-is exceeded. It merely waits for the test to complete and then
-compares the elapsed time to the specified maximum. If you want to
-cancel long-running tests, see <a href="timeout.html">TimeoutAttribute</a>.
-</ol>
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<ul>
-<li><a href="category.html">Category</a></li>
-<li><a href="combinatorial.html">Combinatorial</a></li>
-<li><a href="culture.html">Culture</a></li>
-<li><a href="datapoint.html">Datapoint(s)</a></li>
-<li><a href="description.html">Description</a></li>
-<li><a href="exception.html">Exception</a></li>
-<li><a href="explicit.html">Explicit</a></li>
-<li><a href="ignore.html">Ignore</a></li>
-<li id="current"><a href="maxtime.html">Maxtime</a></li>
-<li><a href="pairwise.html">Pairwise</a></li>
-<li><a href="platform.html">Platform</a></li>
-<li><a href="property.html">Property</a></li>
-<li><a href="random.html">Random</a></li>
-<li><a href="range.html">Range</a></li>
-<li><a href="repeat.html">Repeat</a></li>
-<li><a href="requiredAddin.html">RequiredAddin</a></li>
-<li><a href="requiresMTA.html">Requires&nbsp;MTA</a></li>
-<li><a href="requiresSTA.html">Requires&nbsp;STA</a></li>
-<li><a href="requiresThread.html">Requires&nbsp;Thread</a></li>
-<li><a href="sequential.html">Sequential</a></li>
-<li><a href="setCulture.html">SetCulture</a></li>
-<li><a href="setup.html">Setup</a></li>
-<li><a href="setupFixture.html">SetupFixture</a></li>
-<li><a href="suite.html">Suite</a></li>
-<li><a href="teardown.html">Teardown</a></li>
-<li><a href="test.html">Test</a></li>
-<li><a href="testCase.html">TestCase</a></li>
-<li><a href="testCaseSource.html">TestCaseSource</a></li>
-<li><a href="testFixture.html">TestFixture</a></li>
-<li><a href="fixtureSetup.html">TestFixtureSetUp</a></li>
-<li><a href="fixtureTeardown.html">TestFixtureTearDown</a></li>
-<li><a href="theory.html">Theory</a></li>
-<li><a href="timeout.html">Timeout</a></li>
-<li><a href="values.html">Values</a></li>
-<li><a href="valueSource.html">ValueSource</a></li>
-</ul>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/multiAssembly.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/multiAssembly.html b/lib/NUnit.org/NUnit/2.5.9/doc/multiAssembly.html
deleted file mode 100644
index 4da1f80..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/multiAssembly.html
+++ /dev/null
@@ -1,134 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - MultiAssembly</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h2>Multiple-Assembly Support</h2>
-
-<p>Since version 2.1, NUnit has allowed loading suites of tests from multiple assemblies in both
-the console and GUI runners. This may be done on an adhoc basis or by creating NUnit test projects
-saved as files of type '.nunit'. In either case, a top-level suite is constructed, which contains
-the root suite for each assembly. Tests are run and reported just as for a single assembly.</p>
-
-<h3>Adhoc Usage</h3>
-
-<p>Using the console runner, multiple assemblies may be run simply by specifying their names on the 
-command line. See <a href="consoleCommandLine.html">NUnit-Console Command Line Options</a> for
-an example of this usage.</p>
-
-<p>The gui runner does not support specifying multiple assemblies on the command-line.
-However, you can load a single assembly and then use the Project menu to add additional 
-assemblies. Additionally, you can drag multiple assemblies to the tree view pane, in which 
-case they will replace any assemblies already loaded.</p>
-
-<h3>NUnit Test Projects</h3>
-
-<p>Running tests from multiple assemblies is facilitated by the use of NUnit test projects. These are
-files with the extension .nunit containing information about the assemblies to be loaded. The
-following is an example of a hypothetical test project file:</p>
-
-<div class="code">
-<pre>&lt;NUnitProject&gt;
-  &lt;Settings activeconfig="Debug"/&gt;
-  &lt;Config name="Debug"&gt;
-    &lt;assembly path="LibraryCore\bin\Debug\Library.dll"/&gt;
-    &lt;assembly path="LibraryUI\bin\Debug\LibraryUI.dll"/&gt;
-  &lt;/Config&gt;
-  &lt;Config name="Release"&gt;
-    &lt;assembly path="LibraryCore\bin\Release\Library.dll"/&gt;
-    &lt;assembly path="LibraryUI\bin\Release\LibraryUI.dll"/&gt;
-  &lt;/Config&gt;
-&lt;/NUnitProject&gt;</pre>
-</div>
-
-<p>This project contains two configurations, each of which contains two assemblies. The Debug
-configuration is currently active. By default, the assemblies will be loaded using the directory
-containing this file as the ApplicationBase. The PrivateBinPath will be set automatically to
-<code>LibraryCore\bin\Debug;LibraryUI\bin\Debug</code> or to the corresonding release path.
-XML attributes are used to specify non-default values for the ApplicationBase, Configuration
-File and PrivateBinPath. The <a href="projectEditor.html">Project Editor</a> may
-be used to create or modify NUnit projects.</p>
-
-<p>Even when you are running a single test assembly, NUnit creates an internal project
-to contain that assembly. If you are using the gui, you can save this project, edit it,
-add additional assemblies, etc. Note that the gui does not display the internal project
-unless you add assemblies or modify it in some other way.
-
-<p>If you use <a href="vsSupport.html">Visual Studio Support</a> to load Visual
-Studio .Net project or solution files, NUnit converts them to Test projects internally.
-As with other internal projects, these test projects are not saved automatically but may
-be saved by use of the File menu.</p>
-
-<h3>Loading and Running</h3>
-
-<p>In the past, test writers have been able to rely on the current directory being set to the 
-directory containing the single loaded assembly. For the purpose of compatibility, NUnit continues
-to set the current directory to the directory containing each assembly whenever any test from that 
-assembly is run.</p>
-
-<p>Additionally, because some assemblies may rely on unmanaged dlls in the same directory, the 
-current directory is also set to that of the assembly at the time the assembly is loaded. However, 
-in cases where multiple assemblies reference the same unmanaged assembly, this may not be sufficient 
-and the user may need to place the directory containing the unmanaged dll on the path.</p>
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<ul>
-<li><a href="nunit-console.html">Console&nbsp;Runner</a></li>
-<li><a href="nunit-gui.html">Gui&nbsp;Runner</a></li>
-<li><a href="pnunit.html">PNUnit&nbsp;Runner</a></li>
-<li><a href="runtimeSelection.html">Runtime&nbsp;Selection</a></li>
-<li><a href="assemblyIsolation.html">Assembly&nbsp;Isolation</a></li>
-<li><a href="configFiles.html">Configuration&nbsp;Files</a></li>
-<li id="current"><a href="multiAssembly.html">Multiple&nbsp;Assemblies</a></li>
-<li><a href="vsSupport.html">Visual&nbsp;Studio&nbsp;Support</a></li>
-</ul>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/nunit-agent.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/nunit-agent.html b/lib/NUnit.org/NUnit/2.5.9/doc/nunit-agent.html
deleted file mode 100644
index d5f8039..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/nunit-agent.html
+++ /dev/null
@@ -1,97 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - Nunit-agent</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h2>NUnit-Agent</h2>
-
-<p>The nunit-agent.exe program is used by other runners when the tests are being
-   run in a separate process. It is not intended for direct execution by users.
-
-<p>NUnit runs tests in a separate process in several situations:
-
-<ol>
-<li>When the program needs to be run under a different framework or version
-from the one being used by NUnit itself.
-<li>When the user requests process-level isolation through the command line
-or the NUnit settings.
-</ol>
-
-<h3>Debugging</h3>
-
-<p>When debugging tests that are run in a separate process, it is 
-   not possible to do so by simply running the console or gui runner
-   under the debugger. Rather, it is necessary to attach the debugger
-   to the nunit-agent process after the tests have been loaded. 
-
-<p>When running under the Gui, NUnit will continue to use the same 
-   process to reload tests so that it is not normally necessary to 
-   re-attach to a new process. However, if the settings are changed
-   in a way that requires a differnt process - for example, by changing 
-   the version of the runtime that is being used - the old process will
-   be terminated and a new one created. In that case, it's necessary
-   to re-attach to the new process.
-
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<ul>
-<li><a href="nunit-console.html">Console&nbsp;Runner</a></li>
-<li><a href="nunit-gui.html">Gui&nbsp;Runner</a></li>
-<li><a href="pnunit.html">PNUnit&nbsp;Runner</a></li>
-<li id="current"><a href="nunit-agent.html">NUnit&nbsp;Agent</a></li>
-<li><a href="runtimeSelection.html">Runtime&nbsp;Selection</a></li>
-<li><a href="assemblyIsolation.html">Assembly&nbsp;Isolation</a></li>
-<li><a href="configFiles.html">Configuration&nbsp;Files</a></li>
-<li><a href="multiAssembly.html">Multiple&nbsp;Assemblies</a></li>
-<li><a href="vsSupport.html">Visual&nbsp;Studio&nbsp;Support</a></li>
-</ul>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/nunit-console.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/nunit-console.html b/lib/NUnit.org/NUnit/2.5.9/doc/nunit-console.html
deleted file mode 100644
index dc36fc4..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/nunit-console.html
+++ /dev/null
@@ -1,94 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - Nunit-console</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h2>NUnit-Console</h2>
-<p>The nunit-console.exe program is a text-based runner and can be used when you 
-	want to run all your tests and don&#146;t need a red/yellow/green indication of 
-	success or failure.</p>
-<p>It is useful for automation of tests and integration into other systems. It 
-	automatically saves its results in XML format, allowing you to produce reports 
-	or otherwise process the results. The following is a screenshot of the console 
-	program.</p>
-
-<div class="screenshot-left">
-      <img src="img/console-mock.jpg"></div>
-<p>
-<p>In this example, nunit-console has just run the tests in the mock-assembly.dll 
-	that is part of the NUnit distribution. This assembly contains a number of tests, some
-	of which are either ignored or marked explicit. The summary line shows the
-	result of the test run. Click <a href="files/TestResult.xml">here</a> 
-	to see the XML produced for this test run.</p>
-	
-<p>The .NET 2.0 version of the nunit-console program is built using /platform:anycpu,
-which causes it to be jit-compiled to 32-bit code on a 32-bit system and 64-bit code 
-on a 64 bit system. This causes an exception when NUnit is used to test a 32-bit
-application on a 64-bit system. To avoid this problem, use the nunit-console-x86 
-program, which is built using /platform:x86, when testing 32-bit code on a 
-64-bit system.
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<ul>
-<li id="current"><a href="nunit-console.html">Console&nbsp;Runner</a></li>
-<ul>
-<li><a href="consoleCommandLine.html">Command-Line</a></li>
-</ul>
-<li><a href="nunit-gui.html">Gui&nbsp;Runner</a></li>
-<li><a href="pnunit.html">PNUnit&nbsp;Runner</a></li>
-<li><a href="runtimeSelection.html">Runtime&nbsp;Selection</a></li>
-<li><a href="assemblyIsolation.html">Assembly&nbsp;Isolation</a></li>
-<li><a href="configFiles.html">Configuration&nbsp;Files</a></li>
-<li><a href="multiAssembly.html">Multiple&nbsp;Assemblies</a></li>
-<li><a href="vsSupport.html">Visual&nbsp;Studio&nbsp;Support</a></li>
-</ul>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/nunit-gui.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/nunit-gui.html b/lib/NUnit.org/NUnit/2.5.9/doc/nunit-gui.html
deleted file mode 100644
index 5aab738..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/nunit-gui.html
+++ /dev/null
@@ -1,137 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - Nunit-gui</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h2>NUnit Gui Runner</h2>
-<p>The nunit.exe program is a graphical runner. It shows the tests in an 
-	explorer-like browser window and provides a visual indication of the success or 
-	failure of the tests. It allows you to selectively run single tests or suites 
-	and reloads automatically as you modify and re-compile your code. The following 
-	is a screenshot of NUnit running the same mock-assembly.dll shown in the 
-	nunit-console example.</p>
-
-<div class="screenshot-left">
-     <img src="img/gui-screenshot.jpg"></div>
-<p>
-<h4>Tree Display</h4>
-<p>This version of NUnit uses symbols in the test tree, which allow those who 
-   are unable to easily distinguish colors to determine the test status.
-   Successful tests are colored green, with a check mark. Tests that are ignored 
-   are marked with a yellow circle, containing a question mark. If any
-   tests had failed, they would be marked red, with an X symbol.</p>
-
-<p>In this example, there were a total of 11 test cases, but one of them was not 
-   counted because it was marked Explicit. Note that it is shown as a gray
-   circle in the tree. Of the remaining 10 tests, 5 were run successfully and
-   5 were ignored.</p>
-   
-<p>The symbols shown in the tree are actually files in the NUnit bin directory.
-   These files are named Success.jpg, Failure.jpg and Ignored.jpg and may be
-   modified or replaced by the user.</p>
-   
-<h4>Progress Bar</h4>
-<p>The progress bar shows the progress of the test. It is colored according
-to the "worst" result obtained: red if there were any failures, yellow if
-some tests were ignored and green for success.
-
-<h4>Result Tabs</h4>
-<p>The tabs along the bottom of the display show the results of running
-a test. The <b>Errors and Failures</b> tab displays the error message
-and stack trace for both unexpected exceptions and assertion failures.
-Beginning with NUnit 2.5, source code for each stack location can be displayed
-in this tab - as is seen above - provided that the program was compiled with 
-debug information.
-
-<p>The <b>Tests Not Run</b> tab provides a list of all tests that were
-selected for running but were not run, together with the reason.
-
-<p>The Text Output tab displays text output from the tests, potentially
-including console output, trace output and log output. The default display
-provides a single tab, but additional tabs may be created by the user to
-hold specific kinds of output. For more information on creating new tabs, 
-see the documentation for the 
-<a href="settingsDialog.html">Settings Dialog</a>.
-   
-
-<h3>Mini-Gui</h3>
-
-<p>Since the release of NUnit 2.4, an alternate "mini-gui" is also available. It 
-   may be selected from the View menu. In the following screenshot, the mini
-   gui window has been positioned next to the Visual Studio IDE so
-   that both windows can be seen.</p>
-   
-<div class="screenshot-left">
-     <img src="img/miniGui.jpg"></div>
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<ul>
-<li><a href="nunit-console.html">Console&nbsp;Runner</a></li>
-<li id="current"><a href="nunit-gui.html">Gui&nbsp;Runner</a></li>
-<ul>
-<li><a href="guiCommandLine.html">Command-Line</a></li>
-<li><a href="mainMenu.html">Main&nbsp;Menu</a></li>
-<li><a href="contextMenu.html">Context&nbsp;Menu</a></li>
-<li><a href="settingsDialog.html">Settings&nbsp;Dialog</a></li>
-<li><a href="addinsDialog.html">Addins&nbsp;Dialog</a></li>
-<li><a href="testProperties.html">Test&nbsp;Properties</a></li>
-<li><a href="configEditor.html">Configuration&nbsp;Editor</a></li>
-<li><a href="projectEditor.html">Project&nbsp;Editor</a></li>
-</ul>
-<li><a href="pnunit.html">PNUnit&nbsp;Runner</a></li>
-<li><a href="runtimeSelection.html">Runtime&nbsp;Selection</a></li>
-<li><a href="assemblyIsolation.html">Assembly&nbsp;Isolation</a></li>
-<li><a href="configFiles.html">Configuration&nbsp;Files</a></li>
-<li><a href="multiAssembly.html">Multiple&nbsp;Assemblies</a></li>
-<li><a href="vsSupport.html">Visual&nbsp;Studio&nbsp;Support</a></li>
-</ul>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/nunit.css
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/nunit.css b/lib/NUnit.org/NUnit/2.5.9/doc/nunit.css
deleted file mode 100644
index 174dbbe..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/nunit.css
+++ /dev/null
@@ -1,126 +0,0 @@
-/* HTML Elements */
-html, body { margin: 0;  padding: 0; }
-body { font: 90% "Verdana", "Arial", "Helvetica", sans-serif; }
-img { border: none; padding: 0; margin: 0;}
-table { font: 1em "Verdana", "Arial", "Helvetica", sans-serif; }
-h1 { font-size: 1.8em; font-weight: bold; }
-h2 { font-size: 1.5em; font-weight: bold; }
-h3 { font-size: 1.2em; font-weight: bold; }
-h4 { font-size: 1em; font-weight: bold;  }
-ul.across { width: 100%; display: block; list-style: none; }
-ul.across li { float: left; display: block; width: 9em }
-
-/* Masthead and Main Menu */
-#header { margin: 0; padding: 0; width: 100%; }
-#header img { border: none; padding: 0; margin: 0;}
-#header #logo { margin: 0; padding: 0; position: absolute; top: 15px; left: 15px}
-#header #nav { min-width: 670px; margin: 25px 0 10px 200px; padding: 15px 0 15px 5px;
-    border-top: 1px solid black; border-bottom: 1px solid black; border-left: 1px solid black;
-    white-space: nowrap; }
-/* Hide from IE-mac \*/
-* html #nav { height: 1%; }
-/* End of IE-mac hack */
-
-#nav a{  text-decoration: none; color: #000; font: small "Times New Roman", Roman, serif;
-         text-transform: uppercase; margin: 0 5px; padding: 5px 10px; border: 1px solid black; }
-#nav a.active { background: #999; } 
-#nav a:hover { background: #CCC; }
-
-/* Submenu */
-#subnav { position: absolute; top: 100px; left: 76%; background-color: #ffd;
-          width: 24%; margin: 1em 0 0; padding: .25em ; border: solid #ccc;
-          border-width: .1em 0 .1em .1em; }
-#subnav ul { margin: 0; padding: 0; list-style: none; }
-#subnav li{ margin: 0; padding: 2px 0 2px; }
-#subnav a { font: 1em "Times New Roman", Roman, serif; margin: 0; padding: 0 0 0 26px; 
-  		text-transform: uppercase; text-decoration: none; color: #000; white-space: nowrap;
-  		background: url(img/bulletOff.gif) no-repeat 10px 50%; display: block}
-#subnav ul ul a { padding: 0 0 0 46px; background-position: 30px 50%; }
-#subnav ul ul ul a { padding: 0 0 0 66px; background-position: 50px 50%; }
-#subnav ul ul ul ul a { padding: 0 0 0 86px; background-position: 70px 50%; }
-#subnav ul ul ul ul ul a { padding: 0 0 0 106px; background-position: 90px 50%; }
-#subnav li#current a{ background-image: url(img/bulletOn.gif) }
-#subnav li a:hover { background-image: url(img/bulletOn.gif) }
-
-/* Main Content */
-#content { margin: 3em 25% 10px 0; padding: 0 5% 1em 5%; }
-#content.wide { margin: 3em 5% 0 5%; padding: 0 5% 1em 5%; }
-#content p { padding: 0; margin: 0 0 1em 0; max-width: 660px; }
-#content ul { max-width: 660px; }
-#content ol { max-width: 660px; }
-#content blockquote { max-width: 580px }
-#content div.screenshot { text-align: center; margin: 1em 0; }
-#content div.screenshot-right { text-align: center; float: right; margin: 0 0 0 1em; }
-#content img { padding: 0; margin: 0; border: 0 }
-              
-/* Page Footer */
-#footer { text-align: center; font-size: .8em; color: #444; clear: both;
-          border-top: 2px solid #999; margin: 0 30% 10px 5%; padding: 5px 0 0 0;
-          page-break-after: always }          
-#sig { text-align: right; font-size: .8em; width: 95%; display: none }
-          
-table.nunit { margin: 1em 5%; padding: 0; width: auto; border-collapse: collapse; }
-table.nunit td, table.nunit th { border: 1px solid black; padding: 6px; text-align: left }
-table.nunit th { background: #ccf; font-weight: bold; }
-
-table.articles { margin: 20px 0 0 5%; padding: 0 10px 0 0; }
-
-table.downloads { margin: 1em 5%; padding: 0; width: 24em; border-collapse: collapse; }
-table.downloads td, table.downloads th { border: 1px solid black; padding: 2px; text-align: left }
-table.downloads th { background: #ccf; font-weight: bold; }
-
-table.platforms { margin: 1em 0; padding: 0; width: 24em; border-collapse: collapse; }
-table.platforms td, table.platforms th { border: 1px solid black; padding: 5px; text-align: center }
-table.platforms th { background: #ccf; font-weight: bold; }
-
-table.constraints { margin: 1em 0; padding: 0; width: auto; border-collapse: collapse; }
-table.constraints td, table.constraints th { border: 1px solid black; padding: 6px; text-align: left }
-table.constraints th { background: #ccf; font-weight: bold; text-align: center }
-
-table.roadmap { margin: 1em 0; padding: 0; width: auto; border-collapse: collapse; }
-table.roadmap td, table.roadmap th { border: 1px solid black; padding: 10px; text-align: left }
-table.roadmap th { background: #eef; font-weight: bold; }
-
-table.extensions { margin: 1em 2%; border-collapse: collapse; width: 96%; }
-table.extensions td, table.extensions th { border: solid black 1px; padding: 6px }
-table.extensions th { background: #bbf; font-weight: bold; text-align: center }
-table.extensions td.label { font-weight: bold; text-align: left; width: 10em }
-
-table.quote { margin-left: 30px; margin-right: 30px; background: #FFFFFF; border: 3px black solid; 
-	font: 1.1em/1.5em "Times New Roman", Roman, serif; font-variant: small-caps; 
-	letter-spacing: .1em; padding: 0 }
-table.quote td { padding: 0 }
-table.quote td.sig { border-left: solid black 1px; padding-left: 15px }
-
-#news { position: absolute; top: 100px; left: 76%; border-left: 1px solid black;
-	width: 14%; margin: 1em 0 0; padding: 0 5%; font-size: .8em; background-color: #fff }
-#news h4 { font: 1.2em "Times New Roman", Roman, serif; font-variant: small-caps; text-align: center; margin: 0 0 1em; }
-
-div.code { border: 1px solid #888; background-color: #ccf; width: 36em;
-      margin: 1.5em 0; padding: 2px 0; position: relative; }
-div.code pre { font: .8em "Courier New", Courier, monospace; margin: 0 1em .25em; }
-div.langFilter { position: absolute; top: 100px; left: 5%; }
-div.code div.langFilter { position: absolute; top: -15px; left: 0;}
-div.dropdown { position: absolute; top: 0; left: 14px; padding: 0 10px; width: 20px;
-    text-align: left; border: 1px solid #888; background-color: #ffd; }
-div.code div.dropdown { position: absolute; left: 14px; top: 0; padding: 0 10px; width: 20px;
-	text-align: left; border: 1px solid #888; background-color: #ffd; }
-div.notice { 
-  margin-left: 2em;
-  margin-right: 2em; 
-  text-align: center; 
-  font-style: italic; 
-  font-weight: bold; 
-}
-
-/* 
-#content.wide p { width: expression( document.documentElement.clientWidth > 700 ? "660px" : "auto" ); }
-#content.wide blockquote { width: expression( document.documentElement.clientWidth > 700 ? "580px" : "auto"  ); }
-
-pre, .programText { font-family: "Courier New", Courier, Monospace; color: #000; font-size: 1em }
-
-// The following was needed for IE in quirks mode - probably still needed for IE 5
- div.code div.langFilter { position: absolute; top: -14px; left: -1em; }
-
-// Special handling for absence of max-width in IE
-*/

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/nunitAddins.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/nunitAddins.html b/lib/NUnit.org/NUnit/2.5.9/doc/nunitAddins.html
deleted file mode 100644
index a04dee9..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/nunitAddins.html
+++ /dev/null
@@ -1,223 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - NunitAddins</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h2>NUnit Addins</h2>
-
-<p>NUnit originally identified tests in the time-honored way used in many xUnit
-test frameworks. Test classes inherited from the framework's 
-TestCase class. Individual test case methods were identified by having names
-starting with "test..."</p>
-
-<p>With NUnit 2.0, we introduced the use of attributes to identify both fixtures
-and test cases. Use of attributes in this way was a natural outcome of their 
-presence in .NET and gave us a way of identifying tests that was completely
-independent of both inheritance and naming conventions.</p>
-
-<p>However, by moving away from an inheritance-based mechanism we no longer
-had an easy way for others to extend NUnit's internal behavior. NUnit Addins are 
-intended to fill that gap, providing an mechanism to introduce new or changed 
-behavior without modifying NUnit itself.</p>
-
-<h3>Extension Points, Extensions and Addins</h3>
-
-<p>NUnit provides a number of <b>Extension Points</b>, places where it is
-possible to extend its behavior. Because NUnit works with various hosts
-and uses separate AppDomains to run tests, <b>Extension Points</b> are 
-categorized into three types: Core, Client and Gui. Each of these types is
-supported by a different <b>Extension Host</b>.
-
-<p>An NUnit <b>Addin</b> provides enhanced functionality through one or more 
-extensions, which it installs at identified <b>Extension Points</b>. Each
-<b>Addin</b> is characterized by the types of extensions it supplies, so that
-an <b>Extension Host</b> knows whether to invoke it.</p>
-
-<blockquote>
-<p><b>Note:</b> In the current release, only Core extensions are actually
-supported. An Addin may characterize itself as a Client or Gui extension and
-will be listed as such in the <a href="addinsDialog.html">Addins Dialog</a>, 
-but no other action is taken.</p>
-</blockquote> 
-
-<h3>Addin Identification, Loading and Installation</h3>
-
-<p>NUnit examines all assemblies in the <b>bin/addins</b> directory, looking
-for public classes with the <b>NUnitAddinAttribute</b> and implementing the
-<b>IAddin</b> interface. It loads all those it finds as Addins.</p>
-
-<p><b>NUnitAddinAttribute</b> supports three optional named parameters: Type,
-Name and Description. Name and Description are strings representing the name
-of the extension and a description of what it does. If no name is provided,
-the name of the class is used. Type may be any one or a combination of the 
-ExtensionType enum members:
-
-<pre>
-	[Flags]
-	public enum ExtensionType
-	{
-		Core=1,
-		Client=2,
-		Gui=4
-	}
-</pre>
-
-The values may be or'ed together, allowing for future Addins that require
-extensions at multiple levels of the application. If not provided, Type
-defaults to ExtensionType.Core.</p>
-
-<p>The <b>IAddin</b> interface, which must be implemented by each Addin,
-is defined as follows:</p>
-
-<pre>
-	public interface IAddin
-	{
-		bool Install( IExtensionHost host );
-	}
-</pre>
-
-<p> The <b>Install</b> method is called by each host for which the addin has
-specified an ExtensionType. The addin should check that the necessary extension
-points are available and install itself, returning true for success or false
-for failure to install. The method will be called once for each extension
-host and - for Core extensions - each time a new test domain is loaded.</p>
-
-<p>The Install method uses the <b>IExtensionHost</b> interface to locate
-extension points. It is defined as follows:</p>
-
-<pre>
-	public interface IExtensionHost
-	{
-	 	IExtensionPoint[] ExtensionPoints { get; }
-		IExtensionPoint GetExtensionPoint( string name );
-		ExtensionType ExtensionTypes { get; }
-	}
-</pre>
-
-<p>The <b>ExtensionPoints</b> property returns an array of all extension points
-for those extensions that need the information. The <b>ExtensionTypes</b>
-property returns the flags for the type of extension supported by this host,
-allowing, for example, Gui extensions to only load in a Gui host.</p>
-
-<p>Most addins will only need to use the <b>GetExtensionPoint</b> method to
-get the interface to a particular extension point. The <b>IExtensionPoint</b>
-interface is defined as follows:</p>
-
-<pre>
-	public interface IExtensionPoint
-	{
-		string Name { get; }
-		IExtensionHost Host { get; }
-		void Install( object extension );
-		void Remove( object extension );
-	}
-</pre>
-
-<p>Once again, most addins will only need to use one method - the
-<b>Install</b> method in this case. This method passes an extension object
-to the <b>Extension Point</b> where it is installed. Generally, extensions
-do not need to remove themselves once installed, but the method is
-provided in any case.</p>
-
-<p>With NUnit 2.5, an additional interface, <b>IExtensionPoint2</b> is
-available. It derives from <b>IExtensionPoint</b> and also allows setting
-the priority order in which the extension will be called in comparison to 
-other extensions on the same extension point. The interface is defined
-as follows:
-
-<pre>
-	public interface IExtensionPoint2 : IExtensionPoint
-	{
-		void Install( object extension, int priority );
-	}
-</pre>
-
-<p>Only extension points that use a priority scheme implement this interface.
-In general, extension points with a priority scheme will use a default value
-for priority if the Install method without a priority is called. 
-
-<p>In the NUnit 2.5 release, only the <b>TestDecorators</b> extension point implements
-<b>IExtensionPoint2</b>.
-
-<h3>Extension Point Details</h3>
-
-<p>Depending on the particular extension point, the object passed will
-need to implement one or more interfaces. The following <b>ExtensionPoints</b>
-are implemented in this release of NUnit:
-
-<ul>
-	<li><a href="suiteBuilders.html">SuiteBuilders</a>	<li><a href="testcaseBuilders.html">TestCaseBuilders</a>	<li><a href="testDecorators.html">TestDecorators</a>	<li><a href="testcaseProviders.html">TestCaseProviders</a>	<li><a href="datapointProviders.html">DataPointProviders</a>	<li><a href="eventListeners.html">EventListeners</a></ul></p>
-
-<p>For examples of implementing each type of extension, see the Extensibility
-samples provided with NUnit. More complete examples are available in the
-code of NUnit itself, since NUnit uses the same mechanism internally.</p>
-
-<h4>See also...</h4>
-
-<ul>
-<li><a href="extensionTips.html">Tips for Writing Extensions</a></ul>
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<ul>
-<li><a href="customConstraints.html">Custom&nbsp;Constraints</a></li>
-<li id="current"><a href="nunitAddins.html">NUnit&nbsp;Addins</a></li>
-<ul>
-<li><a href="suiteBuilders.html">SuiteBuilders</a></li>
-<li><a href="testcaseBuilders.html">TestcaseBuilders</a></li>
-<li><a href="testDecorators.html">TestDecorators</a></li>
-<li><a href="testcaseProviders.html">TestcaseProviders</a></li>
-<li><a href="datapointProviders.html">DatapointProviders</a></li>
-<li><a href="eventListeners.html">EventListeners</a></li>
-</ul>
-<li><a href="extensionTips.html">Tips&nbsp;for&nbsp;Extenders</a></li>
-</ul>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/pairwise.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/pairwise.html b/lib/NUnit.org/NUnit/2.5.9/doc/pairwise.html
deleted file mode 100644
index c4e4a4b..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/pairwise.html
+++ /dev/null
@@ -1,109 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - Pairwise</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h3>PairwiseAttribute (NUnit 2.5)</h3>
-
-<p>The <b>PairwiseAttribute</b> is used on a test to specify that NUnit should
-   generate test cases in such a way that all possible pairs of
-   values are used. This is a well-known approach for combatting
-   the combinatorial explosion of test cases when more than
-   two features (parameters) are involved.
-   
-<p><b>Note:</b> In the current Alpha release, this attribute is 
-accepted but ignored and data items are combined usin the default
-combinatorial approach.
-   
-<h4>See also...</h4>
-<ul>
-<li><a href="sequential.html">SequentialAttribute</a><li><a href="combinatorial.html">CombinatorialAttribute</a></ul>
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<ul>
-<li><a href="category.html">Category</a></li>
-<li><a href="combinatorial.html">Combinatorial</a></li>
-<li><a href="culture.html">Culture</a></li>
-<li><a href="datapoint.html">Datapoint(s)</a></li>
-<li><a href="description.html">Description</a></li>
-<li><a href="exception.html">Exception</a></li>
-<li><a href="explicit.html">Explicit</a></li>
-<li><a href="ignore.html">Ignore</a></li>
-<li><a href="maxtime.html">Maxtime</a></li>
-<li id="current"><a href="pairwise.html">Pairwise</a></li>
-<li><a href="platform.html">Platform</a></li>
-<li><a href="property.html">Property</a></li>
-<li><a href="random.html">Random</a></li>
-<li><a href="range.html">Range</a></li>
-<li><a href="repeat.html">Repeat</a></li>
-<li><a href="requiredAddin.html">RequiredAddin</a></li>
-<li><a href="requiresMTA.html">Requires&nbsp;MTA</a></li>
-<li><a href="requiresSTA.html">Requires&nbsp;STA</a></li>
-<li><a href="requiresThread.html">Requires&nbsp;Thread</a></li>
-<li><a href="sequential.html">Sequential</a></li>
-<li><a href="setCulture.html">SetCulture</a></li>
-<li><a href="setup.html">Setup</a></li>
-<li><a href="setupFixture.html">SetupFixture</a></li>
-<li><a href="suite.html">Suite</a></li>
-<li><a href="teardown.html">Teardown</a></li>
-<li><a href="test.html">Test</a></li>
-<li><a href="testCase.html">TestCase</a></li>
-<li><a href="testCaseSource.html">TestCaseSource</a></li>
-<li><a href="testFixture.html">TestFixture</a></li>
-<li><a href="fixtureSetup.html">TestFixtureSetUp</a></li>
-<li><a href="fixtureTeardown.html">TestFixtureTearDown</a></li>
-<li><a href="theory.html">Theory</a></li>
-<li><a href="timeout.html">Timeout</a></li>
-<li><a href="values.html">Values</a></li>
-<li><a href="valueSource.html">ValueSource</a></li>
-</ul>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/parameterizedTests.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/parameterizedTests.html b/lib/NUnit.org/NUnit/2.5.9/doc/parameterizedTests.html
deleted file mode 100644
index bcd9850..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/parameterizedTests.html
+++ /dev/null
@@ -1,155 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - ParameterizedTests</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h2>Parameterized Tests</h2>
-
-<p>NUnit 2.5 supports parameterized tests. Test methods
-may have parameters and various attributes are available
-to indicate what arguments should be supplied by NUnit.
-
-<p>Multiple sets of arguments cause the creation of multiple
-tests. All arguments are created at the point of loading the
-tests, so the individual test cases are available for 
-display and selection in the Gui, if desired.
-
-<p>Some attributes allow you to specify arguments inline - directly on
-   the attribute - while others use a separate method, property or field
-   to hold the arguments. In addition, some attributes identify complete test cases,
-   including all the necessary arguments, while others only provide data
-   for a single argument. This gives rise to four groups of attributes,
-   as shown in the following table.
-   
-<table class="nunit">
-<tr><th></th><th>Complete Test Cases</th><th>Data for One Argument</th></tr>
-<tr><th>Inline</th>
-    <td><a href="testCase.html">TestCaseAttribute</a></td>
-    <td><a href="random.html">RandomAttribute</a><br>
-	    <a href="range.html">RangeAttribute</a><br>
-		<a href="values.html">ValuesAttribute</a></td></tr>
-<tr><th>Separate</th>
-	<td><a href="testCaseSource.html">TestCaseSourceAttribute</a></td>
-	<td><a href="valueSource.html">ValueSourceAttribute</a></td></tr>
-</table>
-
-<p>In addition, when data is specified for individual arguments, special attributes
-may be added to the test method itself in order to tell NUnit how
-to go about combining the arguments. Currently, the following attributes
-are provided:
-
-<ul>
-<li><a href="combinatorial.html">CombinatorialAttribute</a> (default)
-<li><a href="pairwise.html">PairwiseAttribute</a><li><a href="sequential.html">SequentialAttribute</a></ul>
-
-<h3>Order of Execution</h3>
-
-<p>In NUnit 2.5, individual test cases are sorted alphabetically and executed in
-   that order. With NUnit 2.5.1, the individual cases are not sorted, but are
-   executed in the order in which NUnit discovers them. This order does <b>not</b>
-   follow the lexical order of the attributes and will often vary between different
-   compilers or different versions of the CLR.
-   
-<p>The following specific rules for ordering apply:
-<ol>
-<li>If all arguments are specified in a <b>single TestCaseSource</b> attribute,
-    the ordering of the cases provided will be maintained.
-<li>If each parameter has a <b>single Values</b>, <b>ValueSource</b> or
-    <b>Range</b> attribute and the <b>Sequential</b> combining strategy
-	is used - or there is only one argument - the ordering will be maintained.
-<li>In all other cases, including using multiple <b>TestCase</b> attributes
-    or a combination of different types of attributes, the ordering of the
-	test cases is undefined.
-</ol>   
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<ul>
-<li><a href="category.html">Category</a></li>
-<li><a href="combinatorial.html">Combinatorial</a></li>
-<li><a href="culture.html">Culture</a></li>
-<li><a href="datapoint.html">Datapoint(s)</a></li>
-<li><a href="description.html">Description</a></li>
-<li><a href="exception.html">Exception</a></li>
-<li><a href="explicit.html">Explicit</a></li>
-<li><a href="ignore.html">Ignore</a></li>
-<li><a href="maxtime.html">Maxtime</a></li>
-<li><a href="pairwise.html">Pairwise</a></li>
-<li><a href="platform.html">Platform</a></li>
-<li><a href="property.html">Property</a></li>
-<li><a href="random.html">Random</a></li>
-<li><a href="range.html">Range</a></li>
-<li><a href="repeat.html">Repeat</a></li>
-<li><a href="requiredAddin.html">RequiredAddin</a></li>
-<li><a href="requiresMTA.html">Requires&nbsp;MTA</a></li>
-<li><a href="requiresSTA.html">Requires&nbsp;STA</a></li>
-<li><a href="requiresThread.html">Requires&nbsp;Thread</a></li>
-<li><a href="sequential.html">Sequential</a></li>
-<li><a href="setCulture.html">SetCulture</a></li>
-<li><a href="setup.html">Setup</a></li>
-<li><a href="setupFixture.html">SetupFixture</a></li>
-<li><a href="suite.html">Suite</a></li>
-<li><a href="teardown.html">Teardown</a></li>
-<li><a href="test.html">Test</a></li>
-<ul>
-<li id="current"><a href="parameterizedTests.html">Parameterized&nbsp;Tests</a></li>
-</ul>
-<li><a href="testCase.html">TestCase</a></li>
-<li><a href="testCaseSource.html">TestCaseSource</a></li>
-<li><a href="testFixture.html">TestFixture</a></li>
-<li><a href="fixtureSetup.html">TestFixtureSetUp</a></li>
-<li><a href="fixtureTeardown.html">TestFixtureTearDown</a></li>
-<li><a href="theory.html">Theory</a></li>
-<li><a href="timeout.html">Timeout</a></li>
-<li><a href="values.html">Values</a></li>
-<li><a href="valueSource.html">ValueSource</a></li>
-</ul>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/pathConstraints.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/pathConstraints.html b/lib/NUnit.org/NUnit/2.5.9/doc/pathConstraints.html
deleted file mode 100644
index 623d377..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/pathConstraints.html
+++ /dev/null
@@ -1,193 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - PathConstraints</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h2>Path Constraints (NUnit 2.5)</h2>
-
-<p>Path constraints perform tests on paths, without reference to any
-   actual files or directories. This allows testing paths that are
-   created by an application for reference or later use, without 
-   any effect on the environment.
-   
-<p>Path constraints are intended to work across multiple file systems,
-   and convert paths to a canonical form before comparing them. 
-
-<p>It is usually not necessary to know the file system of the paths
-   in order to compare them. Where necessary, the programmer may
-   use the <b>IgnoreCase</b> and <b>RespectCase</b> modifiers to provide 
-   behavior other than the system default.
-      
-<h3>SamePathConstraint</h3>
-
-<h4>Action</h4>
-<p>Tests that two paths are equivalent.
-
-<h4>Constructor</h4>
-<div class="code"><pre>
-SamePathConstraint( string expectedPath )
-</pre></div>
-
-<h4>Syntax</h4>
-<div class="code"><pre>
-Is.SamePath( string expectedPath )
-</pre></div>
-
-<h4>Modifiers</h4>
-<div class="code"><pre>
-...IgnoreCase
-...RespectCase
-</pre></div>
-
-<h4>Examples of Use</h4>
-<div class="code"><pre>
-Assert.That( "/folder1/./junk/../folder2", 
-	Is.SamePath( "/folder1/folder2" ) );
-Assert.That( "/folder1/./junk/../folder2/x", 
-	Is.Not.SamePath( "/folder1/folder2" ) );
-
-Assert.That( @"C:\folder1\folder2",
-	Is.SamePath( @"C:\Folder1\Folder2" ).IgnoreCase );
-Assert.That( "/folder1/folder2",
-	Is.Not.SamePath( "/Folder1/Folder2" ).RespectCase );
-</pre></div>
-
-<h3>SubPathConstraint</h3>
-
-<h4>Action</h4>
-<p>Tests that one path is under another path.
-
-<h4>Constructor</h4>
-<div class="code"><pre>
-SubPathConstraint( string expectedPath )
-</pre></div>
-
-<h4>Syntax</h4>
-<div class="code"><pre>
-Is.SubPath( string expectedPath )
-</pre></div>
-
-<h4>Modifiers</h4>
-<div class="code"><pre>
-...IgnoreCase
-...RespectCase
-</pre></div>
-
-<h4>Examples of Use</h4>
-
-<div class="code"><pre>
-Assert.That( "/folder1/./junk/../folder2", 
-	Is.SubPath( "/folder1/folder2" ) );
-Assert.That( "/folder1/junk/folder2",
-	Is.Not.SubPath( "/folder1/folder2" ) );
-
-Assert.That( @"C:\folder1\folder2\folder3",
-	Is.SubPath( @"C:\Folder1\Folder2/Folder3" ).IgnoreCase );
-Assert.That( "/folder1/folder2/folder3",
-	Is.Not.SubPath( "/Folder1/Folder2/Folder3" ).RespectCase );
-</pre></div>
-
-<h3>SamePathOrUnderConstraint</h3>
-
-<h4>Action</h4>
-<p>Tests that one path is equivalent another path or that it is under it.
-
-<h4>Constructor</h4>
-<div class="code"><pre>
-SamePathOrUnderConstraint( string expectedPath )
-</pre></div>
-
-<h4>Syntax</h4>
-<div class="code"><pre>
-Is.SamePathOrUnder( string expectedPath )
-</pre></div>
-
-<h4>Modifiers</h4>
-<div class="code"><pre>
-...IgnoreCase
-...RespectCase
-</pre></div>
-
-<h4>Examples of Use</h4>
-
-<div class="code"><pre>
-Assert.That( "/folder1/./junk/../folder2", 
-	Is.SamePathOrUnder( "/folder1/folder2" ) );
-Assert.That( "/folder1/junk/../folder2/./folder3",
-	Is.SamePathOrUnder( "/folder1/folder2" ) );
-Assert.That( "/folder1/junk/folder2/folder3",
-	Is.Not.SamePathOrUnder( "/folder1/folder2" ) );
-
-Assert.That( @"C:\folder1\folder2\folder3",
-	Is.SamePathOrUnder( @"C:\Folder1\Folder2" ).IgnoreCase );
-Assert.That( "/folder1/folder2/folder3",
-	Is.Not.SamePathOrUnder( "/Folder1/Folder2" ).RespectCase );
-</pre></div>
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<ul>
-<li><a href="equalConstraint.html">Equal&nbsp;Constraint</a></li>
-<li><a href="sameasConstraint.html">SameAs&nbsp;Constraint</a></li>
-<li><a href="conditionConstraints.html">Condition&nbsp;Constraints</a></li>
-<li><a href="comparisonConstraints.html">Comparison&nbsp;Constrants</a></li>
-<li id="current"><a href="pathConstraints.html">Path&nbsp;Constraints</a></li>
-<li><a href="typeConstraints.html">Type&nbsp;Constraints</a></li>
-<li><a href="stringConstraints.html">String&nbsp;Constraints</a></li>
-<li><a href="collectionConstraints.html">Collection&nbsp;Constraints</a></li>
-<li><a href="propertyConstraint.html">Property&nbsp;Constraint</a></li>
-<li><a href="throwsConstraint.html">Throws&nbsp;Constraint</a></li>
-<li><a href="compoundConstraints.html">Compound&nbsp;Constraints</a></li>
-<li><a href="delayedConstraint.html">Delayed&nbsp;Constraint</a></li>
-<li><a href="listMapper.html">List&nbsp;Mapper</a></li>
-<li><a href="reusableConstraint.html">Reusable&nbsp;Constraint</a></li>
-</ul>
-<li><a href="attributes.html">Attributes</a></li>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>


[41/51] [abbrv] [partial] Cleaning up and getting ready to development towards v4.8

Posted by sy...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Gallio.Ambience.xml
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Gallio.Ambience.xml b/lib/Gallio.3.2.750/tools/Gallio.Ambience.xml
deleted file mode 100644
index f46a69c..0000000
--- a/lib/Gallio.3.2.750/tools/Gallio.Ambience.xml
+++ /dev/null
@@ -1,511 +0,0 @@
-<?xml version="1.0"?>
-<doc>
-    <assembly>
-        <name>Gallio.Ambience</name>
-    </assembly>
-    <members>
-        <member name="T:Gallio.Ambience.AmbienceClient">
-            <summary>
-            The Ambience client accesses shared data provided by a remote <see cref="T:Gallio.Ambience.AmbienceServer"/>.
-            </summary>
-        </member>
-        <member name="M:Gallio.Ambience.AmbienceClient.Dispose">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.Ambience.AmbienceClient.Connect(Gallio.Ambience.AmbienceClientConfiguration)">
-            <summary>
-            Connects the client to the remote server.
-            </summary>
-            <param name="configuration">The client configuration.</param>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="configuration"/> is null.</exception>
-            <exception cref="T:Gallio.Ambience.AmbienceException">Thrown if the operation failed.</exception>
-        </member>
-        <member name="P:Gallio.Ambience.AmbienceClient.Container">
-            <summary>
-            Gets the client's data container.
-            </summary>
-            <exception cref="T:System.ObjectDisposedException">Thrown if the client has been disposed.</exception>
-        </member>
-        <member name="T:Gallio.Ambience.AmbienceSectionHandler">
-             <summary>
-             Recognizes and processes the &lt;ambience&gt; configuration section.
-             </summary>
-             <example>
-             Example configuration:
-             <code><![CDATA[
-             <?xml version="1.0" encoding="utf-8" ?>
-             <configuration>
-               <configSections>
-                 <section name="ambience" type="Gallio.Ambience.AmbienceSectionHandler, Gallio.Ambience" />
-               </configSections>
-            
-               <ambience>
-                 <defaultClient hostName="localhost" port="65436" userName="Test" password="Password" />
-               </ambience>
-             </configuration>
-             ]]></code>
-             </example>
-        </member>
-        <member name="F:Gallio.Ambience.AmbienceSectionHandler.SectionName">
-            <summary>
-            The name of the Ambience section: "ambience".
-            </summary>
-        </member>
-        <member name="M:Gallio.Ambience.AmbienceSectionHandler.Create(System.Object,System.Object,System.Xml.XmlNode)">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.Ambience.AmbienceSectionHandler.GetSection">
-            <summary>
-            Gets the configuration section contents, or a default instance if none available.
-            </summary>
-            <returns>The configuration section.</returns>
-        </member>
-        <member name="T:Gallio.Ambience.AmbienceException">
-            <summary>
-            Describes a problem accessing Gallio Ambience.
-            </summary>
-        </member>
-        <member name="M:Gallio.Ambience.AmbienceException.#ctor">
-            <summary>
-            Creates an exception.
-            </summary>
-        </member>
-        <member name="M:Gallio.Ambience.AmbienceException.#ctor(System.String)">
-            <summary>
-            Creates an exception.
-            </summary>
-            <param name="message">The message.</param>
-        </member>
-        <member name="M:Gallio.Ambience.AmbienceException.#ctor(System.String,System.Exception)">
-            <summary>
-            Creates an exception.
-            </summary>
-            <param name="message">The message.</param>
-            <param name="innerException">The inner exception.</param>
-        </member>
-        <member name="M:Gallio.Ambience.AmbienceException.#ctor(System.Runtime.Serialization.SerializationInfo,System.Runtime.Serialization.StreamingContext)">
-            <summary>
-            Creates an exception from serialization info.
-            </summary>
-            <param name="info">The serialization info.</param>
-            <param name="context">The streaming context.</param>
-        </member>
-        <member name="T:Gallio.Ambience.AmbienceServerConfiguration">
-            <summary>
-            Provides configuration data for <see cref="T:Gallio.Ambience.AmbienceServer"/>.
-            </summary>
-        </member>
-        <member name="P:Gallio.Ambience.AmbienceServerConfiguration.DatabasePath">
-            <summary>
-            Gets or sets the database file path.
-            </summary>
-            <value>The database file path, the default is a file called Default.db
-            in the Gallio.Ambient subdirectory of the Common Application Data folder.
-            </value>
-        </member>
-        <member name="P:Gallio.Ambience.AmbienceServerConfiguration.Port">
-            <summary>
-            Gets or sets the Ambient server port number.
-            </summary>
-            <value>The port number, defaults to 7822.</value>
-            <exception cref="T:System.ArgumentOutOfRangeException">Thrown if the port number is not in the range 1..65535.</exception>
-        </member>
-        <member name="P:Gallio.Ambience.AmbienceServerConfiguration.Credential">
-            <summary>
-            Gets or sets the Ambient server username and password.
-            </summary>
-            <value>The username and password, defaults to an anonymous credential.</value>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="value"/> is null.</exception>
-        </member>
-        <member name="T:Gallio.Ambience.Ambient">
-            <summary>
-            The Ambient object store is a shared lightweight repository for intermediate test data.  
-            </summary>
-            <remarks>
-            <para>
-            The Ambient object is like a persistent whiteboard used to pass information from one test
-            to another or to store it for subsequent analysis.
-            </para>
-            <para>
-            The Ambient object store may be used to model the persistent state of the
-            testing environment for end-to-end black-box integration testing.  It is particularly
-            useful for decoupling tests that incorporate stateful components such as
-            databases (that are not wiped and restored each time) or time-sensitive processes
-            such as asynchronous jobs.
-            </para>
-            </remarks>
-            <example>
-            <para>
-            Suppose we are testing a periodic invoicing process.  The business requirement
-            dictates that on the last day of each month, an invoice must be generated
-            and delivered electronically to all customers with an outstanding balance
-            in their account.
-            </para>
-            <para>
-            To verify this requirement, we might choose to adopt a combination of unit
-            testing and integration testing methodologies.
-            </para>
-            <para>
-            First, we will write unit tests for each component involved in the invoicing
-            process including the invoice generator, data access code, electronic delivery apparatus,
-            and the periodic job scheduler.  During unit testing, we will probably
-            replace the periodic job scheduler with a mock or stub implementation that simulates
-            the end-of-month trigger mechanism.  This is fast and quite effective.
-            </para>
-            <para>
-            Next, for additional confidence we will want to verify that the system works
-            completely as an integrated whole.  Perhaps the job scheduling mechanism is built
-            on 3rd party tools that must be correctly configured for the environment.  In
-            this situation, we might consider implementing an end-to-end system test
-            with nothing mocked out.
-            </para>
-            <para>
-            We can implement an end-to-end test like this:
-            <list type="bullet">
-            <item>Write a few test scripts that are scheduled to run on a regular basis
-            and that generate transactions that will be reflected in the invoices.</item>
-            <item>For each transaction, such as creating a new account or purchasing a service,
-            the scripts should make a record in the <see cref="T:Gallio.Ambience.Ambient"/> object store.</item>
-            <item>Write a few more test scripts that are scheduled to run after the invoicing
-            process occurs.  They should verify the contents of the invoices based on previously
-            stored records in the <see cref="T:Gallio.Ambience.Ambient"/> object store.</item>
-            </list>
-            </para>
-            <para>
-            Of course, in this example it can take up to a month to obtain confirmation that
-            the invoicing process functioned as expected.  Consequently, we should not rely
-            on this approach exclusively for our testing purposes.  Nevertheless, it may be
-            useful as part of an on-going Quality Assurance audit.
-            </para>
-            </example>
-        </member>
-        <member name="P:Gallio.Ambience.Ambient.Data">
-            <summary>
-            Gets the default ambient data container.
-            </summary>
-            <exception cref="T:Gallio.Ambience.AmbienceException">Thrown if the operation failed.</exception>
-        </member>
-        <member name="P:Gallio.Ambience.Ambient.DefaultClientConfiguration">
-            <summary>
-            Gets or sets the default client configuration.
-            </summary>
-            <value>The default client configuration.  The initial value is populated from the contents
-            of the Ambience configuration section in the application's or test's configuration file.
-            See also <seealso cref="T:Gallio.Ambience.AmbienceSectionHandler"/>.</value>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="value"/> is null.</exception>
-        </member>
-        <member name="T:Gallio.Ambience.AmbientDataContainerExtensions">
-            <summary>
-            Extension methods for LINQ syntax over Ambient data containers.
-            </summary>
-        </member>
-        <member name="M:Gallio.Ambience.AmbientDataContainerExtensions.Cast``1(Gallio.Ambience.IAmbientDataContainer)">
-            <summary>
-            Obtains a query over a data container.
-            </summary>
-            <remarks>
-            <para>
-            Client code will not call this method directly.  However, it turns out that
-            the C# compiler will add an implicit call to this method when it attempts to
-            select a value from the container using LINQ syntax.
-            </para>
-            </remarks>
-            <typeparam name="T">The result type.</typeparam>
-            <param name="container">The container.</param>
-            <returns>The query object.</returns>
-        </member>
-        <member name="T:Gallio.Ambience.AmbientDataQueryExtensions">
-            <summary>
-            Extension methods for LINQ syntax over Ambient data queries.
-            </summary>
-        </member>
-        <member name="M:Gallio.Ambience.AmbientDataQueryExtensions.Count``1(Gallio.Ambience.IAmbientDataQuery{``0})">
-            <summary>
-            Counts the number of objects produced by the query.
-            </summary>
-            <typeparam name="TSource">The type of object being queried.</typeparam>
-            <param name="self">The query.</param>
-            <returns>The number of objects.</returns>
-        </member>
-        <member name="M:Gallio.Ambience.AmbientDataQueryExtensions.Select``2(Gallio.Ambience.IAmbientDataQuery{``0},System.Func{``0,``1})">
-            <summary>
-            Produces a new query to select a projection of a component of another query.
-            </summary>
-            <typeparam name="TSource">The type of object being queried.</typeparam>
-            <typeparam name="TRet">The projection result type.</typeparam>
-            <param name="self">The query.</param>
-            <param name="selector">The selection expression.</param>
-            <returns>The projected query.</returns>
-        </member>
-        <member name="M:Gallio.Ambience.AmbientDataQueryExtensions.Where``1(Gallio.Ambience.IAmbientDataQuery{``0},System.Linq.Expressions.Expression{System.Func{``0,System.Boolean}})">
-            <summary>
-            Produces a new query to filter another query by a criteria.
-            </summary>
-            <typeparam name="TSource">The type of object being queried.</typeparam>
-            <param name="self">The query.</param>
-            <param name="expression">The filter expression.</param>
-            <returns>The filtered query.</returns>
-        </member>
-        <member name="M:Gallio.Ambience.AmbientDataQueryExtensions.OrderBy``2(Gallio.Ambience.IAmbientDataQuery{``0},System.Linq.Expressions.Expression{System.Func{``0,``1}})">
-            <summary>
-            Produces a new query ordered by a comparison expression in ascending order.
-            </summary>
-            <typeparam name="TSource">The type of object being queried.</typeparam>
-            <typeparam name="TKey">The sort key type.</typeparam>
-            <param name="self">The query.</param>
-            <param name="expression">The sort comparison expression.</param>
-            <returns>The ordered query.</returns>
-        </member>
-        <member name="M:Gallio.Ambience.AmbientDataQueryExtensions.OrderByDescending``2(Gallio.Ambience.IAmbientDataQuery{``0},System.Linq.Expressions.Expression{System.Func{``0,``1}})">
-            <summary>
-            Produces a new query ordered by a comparison expression in descending order.
-            </summary>
-            <typeparam name="TSource">The type of object being queried.</typeparam>
-            <typeparam name="TKey">The sort key type.</typeparam>
-            <param name="self">The query.</param>
-            <param name="expression">The sort comparison expression.</param>
-            <returns>The ordered query.</returns>
-        </member>
-        <member name="M:Gallio.Ambience.AmbientDataQueryExtensions.ThenBy``2(Gallio.Ambience.IAmbientDataQuery{``0},System.Linq.Expressions.Expression{System.Func{``0,``1}})">
-            <summary>
-            Produces a new query ordered by an additional comparison expression in ascending order.
-            </summary>
-            <typeparam name="TSource">The type of object being queried.</typeparam>
-            <typeparam name="TKey">The sort key type.</typeparam>
-            <param name="self">The query.</param>
-            <param name="expression">The sort comparison expression.</param>
-            <returns>The ordered query.</returns>
-        </member>
-        <member name="M:Gallio.Ambience.AmbientDataQueryExtensions.ThenByDescending``2(Gallio.Ambience.IAmbientDataQuery{``0},System.Linq.Expressions.Expression{System.Func{``0,``1}})">
-            <summary>
-            Produces a new query ordered by an additional comparison expression in descending order.
-            </summary>
-            <typeparam name="TSource">The type of object being queried.</typeparam>
-            <typeparam name="TKey">The sort key type.</typeparam>
-            <param name="self">The query.</param>
-            <param name="expression">The sort comparison expression.</param>
-            <returns>The ordered query.</returns>
-        </member>
-        <member name="T:Gallio.Ambience.IAmbientDataContainer">
-            <summary>
-            Represents a container of Ambient data and providers operations to
-            query, store and update its contents.
-            </summary>
-        </member>
-        <member name="M:Gallio.Ambience.IAmbientDataContainer.Query``1">
-            <summary>
-            Gets all objects of a particular type in the container.
-            </summary>
-            <typeparam name="T">The object type.</typeparam>
-            <returns>The data set.</returns>
-            <exception cref="T:Gallio.Ambience.AmbienceException">Thrown if the operation failed.</exception>
-        </member>
-        <member name="M:Gallio.Ambience.IAmbientDataContainer.Query``1(System.Predicate{``0})">
-            <summary>
-            Gets all objects of a particular type in the container that match a particular filtering criteria.
-            </summary>
-            <typeparam name="T">The object type.</typeparam>
-            <param name="predicate">The filtering criteria.</param>
-            <returns>The data set.</returns>
-            <exception cref="T:Gallio.Ambience.AmbienceException">Thrown if the operation failed.</exception>
-        </member>
-        <member name="M:Gallio.Ambience.IAmbientDataContainer.Delete(System.Object)">
-            <summary>
-            Deletes the object from the container.
-            </summary>
-            <param name="obj">The object to delete.</param>
-            <exception cref="T:Gallio.Ambience.AmbienceException">Thrown if the operation failed.</exception>
-        </member>
-        <member name="M:Gallio.Ambience.IAmbientDataContainer.Store(System.Object)">
-            <summary>
-            Stores or updates an object in the container.
-            </summary>
-            <param name="obj">The object to store.</param>
-            <exception cref="T:Gallio.Ambience.AmbienceException">Thrown if the operation failed.</exception>
-        </member>
-        <member name="M:Gallio.Ambience.IAmbientDataContainer.DeleteAll">
-            <summary>
-            Deletes all objects in the container.
-            </summary>
-            <remarks>
-            <para>
-            Use with caution!
-            </para>
-            </remarks>
-            <exception cref="T:Gallio.Ambience.AmbienceException">Thrown if the operation failed.</exception>
-        </member>
-        <member name="T:Gallio.Ambience.IAmbientDataQuery`1">
-            <summary>
-            Represents a lazily evaluated query over Ambient data for use with
-            the LINQ query syntax.
-            </summary>
-        </member>
-        <member name="T:Gallio.Ambience.AmbienceClientConfiguration">
-            <summary>
-            Provides configuration data for <see cref="T:Gallio.Ambience.AmbienceClient"/>.
-            </summary>
-        </member>
-        <member name="P:Gallio.Ambience.AmbienceClientConfiguration.HostName">
-            <summary>
-            Gets or sets the Ambient server hostname.
-            </summary>
-            <value>The hostname, defaults to "localhost".</value>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="value"/> is null.</exception>
-            <exception cref="T:System.ArgumentException">Thrown if <paramref name="value"/> is empty.</exception>
-        </member>
-        <member name="P:Gallio.Ambience.AmbienceClientConfiguration.Port">
-            <summary>
-            Gets or sets the Ambient server port number.
-            </summary>
-            <value>The port number, defaults to 7822.</value>
-            <exception cref="T:System.ArgumentOutOfRangeException">Thrown if the port number is not in the range 1..65535.</exception>
-        </member>
-        <member name="P:Gallio.Ambience.AmbienceClientConfiguration.Credential">
-            <summary>
-            Gets or sets the Ambient server username and password.
-            </summary>
-            <value>The username and password, defaults to an anonymous credential.</value>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="value"/> is null.</exception>
-        </member>
-        <member name="T:Gallio.Ambience.IAmbientDataSet`1">
-            <summary>
-            A data set containing Ambient objects.
-            </summary>
-        </member>
-        <member name="T:Gallio.Ambience.Impl.AmbienceConfigurationSection">
-            <summary>
-            Provides information from the Ambience configuration section.
-            </summary>
-            <seealso cref="T:Gallio.Ambience.AmbienceSectionHandler"/>
-        </member>
-        <member name="F:Gallio.Ambience.Impl.Constants.DefaultPortNumber">
-            <summary>
-            Gets the default port number for the Ambient server.
-            </summary>
-        </member>
-        <member name="F:Gallio.Ambience.Impl.Constants.DefaultPortNumberString">
-            <summary>
-            Gets the default port number for the Ambient server as a string.
-            </summary>
-        </member>
-        <member name="F:Gallio.Ambience.Impl.Constants.DefaultDatabaseFileName">
-            <summary>
-            Gets the default database file name.
-            </summary>
-        </member>
-        <member name="T:Gallio.Ambience.Impl.Db4oAmbientDataContainer">
-            <summary>
-            Facade over <see cref="T:Db4objects.Db4o.IObjectContainer"/>.
-            </summary>
-        </member>
-        <member name="M:Gallio.Ambience.Impl.Db4oAmbientDataContainer.#ctor(Db4objects.Db4o.IObjectContainer)">
-            <summary>
-            Creates a wrapper for a Db4o object container.
-            </summary>
-            <param name="inner">The inner container.</param>
-        </member>
-        <member name="P:Gallio.Ambience.Impl.Db4oAmbientDataContainer.Inner">
-            <summary>
-            Gets the Db4o object container.
-            </summary>
-        </member>
-        <member name="T:Gallio.Ambience.Impl.Db4oAmbientDataQuery`1">
-            <summary>
-            Facade over <see cref="T:Db4objects.Db4o.Linq.IDb4oLinqQuery`1"/>.
-            </summary>
-            <typeparam name="T">The query result type.</typeparam>
-        </member>
-        <member name="M:Gallio.Ambience.Impl.Db4oAmbientDataQuery`1.#ctor(Db4objects.Db4o.Linq.IDb4oLinqQuery{`0})">
-            <summary>
-            Creates a wrapper for a Db4o query.
-            </summary>
-            <param name="inner">The inner query.</param>
-        </member>
-        <member name="P:Gallio.Ambience.Impl.Db4oAmbientDataQuery`1.Inner">
-            <summary>
-            Gets the Db4o query object.
-            </summary>
-        </member>
-        <member name="T:Gallio.Ambience.Impl.Db4oListWrapper`1">
-            <summary>
-            This wrapper reinterprets Db4o exceptions as Ambience exceptions so that the client
-            can catch them in a meaningful way.
-            </summary>
-            <remarks>
-            <para>
-            Db4o is internalized by Ambience so its exception types are not accessible to clients.
-            </para>
-            </remarks>
-            <typeparam name="T">The item type.</typeparam>
-        </member>
-        <member name="T:Gallio.Ambience.NamespaceDoc">
-            <summary>
-            The Gallio.Ambience namespace provides a lightweight object database based on db4o for
-            storing test data across test runs.
-            </summary>
-        </member>
-        <member name="T:Gallio.Ambience.AmbienceServer">
-            <summary>
-            The Ambience server provides shared data to remote <see cref="T:Gallio.Ambience.AmbienceClient"/>s.
-            </summary>
-        </member>
-        <member name="M:Gallio.Ambience.AmbienceServer.#ctor(Gallio.Ambience.AmbienceServerConfiguration)">
-            <summary>
-            Creates an ambient server with parameters initialized to defaults.
-            </summary>
-            <param name="configuration">The server configuration.</param>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="configuration"/> is null.</exception>
-        </member>
-        <member name="M:Gallio.Ambience.AmbienceServer.Dispose">
-            <summary>
-            Stops and disposes the server.
-            </summary>
-        </member>
-        <member name="M:Gallio.Ambience.AmbienceServer.Start">
-            <summary>
-            Starts the server.
-            </summary>
-            <exception cref="T:System.InvalidOperationException">Thrown if the server has already been started.</exception>
-            <exception cref="T:System.ObjectDisposedException">Thrown if the server has been disposed.</exception>
-            <exception cref="T:Gallio.Ambience.AmbienceException">Thrown if the operation failed.</exception>
-        </member>
-        <member name="M:Gallio.Ambience.AmbienceServer.Stop">
-            <summary>
-            Stops the server.
-            </summary>
-            <remarks>
-            <para>
-            Does nothing if the server has already been stopped.
-            </para>
-            </remarks>
-            <exception cref="T:System.ObjectDisposedException">Thrown if the server has been disposed.</exception>
-        </member>
-        <member name="M:Gallio.Ambience.AmbienceServer.Dispose(System.Boolean)">
-            <summary>
-            Stops and disposes the server.
-            </summary>
-            <param name="disposing">True if disposing.</param>
-        </member>
-        <member name="T:Gallio.Ambience.Properties.Resources">
-            <summary>
-              A strongly-typed resource class, for looking up localized strings, etc.
-            </summary>
-        </member>
-        <member name="P:Gallio.Ambience.Properties.Resources.ResourceManager">
-            <summary>
-              Returns the cached ResourceManager instance used by this class.
-            </summary>
-        </member>
-        <member name="P:Gallio.Ambience.Properties.Resources.Culture">
-            <summary>
-              Overrides the current thread's CurrentUICulture property for all
-              resource lookups using this strongly typed resource class.
-            </summary>
-        </member>
-        <member name="P:Gallio.Ambience.Properties.Resources.Db4oAmbientDataContainer_QueryResultException">
-            <summary>
-              Looks up a localized string similar to An error occurred while accessing the query result set..
-            </summary>
-        </member>
-    </members>
-</doc>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Gallio.Common.Splash.dll
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Gallio.Common.Splash.dll b/lib/Gallio.3.2.750/tools/Gallio.Common.Splash.dll
deleted file mode 100644
index 4d00dfb..0000000
Binary files a/lib/Gallio.3.2.750/tools/Gallio.Common.Splash.dll and /dev/null differ


[28/51] [abbrv] [partial] Cleaning up and getting ready to development towards v4.8

Posted by sy...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/NUnit/Latest/nunit.util.dll
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/NUnit/Latest/nunit.util.dll b/lib/Gallio.3.2.750/tools/NUnit/Latest/nunit.util.dll
deleted file mode 100644
index b31beef..0000000
Binary files a/lib/Gallio.3.2.750/tools/NUnit/Latest/nunit.util.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Resources/Assembly.ico
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Resources/Assembly.ico b/lib/Gallio.3.2.750/tools/Resources/Assembly.ico
deleted file mode 100644
index c448dd4..0000000
Binary files a/lib/Gallio.3.2.750/tools/Resources/Assembly.ico and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Resources/Container.ico
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Resources/Container.ico b/lib/Gallio.3.2.750/tools/Resources/Container.ico
deleted file mode 100644
index 3aa2dad..0000000
Binary files a/lib/Gallio.3.2.750/tools/Resources/Container.ico and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Resources/Fixture.ico
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Resources/Fixture.ico b/lib/Gallio.3.2.750/tools/Resources/Fixture.ico
deleted file mode 100644
index 85936b3..0000000
Binary files a/lib/Gallio.3.2.750/tools/Resources/Fixture.ico and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Resources/Gallio.ControlPanel.ico
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Resources/Gallio.ControlPanel.ico b/lib/Gallio.3.2.750/tools/Resources/Gallio.ControlPanel.ico
deleted file mode 100644
index 4ed5608..0000000
Binary files a/lib/Gallio.3.2.750/tools/Resources/Gallio.ControlPanel.ico and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Resources/Gallio.Copy.ico
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Resources/Gallio.Copy.ico b/lib/Gallio.3.2.750/tools/Resources/Gallio.Copy.ico
deleted file mode 100644
index 7c8600f..0000000
Binary files a/lib/Gallio.3.2.750/tools/Resources/Gallio.Copy.ico and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Resources/Gallio.Echo.ico
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Resources/Gallio.Echo.ico b/lib/Gallio.3.2.750/tools/Resources/Gallio.Echo.ico
deleted file mode 100644
index eb3edb9..0000000
Binary files a/lib/Gallio.3.2.750/tools/Resources/Gallio.Echo.ico and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Resources/Gallio.Icarus.ico
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Resources/Gallio.Icarus.ico b/lib/Gallio.3.2.750/tools/Resources/Gallio.Icarus.ico
deleted file mode 100644
index 4ed5608..0000000
Binary files a/lib/Gallio.3.2.750/tools/Resources/Gallio.Icarus.ico and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Resources/Gallio.Utility.ico
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Resources/Gallio.Utility.ico b/lib/Gallio.3.2.750/tools/Resources/Gallio.Utility.ico
deleted file mode 100644
index eb3edb9..0000000
Binary files a/lib/Gallio.3.2.750/tools/Resources/Gallio.Utility.ico and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Resources/Gallio.ico
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Resources/Gallio.ico b/lib/Gallio.3.2.750/tools/Resources/Gallio.ico
deleted file mode 100644
index 4ed5608..0000000
Binary files a/lib/Gallio.3.2.750/tools/Resources/Gallio.ico and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Resources/MbUnit.ico
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Resources/MbUnit.ico b/lib/Gallio.3.2.750/tools/Resources/MbUnit.ico
deleted file mode 100644
index 7192695..0000000
Binary files a/lib/Gallio.3.2.750/tools/Resources/MbUnit.ico and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Resources/Test.ico
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Resources/Test.ico b/lib/Gallio.3.2.750/tools/Resources/Test.ico
deleted file mode 100644
index 2f2a792..0000000
Binary files a/lib/Gallio.3.2.750/tools/Resources/Test.ico and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Resources/Unsupported.ico
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Resources/Unsupported.ico b/lib/Gallio.3.2.750/tools/Resources/Unsupported.ico
deleted file mode 100644
index 224dfba..0000000
Binary files a/lib/Gallio.3.2.750/tools/Resources/Unsupported.ico and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Resources/css/Gallio-Report.css
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Resources/css/Gallio-Report.css b/lib/Gallio.3.2.750/tools/Resources/css/Gallio-Report.css
deleted file mode 100644
index 60151a1..0000000
--- a/lib/Gallio.3.2.750/tools/Resources/css/Gallio-Report.css
+++ /dev/null
@@ -1,527 +0,0 @@
-/* Common inherited text options */
-.gallio-report
-{
-	font-family: Verdana, Arial, Helvetica, Helv, sans-serif;
-	font-size: 10pt;
-	word-wrap: break-word; /* IE and CSS3, we use <wbr> for other browsers */
-}
-
-/* Containers */
-div.gallio-report, body.gallio-report
-{
-	margin: 0px 0px 0px 0px;
-	padding: 0px 0px 0px 0px;
-	overflow: hidden;
-	width: 100%;
-}
-
-.gallio-report div.header
-{
-	margin: 0px 0px 0px 0px;
-	padding: 0px 0px 0px 0px;
-	background-color: #95b0be;
-	background-image: url(../img/header-background.gif);
-	background-repeat: repeat-y;
-	width: 100%;
-	height: 59px;
-	border-bottom: solid 1px black;
-}
-
-.gallio-report div.header-image
-{
-	margin: 0px 0px 0px 0px;
-	padding: 0px 0px 0px 0px;
-	width: 100%;
-	height: 60px;
-	background-image: url(../img/GallioTestReportHeader.png);
-	background-repeat: no-repeat;
-	background-position: 0 0;
-}
-
-.gallio-report div.content
-{
-	width: 100%;
-}
-
-/* Navigation bar */
-.gallio-report div.navigator
-{
-	position: fixed;
-	right: 0px;
-	bottom: 0px;
-	margin: 0px 0px 0px 0px;
-	padding: 0px 0px 0px 0px;
-	width: 17px;
-	background-color: #d0d4d8;
-	overflow: hidden;
-}
-
-.gallio-report div.navigator a.navigator-box
-{
-	display: block;
-	cursor: pointer;
-	width: 9px;
-	height: 9px;
-	position: absolute;
-	top: 3px;
-	left: 3px;
-	border: solid 1px black;
-}
-
-.gallio-report div.navigator div.navigator-stripes
-{
-	position: absolute;
-	top: 17px;
-	bottom: 0px;
-	width: 17px;
-}
-
-.gallio-report div.navigator div.navigator-stripes a
-{
-	display: block;
-	cursor: pointer;
-	width: 11px;
-	height: 2px;
-	position: absolute;
-	left: 3px;
-}
-
-/* Generate a fixed layout when the report is the whole document */
-body.gallio-report div.header
-{
-	position: fixed;
-	top: 0px;
-	left: 0px;
-}
-
-body.gallio-report div.content
-{
-	position: fixed; 
-	top: 60px;
-	left: 0px;
-	right: 17px;
-	bottom: 0px;
-	overflow: auto;
-	width: auto;
-}
-
-body.gallio-report div.navigator
-{
-	top: 60px;
-}
-
-/* Generate an embedded layout when the report is only a fragment */
-div.gallio-report div.header
-{
-	border: solid 1px black;
-}
-
-div.gallio-report div.navigator
-{
-	top: 0px;
-}
-
-/* Section headings */
-.gallio-report h2
-{
-	font-size: 13pt;
-	letter-spacing: 0.15em;
-	color: #1f1f1f;
-	padding: 0;
-	margin: 0 0 3px 0;
-	text-indent: 8px;
-}
-
-
-/* Toggle regions */
-.gallio-report ul
-{
-	list-style-type: none;
-	padding-left: 0px;
-	margin: 0px 0px 0px 0px;
-}
-
-.gallio-report div.panel
-{
-	margin: 0px 0px 0px 24px;
-}
-
-.gallio-report img.toggle
-{
-	cursor: pointer;
-	margin-right: 6px;
-}
-
-
-/* Status colors */
-.gallio-report .status-passed
-{
-	background-color: #008000;
-}
-
-.gallio-report .status-failed
-{
-	background-color: #ff0000;
-}
-
-.gallio-report .status-inconclusive
-{
-	background-color: #ffff00;
-}
-
-.gallio-report .status-skipped
-{
-	background-color: #999999;
-}
-
-
-/* Outcome bar */
-.gallio-report table.outcome-bar
-{
-	display: inline;
-	vertical-align: middle;
-	margin-left: 8px;
-}
-
-.gallio-report div.outcome-bar
-{
-	overflow: hidden;
-	
-	border: solid 1px #000000;
-	padding: 0px 0px 0px 0px;
-	margin: 0px 0px 0px 0px;
-
-	height: 8px;
-	width: 72px;
-}
-
-.gallio-report div.outcome-bar.condensed
-{
-	height: 6px;
-	width: 20px;
-}
-
-
-/* Outcome statistics */
-.gallio-report span.outcome-icons
-{
-	font-size: 11pt;
-}
-
-
-/* Test Kind Icons (Note: Additional kinds in separate automatically generated css file.)  */
-
-.gallio-report .testKind
-{
-	display: inline-block;
-	margin: 0px 6px 0px 0px;
-	padding: 0px 0px 0px 0px;
-	width: 16px;
-	height: 16px;
-	background-repeat: no-repeat;
-	background-position: center center;
-	background-image: url(../img/UnknownTestKind.png);
-}
-
-/* Test runs */
-.gallio-report .testStepRun
-{
-	margin-top: 12pt;
-	font-size: 10pt;
-}
-
-.gallio-report .testStepRunHeading
-{
-	font-weight: bold;
-	font-size: 10pt;
-}
-
-.gallio-report .testStepRunHeading-Level1
-{
-	font-size: 12pt;
-}
-
-.gallio-report .testStepRunHeading-Level2
-{
-	font-size: 11pt;
-}
-
-.gallio-report .testStepRunHeading-Level3
-{
-	font-size: 10pt;
-}
-
-
-/* Metadata entries */
-.gallio-report .metadata
-{
-	margin: 5px 5px 5px 0px;
-	padding: 5px 5px 5px 5px;
-	
-	background: #f4f4ff;
-	font-size: 9pt;
-}
-
-/* Test logs */
-.gallio-report .log
-{
-	margin: 5px 0px 5px 0px;
-}
-
-.gallio-report .logAttachmentList
-{
-	font-size: 10pt;
-	font-style: italic;
-}
-
-.gallio-report .logStream
-{
-	background-color: #f0f0f0;
-	border-bottom: solid 1px #c6c6c6;
-	border-right: solid 1px #c6c6c6;
-	margin: 5px 5px 5px 0px;
-	padding: 5px 5px 5px 5px;
-}
-
-.gallio-report .logStreamHeading
-{
-	font-weight:bold;
-	font-size: 10pt;
-	text-decoration: underline;
-}
-
-.gallio-report .logStreamBody
-{
-	font-size: 9pt;
-	border-style: none;
-}
-
-.gallio-report .logStreamSection
-{
-	margin-top: 12pt;
-	margin-bottom: 12pt;
-	padding-left: 6px;
-	border-left: solid 3px black;
-}
-
-.gallio-report .logStreamSectionHeading
-{
-	font-weight: bold;
-	text-decoration: underline;
-}
-
-.gallio-report .logStreamEmbed
-{
-	font-style: italic;
-	padding: 5px 10px 5px 10px;
-}
-
-.gallio-report .logHiddenData
-{
-	display: none;
-}
-
-/* Test log streams */
-.gallio-report .logStream-Failures
-{
-	background-color: #ffd8d8;
-	border: dotted 1px #905050;
-}
-
-.gallio-report .logStream-Warnings
-{
-	background-color: #ffffc8;
-	border: dotted 1px #909050;
-}
-
-/* Test log stream markers */
-.gallio-report .logStreamMarker-AssertionFailure
-{
-}
-
-.gallio-report .logStreamMarker-Label
-{
-	font-weight: bold;
-}
-
-.gallio-report .logStreamMarker-Exception
-{
-	font-style: italic;
-}
-
-.gallio-report .logStreamMarker-StackTrace
-{
-	font-style: italic;
-}
-
-.gallio-report .logStreamMarker-Monospace
-{
-	font-family: Consolas, Courier New, Courier;
-}
-
-.gallio-report .logStreamMarker-Highlight
-{
-	background-color: Yellow;
-}
-
-.gallio-report .logStreamMarker-DiffAddition
-{
-	background-color: #b0ffb0;
-}
-
-.gallio-report .logStreamMarker-DiffDeletion
-{
-	background-color: #ffb0b0;
-	text-decoration: line-through;
-}
-
-.gallio-report .logStreamMarker-DiffChange
-{
-	background-color: #b0b0ff;
-}
-
-.gallio-report .logStreamMarker-Ellipsis
-{
-	text-decoration: underline;
-}
-
-.gallio-report .embeddedImage
-{
-	max-width: 800px;
-}
-
-.gallio-report .attachmentLink
-{
-}
-
-/* Sections */
-.gallio-report div.section
-{
-	background-color: #ebeaea;
-	margin: 5px;
-	padding: 10px;
-	border-bottom: solid 1px #dcdcdc;
-	border-right: solid 1px #dcdcdc;
-	overflow: hidden;
-}
-
-.gallio-report div.section-content
-{
-	background-color: #fbfbfb;
-	padding: 10px 10px 10px 10px;
-	overflow: hidden;
-}
-
-.gallio-report table.statistics-table
-{
-	border-collapse: collapse;
-}
-
-.gallio-report table.statistics-table td
-{
-	width: 100%;
-}
-
-.gallio-report table.statistics-table td.statistics-label-cell
-{
-	font-weight: bolder;
-	color: #646464;
-	padding: 0px 10px 0px 10px;
-	width: auto;
-}
-
-.gallio-report table.statistics-table tr.alternate-row td
-{
-	background-color: #f2f2f2;
-}
-
-
-/* Annotations */
-.gallio-report div.annotation
-{
-}
-
-.gallio-report div.annotation-message
-{
-	margin-left: 2em;
-	text-indent: -2em;
-}
-
-.gallio-report div.annotation-location, div.annotation-reference, div.annotation-details
-{
-	margin-left: 4em;
-	text-indent: -2em;
-	font-style: italic;
-}
-
-.gallio-report .annotation-type-error
-{
-	color: #990000;
-}
-
-.gallio-report .annotation-type-warning
-{
-	color: #999900;
-}
-
-.gallio-report .annotation-type-info
-{
-	color: #999999;
-}
-
-/* Log Entries */
-.gallio-report div.logEntry
-{
-}
-
-.gallio-report div.logEntry-text
-{
-	margin-left: 2em;
-	text-indent: -2em;
-}
-
-.gallio-report div.logEntry-details
-{
-	margin-left: 4em;
-	text-indent: -2em;
-	font-style: italic;
-}
-
-.gallio-report .logEntry-severity-error
-{
-	color: #990000;
-}
-
-.gallio-report .logEntry-severity-warning
-{
-	color: #999900;
-}
-
-.gallio-report .logEntry-severity-important
-{
-	color: #000000;
-}
-
-.gallio-report .logEntry-severity-info
-{
-	color: #999999;
-}
-
-.gallio-report .logEntry-severity-debug
-{
-	color: #aaaaaa;
-}
-
-/* Cross-References */
-
-.gallio-report a:hover.crossref
-{
-	background-color: #eeee99;
-}
-
-.gallio-report a.crossref
-{
-	color: #000000;
-	text-decoration: none;
-	border-bottom: dotted 1px #aa00dd;
-}

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Resources/img/Failed.gif
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Resources/img/Failed.gif b/lib/Gallio.3.2.750/tools/Resources/img/Failed.gif
deleted file mode 100644
index bcf4c07..0000000
Binary files a/lib/Gallio.3.2.750/tools/Resources/img/Failed.gif and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Resources/img/FullStop.gif
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Resources/img/FullStop.gif b/lib/Gallio.3.2.750/tools/Resources/img/FullStop.gif
deleted file mode 100644
index dda8c62..0000000
Binary files a/lib/Gallio.3.2.750/tools/Resources/img/FullStop.gif and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Resources/img/GallioTestReportHeader.png
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Resources/img/GallioTestReportHeader.png b/lib/Gallio.3.2.750/tools/Resources/img/GallioTestReportHeader.png
deleted file mode 100644
index 111cca6..0000000
Binary files a/lib/Gallio.3.2.750/tools/Resources/img/GallioTestReportHeader.png and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Resources/img/Ignored.gif
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Resources/img/Ignored.gif b/lib/Gallio.3.2.750/tools/Resources/img/Ignored.gif
deleted file mode 100644
index dd90f46..0000000
Binary files a/lib/Gallio.3.2.750/tools/Resources/img/Ignored.gif and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Resources/img/Minus.gif
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Resources/img/Minus.gif b/lib/Gallio.3.2.750/tools/Resources/img/Minus.gif
deleted file mode 100644
index 46acbcc..0000000
Binary files a/lib/Gallio.3.2.750/tools/Resources/img/Minus.gif and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Resources/img/Passed.gif
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Resources/img/Passed.gif b/lib/Gallio.3.2.750/tools/Resources/img/Passed.gif
deleted file mode 100644
index 1dee9cd..0000000
Binary files a/lib/Gallio.3.2.750/tools/Resources/img/Passed.gif and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Resources/img/Plus.gif
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Resources/img/Plus.gif b/lib/Gallio.3.2.750/tools/Resources/img/Plus.gif
deleted file mode 100644
index 0ce509a..0000000
Binary files a/lib/Gallio.3.2.750/tools/Resources/img/Plus.gif and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Resources/img/UnknownTestKind.png
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Resources/img/UnknownTestKind.png b/lib/Gallio.3.2.750/tools/Resources/img/UnknownTestKind.png
deleted file mode 100644
index 9f91b64..0000000
Binary files a/lib/Gallio.3.2.750/tools/Resources/img/UnknownTestKind.png and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Resources/img/header-background.gif
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Resources/img/header-background.gif b/lib/Gallio.3.2.750/tools/Resources/img/header-background.gif
deleted file mode 100644
index 0e01c4c..0000000
Binary files a/lib/Gallio.3.2.750/tools/Resources/img/header-background.gif and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Resources/js/Gallio-Report.js
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Resources/js/Gallio-Report.js b/lib/Gallio.3.2.750/tools/Resources/js/Gallio-Report.js
deleted file mode 100644
index b4af2c0..0000000
--- a/lib/Gallio.3.2.750/tools/Resources/js/Gallio-Report.js
+++ /dev/null
@@ -1,244 +0,0 @@
-function reportLoaded()
-{
-    fixAttachmentLinksOnIE();
-}
-
-function fixAttachmentLinksOnIE()
-{
-    if (needFixupForIE())
-    {
-        // On IE, pages in the local filesystem that possess the Mark of the Web
-        // are forbidden from navigating to other local files.  This breaks links
-        // to attachments on the local filesystem unless we make some changes.
-        var count = document.links.length;
-        for (var i = 0; i < count; i++)
-        {
-            var link = document.links[i];
-            var href = link.href;
-            if (link.className == "attachmentLink" && isLocalFileUri(href))
-            {
-                link.href = toGallioAttachmentUri(href);
-            }
-        }
-    }
-}
-
-function toGallioAttachmentUri(uri)
-{
-    var path = uri.substring(8).replace(/\//g, "\\");
-    return "gallio:openAttachment?path=" + path;
-}
-
-var needFixupForIECache = undefined;
-function needFixupForIE()
-{
-    if (needFixupForIECache == undefined)
-        needFixupForIECache = isIE() && (isLocalFileUri(window.location.href) || isInMemoryUri(window.location.href));
-        
-    return needFixupForIECache;
-}
-
-function isIE()
-{
-    return navigator.appName == "Microsoft Internet Explorer";
-}
-
-function isLocalFileUri(uri)
-{
-    return uri.search(/^file:\/\/\//) == 0;
-}
-
-function isInMemoryUri(uri)
-{
-    return uri == "about:blank";
-}
-
-function toggle(id)
-{
-    var icon = document.getElementById('toggle-' + id);
-    if (icon != null)
-    {
-        var childElement = document.getElementById(id);
-        if (icon.src.indexOf('Plus.gif') != -1)
-        {
-            icon.src = icon.src.replace('Plus.gif', 'Minus.gif');
-            if (childElement != null)
-                childElement.style.display = "block";
-        }
-        else
-        {
-            icon.src = icon.src.replace('Minus.gif', 'Plus.gif');
-            if (childElement != null)
-                childElement.style.display = "none";
-        }
-    }
-}
-
-function expand(ids)
-{
-    for (var i = 0; i < ids.length; i++)
-    {
-        var id = ids[i];
-        var icon = document.getElementById('toggle-' + id);
-        if (icon != null)
-        {
-            if (icon.src.indexOf('Plus.gif') != -1)
-            {
-                icon.src = icon.src.replace('Plus.gif', 'Minus.gif');
-
-                var childElement = document.getElementById(id);
-                if (childElement != null)
-                    childElement.style.display = "block";
-            }
-        }
-    }
-}
-
-function navigateTo(path, line, column)
-{
-    var navigator = new ActiveXObject("Gallio.Navigator.GallioNavigator");
-    if (navigator)
-        navigator.NavigateTo(path, line, column);
-}
-
-function setInnerHTMLFromUri(id, uri)
-{
-    _asyncLoadContentFromUri(uri, function(loadedDocument)
-    {
-        // workaround for IE failure to auto-detect HTML content
-        var children = isIE() ? loadedDocument.body.children : null;
-        if (children && children.length == 1 && children[0].tagName == "PRE")
-        {
-            var text = getTextContent(loadedDocument.body);
-            setInnerHTMLFromContent(id, text);
-        }
-        else
-        {
-            var html = loadedDocument.body.innerHTML;
-            setInnerHTMLFromContent(id, html);
-        }
-    });
-}
-
-function setPreformattedTextFromUri(id, uri)
-{
-    _asyncLoadContentFromUri(uri, function(loadedDocument) { setPreformattedTextFromContent(id, getTextContent(loadedDocument.body)); });
-}
-
-function setInnerHTMLFromHiddenData(id)
-{
-    var element = document.getElementById(id + '-hidden');
-    if (element)
-        setInnerHTMLFromContent(id, getTextContent(element));
-}
-
-function setPreformattedTextFromHiddenData(id)
-{
-    var element = document.getElementById(id + '-hidden');
-    if (element)
-        setPreformattedTextFromContent(id, getTextContent(element));
-}
-
-function setInnerHTMLFromContent(id, content)
-{
-    if (content != undefined)
-    {
-        var element = document.getElementById(id);
-        if (element)
-            element.innerHTML = content;
-    }
-}
-
-function setPreformattedTextFromContent(id, content)
-{
-    if (content != undefined)
-    {
-        var element = document.getElementById(id);
-        if (element)
-        {
-            element.innerHTML = "<pre></pre>";
-            setTextContent(element.children[0], content);
-        }
-    }
-}
-
-function getTextContent(element)
-{
-    return element.textContent != undefined ? element.textContent : element.innerText;
-}
-
-function setTextContent(element, content)
-{
-    if (element.textContent != undefined)
-        element.textContent = content;
-    else
-        element.innerText = content;
-}
-
-function setFrameLocation(frame, uri)
-{
-    if (frame.contentWindow)
-        frame.contentWindow.location.replace(uri);
-}
-
-function _asyncLoadContentFromUri(uri, callback)
-{
-    var asyncLoadFrame = document.getElementById('_asyncLoadFrame');
-
-    if (!asyncLoadFrame.pendingRequests)
-        asyncLoadFrame.pendingRequests = [];
-
-    asyncLoadFrame.pendingRequests.push({ uri: uri, callback: callback });
-
-    _asyncLoadFrameNext(asyncLoadFrame);
-}
-
-function _asyncLoadFrameOnLoad()
-{
-    var asyncLoadFrame = document.getElementById('_asyncLoadFrame');
-    if (asyncLoadFrame)
-    {
-        var request = asyncLoadFrame.currentRequest;
-        if (request)
-        {
-            asyncLoadFrame.currentRequest = undefined;
-
-            try
-            {
-                var loadedWindow = asyncLoadFrame.contentWindow;
-                if (loadedWindow && loadedWindow.location.href != "about:blank")
-                {
-                    var loadedDocument = loadedWindow.document;
-                    if (loadedDocument)
-                    {
-                        request.callback(loadedDocument);
-                    }
-                }
-            }
-            catch (ex)
-            {
-                //alert(ex.message);
-            }
-        }
-
-        _asyncLoadFrameNext(asyncLoadFrame);
-    }
-}
-
-function _asyncLoadFrameNext(asyncLoadFrame)
-{
-    while (!asyncLoadFrame.currentRequest && asyncLoadFrame.pendingRequests && asyncLoadFrame.pendingRequests.length > 0)
-    {
-        var request = asyncLoadFrame.pendingRequests.shift();
-        asyncLoadFrame.currentRequest = request;
-
-        try
-        {
-            setFrameLocation(asyncLoadFrame, request.uri);
-        }
-        catch (ex)
-        {
-            //alert(ex.message);
-        }
-    }
-}

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Resources/js/expressInstall.swf
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Resources/js/expressInstall.swf b/lib/Gallio.3.2.750/tools/Resources/js/expressInstall.swf
deleted file mode 100644
index 0fbf8fc..0000000
Binary files a/lib/Gallio.3.2.750/tools/Resources/js/expressInstall.swf and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Resources/js/player.swf
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Resources/js/player.swf b/lib/Gallio.3.2.750/tools/Resources/js/player.swf
deleted file mode 100644
index ec848da..0000000
Binary files a/lib/Gallio.3.2.750/tools/Resources/js/player.swf and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Resources/js/swfobject.js
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Resources/js/swfobject.js b/lib/Gallio.3.2.750/tools/Resources/js/swfobject.js
deleted file mode 100644
index 8eafe9d..0000000
--- a/lib/Gallio.3.2.750/tools/Resources/js/swfobject.js
+++ /dev/null
@@ -1,4 +0,0 @@
-/*	SWFObject v2.2 <http://code.google.com/p/swfobject/> 
-	is released under the MIT License <http://www.opensource.org/licenses/mit-license.php> 
-*/
-var swfobject=function(){var D="undefined",r="object",S="Shockwave Flash",W="ShockwaveFlash.ShockwaveFlash",q="application/x-shockwave-flash",R="SWFObjectExprInst",x="onreadystatechange",O=window,j=document,t=navigator,T=false,U=[h],o=[],N=[],I=[],l,Q,E,B,J=false,a=false,n,G,m=true,M=function(){var aa=typeof j.getElementById!=D&&typeof j.getElementsByTagName!=D&&typeof j.createElement!=D,ah=t.userAgent.toLowerCase(),Y=t.platform.toLowerCase(),ae=Y?/win/.test(Y):/win/.test(ah),ac=Y?/mac/.test(Y):/mac/.test(ah),af=/webkit/.test(ah)?parseFloat(ah.replace(/^.*webkit\/(\d+(\.\d+)?).*$/,"$1")):false,X=!+"\v1",ag=[0,0,0],ab=null;if(typeof t.plugins!=D&&typeof t.plugins[S]==r){ab=t.plugins[S].description;if(ab&&!(typeof t.mimeTypes!=D&&t.mimeTypes[q]&&!t.mimeTypes[q].enabledPlugin)){T=true;X=false;ab=ab.replace(/^.*\s+(\S+\s+\S+$)/,"$1");ag[0]=parseInt(ab.replace(/^(.*)\..*$/,"$1"),10);ag[1]=parseInt(ab.replace(/^.*\.(.*)\s.*$/,"$1"),10);ag[2]=/[a-zA-Z]/.test(ab)?parseInt(ab.replace(/^.*[a-
 zA-Z]+(.*)$/,"$1"),10):0}}else{if(typeof O.ActiveXObject!=D){try{var ad=new ActiveXObject(W);if(ad){ab=ad.GetVariable("$version");if(ab){X=true;ab=ab.split(" ")[1].split(",");ag=[parseInt(ab[0],10),parseInt(ab[1],10),parseInt(ab[2],10)]}}}catch(Z){}}}return{w3:aa,pv:ag,wk:af,ie:X,win:ae,mac:ac}}(),k=function(){if(!M.w3){return}if((typeof j.readyState!=D&&j.readyState=="complete")||(typeof j.readyState==D&&(j.getElementsByTagName("body")[0]||j.body))){f()}if(!J){if(typeof j.addEventListener!=D){j.addEventListener("DOMContentLoaded",f,false)}if(M.ie&&M.win){j.attachEvent(x,function(){if(j.readyState=="complete"){j.detachEvent(x,arguments.callee);f()}});if(O==top){(function(){if(J){return}try{j.documentElement.doScroll("left")}catch(X){setTimeout(arguments.callee,0);return}f()})()}}if(M.wk){(function(){if(J){return}if(!/loaded|complete/.test(j.readyState)){setTimeout(arguments.callee,0);return}f()})()}s(f)}}();function f(){if(J){return}try{var Z=j.getElementsByTagName("body")[0].append
 Child(C("span"));Z.parentNode.removeChild(Z)}catch(aa){return}J=true;var X=U.length;for(var Y=0;Y<X;Y++){U[Y]()}}function K(X){if(J){X()}else{U[U.length]=X}}function s(Y){if(typeof O.addEventListener!=D){O.addEventListener("load",Y,false)}else{if(typeof j.addEventListener!=D){j.addEventListener("load",Y,false)}else{if(typeof O.attachEvent!=D){i(O,"onload",Y)}else{if(typeof O.onload=="function"){var X=O.onload;O.onload=function(){X();Y()}}else{O.onload=Y}}}}}function h(){if(T){V()}else{H()}}function V(){var X=j.getElementsByTagName("body")[0];var aa=C(r);aa.setAttribute("type",q);var Z=X.appendChild(aa);if(Z){var Y=0;(function(){if(typeof Z.GetVariable!=D){var ab=Z.GetVariable("$version");if(ab){ab=ab.split(" ")[1].split(",");M.pv=[parseInt(ab[0],10),parseInt(ab[1],10),parseInt(ab[2],10)]}}else{if(Y<10){Y++;setTimeout(arguments.callee,10);return}}X.removeChild(aa);Z=null;H()})()}else{H()}}function H(){var ag=o.length;if(ag>0){for(var af=0;af<ag;af++){var Y=o[af].id;var ab=o[af].callb
 ackFn;var aa={success:false,id:Y};if(M.pv[0]>0){var ae=c(Y);if(ae){if(F(o[af].swfVersion)&&!(M.wk&&M.wk<312)){w(Y,true);if(ab){aa.success=true;aa.ref=z(Y);ab(aa)}}else{if(o[af].expressInstall&&A()){var ai={};ai.data=o[af].expressInstall;ai.width=ae.getAttribute("width")||"0";ai.height=ae.getAttribute("height")||"0";if(ae.getAttribute("class")){ai.styleclass=ae.getAttribute("class")}if(ae.getAttribute("align")){ai.align=ae.getAttribute("align")}var ah={};var X=ae.getElementsByTagName("param");var ac=X.length;for(var ad=0;ad<ac;ad++){if(X[ad].getAttribute("name").toLowerCase()!="movie"){ah[X[ad].getAttribute("name")]=X[ad].getAttribute("value")}}P(ai,ah,Y,ab)}else{p(ae);if(ab){ab(aa)}}}}}else{w(Y,true);if(ab){var Z=z(Y);if(Z&&typeof Z.SetVariable!=D){aa.success=true;aa.ref=Z}ab(aa)}}}}}function z(aa){var X=null;var Y=c(aa);if(Y&&Y.nodeName=="OBJECT"){if(typeof Y.SetVariable!=D){X=Y}else{var Z=Y.getElementsByTagName(r)[0];if(Z){X=Z}}}return X}function A(){return !a&&F("6.0.65")&&(M.win
 ||M.mac)&&!(M.wk&&M.wk<312)}function P(aa,ab,X,Z){a=true;E=Z||null;B={success:false,id:X};var ae=c(X);if(ae){if(ae.nodeName=="OBJECT"){l=g(ae);Q=null}else{l=ae;Q=X}aa.id=R;if(typeof aa.width==D||(!/%$/.test(aa.width)&&parseInt(aa.width,10)<310)){aa.width="310"}if(typeof aa.height==D||(!/%$/.test(aa.height)&&parseInt(aa.height,10)<137)){aa.height="137"}j.title=j.title.slice(0,47)+" - Flash Player Installation";var ad=M.ie&&M.win?"ActiveX":"PlugIn",ac="MMredirectURL="+O.location.toString().replace(/&/g,"%26")+"&MMplayerType="+ad+"&MMdoctitle="+j.title;if(typeof ab.flashvars!=D){ab.flashvars+="&"+ac}else{ab.flashvars=ac}if(M.ie&&M.win&&ae.readyState!=4){var Y=C("div");X+="SWFObjectNew";Y.setAttribute("id",X);ae.parentNode.insertBefore(Y,ae);ae.style.display="none";(function(){if(ae.readyState==4){ae.parentNode.removeChild(ae)}else{setTimeout(arguments.callee,10)}})()}u(aa,ab,X)}}function p(Y){if(M.ie&&M.win&&Y.readyState!=4){var X=C("div");Y.parentNode.insertBefore(X,Y);X.parentNode.re
 placeChild(g(Y),X);Y.style.display="none";(function(){if(Y.readyState==4){Y.parentNode.removeChild(Y)}else{setTimeout(arguments.callee,10)}})()}else{Y.parentNode.replaceChild(g(Y),Y)}}function g(ab){var aa=C("div");if(M.win&&M.ie){aa.innerHTML=ab.innerHTML}else{var Y=ab.getElementsByTagName(r)[0];if(Y){var ad=Y.childNodes;if(ad){var X=ad.length;for(var Z=0;Z<X;Z++){if(!(ad[Z].nodeType==1&&ad[Z].nodeName=="PARAM")&&!(ad[Z].nodeType==8)){aa.appendChild(ad[Z].cloneNode(true))}}}}}return aa}function u(ai,ag,Y){var X,aa=c(Y);if(M.wk&&M.wk<312){return X}if(aa){if(typeof ai.id==D){ai.id=Y}if(M.ie&&M.win){var ah="";for(var ae in ai){if(ai[ae]!=Object.prototype[ae]){if(ae.toLowerCase()=="data"){ag.movie=ai[ae]}else{if(ae.toLowerCase()=="styleclass"){ah+=' class="'+ai[ae]+'"'}else{if(ae.toLowerCase()!="classid"){ah+=" "+ae+'="'+ai[ae]+'"'}}}}}var af="";for(var ad in ag){if(ag[ad]!=Object.prototype[ad]){af+='<param name="'+ad+'" value="'+ag[ad]+'" />'}}aa.outerHTML='<object classid="clsid:D27C
 DB6E-AE6D-11cf-96B8-444553540000"'+ah+">"+af+"</object>";N[N.length]=ai.id;X=c(ai.id)}else{var Z=C(r);Z.setAttribute("type",q);for(var ac in ai){if(ai[ac]!=Object.prototype[ac]){if(ac.toLowerCase()=="styleclass"){Z.setAttribute("class",ai[ac])}else{if(ac.toLowerCase()!="classid"){Z.setAttribute(ac,ai[ac])}}}}for(var ab in ag){if(ag[ab]!=Object.prototype[ab]&&ab.toLowerCase()!="movie"){e(Z,ab,ag[ab])}}aa.parentNode.replaceChild(Z,aa);X=Z}}return X}function e(Z,X,Y){var aa=C("param");aa.setAttribute("name",X);aa.setAttribute("value",Y);Z.appendChild(aa)}function y(Y){var X=c(Y);if(X&&X.nodeName=="OBJECT"){if(M.ie&&M.win){X.style.display="none";(function(){if(X.readyState==4){b(Y)}else{setTimeout(arguments.callee,10)}})()}else{X.parentNode.removeChild(X)}}}function b(Z){var Y=c(Z);if(Y){for(var X in Y){if(typeof Y[X]=="function"){Y[X]=null}}Y.parentNode.removeChild(Y)}}function c(Z){var X=null;try{X=j.getElementById(Z)}catch(Y){}return X}function C(X){return j.createElement(X)}function
  i(Z,X,Y){Z.attachEvent(X,Y);I[I.length]=[Z,X,Y]}function F(Z){var Y=M.pv,X=Z.split(".");X[0]=parseInt(X[0],10);X[1]=parseInt(X[1],10)||0;X[2]=parseInt(X[2],10)||0;return(Y[0]>X[0]||(Y[0]==X[0]&&Y[1]>X[1])||(Y[0]==X[0]&&Y[1]==X[1]&&Y[2]>=X[2]))?true:false}function v(ac,Y,ad,ab){if(M.ie&&M.mac){return}var aa=j.getElementsByTagName("head")[0];if(!aa){return}var X=(ad&&typeof ad=="string")?ad:"screen";if(ab){n=null;G=null}if(!n||G!=X){var Z=C("style");Z.setAttribute("type","text/css");Z.setAttribute("media",X);n=aa.appendChild(Z);if(M.ie&&M.win&&typeof j.styleSheets!=D&&j.styleSheets.length>0){n=j.styleSheets[j.styleSheets.length-1]}G=X}if(M.ie&&M.win){if(n&&typeof n.addRule==r){n.addRule(ac,Y)}}else{if(n&&typeof j.createTextNode!=D){n.appendChild(j.createTextNode(ac+" {"+Y+"}"))}}}function w(Z,X){if(!m){return}var Y=X?"visible":"hidden";if(J&&c(Z)){c(Z).style.visibility=Y}else{v("#"+Z,"visibility:"+Y)}}function L(Y){var Z=/[\\\"<>\.;]/;var X=Z.exec(Y)!=null;return X&&typeof encodeURIC
 omponent!=D?encodeURIComponent(Y):Y}var d=function(){if(M.ie&&M.win){window.attachEvent("onunload",function(){var ac=I.length;for(var ab=0;ab<ac;ab++){I[ab][0].detachEvent(I[ab][1],I[ab][2])}var Z=N.length;for(var aa=0;aa<Z;aa++){y(N[aa])}for(var Y in M){M[Y]=null}M=null;for(var X in swfobject){swfobject[X]=null}swfobject=null})}}();return{registerObject:function(ab,X,aa,Z){if(M.w3&&ab&&X){var Y={};Y.id=ab;Y.swfVersion=X;Y.expressInstall=aa;Y.callbackFn=Z;o[o.length]=Y;w(ab,false)}else{if(Z){Z({success:false,id:ab})}}},getObjectById:function(X){if(M.w3){return z(X)}},embedSWF:function(ab,ah,ae,ag,Y,aa,Z,ad,af,ac){var X={success:false,id:ah};if(M.w3&&!(M.wk&&M.wk<312)&&ab&&ah&&ae&&ag&&Y){w(ah,false);K(function(){ae+="";ag+="";var aj={};if(af&&typeof af===r){for(var al in af){aj[al]=af[al]}}aj.data=ab;aj.width=ae;aj.height=ag;var am={};if(ad&&typeof ad===r){for(var ak in ad){am[ak]=ad[ak]}}if(Z&&typeof Z===r){for(var ai in Z){if(typeof am.flashvars!=D){am.flashvars+="&"+ai+"="+Z[ai]}e
 lse{am.flashvars=ai+"="+Z[ai]}}}if(F(Y)){var an=u(aj,am,ah);if(aj.id==ah){w(ah,true)}X.success=true;X.ref=an}else{if(aa&&A()){aj.data=aa;P(aj,am,ah,ac);return}else{w(ah,true)}}if(ac){ac(X)}})}else{if(ac){ac(X)}}},switchOffAutoHideShow:function(){m=false},ua:M,getFlashPlayerVersion:function(){return{major:M.pv[0],minor:M.pv[1],release:M.pv[2]}},hasFlashPlayerVersion:F,createSWF:function(Z,Y,X){if(M.w3){return u(Z,Y,X)}else{return undefined}},showExpressInstall:function(Z,aa,X,Y){if(M.w3&&A()){P(Z,aa,X,Y)}},removeSWF:function(X){if(M.w3){y(X)}},createCSS:function(aa,Z,Y,X){if(M.w3){v(aa,Z,Y,X)}},addDomLoadEvent:K,addLoadEvent:s,getQueryParamValue:function(aa){var Z=j.location.search||j.location.hash;if(Z){if(/\?/.test(Z)){Z=Z.split("?")[1]}if(aa==null){return L(Z)}var Y=Z.split("&");for(var X=0;X<Y.length;X++){if(Y[X].substring(0,Y[X].indexOf("="))==aa){return L(Y[X].substring((Y[X].indexOf("=")+1)))}}}return""},expressInstallCallback:function(){if(a){var X=c(R);if(X&&l){X.parentNode.
 replaceChild(l,X);if(Q){w(Q,true);if(M.ie&&M.win){l.style.display="block"}}if(E){E(B)}}a=false}}}}();
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Resources/xsl/Gallio-Report.ccnet-details-condensed.xsl
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Resources/xsl/Gallio-Report.ccnet-details-condensed.xsl b/lib/Gallio.3.2.750/tools/Resources/xsl/Gallio-Report.ccnet-details-condensed.xsl
deleted file mode 100644
index 3d1fd81..0000000
--- a/lib/Gallio.3.2.750/tools/Resources/xsl/Gallio-Report.ccnet-details-condensed.xsl
+++ /dev/null
@@ -1,20 +0,0 @@
-<?xml version="1.0" encoding="iso-8859-1"?>
-<xsl:stylesheet version="1.0"
-                xmlns:xsl="http://www.w3.org/1999/XSL/Transform"
-                xmlns:g="http://www.gallio.org/">
-  <xsl:output method="html" indent="no" encoding="utf-8" omit-xml-declaration="yes" />
-  <xsl:param name="resourceRoot" select="''" />
-
-  <xsl:variable name="cssDir">/gallio/css/</xsl:variable>
-  <xsl:variable name="jsDir">/gallio/js/</xsl:variable>
-  <xsl:variable name="imgDir">/gallio/img/</xsl:variable>
-  <xsl:variable name="attachmentBrokerUrl">GallioAttachment.aspx?</xsl:variable>
-  <xsl:variable name="condensed" select="1" />
-
-  <xsl:template match="/">
-    <xsl:apply-templates select="//g:report" mode="html-fragment" />
-  </xsl:template>
-  
-  <!-- Include the base HTML / XHTML report template -->
-  <xsl:include href="Gallio-Report.html+xhtml.xsl" />  
-</xsl:stylesheet>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Resources/xsl/Gallio-Report.ccnet-details.xsl
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Resources/xsl/Gallio-Report.ccnet-details.xsl b/lib/Gallio.3.2.750/tools/Resources/xsl/Gallio-Report.ccnet-details.xsl
deleted file mode 100644
index 0a6baf3..0000000
--- a/lib/Gallio.3.2.750/tools/Resources/xsl/Gallio-Report.ccnet-details.xsl
+++ /dev/null
@@ -1,20 +0,0 @@
-<?xml version="1.0" encoding="iso-8859-1"?>
-<xsl:stylesheet version="1.0"
-                xmlns:xsl="http://www.w3.org/1999/XSL/Transform"
-                xmlns:g="http://www.gallio.org/">
-  <xsl:output method="html" indent="no" encoding="utf-8" omit-xml-declaration="yes" />
-  <xsl:param name="resourceRoot" select="''" />
-
-  <xsl:variable name="cssDir">/gallio/css/</xsl:variable>
-  <xsl:variable name="jsDir">/gallio/js/</xsl:variable>
-  <xsl:variable name="imgDir">/gallio/img/</xsl:variable>
-  <xsl:variable name="attachmentBrokerUrl">GallioAttachment.aspx?</xsl:variable>
-  <xsl:variable name="condensed" select="0" />
-
-  <xsl:template match="/">
-    <xsl:apply-templates select="//g:report" mode="html-fragment" />
-  </xsl:template>
-  
-  <!-- Include the base HTML / XHTML report template -->
-  <xsl:include href="Gallio-Report.html+xhtml.xsl" />  
-</xsl:stylesheet>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Resources/xsl/Gallio-Report.common.xsl
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Resources/xsl/Gallio-Report.common.xsl b/lib/Gallio.3.2.750/tools/Resources/xsl/Gallio-Report.common.xsl
deleted file mode 100644
index 54ef14b..0000000
--- a/lib/Gallio.3.2.750/tools/Resources/xsl/Gallio-Report.common.xsl
+++ /dev/null
@@ -1,356 +0,0 @@
-<?xml version="1.0" encoding="utf-8"?>
-<xsl:stylesheet version="1.0"
-                xmlns:xsl="http://www.w3.org/1999/XSL/Transform"
-                xmlns:msxsl="urn:schemas-microsoft-com:xslt"
-                xmlns:g="http://www.gallio.org/"
-                xmlns="http://www.w3.org/1999/xhtml">
-  <!-- Common utility functions -->
-  
-  <!-- Formats a statistics line like 5 run, 3 passed, 2 failed (1 error), 0 inconclusive, 2 skipped -->
-  <xsl:template name="format-statistics">
-    <xsl:param name="statistics" />
-       
-		<xsl:value-of select="$statistics/@runCount"/>    
-    <xsl:text> run, </xsl:text>
-    
-    <xsl:value-of select="$statistics/@passedCount"/>
-    <xsl:text> passed</xsl:text>
-    <xsl:call-template name="format-statistics-category-counts">
-      <xsl:with-param name="statistics" select="$statistics" />
-      <xsl:with-param name="status">passed</xsl:with-param>
-    </xsl:call-template>
-    <xsl:text>, </xsl:text>
-    
-    <xsl:value-of select="$statistics/@failedCount"/>
-    <xsl:text> failed</xsl:text>
-    <xsl:call-template name="format-statistics-category-counts">
-      <xsl:with-param name="statistics" select="$statistics" />
-      <xsl:with-param name="status">failed</xsl:with-param>
-    </xsl:call-template>
-    <xsl:text>, </xsl:text>
-
-    <xsl:value-of select="$statistics/@inconclusiveCount"/>
-    <xsl:text> inconclusive</xsl:text>
-    <xsl:call-template name="format-statistics-category-counts">
-      <xsl:with-param name="statistics" select="$statistics" />
-      <xsl:with-param name="status">inconclusive</xsl:with-param>
-    </xsl:call-template>
-    <xsl:text>, </xsl:text>
-    
-    <xsl:value-of select="$statistics/@skippedCount"/>
-    <xsl:text> skipped</xsl:text>
-    <xsl:call-template name="format-statistics-category-counts">
-      <xsl:with-param name="statistics" select="$statistics" />
-      <xsl:with-param name="status">skipped</xsl:with-param>
-    </xsl:call-template>
-  </xsl:template>
-  
-  <xsl:template name="format-statistics-category-counts">
-    <xsl:param name="statistics" />
-    <xsl:param name="status" />
-    
-    <xsl:variable name="outcomeSummaries" select="$statistics/g:outcomeSummaries/g:outcomeSummary[g:outcome/@status=$status and g:outcome/@category]" />
-    
-    <xsl:if test="$outcomeSummaries">
-      <xsl:text> (</xsl:text>
-        <xsl:for-each select="$outcomeSummaries">
-          <xsl:sort data-type="text" order="ascending" select="g:outcome/@category"/>
-          
-          <xsl:if test="position() != 1"><xsl:text>, </xsl:text></xsl:if>
-          <xsl:value-of select="@count"/>
-          <xsl:text> </xsl:text>
-          <xsl:value-of select="g:outcome/@category"/>
-        </xsl:for-each>
-      <xsl:text>)</xsl:text>
-    </xsl:if>
-  </xsl:template>
-  
-  <!-- Formats a CodeLocation -->
-  <xsl:template name="format-code-location">
-    <xsl:param name="codeLocation" />
-    
-    <xsl:choose>
-      <xsl:when test="$codeLocation/@path">
-        <xsl:value-of select="$codeLocation/@path"/>
-        <xsl:if test="$codeLocation/@line">
-          <xsl:text>(</xsl:text>
-          <xsl:value-of select="$codeLocation/@line"/>
-          <xsl:if test="$codeLocation/@column">
-            <xsl:text>,</xsl:text>
-            <xsl:value-of select="$codeLocation/@column"/>
-          </xsl:if>
-          <xsl:text>)</xsl:text>
-        </xsl:if>
-      </xsl:when>
-      <xsl:otherwise>
-        <xsl:text>(unknown)</xsl:text>
-      </xsl:otherwise>
-    </xsl:choose>
-  </xsl:template>
-
-  <!-- Formats a CodeReference -->
-  <xsl:template name="format-code-reference">
-    <xsl:param name="codeReference" />
-    
-    <xsl:if test="$codeReference/@parameter">
-      <xsl:text>Parameter </xsl:text>
-      <xsl:value-of select="$codeReference/@parameter"/>
-      <xsl:text> of </xsl:text>
-    </xsl:if>
-    
-    <xsl:choose>
-      <xsl:when test="$codeReference/@type">
-        <xsl:value-of select="$codeReference/@type"/>
-        <xsl:if test="$codeReference/@member">
-          <xsl:text>.</xsl:text>
-          <xsl:value-of select="$codeReference/@member"/>
-        </xsl:if>
-      </xsl:when>
-      <xsl:when test="$codeReference/@namespace">
-        <xsl:value-of select="$codeReference/@namespace"/>
-      </xsl:when>
-    </xsl:choose>
-    
-    <xsl:if test="$codeReference/@assembly">
-      <xsl:if test="$codeReference/@namespace">
-        <xsl:text>, </xsl:text>
-      </xsl:if>
-      <xsl:value-of select="$codeReference/@assembly"/>
-    </xsl:if>
-  </xsl:template>
-  
-  <!-- Creates an aggregate statistics summary from a test instance run and its descendants -->
-  <xsl:template name="aggregate-statistics">
-    <xsl:param name="testStepRun" />
-
-    <xsl:variable name="testCaseResults" select="$testStepRun/descendant-or-self::g:testStepRun[g:testStep/@isTestCase='true']/g:result" />
-    <xsl:variable name="testCaseOutcomes" select="$testCaseResults/g:outcome" />
-    
-    <xsl:variable name="skippedOutcomes" select="$testCaseOutcomes[@status = 'skipped']" />
-    <xsl:variable name="passedOutcomes" select="$testCaseOutcomes[@status = 'passed']" />
-    <xsl:variable name="inconclusiveOutcomes" select="$testCaseOutcomes[@status = 'inconclusive']" />
-    <xsl:variable name="failedOutcomes" select="$testCaseOutcomes[@status = 'failed']" />
-    
-    <xsl:variable name="skippedCount" select="count($skippedOutcomes)"/>
-    <xsl:variable name="passedCount" select="count($passedOutcomes)"/>
-    <xsl:variable name="inconclusiveCount" select="count($inconclusiveOutcomes)"/>
-    <xsl:variable name="failedCount" select="count($failedOutcomes)"/>
-
-    <g:statistics>
-      <xsl:attribute name="duration"><xsl:value-of select="$testStepRun/g:result/@duration"/></xsl:attribute>
-      <xsl:attribute name="assertCount"><xsl:value-of select="$testStepRun/g:result/@assertCount"/></xsl:attribute>
-      
-      <xsl:attribute name="skippedCount"><xsl:value-of select="$skippedCount"/></xsl:attribute>
-      <xsl:attribute name="passedCount"><xsl:value-of select="$passedCount"/></xsl:attribute>
-      <xsl:attribute name="inconclusiveCount"><xsl:value-of select="$inconclusiveCount"/></xsl:attribute>
-      <xsl:attribute name="failedCount"><xsl:value-of select="$failedCount"/></xsl:attribute>
-      
-      <xsl:attribute name="runCount"><xsl:value-of select="$passedCount + $inconclusiveCount + $failedCount"/></xsl:attribute>
-      
-      <g:outcomeSummaries>
-        <xsl:call-template name="aggregate-statistics-outcome-summaries">
-          <xsl:with-param name="status">skipped</xsl:with-param>
-          <xsl:with-param name="outcomes" select="$skippedOutcomes" />
-        </xsl:call-template>
-        <xsl:call-template name="aggregate-statistics-outcome-summaries">
-          <xsl:with-param name="status">passed</xsl:with-param>
-          <xsl:with-param name="outcomes" select="$passedOutcomes" />
-        </xsl:call-template>
-        <xsl:call-template name="aggregate-statistics-outcome-summaries">
-          <xsl:with-param name="status">inconclusive</xsl:with-param>
-          <xsl:with-param name="outcomes" select="$inconclusiveOutcomes" />
-        </xsl:call-template>
-        <xsl:call-template name="aggregate-statistics-outcome-summaries">
-          <xsl:with-param name="status">failed</xsl:with-param>
-          <xsl:with-param name="outcomes" select="$failedOutcomes" />
-        </xsl:call-template>
-      </g:outcomeSummaries>
-    </g:statistics>
-  </xsl:template>
-  
-  <xsl:key name="outcome-category" match="g:outcome" use="@category" />
-  <xsl:template name="aggregate-statistics-outcome-summaries">
-    <xsl:param name="status" />
-    <xsl:param name="outcomes" />
-    
-    <xsl:for-each select="$outcomes[generate-id() = generate-id(key('outcome-category', @category)[1])]">
-      <xsl:variable name="category" select="@category" />
-      <g:outcomeSummary count="{count($outcomes[@category = $category])}">
-        <g:outcome status="{$status}" category="{$category}" />
-      </g:outcomeSummary>
-    </xsl:for-each>
-  </xsl:template>
-  
-  <!-- Indents text using the specified prefix -->
-  <xsl:template name="indent">
-    <xsl:param name="text" />
-    <xsl:param name="firstLinePrefix" select="'  '" />
-    <xsl:param name="otherLinePrefix" select="'  '" />
-    <xsl:param name="trailingNewline" select="1" />
-
-    <xsl:if test="$text!=''">
-      <xsl:call-template name="indent-recursive">
-        <xsl:with-param name="text" select="translate($text, '&#9;&#xA;&#xD;', ' &#xA;')" />
-        <xsl:with-param name="firstLinePrefix" select="$firstLinePrefix" />
-        <xsl:with-param name="otherLinePrefix" select="$otherLinePrefix" />
-        <xsl:with-param name="trailingNewline" select="$trailingNewline" />
-      </xsl:call-template>
-    </xsl:if>
-  </xsl:template>
-
-  <xsl:template name="indent-recursive">
-    <xsl:param name="text" />
-    <xsl:param name="firstLinePrefix" />
-    <xsl:param name="otherLinePrefix" />
-    <xsl:param name="trailingNewline" />
-
-    <xsl:choose>
-      <xsl:when test="contains($text, '&#xA;')">
-        <xsl:value-of select="$firstLinePrefix"/>
-        <xsl:value-of select="substring-before($text, '&#xA;')"/>
-        <xsl:text>&#xA;</xsl:text>
-        <xsl:call-template name="indent-recursive">
-          <xsl:with-param name="text" select="substring-after($text, '&#xA;')" />
-          <xsl:with-param name="firstLinePrefix" select="$otherLinePrefix" />
-          <xsl:with-param name="otherLinePrefix" select="$otherLinePrefix" />
-          <xsl:with-param name="trailingNewline" select="$trailingNewline" />
-        </xsl:call-template>
-      </xsl:when>
-      <!-- Note: when we are not adding a trailing new line, we must be careful
-           to include the leading prefix space even when the text line is empty
-           because subsequently appended text will assume that the current
-           line is already indented appropriately -->
-      <xsl:when test="$text!='' or not($trailingNewline)">
-        <xsl:value-of select="$firstLinePrefix"/>
-        <xsl:value-of select="$text"/>
-        <xsl:if test="$trailingNewline">
-          <xsl:text>&#xA;</xsl:text>
-        </xsl:if>
-      </xsl:when>
-    </xsl:choose>
-  </xsl:template>
-
-  <!-- Prints text with <br/> at line breaks.
-       Also introduces <wbr/> word break characters every so often if no natural breakpoints appear.
-       Some of the soft breaks are useful, but the forced break at 20 chars is intended to work around
-       limitations in browsers that do not support the word-wrap:break-all CSS3 property.
-  -->
-  <xsl:template name="print-text-with-breaks">
-    <xsl:param name="text" />
-    <xsl:param name="count" select="0" />
-    
-    <xsl:if test="$text">
-      <xsl:variable name="char" select="substring($text, 1, 1)"/>
-      
-      <xsl:choose>
-        <!-- natural word breaks -->
-        <xsl:when test="$char = ' '">
-          <!-- Always replace spaces by non-breaking spaces followed by word-breaks to ensure that
-               text can reflow without actually consuming the space.  Without this detail
-               it can happen that spaces that are supposed to be highligted (perhaps as part
-               of a marker for a diff) will instead vanish when the text reflow occurs, giving
-               a false impression of the content. -->
-          <xsl:text>&#160;</xsl:text>
-          <wbr/>
-          <xsl:call-template name="print-text-with-breaks">
-            <xsl:with-param name="text" select="substring($text, 2)" />
-            <xsl:with-param name="count" select="0" />
-          </xsl:call-template>
-        </xsl:when>
-
-        <!-- line breaks -->
-        <xsl:when test="$char = '&#10;'">
-          <br/>
-          <xsl:call-template name="print-text-with-breaks">
-            <xsl:with-param name="text" select="substring($text, 2)" />
-            <xsl:with-param name="count" select="0" />
-          </xsl:call-template>
-        </xsl:when>
-        
-        <!-- characters to break before -->
-        <xsl:when test="$char = '.' or $char = '/' or $char = '\' or $char = ':' or $char = '(' or $char = '&lt;' or $char = '[' or $char = '{' or $char = '_'">
-          <wbr/>
-          <xsl:value-of select="$char"/>
-          <xsl:call-template name="print-text-with-breaks">
-            <xsl:with-param name="text" select="substring($text, 2)" />
-            <xsl:with-param name="count" select="1" />
-          </xsl:call-template>
-        </xsl:when>
-        
-        <!-- characters to break after -->
-        <xsl:when test="$char = ')' or $char = '>' or $char = ']' or $char = '}'">
-          <xsl:value-of select="$char"/>
-          <wbr/>
-          <xsl:call-template name="print-text-with-breaks">
-            <xsl:with-param name="text" select="substring($text, 2)" />
-            <xsl:with-param name="count" select="0" />
-          </xsl:call-template>
-        </xsl:when>
-        
-        <!-- other characters -->
-        <xsl:when test="$count = 19">
-          <xsl:value-of select="$char"/>
-          <wbr/>
-          <xsl:call-template name="print-text-with-breaks">
-            <xsl:with-param name="text" select="substring($text, 2)" />
-            <xsl:with-param name="count" select="0" />
-          </xsl:call-template>
-        </xsl:when>
-        
-        <xsl:otherwise>
-          <xsl:value-of select="$char"/>
-          <xsl:call-template name="print-text-with-breaks">
-            <xsl:with-param name="text" select="substring($text, 2)" />
-            <xsl:with-param name="count" select="$count + 1" />
-          </xsl:call-template>
-        </xsl:otherwise>
-      </xsl:choose>
-    </xsl:if>
-  </xsl:template>
-  
-  <!-- Pretty print date time values -->
-  <xsl:template name="format-datetime">
-    <xsl:param name="datetime" />
-    <xsl:value-of select="substring($datetime, 12, 8)" />, <xsl:value-of select="substring($datetime, 1, 10)" />
-  </xsl:template>
-  
-  <!-- Namespace stripping adapted from http://www.xml.com/pub/a/2004/05/05/tr.html -->
-  <xsl:template name="strip-namespace">
-    <xsl:param name="nodes" />
-    <xsl:apply-templates select="msxsl:node-set($nodes)" mode="strip-namespace" />
-  </xsl:template>
-  
-  <xsl:template match="*" mode="strip-namespace">
-    <xsl:element name="{local-name()}" namespace="">
-      <xsl:apply-templates select="@*|node()" mode="strip-namespace"/>
-    </xsl:element>
-  </xsl:template>
-
-  <xsl:template match="@*" mode="strip-namespace">
-    <xsl:attribute name="{local-name()}" namespace="">
-      <xsl:value-of select="."/>
-    </xsl:attribute>
-  </xsl:template>
-
-  <xsl:template match="processing-instruction()|comment()" mode="strip-namespace">
-    <xsl:copy>
-      <xsl:apply-templates select="node()" mode="strip-namespace"/>
-    </xsl:copy>
-  </xsl:template>  
-  
-  <!-- Converting paths to URIs -->
-  <xsl:template name="path-to-uri">
-    <xsl:param name="path" />    
-    <xsl:if test="$path != ''">
-      <xsl:choose>
-        <xsl:when test="starts-with($path, '\')">/</xsl:when>
-        <xsl:when test="starts-with($path, ' ')">%20</xsl:when>
-        <xsl:when test="starts-with($path, '%')">%25</xsl:when>
-        <xsl:otherwise><xsl:value-of select="substring($path, 1, 1)"/></xsl:otherwise>
-      </xsl:choose>
-      <xsl:call-template name="path-to-uri">
-        <xsl:with-param name="path" select="substring($path, 2)" />
-      </xsl:call-template>
-    </xsl:if>
-  </xsl:template>
-</xsl:stylesheet>


[46/51] [abbrv] [partial] Cleaning up and getting ready to development towards v4.8

Posted by sy...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/vs2010/contrib/Contrib.All.sln
----------------------------------------------------------------------
diff --git a/build/vs2010/contrib/Contrib.All.sln b/build/vs2010/contrib/Contrib.All.sln
deleted file mode 100644
index 97f5cab..0000000
--- a/build/vs2010/contrib/Contrib.All.sln
+++ /dev/null
@@ -1,186 +0,0 @@
-
-Microsoft Visual Studio Solution File, Format Version 11.00
-# Visual C# Express 2010
-#
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-#
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net", "..\..\..\src\core\Lucene.Net.csproj", "{5D4AD9BE-1FFB-41AB-9943-25737971BF57}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Core", "..\..\..\src\contrib\Core\Contrib.Core.csproj", "{FEF899EB-610C-4D3C-A556-A01F56F4AFE0}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Analyzers", "..\..\..\src\contrib\Analyzers\Contrib.Analyzers.csproj", "{4286E961-9143-4821-B46D-3D39D3736386}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.FastVectorHighlighter", "..\..\..\src\contrib\FastVectorHighlighter\Contrib.FastVectorHighlighter.csproj", "{9D2E3153-076F-49C5-B83D-FB2573536B5F}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Highlighter", "..\..\..\src\contrib\Highlighter\Contrib.Highlighter.csproj", "{901D5415-383C-4AA6-A256-879558841BEA}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Queries", "..\..\..\src\contrib\Queries\Contrib.Queries.csproj", "{481CF6E3-52AF-4621-9DEB-022122079AF6}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Snowball", "..\..\..\src\contrib\Snowball\Contrib.Snowball.csproj", "{8F9D7A92-F122-413E-9D8D-027E4ECD327C}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Spatial", "..\..\..\src\contrib\Spatial\Contrib.Spatial.csproj", "{35C347F4-24B2-4BE5-8117-A0E3001551CE}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.SpellChecker", "..\..\..\src\contrib\SpellChecker\Contrib.SpellChecker.csproj", "{FF45EE91-9CA3-443D-8231-75E9FA1AF40E}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.WordNet.SynExpand", "..\..\..\src\contrib\WordNet\SynExpand\Contrib.WordNet.SynExpand.csproj", "{1407C9BA-337C-4C6C-B065-68328D3871B3}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.WordNet.SynLookup", "..\..\..\src\contrib\WordNet\SynLookup\Contrib.WordNet.SynLookup.csproj", "{2CA12E3F-76E1-4FA6-9E87-37079A7B7C69}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.WordNet.Syns2Index", "..\..\..\src\contrib\WordNet\Syns2Index\Contrib.WordNet.Syns2Index.csproj", "{7563D4D9-AE91-42BA-A270-1D264660F6DF}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Regex", "..\..\..\src\contrib\Regex\Contrib.Regex.csproj", "{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "SimpleFacetedSearch", "..\..\..\src\contrib\SimpleFacetedSearch\SimpleFacetedSearch.csproj", "{66772190-FB3F-48F5-8E05-0B302BACEA73}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Memory", "..\..\..\src\contrib\Memory\Contrib.Memory.csproj", "{112B9A7C-29CC-4539-8F5A-45669C07CD4D}"
-EndProject
-Global
-	GlobalSection(SolutionConfigurationPlatforms) = preSolution
-		Debug35|Any CPU = Debug35|Any CPU
-		Debug|Any CPU = Debug|Any CPU
-		Release35|Any CPU = Release35|Any CPU
-		Release|Any CPU = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(ProjectConfigurationPlatforms) = postSolution
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Release|Any CPU.Build.0 = Release|Any CPU
-		{1407C9BA-337C-4C6C-B065-68328D3871B3}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{1407C9BA-337C-4C6C-B065-68328D3871B3}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{1407C9BA-337C-4C6C-B065-68328D3871B3}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{1407C9BA-337C-4C6C-B065-68328D3871B3}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{1407C9BA-337C-4C6C-B065-68328D3871B3}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{1407C9BA-337C-4C6C-B065-68328D3871B3}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{1407C9BA-337C-4C6C-B065-68328D3871B3}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{1407C9BA-337C-4C6C-B065-68328D3871B3}.Release|Any CPU.Build.0 = Release|Any CPU
-		{2CA12E3F-76E1-4FA6-9E87-37079A7B7C69}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{2CA12E3F-76E1-4FA6-9E87-37079A7B7C69}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{2CA12E3F-76E1-4FA6-9E87-37079A7B7C69}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{2CA12E3F-76E1-4FA6-9E87-37079A7B7C69}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{2CA12E3F-76E1-4FA6-9E87-37079A7B7C69}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{2CA12E3F-76E1-4FA6-9E87-37079A7B7C69}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{2CA12E3F-76E1-4FA6-9E87-37079A7B7C69}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{2CA12E3F-76E1-4FA6-9E87-37079A7B7C69}.Release|Any CPU.Build.0 = Release|Any CPU
-		{35C347F4-24B2-4BE5-8117-A0E3001551CE}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{35C347F4-24B2-4BE5-8117-A0E3001551CE}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{35C347F4-24B2-4BE5-8117-A0E3001551CE}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{35C347F4-24B2-4BE5-8117-A0E3001551CE}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{35C347F4-24B2-4BE5-8117-A0E3001551CE}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{35C347F4-24B2-4BE5-8117-A0E3001551CE}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{35C347F4-24B2-4BE5-8117-A0E3001551CE}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{35C347F4-24B2-4BE5-8117-A0E3001551CE}.Release|Any CPU.Build.0 = Release|Any CPU
-		{4286E961-9143-4821-B46D-3D39D3736386}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{4286E961-9143-4821-B46D-3D39D3736386}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{4286E961-9143-4821-B46D-3D39D3736386}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{4286E961-9143-4821-B46D-3D39D3736386}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{4286E961-9143-4821-B46D-3D39D3736386}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{4286E961-9143-4821-B46D-3D39D3736386}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{4286E961-9143-4821-B46D-3D39D3736386}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{4286E961-9143-4821-B46D-3D39D3736386}.Release|Any CPU.Build.0 = Release|Any CPU
-		{481CF6E3-52AF-4621-9DEB-022122079AF6}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{481CF6E3-52AF-4621-9DEB-022122079AF6}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{481CF6E3-52AF-4621-9DEB-022122079AF6}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{481CF6E3-52AF-4621-9DEB-022122079AF6}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{481CF6E3-52AF-4621-9DEB-022122079AF6}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{481CF6E3-52AF-4621-9DEB-022122079AF6}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{481CF6E3-52AF-4621-9DEB-022122079AF6}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{481CF6E3-52AF-4621-9DEB-022122079AF6}.Release|Any CPU.Build.0 = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.Build.0 = Release|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Release|Any CPU.Build.0 = Release|Any CPU
-		{7563D4D9-AE91-42BA-A270-1D264660F6DF}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{7563D4D9-AE91-42BA-A270-1D264660F6DF}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{7563D4D9-AE91-42BA-A270-1D264660F6DF}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{7563D4D9-AE91-42BA-A270-1D264660F6DF}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{7563D4D9-AE91-42BA-A270-1D264660F6DF}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{7563D4D9-AE91-42BA-A270-1D264660F6DF}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{7563D4D9-AE91-42BA-A270-1D264660F6DF}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{7563D4D9-AE91-42BA-A270-1D264660F6DF}.Release|Any CPU.Build.0 = Release|Any CPU
-		{8F9D7A92-F122-413E-9D8D-027E4ECD327C}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{8F9D7A92-F122-413E-9D8D-027E4ECD327C}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{8F9D7A92-F122-413E-9D8D-027E4ECD327C}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{8F9D7A92-F122-413E-9D8D-027E4ECD327C}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{8F9D7A92-F122-413E-9D8D-027E4ECD327C}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{8F9D7A92-F122-413E-9D8D-027E4ECD327C}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{8F9D7A92-F122-413E-9D8D-027E4ECD327C}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{8F9D7A92-F122-413E-9D8D-027E4ECD327C}.Release|Any CPU.Build.0 = Release|Any CPU
-		{901D5415-383C-4AA6-A256-879558841BEA}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{901D5415-383C-4AA6-A256-879558841BEA}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{901D5415-383C-4AA6-A256-879558841BEA}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{901D5415-383C-4AA6-A256-879558841BEA}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{901D5415-383C-4AA6-A256-879558841BEA}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{901D5415-383C-4AA6-A256-879558841BEA}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{901D5415-383C-4AA6-A256-879558841BEA}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{901D5415-383C-4AA6-A256-879558841BEA}.Release|Any CPU.Build.0 = Release|Any CPU
-		{9D2E3153-076F-49C5-B83D-FB2573536B5F}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{9D2E3153-076F-49C5-B83D-FB2573536B5F}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{9D2E3153-076F-49C5-B83D-FB2573536B5F}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{9D2E3153-076F-49C5-B83D-FB2573536B5F}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{9D2E3153-076F-49C5-B83D-FB2573536B5F}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{9D2E3153-076F-49C5-B83D-FB2573536B5F}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{9D2E3153-076F-49C5-B83D-FB2573536B5F}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{9D2E3153-076F-49C5-B83D-FB2573536B5F}.Release|Any CPU.Build.0 = Release|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Release|Any CPU.Build.0 = Release|Any CPU
-		{FEF899EB-610C-4D3C-A556-A01F56F4AFE0}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{FEF899EB-610C-4D3C-A556-A01F56F4AFE0}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{FEF899EB-610C-4D3C-A556-A01F56F4AFE0}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{FEF899EB-610C-4D3C-A556-A01F56F4AFE0}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{FEF899EB-610C-4D3C-A556-A01F56F4AFE0}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{FEF899EB-610C-4D3C-A556-A01F56F4AFE0}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{FEF899EB-610C-4D3C-A556-A01F56F4AFE0}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{FEF899EB-610C-4D3C-A556-A01F56F4AFE0}.Release|Any CPU.Build.0 = Release|Any CPU
-		{FF45EE91-9CA3-443D-8231-75E9FA1AF40E}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{FF45EE91-9CA3-443D-8231-75E9FA1AF40E}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{FF45EE91-9CA3-443D-8231-75E9FA1AF40E}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{FF45EE91-9CA3-443D-8231-75E9FA1AF40E}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{FF45EE91-9CA3-443D-8231-75E9FA1AF40E}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{FF45EE91-9CA3-443D-8231-75E9FA1AF40E}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{FF45EE91-9CA3-443D-8231-75E9FA1AF40E}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{FF45EE91-9CA3-443D-8231-75E9FA1AF40E}.Release|Any CPU.Build.0 = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(SolutionProperties) = preSolution
-		HideSolutionNode = FALSE
-	EndGlobalSection
-EndGlobal

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/vs2010/contrib/Contrib.Analyzers.sln
----------------------------------------------------------------------
diff --git a/build/vs2010/contrib/Contrib.Analyzers.sln b/build/vs2010/contrib/Contrib.Analyzers.sln
deleted file mode 100644
index e14a31c..0000000
--- a/build/vs2010/contrib/Contrib.Analyzers.sln
+++ /dev/null
@@ -1,56 +0,0 @@
-
-Microsoft Visual Studio Solution File, Format Version 11.00
-# Visual C# Express 2010
-#
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-#
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net", "..\..\..\src\core\Lucene.Net.csproj", "{5D4AD9BE-1FFB-41AB-9943-25737971BF57}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Analyzers", "..\..\..\src\contrib\Analyzers\Contrib.Analyzers.csproj", "{4286E961-9143-4821-B46D-3D39D3736386}"
-EndProject
-Global
-	GlobalSection(SolutionConfigurationPlatforms) = preSolution
-		Debug35|Any CPU = Debug35|Any CPU
-		Debug|Any CPU = Debug|Any CPU
-		Release35|Any CPU = Release35|Any CPU
-		Release|Any CPU = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(ProjectConfigurationPlatforms) = postSolution
-		{4286E961-9143-4821-B46D-3D39D3736386}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{4286E961-9143-4821-B46D-3D39D3736386}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{4286E961-9143-4821-B46D-3D39D3736386}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{4286E961-9143-4821-B46D-3D39D3736386}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{4286E961-9143-4821-B46D-3D39D3736386}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{4286E961-9143-4821-B46D-3D39D3736386}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{4286E961-9143-4821-B46D-3D39D3736386}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{4286E961-9143-4821-B46D-3D39D3736386}.Release|Any CPU.Build.0 = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.Build.0 = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(SolutionProperties) = preSolution
-		HideSolutionNode = FALSE
-	EndGlobalSection
-EndGlobal

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/vs2010/contrib/Contrib.Core.sln
----------------------------------------------------------------------
diff --git a/build/vs2010/contrib/Contrib.Core.sln b/build/vs2010/contrib/Contrib.Core.sln
deleted file mode 100644
index 4ee3a09..0000000
--- a/build/vs2010/contrib/Contrib.Core.sln
+++ /dev/null
@@ -1,56 +0,0 @@
-
-Microsoft Visual Studio Solution File, Format Version 11.00
-# Visual C# Express 2010
-#
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-#
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net", "..\..\..\src\core\Lucene.Net.csproj", "{5D4AD9BE-1FFB-41AB-9943-25737971BF57}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Core", "..\..\..\src\contrib\Core\Contrib.Core.csproj", "{FEF899EB-610C-4D3C-A556-A01F56F4AFE0}"
-EndProject
-Global
-	GlobalSection(SolutionConfigurationPlatforms) = preSolution
-		Debug35|Any CPU = Debug35|Any CPU
-		Debug|Any CPU = Debug|Any CPU
-		Release35|Any CPU = Release35|Any CPU
-		Release|Any CPU = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(ProjectConfigurationPlatforms) = postSolution
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.Build.0 = Release|Any CPU
-		{FEF899EB-610C-4D3C-A556-A01F56F4AFE0}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{FEF899EB-610C-4D3C-A556-A01F56F4AFE0}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{FEF899EB-610C-4D3C-A556-A01F56F4AFE0}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{FEF899EB-610C-4D3C-A556-A01F56F4AFE0}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{FEF899EB-610C-4D3C-A556-A01F56F4AFE0}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{FEF899EB-610C-4D3C-A556-A01F56F4AFE0}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{FEF899EB-610C-4D3C-A556-A01F56F4AFE0}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{FEF899EB-610C-4D3C-A556-A01F56F4AFE0}.Release|Any CPU.Build.0 = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(SolutionProperties) = preSolution
-		HideSolutionNode = FALSE
-	EndGlobalSection
-EndGlobal

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/vs2010/contrib/Contrib.FastVectorHighlighter.sln
----------------------------------------------------------------------
diff --git a/build/vs2010/contrib/Contrib.FastVectorHighlighter.sln b/build/vs2010/contrib/Contrib.FastVectorHighlighter.sln
deleted file mode 100644
index 43a615b..0000000
--- a/build/vs2010/contrib/Contrib.FastVectorHighlighter.sln
+++ /dev/null
@@ -1,56 +0,0 @@
-
-Microsoft Visual Studio Solution File, Format Version 11.00
-# Visual C# Express 2010
-#
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-#
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net", "..\..\..\src\core\Lucene.Net.csproj", "{5D4AD9BE-1FFB-41AB-9943-25737971BF57}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.FastVectorHighlighter", "..\..\..\src\contrib\FastVectorHighlighter\Contrib.FastVectorHighlighter.csproj", "{9D2E3153-076F-49C5-B83D-FB2573536B5F}"
-EndProject
-Global
-	GlobalSection(SolutionConfigurationPlatforms) = preSolution
-		Debug35|Any CPU = Debug35|Any CPU
-		Debug|Any CPU = Debug|Any CPU
-		Release35|Any CPU = Release35|Any CPU
-		Release|Any CPU = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(ProjectConfigurationPlatforms) = postSolution
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.Build.0 = Release|Any CPU
-		{9D2E3153-076F-49C5-B83D-FB2573536B5F}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{9D2E3153-076F-49C5-B83D-FB2573536B5F}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{9D2E3153-076F-49C5-B83D-FB2573536B5F}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{9D2E3153-076F-49C5-B83D-FB2573536B5F}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{9D2E3153-076F-49C5-B83D-FB2573536B5F}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{9D2E3153-076F-49C5-B83D-FB2573536B5F}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{9D2E3153-076F-49C5-B83D-FB2573536B5F}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{9D2E3153-076F-49C5-B83D-FB2573536B5F}.Release|Any CPU.Build.0 = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(SolutionProperties) = preSolution
-		HideSolutionNode = FALSE
-	EndGlobalSection
-EndGlobal

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/vs2010/contrib/Contrib.Highlighter.sln
----------------------------------------------------------------------
diff --git a/build/vs2010/contrib/Contrib.Highlighter.sln b/build/vs2010/contrib/Contrib.Highlighter.sln
deleted file mode 100644
index 0d65fdb..0000000
--- a/build/vs2010/contrib/Contrib.Highlighter.sln
+++ /dev/null
@@ -1,66 +0,0 @@
-
-Microsoft Visual Studio Solution File, Format Version 11.00
-# Visual C# Express 2010
-#
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-#
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net", "..\..\..\src\core\Lucene.Net.csproj", "{5D4AD9BE-1FFB-41AB-9943-25737971BF57}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Highlighter", "..\..\..\src\contrib\Highlighter\Contrib.Highlighter.csproj", "{901D5415-383C-4AA6-A256-879558841BEA}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Memory", "..\..\..\src\contrib\Memory\Contrib.Memory.csproj", "{112B9A7C-29CC-4539-8F5A-45669C07CD4D}"
-EndProject
-Global
-	GlobalSection(SolutionConfigurationPlatforms) = preSolution
-		Debug35|Any CPU = Debug35|Any CPU
-		Debug|Any CPU = Debug|Any CPU
-		Release35|Any CPU = Release35|Any CPU
-		Release|Any CPU = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(ProjectConfigurationPlatforms) = postSolution
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Release|Any CPU.Build.0 = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.Build.0 = Release|Any CPU
-		{901D5415-383C-4AA6-A256-879558841BEA}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{901D5415-383C-4AA6-A256-879558841BEA}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{901D5415-383C-4AA6-A256-879558841BEA}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{901D5415-383C-4AA6-A256-879558841BEA}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{901D5415-383C-4AA6-A256-879558841BEA}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{901D5415-383C-4AA6-A256-879558841BEA}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{901D5415-383C-4AA6-A256-879558841BEA}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{901D5415-383C-4AA6-A256-879558841BEA}.Release|Any CPU.Build.0 = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(SolutionProperties) = preSolution
-		HideSolutionNode = FALSE
-	EndGlobalSection
-EndGlobal

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/vs2010/contrib/Contrib.Memory.sln
----------------------------------------------------------------------
diff --git a/build/vs2010/contrib/Contrib.Memory.sln b/build/vs2010/contrib/Contrib.Memory.sln
deleted file mode 100644
index 6c6dc8c..0000000
--- a/build/vs2010/contrib/Contrib.Memory.sln
+++ /dev/null
@@ -1,56 +0,0 @@
-
-Microsoft Visual Studio Solution File, Format Version 11.00
-# Visual C# Express 2010
-#
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-#
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net", "..\..\..\src\core\Lucene.Net.csproj", "{5D4AD9BE-1FFB-41AB-9943-25737971BF57}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Memory", "..\..\..\src\contrib\Memory\Contrib.Memory.csproj", "{112B9A7C-29CC-4539-8F5A-45669C07CD4D}"
-EndProject
-Global
-	GlobalSection(SolutionConfigurationPlatforms) = preSolution
-		Debug35|Any CPU = Debug35|Any CPU
-		Debug|Any CPU = Debug|Any CPU
-		Release35|Any CPU = Release35|Any CPU
-		Release|Any CPU = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(ProjectConfigurationPlatforms) = postSolution
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Release|Any CPU.Build.0 = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.Build.0 = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(SolutionProperties) = preSolution
-		HideSolutionNode = FALSE
-	EndGlobalSection
-EndGlobal

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/vs2010/contrib/Contrib.Queries.sln
----------------------------------------------------------------------
diff --git a/build/vs2010/contrib/Contrib.Queries.sln b/build/vs2010/contrib/Contrib.Queries.sln
deleted file mode 100644
index f7ecdce..0000000
--- a/build/vs2010/contrib/Contrib.Queries.sln
+++ /dev/null
@@ -1,56 +0,0 @@
-
-Microsoft Visual Studio Solution File, Format Version 11.00
-# Visual C# Express 2010
-#
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-#
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net", "..\..\..\src\core\Lucene.Net.csproj", "{5D4AD9BE-1FFB-41AB-9943-25737971BF57}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Queries", "..\..\..\src\contrib\Queries\Contrib.Queries.csproj", "{481CF6E3-52AF-4621-9DEB-022122079AF6}"
-EndProject
-Global
-	GlobalSection(SolutionConfigurationPlatforms) = preSolution
-		Debug35|Any CPU = Debug35|Any CPU
-		Debug|Any CPU = Debug|Any CPU
-		Release35|Any CPU = Release35|Any CPU
-		Release|Any CPU = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(ProjectConfigurationPlatforms) = postSolution
-		{481CF6E3-52AF-4621-9DEB-022122079AF6}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{481CF6E3-52AF-4621-9DEB-022122079AF6}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{481CF6E3-52AF-4621-9DEB-022122079AF6}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{481CF6E3-52AF-4621-9DEB-022122079AF6}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{481CF6E3-52AF-4621-9DEB-022122079AF6}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{481CF6E3-52AF-4621-9DEB-022122079AF6}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{481CF6E3-52AF-4621-9DEB-022122079AF6}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{481CF6E3-52AF-4621-9DEB-022122079AF6}.Release|Any CPU.Build.0 = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.Build.0 = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(SolutionProperties) = preSolution
-		HideSolutionNode = FALSE
-	EndGlobalSection
-EndGlobal

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/vs2010/contrib/Contrib.Regex.sln
----------------------------------------------------------------------
diff --git a/build/vs2010/contrib/Contrib.Regex.sln b/build/vs2010/contrib/Contrib.Regex.sln
deleted file mode 100644
index fd568ac..0000000
--- a/build/vs2010/contrib/Contrib.Regex.sln
+++ /dev/null
@@ -1,56 +0,0 @@
-
-Microsoft Visual Studio Solution File, Format Version 11.00
-# Visual C# Express 2010
-#
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-#
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net", "..\..\..\src\core\Lucene.Net.csproj", "{5D4AD9BE-1FFB-41AB-9943-25737971BF57}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Regex", "..\..\..\src\contrib\Regex\Contrib.Regex.csproj", "{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}"
-EndProject
-Global
-	GlobalSection(SolutionConfigurationPlatforms) = preSolution
-		Debug35|Any CPU = Debug35|Any CPU
-		Debug|Any CPU = Debug|Any CPU
-		Release35|Any CPU = Release35|Any CPU
-		Release|Any CPU = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(ProjectConfigurationPlatforms) = postSolution
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.Build.0 = Release|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Release|Any CPU.Build.0 = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(SolutionProperties) = preSolution
-		HideSolutionNode = FALSE
-	EndGlobalSection
-EndGlobal

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/vs2010/contrib/Contrib.SimpleFacetedSearch.sln
----------------------------------------------------------------------
diff --git a/build/vs2010/contrib/Contrib.SimpleFacetedSearch.sln b/build/vs2010/contrib/Contrib.SimpleFacetedSearch.sln
deleted file mode 100644
index 0cb2617..0000000
--- a/build/vs2010/contrib/Contrib.SimpleFacetedSearch.sln
+++ /dev/null
@@ -1,56 +0,0 @@
-
-Microsoft Visual Studio Solution File, Format Version 11.00
-# Visual C# Express 2010
-#
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-#
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "SimpleFacetedSearch", "..\..\..\src\contrib\SimpleFacetedSearch\SimpleFacetedSearch.csproj", "{66772190-FB3F-48F5-8E05-0B302BACEA73}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net", "..\..\..\src\core\Lucene.Net.csproj", "{5D4AD9BE-1FFB-41AB-9943-25737971BF57}"
-EndProject
-Global
-	GlobalSection(SolutionConfigurationPlatforms) = preSolution
-		Debug35|Any CPU = Debug35|Any CPU
-		Debug|Any CPU = Debug|Any CPU
-		Release35|Any CPU = Release35|Any CPU
-		Release|Any CPU = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(ProjectConfigurationPlatforms) = postSolution
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.Build.0 = Release|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Release|Any CPU.Build.0 = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(SolutionProperties) = preSolution
-		HideSolutionNode = FALSE
-	EndGlobalSection
-EndGlobal

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/vs2010/contrib/Contrib.Snowball.sln
----------------------------------------------------------------------
diff --git a/build/vs2010/contrib/Contrib.Snowball.sln b/build/vs2010/contrib/Contrib.Snowball.sln
deleted file mode 100644
index 5cc016f..0000000
--- a/build/vs2010/contrib/Contrib.Snowball.sln
+++ /dev/null
@@ -1,56 +0,0 @@
-
-Microsoft Visual Studio Solution File, Format Version 11.00
-# Visual C# Express 2010
-#
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-#
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net", "..\..\..\src\core\Lucene.Net.csproj", "{5D4AD9BE-1FFB-41AB-9943-25737971BF57}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Snowball", "..\..\..\src\contrib\Snowball\Contrib.Snowball.csproj", "{8F9D7A92-F122-413E-9D8D-027E4ECD327C}"
-EndProject
-Global
-	GlobalSection(SolutionConfigurationPlatforms) = preSolution
-		Debug35|Any CPU = Debug35|Any CPU
-		Debug|Any CPU = Debug|Any CPU
-		Release35|Any CPU = Release35|Any CPU
-		Release|Any CPU = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(ProjectConfigurationPlatforms) = postSolution
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.Build.0 = Release|Any CPU
-		{8F9D7A92-F122-413E-9D8D-027E4ECD327C}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{8F9D7A92-F122-413E-9D8D-027E4ECD327C}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{8F9D7A92-F122-413E-9D8D-027E4ECD327C}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{8F9D7A92-F122-413E-9D8D-027E4ECD327C}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{8F9D7A92-F122-413E-9D8D-027E4ECD327C}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{8F9D7A92-F122-413E-9D8D-027E4ECD327C}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{8F9D7A92-F122-413E-9D8D-027E4ECD327C}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{8F9D7A92-F122-413E-9D8D-027E4ECD327C}.Release|Any CPU.Build.0 = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(SolutionProperties) = preSolution
-		HideSolutionNode = FALSE
-	EndGlobalSection
-EndGlobal

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/vs2010/contrib/Contrib.Spatial.sln
----------------------------------------------------------------------
diff --git a/build/vs2010/contrib/Contrib.Spatial.sln b/build/vs2010/contrib/Contrib.Spatial.sln
deleted file mode 100644
index 31d28eb..0000000
--- a/build/vs2010/contrib/Contrib.Spatial.sln
+++ /dev/null
@@ -1,66 +0,0 @@
-
-Microsoft Visual Studio Solution File, Format Version 11.00
-# Visual C# Express 2010
-#
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-#
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net", "..\..\..\src\core\Lucene.Net.csproj", "{5D4AD9BE-1FFB-41AB-9943-25737971BF57}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Spatial", "..\..\..\src\contrib\Spatial\Contrib.Spatial.csproj", "{35C347F4-24B2-4BE5-8117-A0E3001551CE}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Spatial.NTS", "..\..\..\src\contrib\Spatial\Contrib.Spatial.NTS.csproj", "{02D030D0-C7B5-4561-8BDD-41408B2E2F41}"
-EndProject
-Global
-	GlobalSection(SolutionConfigurationPlatforms) = preSolution
-		Debug|Any CPU = Debug|Any CPU
-		Debug35|Any CPU = Debug35|Any CPU
-		Release|Any CPU = Release|Any CPU
-		Release35|Any CPU = Release35|Any CPU
-	EndGlobalSection
-	GlobalSection(ProjectConfigurationPlatforms) = postSolution
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.Build.0 = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{35C347F4-24B2-4BE5-8117-A0E3001551CE}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{35C347F4-24B2-4BE5-8117-A0E3001551CE}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{35C347F4-24B2-4BE5-8117-A0E3001551CE}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{35C347F4-24B2-4BE5-8117-A0E3001551CE}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{35C347F4-24B2-4BE5-8117-A0E3001551CE}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{35C347F4-24B2-4BE5-8117-A0E3001551CE}.Release|Any CPU.Build.0 = Release|Any CPU
-		{35C347F4-24B2-4BE5-8117-A0E3001551CE}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{35C347F4-24B2-4BE5-8117-A0E3001551CE}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{02D030D0-C7B5-4561-8BDD-41408B2E2F41}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{02D030D0-C7B5-4561-8BDD-41408B2E2F41}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{02D030D0-C7B5-4561-8BDD-41408B2E2F41}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{02D030D0-C7B5-4561-8BDD-41408B2E2F41}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{02D030D0-C7B5-4561-8BDD-41408B2E2F41}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{02D030D0-C7B5-4561-8BDD-41408B2E2F41}.Release|Any CPU.Build.0 = Release|Any CPU
-		{02D030D0-C7B5-4561-8BDD-41408B2E2F41}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{02D030D0-C7B5-4561-8BDD-41408B2E2F41}.Release35|Any CPU.Build.0 = Release35|Any CPU
-	EndGlobalSection
-	GlobalSection(SolutionProperties) = preSolution
-		HideSolutionNode = FALSE
-	EndGlobalSection
-EndGlobal

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/vs2010/contrib/Contrib.SpellChecker.sln
----------------------------------------------------------------------
diff --git a/build/vs2010/contrib/Contrib.SpellChecker.sln b/build/vs2010/contrib/Contrib.SpellChecker.sln
deleted file mode 100644
index 48fe86f..0000000
--- a/build/vs2010/contrib/Contrib.SpellChecker.sln
+++ /dev/null
@@ -1,56 +0,0 @@
-
-Microsoft Visual Studio Solution File, Format Version 11.00
-# Visual C# Express 2010
-#
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-#
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net", "..\..\..\src\core\Lucene.Net.csproj", "{5D4AD9BE-1FFB-41AB-9943-25737971BF57}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.SpellChecker", "..\..\..\src\contrib\SpellChecker\Contrib.SpellChecker.csproj", "{FF45EE91-9CA3-443D-8231-75E9FA1AF40E}"
-EndProject
-Global
-	GlobalSection(SolutionConfigurationPlatforms) = preSolution
-		Debug35|Any CPU = Debug35|Any CPU
-		Debug|Any CPU = Debug|Any CPU
-		Release35|Any CPU = Release35|Any CPU
-		Release|Any CPU = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(ProjectConfigurationPlatforms) = postSolution
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.Build.0 = Release|Any CPU
-		{FF45EE91-9CA3-443D-8231-75E9FA1AF40E}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{FF45EE91-9CA3-443D-8231-75E9FA1AF40E}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{FF45EE91-9CA3-443D-8231-75E9FA1AF40E}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{FF45EE91-9CA3-443D-8231-75E9FA1AF40E}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{FF45EE91-9CA3-443D-8231-75E9FA1AF40E}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{FF45EE91-9CA3-443D-8231-75E9FA1AF40E}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{FF45EE91-9CA3-443D-8231-75E9FA1AF40E}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{FF45EE91-9CA3-443D-8231-75E9FA1AF40E}.Release|Any CPU.Build.0 = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(SolutionProperties) = preSolution
-		HideSolutionNode = FALSE
-	EndGlobalSection
-EndGlobal

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/vs2010/contrib/Contrib.WordNet.sln
----------------------------------------------------------------------
diff --git a/build/vs2010/contrib/Contrib.WordNet.sln b/build/vs2010/contrib/Contrib.WordNet.sln
deleted file mode 100644
index aa6bdd4..0000000
--- a/build/vs2010/contrib/Contrib.WordNet.sln
+++ /dev/null
@@ -1,76 +0,0 @@
-
-Microsoft Visual Studio Solution File, Format Version 11.00
-# Visual C# Express 2010
-#
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-#
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net", "..\..\..\src\core\Lucene.Net.csproj", "{5D4AD9BE-1FFB-41AB-9943-25737971BF57}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.WordNet.SynExpand", "..\..\..\src\contrib\WordNet\SynExpand\Contrib.WordNet.SynExpand.csproj", "{1407C9BA-337C-4C6C-B065-68328D3871B3}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.WordNet.SynLookup", "..\..\..\src\contrib\WordNet\SynLookup\Contrib.WordNet.SynLookup.csproj", "{2CA12E3F-76E1-4FA6-9E87-37079A7B7C69}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.WordNet.Syns2Index", "..\..\..\src\contrib\WordNet\Syns2Index\Contrib.WordNet.Syns2Index.csproj", "{7563D4D9-AE91-42BA-A270-1D264660F6DF}"
-EndProject
-Global
-	GlobalSection(SolutionConfigurationPlatforms) = preSolution
-		Debug35|Any CPU = Debug35|Any CPU
-		Debug|Any CPU = Debug|Any CPU
-		Release35|Any CPU = Release35|Any CPU
-		Release|Any CPU = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(ProjectConfigurationPlatforms) = postSolution
-		{1407C9BA-337C-4C6C-B065-68328D3871B3}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{1407C9BA-337C-4C6C-B065-68328D3871B3}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{1407C9BA-337C-4C6C-B065-68328D3871B3}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{1407C9BA-337C-4C6C-B065-68328D3871B3}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{1407C9BA-337C-4C6C-B065-68328D3871B3}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{1407C9BA-337C-4C6C-B065-68328D3871B3}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{1407C9BA-337C-4C6C-B065-68328D3871B3}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{1407C9BA-337C-4C6C-B065-68328D3871B3}.Release|Any CPU.Build.0 = Release|Any CPU
-		{2CA12E3F-76E1-4FA6-9E87-37079A7B7C69}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{2CA12E3F-76E1-4FA6-9E87-37079A7B7C69}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{2CA12E3F-76E1-4FA6-9E87-37079A7B7C69}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{2CA12E3F-76E1-4FA6-9E87-37079A7B7C69}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{2CA12E3F-76E1-4FA6-9E87-37079A7B7C69}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{2CA12E3F-76E1-4FA6-9E87-37079A7B7C69}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{2CA12E3F-76E1-4FA6-9E87-37079A7B7C69}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{2CA12E3F-76E1-4FA6-9E87-37079A7B7C69}.Release|Any CPU.Build.0 = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.Build.0 = Release|Any CPU
-		{7563D4D9-AE91-42BA-A270-1D264660F6DF}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{7563D4D9-AE91-42BA-A270-1D264660F6DF}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{7563D4D9-AE91-42BA-A270-1D264660F6DF}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{7563D4D9-AE91-42BA-A270-1D264660F6DF}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{7563D4D9-AE91-42BA-A270-1D264660F6DF}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{7563D4D9-AE91-42BA-A270-1D264660F6DF}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{7563D4D9-AE91-42BA-A270-1D264660F6DF}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{7563D4D9-AE91-42BA-A270-1D264660F6DF}.Release|Any CPU.Build.0 = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(SolutionProperties) = preSolution
-		HideSolutionNode = FALSE
-	EndGlobalSection
-EndGlobal

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/vs2010/core/Lucene.Net.Core.sln
----------------------------------------------------------------------
diff --git a/build/vs2010/core/Lucene.Net.Core.sln b/build/vs2010/core/Lucene.Net.Core.sln
deleted file mode 100644
index 638c6ad..0000000
--- a/build/vs2010/core/Lucene.Net.Core.sln
+++ /dev/null
@@ -1,46 +0,0 @@
-
-Microsoft Visual Studio Solution File, Format Version 11.00
-# Visual C# Express 2010
-#
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-#
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net", "..\..\..\src\core\Lucene.Net.csproj", "{5D4AD9BE-1FFB-41AB-9943-25737971BF57}"
-EndProject
-Global
-	GlobalSection(SolutionConfigurationPlatforms) = preSolution
-		Debug35|Any CPU = Debug35|Any CPU
-		Debug|Any CPU = Debug|Any CPU
-		Release35|Any CPU = Release35|Any CPU
-		Release|Any CPU = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(ProjectConfigurationPlatforms) = postSolution
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.Build.0 = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(SolutionProperties) = preSolution
-		HideSolutionNode = FALSE
-	EndGlobalSection
-EndGlobal

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/vs2010/demo/Lucene.Net.Demo.sln
----------------------------------------------------------------------
diff --git a/build/vs2010/demo/Lucene.Net.Demo.sln b/build/vs2010/demo/Lucene.Net.Demo.sln
deleted file mode 100644
index f8f0e92..0000000
--- a/build/vs2010/demo/Lucene.Net.Demo.sln
+++ /dev/null
@@ -1,96 +0,0 @@
-
-Microsoft Visual Studio Solution File, Format Version 11.00
-# Visual C# Express 2010
-#
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-#
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net", "..\..\..\src\core\Lucene.Net.csproj", "{5D4AD9BE-1FFB-41AB-9943-25737971BF57}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Demo.Common", "..\..\..\src\demo\Demo.Common\Demo.Common.csproj", "{F04CA2F4-E182-46A8-B914-F46AF5319E83}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "DeleteFiles", "..\..\..\src\demo\DeleteFiles\DeleteFiles.csproj", "{BA3A94CC-6D1E-4AA8-9C95-8C6FD896810E}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "IndexFiles", "..\..\..\src\demo\IndexFiles\IndexFiles.csproj", "{3E561192-4292-4998-BC67-8C1B82A56108}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "IndexHtml", "..\..\..\src\demo\IndexHtml\IndexHtml.csproj", "{2B86751C-0D3A-486E-A176-E995C63EB653}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "SearchFiles", "..\..\..\src\demo\SearchFiles\SearchFiles.csproj", "{5CF56C9F-F8DF-471E-B73A-C736464948C0}"
-EndProject
-Global
-	GlobalSection(SolutionConfigurationPlatforms) = preSolution
-		Debug35|Any CPU = Debug35|Any CPU
-		Debug|Any CPU = Debug|Any CPU
-		Release35|Any CPU = Release35|Any CPU
-		Release|Any CPU = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(ProjectConfigurationPlatforms) = postSolution
-		{2B86751C-0D3A-486E-A176-E995C63EB653}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{2B86751C-0D3A-486E-A176-E995C63EB653}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{2B86751C-0D3A-486E-A176-E995C63EB653}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{2B86751C-0D3A-486E-A176-E995C63EB653}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{2B86751C-0D3A-486E-A176-E995C63EB653}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{2B86751C-0D3A-486E-A176-E995C63EB653}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{2B86751C-0D3A-486E-A176-E995C63EB653}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{2B86751C-0D3A-486E-A176-E995C63EB653}.Release|Any CPU.Build.0 = Release|Any CPU
-		{3E561192-4292-4998-BC67-8C1B82A56108}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{3E561192-4292-4998-BC67-8C1B82A56108}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{3E561192-4292-4998-BC67-8C1B82A56108}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{3E561192-4292-4998-BC67-8C1B82A56108}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{3E561192-4292-4998-BC67-8C1B82A56108}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{3E561192-4292-4998-BC67-8C1B82A56108}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{3E561192-4292-4998-BC67-8C1B82A56108}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{3E561192-4292-4998-BC67-8C1B82A56108}.Release|Any CPU.Build.0 = Release|Any CPU
-		{5CF56C9F-F8DF-471E-B73A-C736464948C0}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{5CF56C9F-F8DF-471E-B73A-C736464948C0}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{5CF56C9F-F8DF-471E-B73A-C736464948C0}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{5CF56C9F-F8DF-471E-B73A-C736464948C0}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{5CF56C9F-F8DF-471E-B73A-C736464948C0}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{5CF56C9F-F8DF-471E-B73A-C736464948C0}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{5CF56C9F-F8DF-471E-B73A-C736464948C0}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{5CF56C9F-F8DF-471E-B73A-C736464948C0}.Release|Any CPU.Build.0 = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.Build.0 = Release|Any CPU
-		{BA3A94CC-6D1E-4AA8-9C95-8C6FD896810E}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{BA3A94CC-6D1E-4AA8-9C95-8C6FD896810E}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{BA3A94CC-6D1E-4AA8-9C95-8C6FD896810E}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{BA3A94CC-6D1E-4AA8-9C95-8C6FD896810E}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{BA3A94CC-6D1E-4AA8-9C95-8C6FD896810E}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{BA3A94CC-6D1E-4AA8-9C95-8C6FD896810E}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{BA3A94CC-6D1E-4AA8-9C95-8C6FD896810E}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{BA3A94CC-6D1E-4AA8-9C95-8C6FD896810E}.Release|Any CPU.Build.0 = Release|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Release|Any CPU.Build.0 = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(SolutionProperties) = preSolution
-		HideSolutionNode = FALSE
-	EndGlobalSection
-EndGlobal


[04/51] [abbrv] [partial] Cleaning up and getting ready to development towards v4.8

Posted by sy...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/src/Lucene.Net.Codecs/Memory/FSTTermsWriter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Codecs/Memory/FSTTermsWriter.cs b/src/Lucene.Net.Codecs/Memory/FSTTermsWriter.cs
new file mode 100644
index 0000000..367b83d
--- /dev/null
+++ b/src/Lucene.Net.Codecs/Memory/FSTTermsWriter.cs
@@ -0,0 +1,277 @@
+package org.apache.lucene.codecs.memory;
+
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+import java.io.IOException;
+import java.util.List;
+import java.util.ArrayList;
+import java.util.Comparator;
+
+import org.apache.lucene.index.FieldInfo.IndexOptions;
+import org.apache.lucene.index.FieldInfo;
+import org.apache.lucene.index.FieldInfos;
+import org.apache.lucene.index.IndexFileNames;
+import org.apache.lucene.index.SegmentWriteState;
+import org.apache.lucene.store.DataOutput;
+import org.apache.lucene.store.IndexOutput;
+import org.apache.lucene.store.RAMOutputStream;
+import org.apache.lucene.util.ArrayUtil;
+import org.apache.lucene.util.BytesRef;
+import org.apache.lucene.util.IOUtils;
+import org.apache.lucene.util.IntsRef;
+import org.apache.lucene.util.fst.Builder;
+import org.apache.lucene.util.fst.FST;
+import org.apache.lucene.util.fst.Util;
+import org.apache.lucene.codecs.BlockTermState;
+import org.apache.lucene.codecs.PostingsWriterBase;
+import org.apache.lucene.codecs.PostingsConsumer;
+import org.apache.lucene.codecs.FieldsConsumer;
+import org.apache.lucene.codecs.TermsConsumer;
+import org.apache.lucene.codecs.TermStats;
+import org.apache.lucene.codecs.CodecUtil;
+
+/**
+ * FST-based term dict, using metadata as FST output.
+ *
+ * The FST directly holds the mapping between &lt;term, metadata&gt;.
+ *
+ * Term metadata consists of three parts:
+ * 1. term statistics: docFreq, totalTermFreq;
+ * 2. monotonic long[], e.g. the pointer to the postings list for that term;
+ * 3. generic byte[], e.g. other information need by postings reader.
+ *
+ * <p>
+ * File:
+ * <ul>
+ *   <li><tt>.tst</tt>: <a href="#Termdictionary">Term Dictionary</a></li>
+ * </ul>
+ * <p>
+ *
+ * <a name="Termdictionary" id="Termdictionary"></a>
+ * <h3>Term Dictionary</h3>
+ * <p>
+ *  The .tst contains a list of FSTs, one for each field.
+ *  The FST maps a term to its corresponding statistics (e.g. docfreq) 
+ *  and metadata (e.g. information for postings list reader like file pointer
+ *  to postings list).
+ * </p>
+ * <p>
+ *  Typically the metadata is separated into two parts:
+ *  <ul>
+ *   <li>
+ *    Monotonical long array: Some metadata will always be ascending in order
+ *    with the corresponding term. This part is used by FST to share outputs between arcs.
+ *   </li>
+ *   <li>
+ *    Generic byte array: Used to store non-monotonic metadata.
+ *   </li>
+ *  </ul>
+ * </p>
+ *
+ * File format:
+ * <ul>
+ *  <li>TermsDict(.tst) --&gt; Header, <i>PostingsHeader</i>, FieldSummary, DirOffset</li>
+ *  <li>FieldSummary --&gt; NumFields, &lt;FieldNumber, NumTerms, SumTotalTermFreq?, 
+ *                                      SumDocFreq, DocCount, LongsSize, TermFST &gt;<sup>NumFields</sup></li>
+ *  <li>TermFST --&gt; {@link FST FST&lt;TermData&gt;}</li>
+ *  <li>TermData --&gt; Flag, BytesSize?, LongDelta<sup>LongsSize</sup>?, Byte<sup>BytesSize</sup>?, 
+ *                      &lt; DocFreq[Same?], (TotalTermFreq-DocFreq) &gt; ? </li>
+ *  <li>Header --&gt; {@link CodecUtil#writeHeader CodecHeader}</li>
+ *  <li>DirOffset --&gt; {@link DataOutput#writeLong Uint64}</li>
+ *  <li>DocFreq, LongsSize, BytesSize, NumFields,
+ *        FieldNumber, DocCount --&gt; {@link DataOutput#writeVInt VInt}</li>
+ *  <li>TotalTermFreq, NumTerms, SumTotalTermFreq, SumDocFreq, LongDelta --&gt; 
+ *        {@link DataOutput#writeVLong VLong}</li>
+ * </ul>
+ * <p>Notes:</p>
+ * <ul>
+ *  <li>
+ *   The format of PostingsHeader and generic meta bytes are customized by the specific postings implementation:
+ *   they contain arbitrary per-file data (such as parameters or versioning information), and per-term data
+ *   (non-monotonic ones like pulsed postings data).
+ *  </li>
+ *  <li>
+ *   The format of TermData is determined by FST, typically monotonic metadata will be dense around shallow arcs,
+ *   while in deeper arcs only generic bytes and term statistics exist.
+ *  </li>
+ *  <li>
+ *   The byte Flag is used to indicate which part of metadata exists on current arc. Specially the monotonic part
+ *   is omitted when it is an array of 0s.
+ *  </li>
+ *  <li>
+ *   Since LongsSize is per-field fixed, it is only written once in field summary.
+ *  </li>
+ * </ul>
+ *
+ * @lucene.experimental
+ */
+
+public class FSTTermsWriter extends FieldsConsumer {
+  static final String TERMS_EXTENSION = "tmp";
+  static final String TERMS_CODEC_NAME = "FST_TERMS_DICT";
+  public static final int TERMS_VERSION_START = 0;
+  public static final int TERMS_VERSION_CHECKSUM = 1;
+  public static final int TERMS_VERSION_CURRENT = TERMS_VERSION_CHECKSUM;
+  
+  final PostingsWriterBase postingsWriter;
+  final FieldInfos fieldInfos;
+  IndexOutput out;
+  final List<FieldMetaData> fields = new ArrayList<>();
+
+  public FSTTermsWriter(SegmentWriteState state, PostingsWriterBase postingsWriter)  {
+    final String termsFileName = IndexFileNames.segmentFileName(state.segmentInfo.name, state.segmentSuffix, TERMS_EXTENSION);
+
+    this.postingsWriter = postingsWriter;
+    this.fieldInfos = state.fieldInfos;
+    this.out = state.directory.createOutput(termsFileName, state.context);
+
+    bool success = false;
+    try {
+      writeHeader(out);
+      this.postingsWriter.init(out); 
+      success = true;
+    } finally {
+      if (!success) {
+        IOUtils.closeWhileHandlingException(out);
+      }
+    }
+  }
+  private void writeHeader(IndexOutput out)  {
+    CodecUtil.writeHeader(out, TERMS_CODEC_NAME, TERMS_VERSION_CURRENT);   
+  }
+  private void writeTrailer(IndexOutput out, long dirStart)  {
+    out.writeLong(dirStart);
+  }
+
+  @Override
+  public TermsConsumer addField(FieldInfo field)  {
+    return new TermsWriter(field);
+  }
+
+  @Override
+  public void close()  {
+    if (out != null) {
+      IOException ioe = null;
+      try {
+        // write field summary
+        final long dirStart = out.getFilePointer();
+        
+        out.writeVInt(fields.size());
+        for (FieldMetaData field : fields) {
+          out.writeVInt(field.fieldInfo.number);
+          out.writeVLong(field.numTerms);
+          if (field.fieldInfo.getIndexOptions() != IndexOptions.DOCS_ONLY) {
+            out.writeVLong(field.sumTotalTermFreq);
+          }
+          out.writeVLong(field.sumDocFreq);
+          out.writeVInt(field.docCount);
+          out.writeVInt(field.longsSize);
+          field.dict.save(out);
+        }
+        writeTrailer(out, dirStart);
+        CodecUtil.writeFooter(out);
+      } catch (IOException ioe2) {
+        ioe = ioe2;
+      } finally {
+        IOUtils.closeWhileHandlingException(ioe, out, postingsWriter);
+        out = null;
+      }
+    }
+  }
+
+  private static class FieldMetaData {
+    public final FieldInfo fieldInfo;
+    public final long numTerms;
+    public final long sumTotalTermFreq;
+    public final long sumDocFreq;
+    public final int docCount;
+    public final int longsSize;
+    public final FST<FSTTermOutputs.TermData> dict;
+
+    public FieldMetaData(FieldInfo fieldInfo, long numTerms, long sumTotalTermFreq, long sumDocFreq, int docCount, int longsSize, FST<FSTTermOutputs.TermData> fst) {
+      this.fieldInfo = fieldInfo;
+      this.numTerms = numTerms;
+      this.sumTotalTermFreq = sumTotalTermFreq;
+      this.sumDocFreq = sumDocFreq;
+      this.docCount = docCount;
+      this.longsSize = longsSize;
+      this.dict = fst;
+    }
+  }
+
+  final class TermsWriter extends TermsConsumer {
+    private final Builder<FSTTermOutputs.TermData> builder;
+    private final FSTTermOutputs outputs;
+    private final FieldInfo fieldInfo;
+    private final int longsSize;
+    private long numTerms;
+
+    private final IntsRef scratchTerm = new IntsRef();
+    private final RAMOutputStream statsWriter = new RAMOutputStream();
+    private final RAMOutputStream metaWriter = new RAMOutputStream();
+
+    TermsWriter(FieldInfo fieldInfo) {
+      this.numTerms = 0;
+      this.fieldInfo = fieldInfo;
+      this.longsSize = postingsWriter.setField(fieldInfo);
+      this.outputs = new FSTTermOutputs(fieldInfo, longsSize);
+      this.builder = new Builder<>(FST.INPUT_TYPE.BYTE1, outputs);
+    }
+
+    @Override
+    public Comparator<BytesRef> getComparator() {
+      return BytesRef.getUTF8SortedAsUnicodeComparator();
+    }
+
+    @Override
+    public PostingsConsumer startTerm(BytesRef text)  {
+      postingsWriter.startTerm();
+      return postingsWriter;
+    }
+
+    @Override
+    public void finishTerm(BytesRef text, TermStats stats)  {
+      // write term meta data into fst
+      final BlockTermState state = postingsWriter.newTermState();
+      final FSTTermOutputs.TermData meta = new FSTTermOutputs.TermData();
+      meta.longs = new long[longsSize];
+      meta.bytes = null;
+      meta.docFreq = state.docFreq = stats.docFreq;
+      meta.totalTermFreq = state.totalTermFreq = stats.totalTermFreq;
+      postingsWriter.finishTerm(state);
+      postingsWriter.encodeTerm(meta.longs, metaWriter, fieldInfo, state, true);
+      final int bytesSize = (int)metaWriter.getFilePointer();
+      if (bytesSize > 0) {
+        meta.bytes = new byte[bytesSize];
+        metaWriter.writeTo(meta.bytes, 0);
+        metaWriter.reset();
+      }
+      builder.add(Util.toIntsRef(text, scratchTerm), meta);
+      numTerms++;
+    }
+
+    @Override
+    public void finish(long sumTotalTermFreq, long sumDocFreq, int docCount)  {
+      // save FST dict
+      if (numTerms > 0) {
+        final FST<FSTTermOutputs.TermData> fst = builder.finish();
+        fields.add(new FieldMetaData(fieldInfo, numTerms, sumTotalTermFreq, sumDocFreq, docCount, longsSize, fst));
+      }
+    }
+  }
+}

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/src/Lucene.Net.Codecs/Memory/MemoryDocValuesConsumer.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Codecs/Memory/MemoryDocValuesConsumer.cs b/src/Lucene.Net.Codecs/Memory/MemoryDocValuesConsumer.cs
new file mode 100644
index 0000000..e8026df
--- /dev/null
+++ b/src/Lucene.Net.Codecs/Memory/MemoryDocValuesConsumer.cs
@@ -0,0 +1,408 @@
+package org.apache.lucene.codecs.memory;
+
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+import java.io.IOException;
+import java.util.HashMap;
+import java.util.HashSet;
+import java.util.Iterator;
+import java.util.NoSuchElementException;
+
+import org.apache.lucene.codecs.CodecUtil;
+import org.apache.lucene.codecs.DocValuesConsumer;
+import org.apache.lucene.index.FieldInfo;
+import org.apache.lucene.index.IndexFileNames;
+import org.apache.lucene.index.SegmentWriteState;
+import org.apache.lucene.store.ByteArrayDataOutput;
+import org.apache.lucene.store.IndexOutput;
+import org.apache.lucene.util.ArrayUtil;
+import org.apache.lucene.util.BytesRef;
+import org.apache.lucene.util.IOUtils;
+import org.apache.lucene.util.IntsRef;
+import org.apache.lucene.util.MathUtil;
+import org.apache.lucene.util.fst.Builder;
+import org.apache.lucene.util.fst.FST.INPUT_TYPE;
+import org.apache.lucene.util.fst.FST;
+import org.apache.lucene.util.fst.PositiveIntOutputs;
+import org.apache.lucene.util.fst.Util;
+import org.apache.lucene.util.packed.BlockPackedWriter;
+import org.apache.lucene.util.packed.MonotonicBlockPackedWriter;
+import org.apache.lucene.util.packed.PackedInts.FormatAndBits;
+import org.apache.lucene.util.packed.PackedInts;
+
+import static org.apache.lucene.codecs.memory.MemoryDocValuesProducer.VERSION_CURRENT;
+import static org.apache.lucene.codecs.memory.MemoryDocValuesProducer.BLOCK_SIZE;
+import static org.apache.lucene.codecs.memory.MemoryDocValuesProducer.BYTES;
+import static org.apache.lucene.codecs.memory.MemoryDocValuesProducer.NUMBER;
+import static org.apache.lucene.codecs.memory.MemoryDocValuesProducer.FST;
+import static org.apache.lucene.codecs.memory.MemoryDocValuesProducer.DELTA_COMPRESSED;
+import static org.apache.lucene.codecs.memory.MemoryDocValuesProducer.GCD_COMPRESSED;
+import static org.apache.lucene.codecs.memory.MemoryDocValuesProducer.TABLE_COMPRESSED;
+import static org.apache.lucene.codecs.memory.MemoryDocValuesProducer.UNCOMPRESSED;
+
+/**
+ * Writer for {@link MemoryDocValuesFormat}
+ */
+class MemoryDocValuesConsumer extends DocValuesConsumer {
+  IndexOutput data, meta;
+  final int maxDoc;
+  final float acceptableOverheadRatio;
+  
+  MemoryDocValuesConsumer(SegmentWriteState state, String dataCodec, String dataExtension, String metaCodec, String metaExtension, float acceptableOverheadRatio)  {
+    this.acceptableOverheadRatio = acceptableOverheadRatio;
+    maxDoc = state.segmentInfo.getDocCount();
+    bool success = false;
+    try {
+      String dataName = IndexFileNames.segmentFileName(state.segmentInfo.name, state.segmentSuffix, dataExtension);
+      data = state.directory.createOutput(dataName, state.context);
+      CodecUtil.writeHeader(data, dataCodec, VERSION_CURRENT);
+      String metaName = IndexFileNames.segmentFileName(state.segmentInfo.name, state.segmentSuffix, metaExtension);
+      meta = state.directory.createOutput(metaName, state.context);
+      CodecUtil.writeHeader(meta, metaCodec, VERSION_CURRENT);
+      success = true;
+    } finally {
+      if (!success) {
+        IOUtils.closeWhileHandlingException(this);
+      }
+    }
+  }
+
+  @Override
+  public void addNumericField(FieldInfo field, Iterable<Number> values)  {
+    addNumericField(field, values, true);
+  }
+
+  void addNumericField(FieldInfo field, Iterable<Number> values, bool optimizeStorage)  {
+    meta.writeVInt(field.number);
+    meta.writeByte(NUMBER);
+    meta.writeLong(data.getFilePointer());
+    long minValue = Long.MAX_VALUE;
+    long maxValue = Long.MIN_VALUE;
+    long gcd = 0;
+    bool missing = false;
+    // TODO: more efficient?
+    HashSet<Long> uniqueValues = null;
+    if (optimizeStorage) {
+      uniqueValues = new HashSet<>();
+
+      long count = 0;
+      for (Number nv : values) {
+        final long v;
+        if (nv == null) {
+          v = 0;
+          missing = true;
+        } else {
+          v = nv.longValue();
+        }
+
+        if (gcd != 1) {
+          if (v < Long.MIN_VALUE / 2 || v > Long.MAX_VALUE / 2) {
+            // in that case v - minValue might overflow and make the GCD computation return
+            // wrong results. Since these extreme values are unlikely, we just discard
+            // GCD computation for them
+            gcd = 1;
+          } else if (count != 0) { // minValue needs to be set first
+            gcd = MathUtil.gcd(gcd, v - minValue);
+          }
+        }
+
+        minValue = Math.min(minValue, v);
+        maxValue = Math.max(maxValue, v);
+
+        if (uniqueValues != null) {
+          if (uniqueValues.add(v)) {
+            if (uniqueValues.size() > 256) {
+              uniqueValues = null;
+            }
+          }
+        }
+
+        ++count;
+      }
+      Debug.Assert( count == maxDoc;
+    }
+    
+    if (missing) {
+      long start = data.getFilePointer();
+      writeMissingBitset(values);
+      meta.writeLong(start);
+      meta.writeLong(data.getFilePointer() - start);
+    } else {
+      meta.writeLong(-1L);
+    }
+
+    if (uniqueValues != null) {
+      // small number of unique values
+      final int bitsPerValue = PackedInts.bitsRequired(uniqueValues.size()-1);
+      FormatAndBits formatAndBits = PackedInts.fastestFormatAndBits(maxDoc, bitsPerValue, acceptableOverheadRatio);
+      if (formatAndBits.bitsPerValue == 8 && minValue >= Byte.MIN_VALUE && maxValue <= Byte.MAX_VALUE) {
+        meta.writeByte(UNCOMPRESSED); // uncompressed
+        for (Number nv : values) {
+          data.writeByte(nv == null ? 0 : (byte) nv.longValue());
+        }
+      } else {
+        meta.writeByte(TABLE_COMPRESSED); // table-compressed
+        Long[] decode = uniqueValues.toArray(new Long[uniqueValues.size()]);
+        final HashMap<Long,Integer> encode = new HashMap<>();
+        data.writeVInt(decode.length);
+        for (int i = 0; i < decode.length; i++) {
+          data.writeLong(decode[i]);
+          encode.put(decode[i], i);
+        }
+
+        meta.writeVInt(PackedInts.VERSION_CURRENT);
+        data.writeVInt(formatAndBits.format.getId());
+        data.writeVInt(formatAndBits.bitsPerValue);
+
+        final PackedInts.Writer writer = PackedInts.getWriterNoHeader(data, formatAndBits.format, maxDoc, formatAndBits.bitsPerValue, PackedInts.DEFAULT_BUFFER_SIZE);
+        for(Number nv : values) {
+          writer.add(encode.get(nv == null ? 0 : nv.longValue()));
+        }
+        writer.finish();
+      }
+    } else if (gcd != 0 && gcd != 1) {
+      meta.writeByte(GCD_COMPRESSED);
+      meta.writeVInt(PackedInts.VERSION_CURRENT);
+      data.writeLong(minValue);
+      data.writeLong(gcd);
+      data.writeVInt(BLOCK_SIZE);
+
+      final BlockPackedWriter writer = new BlockPackedWriter(data, BLOCK_SIZE);
+      for (Number nv : values) {
+        long value = nv == null ? 0 : nv.longValue();
+        writer.add((value - minValue) / gcd);
+      }
+      writer.finish();
+    } else {
+      meta.writeByte(DELTA_COMPRESSED); // delta-compressed
+
+      meta.writeVInt(PackedInts.VERSION_CURRENT);
+      data.writeVInt(BLOCK_SIZE);
+
+      final BlockPackedWriter writer = new BlockPackedWriter(data, BLOCK_SIZE);
+      for (Number nv : values) {
+        writer.add(nv == null ? 0 : nv.longValue());
+      }
+      writer.finish();
+    }
+  }
+  
+  @Override
+  public void close()  {
+    bool success = false;
+    try {
+      if (meta != null) {
+        meta.writeVInt(-1); // write EOF marker
+        CodecUtil.writeFooter(meta); // write checksum
+      }
+      if (data != null) {
+        CodecUtil.writeFooter(data);
+      }
+      success = true;
+    } finally {
+      if (success) {
+        IOUtils.close(data, meta);
+      } else {
+        IOUtils.closeWhileHandlingException(data, meta);
+      }
+      data = meta = null;
+    }
+  }
+
+  @Override
+  public void addBinaryField(FieldInfo field, final Iterable<BytesRef> values)  {
+    // write the byte[] data
+    meta.writeVInt(field.number);
+    meta.writeByte(BYTES);
+    int minLength = Integer.MAX_VALUE;
+    int maxLength = Integer.MIN_VALUE;
+    final long startFP = data.getFilePointer();
+    bool missing = false;
+    for(BytesRef v : values) {
+      final int length;
+      if (v == null) {
+        length = 0;
+        missing = true;
+      } else {
+        length = v.length;
+      }
+      if (length > MemoryDocValuesFormat.MAX_BINARY_FIELD_LENGTH) {
+        throw new IllegalArgumentException("DocValuesField \"" + field.name + "\" is too large, must be <= " + MemoryDocValuesFormat.MAX_BINARY_FIELD_LENGTH);
+      }
+      minLength = Math.min(minLength, length);
+      maxLength = Math.max(maxLength, length);
+      if (v != null) {
+        data.writeBytes(v.bytes, v.offset, v.length);
+      }
+    }
+    meta.writeLong(startFP);
+    meta.writeLong(data.getFilePointer() - startFP);
+    if (missing) {
+      long start = data.getFilePointer();
+      writeMissingBitset(values);
+      meta.writeLong(start);
+      meta.writeLong(data.getFilePointer() - start);
+    } else {
+      meta.writeLong(-1L);
+    }
+    meta.writeVInt(minLength);
+    meta.writeVInt(maxLength);
+    
+    // if minLength == maxLength, its a fixed-length byte[], we are done (the addresses are implicit)
+    // otherwise, we need to record the length fields...
+    if (minLength != maxLength) {
+      meta.writeVInt(PackedInts.VERSION_CURRENT);
+      meta.writeVInt(BLOCK_SIZE);
+
+      final MonotonicBlockPackedWriter writer = new MonotonicBlockPackedWriter(data, BLOCK_SIZE);
+      long addr = 0;
+      for (BytesRef v : values) {
+        if (v != null) {
+          addr += v.length;
+        }
+        writer.add(addr);
+      }
+      writer.finish();
+    }
+  }
+  
+  private void writeFST(FieldInfo field, Iterable<BytesRef> values)  {
+    meta.writeVInt(field.number);
+    meta.writeByte(FST);
+    meta.writeLong(data.getFilePointer());
+    PositiveIntOutputs outputs = PositiveIntOutputs.getSingleton();
+    Builder<Long> builder = new Builder<>(INPUT_TYPE.BYTE1, outputs);
+    IntsRef scratch = new IntsRef();
+    long ord = 0;
+    for (BytesRef v : values) {
+      builder.add(Util.toIntsRef(v, scratch), ord);
+      ord++;
+    }
+    FST<Long> fst = builder.finish();
+    if (fst != null) {
+      fst.save(data);
+    }
+    meta.writeVLong(ord);
+  }
+  
+  // TODO: in some cases representing missing with minValue-1 wouldn't take up additional space and so on,
+  // but this is very simple, and algorithms only check this for values of 0 anyway (doesnt slow down normal decode)
+  void writeMissingBitset(Iterable<?> values)  {
+    long bits = 0;
+    int count = 0;
+    for (Object v : values) {
+      if (count == 64) {
+        data.writeLong(bits);
+        count = 0;
+        bits = 0;
+      }
+      if (v != null) {
+        bits |= 1L << (count & 0x3f);
+      }
+      count++;
+    }
+    if (count > 0) {
+      data.writeLong(bits);
+    }
+  }
+
+  @Override
+  public void addSortedField(FieldInfo field, Iterable<BytesRef> values, Iterable<Number> docToOrd)  {
+    // write the ordinals as numerics
+    addNumericField(field, docToOrd, false);
+    
+    // write the values as FST
+    writeFST(field, values);
+  }
+
+  // note: this might not be the most efficient... but its fairly simple
+  @Override
+  public void addSortedSetField(FieldInfo field, Iterable<BytesRef> values, final Iterable<Number> docToOrdCount, final Iterable<Number> ords)  {
+    // write the ordinals as a binary field
+    addBinaryField(field, new Iterable<BytesRef>() {
+      @Override
+      public Iterator<BytesRef> iterator() {
+        return new SortedSetIterator(docToOrdCount.iterator(), ords.iterator());
+      }
+    });
+      
+    // write the values as FST
+    writeFST(field, values);
+  }
+  
+  // per-document vint-encoded byte[]
+  static class SortedSetIterator implements Iterator<BytesRef> {
+    byte[] buffer = new byte[10];
+    ByteArrayDataOutput out = new ByteArrayDataOutput();
+    BytesRef ref = new BytesRef();
+    
+    final Iterator<Number> counts;
+    final Iterator<Number> ords;
+    
+    SortedSetIterator(Iterator<Number> counts, Iterator<Number> ords) {
+      this.counts = counts;
+      this.ords = ords;
+    }
+    
+    @Override
+    public bool hasNext() {
+      return counts.hasNext();
+    }
+
+    @Override
+    public BytesRef next() {
+      if (!hasNext()) {
+        throw new NoSuchElementException();
+      }
+      
+      int count = counts.next().intValue();
+      int maxSize = count*9; // worst case
+      if (maxSize > buffer.length) {
+        buffer = ArrayUtil.grow(buffer, maxSize);
+      }
+      
+      try {
+        encodeValues(count);
+      } catch (IOException bogus) {
+        throw new RuntimeException(bogus);
+      }
+      
+      ref.bytes = buffer;
+      ref.offset = 0;
+      ref.length = out.getPosition();
+
+      return ref;
+    }
+    
+    // encodes count values to buffer
+    private void encodeValues(int count)  {
+      out.reset(buffer);
+      long lastOrd = 0;
+      for (int i = 0; i < count; i++) {
+        long ord = ords.next().longValue();
+        out.writeVLong(ord - lastOrd);
+        lastOrd = ord;
+      }
+    }
+
+    @Override
+    public void remove() {
+      throw new UnsupportedOperationException();
+    }
+  }
+}

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/src/Lucene.Net.Codecs/Memory/MemoryDocValuesFormat.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Codecs/Memory/MemoryDocValuesFormat.cs b/src/Lucene.Net.Codecs/Memory/MemoryDocValuesFormat.cs
new file mode 100644
index 0000000..efc1aba
--- /dev/null
+++ b/src/Lucene.Net.Codecs/Memory/MemoryDocValuesFormat.cs
@@ -0,0 +1,72 @@
+package org.apache.lucene.codecs.memory;
+
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+import java.io.IOException;
+
+import org.apache.lucene.codecs.DocValuesConsumer;
+import org.apache.lucene.codecs.DocValuesProducer;
+import org.apache.lucene.codecs.DocValuesFormat;
+import org.apache.lucene.index.SegmentReadState;
+import org.apache.lucene.index.SegmentWriteState;
+import org.apache.lucene.util.packed.PackedInts;
+
+/** In-memory docvalues format */
+public class MemoryDocValuesFormat extends DocValuesFormat {
+
+  /** Maximum length for each binary doc values field. */
+  public static final int MAX_BINARY_FIELD_LENGTH = (1 << 15) - 2;
+  
+  final float acceptableOverheadRatio;
+  
+  /** 
+   * Calls {@link #MemoryDocValuesFormat(float) 
+   * MemoryDocValuesFormat(PackedInts.DEFAULT)} 
+   */
+  public MemoryDocValuesFormat() {
+    this(PackedInts.DEFAULT);
+  }
+  
+  /**
+   * Creates a new MemoryDocValuesFormat with the specified
+   * <code>acceptableOverheadRatio</code> for NumericDocValues.
+   * @param acceptableOverheadRatio compression parameter for numerics. 
+   *        Currently this is only used when the number of unique values is small.
+   *        
+   * @lucene.experimental
+   */
+  public MemoryDocValuesFormat(float acceptableOverheadRatio) {
+    super("Memory");
+    this.acceptableOverheadRatio = acceptableOverheadRatio;
+  }
+
+  @Override
+  public DocValuesConsumer fieldsConsumer(SegmentWriteState state)  {
+    return new MemoryDocValuesConsumer(state, DATA_CODEC, DATA_EXTENSION, METADATA_CODEC, METADATA_EXTENSION, acceptableOverheadRatio);
+  }
+  
+  @Override
+  public DocValuesProducer fieldsProducer(SegmentReadState state)  {
+    return new MemoryDocValuesProducer(state, DATA_CODEC, DATA_EXTENSION, METADATA_CODEC, METADATA_EXTENSION);
+  }
+  
+  static final String DATA_CODEC = "MemoryDocValuesData";
+  static final String DATA_EXTENSION = "mdvd";
+  static final String METADATA_CODEC = "MemoryDocValuesMetadata";
+  static final String METADATA_EXTENSION = "mdvm";
+}

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/src/Lucene.Net.Codecs/Memory/MemoryDocValuesProducer.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Codecs/Memory/MemoryDocValuesProducer.cs b/src/Lucene.Net.Codecs/Memory/MemoryDocValuesProducer.cs
new file mode 100644
index 0000000..ce004b4
--- /dev/null
+++ b/src/Lucene.Net.Codecs/Memory/MemoryDocValuesProducer.cs
@@ -0,0 +1,658 @@
+package org.apache.lucene.codecs.memory;
+
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+import java.io.IOException;
+import java.util.Comparator;
+import java.util.HashMap;
+import java.util.Map;
+import java.util.concurrent.atomic.AtomicLong;
+
+import org.apache.lucene.codecs.CodecUtil;
+import org.apache.lucene.codecs.DocValuesProducer;
+import org.apache.lucene.index.BinaryDocValues;
+import org.apache.lucene.index.CorruptIndexException;
+import org.apache.lucene.index.DocValues;
+import org.apache.lucene.index.DocsAndPositionsEnum;
+import org.apache.lucene.index.DocsEnum;
+import org.apache.lucene.index.FieldInfo;
+import org.apache.lucene.index.FieldInfos;
+import org.apache.lucene.index.IndexFileNames;
+import org.apache.lucene.index.NumericDocValues;
+import org.apache.lucene.index.SegmentReadState;
+import org.apache.lucene.index.SortedDocValues;
+import org.apache.lucene.index.SortedSetDocValues;
+import org.apache.lucene.index.TermsEnum;
+import org.apache.lucene.store.ByteArrayDataInput;
+import org.apache.lucene.store.ChecksumIndexInput;
+import org.apache.lucene.store.IndexInput;
+import org.apache.lucene.util.Bits;
+import org.apache.lucene.util.BytesRef;
+import org.apache.lucene.util.FixedBitSet;
+import org.apache.lucene.util.IOUtils;
+import org.apache.lucene.util.IntsRef;
+import org.apache.lucene.util.PagedBytes;
+import org.apache.lucene.util.RamUsageEstimator;
+import org.apache.lucene.util.fst.BytesRefFSTEnum;
+import org.apache.lucene.util.fst.BytesRefFSTEnum.InputOutput;
+import org.apache.lucene.util.fst.FST;
+import org.apache.lucene.util.fst.FST.Arc;
+import org.apache.lucene.util.fst.FST.BytesReader;
+import org.apache.lucene.util.fst.PositiveIntOutputs;
+import org.apache.lucene.util.fst.Util;
+import org.apache.lucene.util.packed.BlockPackedReader;
+import org.apache.lucene.util.packed.MonotonicBlockPackedReader;
+import org.apache.lucene.util.packed.PackedInts;
+
+/**
+ * Reader for {@link MemoryDocValuesFormat}
+ */
+class MemoryDocValuesProducer extends DocValuesProducer {
+  // metadata maps (just file pointers and minimal stuff)
+  private final Map<Integer,NumericEntry> numerics;
+  private final Map<Integer,BinaryEntry> binaries;
+  private final Map<Integer,FSTEntry> fsts;
+  private final IndexInput data;
+  
+  // ram instances we have already loaded
+  private final Map<Integer,NumericDocValues> numericInstances = 
+      new HashMap<>();
+  private final Map<Integer,BinaryDocValues> binaryInstances =
+      new HashMap<>();
+  private final Map<Integer,FST<Long>> fstInstances =
+      new HashMap<>();
+  private final Map<Integer,Bits> docsWithFieldInstances = new HashMap<>();
+  
+  private final int maxDoc;
+  private final AtomicLong ramBytesUsed;
+  private final int version;
+  
+  static final byte NUMBER = 0;
+  static final byte BYTES = 1;
+  static final byte FST = 2;
+
+  static final int BLOCK_SIZE = 4096;
+  
+  static final byte DELTA_COMPRESSED = 0;
+  static final byte TABLE_COMPRESSED = 1;
+  static final byte UNCOMPRESSED = 2;
+  static final byte GCD_COMPRESSED = 3;
+  
+  static final int VERSION_START = 0;
+  static final int VERSION_GCD_COMPRESSION = 1;
+  static final int VERSION_CHECKSUM = 2;
+  static final int VERSION_CURRENT = VERSION_CHECKSUM;
+    
+  MemoryDocValuesProducer(SegmentReadState state, String dataCodec, String dataExtension, String metaCodec, String metaExtension)  {
+    maxDoc = state.segmentInfo.getDocCount();
+    String metaName = IndexFileNames.segmentFileName(state.segmentInfo.name, state.segmentSuffix, metaExtension);
+    // read in the entries from the metadata file.
+    ChecksumIndexInput in = state.directory.openChecksumInput(metaName, state.context);
+    bool success = false;
+    try {
+      version = CodecUtil.checkHeader(in, metaCodec, 
+                                      VERSION_START,
+                                      VERSION_CURRENT);
+      numerics = new HashMap<>();
+      binaries = new HashMap<>();
+      fsts = new HashMap<>();
+      readFields(in, state.fieldInfos);
+      if (version >= VERSION_CHECKSUM) {
+        CodecUtil.checkFooter(in);
+      } else {
+        CodecUtil.checkEOF(in);
+      }
+      ramBytesUsed = new AtomicLong(RamUsageEstimator.shallowSizeOfInstance(getClass()));
+      success = true;
+    } finally {
+      if (success) {
+        IOUtils.close(in);
+      } else {
+        IOUtils.closeWhileHandlingException(in);
+      }
+    }
+
+    success = false;
+    try {
+      String dataName = IndexFileNames.segmentFileName(state.segmentInfo.name, state.segmentSuffix, dataExtension);
+      data = state.directory.openInput(dataName, state.context);
+      final int version2 = CodecUtil.checkHeader(data, dataCodec, 
+                                                 VERSION_START,
+                                                 VERSION_CURRENT);
+      if (version != version2) {
+        throw new CorruptIndexException("Format versions mismatch");
+      }
+
+      success = true;
+    } finally {
+      if (!success) {
+        IOUtils.closeWhileHandlingException(this.data);
+      }
+    }
+  }
+  
+  private void readFields(IndexInput meta, FieldInfos infos)  {
+    int fieldNumber = meta.readVInt();
+    while (fieldNumber != -1) {
+      int fieldType = meta.readByte();
+      if (fieldType == NUMBER) {
+        NumericEntry entry = new NumericEntry();
+        entry.offset = meta.readLong();
+        entry.missingOffset = meta.readLong();
+        if (entry.missingOffset != -1) {
+          entry.missingBytes = meta.readLong();
+        } else {
+          entry.missingBytes = 0;
+        }
+        entry.format = meta.readByte();
+        switch(entry.format) {
+          case DELTA_COMPRESSED:
+          case TABLE_COMPRESSED:
+          case GCD_COMPRESSED:
+          case UNCOMPRESSED:
+               break;
+          default:
+               throw new CorruptIndexException("Unknown format: " + entry.format + ", input=" + meta);
+        }
+        if (entry.format != UNCOMPRESSED) {
+          entry.packedIntsVersion = meta.readVInt();
+        }
+        numerics.put(fieldNumber, entry);
+      } else if (fieldType == BYTES) {
+        BinaryEntry entry = new BinaryEntry();
+        entry.offset = meta.readLong();
+        entry.numBytes = meta.readLong();
+        entry.missingOffset = meta.readLong();
+        if (entry.missingOffset != -1) {
+          entry.missingBytes = meta.readLong();
+        } else {
+          entry.missingBytes = 0;
+        }
+        entry.minLength = meta.readVInt();
+        entry.maxLength = meta.readVInt();
+        if (entry.minLength != entry.maxLength) {
+          entry.packedIntsVersion = meta.readVInt();
+          entry.blockSize = meta.readVInt();
+        }
+        binaries.put(fieldNumber, entry);
+      } else if (fieldType == FST) {
+        FSTEntry entry = new FSTEntry();
+        entry.offset = meta.readLong();
+        entry.numOrds = meta.readVLong();
+        fsts.put(fieldNumber, entry);
+      } else {
+        throw new CorruptIndexException("invalid entry type: " + fieldType + ", input=" + meta);
+      }
+      fieldNumber = meta.readVInt();
+    }
+  }
+
+  @Override
+  public synchronized NumericDocValues getNumeric(FieldInfo field)  {
+    NumericDocValues instance = numericInstances.get(field.number);
+    if (instance == null) {
+      instance = loadNumeric(field);
+      numericInstances.put(field.number, instance);
+    }
+    return instance;
+  }
+  
+  @Override
+  public long ramBytesUsed() {
+    return ramBytesUsed.get();
+  }
+  
+  @Override
+  public void checkIntegrity()  {
+    if (version >= VERSION_CHECKSUM) {
+      CodecUtil.checksumEntireFile(data);
+    }
+  }
+  
+  private NumericDocValues loadNumeric(FieldInfo field)  {
+    NumericEntry entry = numerics.get(field.number);
+    data.seek(entry.offset + entry.missingBytes);
+    switch (entry.format) {
+      case TABLE_COMPRESSED:
+        int size = data.readVInt();
+        if (size > 256) {
+          throw new CorruptIndexException("TABLE_COMPRESSED cannot have more than 256 distinct values, input=" + data);
+        }
+        final long decode[] = new long[size];
+        for (int i = 0; i < decode.length; i++) {
+          decode[i] = data.readLong();
+        }
+        final int formatID = data.readVInt();
+        final int bitsPerValue = data.readVInt();
+        final PackedInts.Reader ordsReader = PackedInts.getReaderNoHeader(data, PackedInts.Format.byId(formatID), entry.packedIntsVersion, maxDoc, bitsPerValue);
+        ramBytesUsed.addAndGet(RamUsageEstimator.sizeOf(decode) + ordsReader.ramBytesUsed());
+        return new NumericDocValues() {
+          @Override
+          public long get(int docID) {
+            return decode[(int)ordsReader.get(docID)];
+          }
+        };
+      case DELTA_COMPRESSED:
+        final int blockSize = data.readVInt();
+        final BlockPackedReader reader = new BlockPackedReader(data, entry.packedIntsVersion, blockSize, maxDoc, false);
+        ramBytesUsed.addAndGet(reader.ramBytesUsed());
+        return reader;
+      case UNCOMPRESSED:
+        final byte bytes[] = new byte[maxDoc];
+        data.readBytes(bytes, 0, bytes.length);
+        ramBytesUsed.addAndGet(RamUsageEstimator.sizeOf(bytes));
+        return new NumericDocValues() {
+          @Override
+          public long get(int docID) {
+            return bytes[docID];
+          }
+        };
+      case GCD_COMPRESSED:
+        final long min = data.readLong();
+        final long mult = data.readLong();
+        final int quotientBlockSize = data.readVInt();
+        final BlockPackedReader quotientReader = new BlockPackedReader(data, entry.packedIntsVersion, quotientBlockSize, maxDoc, false);
+        ramBytesUsed.addAndGet(quotientReader.ramBytesUsed());
+        return new NumericDocValues() {
+          @Override
+          public long get(int docID) {
+            return min + mult * quotientReader.get(docID);
+          }
+        };
+      default:
+        throw new Debug.Assert(ionError();
+    }
+  }
+
+  @Override
+  public synchronized BinaryDocValues getBinary(FieldInfo field)  {
+    BinaryDocValues instance = binaryInstances.get(field.number);
+    if (instance == null) {
+      instance = loadBinary(field);
+      binaryInstances.put(field.number, instance);
+    }
+    return instance;
+  }
+  
+  private BinaryDocValues loadBinary(FieldInfo field)  {
+    BinaryEntry entry = binaries.get(field.number);
+    data.seek(entry.offset);
+    PagedBytes bytes = new PagedBytes(16);
+    bytes.copy(data, entry.numBytes);
+    final PagedBytes.Reader bytesReader = bytes.freeze(true);
+    if (entry.minLength == entry.maxLength) {
+      final int fixedLength = entry.minLength;
+      ramBytesUsed.addAndGet(bytes.ramBytesUsed());
+      return new BinaryDocValues() {
+        @Override
+        public void get(int docID, BytesRef result) {
+          bytesReader.fillSlice(result, fixedLength * (long)docID, fixedLength);
+        }
+      };
+    } else {
+      data.seek(data.getFilePointer() + entry.missingBytes);
+      final MonotonicBlockPackedReader addresses = new MonotonicBlockPackedReader(data, entry.packedIntsVersion, entry.blockSize, maxDoc, false);
+      ramBytesUsed.addAndGet(bytes.ramBytesUsed() + addresses.ramBytesUsed());
+      return new BinaryDocValues() {
+        @Override
+        public void get(int docID, BytesRef result) {
+          long startAddress = docID == 0 ? 0 : addresses.get(docID-1);
+          long endAddress = addresses.get(docID); 
+          bytesReader.fillSlice(result, startAddress, (int) (endAddress - startAddress));
+        }
+      };
+    }
+  }
+  
+  @Override
+  public SortedDocValues getSorted(FieldInfo field)  {
+    final FSTEntry entry = fsts.get(field.number);
+    if (entry.numOrds == 0) {
+      return DocValues.EMPTY_SORTED;
+    }
+    FST<Long> instance;
+    synchronized(this) {
+      instance = fstInstances.get(field.number);
+      if (instance == null) {
+        data.seek(entry.offset);
+        instance = new FST<>(data, PositiveIntOutputs.getSingleton());
+        ramBytesUsed.addAndGet(instance.sizeInBytes());
+        fstInstances.put(field.number, instance);
+      }
+    }
+    final NumericDocValues docToOrd = getNumeric(field);
+    final FST<Long> fst = instance;
+    
+    // per-thread resources
+    final BytesReader in = fst.getBytesReader();
+    final Arc<Long> firstArc = new Arc<>();
+    final Arc<Long> scratchArc = new Arc<>();
+    final IntsRef scratchInts = new IntsRef();
+    final BytesRefFSTEnum<Long> fstEnum = new BytesRefFSTEnum<>(fst);
+    
+    return new SortedDocValues() {
+      @Override
+      public int getOrd(int docID) {
+        return (int) docToOrd.get(docID);
+      }
+
+      @Override
+      public void lookupOrd(int ord, BytesRef result) {
+        try {
+          in.setPosition(0);
+          fst.getFirstArc(firstArc);
+          IntsRef output = Util.getByOutput(fst, ord, in, firstArc, scratchArc, scratchInts);
+          result.bytes = new byte[output.length];
+          result.offset = 0;
+          result.length = 0;
+          Util.toBytesRef(output, result);
+        } catch (IOException bogus) {
+          throw new RuntimeException(bogus);
+        }
+      }
+
+      @Override
+      public int lookupTerm(BytesRef key) {
+        try {
+          InputOutput<Long> o = fstEnum.seekCeil(key);
+          if (o == null) {
+            return -getValueCount()-1;
+          } else if (o.input.equals(key)) {
+            return o.output.intValue();
+          } else {
+            return (int) -o.output-1;
+          }
+        } catch (IOException bogus) {
+          throw new RuntimeException(bogus);
+        }
+      }
+
+      @Override
+      public int getValueCount() {
+        return (int)entry.numOrds;
+      }
+
+      @Override
+      public TermsEnum termsEnum() {
+        return new FSTTermsEnum(fst);
+      }
+    };
+  }
+  
+  @Override
+  public SortedSetDocValues getSortedSet(FieldInfo field)  {
+    final FSTEntry entry = fsts.get(field.number);
+    if (entry.numOrds == 0) {
+      return DocValues.EMPTY_SORTED_SET; // empty FST!
+    }
+    FST<Long> instance;
+    synchronized(this) {
+      instance = fstInstances.get(field.number);
+      if (instance == null) {
+        data.seek(entry.offset);
+        instance = new FST<>(data, PositiveIntOutputs.getSingleton());
+        ramBytesUsed.addAndGet(instance.sizeInBytes());
+        fstInstances.put(field.number, instance);
+      }
+    }
+    final BinaryDocValues docToOrds = getBinary(field);
+    final FST<Long> fst = instance;
+    
+    // per-thread resources
+    final BytesReader in = fst.getBytesReader();
+    final Arc<Long> firstArc = new Arc<>();
+    final Arc<Long> scratchArc = new Arc<>();
+    final IntsRef scratchInts = new IntsRef();
+    final BytesRefFSTEnum<Long> fstEnum = new BytesRefFSTEnum<>(fst);
+    final BytesRef ref = new BytesRef();
+    final ByteArrayDataInput input = new ByteArrayDataInput();
+    return new SortedSetDocValues() {
+      long currentOrd;
+
+      @Override
+      public long nextOrd() {
+        if (input.eof()) {
+          return NO_MORE_ORDS;
+        } else {
+          currentOrd += input.readVLong();
+          return currentOrd;
+        }
+      }
+      
+      @Override
+      public void setDocument(int docID) {
+        docToOrds.get(docID, ref);
+        input.reset(ref.bytes, ref.offset, ref.length);
+        currentOrd = 0;
+      }
+
+      @Override
+      public void lookupOrd(long ord, BytesRef result) {
+        try {
+          in.setPosition(0);
+          fst.getFirstArc(firstArc);
+          IntsRef output = Util.getByOutput(fst, ord, in, firstArc, scratchArc, scratchInts);
+          result.bytes = new byte[output.length];
+          result.offset = 0;
+          result.length = 0;
+          Util.toBytesRef(output, result);
+        } catch (IOException bogus) {
+          throw new RuntimeException(bogus);
+        }
+      }
+
+      @Override
+      public long lookupTerm(BytesRef key) {
+        try {
+          InputOutput<Long> o = fstEnum.seekCeil(key);
+          if (o == null) {
+            return -getValueCount()-1;
+          } else if (o.input.equals(key)) {
+            return o.output.intValue();
+          } else {
+            return -o.output-1;
+          }
+        } catch (IOException bogus) {
+          throw new RuntimeException(bogus);
+        }
+      }
+
+      @Override
+      public long getValueCount() {
+        return entry.numOrds;
+      }
+
+      @Override
+      public TermsEnum termsEnum() {
+        return new FSTTermsEnum(fst);
+      }
+    };
+  }
+  
+  private Bits getMissingBits(int fieldNumber, final long offset, final long length)  {
+    if (offset == -1) {
+      return new Bits.MatchAllBits(maxDoc);
+    } else {
+      Bits instance;
+      synchronized(this) {
+        instance = docsWithFieldInstances.get(fieldNumber);
+        if (instance == null) {
+          IndexInput data = this.data.clone();
+          data.seek(offset);
+          Debug.Assert( length % 8 == 0;
+          long bits[] = new long[(int) length >> 3];
+          for (int i = 0; i < bits.length; i++) {
+            bits[i] = data.readLong();
+          }
+          instance = new FixedBitSet(bits, maxDoc);
+          docsWithFieldInstances.put(fieldNumber, instance);
+        }
+      }
+      return instance;
+    }
+  }
+  
+  @Override
+  public Bits getDocsWithField(FieldInfo field)  {
+    switch(field.getDocValuesType()) {
+      case SORTED_SET:
+        return DocValues.docsWithValue(getSortedSet(field), maxDoc);
+      case SORTED:
+        return DocValues.docsWithValue(getSorted(field), maxDoc);
+      case BINARY:
+        BinaryEntry be = binaries.get(field.number);
+        return getMissingBits(field.number, be.missingOffset, be.missingBytes);
+      case NUMERIC:
+        NumericEntry ne = numerics.get(field.number);
+        return getMissingBits(field.number, ne.missingOffset, ne.missingBytes);
+      default: 
+        throw new Debug.Assert(ionError();
+    }
+  }
+
+  @Override
+  public void close()  {
+    data.close();
+  }
+  
+  static class NumericEntry {
+    long offset;
+    long missingOffset;
+    long missingBytes;
+    byte format;
+    int packedIntsVersion;
+  }
+  
+  static class BinaryEntry {
+    long offset;
+    long missingOffset;
+    long missingBytes;
+    long numBytes;
+    int minLength;
+    int maxLength;
+    int packedIntsVersion;
+    int blockSize;
+  }
+  
+  static class FSTEntry {
+    long offset;
+    long numOrds;
+  }
+  
+  // exposes FSTEnum directly as a TermsEnum: avoids binary-search next()
+  static class FSTTermsEnum extends TermsEnum {
+    final BytesRefFSTEnum<Long> in;
+    
+    // this is all for the complicated seek(ord)...
+    // maybe we should add a FSTEnum that supports this operation?
+    final FST<Long> fst;
+    final FST.BytesReader bytesReader;
+    final Arc<Long> firstArc = new Arc<>();
+    final Arc<Long> scratchArc = new Arc<>();
+    final IntsRef scratchInts = new IntsRef();
+    final BytesRef scratchBytes = new BytesRef();
+    
+    FSTTermsEnum(FST<Long> fst) {
+      this.fst = fst;
+      in = new BytesRefFSTEnum<>(fst);
+      bytesReader = fst.getBytesReader();
+    }
+
+    @Override
+    public BytesRef next()  {
+      InputOutput<Long> io = in.next();
+      if (io == null) {
+        return null;
+      } else {
+        return io.input;
+      }
+    }
+
+    @Override
+    public Comparator<BytesRef> getComparator() {
+      return BytesRef.getUTF8SortedAsUnicodeComparator();
+    }
+
+    @Override
+    public SeekStatus seekCeil(BytesRef text)  {
+      if (in.seekCeil(text) == null) {
+        return SeekStatus.END;
+      } else if (term().equals(text)) {
+        // TODO: add SeekStatus to FSTEnum like in https://issues.apache.org/jira/browse/LUCENE-3729
+        // to remove this comparision?
+        return SeekStatus.FOUND;
+      } else {
+        return SeekStatus.NOT_FOUND;
+      }
+    }
+
+    @Override
+    public bool seekExact(BytesRef text)  {
+      if (in.seekExact(text) == null) {
+        return false;
+      } else {
+        return true;
+      }
+    }
+
+    @Override
+    public void seekExact(long ord)  {
+      // TODO: would be better to make this simpler and faster.
+      // but we dont want to introduce a bug that corrupts our enum state!
+      bytesReader.setPosition(0);
+      fst.getFirstArc(firstArc);
+      IntsRef output = Util.getByOutput(fst, ord, bytesReader, firstArc, scratchArc, scratchInts);
+      scratchBytes.bytes = new byte[output.length];
+      scratchBytes.offset = 0;
+      scratchBytes.length = 0;
+      Util.toBytesRef(output, scratchBytes);
+      // TODO: we could do this lazily, better to try to push into FSTEnum though?
+      in.seekExact(scratchBytes);
+    }
+
+    @Override
+    public BytesRef term()  {
+      return in.current().input;
+    }
+
+    @Override
+    public long ord()  {
+      return in.current().output;
+    }
+
+    @Override
+    public int docFreq()  {
+      throw new UnsupportedOperationException();
+    }
+
+    @Override
+    public long totalTermFreq()  {
+      throw new UnsupportedOperationException();
+    }
+
+    @Override
+    public DocsEnum docs(Bits liveDocs, DocsEnum reuse, int flags)  {
+      throw new UnsupportedOperationException();
+    }
+
+    @Override
+    public DocsAndPositionsEnum docsAndPositions(Bits liveDocs, DocsAndPositionsEnum reuse, int flags)  {
+      throw new UnsupportedOperationException();
+    }
+  }
+}

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/src/Lucene.Net.Codecs/Memory/MemoryPostingsFormat.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Codecs/Memory/MemoryPostingsFormat.cs b/src/Lucene.Net.Codecs/Memory/MemoryPostingsFormat.cs
new file mode 100644
index 0000000..ae5abca
--- /dev/null
+++ b/src/Lucene.Net.Codecs/Memory/MemoryPostingsFormat.cs
@@ -0,0 +1,936 @@
+package org.apache.lucene.codecs.memory;
+
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+import java.io.IOException;
+import java.util.Collections;
+import java.util.Comparator;
+import java.util.Iterator;
+import java.util.Map;
+import java.util.SortedMap;
+import java.util.TreeMap;
+
+import org.apache.lucene.codecs.CodecUtil;
+import org.apache.lucene.codecs.FieldsConsumer;
+import org.apache.lucene.codecs.FieldsProducer;
+import org.apache.lucene.codecs.PostingsConsumer;
+import org.apache.lucene.codecs.PostingsFormat;
+import org.apache.lucene.codecs.TermStats;
+import org.apache.lucene.codecs.TermsConsumer;
+import org.apache.lucene.index.DocsAndPositionsEnum;
+import org.apache.lucene.index.DocsEnum;
+import org.apache.lucene.index.FieldInfo.IndexOptions;
+import org.apache.lucene.index.FieldInfo;
+import org.apache.lucene.index.FieldInfos;
+import org.apache.lucene.index.IndexFileNames;
+import org.apache.lucene.index.SegmentReadState;
+import org.apache.lucene.index.SegmentWriteState;
+import org.apache.lucene.index.Terms;
+import org.apache.lucene.index.TermsEnum;
+import org.apache.lucene.store.ByteArrayDataInput;
+import org.apache.lucene.store.ChecksumIndexInput;
+import org.apache.lucene.store.IOContext;
+import org.apache.lucene.store.IndexInput;
+import org.apache.lucene.store.IndexOutput;
+import org.apache.lucene.store.RAMOutputStream;
+import org.apache.lucene.util.ArrayUtil;
+import org.apache.lucene.util.Bits;
+import org.apache.lucene.util.BytesRef;
+import org.apache.lucene.util.IOUtils;
+import org.apache.lucene.util.IntsRef;
+import org.apache.lucene.util.RamUsageEstimator;
+import org.apache.lucene.util.fst.Builder;
+import org.apache.lucene.util.fst.ByteSequenceOutputs;
+import org.apache.lucene.util.fst.BytesRefFSTEnum;
+import org.apache.lucene.util.fst.FST;
+import org.apache.lucene.util.fst.Util;
+import org.apache.lucene.util.packed.PackedInts;
+
+// TODO: would be nice to somehow allow this to act like
+// InstantiatedIndex, by never writing to disk; ie you write
+// to this Codec in RAM only and then when you open a reader
+// it pulls the FST directly from what you wrote w/o going
+// to disk.
+
+/** Stores terms & postings (docs, positions, payloads) in
+ *  RAM, using an FST.
+ *
+ * <p>Note that this codec implements advance as a linear
+ * scan!  This means if you store large fields in here,
+ * queries that rely on advance will (AND boolQuery,
+ * PhraseQuery) will be relatively slow!
+ *
+ * @lucene.experimental */
+
+// TODO: Maybe name this 'Cached' or something to reflect
+// the reality that it is actually written to disk, but
+// loads itself in ram?
+public final class MemoryPostingsFormat extends PostingsFormat {
+
+  private final bool doPackFST;
+  private final float acceptableOverheadRatio;
+
+  public MemoryPostingsFormat() {
+    this(false, PackedInts.DEFAULT);
+  }
+
+  /**
+   * Create MemoryPostingsFormat, specifying advanced FST options.
+   * @param doPackFST true if a packed FST should be built.
+   *        NOTE: packed FSTs are limited to ~2.1 GB of postings.
+   * @param acceptableOverheadRatio allowable overhead for packed ints
+   *        during FST construction.
+   */
+  public MemoryPostingsFormat(bool doPackFST, float acceptableOverheadRatio) {
+    super("Memory");
+    this.doPackFST = doPackFST;
+    this.acceptableOverheadRatio = acceptableOverheadRatio;
+  }
+  
+  @Override
+  public String toString() {
+    return "PostingsFormat(name=" + getName() + " doPackFST= " + doPackFST + ")";
+  }
+
+  private final static class TermsWriter extends TermsConsumer {
+    private final IndexOutput out;
+    private final FieldInfo field;
+    private final Builder<BytesRef> builder;
+    private final ByteSequenceOutputs outputs = ByteSequenceOutputs.getSingleton();
+    private final bool doPackFST;
+    private final float acceptableOverheadRatio;
+    private int termCount;
+
+    public TermsWriter(IndexOutput out, FieldInfo field, bool doPackFST, float acceptableOverheadRatio) {
+      this.out = out;
+      this.field = field;
+      this.doPackFST = doPackFST;
+      this.acceptableOverheadRatio = acceptableOverheadRatio;
+      builder = new Builder<>(FST.INPUT_TYPE.BYTE1, 0, 0, true, true, Integer.MAX_VALUE, outputs, null, doPackFST, acceptableOverheadRatio, true, 15);
+    }
+
+    private class PostingsWriter extends PostingsConsumer {
+      private int lastDocID;
+      private int lastPos;
+      private int lastPayloadLen;
+
+      // NOTE: not private so we don't pay access check at runtime:
+      int docCount;
+      RAMOutputStream buffer = new RAMOutputStream();
+      
+      int lastOffsetLength;
+      int lastOffset;
+
+      @Override
+      public void startDoc(int docID, int termDocFreq)  {
+        //System.out.println("    startDoc docID=" + docID + " freq=" + termDocFreq);
+        final int delta = docID - lastDocID;
+        Debug.Assert( docID == 0 || delta > 0;
+        lastDocID = docID;
+        docCount++;
+
+        if (field.getIndexOptions() == IndexOptions.DOCS_ONLY) {
+          buffer.writeVInt(delta);
+        } else if (termDocFreq == 1) {
+          buffer.writeVInt((delta<<1) | 1);
+        } else {
+          buffer.writeVInt(delta<<1);
+          Debug.Assert( termDocFreq > 0;
+          buffer.writeVInt(termDocFreq);
+        }
+
+        lastPos = 0;
+        lastOffset = 0;
+      }
+
+      @Override
+      public void addPosition(int pos, BytesRef payload, int startOffset, int endOffset)  {
+        Debug.Assert( payload == null || field.hasPayloads();
+
+        //System.out.println("      addPos pos=" + pos + " payload=" + payload);
+
+        final int delta = pos - lastPos;
+        Debug.Assert( delta >= 0;
+        lastPos = pos;
+        
+        int payloadLen = 0;
+        
+        if (field.hasPayloads()) {
+          payloadLen = payload == null ? 0 : payload.length;
+          if (payloadLen != lastPayloadLen) {
+            lastPayloadLen = payloadLen;
+            buffer.writeVInt((delta<<1)|1);
+            buffer.writeVInt(payloadLen);
+          } else {
+            buffer.writeVInt(delta<<1);
+          }
+        } else {
+          buffer.writeVInt(delta);
+        }
+        
+        if (field.getIndexOptions().compareTo(IndexOptions.DOCS_AND_FREQS_AND_POSITIONS_AND_OFFSETS) >= 0) {
+          // don't use startOffset - lastEndOffset, because this creates lots of negative vints for synonyms,
+          // and the numbers aren't that much smaller anyways.
+          int offsetDelta = startOffset - lastOffset;
+          int offsetLength = endOffset - startOffset;
+          if (offsetLength != lastOffsetLength) {
+            buffer.writeVInt(offsetDelta << 1 | 1);
+            buffer.writeVInt(offsetLength);
+          } else {
+            buffer.writeVInt(offsetDelta << 1);
+          }
+          lastOffset = startOffset;
+          lastOffsetLength = offsetLength;
+        }
+        
+        if (payloadLen > 0) {
+          buffer.writeBytes(payload.bytes, payload.offset, payloadLen);
+        }
+      }
+
+      @Override
+      public void finishDoc() {
+      }
+
+      public PostingsWriter reset() {
+        Debug.Assert( buffer.getFilePointer() == 0;
+        lastDocID = 0;
+        docCount = 0;
+        lastPayloadLen = 0;
+        // force first offset to write its length
+        lastOffsetLength = -1;
+        return this;
+      }
+    }
+
+    private final PostingsWriter postingsWriter = new PostingsWriter();
+
+    @Override
+    public PostingsConsumer startTerm(BytesRef text) {
+      //System.out.println("  startTerm term=" + text.utf8ToString());
+      return postingsWriter.reset();
+    }
+
+    private final RAMOutputStream buffer2 = new RAMOutputStream();
+    private final BytesRef spare = new BytesRef();
+    private byte[] finalBuffer = new byte[128];
+
+    private final IntsRef scratchIntsRef = new IntsRef();
+
+    @Override
+    public void finishTerm(BytesRef text, TermStats stats)  {
+
+      Debug.Assert( postingsWriter.docCount == stats.docFreq;
+
+      Debug.Assert( buffer2.getFilePointer() == 0;
+
+      buffer2.writeVInt(stats.docFreq);
+      if (field.getIndexOptions() != IndexOptions.DOCS_ONLY) {
+        buffer2.writeVLong(stats.totalTermFreq-stats.docFreq);
+      }
+      int pos = (int) buffer2.getFilePointer();
+      buffer2.writeTo(finalBuffer, 0);
+      buffer2.reset();
+
+      final int totalBytes = pos + (int) postingsWriter.buffer.getFilePointer();
+      if (totalBytes > finalBuffer.length) {
+        finalBuffer = ArrayUtil.grow(finalBuffer, totalBytes);
+      }
+      postingsWriter.buffer.writeTo(finalBuffer, pos);
+      postingsWriter.buffer.reset();
+
+      spare.bytes = finalBuffer;
+      spare.length = totalBytes;
+
+      //System.out.println("    finishTerm term=" + text.utf8ToString() + " " + totalBytes + " bytes totalTF=" + stats.totalTermFreq);
+      //for(int i=0;i<totalBytes;i++) {
+      //  System.out.println("      " + Integer.toHexString(finalBuffer[i]&0xFF));
+      //}
+
+      builder.add(Util.toIntsRef(text, scratchIntsRef), BytesRef.deepCopyOf(spare));
+      termCount++;
+    }
+
+    @Override
+    public void finish(long sumTotalTermFreq, long sumDocFreq, int docCount)  {
+      if (termCount > 0) {
+        out.writeVInt(termCount);
+        out.writeVInt(field.number);
+        if (field.getIndexOptions() != IndexOptions.DOCS_ONLY) {
+          out.writeVLong(sumTotalTermFreq);
+        }
+        out.writeVLong(sumDocFreq);
+        out.writeVInt(docCount);
+        FST<BytesRef> fst = builder.finish();
+        fst.save(out);
+        //System.out.println("finish field=" + field.name + " fp=" + out.getFilePointer());
+      }
+    }
+
+    @Override
+    public Comparator<BytesRef> getComparator() {
+      return BytesRef.getUTF8SortedAsUnicodeComparator();
+    }
+  }
+
+  private static String EXTENSION = "ram";
+  private static final String CODEC_NAME = "MemoryPostings";
+  private static final int VERSION_START = 0;
+  private static final int VERSION_CURRENT = VERSION_START;
+
+  @Override
+  public FieldsConsumer fieldsConsumer(SegmentWriteState state)  {
+
+    final String fileName = IndexFileNames.segmentFileName(state.segmentInfo.name, state.segmentSuffix, EXTENSION);
+    final IndexOutput out = state.directory.createOutput(fileName, state.context);
+    bool success = false;
+    try {
+      CodecUtil.writeHeader(out, CODEC_NAME, VERSION_CURRENT);
+      success = true;
+    } finally {
+      if (!success) {
+        IOUtils.closeWhileHandlingException(out);
+      }
+    }
+    
+    return new FieldsConsumer() {
+      @Override
+      public TermsConsumer addField(FieldInfo field) {
+        //System.out.println("\naddField field=" + field.name);
+        return new TermsWriter(out, field, doPackFST, acceptableOverheadRatio);
+      }
+
+      @Override
+      public void close()  {
+        // EOF marker:
+        try {
+          out.writeVInt(0);
+          CodecUtil.writeFooter(out);
+        } finally {
+          out.close();
+        }
+      }
+    };
+  }
+
+  private final static class FSTDocsEnum extends DocsEnum {
+    private final IndexOptions indexOptions;
+    private final bool storePayloads;
+    private byte[] buffer = new byte[16];
+    private final ByteArrayDataInput in = new ByteArrayDataInput(buffer);
+
+    private Bits liveDocs;
+    private int docUpto;
+    private int docID = -1;
+    private int accum;
+    private int freq;
+    private int payloadLen;
+    private int numDocs;
+
+    public FSTDocsEnum(IndexOptions indexOptions, bool storePayloads) {
+      this.indexOptions = indexOptions;
+      this.storePayloads = storePayloads;
+    }
+
+    public bool canReuse(IndexOptions indexOptions, bool storePayloads) {
+      return indexOptions == this.indexOptions && storePayloads == this.storePayloads;
+    }
+    
+    public FSTDocsEnum reset(BytesRef bufferIn, Bits liveDocs, int numDocs) {
+      Debug.Assert( numDocs > 0;
+      if (buffer.length < bufferIn.length) {
+        buffer = ArrayUtil.grow(buffer, bufferIn.length);
+      }
+      in.reset(buffer, 0, bufferIn.length);
+      System.arraycopy(bufferIn.bytes, bufferIn.offset, buffer, 0, bufferIn.length);
+      this.liveDocs = liveDocs;
+      docID = -1;
+      accum = 0;
+      docUpto = 0;
+      freq = 1;
+      payloadLen = 0;
+      this.numDocs = numDocs;
+      return this;
+    }
+
+    @Override
+    public int nextDoc() {
+      while(true) {
+        //System.out.println("  nextDoc cycle docUpto=" + docUpto + " numDocs=" + numDocs + " fp=" + in.getPosition() + " this=" + this);
+        if (docUpto == numDocs) {
+          // System.out.println("    END");
+          return docID = NO_MORE_DOCS;
+        }
+        docUpto++;
+        if (indexOptions == IndexOptions.DOCS_ONLY) {
+          accum += in.readVInt();
+        } else {
+          final int code = in.readVInt();
+          accum += code >>> 1;
+          //System.out.println("  docID=" + accum + " code=" + code);
+          if ((code & 1) != 0) {
+            freq = 1;
+          } else {
+            freq = in.readVInt();
+            Debug.Assert( freq > 0;
+          }
+
+          if (indexOptions == IndexOptions.DOCS_AND_FREQS_AND_POSITIONS) {
+            // Skip positions/payloads
+            for(int posUpto=0;posUpto<freq;posUpto++) {
+              if (!storePayloads) {
+                in.readVInt();
+              } else {
+                final int posCode = in.readVInt();
+                if ((posCode & 1) != 0) {
+                  payloadLen = in.readVInt();
+                }
+                in.skipBytes(payloadLen);
+              }
+            }
+          } else if (indexOptions == IndexOptions.DOCS_AND_FREQS_AND_POSITIONS_AND_OFFSETS) {
+            // Skip positions/offsets/payloads
+            for(int posUpto=0;posUpto<freq;posUpto++) {
+              int posCode = in.readVInt();
+              if (storePayloads && ((posCode & 1) != 0)) {
+                payloadLen = in.readVInt();
+              }
+              if ((in.readVInt() & 1) != 0) {
+                // new offset length
+                in.readVInt();
+              }
+              if (storePayloads) {
+                in.skipBytes(payloadLen);
+              }
+            }
+          }
+        }
+
+        if (liveDocs == null || liveDocs.get(accum)) {
+          //System.out.println("    return docID=" + accum + " freq=" + freq);
+          return (docID = accum);
+        }
+      }
+    }
+
+    @Override
+    public int docID() {
+      return docID;
+    }
+
+    @Override
+    public int advance(int target)  {
+      // TODO: we could make more efficient version, but, it
+      // should be rare that this will matter in practice
+      // since usually apps will not store "big" fields in
+      // this codec!
+      return slowAdvance(target);
+    }
+
+    @Override
+    public int freq() {
+      return freq;
+    }
+    
+    @Override
+    public long cost() {
+      return numDocs;
+    }
+  }
+
+  private final static class FSTDocsAndPositionsEnum extends DocsAndPositionsEnum {
+    private final bool storePayloads;
+    private byte[] buffer = new byte[16];
+    private final ByteArrayDataInput in = new ByteArrayDataInput(buffer);
+
+    private Bits liveDocs;
+    private int docUpto;
+    private int docID = -1;
+    private int accum;
+    private int freq;
+    private int numDocs;
+    private int posPending;
+    private int payloadLength;
+    final bool storeOffsets;
+    int offsetLength;
+    int startOffset;
+
+    private int pos;
+    private final BytesRef payload = new BytesRef();
+
+    public FSTDocsAndPositionsEnum(bool storePayloads, bool storeOffsets) {
+      this.storePayloads = storePayloads;
+      this.storeOffsets = storeOffsets;
+    }
+
+    public bool canReuse(bool storePayloads, bool storeOffsets) {
+      return storePayloads == this.storePayloads && storeOffsets == this.storeOffsets;
+    }
+    
+    public FSTDocsAndPositionsEnum reset(BytesRef bufferIn, Bits liveDocs, int numDocs) {
+      Debug.Assert( numDocs > 0;
+
+      // System.out.println("D&P reset bytes this=" + this);
+      // for(int i=bufferIn.offset;i<bufferIn.length;i++) {
+      //   System.out.println("  " + Integer.toHexString(bufferIn.bytes[i]&0xFF));
+      // }
+
+      if (buffer.length < bufferIn.length) {
+        buffer = ArrayUtil.grow(buffer, bufferIn.length);
+      }
+      in.reset(buffer, 0, bufferIn.length - bufferIn.offset);
+      System.arraycopy(bufferIn.bytes, bufferIn.offset, buffer, 0, bufferIn.length);
+      this.liveDocs = liveDocs;
+      docID = -1;
+      accum = 0;
+      docUpto = 0;
+      payload.bytes = buffer;
+      payloadLength = 0;
+      this.numDocs = numDocs;
+      posPending = 0;
+      startOffset = storeOffsets ? 0 : -1; // always return -1 if no offsets are stored
+      offsetLength = 0;
+      return this;
+    }
+
+    @Override
+    public int nextDoc() {
+      while (posPending > 0) {
+        nextPosition();
+      }
+      while(true) {
+        //System.out.println("  nextDoc cycle docUpto=" + docUpto + " numDocs=" + numDocs + " fp=" + in.getPosition() + " this=" + this);
+        if (docUpto == numDocs) {
+          //System.out.println("    END");
+          return docID = NO_MORE_DOCS;
+        }
+        docUpto++;
+        
+        final int code = in.readVInt();
+        accum += code >>> 1;
+        if ((code & 1) != 0) {
+          freq = 1;
+        } else {
+          freq = in.readVInt();
+          Debug.Assert( freq > 0;
+        }
+
+        if (liveDocs == null || liveDocs.get(accum)) {
+          pos = 0;
+          startOffset = storeOffsets ? 0 : -1;
+          posPending = freq;
+          //System.out.println("    return docID=" + accum + " freq=" + freq);
+          return (docID = accum);
+        }
+
+        // Skip positions
+        for(int posUpto=0;posUpto<freq;posUpto++) {
+          if (!storePayloads) {
+            in.readVInt();
+          } else {
+            final int skipCode = in.readVInt();
+            if ((skipCode & 1) != 0) {
+              payloadLength = in.readVInt();
+              //System.out.println("    new payloadLen=" + payloadLength);
+            }
+          }
+          
+          if (storeOffsets) {
+            if ((in.readVInt() & 1) != 0) {
+              // new offset length
+              offsetLength = in.readVInt();
+            }
+          }
+          
+          if (storePayloads) {
+            in.skipBytes(payloadLength);
+          }
+        }
+      }
+    }
+
+    @Override
+    public int nextPosition() {
+      //System.out.println("    nextPos storePayloads=" + storePayloads + " this=" + this);
+      Debug.Assert( posPending > 0;
+      posPending--;
+      if (!storePayloads) {
+        pos += in.readVInt();
+      } else {
+        final int code = in.readVInt();
+        pos += code >>> 1;
+        if ((code & 1) != 0) {
+          payloadLength = in.readVInt();
+          //System.out.println("      new payloadLen=" + payloadLength);
+          //} else {
+          //System.out.println("      same payloadLen=" + payloadLength);
+        }
+      }
+      
+      if (storeOffsets) {
+        int offsetCode = in.readVInt();
+        if ((offsetCode & 1) != 0) {
+          // new offset length
+          offsetLength = in.readVInt();
+        }
+        startOffset += offsetCode >>> 1;
+      }
+      
+      if (storePayloads) {
+        payload.offset = in.getPosition();
+        in.skipBytes(payloadLength);
+        payload.length = payloadLength;
+      }
+
+      //System.out.println("      pos=" + pos + " payload=" + payload + " fp=" + in.getPosition());
+      return pos;
+    }
+
+    @Override
+    public int startOffset() {
+      return startOffset;
+    }
+
+    @Override
+    public int endOffset() {
+      return startOffset + offsetLength;
+    }
+
+    @Override
+    public BytesRef getPayload() {
+      return payload.length > 0 ? payload : null;
+    }
+
+    @Override
+    public int docID() {
+      return docID;
+    }
+
+    @Override
+    public int advance(int target)  {
+      // TODO: we could make more efficient version, but, it
+      // should be rare that this will matter in practice
+      // since usually apps will not store "big" fields in
+      // this codec!
+      return slowAdvance(target);
+    }
+
+    @Override
+    public int freq() {
+      return freq;
+    }
+    
+    @Override
+    public long cost() {
+      return numDocs;
+    }
+  }
+
+  private final static class FSTTermsEnum extends TermsEnum {
+    private final FieldInfo field;
+    private final BytesRefFSTEnum<BytesRef> fstEnum;
+    private final ByteArrayDataInput buffer = new ByteArrayDataInput();
+    private bool didDecode;
+
+    private int docFreq;
+    private long totalTermFreq;
+    private BytesRefFSTEnum.InputOutput<BytesRef> current;
+    private BytesRef postingsSpare = new BytesRef();
+
+    public FSTTermsEnum(FieldInfo field, FST<BytesRef> fst) {
+      this.field = field;
+      fstEnum = new BytesRefFSTEnum<>(fst);
+    }
+
+    private void decodeMetaData() {
+      if (!didDecode) {
+        buffer.reset(current.output.bytes, current.output.offset, current.output.length);
+        docFreq = buffer.readVInt();
+        if (field.getIndexOptions() != IndexOptions.DOCS_ONLY) {
+          totalTermFreq = docFreq + buffer.readVLong();
+        } else {
+          totalTermFreq = -1;
+        }
+        postingsSpare.bytes = current.output.bytes;
+        postingsSpare.offset = buffer.getPosition();
+        postingsSpare.length = current.output.length - (buffer.getPosition() - current.output.offset);
+        //System.out.println("  df=" + docFreq + " totTF=" + totalTermFreq + " offset=" + buffer.getPosition() + " len=" + current.output.length);
+        didDecode = true;
+      }
+    }
+
+    @Override
+    public bool seekExact(BytesRef text)  {
+      //System.out.println("te.seekExact text=" + field.name + ":" + text.utf8ToString() + " this=" + this);
+      current = fstEnum.seekExact(text);
+      didDecode = false;
+      return current != null;
+    }
+
+    @Override
+    public SeekStatus seekCeil(BytesRef text)  {
+      //System.out.println("te.seek text=" + field.name + ":" + text.utf8ToString() + " this=" + this);
+      current = fstEnum.seekCeil(text);
+      if (current == null) {
+        return SeekStatus.END;
+      } else {
+
+        // System.out.println("  got term=" + current.input.utf8ToString());
+        // for(int i=0;i<current.output.length;i++) {
+        //   System.out.println("    " + Integer.toHexString(current.output.bytes[i]&0xFF));
+        // }
+
+        didDecode = false;
+
+        if (text.equals(current.input)) {
+          //System.out.println("  found!");
+          return SeekStatus.FOUND;
+        } else {
+          //System.out.println("  not found: " + current.input.utf8ToString());
+          return SeekStatus.NOT_FOUND;
+        }
+      }
+    }
+    
+    @Override
+    public DocsEnum docs(Bits liveDocs, DocsEnum reuse, int flags) {
+      decodeMetaData();
+      FSTDocsEnum docsEnum;
+
+      if (reuse == null || !(reuse instanceof FSTDocsEnum)) {
+        docsEnum = new FSTDocsEnum(field.getIndexOptions(), field.hasPayloads());
+      } else {
+        docsEnum = (FSTDocsEnum) reuse;        
+        if (!docsEnum.canReuse(field.getIndexOptions(), field.hasPayloads())) {
+          docsEnum = new FSTDocsEnum(field.getIndexOptions(), field.hasPayloads());
+        }
+      }
+      return docsEnum.reset(this.postingsSpare, liveDocs, docFreq);
+    }
+
+    @Override
+    public DocsAndPositionsEnum docsAndPositions(Bits liveDocs, DocsAndPositionsEnum reuse, int flags) {
+
+      bool hasOffsets = field.getIndexOptions().compareTo(IndexOptions.DOCS_AND_FREQS_AND_POSITIONS_AND_OFFSETS) >= 0;
+      if (field.getIndexOptions().compareTo(IndexOptions.DOCS_AND_FREQS_AND_POSITIONS) < 0) {
+        return null;
+      }
+      decodeMetaData();
+      FSTDocsAndPositionsEnum docsAndPositionsEnum;
+      if (reuse == null || !(reuse instanceof FSTDocsAndPositionsEnum)) {
+        docsAndPositionsEnum = new FSTDocsAndPositionsEnum(field.hasPayloads(), hasOffsets);
+      } else {
+        docsAndPositionsEnum = (FSTDocsAndPositionsEnum) reuse;        
+        if (!docsAndPositionsEnum.canReuse(field.hasPayloads(), hasOffsets)) {
+          docsAndPositionsEnum = new FSTDocsAndPositionsEnum(field.hasPayloads(), hasOffsets);
+        }
+      }
+      //System.out.println("D&P reset this=" + this);
+      return docsAndPositionsEnum.reset(postingsSpare, liveDocs, docFreq);
+    }
+
+    @Override
+    public BytesRef term() {
+      return current.input;
+    }
+
+    @Override
+    public BytesRef next()  {
+      //System.out.println("te.next");
+      current = fstEnum.next();
+      if (current == null) {
+        //System.out.println("  END");
+        return null;
+      }
+      didDecode = false;
+      //System.out.println("  term=" + field.name + ":" + current.input.utf8ToString());
+      return current.input;
+    }
+
+    @Override
+    public int docFreq() {
+      decodeMetaData();
+      return docFreq;
+    }
+
+    @Override
+    public long totalTermFreq() {
+      decodeMetaData();
+      return totalTermFreq;
+    }
+
+    @Override
+    public Comparator<BytesRef> getComparator() {
+      return BytesRef.getUTF8SortedAsUnicodeComparator();
+    }
+
+    @Override
+    public void seekExact(long ord) {
+      // NOTE: we could add this...
+      throw new UnsupportedOperationException();
+    }
+
+    @Override
+    public long ord() {
+      // NOTE: we could add this...
+      throw new UnsupportedOperationException();
+    }
+  }
+
+  private final static class TermsReader extends Terms {
+
+    private final long sumTotalTermFreq;
+    private final long sumDocFreq;
+    private final int docCount;
+    private final int termCount;
+    private FST<BytesRef> fst;
+    private final ByteSequenceOutputs outputs = ByteSequenceOutputs.getSingleton();
+    private final FieldInfo field;
+
+    public TermsReader(FieldInfos fieldInfos, IndexInput in, int termCount)  {
+      this.termCount = termCount;
+      final int fieldNumber = in.readVInt();
+      field = fieldInfos.fieldInfo(fieldNumber);
+      if (field.getIndexOptions() != IndexOptions.DOCS_ONLY) {
+        sumTotalTermFreq = in.readVLong();
+      } else {
+        sumTotalTermFreq = -1;
+      }
+      sumDocFreq = in.readVLong();
+      docCount = in.readVInt();
+      
+      fst = new FST<>(in, outputs);
+    }
+
+    @Override
+    public long getSumTotalTermFreq() {
+      return sumTotalTermFreq;
+    }
+
+    @Override
+    public long getSumDocFreq() {
+      return sumDocFreq;
+    }
+
+    @Override
+    public int getDocCount() {
+      return docCount;
+    }
+
+    @Override
+    public long size() {
+      return termCount;
+    }
+
+    @Override
+    public TermsEnum iterator(TermsEnum reuse) {
+      return new FSTTermsEnum(field, fst);
+    }
+
+    @Override
+    public Comparator<BytesRef> getComparator() {
+      return BytesRef.getUTF8SortedAsUnicodeComparator();
+    }
+
+    @Override
+    public bool hasFreqs() {
+      return field.getIndexOptions().compareTo(IndexOptions.DOCS_AND_FREQS) >= 0;
+    }
+
+    @Override
+    public bool hasOffsets() {
+      return field.getIndexOptions().compareTo(IndexOptions.DOCS_AND_FREQS_AND_POSITIONS_AND_OFFSETS) >= 0;
+    }
+
+    @Override
+    public bool hasPositions() {
+      return field.getIndexOptions().compareTo(IndexOptions.DOCS_AND_FREQS_AND_POSITIONS) >= 0;
+    }
+    
+    @Override
+    public bool hasPayloads() {
+      return field.hasPayloads();
+    }
+
+    public long ramBytesUsed() {
+      return ((fst!=null) ? fst.sizeInBytes() : 0);
+    }
+  }
+
+  @Override
+  public FieldsProducer fieldsProducer(SegmentReadState state)  {
+    final String fileName = IndexFileNames.segmentFileName(state.segmentInfo.name, state.segmentSuffix, EXTENSION);
+    final ChecksumIndexInput in = state.directory.openChecksumInput(fileName, IOContext.READONCE);
+
+    final SortedMap<String,TermsReader> fields = new TreeMap<>();
+
+    try {
+      CodecUtil.checkHeader(in, CODEC_NAME, VERSION_START, VERSION_CURRENT);
+      while(true) {
+        final int termCount = in.readVInt();
+        if (termCount == 0) {
+          break;
+        }
+        final TermsReader termsReader = new TermsReader(state.fieldInfos, in, termCount);
+        // System.out.println("load field=" + termsReader.field.name);
+        fields.put(termsReader.field.name, termsReader);
+      }
+      CodecUtil.checkFooter(in);
+    } finally {
+      in.close();
+    }
+
+    return new FieldsProducer() {
+      @Override
+      public Iterator<String> iterator() {
+        return Collections.unmodifiableSet(fields.keySet()).iterator();
+      }
+
+      @Override
+      public Terms terms(String field) {
+        return fields.get(field);
+      }
+      
+      @Override
+      public int size() {
+        return fields.size();
+      }
+
+      @Override
+      public void close() {
+        // Drop ref to FST:
+        for(TermsReader termsReader : fields.values()) {
+          termsReader.fst = null;
+        }
+      }
+
+      @Override
+      public long ramBytesUsed() {
+        long sizeInBytes = 0;
+        for(Map.Entry<String,TermsReader> entry: fields.entrySet()) {
+          sizeInBytes += (entry.getKey().length() * RamUsageEstimator.NUM_BYTES_CHAR);
+          sizeInBytes += entry.getValue().ramBytesUsed();
+        }
+        return sizeInBytes;
+      }
+      
+      @Override
+      public void checkIntegrity()  {}
+    };
+  }
+}

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/src/Lucene.Net.Codecs/Properties/AssemblyInfo.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Codecs/Properties/AssemblyInfo.cs b/src/Lucene.Net.Codecs/Properties/AssemblyInfo.cs
new file mode 100644
index 0000000..152a9c0
--- /dev/null
+++ b/src/Lucene.Net.Codecs/Properties/AssemblyInfo.cs
@@ -0,0 +1,36 @@
+using System.Reflection;
+using System.Runtime.CompilerServices;
+using System.Runtime.InteropServices;
+
+// General Information about an assembly is controlled through the following 
+// set of attributes. Change these attribute values to modify the information
+// associated with an assembly.
+[assembly: AssemblyTitle("Codecs")]
+[assembly: AssemblyDescription("")]
+[assembly: AssemblyConfiguration("")]
+[assembly: AssemblyCompany("")]
+[assembly: AssemblyProduct("Codecs")]
+[assembly: AssemblyCopyright("Copyright ©  2014")]
+[assembly: AssemblyTrademark("")]
+[assembly: AssemblyCulture("")]
+
+// Setting ComVisible to false makes the types in this assembly not visible 
+// to COM components.  If you need to access a type in this assembly from 
+// COM, set the ComVisible attribute to true on that type.
+[assembly: ComVisible(false)]
+
+// The following GUID is for the ID of the typelib if this project is exposed to COM
+[assembly: Guid("03ad88e5-c647-4821-9c75-ca5507ab18f0")]
+
+// Version information for an assembly consists of the following four values:
+//
+//      Major Version
+//      Minor Version 
+//      Build Number
+//      Revision
+//
+// You can specify all the values or you can default the Build and Revision Numbers 
+// by using the '*' as shown below:
+// [assembly: AssemblyVersion("1.0.*")]
+[assembly: AssemblyVersion("1.0.0.0")]
+[assembly: AssemblyFileVersion("1.0.0.0")]

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/src/Lucene.Net.Codecs/Pulsing/Pulsing41PostingsFormat.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Codecs/Pulsing/Pulsing41PostingsFormat.cs b/src/Lucene.Net.Codecs/Pulsing/Pulsing41PostingsFormat.cs
new file mode 100644
index 0000000..f2634f4
--- /dev/null
+++ b/src/Lucene.Net.Codecs/Pulsing/Pulsing41PostingsFormat.cs
@@ -0,0 +1,47 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+namespace Lucene.Net.Codecs.Pulsing
+{
+    using Lucene.Net.Codecs.Lucene41;
+
+    /// <summary>
+    /// Concrete pulsing implementation over {@link Lucene41PostingsFormat}.
+    /// 
+    /// @lucene.experimental 
+    /// </summary>
+    public class Pulsing41PostingsFormat : PulsingPostingsFormat
+    {
+
+        /// <summary>Inlines docFreq=1 terms, otherwise uses the normal "Lucene41" format.</summary>
+        public Pulsing41PostingsFormat() : this(1)
+        {
+        }
+
+        /// <summary>Inlines docFreq=<code>freqCutoff</code> terms, otherwise uses the normal "Lucene41" format.</summary>
+        public Pulsing41PostingsFormat(int freqCutoff) :
+            this(freqCutoff, BlockTreeTermsWriter.DEFAULT_MIN_BLOCK_SIZE, BlockTreeTermsWriter.DEFAULT_MAX_BLOCK_SIZE)
+        {
+        }
+
+        /// <summary>Inlines docFreq=<code>freqCutoff</code> terms, otherwise uses the normal "Lucene41" format.</summary>
+        public Pulsing41PostingsFormat(int freqCutoff, int minBlockSize, int maxBlockSize) :
+            base("Pulsing41", new Lucene41PostingsBaseFormat(), freqCutoff, minBlockSize, maxBlockSize)
+        {
+        }
+    }
+}


[37/51] [abbrv] [partial] Cleaning up and getting ready to development towards v4.8

Posted by sy...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Gallio.UI.xml
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Gallio.UI.xml b/lib/Gallio.3.2.750/tools/Gallio.UI.xml
deleted file mode 100644
index 36749cb..0000000
--- a/lib/Gallio.3.2.750/tools/Gallio.UI.xml
+++ /dev/null
@@ -1,1373 +0,0 @@
-<?xml version="1.0"?>
-<doc>
-    <assembly>
-        <name>Gallio.UI</name>
-    </assembly>
-    <members>
-        <member name="T:Gallio.UI.Common.Policies.IUnhandledExceptionPolicy">
-            <summary>
-             Wrapper for static <see cref="T:Gallio.Common.Policies.UnhandledExceptionPolicy">UnhandledExceptionPolicy</see> 
-             class (to improve testability).
-            </summary>
-        </member>
-        <member name="M:Gallio.UI.Common.Policies.IUnhandledExceptionPolicy.Report(System.String,System.Exception)">
-            <summary>
-            Reports an unhandled exception.
-            </summary>
-            <param name="message">A message to explain how the exception was intercepted.</param>
-            <param name="unhandledException">The unhandled exception.</param>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="message"/> or 
-            <paramref name="unhandledException"/> is null.</exception>
-        </member>
-        <member name="T:Gallio.UI.Common.Policies.UnhandledExceptionPolicy">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.UI.Common.Policies.UnhandledExceptionPolicy.Report(System.String,System.Exception)">
-            <inheritdoc />
-        </member>
-        <member name="T:Gallio.UI.Common.Synchronization.SynchronizationContext">
-            <summary>
-             Holder for the current sync context (e.g. the winforms current).
-            </summary>
-        </member>
-        <member name="M:Gallio.UI.Common.Synchronization.SynchronizationContext.Send(System.Threading.SendOrPostCallback,System.Object)">
-            <summary>
-            Wrapper for Send on the shared sync context.
-            </summary>
-            <param name="sendOrPostCallback">The SendOrPostCallback delegate to call.</param>
-            <param name="state">The object passed to the delegate.</param>
-        </member>
-        <member name="M:Gallio.UI.Common.Synchronization.SynchronizationContext.Post(System.Threading.SendOrPostCallback,System.Object)">
-            <summary>
-            Wrapper for Post on the shared sync context.
-            </summary>
-            <param name="sendOrPostCallback">The SendOrPostCallback delegate to call.</param>
-            <param name="state">The object passed to the delegate.</param>
-        </member>
-        <member name="P:Gallio.UI.Common.Synchronization.SynchronizationContext.Current">
-            <summary>
-             Returns a shared SynchronizationContext instance.
-            </summary>
-             <remarks>
-             Usually used to stash a reference to the win forms synchronization 
-             context (WindowsFormsSynchronizationContext.Current), used for 
-             cross-thread data binding.
-             </remarks>
-        </member>
-        <member name="T:Gallio.UI.ControlPanel.ControlPanelPresenter">
-            <summary>
-            Presents the control panel dialog.
-            </summary>
-        </member>
-        <member name="T:Gallio.UI.ControlPanel.IControlPanelPresenter">
-            <summary>
-            Presents the control panel dialog.
-            </summary>
-        </member>
-        <member name="M:Gallio.UI.ControlPanel.IControlPanelPresenter.Show(System.Windows.Forms.IWin32Window)">
-            <summary>
-            Shows the control panel dialog.
-            </summary>
-            <param name="owner">The dialog owner control.</param>
-            <returns>The dialog result, either <see cref="F:System.Windows.Forms.DialogResult.OK"/>
-            or <see cref="F:System.Windows.Forms.DialogResult.Cancel"/> depending on how the dialog
-            was closed.</returns>
-        </member>
-        <member name="M:Gallio.UI.ControlPanel.ControlPanelPresenter.#ctor(Gallio.Runtime.Extensibility.ComponentHandle{Gallio.UI.ControlPanel.IControlPanelTabProvider,Gallio.UI.ControlPanel.ControlPanelTabProviderTraits}[],Gallio.Runtime.Security.IElevationManager)">
-            <summary>
-            Creates a control panel presenter.
-            </summary>
-            <param name="controlPanelTabProviderHandles">The preference page provider handles, not null.</param>
-            <param name="elevationManager">The elevation manager, not null.</param>
-        </member>
-        <member name="M:Gallio.UI.ControlPanel.ControlPanelPresenter.Show(System.Windows.Forms.IWin32Window)">
-            <inheritdoc />
-        </member>
-        <member name="T:Gallio.UI.ControlPanel.ControlPanelTab">
-            <summary>
-            Base class for components that present control panel tabs.
-            </summary>
-        </member>
-        <member name="T:Gallio.UI.ControlPanel.SettingsEditor">
-            <summary>
-            Base class for user controls for editing settings with deferred application.
-            </summary>
-        </member>
-        <member name="M:Gallio.UI.ControlPanel.SettingsEditor.ApplyPendingSettingsChanges(Gallio.Runtime.Security.IElevationContext,Gallio.Runtime.ProgressMonitoring.IProgressMonitor)">
-            <summary>
-            Applies pending settings changes.
-            </summary>
-            <param name="elevationContext">An elevation context when <see cref="P:Gallio.UI.ControlPanel.SettingsEditor.RequiresElevation"/>
-            is true, otherwise null.</param>
-            <param name="progressMonitor">The progress monitor, not null.</param>
-            <remarks>
-            The default implementation simply sets <see cref="P:Gallio.UI.ControlPanel.SettingsEditor.PendingSettingsChanges"/> to false.
-            </remarks>
-        </member>
-        <member name="M:Gallio.UI.ControlPanel.SettingsEditor.OnPendingSettingsChangesChanged(System.EventArgs)">
-            <summary>
-            Raises the <see cref="P:Gallio.UI.ControlPanel.SettingsEditor.PendingSettingsChanges"/> event.
-            </summary>
-            <param name="e">The event arguments.</param>
-        </member>
-        <member name="M:Gallio.UI.ControlPanel.SettingsEditor.OnRequiresElevationChanged(System.EventArgs)">
-            <summary>
-            Raises the <see cref="E:Gallio.UI.ControlPanel.SettingsEditor.RequiresElevationChanged"/> event.
-            </summary>
-            <param name="e">The event arguments.</param>
-        </member>
-        <member name="E:Gallio.UI.ControlPanel.SettingsEditor.PendingSettingsChangesChanged">
-            <summary>
-            Event raised when the value of <see cref="P:Gallio.UI.ControlPanel.SettingsEditor.PendingSettingsChanges"/> changes.
-            </summary>
-        </member>
-        <member name="E:Gallio.UI.ControlPanel.SettingsEditor.RequiresElevationChanged">
-            <summary>
-            Event raised when the value of <see cref="P:Gallio.UI.ControlPanel.SettingsEditor.RequiresElevation"/> changes.
-            </summary>
-        </member>
-        <member name="P:Gallio.UI.ControlPanel.SettingsEditor.PendingSettingsChanges">
-            <summary>
-            Gets or sets whether there are pending settings changes yet to be applied.
-            </summary>
-        </member>
-        <member name="P:Gallio.UI.ControlPanel.SettingsEditor.RequiresElevation">
-            <summary>
-            Gets or sets whether elevation will be required to apply pending modifications.
-            </summary>
-        </member>
-        <member name="M:Gallio.UI.ControlPanel.ControlPanelTab.#ctor">
-            <summary>
-            Creates a control panel tab.
-            </summary>
-        </member>
-        <member name="F:Gallio.UI.ControlPanel.ControlPanelTab.components">
-            <summary> 
-            Required designer variable.
-            </summary>
-        </member>
-        <member name="M:Gallio.UI.ControlPanel.ControlPanelTab.Dispose(System.Boolean)">
-            <summary> 
-            Clean up any resources being used.
-            </summary>
-            <param name="disposing">true if managed resources should be disposed; otherwise, false.</param>
-        </member>
-        <member name="M:Gallio.UI.ControlPanel.ControlPanelTab.InitializeComponent">
-            <summary> 
-            Required method for Designer support - do not modify 
-            the contents of this method with the code editor.
-            </summary>
-        </member>
-        <member name="T:Gallio.UI.ControlPanel.ControlPanelTabProviderTraits">
-            <summary>
-            Describes the traits of a <see cref="T:Gallio.UI.ControlPanel.IControlPanelTabProvider"/>.
-            </summary>
-        </member>
-        <member name="M:Gallio.UI.ControlPanel.ControlPanelTabProviderTraits.#ctor(System.String)">
-            <summary>
-            Creates a traits object for a control panel tab provider.
-            </summary>
-            <param name="name">The control panel tab name.</param>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="name"/> is null.</exception>
-            <exception cref="T:System.ArgumentException">Thrown if <paramref name="name"/> is empty.</exception>
-        </member>
-        <member name="P:Gallio.UI.ControlPanel.ControlPanelTabProviderTraits.Name">
-            <summary>
-            Gets the control panel tab name.
-            </summary>
-        </member>
-        <member name="P:Gallio.UI.ControlPanel.ControlPanelTabProviderTraits.Order">
-            <summary>
-            Gets or sets an integer index used to sort control panel tabs in ascending order.
-            </summary>
-        </member>
-        <member name="T:Gallio.UI.ControlPanel.IControlPanelTabProvider">
-            <summary>
-            Provides a preference pane to be incorporated into the Gallio control panel.
-            </summary>
-        </member>
-        <member name="M:Gallio.UI.ControlPanel.IControlPanelTabProvider.CreateControlPanelTab">
-            <summary>
-            Creates a control panel tab to include in the control panel.
-            </summary>
-            <returns>The control panel tab.</returns>
-        </member>
-        <member name="T:Gallio.UI.ControlPanel.ControlPanelDialog">
-            <summary>
-            Presents a dialog with control panel options.
-            </summary>
-        </member>
-        <member name="M:Gallio.UI.ControlPanel.ControlPanelDialog.#ctor">
-            <summary>
-            Creates a control panel dialog.
-            </summary>
-        </member>
-        <member name="M:Gallio.UI.ControlPanel.ControlPanelDialog.AddTab(System.String,Gallio.Common.Func{Gallio.UI.ControlPanel.ControlPanelTab})">
-            <summary>
-            Adds a tab.
-            </summary>
-            <param name="name">The tab name.</param>
-            <param name="tabFactory">The tab factory.</param>
-        </member>
-        <member name="F:Gallio.UI.ControlPanel.ControlPanelDialog.components">
-            <summary>
-            Required designer variable.
-            </summary>
-        </member>
-        <member name="M:Gallio.UI.ControlPanel.ControlPanelDialog.Dispose(System.Boolean)">
-            <summary>
-            Clean up any resources being used.
-            </summary>
-            <param name="disposing">true if managed resources should be disposed; otherwise, false.</param>
-        </member>
-        <member name="M:Gallio.UI.ControlPanel.ControlPanelDialog.InitializeComponent">
-            <summary>
-            Required method for Designer support - do not modify
-            the contents of this method with the code editor.
-            </summary>
-        </member>
-        <member name="P:Gallio.UI.ControlPanel.ControlPanelDialog.ElevationManager">
-            <summary>
-            Gets or sets the elevation manager used to obtain an elevation context.
-            </summary>
-        </member>
-        <member name="P:Gallio.UI.ControlPanel.ControlPanelDialog.ProgressMonitorProvider">
-            <summary>
-            Gets or sets the progress monitor provider to use.
-            </summary>
-        </member>
-        <member name="T:Gallio.UI.ControlPanel.Plugins.NamespaceDoc">
-            <summary>
-            The Gallio.UI.ControlPanel.Plugins namespace contains types for a standard Control
-            Panel extension that displays installed plugins.
-            </summary>
-        </member>
-        <member name="F:Gallio.UI.ControlPanel.Plugins.PluginControlPanelTab.components">
-            <summary> 
-            Required designer variable.
-            </summary>
-        </member>
-        <member name="M:Gallio.UI.ControlPanel.Plugins.PluginControlPanelTab.Dispose(System.Boolean)">
-            <summary> 
-            Clean up any resources being used.
-            </summary>
-            <param name="disposing">true if managed resources should be disposed; otherwise, false.</param>
-        </member>
-        <member name="M:Gallio.UI.ControlPanel.Plugins.PluginControlPanelTab.InitializeComponent">
-            <summary> 
-            Required method for Designer support - do not modify 
-            the contents of this method with the code editor.
-            </summary>
-        </member>
-        <member name="T:Gallio.UI.ControlPanel.Plugins.PluginControlPanelTabProvider">
-            <summary>
-            A control panel tab for managing installed plugins.
-            </summary>
-        </member>
-        <member name="M:Gallio.UI.ControlPanel.Plugins.PluginControlPanelTabProvider.#ctor(Gallio.Runtime.Extensibility.IRegistry)">
-            <summary>
-            Creates a control panel tab for managing installed plugins.
-            </summary>
-            <param name="registry">The plugin registry, not null.</param>
-        </member>
-        <member name="M:Gallio.UI.ControlPanel.Plugins.PluginControlPanelTabProvider.CreateControlPanelTab">
-            <inheritdoc />
-        </member>
-        <member name="T:Gallio.UI.ControlPanel.Preferences.NamespaceDoc">
-            <summary>
-            The Gallio.UI.ControlPanel namespace contains types for using and extending the
-            Preference Tab of the Gallio Control Panel UI.
-            </summary>
-        </member>
-        <member name="T:Gallio.UI.ControlPanel.Preferences.PreferencePaneContainer">
-            <summary>
-            Contains a preference pane and decorates it with a title.
-            </summary>
-        </member>
-        <member name="F:Gallio.UI.ControlPanel.Preferences.PreferencePaneContainer.components">
-            <summary> 
-            Required designer variable.
-            </summary>
-        </member>
-        <member name="M:Gallio.UI.ControlPanel.Preferences.PreferencePaneContainer.Dispose(System.Boolean)">
-            <summary> 
-            Clean up any resources being used.
-            </summary>
-            <param name="disposing">true if managed resources should be disposed; otherwise, false.</param>
-        </member>
-        <member name="M:Gallio.UI.ControlPanel.Preferences.PreferencePaneContainer.InitializeComponent">
-            <summary> 
-            Required method for Designer support - do not modify 
-            the contents of this method with the code editor.
-            </summary>
-        </member>
-        <member name="P:Gallio.UI.ControlPanel.Preferences.PreferencePaneContainer.PreferencePane">
-            <summary>
-            Gets or sets the preference pane, or null if none.
-            </summary>
-        </member>
-        <member name="P:Gallio.UI.ControlPanel.Preferences.PreferencePaneContainer.Title">
-            <summary>
-            Gets or sets the preference pane title, or null if none.
-            </summary>
-        </member>
-        <member name="T:Gallio.UI.ControlPanel.Preferences.PreferencePaneScope">
-            <summary>
-            Specifies the scope of the changes effected by a preference pane.
-            </summary>
-        </member>
-        <member name="F:Gallio.UI.ControlPanel.Preferences.PreferencePaneScope.User">
-            <summary>
-            Changes affect the current user only.
-            </summary>
-        </member>
-        <member name="F:Gallio.UI.ControlPanel.Preferences.PreferencePaneScope.Machine">
-            <summary>
-            Changes affect all users of the machine.
-            </summary>
-        </member>
-        <member name="T:Gallio.UI.ControlPanel.Preferences.RuntimePreferencePaneCommitterElevatedCommand">
-            <summary>
-            Applies changes made by the <see cref="T:Gallio.UI.ControlPanel.Preferences.RuntimePreferencePane"/>.
-            </summary>
-        </member>
-        <member name="M:Gallio.UI.ControlPanel.Preferences.RuntimePreferencePaneCommitterElevatedCommand.Execute(Gallio.Runtime.InstallationConfiguration,Gallio.Runtime.ProgressMonitoring.IProgressMonitor)">
-            <inheritdoc />
-        </member>
-        <member name="T:Gallio.UI.ControlPanel.Preferences.PreferencePane">
-            <summary>
-            Base class for components that present preference panels.
-            </summary>
-        </member>
-        <member name="M:Gallio.UI.ControlPanel.Preferences.PreferencePane.#ctor">
-            <summary>
-            Creates a preference pane.
-            </summary>
-        </member>
-        <member name="F:Gallio.UI.ControlPanel.Preferences.PreferencePane.components">
-            <summary> 
-            Required designer variable.
-            </summary>
-        </member>
-        <member name="M:Gallio.UI.ControlPanel.Preferences.PreferencePane.Dispose(System.Boolean)">
-            <summary> 
-            Clean up any resources being used.
-            </summary>
-            <param name="disposing">true if managed resources should be disposed; otherwise, false.</param>
-        </member>
-        <member name="M:Gallio.UI.ControlPanel.Preferences.PreferencePane.InitializeComponent">
-            <summary> 
-            Required method for Designer support - do not modify 
-            the contents of this method with the code editor.
-            </summary>
-        </member>
-        <member name="F:Gallio.UI.ControlPanel.Preferences.PlaceholderPreferencePane.components">
-            <summary> 
-            Required designer variable.
-            </summary>
-        </member>
-        <member name="M:Gallio.UI.ControlPanel.Preferences.PlaceholderPreferencePane.Dispose(System.Boolean)">
-            <summary> 
-            Clean up any resources being used.
-            </summary>
-            <param name="disposing">true if managed resources should be disposed; otherwise, false.</param>
-        </member>
-        <member name="M:Gallio.UI.ControlPanel.Preferences.PlaceholderPreferencePane.InitializeComponent">
-            <summary> 
-            Required method for Designer support - do not modify 
-            the contents of this method with the code editor.
-            </summary>
-        </member>
-        <member name="T:Gallio.UI.ControlPanel.Preferences.PlaceholderPreferencePaneProvider">
-            <summary>
-            A preference pane provider that is used as an empty placeholder for a
-            non-leaf node in the preference pane tree.
-            </summary>
-        </member>
-        <member name="T:Gallio.UI.ControlPanel.Preferences.IPreferencePaneProvider">
-            <summary>
-            Provides a preference pane to be incorporated into the Gallio control panel.
-            </summary>
-        </member>
-        <member name="M:Gallio.UI.ControlPanel.Preferences.IPreferencePaneProvider.CreatePreferencePane">
-            <summary>
-            Creates a preference pane to include in the control panel.
-            </summary>
-            <returns>The preference pane.</returns>
-        </member>
-        <member name="M:Gallio.UI.ControlPanel.Preferences.PlaceholderPreferencePaneProvider.CreatePreferencePane">
-            <inheritdoc />
-        </member>
-        <member name="F:Gallio.UI.ControlPanel.Preferences.RuntimePreferencePane.components">
-            <summary> 
-            Required designer variable.
-            </summary>
-        </member>
-        <member name="M:Gallio.UI.ControlPanel.Preferences.RuntimePreferencePane.Dispose(System.Boolean)">
-            <summary> 
-            Clean up any resources being used.
-            </summary>
-            <param name="disposing">true if managed resources should be disposed; otherwise, false.</param>
-        </member>
-        <member name="M:Gallio.UI.ControlPanel.Preferences.RuntimePreferencePane.InitializeComponent">
-            <summary> 
-            Required method for Designer support - do not modify 
-            the contents of this method with the code editor.
-            </summary>
-        </member>
-        <member name="T:Gallio.UI.ControlPanel.Preferences.RuntimePreferencePaneProvider">
-            <summary>
-            Provides the preference pane for the Gallio runtime paths.
-            </summary>
-        </member>
-        <member name="M:Gallio.UI.ControlPanel.Preferences.RuntimePreferencePaneProvider.CreatePreferencePane">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.UI.ControlPanel.Preferences.PreferenceControlPanelTab.AddPane(System.String,System.Drawing.Icon,Gallio.UI.ControlPanel.Preferences.PreferencePaneScope,Gallio.Common.Func{Gallio.UI.ControlPanel.Preferences.PreferencePane})">
-            <summary>
-            Adds a preference pane.
-            </summary>
-            <param name="path">The preference pane path consisting of slash-delimited name segments
-            specifying tree nodes.</param>
-            <param name="icon">The preference pane icon, or null if none.</param>
-            <param name="scope">The preference pane scope, or null if none.</param>
-            <param name="paneFactory">The preference pane factory.</param>
-        </member>
-        <member name="M:Gallio.UI.ControlPanel.Preferences.PreferenceControlPanelTab.ApplyPendingSettingsChanges(Gallio.Runtime.Security.IElevationContext,Gallio.Runtime.ProgressMonitoring.IProgressMonitor)">
-            <inheritdoc />
-        </member>
-        <member name="F:Gallio.UI.ControlPanel.Preferences.PreferenceControlPanelTab.components">
-            <summary> 
-            Required designer variable.
-            </summary>
-        </member>
-        <member name="M:Gallio.UI.ControlPanel.Preferences.PreferenceControlPanelTab.Dispose(System.Boolean)">
-            <summary> 
-            Clean up any resources being used.
-            </summary>
-            <param name="disposing">true if managed resources should be disposed; otherwise, false.</param>
-        </member>
-        <member name="M:Gallio.UI.ControlPanel.Preferences.PreferenceControlPanelTab.InitializeComponent">
-            <summary> 
-            Required method for Designer support - do not modify 
-            the contents of this method with the code editor.
-            </summary>
-        </member>
-        <member name="T:Gallio.UI.ControlPanel.Preferences.PreferenceControlPanelTabProvider">
-            <summary>
-            Provides the preferences control panel tab.
-            </summary>
-        </member>
-        <member name="M:Gallio.UI.ControlPanel.Preferences.PreferenceControlPanelTabProvider.#ctor(Gallio.Runtime.Extensibility.ComponentHandle{Gallio.UI.ControlPanel.Preferences.IPreferencePaneProvider,Gallio.UI.ControlPanel.Preferences.PreferencePaneProviderTraits}[])">
-            <summary>
-            Creates a control panel tab provider for preference panes.
-            </summary>
-            <param name="preferencePaneProviderHandles">The preference page provider handles, not null.</param>
-        </member>
-        <member name="M:Gallio.UI.ControlPanel.Preferences.PreferenceControlPanelTabProvider.CreateControlPanelTab">
-            <inheritdoc />
-        </member>
-        <member name="T:Gallio.UI.ControlPanel.Preferences.PreferencePaneProviderTraits">
-            <summary>
-            Describes the traits of a <see cref="T:Gallio.UI.ControlPanel.Preferences.IPreferencePaneProvider"/>.
-            </summary>
-        </member>
-        <member name="M:Gallio.UI.ControlPanel.Preferences.PreferencePaneProviderTraits.#ctor(System.String)">
-            <summary>
-            Creates a traits object for a preference pane provider.
-            </summary>
-            <param name="path">The preference pane path consisting of slash-delimited name segments
-            specifying tree nodes.</param>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="path"/> is null.</exception>
-            <exception cref="T:System.ArgumentException">Thrown if <paramref name="path"/> is empty.</exception>
-        </member>
-        <member name="P:Gallio.UI.ControlPanel.Preferences.PreferencePaneProviderTraits.Path">
-            <summary>
-            Gets the preference pane path consisting of slash-delimited name segments
-            specifying tree nodes.
-            </summary>
-        </member>
-        <member name="P:Gallio.UI.ControlPanel.Preferences.PreferencePaneProviderTraits.Icon">
-            <summary>
-            Gets or sets an icon (16x16) for the preference pane, or null if none.
-            </summary>
-        </member>
-        <member name="P:Gallio.UI.ControlPanel.Preferences.PreferencePaneProviderTraits.Order">
-            <summary>
-            Gets or sets an integer index used to sort control panel tabs in ascending order.
-            </summary>
-        </member>
-        <member name="P:Gallio.UI.ControlPanel.Preferences.PreferencePaneProviderTraits.Scope">
-            <summary>
-            Gets or sets a value that describes the scope of the changes effected by a preference pane.
-            </summary>
-            <value>The scope.  <see cref="F:Gallio.UI.ControlPanel.Preferences.PreferencePaneScope.User"/> by default.</value>
-        </member>
-        <member name="T:Gallio.UI.ControlPanel.NamespaceDoc">
-            <summary>
-            The Gallio.UI.ControlPanel namespace contains types for using and extending the
-            Gallio Control Panel UI.
-            </summary>
-        </member>
-        <member name="T:Gallio.UI.Controls.CommandToolStripMenuItem">
-            <summary>
-            Extends the win forms ToolStripMenuItem to wrap a MenuCommand.
-            </summary>
-        </member>
-        <member name="M:Gallio.UI.Controls.CommandToolStripMenuItem.#ctor(Gallio.UI.Menus.MenuCommand)">
-            <summary>
-             Constructor providing a menu command.
-            </summary>
-             <remarks>
-             When clicked, the command will be run synchronously.
-             </remarks>
-            <param name="command">The command to use.</param>
-        </member>
-        <member name="M:Gallio.UI.Controls.CommandToolStripMenuItem.#ctor(Gallio.UI.Menus.MenuCommand,Gallio.UI.ProgressMonitoring.ITaskManager)">
-            <summary>
-            Constructor providing a command and task manager.
-            </summary>
-            <remarks>
-            When clicked, the command will be queued with the 
-            supplied task manager.
-            </remarks>
-            <param name="command">The command to use.</param>
-            <param name="taskManager">The task manager to use.</param>
-        </member>
-        <member name="M:Gallio.UI.Controls.CommandToolStripMenuItem.#ctor(Gallio.UI.Menus.MenuCommand,Gallio.UI.ProgressMonitoring.ITaskManager,Gallio.UI.Controls.IKeysParser)">
-            <summary>
-             Constructor providing a command, task manager and keys parser.
-            </summary>
-            <param name="command">The command to use.</param>
-            <param name="taskManager">The task manager to use.</param>
-            <param name="keysParser">The keys parser to use.</param>
-        </member>
-        <member name="T:Gallio.UI.Controls.TruncatedToolStripMenuItem">
-            <summary>
-            A menu item that truncates the text, using ellipses (...), if necessary.
-            </summary>
-        </member>
-        <member name="T:Gallio.UI.Controls.ToolStripMenuItem">
-            <summary>
-            Sub-class of <see cref="T:System.Windows.Forms.ToolStripMenuItem">ToolStripMenuItem</see>, 
-            making databinding easier.
-            </summary>
-        </member>
-        <member name="P:Gallio.UI.Controls.ToolStripMenuItem.BindingContext">
-            <summary>
-            Gets or sets the collection of currency managers for the IBindableComponent.
-            </summary>
-        </member>
-        <member name="P:Gallio.UI.Controls.ToolStripMenuItem.DataBindings">
-            <summary>
-            Gets the collection of data-binding objects for this IBindableComponent.
-            </summary>
-        </member>
-        <member name="M:Gallio.UI.Controls.TruncatedToolStripMenuItem.#ctor(System.String,System.Int32)">
-            <summary>
-             Ctor.
-            </summary>
-            <param name="text">The text for the menu item to display. 
-             The full text will be the tooltip, but the display text
-             will be truncated if longer than specified.</param>
-            <param name="width">The maximum length text to display.</param>
-        </member>
-        <member name="T:Gallio.UI.Controls.IKeysParser">
-            <summary>
-             Parses a string representation of a <see cref="T:System.Windows.Forms.Keys"/> enum.
-            </summary>
-        </member>
-        <member name="M:Gallio.UI.Controls.IKeysParser.Parse(System.String)">
-            <summary>
-             Parses a string representation of a <see cref="T:System.Windows.Forms.Keys"/> enum.
-            </summary>
-            <param name="shortcut">The shortcut string to parse.</param>
-            <returns>A <see cref="T:System.Windows.Forms.Keys"/> enum.</returns>
-             <example>
-             For example, "Ctrl + S" would parse as Keys.Control | Keys.S
-             </example>
-        </member>
-        <member name="T:Gallio.UI.Controls.KeysParser">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.UI.Controls.KeysParser.Parse(System.String)">
-            <inheritdoc />
-        </member>
-        <member name="T:Gallio.UI.Controls.ToolStripButton">
-            <summary>
-            Sub-class of <see cref="T:System.Windows.Forms.ToolStripButton">ToolStripButton</see>, 
-            making databinding easier.
-            </summary>
-        </member>
-        <member name="P:Gallio.UI.Controls.ToolStripButton.BindingContext">
-            <summary>
-            Gets or sets the collection of currency managers for the IBindableComponent.
-            </summary>
-        </member>
-        <member name="P:Gallio.UI.Controls.ToolStripButton.DataBindings">
-            <summary>
-            Gets the collection of data-binding objects for this IBindableComponent.
-            </summary>
-        </member>
-        <member name="T:Gallio.UI.DataBinding.Observable`1">
-            <summary>
-            Wrapper for a field, that implements INotifyPropertyChanged.
-            </summary>
-            <typeparam name="T">The type to wrap.</typeparam>
-            <remarks>
-            All credit to Ayende:
-            http://ayende.com/Blog/archive/2009/08/08/an-easier-way-to-manage-inotifypropertychanged.aspx
-            </remarks>
-        </member>
-        <member name="M:Gallio.UI.DataBinding.Observable`1.#ctor">
-            <summary>
-            Default constructor.
-            </summary>
-        </member>
-        <member name="M:Gallio.UI.DataBinding.Observable`1.#ctor(`0)">
-            <summary>
-            Constructor initializing field.
-            </summary>
-            <param name="value">The initial value to wrap.</param>
-        </member>
-        <member name="M:Gallio.UI.DataBinding.Observable`1.op_Implicit(Gallio.UI.DataBinding.Observable{`0})~`0">
-            <summary>
-            Implicit operator allowing use of value.
-            </summary>
-            <param name="val"></param>
-            <returns></returns>
-        </member>
-        <member name="P:Gallio.UI.DataBinding.Observable`1.Value">
-            <summary>
-            The value being wrapped.
-            </summary>
-        </member>
-        <member name="E:Gallio.UI.DataBinding.Observable`1.PropertyChanged">
-            <summary>
-            Event fired when the value changes.
-            </summary>
-        </member>
-        <member name="T:Gallio.UI.DataBinding.ObservableList`1">
-            <summary>
-             List that raises an event when the contents are modified.
-            </summary>
-             <remarks>Wraps a List&lt;T&gt;.</remarks>
-            <typeparam name="T">The type of elements in the list.</typeparam>
-        </member>
-        <member name="M:Gallio.UI.DataBinding.ObservableList`1.GetEnumerator">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.UI.DataBinding.ObservableList`1.System#Collections#IEnumerable#GetEnumerator">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.UI.DataBinding.ObservableList`1.Add(`0)">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.UI.DataBinding.ObservableList`1.Clear">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.UI.DataBinding.ObservableList`1.Contains(`0)">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.UI.DataBinding.ObservableList`1.CopyTo(`0[],System.Int32)">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.UI.DataBinding.ObservableList`1.Remove(`0)">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.UI.DataBinding.ObservableList`1.IndexOf(`0)">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.UI.DataBinding.ObservableList`1.Insert(System.Int32,`0)">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.UI.DataBinding.ObservableList`1.RemoveAt(System.Int32)">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.UI.DataBinding.ObservableList`1.ToArray">
-            <summary>
-            Copies the elements of the list to a new array.
-            </summary>
-            <returns>An array containing copies of the elements of the list.</returns>
-        </member>
-        <member name="M:Gallio.UI.DataBinding.ObservableList`1.AddRange(System.Collections.Generic.IEnumerable{`0})">
-            <summary>
-            Adds the elements of the specified collection to the end of the list.
-            </summary>
-            <param name="collection"></param>
-        </member>
-        <member name="P:Gallio.UI.DataBinding.ObservableList`1.Count">
-            <inheritdoc />
-        </member>
-        <member name="P:Gallio.UI.DataBinding.ObservableList`1.IsReadOnly">
-            <inheritdoc />
-        </member>
-        <member name="P:Gallio.UI.DataBinding.ObservableList`1.Item(System.Int32)">
-            <inheritdoc />
-        </member>
-        <member name="E:Gallio.UI.DataBinding.ObservableList`1.PropertyChanged">
-            <inheritdoc />
-        </member>
-        <member name="T:Gallio.UI.ErrorReporting.ErrorDialog">
-            <summary>
-            Presents an error dialog consisting of a title, a message and a detailed message.
-            </summary>
-        </member>
-        <member name="M:Gallio.UI.ErrorReporting.ErrorDialog.#ctor">
-            <summary>
-            Creates the dialog.
-            </summary>
-        </member>
-        <member name="M:Gallio.UI.ErrorReporting.ErrorDialog.Show(System.Windows.Forms.IWin32Window,System.String,System.String,System.String)">
-            <summary>
-            Shows the error dialog.
-            </summary>
-            <param name="owner">The owner window, or null if none.</param>
-            <param name="errorTitle">The error title.</param>
-            <param name="errorMessage">The error message.</param>
-            <param name="errorDetails">The error details.</param>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="errorTitle"/>,
-            <paramref name="errorMessage"/> or <paramref name="errorDetails"/> is null.</exception>
-        </member>
-        <member name="F:Gallio.UI.ErrorReporting.ErrorDialog.components">
-            <summary>
-            Required designer variable.
-            </summary>
-        </member>
-        <member name="M:Gallio.UI.ErrorReporting.ErrorDialog.Dispose(System.Boolean)">
-            <summary>
-            Clean up any resources being used.
-            </summary>
-            <param name="disposing">true if managed resources should be disposed; otherwise, false.</param>
-        </member>
-        <member name="M:Gallio.UI.ErrorReporting.ErrorDialog.InitializeComponent">
-            <summary>
-            Required method for Designer support - do not modify
-            the contents of this method with the code editor.
-            </summary>
-        </member>
-        <member name="P:Gallio.UI.ErrorReporting.ErrorDialog.ErrorTitle">
-            <summary>
-            Gets or sets the error title.
-            </summary>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="value"/> is null.</exception>
-        </member>
-        <member name="P:Gallio.UI.ErrorReporting.ErrorDialog.ErrorMessage">
-            <summary>
-            Gets or sets the error message.
-            </summary>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="value"/> is null.</exception>
-        </member>
-        <member name="P:Gallio.UI.ErrorReporting.ErrorDialog.ErrorDetails">
-            <summary>
-            Gets or sets the error details.
-            </summary>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="value"/> is null.</exception>
-        </member>
-        <member name="P:Gallio.UI.ErrorReporting.ErrorDialog.ErrorDetailsVisible">
-            <summary>
-            Gets or sets whether the error details panel is visible.
-            </summary>
-        </member>
-        <member name="T:Gallio.UI.Controls.NamespaceDoc">
-            <summary>
-            The Gallio.UI.Controls namespace contains types for reusable Windows Forms custom controls.
-            </summary>
-        </member>
-        <member name="T:Gallio.UI.Controls.ShieldButton">
-            <summary>
-            An extension of the Button class that displays the "Shield" icon when
-            privilege elevation is required.
-            </summary>
-        </member>
-        <member name="M:Gallio.UI.Controls.ShieldButton.#ctor">
-            <summary>
-            Creates a shield button.
-            </summary>
-        </member>
-        <member name="M:Gallio.UI.Controls.ShieldButton.OnShieldChanged(System.EventArgs)">
-            <summary>
-            Raises the <see cref="E:Gallio.UI.Controls.ShieldButton.ShieldChanged"/> event.
-            </summary>
-            <param name="e">The event arguments.</param>
-        </member>
-        <member name="E:Gallio.UI.Controls.ShieldButton.ShieldChanged">
-            <summary>
-            An event raised when the value of <see cref="P:Gallio.UI.Controls.ShieldButton.Shield"/> has changed.
-            </summary>
-        </member>
-        <member name="P:Gallio.UI.Controls.ShieldButton.Shield">
-            <summary>
-            Gets or sets whether the shield icon should be displayed.
-            </summary>
-        </member>
-        <member name="T:Gallio.UI.ErrorReporting.ErrorDialogUnhandledExceptionHandler">
-            <summary>
-            Installs an unhandled exception handler that displays an error dialog.
-            </summary>
-        </member>
-        <member name="M:Gallio.UI.ErrorReporting.ErrorDialogUnhandledExceptionHandler.Install(System.Windows.Forms.Form)">
-            <summary>
-            Installs the handler.
-            </summary>
-            <remarks>
-            <para>
-            The handler is automatically removed when the form is disposed.
-            </para>
-            </remarks>
-            <param name="owner">The owner window.</param>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="owner"/> is null.</exception>
-            <exception cref="T:System.InvalidOperationException">Thrown if there is already a handler installed for a different owner.</exception>
-        </member>
-        <member name="M:Gallio.UI.ErrorReporting.ErrorDialogUnhandledExceptionHandler.Uninstall">
-            <summary>
-            Uninstalls the handler.
-            </summary>
-        </member>
-        <member name="M:Gallio.UI.ErrorReporting.ErrorDialogUnhandledExceptionHandler.RunApplicationWithHandler(System.Windows.Forms.Form)">
-            <summary>
-            Runs an application 
-            </summary>
-            <param name="mainForm">The main form.</param>
-        </member>
-        <member name="T:Gallio.UI.Events.Event">
-            <summary>
-            Marker class for Events.
-            </summary>
-        </member>
-        <member name="T:Gallio.UI.Events.EventAggregator">
-            <inheritdoc />
-        </member>
-        <member name="T:Gallio.UI.Events.IEventAggregator">
-            <summary>
-            An event aggregator.
-            http://martinfowler.com/eaaDev/EventAggregator.html
-            </summary>
-        </member>
-        <member name="M:Gallio.UI.Events.IEventAggregator.Send``1(System.Object,``0)">
-            <summary>
-             Send an event to all interested parties (synchronous).
-            </summary>
-            <param name="sender">The sender of the message.</param>
-            <param name="message">The message to send.</param>
-            <typeparam name="T">The type of event.</typeparam>
-        </member>
-        <member name="M:Gallio.UI.Events.EventAggregator.#ctor(Gallio.Runtime.Extensibility.IServiceLocator)">
-            <summary>
-             Ctor.
-            </summary>
-            <param name="serviceLocator">A service locator used to find registered handlers.</param>
-        </member>
-        <member name="M:Gallio.UI.Events.EventAggregator.Send``1(System.Object,``0)">
-            <inheritdoc />
-        </member>
-        <member name="T:Gallio.UI.Events.EventHandlerProxy`1">
-            <summary>
-             Proxy event handler.
-            </summary>
-            <typeparam name="T">The type of event.</typeparam>
-        </member>
-        <member name="T:Gallio.UI.Events.Handles`1">
-            <summary>
-            Marker interface used by the EventAggregator to
-            locate classes interested in an event.
-            </summary>
-            <typeparam name="T">The type of event.</typeparam>
-        </member>
-        <member name="M:Gallio.UI.Events.Handles`1.Handle(`0)">
-            <summary>
-             Handle an <see cref="T:Gallio.UI.Events.Event"/>.
-            </summary>
-            <param name="event">The event to handle.</param>
-        </member>
-        <member name="M:Gallio.UI.Events.EventHandlerProxy`1.#ctor(Gallio.UI.Events.Handles{`0})">
-            <summary>
-             Ctor.
-            </summary>
-            <param name="target">The handler to proxy for.</param>
-        </member>
-        <member name="M:Gallio.UI.Events.EventHandlerProxy`1.Handle(`0)">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.UI.Events.EventHandlerProxy`1.Equals(Gallio.UI.Events.EventHandlerProxy{`0})">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.UI.Events.EventHandlerProxy`1.Equals(System.Object)">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.UI.Events.EventHandlerProxy`1.GetHashCode">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.UI.Events.EventHandlerProxy`1.op_Equality(Gallio.UI.Events.EventHandlerProxy{`0},Gallio.UI.Events.EventHandlerProxy{`0})">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.UI.Events.EventHandlerProxy`1.op_Inequality(Gallio.UI.Events.EventHandlerProxy{`0},Gallio.UI.Events.EventHandlerProxy{`0})">
-            <inheritdoc />
-        </member>
-        <member name="T:Gallio.UI.Menus.MenuCommand">
-            <summary>
-            Wraps an <see cref="T:Gallio.UI.ProgressMonitoring.ICommand">ICommand</see> and provides
-            hints for the UI.
-            </summary>
-            <remarks>
-            Inspired by the WPF Command pattern.
-            http://msdn.microsoft.com/en-us/library/system.windows.input.icommand.aspx
-            </remarks>
-        </member>
-        <member name="M:Gallio.UI.Menus.MenuCommand.#ctor">
-            <summary>
-            Default constructor.
-            </summary>
-        </member>
-        <member name="P:Gallio.UI.Menus.MenuCommand.Command">
-            <summary>
-            The command that will be executed.
-            </summary>
-        </member>
-        <member name="P:Gallio.UI.Menus.MenuCommand.CanExecute">
-            <summary>
-            Whether the command can currently be executed, or not.
-            </summary>
-            <remarks>
-            Defaults to true.
-            </remarks>
-        </member>
-        <member name="P:Gallio.UI.Menus.MenuCommand.Text">
-            <summary>
-            The text description of the command.
-            </summary>
-        </member>
-        <member name="P:Gallio.UI.Menus.MenuCommand.Shortcut">
-            <summary>
-             The shortcut to use for the command.
-            </summary>
-        </member>
-        <member name="P:Gallio.UI.Menus.MenuCommand.Image">
-            <summary>
-             The image to use for the command.
-            </summary>
-        </member>
-        <member name="T:Gallio.UI.ProgressMonitoring.ITaskQueue">
-            <summary>
-             A task queue, for use by the <see cref="T:Gallio.UI.ProgressMonitoring.TaskManager"/>.
-            </summary>
-        </member>
-        <member name="M:Gallio.UI.ProgressMonitoring.ITaskQueue.AddTask(System.String,Gallio.UI.ProgressMonitoring.ICommand)">
-            <summary>
-            Adds a task to the specified queue.
-            </summary>
-            <param name="queueId">The id of the queue to use.</param>
-            <param name="command">An <see cref="T:Gallio.UI.ProgressMonitoring.ICommand"/> to queue.</param>
-        </member>
-        <member name="M:Gallio.UI.ProgressMonitoring.ITaskQueue.GetNextTask(System.String)">
-            <summary>
-            Get the next task for the specified queue.
-            </summary>
-            <param name="queueId">The id of the queue to use.</param>
-            <returns>An <see cref="T:Gallio.UI.ProgressMonitoring.ICommand"/>, or null if the queue is empty.</returns>
-        </member>
-        <member name="M:Gallio.UI.ProgressMonitoring.ITaskQueue.RemoveAllTasks(System.String)">
-            <summary>
-            Removes all tasks from the specified queue.
-            </summary>
-            <param name="queueId">The id of the queue to use.</param>
-        </member>
-        <member name="T:Gallio.UI.ProgressMonitoring.ITaskRunner">
-            <summary>
-             Takes care of running queued tasks.
-            </summary>
-        </member>
-        <member name="M:Gallio.UI.ProgressMonitoring.ITaskRunner.RunTask(System.String)">
-            <summary>
-             Run the next task for a named queue, if there is one.
-            </summary>
-            <param name="queueId">The id of the queue to use.</param>
-        </member>
-        <member name="T:Gallio.UI.ProgressMonitoring.TaskCancelled">
-            <summary>
-             Event fired when a task is cancelled.
-            </summary>
-        </member>
-        <member name="M:Gallio.UI.ProgressMonitoring.TaskCancelled.#ctor(System.String)">
-            <summary>
-             Ctor.
-            </summary>
-            <param name="queueId">The id of the queue.</param>
-        </member>
-        <member name="P:Gallio.UI.ProgressMonitoring.TaskCancelled.QueueId">
-            <summary>
-             The id of the queue.
-            </summary>
-        </member>
-        <member name="T:Gallio.UI.ProgressMonitoring.TaskCompleted">
-            <summary>
-             Event fired when a task is completed.
-            </summary>
-        </member>
-        <member name="M:Gallio.UI.ProgressMonitoring.TaskCompleted.#ctor(System.String)">
-            <summary>
-             Ctor.
-            </summary>
-            <param name="queueId">The id of the queue.</param>
-        </member>
-        <member name="P:Gallio.UI.ProgressMonitoring.TaskCompleted.QueueId">
-            <summary>
-             The id of the queue.
-            </summary>
-        </member>
-        <member name="T:Gallio.UI.ProgressMonitoring.TaskQueue">
-            <summary>
-            Manages multiple queues of tasks.
-            </summary>
-            <remarks>
-            Queue id is an arbitrary string, used as a key.
-            </remarks>
-        </member>
-        <member name="M:Gallio.UI.ProgressMonitoring.TaskQueue.#ctor">
-            <summary>
-             Ctor.
-            </summary>
-        </member>
-        <member name="M:Gallio.UI.ProgressMonitoring.TaskQueue.AddTask(System.String,Gallio.UI.ProgressMonitoring.ICommand)">
-            <summary>
-            Adds a task to the specified queue.
-            </summary>
-            <param name="queueId">The id of the queue to use.</param>
-            <param name="command">An <see cref="T:Gallio.UI.ProgressMonitoring.ICommand"/> to queue.</param>
-        </member>
-        <member name="M:Gallio.UI.ProgressMonitoring.TaskQueue.GetNextTask(System.String)">
-            <summary>
-            Get the next task for the specified queue.
-            </summary>
-            <param name="queueId">The id of the queue to use.</param>
-            <returns>An <see cref="T:Gallio.UI.ProgressMonitoring.ICommand"/>, or null if the queue is empty.</returns>
-        </member>
-        <member name="M:Gallio.UI.ProgressMonitoring.TaskQueue.RemoveAllTasks(System.String)">
-            <summary>
-            Removes all tasks from the specified queue.
-            </summary>
-            <param name="queueId">The id of the queue to use.</param>
-        </member>
-        <member name="T:Gallio.UI.ProgressMonitoring.TaskRunner">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.UI.ProgressMonitoring.TaskRunner.#ctor(Gallio.UI.ProgressMonitoring.ITaskQueue,Gallio.UI.Events.IEventAggregator,Gallio.UI.Common.Policies.IUnhandledExceptionPolicy)">
-            <summary>
-             Ctor.
-            </summary>
-            <param name="taskQueue">The task queue to use.</param>
-            <param name="eventAggregator">An event aggregator.</param>
-            <param name="unhandledExceptionPolicy">An exception policy.</param>
-        </member>
-        <member name="M:Gallio.UI.ProgressMonitoring.TaskRunner.RunTask(System.String)">
-            <inheritdoc />
-        </member>
-        <member name="T:Gallio.UI.ProgressMonitoring.ICommand">
-            <summary>
-            Command pattern.
-            </summary>
-        </member>
-        <member name="M:Gallio.UI.ProgressMonitoring.ICommand.Execute(Gallio.Runtime.ProgressMonitoring.IProgressMonitor)">
-            <summary>
-            Run a task (with progress information).
-            </summary>
-            <param name="progressMonitor">The progress monitor.</param>
-        </member>
-        <member name="T:Gallio.UI.ProgressMonitoring.ITaskManager">
-            <summary>
-             A task manager for UI applications.
-            </summary>
-        </member>
-        <member name="M:Gallio.UI.ProgressMonitoring.ITaskManager.BackgroundTask(Gallio.Common.Action)">
-            <summary>
-             Run a task as a background action (uses ThreadPool). 
-             No progress information will be displayed.
-            </summary>
-            <param name="action">The action to perform.</param>
-        </member>
-        <member name="M:Gallio.UI.ProgressMonitoring.ITaskManager.ClearQueue">
-            <summary>
-             Empty the queue of tasks.
-            </summary>
-        </member>
-        <member name="M:Gallio.UI.ProgressMonitoring.ITaskManager.ClearQueue(System.String)">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.UI.ProgressMonitoring.ITaskManager.QueueTask(Gallio.UI.ProgressMonitoring.ICommand)">
-            <summary>
-             Add a task to the queue. If nothing is in the queue or 
-             running, then the task will be executed.
-            </summary>
-            <param name="command">The command to queue.</param>
-        </member>
-        <member name="M:Gallio.UI.ProgressMonitoring.ITaskManager.QueueTask(System.String,Gallio.UI.ProgressMonitoring.ICommand)">
-            <inheritdoc />
-        </member>
-        <member name="T:Gallio.UI.ProgressMonitoring.ProgressMonitorDialog">
-            <summary>
-             Progress dialog.
-            </summary>
-        </member>
-        <member name="M:Gallio.UI.ProgressMonitoring.ProgressMonitorDialog.#ctor(Gallio.Runtime.ProgressMonitoring.ObservableProgressMonitor)">
-            <summary>
-             Default constructor.
-            </summary>
-            <param name="progressMonitor">The progress monitor to display information for.</param>
-        </member>
-        <member name="M:Gallio.UI.ProgressMonitoring.ProgressMonitorDialog.OnLoad(System.EventArgs)">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.UI.ProgressMonitoring.ProgressMonitorDialog.OnFormClosing(System.Windows.Forms.FormClosingEventArgs)">
-            <inherit />
-        </member>
-        <member name="F:Gallio.UI.ProgressMonitoring.ProgressMonitorDialog.components">
-            <summary>
-            Required designer variable.
-            </summary>
-        </member>
-        <member name="M:Gallio.UI.ProgressMonitoring.ProgressMonitorDialog.Dispose(System.Boolean)">
-            <summary>
-            Clean up any resources being used.
-            </summary>
-            <param name="disposing">true if managed resources should be disposed; otherwise, false.</param>
-        </member>
-        <member name="M:Gallio.UI.ProgressMonitoring.ProgressMonitorDialog.InitializeComponent">
-            <summary>
-            Required method for Designer support - do not modify
-            the contents of this method with the code editor.
-            </summary>
-        </member>
-        <member name="T:Gallio.UI.ProgressMonitoring.TaskManager">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.UI.ProgressMonitoring.TaskManager.#ctor(Gallio.UI.ProgressMonitoring.ITaskQueue,Gallio.UI.ProgressMonitoring.ITaskRunner)">
-            <summary>
-             Default constructor.
-            </summary>
-            <param name="taskQueue">A task queue.</param>
-            <param name="taskRunner">A task runner.</param>
-        </member>
-        <member name="M:Gallio.UI.ProgressMonitoring.TaskManager.QueueTask(Gallio.UI.ProgressMonitoring.ICommand)">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.UI.ProgressMonitoring.TaskManager.QueueTask(System.String,Gallio.UI.ProgressMonitoring.ICommand)">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.UI.ProgressMonitoring.TaskManager.BackgroundTask(Gallio.Common.Action)">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.UI.ProgressMonitoring.TaskManager.ClearQueue">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.UI.ProgressMonitoring.TaskManager.ClearQueue(System.String)">
-            <inheritdoc />
-        </member>
-        <member name="T:Gallio.UI.ProgressMonitoring.TaskStarted">
-            <summary>
-             Event fired when a task is started.
-            </summary>
-        </member>
-        <member name="M:Gallio.UI.ProgressMonitoring.TaskStarted.#ctor(System.String,Gallio.Runtime.ProgressMonitoring.ObservableProgressMonitor)">
-            <summary>
-             Ctor.
-            </summary>
-            <param name="queueId">The queue id.</param>
-            <param name="progressMonitor">A progress monitor.</param>
-        </member>
-        <member name="P:Gallio.UI.ProgressMonitoring.TaskStarted.QueueId">
-            <summary>
-             The id of the queue.
-            </summary>
-        </member>
-        <member name="P:Gallio.UI.ProgressMonitoring.TaskStarted.ProgressMonitor">
-            <summary>
-             A progress monitor attached to the task.
-            </summary>
-        </member>
-        <member name="T:Gallio.UI.ProgressMonitoring.ToolStripProgressBar">
-            <summary>
-             Impl of a tool strip progress bar for Gallio progress monitoring.
-            </summary>
-        </member>
-        <member name="P:Gallio.UI.ProgressMonitoring.ToolStripProgressBar.TotalWork">
-            <summary>
-             Total work to do.
-            </summary>
-        </member>
-        <member name="P:Gallio.UI.ProgressMonitoring.ToolStripProgressBar.CompletedWork">
-            <summary>
-             Total work to do.
-            </summary>
-        </member>
-        <member name="T:Gallio.UI.Reports.HtmlTestStepRunFormatter">
-            <summary>
-            <para>
-            An optimized HTML renderer for individual test step runs and their descendants.
-            </para>
-            </summary>
-        </member>
-        <member name="M:Gallio.UI.Reports.HtmlTestStepRunFormatter.TestStepReportWriter.ShouldUseFlash(System.Collections.Generic.IEnumerable{Gallio.Runner.Reports.Schema.TestStepRun})">
-            <summary>
-            Attempting to load flash content in a 64bit process on Windows is doomed to failure
-            because Adobe does not ship a 64bit version of the Flash plug-in at this time.
-            Unfortunately instead of failing gracefully, what happens is that Windows pops up a
-            warning dialog (when the browser is disposed) complaining about a missing flash.ocx.
-            </summary>
-        </member>
-        <member name="T:Gallio.UI.Properties.Resources">
-            <summary>
-              A strongly-typed resource class, for looking up localized strings, etc.
-            </summary>
-        </member>
-        <member name="P:Gallio.UI.Properties.Resources.ResourceManager">
-            <summary>
-              Returns the cached ResourceManager instance used by this class.
-            </summary>
-        </member>
-        <member name="P:Gallio.UI.Properties.Resources.Culture">
-            <summary>
-              Overrides the current thread's CurrentUICulture property for all
-              resource lookups using this strongly typed resource class.
-            </summary>
-        </member>
-        <member name="T:Gallio.UI.Reports.NamespaceDoc">
-            <summary>
-            The Gallio.UI.Reports namespace contains types for formatting reports for
-            display in a Windows Forms UI.
-            </summary>
-        </member>
-        <member name="T:Gallio.UI.Reports.TestStepRunViewer">
-            <summary>
-            <para>
-            Displays a summary of a set of test step runs.
-            </para>
-            <para>
-            This control is optimized to display individual test run results to the user on
-            demand more quickly than could be done if we had to show the whole report at once.
-            </para>
-            </summary>
-        </member>
-        <member name="M:Gallio.UI.Reports.TestStepRunViewer.#ctor">
-            <summary>
-            Creates a test step run viewer.
-            </summary>
-        </member>
-        <member name="M:Gallio.UI.Reports.TestStepRunViewer.OnLoad(System.EventArgs)">
-            <summary>
-            Raises the <see cref="E:System.Windows.Forms.UserControl.Load"/> event.
-            </summary>
-            <param name="e">An <see cref="T:System.EventArgs"/> that contains the event data.</param>
-        </member>
-        <member name="M:Gallio.UI.Reports.TestStepRunViewer.Clear">
-            <summary>
-            Clears the contents of the report viewer and discards all cached content.
-            </summary>
-        </member>
-        <member name="M:Gallio.UI.Reports.TestStepRunViewer.Show(System.Collections.Generic.ICollection{Gallio.Runner.Reports.Schema.TestStepRun})">
-            <summary>
-            Displays information about a set of test step run.
-            </summary>
-            <param name="testStepRuns">The test step runs.</param>
-        </member>
-        <member name="M:Gallio.UI.Reports.TestStepRunViewer.Show(System.Collections.Generic.ICollection{Gallio.Runner.Reports.Schema.TestStepRun},Gallio.Model.Schema.TestModelData)">
-            <summary>
-            Displays information about a set of test step runs, using additional
-            information from the test model when available.
-            </summary>
-            <param name="testStepRuns">The test step runs.</param>
-            <param name="testModelData">The test model data, or null if not available.</param>
-        </member>
-        <member name="F:Gallio.UI.Reports.TestStepRunViewer.components">
-            <summary> 
-            Required designer variable.
-            </summary>
-        </member>
-        <member name="M:Gallio.UI.Reports.TestStepRunViewer.Dispose(System.Boolean)">
-            <summary> 
-            Clean up any resources being used.
-            </summary>
-            <param name="disposing">true if managed resources should be disposed; otherwise, false.</param>
-        </member>
-        <member name="M:Gallio.UI.Reports.TestStepRunViewer.InitializeComponent">
-            <summary> 
-            Required method for Designer support - do not modify 
-            the contents of this method with the code editor.
-            </summary>
-        </member>
-        <member name="T:Gallio.UI.Tree.NodeControls.NodeCheckBox">
-            <summary>
-             Node check box.
-            </summary>
-        </member>
-        <member name="M:Gallio.UI.Tree.NodeControls.NodeCheckBox.#ctor">
-            <summary>
-             Node check box.
-            </summary>
-        </member>
-        <member name="M:Gallio.UI.Tree.NodeControls.NodeCheckBox.GetValue(Aga.Controls.Tree.TreeNodeAdv)">
-            <summary>
-             Gets the value from the node.
-            </summary>
-            <param name="node">The node.</param>
-            <returns>The value.</returns>
-        </member>
-        <member name="M:Gallio.UI.Tree.NodeControls.NodeCheckBox.SetCheckState(Aga.Controls.Tree.TreeNodeAdv,System.Windows.Forms.CheckState)">
-            <summary>
-            Sets the check state of the node.
-            </summary>
-            <param name="node">The node.</param>
-            <param name="value">The value.</param>
-        </member>
-        <member name="M:Gallio.UI.Tree.NodeControls.NodeCheckBox.GetNewState(System.Windows.Forms.CheckState)">
-            <summary>
-            Gets the new check state.
-            </summary>
-            <param name="state">The state.</param>
-            <returns>The new check state.</returns>
-        </member>
-        <member name="T:Gallio.UI.Tree.Nodes.ThreeStateNode">
-            <summary>
-             A three-state node.
-            </summary>
-        </member>
-        <member name="M:Gallio.UI.Tree.Nodes.ThreeStateNode.#ctor(System.String)">
-            <summary>
-             Ctor.
-            </summary>
-            <param name="text">The text to display.</param>
-        </member>
-        <member name="M:Gallio.UI.Tree.Nodes.ThreeStateNode.GetSiblingsState">
-            <summary>
-            Returns the 'combined' state for all siblings of a node.
-            </summary>
-        </member>
-        <member name="M:Gallio.UI.Tree.Nodes.ThreeStateNode.UpdateStateOfRelatedNodes">
-            <summary>
-            Manages updating related child and parent nodes of this instance.
-            </summary>
-        </member>
-        <member name="M:Gallio.UI.Tree.Nodes.ThreeStateNode.UpdateChildNodeState">
-            <summary>
-            Recursively update child node's state based on the state of this node.
-            </summary>
-        </member>
-        <member name="M:Gallio.UI.Tree.Nodes.ThreeStateNode.ChildShouldBeChecked(Gallio.UI.Tree.Nodes.ThreeStateNode,System.Windows.Forms.CheckState)">
-            <summary>
-            Allows inheriting classes to block cascading check state.
-            </summary>
-            <param name="child">The child to evaluate.</param>
-            <param name="checkState">The proposed check state.</param>
-            <returns>True if the check state can be cascaded, otherwise false.</returns>
-        </member>
-        <member name="M:Gallio.UI.Tree.Nodes.ThreeStateNode.UpdateParentNodeState">
-            <summary>
-            Recursively update parent node state based on the current state of this node.
-            </summary>
-        </member>
-        <member name="P:Gallio.UI.Tree.Nodes.ThreeStateNode.CheckState">
-            <summary>
-             The check state of the node
-            </summary>
-        </member>
-    </members>
-</doc>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Gallio.Utility.exe
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Gallio.Utility.exe b/lib/Gallio.3.2.750/tools/Gallio.Utility.exe
deleted file mode 100644
index 64941c8..0000000
Binary files a/lib/Gallio.3.2.750/tools/Gallio.Utility.exe and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Gallio.Utility.exe.config
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Gallio.Utility.exe.config b/lib/Gallio.3.2.750/tools/Gallio.Utility.exe.config
deleted file mode 100644
index 9815426..0000000
--- a/lib/Gallio.3.2.750/tools/Gallio.Utility.exe.config
+++ /dev/null
@@ -1,26 +0,0 @@
-<?xml version="1.0" encoding="utf-8" ?>
-<configuration>
-  <configSections>
-    <section name="gallio" type="Gallio.Runtime.GallioSectionHandler, Gallio" />
-  </configSections>
-
-  <runtime>
-    <legacyUnhandledExceptionPolicy enabled="1" />
-
-    <!-- Enable loading assemblies over the network in .Net 4.0 -->
-    <loadFromRemoteSources enabled="true" />
-  </runtime>
-
-  <system.runtime.remoting>
-    <customErrors mode="off"/>
-  </system.runtime.remoting>
-
-  <system.diagnostics>
-    <assert assertuienabled="false" />
-  </system.diagnostics>
-
-  <startup>
-    <supportedRuntime version="v4.0.30319" />
-    <supportedRuntime version="v2.0.50727" />
-  </startup>
-</configuration>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Gallio.Utility.plugin
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Gallio.Utility.plugin b/lib/Gallio.3.2.750/tools/Gallio.Utility.plugin
deleted file mode 100644
index 099358b..0000000
--- a/lib/Gallio.3.2.750/tools/Gallio.Utility.plugin
+++ /dev/null
@@ -1,18 +0,0 @@
-<?xml version="1.0" encoding="utf-8" ?>
-<plugin pluginId="Gallio.Utility"
-        recommendedInstallationPath=""
-        xmlns="http://www.gallio.org/">
-  <traits>
-    <name>Gallio Utility</name>
-    <version>3.2.0.0</version>
-    <description>A command-line utility for performing maintenance tasks related to the Gallio installation.</description>
-    <icon>plugin://Gallio.Utility/Resources/Gallio.Utility.ico</icon>
-  </traits>
-
-  <files>
-    <file path="Gallio.Utility.plugin" />
-    <file path="Gallio.Utility.exe" />
-    <file path="Gallio.Utility.exe.config" />
-    <file path="Resources\Gallio.Utility.ico" />
-  </files>
-</plugin>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Gallio.VisualStudio.Interop.dll
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Gallio.VisualStudio.Interop.dll b/lib/Gallio.3.2.750/tools/Gallio.VisualStudio.Interop.dll
deleted file mode 100644
index fdf77f2..0000000
Binary files a/lib/Gallio.3.2.750/tools/Gallio.VisualStudio.Interop.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Gallio.VisualStudio.Interop.plugin
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Gallio.VisualStudio.Interop.plugin b/lib/Gallio.3.2.750/tools/Gallio.VisualStudio.Interop.plugin
deleted file mode 100644
index 7c04421..0000000
--- a/lib/Gallio.3.2.750/tools/Gallio.VisualStudio.Interop.plugin
+++ /dev/null
@@ -1,28 +0,0 @@
-<?xml version="1.0" encoding="utf-8" ?>
-<plugin pluginId="Gallio.VisualStudio.Interop"
-        recommendedInstallationPath=""
-        xmlns="http://www.gallio.org/">
-  <traits>
-    <name>Visual Studio Interoperability Plugin</name>
-    <version>3.2.0.0</version>
-    <description>Provides support for opening files in Visual Studio and launching the debugger.</description>
-  </traits>
-
-  <dependencies>
-    <dependency pluginId="Gallio" />
-  </dependencies>
-
-  <files>
-    <file path="Gallio.VisualStudio.Interop.plugin" />
-    <file path="Gallio.VisualStudio.Interop.dll" />
-  </files>
-
-  <assemblies>
-    <assembly fullName="Gallio.VisualStudio.Interop, Version=3.2.0.0, Culture=neutral, PublicKeyToken=eb9cfa67ee6ab36e"
-              codeBase="Gallio.VisualStudio.Interop.dll"
-              qualifyPartialName="true" />
-  </assemblies>
-
-  <components>
-  </components>
-</plugin>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Gallio.XmlSerializers.dll
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Gallio.XmlSerializers.dll b/lib/Gallio.3.2.750/tools/Gallio.XmlSerializers.dll
deleted file mode 100644
index 3086a94..0000000
Binary files a/lib/Gallio.3.2.750/tools/Gallio.XmlSerializers.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Gallio.dll
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Gallio.dll b/lib/Gallio.3.2.750/tools/Gallio.dll
deleted file mode 100644
index 1d605ae..0000000
Binary files a/lib/Gallio.3.2.750/tools/Gallio.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Gallio.pdb
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Gallio.pdb b/lib/Gallio.3.2.750/tools/Gallio.pdb
deleted file mode 100644
index f678678..0000000
Binary files a/lib/Gallio.3.2.750/tools/Gallio.pdb and /dev/null differ


[42/51] [abbrv] [partial] Cleaning up and getting ready to development towards v4.8

Posted by sy...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/vs2012/test/Lucene.Net.Test.sln
----------------------------------------------------------------------
diff --git a/build/vs2012/test/Lucene.Net.Test.sln b/build/vs2012/test/Lucene.Net.Test.sln
deleted file mode 100644
index ecc9006..0000000
--- a/build/vs2012/test/Lucene.Net.Test.sln
+++ /dev/null
@@ -1,66 +0,0 @@
-
-Microsoft Visual Studio Solution File, Format Version 12.00
-# Visual Studio 2012
-#
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-#
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net", "..\..\..\src\core\Lucene.Net.csproj", "{5D4AD9BE-1FFB-41AB-9943-25737971BF57}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net.Test", "..\..\..\test\core\Lucene.Net.Test.csproj", "{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Demo.Common", "..\..\..\src\demo\Demo.Common\Demo.Common.csproj", "{F04CA2F4-E182-46A8-B914-F46AF5319E83}"
-EndProject
-Global
-	GlobalSection(SolutionConfigurationPlatforms) = preSolution
-		Debug35|Any CPU = Debug35|Any CPU
-		Debug|Any CPU = Debug|Any CPU
-		Release35|Any CPU = Release35|Any CPU
-		Release|Any CPU = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(ProjectConfigurationPlatforms) = postSolution
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.Build.0 = Release|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Release|Any CPU.Build.0 = Release|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Release|Any CPU.Build.0 = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(SolutionProperties) = preSolution
-		HideSolutionNode = FALSE
-	EndGlobalSection
-EndGlobal

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/Gallio License.txt
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/Gallio License.txt b/lib/Gallio.3.2.750/Gallio License.txt
deleted file mode 100644
index 3e17665..0000000
--- a/lib/Gallio.3.2.750/Gallio License.txt	
+++ /dev/null
@@ -1,14 +0,0 @@
-Copyright 2005-2010 Gallio Project - http://www.gallio.org/
-Portions Copyright 2000-2004 Jonathan de Halleux
-
-Licensed under the Apache License, Version 2.0 (the "License");
-you may not use this file except in compliance with the License.
-You may obtain a copy of the License at
-
-    http://www.apache.org/licenses/LICENSE-2.0
-
-Unless required by applicable law or agreed to in writing, software
-distributed under the License is distributed on an "AS IS" BASIS,
-WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-See the License for the specific language governing permissions and
-limitations under the License.

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/licenses/CciMetadata.License.txt
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/licenses/CciMetadata.License.txt b/lib/Gallio.3.2.750/licenses/CciMetadata.License.txt
deleted file mode 100644
index 0218f75..0000000
--- a/lib/Gallio.3.2.750/licenses/CciMetadata.License.txt
+++ /dev/null
@@ -1,31 +0,0 @@
-Microsoft Public License (Ms-PL)
-
-This license governs use of the accompanying software. If you use the software, you accept this license. If you do not accept the license, do not use the software.
-
-1. Definitions
-
-The terms "reproduce," "reproduction," "derivative works," and "distribution" have the same meaning here as under U.S. copyright law.
-
-A "contribution" is the original software, or any additions or changes to the software.
-
-A "contributor" is any person that distributes its contribution under this license.
-
-"Licensed patents" are a contributor's patent claims that read directly on its contribution.
-
-2. Grant of Rights
-
-(A) Copyright Grant- Subject to the terms of this license, including the license conditions and limitations in section 3, each contributor grants you a non-exclusive, worldwide, royalty-free copyright license to reproduce its contribution, prepare derivative works of its contribution, and distribute its contribution or any derivative works that you create.
-
-(B) Patent Grant- Subject to the terms of this license, including the license conditions and limitations in section 3, each contributor grants you a non-exclusive, worldwide, royalty-free license under its licensed patents to make, have made, use, sell, offer for sale, import, and/or otherwise dispose of its contribution in the software or derivative works of the contribution in the software.
-
-3. Conditions and Limitations
-
-(A) No Trademark License- This license does not grant you rights to use any contributors' name, logo, or trademarks.
-
-(B) If you bring a patent claim against any contributor over patents that you claim are infringed by the software, your patent license from such contributor to the software ends automatically.
-
-(C) If you distribute any portion of the software, you must retain all copyright, patent, trademark, and attribution notices that are present in the software.
-
-(D) If you distribute any portion of the software in source code form, you may do so only under this license by including a complete copy of this license with your distribution. If you distribute any portion of the software in compiled or object code form, you may only do so under a license that complies with this license.
-
-(E) The software is licensed "as-is." You bear the risk of using it. The contributors give no express warranties, guarantees or conditions. You may have additional consumer rights under your local laws which this license cannot change. To the extent permitted under your local laws, the contributors exclude the implied warranties of merchantability, fitness for a particular purpose and non-infringement.
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/licenses/Cecil.FlowAnalysis.license.html
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/licenses/Cecil.FlowAnalysis.license.html b/lib/Gallio.3.2.750/licenses/Cecil.FlowAnalysis.license.html
deleted file mode 100644
index 46822d4..0000000
--- a/lib/Gallio.3.2.750/licenses/Cecil.FlowAnalysis.license.html
+++ /dev/null
@@ -1,37 +0,0 @@
-<html>
-<head>
-<title>Cecil.FlowAnalysis.license</title>
-<Style>
-BODY, P, TD { font-family: Verdana, Arial, Helvetica, sans-serif; font-size: 10pt; color: #666666 }
-H2,H3,H4,H5 { color: black; font-weight: bold; }
-H2 { font-size: 13pt; }
-H3 { font-size: 12pt; }
-H4 { font-size: 10pt; color: black; }
-</style>
-</head>
-<body bgcolor="#FFFFFF" color=#000000>
-    <p>
-        (C) 2005-2006 db4objects, Inc. http://www.db4o.com
-    </p>
-    <p>
-        Permission is hereby granted, free of charge, to any person obtaining a copy of
-        this software and associated documentation files (the "Software"), to deal in the
-        Software without restriction, including without limitation the rights to use, copy,
-        modify, merge, publish, distribute, sublicense, and/or sell copies of the Software,
-        and to permit persons to whom the Software is furnished to do so, subject to the
-        following conditions:
-    </p>
-    <p>
-        The above copyright notice and this permission notice shall be included in all copies
-        or substantial portions of the Software.
-    </p>
-    <p>
-        THE SOFTWARE IS PROVIDED "AS IS", WITHOUT WARRANTY OF ANY KIND, EXPRESS OR IMPLIED,
-        INCLUDING BUT NOT LIMITED TO THE WARRANTIES OF MERCHANTABILITY, FITNESS FOR A PARTICULAR
-        PURPOSE AND NONINFRINGEMENT. IN NO EVENT SHALL THE AUTHORS OR COPYRIGHT HOLDERS
-        BE LIABLE FOR ANY CLAIM, DAMAGES OR OTHER LIABILITY, WHETHER IN AN ACTION OF CONTRACT,
-        TORT OR OTHERWISE, ARISING FROM, OUT OF OR IN CONNECTION WITH THE SOFTWARE OR THE
-        USE OR OTHER DEALINGS IN THE SOFTWARE.
-    </p>
-</body>
-</html>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/licenses/ICSharpCode.TextEditor.License.txt
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/licenses/ICSharpCode.TextEditor.License.txt b/lib/Gallio.3.2.750/licenses/ICSharpCode.TextEditor.License.txt
deleted file mode 100644
index 720daab..0000000
--- a/lib/Gallio.3.2.750/licenses/ICSharpCode.TextEditor.License.txt
+++ /dev/null
@@ -1,458 +0,0 @@
-		  GNU LESSER GENERAL PUBLIC LICENSE
-		       Version 2.1, February 1999
-
- Copyright (C) 1991, 1999 Free Software Foundation, Inc.
-     51 Franklin St, Fifth Floor, Boston, MA  02110-1301  USA
- Everyone is permitted to copy and distribute verbatim copies
- of this license document, but changing it is not allowed.
-
-[This is the first released version of the Lesser GPL.  It also counts
- as the successor of the GNU Library Public License, version 2, hence
- the version number 2.1.]
-
-			    Preamble
-
-  The licenses for most software are designed to take away your
-freedom to share and change it.  By contrast, the GNU General Public
-Licenses are intended to guarantee your freedom to share and change
-free software--to make sure the software is free for all its users.
-
-  This license, the Lesser General Public License, applies to some
-specially designated software packages--typically libraries--of the
-Free Software Foundation and other authors who decide to use it.  You
-can use it too, but we suggest you first think carefully about whether
-this license or the ordinary General Public License is the better
-strategy to use in any particular case, based on the explanations below.
-
-  When we speak of free software, we are referring to freedom of use,
-not price.  Our General Public Licenses are designed to make sure that
-you have the freedom to distribute copies of free software (and charge
-for this service if you wish); that you receive source code or can get
-it if you want it; that you can change the software and use pieces of
-it in new free programs; and that you are informed that you can do
-these things.
-
-  To protect your rights, we need to make restrictions that forbid
-distributors to deny you these rights or to ask you to surrender these
-rights.  These restrictions translate to certain responsibilities for
-you if you distribute copies of the library or if you modify it.
-
-  For example, if you distribute copies of the library, whether gratis
-or for a fee, you must give the recipients all the rights that we gave
-you.  You must make sure that they, too, receive or can get the source
-code.  If you link other code with the library, you must provide
-complete object files to the recipients, so that they can relink them
-with the library after making changes to the library and recompiling
-it.  And you must show them these terms so they know their rights.
-
-  We protect your rights with a two-step method: (1) we copyright the
-library, and (2) we offer you this license, which gives you legal
-permission to copy, distribute and/or modify the library.
-
-  To protect each distributor, we want to make it very clear that
-there is no warranty for the free library.  Also, if the library is
-modified by someone else and passed on, the recipients should know
-that what they have is not the original version, so that the original
-author's reputation will not be affected by problems that might be
-introduced by others.
-
-  Finally, software patents pose a constant threat to the existence of
-any free program.  We wish to make sure that a company cannot
-effectively restrict the users of a free program by obtaining a
-restrictive license from a patent holder.  Therefore, we insist that
-any patent license obtained for a version of the library must be
-consistent with the full freedom of use specified in this license.
-
-  Most GNU software, including some libraries, is covered by the
-ordinary GNU General Public License.  This license, the GNU Lesser
-General Public License, applies to certain designated libraries, and
-is quite different from the ordinary General Public License.  We use
-this license for certain libraries in order to permit linking those
-libraries into non-free programs.
-
-  When a program is linked with a library, whether statically or using
-a shared library, the combination of the two is legally speaking a
-combined work, a derivative of the original library.  The ordinary
-General Public License therefore permits such linking only if the
-entire combination fits its criteria of freedom.  The Lesser General
-Public License permits more lax criteria for linking other code with
-the library.
-
-  We call this license the "Lesser" General Public License because it
-does Less to protect the user's freedom than the ordinary General
-Public License.  It also provides other free software developers Less
-of an advantage over competing non-free programs.  These disadvantages
-are the reason we use the ordinary General Public License for many
-libraries.  However, the Lesser license provides advantages in certain
-special circumstances.
-
-  For example, on rare occasions, there may be a special need to
-encourage the widest possible use of a certain library, so that it becomes
-a de-facto standard.  To achieve this, non-free programs must be
-allowed to use the library.  A more frequent case is that a free
-library does the same job as widely used non-free libraries.  In this
-case, there is little to gain by limiting the free library to free
-software only, so we use the Lesser General Public License.
-
-  In other cases, permission to use a particular library in non-free
-programs enables a greater number of people to use a large body of
-free software.  For example, permission to use the GNU C Library in
-non-free programs enables many more people to use the whole GNU
-operating system, as well as its variant, the GNU/Linux operating
-system.
-
-  Although the Lesser General Public License is Less protective of the
-users' freedom, it does ensure that the user of a program that is
-linked with the Library has the freedom and the wherewithal to run
-that program using a modified version of the Library.
-
-  The precise terms and conditions for copying, distribution and
-modification follow.  Pay close attention to the difference between a
-"work based on the library" and a "work that uses the library".  The
-former contains code derived from the library, whereas the latter must
-be combined with the library in order to run.
-
-		  GNU LESSER GENERAL PUBLIC LICENSE
-   TERMS AND CONDITIONS FOR COPYING, DISTRIBUTION AND MODIFICATION
-
-  0. This License Agreement applies to any software library or other
-program which contains a notice placed by the copyright holder or
-other authorized party saying it may be distributed under the terms of
-this Lesser General Public License (also called "this License").
-Each licensee is addressed as "you".
-
-  A "library" means a collection of software functions and/or data
-prepared so as to be conveniently linked with application programs
-(which use some of those functions and data) to form executables.
-
-  The "Library", below, refers to any such software library or work
-which has been distributed under these terms.  A "work based on the
-Library" means either the Library or any derivative work under
-copyright law: that is to say, a work containing the Library or a
-portion of it, either verbatim or with modifications and/or translated
-straightforwardly into another language.  (Hereinafter, translation is
-included without limitation in the term "modification".)
-
-  "Source code" for a work means the preferred form of the work for
-making modifications to it.  For a library, complete source code means
-all the source code for all modules it contains, plus any associated
-interface definition files, plus the scripts used to control compilation
-and installation of the library.
-
-  Activities other than copying, distribution and modification are not
-covered by this License; they are outside its scope.  The act of
-running a program using the Library is not restricted, and output from
-such a program is covered only if its contents constitute a work based
-on the Library (independent of the use of the Library in a tool for
-writing it).  Whether that is true depends on what the Library does
-and what the program that uses the Library does.
-  
-  1. You may copy and distribute verbatim copies of the Library's
-complete source code as you receive it, in any medium, provided that
-you conspicuously and appropriately publish on each copy an
-appropriate copyright notice and disclaimer of warranty; keep intact
-all the notices that refer to this License and to the absence of any
-warranty; and distribute a copy of this License along with the
-Library.
-
-  You may charge a fee for the physical act of transferring a copy,
-and you may at your option offer warranty protection in exchange for a
-fee.
-
-  2. You may modify your copy or copies of the Library or any portion
-of it, thus forming a work based on the Library, and copy and
-distribute such modifications or work under the terms of Section 1
-above, provided that you also meet all of these conditions:
-
-    a) The modified work must itself be a software library.
-
-    b) You must cause the files modified to carry prominent notices
-    stating that you changed the files and the date of any change.
-
-    c) You must cause the whole of the work to be licensed at no
-    charge to all third parties under the terms of this License.
-
-    d) If a facility in the modified Library refers to a function or a
-    table of data to be supplied by an application program that uses
-    the facility, other than as an argument passed when the facility
-    is invoked, then you must make a good faith effort to ensure that,
-    in the event an application does not supply such function or
-    table, the facility still operates, and performs whatever part of
-    its purpose remains meaningful.
-
-    (For example, a function in a library to compute square roots has
-    a purpose that is entirely well-defined independent of the
-    application.  Therefore, Subsection 2d requires that any
-    application-supplied function or table used by this function must
-    be optional: if the application does not supply it, the square
-    root function must still compute square roots.)
-
-These requirements apply to the modified work as a whole.  If
-identifiable sections of that work are not derived from the Library,
-and can be reasonably considered independent and separate works in
-themselves, then this License, and its terms, do not apply to those
-sections when you distribute them as separate works.  But when you
-distribute the same sections as part of a whole which is a work based
-on the Library, the distribution of the whole must be on the terms of
-this License, whose permissions for other licensees extend to the
-entire whole, and thus to each and every part regardless of who wrote
-it.
-
-Thus, it is not the intent of this section to claim rights or contest
-your rights to work written entirely by you; rather, the intent is to
-exercise the right to control the distribution of derivative or
-collective works based on the Library.
-
-In addition, mere aggregation of another work not based on the Library
-with the Library (or with a work based on the Library) on a volume of
-a storage or distribution medium does not bring the other work under
-the scope of this License.
-
-  3. You may opt to apply the terms of the ordinary GNU General Public
-License instead of this License to a given copy of the Library.  To do
-this, you must alter all the notices that refer to this License, so
-that they refer to the ordinary GNU General Public License, version 2,
-instead of to this License.  (If a newer version than version 2 of the
-ordinary GNU General Public License has appeared, then you can specify
-that version instead if you wish.)  Do not make any other change in
-these notices.
-
-  Once this change is made in a given copy, it is irreversible for
-that copy, so the ordinary GNU General Public License applies to all
-subsequent copies and derivative works made from that copy.
-
-  This option is useful when you wish to copy part of the code of
-the Library into a program that is not a library.
-
-  4. You may copy and distribute the Library (or a portion or
-derivative of it, under Section 2) in object code or executable form
-under the terms of Sections 1 and 2 above provided that you accompany
-it with the complete corresponding machine-readable source code, which
-must be distributed under the terms of Sections 1 and 2 above on a
-medium customarily used for software interchange.
-
-  If distribution of object code is made by offering access to copy
-from a designated place, then offering equivalent access to copy the
-source code from the same place satisfies the requirement to
-distribute the source code, even though third parties are not
-compelled to copy the source along with the object code.
-
-  5. A program that contains no derivative of any portion of the
-Library, but is designed to work with the Library by being compiled or
-linked with it, is called a "work that uses the Library".  Such a
-work, in isolation, is not a derivative work of the Library, and
-therefore falls outside the scope of this License.
-
-  However, linking a "work that uses the Library" with the Library
-creates an executable that is a derivative of the Library (because it
-contains portions of the Library), rather than a "work that uses the
-library".  The executable is therefore covered by this License.
-Section 6 states terms for distribution of such executables.
-
-  When a "work that uses the Library" uses material from a header file
-that is part of the Library, the object code for the work may be a
-derivative work of the Library even though the source code is not.
-Whether this is true is especially significant if the work can be
-linked without the Library, or if the work is itself a library.  The
-threshold for this to be true is not precisely defined by law.
-
-  If such an object file uses only numerical parameters, data
-structure layouts and accessors, and small macros and small inline
-functions (ten lines or less in length), then the use of the object
-file is unrestricted, regardless of whether it is legally a derivative
-work.  (Executables containing this object code plus portions of the
-Library will still fall under Section 6.)
-
-  Otherwise, if the work is a derivative of the Library, you may
-distribute the object code for the work under the terms of Section 6.
-Any executables containing that work also fall under Section 6,
-whether or not they are linked directly with the Library itself.
-
-  6. As an exception to the Sections above, you may also combine or
-link a "work that uses the Library" with the Library to produce a
-work containing portions of the Library, and distribute that work
-under terms of your choice, provided that the terms permit
-modification of the work for the customer's own use and reverse
-engineering for debugging such modifications.
-
-  You must give prominent notice with each copy of the work that the
-Library is used in it and that the Library and its use are covered by
-this License.  You must supply a copy of this License.  If the work
-during execution displays copyright notices, you must include the
-copyright notice for the Library among them, as well as a reference
-directing the user to the copy of this License.  Also, you must do one
-of these things:
-
-    a) Accompany the work with the complete corresponding
-    machine-readable source code for the Library including whatever
-    changes were used in the work (which must be distributed under
-    Sections 1 and 2 above); and, if the work is an executable linked
-    with the Library, with the complete machine-readable "work that
-    uses the Library", as object code and/or source code, so that the
-    user can modify the Library and then relink to produce a modified
-    executable containing the modified Library.  (It is understood
-    that the user who changes the contents of definitions files in the
-    Library will not necessarily be able to recompile the application
-    to use the modified definitions.)
-
-    b) Use a suitable shared library mechanism for linking with the
-    Library.  A suitable mechanism is one that (1) uses at run time a
-    copy of the library already present on the user's computer system,
-    rather than copying library functions into the executable, and (2)
-    will operate properly with a modified version of the library, if
-    the user installs one, as long as the modified version is
-    interface-compatible with the version that the work was made with.
-
-    c) Accompany the work with a written offer, valid for at
-    least three years, to give the same user the materials
-    specified in Subsection 6a, above, for a charge no more
-    than the cost of performing this distribution.
-
-    d) If distribution of the work is made by offering access to copy
-    from a designated place, offer equivalent access to copy the above
-    specified materials from the same place.
-
-    e) Verify that the user has already received a copy of these
-    materials or that you have already sent this user a copy.
-
-  For an executable, the required form of the "work that uses the
-Library" must include any data and utility programs needed for
-reproducing the executable from it.  However, as a special exception,
-the materials to be distributed need not include anything that is
-normally distributed (in either source or binary form) with the major
-components (compiler, kernel, and so on) of the operating system on
-which the executable runs, unless that component itself accompanies
-the executable.
-
-  It may happen that this requirement contradicts the license
-restrictions of other proprietary libraries that do not normally
-accompany the operating system.  Such a contradiction means you cannot
-use both them and the Library together in an executable that you
-distribute.
-
-  7. You may place library facilities that are a work based on the
-Library side-by-side in a single library together with other library
-facilities not covered by this License, and distribute such a combined
-library, provided that the separate distribution of the work based on
-the Library and of the other library facilities is otherwise
-permitted, and provided that you do these two things:
-
-    a) Accompany the combined library with a copy of the same work
-    based on the Library, uncombined with any other library
-    facilities.  This must be distributed under the terms of the
-    Sections above.
-
-    b) Give prominent notice with the combined library of the fact
-    that part of it is a work based on the Library, and explaining
-    where to find the accompanying uncombined form of the same work.
-
-  8. You may not copy, modify, sublicense, link with, or distribute
-the Library except as expressly provided under this License.  Any
-attempt otherwise to copy, modify, sublicense, link with, or
-distribute the Library is void, and will automatically terminate your
-rights under this License.  However, parties who have received copies,
-or rights, from you under this License will not have their licenses
-terminated so long as such parties remain in full compliance.
-
-  9. You are not required to accept this License, since you have not
-signed it.  However, nothing else grants you permission to modify or
-distribute the Library or its derivative works.  These actions are
-prohibited by law if you do not accept this License.  Therefore, by
-modifying or distributing the Library (or any work based on the
-Library), you indicate your acceptance of this License to do so, and
-all its terms and conditions for copying, distributing or modifying
-the Library or works based on it.
-
-  10. Each time you redistribute the Library (or any work based on the
-Library), the recipient automatically receives a license from the
-original licensor to copy, distribute, link with or modify the Library
-subject to these terms and conditions.  You may not impose any further
-restrictions on the recipients' exercise of the rights granted herein.
-You are not responsible for enforcing compliance by third parties with
-this License.
-
-  11. If, as a consequence of a court judgment or allegation of patent
-infringement or for any other reason (not limited to patent issues),
-conditions are imposed on you (whether by court order, agreement or
-otherwise) that contradict the conditions of this License, they do not
-excuse you from the conditions of this License.  If you cannot
-distribute so as to satisfy simultaneously your obligations under this
-License and any other pertinent obligations, then as a consequence you
-may not distribute the Library at all.  For example, if a patent
-license would not permit royalty-free redistribution of the Library by
-all those who receive copies directly or indirectly through you, then
-the only way you could satisfy both it and this License would be to
-refrain entirely from distribution of the Library.
-
-If any portion of this section is held invalid or unenforceable under any
-particular circumstance, the balance of the section is intended to apply,
-and the section as a whole is intended to apply in other circumstances.
-
-It is not the purpose of this section to induce you to infringe any
-patents or other property right claims or to contest validity of any
-such claims; this section has the sole purpose of protecting the
-integrity of the free software distribution system which is
-implemented by public license practices.  Many people have made
-generous contributions to the wide range of software distributed
-through that system in reliance on consistent application of that
-system; it is up to the author/donor to decide if he or she is willing
-to distribute software through any other system and a licensee cannot
-impose that choice.
-
-This section is intended to make thoroughly clear what is believed to
-be a consequence of the rest of this License.
-
-  12. If the distribution and/or use of the Library is restricted in
-certain countries either by patents or by copyrighted interfaces, the
-original copyright holder who places the Library under this License may add
-an explicit geographical distribution limitation excluding those countries,
-so that distribution is permitted only in or among countries not thus
-excluded.  In such case, this License incorporates the limitation as if
-written in the body of this License.
-
-  13. The Free Software Foundation may publish revised and/or new
-versions of the Lesser General Public License from time to time.
-Such new versions will be similar in spirit to the present version,
-but may differ in detail to address new problems or concerns.
-
-Each version is given a distinguishing version number.  If the Library
-specifies a version number of this License which applies to it and
-"any later version", you have the option of following the terms and
-conditions either of that version or of any later version published by
-the Free Software Foundation.  If the Library does not specify a
-license version number, you may choose any version ever published by
-the Free Software Foundation.
-
-  14. If you wish to incorporate parts of the Library into other free
-programs whose distribution conditions are incompatible with these,
-write to the author to ask for permission.  For software which is
-copyrighted by the Free Software Foundation, write to the Free
-Software Foundation; we sometimes make exceptions for this.  Our
-decision will be guided by the two goals of preserving the free status
-of all derivatives of our free software and of promoting the sharing
-and reuse of software generally.
-
-			    NO WARRANTY
-
-  15. BECAUSE THE LIBRARY IS LICENSED FREE OF CHARGE, THERE IS NO
-WARRANTY FOR THE LIBRARY, TO THE EXTENT PERMITTED BY APPLICABLE LAW.
-EXCEPT WHEN OTHERWISE STATED IN WRITING THE COPYRIGHT HOLDERS AND/OR
-OTHER PARTIES PROVIDE THE LIBRARY "AS IS" WITHOUT WARRANTY OF ANY
-KIND, EITHER EXPRESSED OR IMPLIED, INCLUDING, BUT NOT LIMITED TO, THE
-IMPLIED WARRANTIES OF MERCHANTABILITY AND FITNESS FOR A PARTICULAR
-PURPOSE.  THE ENTIRE RISK AS TO THE QUALITY AND PERFORMANCE OF THE
-LIBRARY IS WITH YOU.  SHOULD THE LIBRARY PROVE DEFECTIVE, YOU ASSUME
-THE COST OF ALL NECESSARY SERVICING, REPAIR OR CORRECTION.
-
-  16. IN NO EVENT UNLESS REQUIRED BY APPLICABLE LAW OR AGREED TO IN
-WRITING WILL ANY COPYRIGHT HOLDER, OR ANY OTHER PARTY WHO MAY MODIFY
-AND/OR REDISTRIBUTE THE LIBRARY AS PERMITTED ABOVE, BE LIABLE TO YOU
-FOR DAMAGES, INCLUDING ANY GENERAL, SPECIAL, INCIDENTAL OR
-CONSEQUENTIAL DAMAGES ARISING OUT OF THE USE OR INABILITY TO USE THE
-LIBRARY (INCLUDING BUT NOT LIMITED TO LOSS OF DATA OR DATA BEING
-RENDERED INACCURATE OR LOSSES SUSTAINED BY YOU OR THIRD PARTIES OR A
-FAILURE OF THE LIBRARY TO OPERATE WITH ANY OTHER SOFTWARE), EVEN IF
-SUCH HOLDER OR OTHER PARTY HAS BEEN ADVISED OF THE POSSIBILITY OF SUCH
-DAMAGES.
-
-		     END OF TERMS AND CONDITIONS

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/licenses/Mono.Cecil.license.html
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/licenses/Mono.Cecil.license.html b/lib/Gallio.3.2.750/licenses/Mono.Cecil.license.html
deleted file mode 100644
index c1429b1..0000000
--- a/lib/Gallio.3.2.750/licenses/Mono.Cecil.license.html
+++ /dev/null
@@ -1,36 +0,0 @@
-<html>
-<head>
-<title>Mono.Cecil.license</title>
-<Style>
-BODY, P, TD { font-family: Verdana, Arial, Helvetica, sans-serif; font-size: 10pt; color: #666666 }
-H2,H3,H4,H5 { color: black; font-weight: bold; }
-H2 { font-size: 13pt; }
-H3 { font-size: 12pt; }
-H4 { font-size: 10pt; color: black; }
-</style>
-</head>
-<body bgcolor="#FFFFFF" color=#000000>
-    <p>
-        (C) 2004-2006 Jb Evain
-    </p>
-    <p>
-        Permission is hereby granted, free of charge, to any person obtaining a copy of
-        this software and associated documentation files (the "Software"), to deal in the
-        Software without restriction, including without limitation the rights to use, copy,
-        modify, merge, publish, distribute, sublicense, and/or sell copies of the Software,
-        and to permit persons to whom the Software is furnished to do so, subject to the
-        following conditions:
-    </p>
-    <p>
-        The above copyright notice and this permission notice shall be included in all copies
-        or substantial portions of the Software.
-    </p>
-    <p>
-        THE SOFTWARE IS PROVIDED "AS IS", WITHOUT WARRANTY OF ANY KIND, EXPRESS OR IMPLIED,
-        INCLUDING BUT NOT LIMITED TO THE WARRANTIES OF MERCHANTABILITY, FITNESS FOR A PARTICULAR
-        PURPOSE AND NONINFRINGEMENT. IN NO EVENT SHALL THE AUTHORS OR COPYRIGHT HOLDERS
-        BE LIABLE FOR ANY CLAIM, DAMAGES OR OTHER LIABILITY, WHETHER IN AN ACTION OF CONTRACT,
-        TORT OR OTHERWISE, ARISING FROM, OUT OF OR IN CONNECTION WITH THE SOFTWARE OR THE
-        USE OR OTHER DEALINGS IN THE SOFTWARE.</p>
-</body>
-</html>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/licenses/Mono.GetOptions.license.html
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/licenses/Mono.GetOptions.license.html b/lib/Gallio.3.2.750/licenses/Mono.GetOptions.license.html
deleted file mode 100644
index 115f890..0000000
--- a/lib/Gallio.3.2.750/licenses/Mono.GetOptions.license.html
+++ /dev/null
@@ -1,38 +0,0 @@
-<html>
-<head>
-<title>Mono.GetOptions.license</title>
-<Style>
-BODY, P, TD { font-family: Verdana, Arial, Helvetica, sans-serif; font-size: 10pt; color: #666666 }
-H2,H3,H4,H5 { color: black; font-weight: bold; }
-H2 { font-size: 13pt; }
-H3 { font-size: 12pt; }
-H4 { font-size: 10pt; color: black; }
-</style>
-</head>
-<body bgcolor="#FFFFFF" color=#000000>
-    <p>
-        Mono.GetOptions -
-        (C) 2002, 2003, 2004, 2005 Rafael Teixeira
-    </p>
-    <p>
-        Permission is hereby granted, free of charge, to any person obtaining a copy of
-        this software and associated documentation files (the "Software"), to deal in the
-        Software without restriction, including without limitation the rights to use, copy,
-        modify, merge, publish, distribute, sublicense, and/or sell copies of the Software,
-        and to permit persons to whom the Software is furnished to do so, subject to the
-        following conditions:
-    </p>
-    <p>
-        The above copyright notice and this permission notice shall be included in all copies
-        or substantial portions of the Software.
-    </p>
-    <p>
-        THE SOFTWARE IS PROVIDED "AS IS", WITHOUT WARRANTY OF ANY KIND, EXPRESS OR IMPLIED,
-        INCLUDING BUT NOT LIMITED TO THE WARRANTIES OF MERCHANTABILITY, FITNESS FOR A PARTICULAR
-        PURPOSE AND NONINFRINGEMENT. IN NO EVENT SHALL THE AUTHORS OR COPYRIGHT HOLDERS
-        BE LIABLE FOR ANY CLAIM, DAMAGES OR OTHER LIABILITY, WHETHER IN AN ACTION OF CONTRACT,
-        TORT OR OTHERWISE, ARISING FROM, OUT OF OR IN CONNECTION WITH THE SOFTWARE OR THE
-        USE OR OTHER DEALINGS IN THE SOFTWARE.
-    </p>
-</body>
-</html>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/licenses/WeifenLuo.WinFormsUI.Docking.License.txt
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/licenses/WeifenLuo.WinFormsUI.Docking.License.txt b/lib/Gallio.3.2.750/licenses/WeifenLuo.WinFormsUI.Docking.License.txt
deleted file mode 100644
index 290b9a4..0000000
--- a/lib/Gallio.3.2.750/licenses/WeifenLuo.WinFormsUI.Docking.License.txt
+++ /dev/null
@@ -1,9 +0,0 @@
-The MIT License
-
-Copyright (c) 2007 Weifen Luo (email: weifenluo@yahoo.com)
-
-Permission is hereby granted, free of charge, to any person obtaining a copy of this software and associated documentation files (the "Software"), to deal in the Software without restriction, including without limitation the rights to use, copy, modify, merge, publish, distribute, sublicense, and/or sell copies of the Software, and to permit persons to whom the Software is furnished to do so, subject to the following conditions:
-
-The above copyright notice and this permission notice shall be included in all copies or substantial portions of the Software.
-
-THE SOFTWARE IS PROVIDED "AS IS", WITHOUT WARRANTY OF ANY KIND, EXPRESS OR IMPLIED, INCLUDING BUT NOT LIMITED TO THE WARRANTIES OF MERCHANTABILITY, FITNESS FOR A PARTICULAR PURPOSE AND NONINFRINGEMENT. IN NO EVENT SHALL THE AUTHORS OR COPYRIGHT HOLDERS BE LIABLE FOR ANY CLAIM, DAMAGES OR OTHER LIABILITY, WHETHER IN AN ACTION OF CONTRACT, TORT OR OTHERWISE, ARISING FROM, OUT OF OR IN CONNECTION WITH THE SOFTWARE OR THE USE OR OTHER DEALINGS IN THE SOFTWARE.

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/licenses/db4o.license.html
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/licenses/db4o.license.html b/lib/Gallio.3.2.750/licenses/db4o.license.html
deleted file mode 100644
index be37aea..0000000
--- a/lib/Gallio.3.2.750/licenses/db4o.license.html
+++ /dev/null
@@ -1,384 +0,0 @@
-<html>
-<head>
-<title>GNU GENERAL PUBLIC LICENSE</title>
-<Style>
-BODY, P, TD { font-family: Verdana, Arial, Helvetica, sans-serif; font-size: 10pt; color: #666666 }
-H2,H3,H4,H5 { color: black; font-weight: bold; }
-H2 { font-size: 13pt; }
-H3 { font-size: 12pt; }
-H4 { font-size: 10pt; color: black; }
-</style>
-</head>
-<body bgcolor="#FFFFFF" color=#000000 style="text-align: justify">
-    <h2>
-        GNU GENERAL PUBLIC LICENSE
-        <br />
-    </h2>
-    Version 2, June 1991
-    <br />
-    Copyright (C) 1989, 1991 Free Software Foundation, Inc.
-    <br />
-    59 Temple Place, Suite 330, Boston, MA 02111-1307 USA
-    <br />
-    Everyone is permitted to copy and distribute verbatim copies of this license document,
-    but changing it is not allowed.
-    <br />
-    <br />
-    <p>
-        Preamble</p>
-    <p>
-        The licenses for most software are designed to take away your freedom to share and
-        change it. By contrast, the GNU General Public License is intended to guarantee
-        your freedom to share and change free software--to make sure the software is free
-        for all its users. This General Public License applies to most of the Free Software
-        Foundation's software and to any other program whose authors commit to using it.
-        (Some other Free Software Foundation software is covered by the GNU Library General
-        Public License instead.) You can apply it to your programs, too.
-        <br />
-    </p>
-    <p>
-        When we speak of free software, we are referring to freedom, not price. Our General
-        Public Licenses are designed to make sure that you have the freedom to distribute
-        copies of free software (and charge for this service if you wish), that you receive
-        source code or can get it if you want it, that you can change the software or use
-        pieces of it in new free programs; and that you know you can do these things.
-        <br />
-    </p>
-    <p>
-        To protect your rights, we need to make restrictions that forbid anyone to deny
-        you these rights or to ask you to surrender the rights. These restrictions translate
-        to certain responsibilities for you if you distribute copies of the software, or
-        if you modify it.
-        <br />
-        <br />
-        For example, if you distribute copies of such a program, whether gratis or for a
-        fee, you must give the recipients all the rights that you have. You must make sure
-        that they, too, receive or can get the source code. And you must show them these
-        terms so they know their rights.
-        <br />
-        <br />
-        We protect your rights with two steps: (1) copyright the software, and (2) offer
-        you this license which gives you legal permission to copy, distribute and/or modify
-        the software.
-        <br />
-        <br />
-        Also, for each author's protection and ours, we want to make certain that everyone
-        understands that there is no warranty for this free software. If the software is
-        modified by someone else and passed on, we want its recipients to know that what
-        they have is not the original, so that any problems introduced by others will not
-        reflect on the original authors' reputations.
-        <br />
-        <br />
-        Finally, any free program is threatened constantly by software patents. We wish
-        to avoid the danger that redistributors of a free program will individually obtain
-        patent licenses, in effect making the program proprietary. To prevent this, we have
-        made it clear that any patent must be licensed for everyone's free use or not licensed
-        at all.
-        <br />
-        <br />
-        The precise terms and conditions for copying, distribution and modification follow.
-        <br />
-    </p>
-    <p>
-        GNU GENERAL PUBLIC LICENSE TERMS AND CONDITIONS FOR COPYING, DISTRIBUTION AND MODIFICATION
-        <br />
-        <br />
-        0. This License applies to any program or other work which contains a notice placed
-        by the copyright holder saying it may be distributed under the terms of this General
-        Public License. The "Program", below, refers to any such program or work, and a
-        "work based on the Program" means either the Program or any derivative work under
-        copyright law: that is to say, a work containing the Program or a portion of it,
-        either verbatim or with modifications and/or translated into another language. (Hereinafter,
-        translation is included without limitation in the term "modification".) Each licensee
-        is addressed as "you".
-        <br />
-        <br />
-        Activities other than copying, distribution and modification are not covered by
-        this License; they are outside its scope. The act of running the Program is not
-        restricted, and the output from the Program is covered only if its contents constitute
-        a work based on the Program (independent of having been made by running the Program).
-        Whether that is true depends on what the Program does.
-        <br />
-        <br />
-        1. You may copy and distribute verbatim copies of the Program's source code as you
-        receive it, in any medium, provided that you conspicuously and appropriately publish
-        on each copy an appropriate copyright notice and disclaimer of warranty; keep intact
-        all the notices that refer to this License and to the absence of any warranty; and
-        give any other recipients of the Program a copy of this License along with the Program.
-        <br />
-        <br />
-        You may charge a fee for the physical act of transferring a copy, and you may at
-        your option offer warranty protection in exchange for a fee.
-        <br />
-        <br />
-        2. You may modify your copy or copies of the Program or any portion of it, thus
-        forming a work based on the Program, and copy and distribute such modifications
-        or work under the terms of Section 1 above, provided that you also meet all of these
-        conditions:
-        <br />
-        a) You must cause the modified files to carry prominent notices stating that you
-        changed the files and the date of any change.
-        <br />
-        b) You must cause any work that you distribute or publish, that in whole or in part
-        contains or is derived from the Program or any part thereof, to be licensed as a
-        whole at no charge to all third parties under the terms of this License.
-        <br />
-        c) If the modified program normally reads commands interactively when run, you must
-        cause it, when started running for such interactive use in the most ordinary way,
-        to print or display an announcement including an appropriate copyright notice and
-        a notice that there is no warranty (or else, saying that you provide a warranty)
-        and that users may redistribute the program under these conditions, and telling
-        the user how to view a copy of this License. (Exception: if the Program itself is
-        interactive but does not normally print such an announcement, your work based on
-        the Program is not required to print an announcement.)
-        <br />
-        <br />
-        These requirements apply to the modified work as a whole. If identifiable sections
-        of that work are not derived from the Program, and can be reasonably considered
-        independent and separate works in themselves, then this License, and its terms,
-        do not apply to those sections when you distribute them as separate works. But when
-        you distribute the same sections as part of a whole which is a work based on the
-        Program, the distribution of the whole must be on the terms of this License, whose
-        permissions for other licensees extend to the entire whole, and thus to each and
-        every part regardless of who wrote it.
-        <br />
-        <br />
-        Thus, it is not the intent of this section to claim rights or contest your rights
-        to work written entirely by you; rather, the intent is to exercise the right to
-        control the distribution of derivative or collective works based on the Program.
-        <br />
-        <br />
-        In addition, mere aggregation of another work not based on the Program with the
-        Program (or with a work based on the Program) on a volume of a storage or distribution
-        medium does not bring the other work under the scope of this License.
-        <br />
-        <br />
-        3. You may copy and distribute the Program (or a work based on it, under Section
-        2) in object code or executable form under the terms of Sections 1 and 2 above provided
-        that you also do one of the following:
-        <br />
-        a) Accompany it with the complete corresponding machine-readable source code, which
-        must be distributed under the terms of Sections 1 and 2 above on a medium customarily
-        used for software interchange; or,
-        <br />
-        b) Accompany it with a written offer, valid for at least three years, to give any
-        third party, for a charge no more than your cost of physically performing source
-        distribution, a complete machine-readable copy of the corresponding source code,
-        to be distributed under the terms of Sections 1 and 2 above on a medium customarily
-        used for software interchange; or,
-        <br />
-        c) Accompany it with the information you received as to the offer to distribute
-        corresponding source code. (This alternative is allowed only for noncommercial distribution
-        and only if you received the program in object code or executable form with such
-        an offer, in accord with Subsection b above.)
-        <br />
-        <br />
-        The source code for a work means the preferred form of the work for making modifications
-        to it. For an executable work, complete source code means all the source code for
-        all modules it contains, plus any associated interface definition files, plus the
-        scripts used to control compilation and installation of the executable. However,
-        as a special exception, the source code distributed need not include anything that
-        is normally distributed (in either source or binary form) with the major components
-        (compiler, kernel, and so on) of the operating system on which the executable runs,
-        unless that component itself accompanies the executable.
-        <br />
-        <br />
-        If distribution of executable or object code is made by offering access to copy
-        from a designated place, then offering equivalent access to copy the source code
-        from the same place counts as distribution of the source code, even though third
-        parties are not compelled to copy the source along with the object code.
-        <br />
-        <br />
-        4. You may not copy, modify, sublicense, or distribute the Program except as expressly
-        provided under this License. Any attempt otherwise to copy, modify, sublicense or
-        distribute the Program is void, and will automatically terminate your rights under
-        this License. However, parties who have received copies, or rights, from you under
-        this License will not have their licenses terminated so long as such parties remain
-        in full compliance.
-        <br />
-        <br />
-        5. You are not required to accept this License, since you have not signed it. However,
-        nothing else grants you permission to modify or distribute the Program or its derivative
-        works. These actions are prohibited by law if you do not accept this License. Therefore,
-        by modifying or distributing the Program (or any work based on the Program), you
-        indicate your acceptance of this License to do so, and all its terms and conditions
-        for copying, distributing or modifying the Program or works based on it.
-        <br />
-        <br />
-        6. Each time you redistribute the Program (or any work based on the Program), the
-        recipient automatically receives a license from the original licensor to copy, distribute
-        or modify the Program subject to these terms and conditions. You may not impose
-        any further restrictions on the recipients' exercise of the rights granted herein.
-        You are not responsible for enforcing compliance by third parties to this License.
-        <br />
-        <br />
-        7. If, as a consequence of a court judgment or allegation of patent infringement
-        or for any other reason (not limited to patent issues), conditions are imposed on
-        you (whether by court order, agreement or otherwise) that contradict the conditions
-        of this License, they do not excuse you from the conditions of this License. If
-        you cannot distribute so as to satisfy simultaneously your obligations under this
-        License and any other pertinent obligations, then as a consequence you may not distribute
-        the Program at all. For example, if a patent license would not permit royalty-free
-        redistribution of the Program by all those who receive copies directly or indirectly
-        through you, then the only way you could satisfy both it and this License would
-        be to refrain entirely from distribution of the Program.
-        <br />
-        <br />
-        If any portion of this section is held invalid or unenforceable under any particular
-        circumstance, the balance of the section is intended to apply and the section as
-        a whole is intended to apply in other circumstances.
-        <br />
-        <br />
-        It is not the purpose of this section to induce you to infringe any patents or other
-        property right claims or to contest validity of any such claims; this section has
-        the sole purpose of protecting the integrity of the free software distribution system,
-        which is implemented by public license practices. Many people have made generous
-        contributions to the wide range of software distributed through that system in reliance
-        on consistent application of that system; it is up to the author/donor to decide
-        if he or she is willing to distribute software through any other system and a licensee
-        cannot impose that choice.
-        <br />
-        <br />
-        This section is intended to make thoroughly clear what is believed to be a consequence
-        of the rest of this License.
-        <br />
-        <br />
-        8. If the distribution and/or use of the Program is restricted in certain countries
-        either by patents or by copyrighted interfaces, the original copyright holder who
-        places the Program under this License may add an explicit geographical distribution
-        limitation excluding those countries, so that distribution is permitted only in
-        or among countries not thus excluded. In such case, this License incorporates the
-        limitation as if written in the body of this License.
-        <br />
-        <br />
-        9. The Free Software Foundation may publish revised and/or new versions of the General
-        Public License from time to time. Such new versions will be similar in spirit to
-        the present version, but may differ in detail to address new problems or concerns.
-        <br />
-        <br />
-        Each version is given a distinguishing version number. If the Program specifies
-        a version number of this License which applies to it and "any later version", you
-        have the option of following the terms and conditions either of that version or
-        of any later version published by the Free Software Foundation. If the Program does
-        not specify a version number of this License, you may choose any version ever published
-        by the Free Software Foundation.
-        <br />
-        <br />
-        10. If you wish to incorporate parts of the Program into other free programs whose
-        distribution conditions are different, write to the author to ask for permission.
-        For software which is copyrighted by the Free Software Foundation, write to the
-        Free Software Foundation; we sometimes make exceptions for this. Our decision will
-        be guided by the two goals of preserving the free status of all derivatives of our
-        free software and of promoting the sharing and reuse of software generally.
-        <br />
-        <br />
-        NO WARRANTY
-        <br />
-        <br />
-        11. BECAUSE THE PROGRAM IS LICENSED FREE OF CHARGE, THERE IS NO WARRANTY FOR THE
-        PROGRAM, TO THE EXTENT PERMITTED BY APPLICABLE LAW. EXCEPT WHEN OTHERWISE STATED
-        IN WRITING THE COPYRIGHT HOLDERS AND/OR OTHER PARTIES PROVIDE THE PROGRAM "AS IS"
-        WITHOUT WARRANTY OF ANY KIND, EITHER EXPRESSED OR IMPLIED, INCLUDING, BUT NOT LIMITED
-        TO, THE IMPLIED WARRANTIES OF MERCHANTABILITY AND FITNESS FOR A PARTICULAR PURPOSE.
-        THE ENTIRE RISK AS TO THE QUALITY AND PERFORMANCE OF THE PROGRAM IS WITH YOU. SHOULD
-        THE PROGRAM PROVE DEFECTIVE, YOU ASSUME THE COST OF ALL NECESSARY SERVICING, REPAIR
-        OR CORRECTION.
-        <br />
-        <br />
-        12. IN NO EVENT UNLESS REQUIRED BY APPLICABLE LAW OR AGREED TO IN WRITING WILL ANY
-        COPYRIGHT HOLDER, OR ANY OTHER PARTY WHO MAY MODIFY AND/OR REDISTRIBUTE THE PROGRAM
-        AS PERMITTED ABOVE, BE LIABLE TO YOU FOR DAMAGES, INCLUDING ANY GENERAL, SPECIAL,
-        INCIDENTAL OR CONSEQUENTIAL DAMAGES ARISING OUT OF THE USE OR INABILITY TO USE THE
-        PROGRAM (INCLUDING BUT NOT LIMITED TO LOSS OF DATA OR DATA BEING RENDERED INACCURATE
-        OR LOSSES SUSTAINED BY YOU OR THIRD PARTIES OR A FAILURE OF THE PROGRAM TO OPERATE
-        WITH ANY OTHER PROGRAMS), EVEN IF SUCH HOLDER OR OTHER PARTY HAS BEEN ADVISED OF
-        THE POSSIBILITY OF SUCH DAMAGES.
-        <br />
-        <br />
-        END OF TERMS AND CONDITIONS
-        <br />
-        <br />
-        How to Apply These Terms to Your New Programs
-        <br />
-        <br />
-        If you develop a new program, and you want it to be of the greatest possible use
-        to the public, the best way to achieve this is to make it free software which everyone
-        can redistribute and change under these terms.
-        <br />
-        <br />
-        To do so, attach the following notices to the program. It is safest to attach them
-        to the start of each source file to most effectively convey the exclusion of warranty;
-        and each file should have at least the "copyright" line and a pointer to where the
-        full notice is found.&nbsp;<br />
-        <br /></p>
-       <blockquote><p>
-        &lt;one line to give the program's name and a brief idea of what it does.&gt;<br/>
-    
-        Copyright (C) &lt;year&gt; &lt;name of author&gt;
-    </p>
-       
-<p>
-        This program is free software; you can redistribute it and/or modify it under the
-        terms of the GNU General Public License as published by the Free Software Foundation;
-        either version 2 of the License, or (at your option) any later version.
-    </p>
-   <p> 
-        This program
-        is distributed in the hope that it will be useful, but WITHOUT ANY WARRANTY; without
-        even the implied warranty of MERCHANTABILITY or FITNESS FOR A PARTICULAR PURPOSE.
-        See the GNU General Public License for more details. 
-    </p>
-   <p>
-        You should have received a
-        copy of the GNU General Public License along with this program; if not, write to
-        the Free Software Foundation, Inc., 59 Temple Place, Suite 330, Boston, MA 02111-1307
-        USA </p>
-    </blockquote>
-    <p>
-        Also add information on how to contact you by electronic and paper mail. 
-    </p>
-    <p>
-        If
-        the program is interactive, make it output a short notice like this when it starts
-        in an interactive mode: 
-    </p>
-    <blockquote>
-        Gnomovision version 69, Copyright (C) year name of author
-        <br />
-        Gnomovision comes with ABSOLUTELY NO WARRANTY; for details type `show w'.<br />
-        This is
-        free software, and you are welcome to redistribute it under certain conditions;
-        type `show c' for details. 
-    </blockquote>
-    <p>
-        The hypothetical commands `show w' and `show c' should
-        show the appropriate parts of the General Public License. Of course, the commands
-        you use may be called something other than `show w' and `show c'; they could even
-        be mouse-clicks or menu items
-        -whatever suits your program. 
-    </p>
-    <p>
-        You should also get
-        your employer (if you work as a programmer) or your school, if any, to sign a "copyright
-        disclaimer" for the program, if necessary. Here is a sample; alter the names: 
-    </p>
-    
-<blockquote>    
-    <p>
-        Yoyodyne,
-        Inc., hereby disclaims all copyright interest in the program `Gnomovision' (which
-        makes passes at compilers) written by James Hacker.</p>
-    <p>
-        &lt;signature of Ty Coon&gt;,
-        1 April 1989 <br />Ty Coon, President of Vice 
-    </p>
-   </blockquote> 
-    <p>
-        This General Public License does not permit
-        incorporating your program into proprietary programs. If your program is a subroutine
-        library, you may consider it more useful to permit linking proprietary applications
-        with the library. If this is what you want to do, use the GNU Library General Public
-        License instead of this License.
-    </p>
-</body>
-</html>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/licenses/objectarx_license.doc
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/licenses/objectarx_license.doc b/lib/Gallio.3.2.750/licenses/objectarx_license.doc
deleted file mode 100644
index 51aec72..0000000
Binary files a/lib/Gallio.3.2.750/licenses/objectarx_license.doc and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Aga.Controls.dll
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Aga.Controls.dll b/lib/Gallio.3.2.750/tools/Aga.Controls.dll
deleted file mode 100644
index 0fc198a..0000000
Binary files a/lib/Gallio.3.2.750/tools/Aga.Controls.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Gallio.Ambience.Server.exe
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Gallio.Ambience.Server.exe b/lib/Gallio.3.2.750/tools/Gallio.Ambience.Server.exe
deleted file mode 100644
index d625e47..0000000
Binary files a/lib/Gallio.3.2.750/tools/Gallio.Ambience.Server.exe and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Gallio.Ambience.Server.exe.config
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Gallio.Ambience.Server.exe.config b/lib/Gallio.3.2.750/tools/Gallio.Ambience.Server.exe.config
deleted file mode 100644
index 9c557ea..0000000
--- a/lib/Gallio.3.2.750/tools/Gallio.Ambience.Server.exe.config
+++ /dev/null
@@ -1,19 +0,0 @@
-<?xml version="1.0" encoding="utf-8" ?>
-<configuration>
-  <runtime>
-    <legacyUnhandledExceptionPolicy enabled="1" />
-  </runtime>
-
-  <system.runtime.remoting>
-    <customErrors mode="off"/>
-  </system.runtime.remoting>
-
-  <system.diagnostics>
-    <assert assertuienabled="false" />
-  </system.diagnostics>
-
-  <startup>
-    <supportedRuntime version="v4.0.30319" />
-    <supportedRuntime version="v2.0.50727" />
-  </startup>
-</configuration>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Gallio.Ambience.UI.dll
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Gallio.Ambience.UI.dll b/lib/Gallio.3.2.750/tools/Gallio.Ambience.UI.dll
deleted file mode 100644
index 63b0328..0000000
Binary files a/lib/Gallio.3.2.750/tools/Gallio.Ambience.UI.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Gallio.Ambience.UI.plugin
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Gallio.Ambience.UI.plugin b/lib/Gallio.3.2.750/tools/Gallio.Ambience.UI.plugin
deleted file mode 100644
index 0fa1a4d..0000000
--- a/lib/Gallio.3.2.750/tools/Gallio.Ambience.UI.plugin
+++ /dev/null
@@ -1,46 +0,0 @@
-<?xml version="1.0" encoding="utf-8" ?>
-<plugin pluginId="Gallio.Ambience.UI"
-        recommendedInstallationPath=""
-        enableCondition="${minFramework:NET35}"
-        xmlns="http://www.gallio.org/">
-  <traits>
-    <name>Gallio Ambience UI</name>
-    <version>3.2.0.0</version>
-    <description>Ambience UI components.</description>
-  </traits>
-
-  <dependencies>
-    <dependency pluginId="Gallio" />
-    <dependency pluginId="Gallio.UI" />
-    <dependency pluginId="Gallio.Ambience" />
-  </dependencies>
-
-  <files>
-    <file path="Gallio.Ambience.UI.plugin" />
-    <file path="Gallio.Ambience.UI.dll" />
-  </files>
-
-  <assemblies>
-    <assembly fullName="Gallio.Ambience.UI, Version=3.2.0.0, Culture=neutral, PublicKeyToken=eb9cfa67ee6ab36e"
-              codeBase="Gallio.Ambience.UI.dll"
-              qualifyPartialName="true" />
-  </assemblies>
-
-  <components>
-    <component componentId="Ambience.UI.PlaceholderPreferencePaneProvider"
-               serviceId="Gallio.UI.PreferencePaneProvider">
-      <traits>
-        <path>Ambience</path>
-      </traits>
-    </component>
-
-    <component componentId="Ambience.UI.ServerPreferencePaneProvider"
-               serviceId="Gallio.UI.PreferencePaneProvider"
-               componentType="Gallio.Ambience.UI.Preferences.AmbienceServerPreferencePaneProvider, Gallio.Ambience.UI">
-      <traits>
-        <path>Ambience/Server</path>
-        <scope>Machine</scope>
-      </traits>
-    </component>
-  </components>
-</plugin>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Gallio.Ambience.dll
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Gallio.Ambience.dll b/lib/Gallio.3.2.750/tools/Gallio.Ambience.dll
deleted file mode 100644
index ba02268..0000000
Binary files a/lib/Gallio.3.2.750/tools/Gallio.Ambience.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Gallio.Ambience.pdb
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Gallio.Ambience.pdb b/lib/Gallio.3.2.750/tools/Gallio.Ambience.pdb
deleted file mode 100644
index 7c92b07..0000000
Binary files a/lib/Gallio.3.2.750/tools/Gallio.Ambience.pdb and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Gallio.Ambience.plugin
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Gallio.Ambience.plugin b/lib/Gallio.3.2.750/tools/Gallio.Ambience.plugin
deleted file mode 100644
index 356411b..0000000
--- a/lib/Gallio.3.2.750/tools/Gallio.Ambience.plugin
+++ /dev/null
@@ -1,30 +0,0 @@
-<?xml version="1.0" encoding="utf-8" ?>
-<plugin pluginId="Gallio.Ambience"
-        recommendedInstallationPath=""
-        enableCondition="${minFramework:NET35}"
-        xmlns="http://www.gallio.org/">
-  <traits>
-    <name>Gallio Ambience Library</name>
-    <version>3.2.0.0</version>
-    <description>Provides a lightweight object database based on db4o for storing test data across test runs.</description>
-  </traits>
-
-  <dependencies>
-    <dependency pluginId="Gallio" />
-  </dependencies>
-
-  <files>
-    <file path="Gallio.Ambience.plugin" />
-    <file path="Gallio.Ambience.dll" />
-    <file path="Gallio.Ambience.pdb" />
-    <file path="Gallio.Ambience.xml" />
-    <file path="Gallio.Ambience.Server.exe" />
-    <file path="Gallio.Ambience.Server.exe.config" />
-  </files>
-
-  <assemblies>
-    <assembly fullName="Gallio.Ambience, Version=3.2.0.0, Culture=neutral, PublicKeyToken=eb9cfa67ee6ab36e"
-              codeBase="Gallio.Ambience.dll"
-              qualifyPartialName="true" />
-  </assemblies>
-</plugin>
\ No newline at end of file


[08/51] [abbrv] [partial] Cleaning up and getting ready to development towards v4.8

Posted by sy...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/src/Lucene.Net.Codecs/BlockTerms/VariableGapTermsIndexWriter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Codecs/BlockTerms/VariableGapTermsIndexWriter.cs b/src/Lucene.Net.Codecs/BlockTerms/VariableGapTermsIndexWriter.cs
new file mode 100644
index 0000000..1a8f9d4
--- /dev/null
+++ b/src/Lucene.Net.Codecs/BlockTerms/VariableGapTermsIndexWriter.cs
@@ -0,0 +1,366 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+using System;
+using System.Collections.Generic;
+using System.Diagnostics;
+using Lucene.Net.Codecs;
+using Lucene.Net.Codecs.BlockTerms;
+using Lucene.Net.Index;
+using Lucene.Net.Store;
+using Lucene.Net.Util;
+using Lucene.Net.Util.Fst;
+
+namespace Lucene.Net.Codecs.BlockTerms
+{
+    
+}
+/**
+ * Selects index terms according to provided pluggable
+ * {@link IndexTermSelector}, and stores them in a prefix trie that's
+ * loaded entirely in RAM stored as an FST.  This terms
+ * index only supports unsigned byte term sort order
+ * (unicode codepoint order when the bytes are UTF8).
+ *
+ * @lucene.experimental */
+public class VariableGapTermsIndexWriter : TermsIndexWriterBase {
+  protected IndexOutput output;
+
+  /** Extension of terms index file */
+  public const String TERMS_INDEX_EXTENSION = "tiv";
+
+ public const String CODEC_NAME = "VARIABLE_GAP_TERMS_INDEX";
+ public const int VERSION_START = 0;
+public const int VERSION_APPEND_ONLY = 1;
+  public const int VERSION_CHECKSUM = 2;
+  public const int VERSION_CURRENT = VERSION_CHECKSUM;
+
+  private readonly List<FSTFieldWriter> fields = new ArrayList<>();
+  
+  @SuppressWarnings("unused") private final FieldInfos fieldInfos; // unread
+  private final IndexTermSelector policy;
+
+  /** 
+   * Hook for selecting which terms should be placed in the terms index.
+   * <p>
+   * {@link #newField} is called at the start of each new field, and
+   * {@link #isIndexTerm} for each term in that field.
+   * 
+   * @lucene.experimental 
+   */
+
+    public abstract class IndexTermSelector
+    {
+        /// <summary>
+        /// Called sequentially on every term being written
+        /// returning true if this term should be indexed
+        /// </summary>
+        public abstract bool IsIndexTerm(BytesRef term, TermStats stats);
+        
+        /// <summary>Called when a new field is started</summary>
+        public abstract void NewField(FieldInfo fieldInfo);
+    }
+
+    /// <remarks>
+    /// Same policy as {@link FixedGapTermsIndexWriter}
+    /// </remarks>
+    public sealed class EveryNTermSelector : IndexTermSelector
+    {
+        private int count;
+        private readonly int interval;
+
+        public EveryNTermSelector(int interval)
+        {
+            this.interval = interval;
+            // First term is first indexed term:
+            count = interval;
+        }
+
+        public override bool IsIndexTerm(BytesRef term, TermStats stats)
+        {
+            if (count >= interval)
+            {
+                count = 1;
+                return true;
+            }
+            else
+            {
+                count++;
+                return false;
+            }
+        }
+
+        public override void NewField(FieldInfo fieldInfo)
+        {
+            count = interval;
+        }
+    }
+
+    /// <summary>
+    /// Sets an index term when docFreq >= docFreqThresh, or
+    /// every interval terms.  This should reduce seek time
+    /// to high docFreq terms. 
+    /// </summary>
+    public class EveryNOrDocFreqTermSelector : IndexTermSelector
+    {
+        private int count;
+        private readonly int docFreqThresh;
+        private readonly int interval;
+
+        public EveryNOrDocFreqTermSelector(int docFreqThresh, int interval)
+        {
+            this.interval = interval;
+            this.docFreqThresh = docFreqThresh;
+
+            // First term is first indexed term:
+            count = interval;
+        }
+
+        public override bool IsIndexTerm(BytesRef term, TermStats stats)
+        {
+            if (stats.DocFreq >= docFreqThresh || count >= interval)
+            {
+                count = 1;
+                return true;
+            }
+            else
+            {
+                count++;
+                return false;
+            }
+        }
+
+        public override void NewField(FieldInfo fieldInfo)
+        {
+            count = interval;
+        }
+    }
+
+    // TODO: it'd be nice to let the FST builder prune based
+  // on term count of each node (the prune1/prune2 that it
+  // accepts), and build the index based on that.  This
+  // should result in a more compact terms index, more like
+  // a prefix trie than the other selectors, because it
+  // only stores enough leading bytes to get down to N
+  // terms that may complete that prefix.  It becomes
+  // "deeper" when terms are dense, and "shallow" when they
+  // are less dense.
+  //
+  // However, it's not easy to make that work this this
+  // API, because that pruning doesn't immediately know on
+  // seeing each term whether that term will be a seek point
+  // or not.  It requires some non-causality in the API, ie
+  // only on seeing some number of future terms will the
+  // builder decide which past terms are seek points.
+  // Somehow the API'd need to be able to return a "I don't
+  // know" value, eg like a Future, which only later on is
+  // flipped (frozen) to true or false.
+  //
+  // We could solve this with a 2-pass approach, where the
+  // first pass would build an FSA (no outputs) solely to
+  // determine which prefixes are the 'leaves' in the
+  // pruning. The 2nd pass would then look at this prefix
+  // trie to mark the seek points and build the FST mapping
+  // to the true output.
+  //
+  // But, one downside to this approach is that it'd result
+  // in uneven index term selection.  EG with prune1=10, the
+  // resulting index terms could be as frequent as every 10
+  // terms or as rare as every <maxArcCount> * 10 (eg 2560),
+  // in the extremes.
+
+    public VariableGapTermsIndexWriter(SegmentWriteState state, IndexTermSelector policy)
+    {
+        string indexFileName = IndexFileNames.SegmentFileName(state.SegmentInfo.Name, state.SegmentSuffix,
+            TERMS_INDEX_EXTENSION);
+        output = state.Directory.CreateOutput(indexFileName, state.Context);
+        bool success = false;
+        try
+        {
+            FieldInfos = state.FieldInfos;
+            this.Policy = policy;
+            writeHeader(output);
+            success = true;
+        }
+        finally
+        {
+            if (!success)
+            {
+                IOUtils.CloseWhileHandlingException(output);
+            }
+        }
+    }
+
+    private void WriteHeader(IndexOutput output)
+    {
+        CodecUtil.WriteHeader(output, CODEC_NAME, VERSION_CURRENT);
+    }
+
+    public override FieldWriter AddField(FieldInfo field, long termsFilePointer)
+    {
+        ////System.out.println("VGW: field=" + field.name);
+        Policy.newField(field);
+        FSTFieldWriter writer = new FSTFieldWriter(field, termsFilePointer);
+        fields.Add(writer);
+        return writer;
+    }
+
+    /** NOTE: if your codec does not sort in unicode code
+   *  point order, you must override this method, to simply
+   *  return indexedTerm.length. */
+
+    protected int IndexedTermPrefixLength(BytesRef priorTerm, BytesRef indexedTerm)
+    {
+        // As long as codec sorts terms in unicode codepoint
+        // order, we can safely strip off the non-distinguishing
+        // suffix to save RAM in the loaded terms index.
+        int idxTermOffset = indexedTerm.Offset;
+        int priorTermOffset = priorTerm.Offset;
+        int limit = Math.Min(priorTerm.Length, indexedTerm.Length);
+        for (int byteIdx = 0; byteIdx < limit; byteIdx++)
+        {
+            if (priorTerm.Bytes[priorTermOffset + byteIdx] != indexedTerm.Bytes[idxTermOffset + byteIdx])
+            {
+                return byteIdx + 1;
+            }
+        }
+
+        return Math.Min(1 + priorTerm.Length, indexedTerm.Length);
+    }
+
+    private class FSTFieldWriter : FieldWriter
+    {
+        private readonly Builder<long> fstBuilder;
+        private readonly PositiveIntOutputs fstOutputs;
+        private readonly long startTermsFilePointer;
+
+        public FieldInfo fieldInfo;
+        private FST<long> fst;
+        private long indexStart;
+
+        private readonly BytesRef lastTerm = new BytesRef();
+        private bool first = true;
+
+        public FSTFieldWriter(FieldInfo fieldInfo, long termsFilePointer)
+        {
+            this.fieldInfo = fieldInfo;
+            fstOutputs = PositiveIntOutputs.Singleton;
+            fstBuilder = new Builder<>(FST.INPUT_TYPE.BYTE1, fstOutputs);
+            indexStart = output.FilePointer;
+            ////System.out.println("VGW: field=" + fieldInfo.name);
+
+            // Always put empty string in
+            fstBuilder.Add(new IntsRef(), termsFilePointer);
+            startTermsFilePointer = termsFilePointer;
+        }
+
+        public override bool CheckIndexTerm(BytesRef text, TermStats stats)
+        {
+            //System.out.println("VGW: index term=" + text.utf8ToString());
+            // NOTE: we must force the first term per field to be
+            // indexed, in case policy doesn't:
+            if (policy.isIndexTerm(text, stats) || first)
+            {
+                first = false;
+                //System.out.println("  YES");
+                return true;
+            }
+            else
+            {
+                lastTerm.CopyBytes(text);
+                return false;
+            }
+        }
+
+        private readonly IntsRef scratchIntsRef = new IntsRef();
+
+        public override void Add(BytesRef text, TermStats stats, long termsFilePointer)
+        {
+            if (text.Length == 0)
+            {
+                // We already added empty string in ctor
+                Debug.Assert(termsFilePointer == startTermsFilePointer);
+                return;
+            }
+            int lengthSave = text.Length;
+            text.Length = IndexedTermPrefixLength(lastTerm, text);
+            try
+            {
+                fstBuilder.Add(Util.ToIntsRef(text, scratchIntsRef), termsFilePointer);
+            }
+            finally
+            {
+                text.Length = lengthSave;
+            }
+            lastTerm.CopyBytes(text);
+        }
+
+        public override void Finish(long termsFilePointer)
+        {
+            fst = fstBuilder.Finish();
+            if (fst != null)
+            {
+                fst.Save(output);
+            }
+        }
+    }
+
+    public void Dispose()
+    {
+        if (output != null)
+        {
+            try
+            {
+                long dirStart = output.FilePointer;
+                int fieldCount = fields.Size;
+
+                int nonNullFieldCount = 0;
+                for (int i = 0; i < fieldCount; i++)
+                {
+                    FSTFieldWriter field = fields[i];
+                    if (field.fst != null)
+                    {
+                        nonNullFieldCount++;
+                    }
+                }
+
+                output.WriteVInt(nonNullFieldCount);
+                for (int i = 0; i < fieldCount; i++)
+                {
+                    FSTFieldWriter field = fields[i];
+                    if (field.Fst != null)
+                    {
+                        output.WriteVInt(field.fieldInfo.Number);
+                        output.WriteVLong(field.indexStart);
+                    }
+                }
+                writeTrailer(dirStart);
+                CodecUtil.WriteFooter(output);
+            }
+            finally
+            {
+                output.Dispose();
+                output = null;
+            }
+        }
+    }
+
+    private void WriteTrailer(long dirStart)
+    {
+        output.WriteLong(dirStart);
+    }
+}

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/src/Lucene.Net.Codecs/Bloom/BloomFilterFactory.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Codecs/Bloom/BloomFilterFactory.cs b/src/Lucene.Net.Codecs/Bloom/BloomFilterFactory.cs
new file mode 100644
index 0000000..6bac454
--- /dev/null
+++ b/src/Lucene.Net.Codecs/Bloom/BloomFilterFactory.cs
@@ -0,0 +1,63 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+namespace Lucene.Net.Codecs.Bloom
+{
+
+    using Lucene.Net.Index;
+
+    /// <summary>
+    /// Class used to create index-time {@link FuzzySet} appropriately configured for
+    /// each field. Also called to right-size bitsets for serialization.
+    ///
+    ///  @lucene.experimental
+    /// </summary>
+    public abstract class BloomFilterFactory
+    {
+
+        /// <summary>
+        /// 
+        /// </summary>
+        /// <param name="state">The content to be indexed</param>
+        /// <param name="info">The field requiring a BloomFilter</param>
+        /// <returns>An appropriately sized set or null if no BloomFiltering required</returns>
+        public abstract FuzzySet GetSetForField(SegmentWriteState state, FieldInfo info);
+
+        /// <summary>
+        /// Called when downsizing bitsets for serialization
+        /// </summary>
+        /// <param name="fieldInfo">The field with sparse set bits</param>
+        /// <param name="initialSet">The bits accumulated</param>
+        /// <returns> null or a hopefully more densely packed, smaller bitset</returns>
+        public FuzzySet Downsize(FieldInfo fieldInfo, FuzzySet initialSet)
+        {
+            // Aim for a bitset size that would have 10% of bits set (so 90% of searches
+            // would fail-fast)
+            const float targetMaxSaturation = 0.1f;
+            return initialSet.Downsize(targetMaxSaturation);
+        }
+
+        /// <summary>
+        /// Used to determine if the given filter has reached saturation and should be retired i.e. not saved any more
+        /// </summary>
+        /// <param name="bloomFilter">The bloomFilter being tested</param>
+        /// <param name="fieldInfo">The field with which this filter is associated</param>
+        /// <returns>true if the set has reached saturation and should be retired</returns>
+        public abstract bool IsSaturated(FuzzySet bloomFilter, FieldInfo fieldInfo);
+
+    }
+}

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/src/Lucene.Net.Codecs/Bloom/BloomFilteringPostingsFormat.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Codecs/Bloom/BloomFilteringPostingsFormat.cs b/src/Lucene.Net.Codecs/Bloom/BloomFilteringPostingsFormat.cs
new file mode 100644
index 0000000..eb710b8
--- /dev/null
+++ b/src/Lucene.Net.Codecs/Bloom/BloomFilteringPostingsFormat.cs
@@ -0,0 +1,547 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+namespace Lucene.Net.Codecs.Bloom
+{
+
+    using System;
+    using System.Collections.Generic;
+    using System.Diagnostics;
+    using Lucene.Net.Index;
+    using Lucene.Net.Search;
+    using Lucene.Net.Store;
+    using Lucene.Net.Support;
+    using Lucene.Net.Util;
+    using Lucene.Net.Util.Automaton;
+
+    /// <summary>
+    /// 
+    /// A {@link PostingsFormat} useful for low doc-frequency fields such as primary
+    /// keys. Bloom filters are maintained in a ".blm" file which offers "fast-fail"
+    /// for reads in segments known to have no record of the key. A choice of
+    /// delegate PostingsFormat is used to record all other Postings data.
+    /// 
+    /// A choice of {@link BloomFilterFactory} can be passed to tailor Bloom Filter
+    /// settings on a per-field basis. The default configuration is
+    /// {@link DefaultBloomFilterFactory} which allocates a ~8mb bitset and hashes
+    /// values using {@link MurmurHash2}. This should be suitable for most purposes.
+    ///
+    /// The format of the blm file is as follows:
+    ///
+    /// <ul>
+    /// <li>BloomFilter (.blm) --&gt; Header, DelegatePostingsFormatName,
+    /// NumFilteredFields, Filter<sup>NumFilteredFields</sup>, Footer</li>
+    /// <li>Filter --&gt; FieldNumber, FuzzySet</li>
+    /// <li>FuzzySet --&gt;See {@link FuzzySet#serialize(DataOutput)}</li>
+    /// <li>Header --&gt; {@link CodecUtil#writeHeader CodecHeader}</li>
+    /// <li>DelegatePostingsFormatName --&gt; {@link DataOutput#writeString(String)
+    /// String} The name of a ServiceProvider registered {@link PostingsFormat}</li>
+    /// <li>NumFilteredFields --&gt; {@link DataOutput#writeInt Uint32}</li>
+    /// <li>FieldNumber --&gt; {@link DataOutput#writeInt Uint32} The number of the
+    /// field in this segment</li>
+    /// <li>Footer --&gt; {@link CodecUtil#writeFooter CodecFooter}</li>
+    /// </ul>
+    ///
+    ///  @lucene.experimental
+    /// </summary>
+    public sealed class BloomFilteringPostingsFormat : PostingsFormat
+    {
+        public static readonly String BLOOM_CODEC_NAME = "BloomFilter";
+        public static readonly int VERSION_START = 1;
+        public static readonly int VERSION_CHECKSUM = 2;
+        public static readonly int VERSION_CURRENT = VERSION_CHECKSUM;
+
+        /** Extension of Bloom Filters file */
+        private static readonly String BLOOM_EXTENSION = "blm";
+
+        private BloomFilterFactory bloomFilterFactory = new DefaultBloomFilterFactory();
+        private PostingsFormat delegatePostingsFormat;
+        
+        /// <summary>
+        ///  Creates Bloom filters for a selection of fields created in the index. This
+        /// is recorded as a set of Bitsets held as a segment summary in an additional
+        /// "blm" file. This PostingsFormat delegates to a choice of delegate
+        /// PostingsFormat for encoding all other postings data.
+        /// </summary>
+        /// <param name="delegatePostingsFormat">The PostingsFormat that records all the non-bloom filter data i.e. postings info.</param>
+        /// <param name="bloomFilterFactory">The {@link BloomFilterFactory} responsible for sizing BloomFilters appropriately</param>
+        public BloomFilteringPostingsFormat(PostingsFormat delegatePostingsFormat,
+            BloomFilterFactory bloomFilterFactory) : base(BLOOM_CODEC_NAME)
+        {
+            this.delegatePostingsFormat = delegatePostingsFormat;
+            this.bloomFilterFactory = bloomFilterFactory;
+        }
+
+        /// <summary>
+        /// Creates Bloom filters for a selection of fields created in the index. This
+        /// is recorded as a set of Bitsets held as a segment summary in an additional
+        /// "blm" file. This PostingsFormat delegates to a choice of delegate
+        /// PostingsFormat for encoding all other postings data. This choice of
+        /// constructor defaults to the {@link DefaultBloomFilterFactory} for
+        /// configuring per-field BloomFilters.
+        /// </summary>
+        /// <param name="delegatePostingsFormat">The PostingsFormat that records all the non-bloom filter data i.e. postings info.</param>
+        public BloomFilteringPostingsFormat(PostingsFormat delegatePostingsFormat)
+            : this(delegatePostingsFormat, new DefaultBloomFilterFactory())
+        {
+        }
+
+        /// <summary>
+        /// Used only by core Lucene at read-time via Service Provider instantiation -
+        /// do not use at Write-time in application code.
+        /// </summary>
+        public BloomFilteringPostingsFormat() : base(BLOOM_CODEC_NAME)
+        {
+        }
+
+        public override FieldsConsumer FieldsConsumer(SegmentWriteState state)
+        {
+            if (delegatePostingsFormat == null)
+            {
+                throw new InvalidOperationException("Error - constructed without a choice of PostingsFormat");
+            }
+            return new BloomFilteredFieldsConsumer(
+                delegatePostingsFormat.FieldsConsumer(state), state,
+                delegatePostingsFormat);
+        }
+
+        public override FieldsProducer FieldsProducer(SegmentReadState state)
+        {
+            return new BloomFilteredFieldsProducer(state);
+        }
+
+        internal class BloomFilteredFieldsProducer : FieldsProducer
+        {
+            private FieldsProducer delegateFieldsProducer;
+            private HashMap<String, FuzzySet> bloomsByFieldName = new HashMap<String, FuzzySet>();
+
+            public BloomFilteredFieldsProducer(SegmentReadState state)
+            {
+
+                String bloomFileName = IndexFileNames.SegmentFileName(
+                    state.SegmentInfo.Name, state.SegmentSuffix, BLOOM_EXTENSION);
+                ChecksumIndexInput bloomIn = null;
+                bool success = false;
+                try
+                {
+                    bloomIn = state.Directory.OpenChecksumInput(bloomFileName, state.Context);
+                    int version = CodecUtil.CheckHeader(bloomIn, BLOOM_CODEC_NAME, VERSION_START, VERSION_CURRENT);
+                    // // Load the hash function used in the BloomFilter
+                    // hashFunction = HashFunction.forName(bloomIn.readString());
+                    // Load the delegate postings format
+                    PostingsFormat delegatePostingsFormat = PostingsFormat.ForName(bloomIn
+                        .ReadString());
+
+                    this.delegateFieldsProducer = delegatePostingsFormat
+                        .FieldsProducer(state);
+                    int numBlooms = bloomIn.ReadInt();
+                    for (int i = 0; i < numBlooms; i++)
+                    {
+                        int fieldNum = bloomIn.ReadInt();
+                        FuzzySet bloom = FuzzySet.Deserialize(bloomIn);
+                        FieldInfo fieldInfo = state.FieldInfos.FieldInfo(fieldNum);
+                        bloomsByFieldName.Add(fieldInfo.Name, bloom);
+                    }
+                    if (version >= VERSION_CHECKSUM)
+                    {
+                        CodecUtil.CheckFooter(bloomIn);
+                    }
+                    else
+                    {
+                        CodecUtil.CheckEOF(bloomIn);
+                    }
+                    IOUtils.Close(bloomIn);
+                    success = true;
+                }
+                finally
+                {
+                    if (!success)
+                    {
+                        IOUtils.CloseWhileHandlingException(bloomIn, delegateFieldsProducer);
+                    }
+                }
+            }
+
+            public override IEnumerator<string> GetEnumerator()
+            {
+                return delegateFieldsProducer.GetEnumerator();
+            }
+
+            public override Terms Terms(String field)
+            {
+                FuzzySet filter = bloomsByFieldName[field];
+                if (filter == null)
+                {
+                    return delegateFieldsProducer.Terms(field);
+                }
+                else
+                {
+                    Terms result = delegateFieldsProducer.Terms(field);
+                    if (result == null)
+                    {
+                        return null;
+                    }
+                    return new BloomFilteredTerms(result, filter);
+                }
+            }
+
+            public override int Size()
+            {
+                return delegateFieldsProducer.Size();
+            }
+
+            public override long UniqueTermCount
+            {
+                get { return delegateFieldsProducer.UniqueTermCount; }
+            }
+
+            public override void Dispose()
+            {
+                delegateFieldsProducer.Dispose();
+            }
+
+            public override long RamBytesUsed()
+            {
+                long sizeInBytes = ((delegateFieldsProducer != null) ? delegateFieldsProducer.RamBytesUsed() : 0);
+                foreach (var entry in bloomsByFieldName.EntrySet())
+                {
+                    sizeInBytes += entry.Key.Length*RamUsageEstimator.NUM_BYTES_CHAR;
+                    sizeInBytes += entry.Value.RamBytesUsed();
+                }
+                return sizeInBytes;
+            }
+
+            public override void CheckIntegrity()
+            {
+                delegateFieldsProducer.CheckIntegrity();
+            }
+
+            internal class BloomFilteredTerms : Terms
+            {
+                private Terms delegateTerms;
+                private FuzzySet filter;
+
+                public BloomFilteredTerms(Terms terms, FuzzySet filter)
+                {
+                    this.delegateTerms = terms;
+                    this.filter = filter;
+                }
+
+                public override TermsEnum Intersect(CompiledAutomaton compiled,
+                    BytesRef startTerm)
+                {
+                    return delegateTerms.Intersect(compiled, startTerm);
+                }
+
+                public override TermsEnum Iterator(TermsEnum reuse)
+                {
+                    if ((reuse != null) && (reuse is BloomFilteredTermsEnum))
+                    {
+                        // recycle the existing BloomFilteredTermsEnum by asking the delegate
+                        // to recycle its contained TermsEnum
+                        BloomFilteredTermsEnum bfte = (BloomFilteredTermsEnum) reuse;
+                        if (bfte.filter == filter)
+                        {
+                            bfte.Reset(delegateTerms, bfte.delegateTermsEnum);
+                            return bfte;
+                        }
+                    }
+                    // We have been handed something we cannot reuse (either null, wrong
+                    // class or wrong filter) so allocate a new object
+                    return new BloomFilteredTermsEnum(delegateTerms, reuse, filter);
+                }
+
+                public override IComparer<BytesRef> Comparator
+                {
+                    get { return delegateTerms.Comparator; }
+                }
+
+                public override long Size()
+                {
+                    return delegateTerms.Size();
+                }
+
+                public override long SumTotalTermFreq
+                {
+                    get { return delegateTerms.SumTotalTermFreq; }
+                }
+
+                public override long SumDocFreq
+                {
+                    get { return delegateTerms.SumDocFreq; }
+                }
+
+                public override int DocCount
+                {
+                    get { return delegateTerms.DocCount; }
+                }
+
+                public override bool HasFreqs()
+                {
+                    return delegateTerms.HasFreqs();
+                }
+
+                public override bool HasOffsets()
+                {
+                    return delegateTerms.HasOffsets();
+                }
+
+                public override bool HasPositions()
+                {
+                    return delegateTerms.HasPositions();
+                }
+
+                public override bool HasPayloads()
+                {
+                    return delegateTerms.HasPayloads();
+                }
+            }
+
+            internal sealed class BloomFilteredTermsEnum : TermsEnum
+            {
+                private Terms delegateTerms;
+                internal TermsEnum delegateTermsEnum;
+                private TermsEnum reuseDelegate;
+                internal readonly FuzzySet filter;
+
+                public BloomFilteredTermsEnum(Terms delegateTerms, TermsEnum reuseDelegate, FuzzySet filter)
+                {
+                    this.delegateTerms = delegateTerms;
+                    this.reuseDelegate = reuseDelegate;
+                    this.filter = filter;
+                }
+
+                internal void Reset(Terms delegateTerms, TermsEnum reuseDelegate)
+                {
+                    this.delegateTerms = delegateTerms;
+                    this.reuseDelegate = reuseDelegate;
+                    this.delegateTermsEnum = null;
+                }
+
+                private TermsEnum Delegate()
+                {
+                    if (delegateTermsEnum == null)
+                    {
+                        /* pull the iterator only if we really need it -
+                    * this can be a relativly heavy operation depending on the 
+                    * delegate postings format and they underlying directory
+                    * (clone IndexInput) */
+                        delegateTermsEnum = delegateTerms.Iterator(reuseDelegate);
+                    }
+
+                    return delegateTermsEnum;
+                }
+
+                public override BytesRef Next()
+                {
+                    return Delegate().Next();
+                }
+
+                public override IComparer<BytesRef> Comparator
+                {
+                    get { return delegateTerms.Comparator; }
+                }
+
+                public override bool SeekExact(BytesRef text)
+                {
+                    // The magical fail-fast speed up that is the entire point of all of
+                    // this code - save a disk seek if there is a match on an in-memory
+                    // structure
+                    // that may occasionally give a false positive but guaranteed no false
+                    // negatives
+                    if (filter.Contains(text) == FuzzySet.ContainsResult.No)
+                    {
+                        return false;
+                    }
+                    return Delegate().SeekExact(text);
+                }
+
+                public override SeekStatus SeekCeil(BytesRef text)
+                {
+                    return Delegate().SeekCeil(text);
+                }
+
+                public override void SeekExact(long ord)
+                {
+                    Delegate().SeekExact(ord);
+                }
+
+                public override BytesRef Term()
+                {
+                    return Delegate().Term();
+                }
+
+                public override long Ord()
+                {
+                    return Delegate().Ord();
+                }
+
+                public override int DocFreq()
+                {
+                    return Delegate().DocFreq();
+                }
+
+                public override long TotalTermFreq()
+                {
+                    return Delegate().TotalTermFreq();
+                }
+
+                public override DocsAndPositionsEnum DocsAndPositions(Bits liveDocs,
+                    DocsAndPositionsEnum reuse, int flags)
+                {
+                    return Delegate().DocsAndPositions(liveDocs, reuse, flags);
+                }
+
+                public override DocsEnum Docs(Bits liveDocs, DocsEnum reuse, int flags)
+                {
+                    return Delegate().Docs(liveDocs, reuse, flags);
+                }
+            }
+
+        }
+
+        internal class BloomFilteredFieldsConsumer : FieldsConsumer
+        {
+            private FieldsConsumer delegateFieldsConsumer;
+            private Dictionary<FieldInfo, FuzzySet> bloomFilters = new Dictionary<FieldInfo, FuzzySet>();
+            private SegmentWriteState state;
+
+            public BloomFilteredFieldsConsumer(FieldsConsumer fieldsConsumer,
+                SegmentWriteState state, PostingsFormat delegatePostingsFormat)
+            {
+                this.delegateFieldsConsumer = fieldsConsumer;
+                this.state = state;
+            }
+
+            public override TermsConsumer AddField(FieldInfo field)
+            {
+                FuzzySet bloomFilter = bloomFilterFactory.GetSetForField(state, field);
+                if (bloomFilter != null)
+                {
+                    Debug.Debug.Assert((bloomFilters.ContainsKey(field) == false);
+                    bloomFilters.Add(field, bloomFilter);
+                    return new WrappedTermsConsumer(delegateFieldsConsumer.AddField(field), bloomFilter);
+                }
+                else
+                {
+                    // No, use the unfiltered fieldsConsumer - we are not interested in
+                    // recording any term Bitsets.
+                    return delegateFieldsConsumer.AddField(field);
+                }
+            }
+
+            public override void Dispose()
+            {
+                delegateFieldsConsumer.Dispose();
+                // Now we are done accumulating values for these fields
+                var nonSaturatedBlooms = new List<KeyValuePair<FieldInfo, FuzzySet>>();
+
+                foreach (var entry in bloomFilters.EntrySet())
+                {
+                    FuzzySet bloomFilter = entry.Value;
+                    if (!bloomFilterFactory.IsSaturated(bloomFilter, entry.Key))
+                    {
+                        nonSaturatedBlooms.Add(entry);
+                    }
+                }
+
+                String bloomFileName = IndexFileNames.SegmentFileName(
+                    state.SegmentInfo.Name, state.SegmentSuffix, BLOOM_EXTENSION);
+                IndexOutput bloomOutput = null;
+
+                try
+                {
+                    bloomOutput = state.Directory.CreateOutput(bloomFileName, state.Context);
+                    CodecUtil.WriteHeader(bloomOutput, BLOOM_CODEC_NAME, VERSION_CURRENT);
+                    // remember the name of the postings format we will delegate to
+                    bloomOutput.WriteString(delegatePostingsFormat.Name);
+
+                    // First field in the output file is the number of fields+blooms saved
+                    bloomOutput.WriteInt(nonSaturatedBlooms.Count);
+                    foreach (var entry in nonSaturatedBlooms)
+                    {
+                        FieldInfo fieldInfo = entry.Key;
+                        FuzzySet bloomFilter = entry.Value;
+                        bloomOutput.WriteInt(fieldInfo.Number);
+                        SaveAppropriatelySizedBloomFilter(bloomOutput, bloomFilter, fieldInfo);
+                    }
+
+                    CodecUtil.WriteFooter(bloomOutput);
+                }
+                finally
+                {
+                    IOUtils.Close(bloomOutput);
+                }
+                //We are done with large bitsets so no need to keep them hanging around
+                bloomFilters.Clear();
+            }
+
+            private void SaveAppropriatelySizedBloomFilter(IndexOutput bloomOutput,
+                FuzzySet bloomFilter, FieldInfo fieldInfo)
+            {
+
+                FuzzySet rightSizedSet = bloomFilterFactory.Downsize(fieldInfo,
+                    bloomFilter);
+                if (rightSizedSet == null)
+                {
+                    rightSizedSet = bloomFilter;
+                }
+                rightSizedSet.Serialize(bloomOutput);
+            }
+
+        }
+
+        internal class WrappedTermsConsumer : TermsConsumer
+        {
+            private TermsConsumer delegateTermsConsumer;
+            private FuzzySet bloomFilter;
+
+            public WrappedTermsConsumer(TermsConsumer termsConsumer, FuzzySet bloomFilter)
+            {
+                this.delegateTermsConsumer = termsConsumer;
+                this.bloomFilter = bloomFilter;
+            }
+
+            public override PostingsConsumer StartTerm(BytesRef text)
+            {
+                return delegateTermsConsumer.StartTerm(text);
+            }
+
+            public override void FinishTerm(BytesRef text, TermStats stats)
+            {
+                // Record this term in our BloomFilter
+                if (stats.DocFreq > 0)
+                {
+                    bloomFilter.AddValue(text);
+                }
+                delegateTermsConsumer.FinishTerm(text, stats);
+            }
+
+            public override void Finish(long sumTotalTermFreq, long sumDocFreq, int docCount)
+            {
+                delegateTermsConsumer.Finish(sumTotalTermFreq, sumDocFreq, docCount);
+            }
+
+            public override IComparer<BytesRef> Comparator
+            {
+                get { return delegateTermsConsumer.Comparator; }
+            }
+
+        }
+
+    }
+}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/src/Lucene.Net.Codecs/Bloom/DefaultBloomFilterFactory.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Codecs/Bloom/DefaultBloomFilterFactory.cs b/src/Lucene.Net.Codecs/Bloom/DefaultBloomFilterFactory.cs
new file mode 100644
index 0000000..6d1bb54
--- /dev/null
+++ b/src/Lucene.Net.Codecs/Bloom/DefaultBloomFilterFactory.cs
@@ -0,0 +1,45 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+namespace Lucene.Net.Codecs.Bloom
+{
+    using Lucene.Net.Index;
+
+    /// <summary>
+    /// Default policy is to allocate a bitset with 10% saturation given a unique term per document.
+    /// Bits are set via MurmurHash2 hashing function.
+    ///
+    /// @lucene.experimental
+    /// </summary>
+    public class DefaultBloomFilterFactory : BloomFilterFactory
+    {
+
+        public override FuzzySet GetSetForField(SegmentWriteState state, FieldInfo info)
+        {
+            //Assume all of the docs have a unique term (e.g. a primary key) and we hope to maintain a set with 10% of bits set
+            return FuzzySet.CreateSetBasedOnQuality(state.SegmentInfo.DocCount, 0.10f);
+        }
+
+        public override bool IsSaturated(FuzzySet bloomFilter, FieldInfo fieldInfo)
+        {
+            // Don't bother saving bitsets if >90% of bits are set - we don't want to
+            // throw any more memory at this problem.
+            return bloomFilter.GetSaturation() > 0.9f;
+        }
+
+    }
+}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/src/Lucene.Net.Codecs/Bloom/FuzzySet.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Codecs/Bloom/FuzzySet.cs b/src/Lucene.Net.Codecs/Bloom/FuzzySet.cs
new file mode 100644
index 0000000..5a97564
--- /dev/null
+++ b/src/Lucene.Net.Codecs/Bloom/FuzzySet.cs
@@ -0,0 +1,347 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+namespace Lucene.Net.Codecs.Bloom
+{
+
+    using System;
+    using System.Diagnostics;
+    using Lucene.Net.Store;
+    using Lucene.Net.Util;
+
+    /// <summary>
+    /// A class used to represent a set of many, potentially large, values (e.g. many
+    /// long strings such as URLs), using a significantly smaller amount of memory.
+    ///
+    /// The set is "lossy" in that it cannot definitively state that is does contain
+    /// a value but it <em>can</em> definitively say if a value is <em>not</em> in
+    /// the set. It can therefore be used as a Bloom Filter.
+    /// 
+    /// Another application of the set is that it can be used to perform fuzzy counting because
+    /// it can estimate reasonably accurately how many unique values are contained in the set. 
+    ///
+    /// This class is NOT threadsafe.
+    ///
+    /// Internally a Bitset is used to record values and once a client has finished recording
+    /// a stream of values the {@link #downsize(float)} method can be used to create a suitably smaller set that
+    /// is sized appropriately for the number of values recorded and desired saturation levels. 
+    /// 
+    /// @lucene.experimental
+    /// </summary>
+    public class FuzzySet
+    {
+
+        public static readonly int VERSION_SPI = 1; // HashFunction used to be loaded through a SPI
+        public static readonly int VERSION_START = VERSION_SPI;
+        public static readonly int VERSION_CURRENT = 2;
+
+        public static HashFunction hashFunctionForVersion(int version)
+        {
+            if (version < VERSION_START)
+            {
+                throw new ArgumentException("Version " + version + " is too old, expected at least " +
+                                                   VERSION_START);
+            }
+            else if (version > VERSION_CURRENT)
+            {
+                throw new ArgumentException("Version " + version + " is too new, expected at most " +
+                                                   VERSION_CURRENT);
+            }
+            return MurmurHash2.INSTANCE;
+        }
+
+        /// <remarks>
+        /// Result from {@link FuzzySet#contains(BytesRef)}:
+        /// can never return definitively YES (always MAYBE), 
+        /// but can sometimes definitely return NO.
+        /// </remarks>
+        public enum ContainsResult
+        {
+            Maybe,
+            No
+        };
+
+        private readonly HashFunction hashFunction;
+        private readonly FixedBitSet filter;
+        private readonly int bloomSize;
+
+        //The sizes of BitSet used are all numbers that, when expressed in binary form,
+        //are all ones. This is to enable fast downsizing from one bitset to another
+        //by simply ANDing each set index in one bitset with the size of the target bitset
+        // - this provides a fast modulo of the number. Values previously accumulated in
+        // a large bitset and then mapped to a smaller set can be looked up using a single
+        // AND operation of the query term's hash rather than needing to perform a 2-step
+        // translation of the query term that mirrors the stored content's reprojections.
+        private static int[] usableBitSetSizes;
+
+        private static 
+        {
+            usableBitSetSizes = new int[30];
+            int mask = 1;
+            int size = mask;
+            for (int i = 0; i < usableBitSetSizes.Length; i++)
+            {
+                size = (size << 1) | mask;
+                usableBitSetSizes[i] = size;
+            }
+        }
+
+        /**
+   * Rounds down required maxNumberOfBits to the nearest number that is made up
+   * of all ones as a binary number.  
+   * Use this method where controlling memory use is paramount.
+   */
+
+        public static int GetNearestSetSize(int maxNumberOfBits)
+        {
+            int result = usableBitSetSizes[0];
+            for (int i = 0; i < usableBitSetSizes.Length; i++)
+            {
+                if (usableBitSetSizes[i] <= maxNumberOfBits)
+                {
+                    result = usableBitSetSizes[i];
+                }
+            }
+            return result;
+        }
+
+        /**
+   * Use this method to choose a set size where accuracy (low content saturation) is more important
+   * than deciding how much memory to throw at the problem.
+   * @param desiredSaturation A number between 0 and 1 expressing the % of bits set once all values have been recorded
+   * @return The size of the set nearest to the required size
+   */
+
+        public static int GetNearestSetSize(int maxNumberOfValuesExpected,
+            float desiredSaturation)
+        {
+            // Iterate around the various scales of bitset from smallest to largest looking for the first that
+            // satisfies value volumes at the chosen saturation level
+            for (int i = 0; i < usableBitSetSizes.Length; i++)
+            {
+                int numSetBitsAtDesiredSaturation = (int) (usableBitSetSizes[i]*desiredSaturation);
+                int estimatedNumUniqueValues = GetEstimatedNumberUniqueValuesAllowingForCollisions(
+                    usableBitSetSizes[i], numSetBitsAtDesiredSaturation);
+                if (estimatedNumUniqueValues > maxNumberOfValuesExpected)
+                {
+                    return usableBitSetSizes[i];
+                }
+            }
+            return -1;
+        }
+
+        public static FuzzySet CreateSetBasedOnMaxMemory(int maxNumBytes)
+        {
+            int setSize = GetNearestSetSize(maxNumBytes);
+            return new FuzzySet(new FixedBitSet(setSize + 1), setSize, hashFunctionForVersion(VERSION_CURRENT));
+        }
+
+        public static FuzzySet CreateSetBasedOnQuality(int maxNumUniqueValues, float desiredMaxSaturation)
+        {
+            int setSize = GetNearestSetSize(maxNumUniqueValues, desiredMaxSaturation);
+            return new FuzzySet(new FixedBitSet(setSize + 1), setSize, hashFunctionForVersion(VERSION_CURRENT));
+        }
+
+        private FuzzySet(FixedBitSet filter, int bloomSize, HashFunction hashFunction)
+        {
+            this.filter = filter;
+            this.bloomSize = bloomSize;
+            this.hashFunction = hashFunction;
+        }
+
+        /**
+   * The main method required for a Bloom filter which, given a value determines set membership.
+   * Unlike a conventional set, the fuzzy set returns NO or MAYBE rather than true or false.
+   * @return NO or MAYBE
+   */
+
+        public ContainsResult Contains(BytesRef value)
+        {
+            int hash = hashFunction.Hash(value);
+            if (hash < 0)
+            {
+                hash = hash*-1;
+            }
+            return MayContainValue(hash);
+        }
+
+        /**
+   * Serializes the data set to file using the following format:
+   * <ul>
+   *  <li>FuzzySet --&gt;FuzzySetVersion,HashFunctionName,BloomSize,
+   * NumBitSetWords,BitSetWord<sup>NumBitSetWords</sup></li> 
+   * <li>HashFunctionName --&gt; {@link DataOutput#writeString(String) String} The
+   * name of a ServiceProvider registered {@link HashFunction}</li>
+   * <li>FuzzySetVersion --&gt; {@link DataOutput#writeInt Uint32} The version number of the {@link FuzzySet} class</li>
+   * <li>BloomSize --&gt; {@link DataOutput#writeInt Uint32} The modulo value used
+   * to project hashes into the field's Bitset</li>
+   * <li>NumBitSetWords --&gt; {@link DataOutput#writeInt Uint32} The number of
+   * longs (as returned from {@link FixedBitSet#getBits})</li>
+   * <li>BitSetWord --&gt; {@link DataOutput#writeLong Long} A long from the array
+   * returned by {@link FixedBitSet#getBits}</li>
+   * </ul>
+   * @param out Data output stream
+   * @ If there is a low-level I/O error
+   */
+
+        public void Serialize(DataOutput output)
+        {
+            output.WriteInt(VERSION_CURRENT);
+            output.WriteInt(bloomSize);
+            long[] bits = filter.GetBits();
+            output.WriteInt(bits.Length);
+            for (int i = 0; i < bits.Length; i++)
+            {
+                // Can't used VLong encoding because cant cope with negative numbers
+                // output by FixedBitSet
+                output.WriteLong(bits[i]);
+            }
+        }
+
+        public static FuzzySet Deserialize(DataInput input)
+        {
+            int version = input.ReadInt();
+            if (version == VERSION_SPI)
+            {
+                input.ReadString();
+            }
+            HashFunction hashFunction = hashFunctionForVersion(version);
+            int bloomSize = input.ReadInt();
+            int numLongs = input.ReadInt();
+            long[] longs = new long[numLongs];
+            for (int i = 0; i < numLongs; i++)
+            {
+                longs[i] = input.ReadLong();
+            }
+            FixedBitSet bits = new FixedBitSet(longs, bloomSize + 1);
+            return new FuzzySet(bits, bloomSize, hashFunction);
+        }
+
+        private ContainsResult MayContainValue(int positiveHash)
+        {
+            Debug.Debug.Assert((positiveHash >= 0);
+
+            // Bloom sizes are always base 2 and so can be ANDed for a fast modulo
+            int pos = positiveHash & bloomSize;
+            if (filter.Get(pos))
+            {
+                // This term may be recorded in this index (but could be a collision)
+                return ContainsResult.Maybe;
+            }
+            // definitely NOT in this segment
+            return ContainsResult.No;
+        }
+
+        /**
+   * Records a value in the set. The referenced bytes are hashed and then modulo n'd where n is the
+   * chosen size of the internal bitset.
+   * @param value the key value to be hashed
+   * @ If there is a low-level I/O error
+   */
+
+        public void AddValue(BytesRef value)
+        {
+            int hash = hashFunction.Hash(value);
+            if (hash < 0)
+            {
+                hash = hash*-1;
+            }
+            // Bitmasking using bloomSize is effectively a modulo operation.
+            int bloomPos = hash & bloomSize;
+            filter.Set(bloomPos);
+        }
+
+
+        /**
+   * 
+   * @param targetMaxSaturation A number between 0 and 1 describing the % of bits that would ideally be set in the 
+   * result. Lower values have better accuracy but require more space.
+   * @return a smaller FuzzySet or null if the current set is already over-saturated
+   */
+
+        public FuzzySet Downsize(float targetMaxSaturation)
+        {
+            int numBitsSet = filter.Cardinality();
+            FixedBitSet rightSizedBitSet = filter;
+            int rightSizedBitSetSize = bloomSize;
+            //Hopefully find a smaller size bitset into which we can project accumulated values while maintaining desired saturation level
+            for (int i = 0; i < usableBitSetSizes.Length; i++)
+            {
+                int candidateBitsetSize = usableBitSetSizes[i];
+                float candidateSaturation = (float) numBitsSet
+                                            /(float) candidateBitsetSize;
+                if (candidateSaturation <= targetMaxSaturation)
+                {
+                    rightSizedBitSetSize = candidateBitsetSize;
+                    break;
+                }
+            }
+            // Re-project the numbers to a smaller space if necessary
+            if (rightSizedBitSetSize < bloomSize)
+            {
+                // Reset the choice of bitset to the smaller version
+                rightSizedBitSet = new FixedBitSet(rightSizedBitSetSize + 1);
+                // Map across the bits from the large set to the smaller one
+                int bitIndex = 0;
+                do
+                {
+                    bitIndex = filter.NextSetBit(bitIndex);
+                    if (bitIndex >= 0)
+                    {
+                        // Project the larger number into a smaller one effectively
+                        // modulo-ing by using the target bitset size as a mask
+                        int downSizedBitIndex = bitIndex & rightSizedBitSetSize;
+                        rightSizedBitSet.Set(downSizedBitIndex);
+                        bitIndex++;
+                    }
+                } while ((bitIndex >= 0) && (bitIndex <= bloomSize));
+            }
+            else
+            {
+                return null;
+            }
+            return new FuzzySet(rightSizedBitSet, rightSizedBitSetSize, hashFunction);
+        }
+
+        public int GetEstimatedUniqueValues()
+        {
+            return GetEstimatedNumberUniqueValuesAllowingForCollisions(bloomSize, filter.Cardinality());
+        }
+
+        // Given a set size and a the number of set bits, produces an estimate of the number of unique values recorded
+        public static int GetEstimatedNumberUniqueValuesAllowingForCollisions(
+            int setSize, int numRecordedBits)
+        {
+            double setSizeAsDouble = setSize;
+            double numRecordedBitsAsDouble = numRecordedBits;
+            double saturation = numRecordedBitsAsDouble/setSizeAsDouble;
+            double logInverseSaturation = Math.Log(1 - saturation)*-1;
+            return (int) (setSizeAsDouble*logInverseSaturation);
+        }
+
+        public float GetSaturation()
+        {
+            int numBitsSet = filter.Cardinality();
+            return (float) numBitsSet/(float) bloomSize;
+        }
+
+        public long RamBytesUsed()
+        {
+            return RamUsageEstimator.SizeOf(filter.GetBits());
+        }
+    }
+}

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/src/Lucene.Net.Codecs/Bloom/HashFunction.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Codecs/Bloom/HashFunction.cs b/src/Lucene.Net.Codecs/Bloom/HashFunction.cs
new file mode 100644
index 0000000..9431e1b
--- /dev/null
+++ b/src/Lucene.Net.Codecs/Bloom/HashFunction.cs
@@ -0,0 +1,40 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+namespace Lucene.Net.Codecs.Bloom
+{
+    using Lucene.Net.Util;
+
+    /// <summary>
+    /// Base class for hashing functions that can be referred to by name.
+    /// Subclasses are expected to provide threadsafe implementations of the hash function
+    /// on the range of bytes referenced in the provided {@link BytesRef}
+    /// 
+    /// @lucene.experimental
+    /// </summary>
+    public abstract class HashFunction
+    {
+
+        /// <summary>
+        /// Hashes the contents of the referenced bytes
+        /// @param bytes the data to be hashed
+        /// @return the hash of the bytes referenced by bytes.offset and length bytes.length
+        /// </summary>
+        public abstract int Hash(BytesRef bytes);
+
+    }
+}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/src/Lucene.Net.Codecs/Bloom/MurmurHash2.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Codecs/Bloom/MurmurHash2.cs b/src/Lucene.Net.Codecs/Bloom/MurmurHash2.cs
new file mode 100644
index 0000000..cb70d5d
--- /dev/null
+++ b/src/Lucene.Net.Codecs/Bloom/MurmurHash2.cs
@@ -0,0 +1,111 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+using System;
+
+namespace Lucene.Net.Codecs.Bloom
+{
+
+    using Lucene.Net.Util;
+
+    /// <summary>
+    /// This is a very fast, non-cryptographic hash suitable for general hash-based
+    /// lookup. See http://murmurhash.googlepages.com/ for more details.
+    ///
+    /// The C version of MurmurHash 2.0 found at that site was ported to Java by
+    /// Andrzej Bialecki (ab at getopt org).
+    ///
+    ///  The code from getopt.org was adapted by Mark Harwood in the form here as one of a pluggable choice of 
+    /// hashing functions as the core function had to be adapted to work with BytesRefs with offsets and lengths
+    /// rather than raw byte arrays.  
+    /// 
+    /// @lucene.experimental
+    /// </summary>
+    public sealed class MurmurHash2 : HashFunction
+    {
+
+        public static readonly MurmurHash2 INSTANCE = new MurmurHash2();
+
+        private MurmurHash2()
+        {
+        }
+
+        public static int Hash(byte[] data, uint seed, int offset, int len)
+        {
+            int m = 0x5bd1e995;
+            int r = 24;
+            int h = (int)(seed ^ (long)len);
+            int len_4 = len >> 2;
+            for (int i = 0; i < len_4; i++)
+            {
+                int i_4 = offset + (i << 2);
+                int k = data[i_4 + 3];
+                k = k << 8;
+                k = k | (data[i_4 + 2] & 0xff);
+                k = k << 8;
+                k = k | (data[i_4 + 1] & 0xff);
+                k = k << 8;
+                k = k | (data[i_4 + 0] & 0xff);
+                k *= m;
+                k ^= k >> r;
+                k *= m;
+                h *= m;
+                h ^= k;
+            }
+            int len_m = len_4 << 2;
+            int left = len - len_m;
+            if (left != 0)
+            {
+                if (left >= 3)
+                {
+                    h ^= data[offset + len - 3] << 16;
+                }
+                if (left >= 2)
+                {
+                    h ^= data[offset + len - 2] << 8;
+                }
+                if (left >= 1)
+                {
+                    h ^= data[offset + len - 1];
+                }
+                h *= m;
+            }
+            h ^= h >> 13;
+            h *= m;
+            h ^= h >> 15;
+            return h;
+        }
+
+        /// <summary>
+        /// Generates 32 bit hash from byte array with default seed value.
+        /// </summary>
+        /// <param name="data">byte array to hash</param>
+        /// <param name="offset">the start position in the array to hash</param>
+        /// <param name="len">length of the array elements to hash</param>
+        /// <returns>32 bit hash of the given array</returns>
+        public static int Hash32(byte[] data, int offset, int len)
+        {
+            return Hash(data, 0x9747b28c, offset, len);
+        }
+
+        public override int Hash(BytesRef br)
+        {
+            return Hash32((byte[])(Array)br.Bytes, br.Offset, br.Length);
+        }
+
+    }
+}

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/src/Lucene.Net.Codecs/DiskDV/DiskDocValuesFormat.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Codecs/DiskDV/DiskDocValuesFormat.cs b/src/Lucene.Net.Codecs/DiskDV/DiskDocValuesFormat.cs
new file mode 100644
index 0000000..c71295c
--- /dev/null
+++ b/src/Lucene.Net.Codecs/DiskDV/DiskDocValuesFormat.cs
@@ -0,0 +1,55 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+
+namespace Lucene.Net.Codecs.DiskDV
+{
+    using Lucene.Net.Codecs;
+    using Lucene.Net.Codecs.Lucene45;
+    using Lucene.Net.Index;
+    using System;
+
+    /// <summary>
+    /// DocValues format that keeps most things on disk.
+    /// Only things like disk offsets are loaded into ram.
+    ///
+    /// @lucene.experimental
+    /// </summary>
+    public sealed class DiskDocValuesFormat : DocValuesFormat
+    {
+
+        public const String DATA_CODEC = "DiskDocValuesData";
+        public const String DATA_EXTENSION = "dvdd";
+        public const String META_CODEC = "DiskDocValuesMetadata";
+        public const String META_EXTENSION = "dvdm";
+
+        public DiskDocValuesFormat() : base("Disk")
+        {
+        }
+
+        public override DocValuesConsumer FieldsConsumer(SegmentWriteState state)
+        {
+            return new Lucene45DocValuesConsumer(state, DATA_CODEC, DATA_EXTENSION, META_CODEC, META_EXTENSION);
+        }
+
+        public override DocValuesProducer FieldsProducer(SegmentReadState state)
+        {
+            return new DiskDocValuesProducer(state, DATA_CODEC, DATA_EXTENSION, META_CODEC, META_EXTENSION);
+        }
+
+    }
+}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/src/Lucene.Net.Codecs/DiskDV/DiskDocValuesProducer.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Codecs/DiskDV/DiskDocValuesProducer.cs b/src/Lucene.Net.Codecs/DiskDV/DiskDocValuesProducer.cs
new file mode 100644
index 0000000..a5241be
--- /dev/null
+++ b/src/Lucene.Net.Codecs/DiskDV/DiskDocValuesProducer.cs
@@ -0,0 +1,57 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+namespace Lucene.Net.Codecs.DiskDV
+{
+    using System;
+    using Lucene.Net.Codecs.Lucene45;
+    using Lucene.Net.Index;
+    using Lucene.Net.Store;
+    using Lucene.Net.Util.Packed;
+
+    public class DiskDocValuesProducer : Lucene45DocValuesProducer
+    {
+
+        public DiskDocValuesProducer(SegmentReadState state, String dataCodec, String dataExtension, String metaCodec,
+            String metaExtension) :
+                base(state, dataCodec, dataExtension, metaCodec, metaExtension)
+        {
+        }
+
+        protected override MonotonicBlockPackedReader GetAddressInstance(IndexInput data, FieldInfo field,
+            BinaryEntry bytes)
+        {
+            data.Seek(bytes.AddressesOffset);
+            return new MonotonicBlockPackedReader((IndexInput)data.Clone(), bytes.PackedIntsVersion, bytes.BlockSize, bytes.Count,
+                true);
+        }
+
+        protected override MonotonicBlockPackedReader GetIntervalInstance(IndexInput data, FieldInfo field,
+            BinaryEntry bytes)
+        {
+            throw new InvalidOperationException();
+        }
+
+        protected override MonotonicBlockPackedReader GetOrdIndexInstance(IndexInput data, FieldInfo field,
+            NumericEntry entry)
+        {
+            data.Seek(entry.Offset);
+            return new MonotonicBlockPackedReader((IndexInput)data.Clone(), entry.PackedIntsVersion, entry.BlockSize, entry.Count,
+                true);
+        }
+    }
+}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/src/Lucene.Net.Codecs/DiskDV/DiskNormsFormat.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Codecs/DiskDV/DiskNormsFormat.cs b/src/Lucene.Net.Codecs/DiskDV/DiskNormsFormat.cs
new file mode 100644
index 0000000..91dd77b
--- /dev/null
+++ b/src/Lucene.Net.Codecs/DiskDV/DiskNormsFormat.cs
@@ -0,0 +1,47 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+namespace Lucene.Net.Codecs.DiskDV
+{
+
+    using System;
+    using Lucene.Net.Codecs;
+    using Lucene.Net.Codecs.Lucene45;
+    using Lucene.Net.Index;
+
+    /// <summary>
+    /// Norms format that keeps all norms on disk
+    /// </summary>
+    public sealed class DiskNormsFormat : NormsFormat
+    {
+        private const String DATA_CODEC = "DiskNormsData";
+        private const String DATA_EXTENSION = "dnvd";
+        private const String META_CODEC = "DiskNormsMetadata";
+        private const String META_EXTENSION = "dnvm";
+
+        public override DocValuesConsumer NormsConsumer(SegmentWriteState state)
+        {
+            return new Lucene45DocValuesConsumer(state, DATA_CODEC, DATA_EXTENSION, META_CODEC, META_EXTENSION);
+        }
+
+        public override DocValuesProducer NormsProducer(SegmentReadState state)
+        {
+            return new DiskDocValuesProducer(state, DATA_CODEC, DATA_EXTENSION, META_CODEC, META_EXTENSION);
+        }
+
+    }
+}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/src/Lucene.Net.Codecs/Intblock/FixedIntBlockIndexInput.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Codecs/Intblock/FixedIntBlockIndexInput.cs b/src/Lucene.Net.Codecs/Intblock/FixedIntBlockIndexInput.cs
new file mode 100644
index 0000000..3594005
--- /dev/null
+++ b/src/Lucene.Net.Codecs/Intblock/FixedIntBlockIndexInput.cs
@@ -0,0 +1,68 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+using Lucene.Net.Store;
+
+namespace Lucene.Net.Codecs.Intblock
+{
+ 
+    /// <summary>
+    /// Naive int block API that writes vInts.  This is
+    /// expected to give poor performance; it's really only for
+    /// testing the pluggability.  One should typically use pfor instead. */
+    ///
+    /// Abstract base class that reads fixed-size blocks of ints
+    /// from an IndexInput.  While this is a simple approach, a
+    /// more performant approach would directly create an impl
+    /// of IntIndexInput inside Directory.  Wrapping a generic
+    /// IndexInput will likely cost performance.
+    /// 
+    /// @lucene.experimental
+    /// </summary>
+public abstract class FixedIntBlockIndexInput : IntIndexInput {
+
+  private readonly IndexInput input;
+  protected readonly int BlockSize;
+
+        protected FixedIntBlockIndexInput(IndexInput input)
+        {
+            this.input = input;
+            BlockSize = input.ReadVInt();
+        }
+
+  public override IntIndexInput.Reader reader() {
+    final int[] buffer = new int[BlockSize];
+    final IndexInput clone = in.clone();
+
+    // TODO: can this be simplified?
+    return new Reader(clone, buffer, this.GetBlockReader(clone, buffer));
+  }
+
+        public override void Close()
+        {
+            input.Close();
+        }
+
+  public override IntIndexInput.Index Index() {
+    return new Index();
+  }
+
+  protected abstract BlockReader getBlockReader(IndexInput in, int[] buffer);
+
+  
+}
+}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/src/Lucene.Net.Codecs/Intblock/FixedIntBlockIndexOutput.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Codecs/Intblock/FixedIntBlockIndexOutput.cs b/src/Lucene.Net.Codecs/Intblock/FixedIntBlockIndexOutput.cs
new file mode 100644
index 0000000..a83fd38
--- /dev/null
+++ b/src/Lucene.Net.Codecs/Intblock/FixedIntBlockIndexOutput.cs
@@ -0,0 +1,128 @@
+package org.apache.lucene.codecs.intblock;
+
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+/** Naive int block API that writes vInts.  This is
+ *  expected to give poor performance; it's really only for
+ *  testing the pluggability.  One should typically use pfor instead. */
+
+import java.io.IOException;
+
+import org.apache.lucene.codecs.sep.IntIndexOutput;
+import org.apache.lucene.store.DataOutput;
+import org.apache.lucene.store.IndexOutput;
+
+/** Abstract base class that writes fixed-size blocks of ints
+ *  to an IndexOutput.  While this is a simple approach, a
+ *  more performant approach would directly create an impl
+ *  of IntIndexOutput inside Directory.  Wrapping a generic
+ *  IndexInput will likely cost performance.
+ *
+ * @lucene.experimental
+ */
+public abstract class FixedIntBlockIndexOutput extends IntIndexOutput {
+
+  protected final IndexOutput out;
+  private final int blockSize;
+  protected final int[] buffer;
+  private int upto;
+
+  protected FixedIntBlockIndexOutput(IndexOutput out, int fixedBlockSize)  {
+    blockSize = fixedBlockSize;
+    this.out = out;
+    out.writeVInt(blockSize);
+    buffer = new int[blockSize];
+  }
+
+  protected abstract void flushBlock() ;
+
+  @Override
+  public IntIndexOutput.Index index() {
+    return new Index();
+  }
+
+  private class Index extends IntIndexOutput.Index {
+    long fp;
+    int upto;
+    long lastFP;
+    int lastUpto;
+
+    @Override
+    public void mark()  {
+      fp = out.getFilePointer();
+      upto = FixedIntBlockIndexOutput.this.upto;
+    }
+
+    @Override
+    public void copyFrom(IntIndexOutput.Index other, bool copyLast)  {
+      Index idx = (Index) other;
+      fp = idx.fp;
+      upto = idx.upto;
+      if (copyLast) {
+        lastFP = fp;
+        lastUpto = upto;
+      }
+    }
+
+    @Override
+    public void write(DataOutput indexOut, bool absolute)  {
+      if (absolute) {
+        indexOut.writeVInt(upto);
+        indexOut.writeVLong(fp);
+      } else if (fp == lastFP) {
+        // same block
+        Debug.Assert( upto >= lastUpto;
+        int uptoDelta = upto - lastUpto;
+        indexOut.writeVInt(uptoDelta << 1 | 1);
+      } else {      
+        // new block
+        indexOut.writeVInt(upto << 1);
+        indexOut.writeVLong(fp - lastFP);
+      }
+      lastUpto = upto;
+      lastFP = fp;
+    }
+
+    @Override
+    public String toString() {
+      return "fp=" + fp + " upto=" + upto;
+    }
+  }
+
+  @Override
+  public void write(int v)  {
+    buffer[upto++] = v;
+    if (upto == blockSize) {
+      flushBlock();
+      upto = 0;
+    }
+  }
+
+  @Override
+  public void close()  {
+    try {
+      if (upto > 0) {
+        // NOTE: entries in the block after current upto are
+        // invalid
+        flushBlock();
+      }
+    } finally {
+      out.close();
+    }
+  }
+}

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/src/Lucene.Net.Codecs/Intblock/IBlockReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Codecs/Intblock/IBlockReader.cs b/src/Lucene.Net.Codecs/Intblock/IBlockReader.cs
new file mode 100644
index 0000000..adf14ec
--- /dev/null
+++ b/src/Lucene.Net.Codecs/Intblock/IBlockReader.cs
@@ -0,0 +1,29 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+namespace Lucene.Net.Codecs.Intblock
+{
+    /// <summary>
+    /// Interface for fixed-size block decoders
+    /// 
+    /// Implementations should decode into the buffer in {@link #ReadBlock}
+    /// </summary>
+    public interface IBlockReader
+    {
+         void ReadBlock();
+    }
+}

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/src/Lucene.Net.Codecs/Intblock/Index.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Codecs/Intblock/Index.cs b/src/Lucene.Net.Codecs/Intblock/Index.cs
new file mode 100644
index 0000000..67710a6
--- /dev/null
+++ b/src/Lucene.Net.Codecs/Intblock/Index.cs
@@ -0,0 +1,81 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+namespace Lucene.Net.Codecs.Intblock
+{
+    using System;
+    using Lucene.Net.Codecs.Intblock;
+
+    internal class Index : IntIndexInput.Index 
+    {
+    private long fp;
+    private int upto;
+
+        public override void Read(final DataInput indexIn, final bool absolute)
+    {
+        if (absolute)
+        {
+            upto = indexIn.readVInt();
+            fp = indexIn.readVLong();
+        }
+        else
+        {
+            final
+            int uptoDelta = indexIn.readVInt();
+            if ((uptoDelta & 1) == 1)
+            {
+                // same block
+                upto += uptoDelta >> > 1;
+            }
+            else
+            {
+                // new block
+                upto = uptoDelta >> > 1;
+                fp += indexIn.readVLong();
+            }
+        }
+        Debug.Assert(
+        upto < blockSize;
+    }
+
+        public override void Seek(final IntIndexInput .Reader other)
+        {
+            ((Reader) other).seek(fp, upto);
+        }
+
+        public override void CopyFrom(IntIndexInput.Index other)
+        {
+            Index idx = (Index) other;
+            fp = idx.fp;
+            upto = idx.upto;
+        }
+
+        public override Index Clone()
+        {
+            Index other = new Index();
+            other.fp = fp;
+            other.upto = upto;
+            return other;
+        }
+
+        public override String ToString()
+        {
+            return "fp=" + fp + " upto=" + upto;
+        }
+    
+    }
+}

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/src/Lucene.Net.Codecs/Intblock/Reader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Codecs/Intblock/Reader.cs b/src/Lucene.Net.Codecs/Intblock/Reader.cs
new file mode 100644
index 0000000..8e0eb1d
--- /dev/null
+++ b/src/Lucene.Net.Codecs/Intblock/Reader.cs
@@ -0,0 +1,67 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+namespace Lucene.Net.Codecs.Intblock
+{
+    internal static class Reader : IntIndexInput.Reader
+    {
+
+    private final IndexInput in;
+    private final BlockReader blockReader;
+    private final int blockSize;
+    private final int[] pending;
+
+    private int upto;
+    private bool seekPending;
+    private long pendingFP;
+    private long lastBlockFP = -1;
+
+    public Reader(final IndexInput in, final int[] pending, final BlockReader blockReader) {
+      this.in = in;
+      this.pending = pending;
+      this.blockSize = pending.length;
+      this.blockReader = blockReader;
+      upto = blockSize;
+    }
+
+    void Seek(final long fp, final int upto) {
+      Debug.Assert( upto < blockSize;
+      if (seekPending || fp != lastBlockFP) {
+        pendingFP = fp;
+        seekPending = true;
+      }
+      this.upto = upto;
+    }
+
+    public override int Next() {
+      if (seekPending) {
+        // Seek & load new block
+        in.seek(pendingFP);
+        lastBlockFP = pendingFP;
+        blockReader.readBlock();
+        seekPending = false;
+      } else if (upto == blockSize) {
+        // Load new block
+        lastBlockFP = in.getFilePointer();
+        blockReader.readBlock();
+        upto = 0;
+      }
+      return pending[upto++];
+    }
+  }
+    }
+}


[25/51] [abbrv] [partial] Cleaning up and getting ready to development towards v4.8

Posted by sy...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/framework/nunit.framework.xml
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/framework/nunit.framework.xml b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/framework/nunit.framework.xml
deleted file mode 100644
index 87f666b..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/framework/nunit.framework.xml
+++ /dev/null
@@ -1,9832 +0,0 @@
-<?xml version="1.0"?>
-<doc>
-    <assembly>
-        <name>nunit.framework</name>
-    </assembly>
-    <members>
-        <member name="T:NUnit.Framework.CategoryAttribute">
-            <summary>
-            Attribute used to apply a category to a test
-            </summary>
-        </member>
-        <member name="F:NUnit.Framework.CategoryAttribute.categoryName">
-            <summary>
-            The name of the category
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.CategoryAttribute.#ctor(System.String)">
-            <summary>
-            Construct attribute for a given category based on
-            a name. The name may not contain the characters ',',
-            '+', '-' or '!'. However, this is not checked in the
-            constructor since it would cause an error to arise at
-            as the test was loaded without giving a clear indication
-            of where the problem is located. The error is handled
-            in NUnitFramework.cs by marking the test as not
-            runnable.
-            </summary>
-            <param name="name">The name of the category</param>
-        </member>
-        <member name="M:NUnit.Framework.CategoryAttribute.#ctor">
-            <summary>
-            Protected constructor uses the Type name as the name
-            of the category.
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.CategoryAttribute.Name">
-            <summary>
-            The name of the category
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.DatapointAttribute">
-            <summary>
-            Used to mark a field for use as a datapoint when executing a theory
-            within the same fixture that requires an argument of the field's Type.
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.DatapointsAttribute">
-            <summary>
-            Used to mark an array as containing a set of datapoints to be used
-            executing a theory within the same fixture that requires an argument 
-            of the Type of the array elements.
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.DescriptionAttribute">
-            <summary>
-            Attribute used to provide descriptive text about a 
-            test case or fixture.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.DescriptionAttribute.#ctor(System.String)">
-            <summary>
-            Construct the attribute
-            </summary>
-            <param name="description">Text describing the test</param>
-        </member>
-        <member name="P:NUnit.Framework.DescriptionAttribute.Description">
-            <summary>
-            Gets the test description
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.MessageMatch">
-            <summary>
-            Enumeration indicating how the expected message parameter is to be used
-            </summary>
-        </member>
-        <member name="F:NUnit.Framework.MessageMatch.Exact">
-            Expect an exact match
-        </member>
-        <member name="F:NUnit.Framework.MessageMatch.Contains">
-            Expect a message containing the parameter string
-        </member>
-        <member name="F:NUnit.Framework.MessageMatch.Regex">
-            Match the regular expression provided as a parameter
-        </member>
-        <member name="F:NUnit.Framework.MessageMatch.StartsWith">
-            Expect a message that starts with the parameter string
-        </member>
-        <member name="T:NUnit.Framework.ExpectedExceptionAttribute">
-            <summary>
-            ExpectedExceptionAttribute
-            </summary>
-            
-        </member>
-        <member name="M:NUnit.Framework.ExpectedExceptionAttribute.#ctor">
-            <summary>
-            Constructor for a non-specific exception
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.ExpectedExceptionAttribute.#ctor(System.Type)">
-            <summary>
-            Constructor for a given type of exception
-            </summary>
-            <param name="exceptionType">The type of the expected exception</param>
-        </member>
-        <member name="M:NUnit.Framework.ExpectedExceptionAttribute.#ctor(System.String)">
-            <summary>
-            Constructor for a given exception name
-            </summary>
-            <param name="exceptionName">The full name of the expected exception</param>
-        </member>
-        <member name="P:NUnit.Framework.ExpectedExceptionAttribute.ExpectedException">
-            <summary>
-            Gets or sets the expected exception type
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.ExpectedExceptionAttribute.ExpectedExceptionName">
-            <summary>
-            Gets or sets the full Type name of the expected exception
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.ExpectedExceptionAttribute.ExpectedMessage">
-            <summary>
-            Gets or sets the expected message text
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.ExpectedExceptionAttribute.UserMessage">
-            <summary>
-            Gets or sets the user message displayed in case of failure
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.ExpectedExceptionAttribute.MatchType">
-            <summary>
-             Gets or sets the type of match to be performed on the expected message
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.ExpectedExceptionAttribute.Handler">
-            <summary>
-             Gets the name of a method to be used as an exception handler
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.ExplicitAttribute">
-            <summary>
-            ExplicitAttribute marks a test or test fixture so that it will
-            only be run if explicitly executed from the gui or command line
-            or if it is included by use of a filter. The test will not be
-            run simply because an enclosing suite is run.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.ExplicitAttribute.#ctor">
-            <summary>
-            Default constructor
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.ExplicitAttribute.#ctor(System.String)">
-            <summary>
-            Constructor with a reason
-            </summary>
-            <param name="reason">The reason test is marked explicit</param>
-        </member>
-        <member name="P:NUnit.Framework.ExplicitAttribute.Reason">
-            <summary>
-            The reason test is marked explicit
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.IgnoreAttribute">
-            <summary>
-            Attribute used to mark a test that is to be ignored.
-            Ignored tests result in a warning message when the
-            tests are run.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.IgnoreAttribute.#ctor">
-            <summary>
-            Constructs the attribute without giving a reason 
-            for ignoring the test.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.IgnoreAttribute.#ctor(System.String)">
-            <summary>
-            Constructs the attribute giving a reason for ignoring the test
-            </summary>
-            <param name="reason">The reason for ignoring the test</param>
-        </member>
-        <member name="P:NUnit.Framework.IgnoreAttribute.Reason">
-            <summary>
-            The reason for ignoring a test
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.IncludeExcludeAttribute">
-            <summary>
-            Abstract base for Attributes that are used to include tests
-            in the test run based on environmental settings.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.IncludeExcludeAttribute.#ctor">
-            <summary>
-            Constructor with no included items specified, for use
-            with named property syntax.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.IncludeExcludeAttribute.#ctor(System.String)">
-            <summary>
-            Constructor taking one or more included items
-            </summary>
-            <param name="include">Comma-delimited list of included items</param>
-        </member>
-        <member name="P:NUnit.Framework.IncludeExcludeAttribute.Include">
-            <summary>
-            Name of the item that is needed in order for
-            a test to run. Multiple itemss may be given,
-            separated by a comma.
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.IncludeExcludeAttribute.Exclude">
-            <summary>
-            Name of the item to be excluded. Multiple items
-            may be given, separated by a comma.
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.IncludeExcludeAttribute.Reason">
-            <summary>
-            The reason for including or excluding the test
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.PlatformAttribute">
-            <summary>
-            PlatformAttribute is used to mark a test fixture or an
-            individual method as applying to a particular platform only.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.PlatformAttribute.#ctor">
-            <summary>
-            Constructor with no platforms specified, for use
-            with named property syntax.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.PlatformAttribute.#ctor(System.String)">
-            <summary>
-            Constructor taking one or more platforms
-            </summary>
-            <param name="platforms">Comma-deliminted list of platforms</param>
-        </member>
-        <member name="T:NUnit.Framework.CultureAttribute">
-            <summary>
-            CultureAttribute is used to mark a test fixture or an
-            individual method as applying to a particular Culture only.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.CultureAttribute.#ctor">
-            <summary>
-            Constructor with no cultures specified, for use
-            with named property syntax.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.CultureAttribute.#ctor(System.String)">
-            <summary>
-            Constructor taking one or more cultures
-            </summary>
-            <param name="cultures">Comma-deliminted list of cultures</param>
-        </member>
-        <member name="T:NUnit.Framework.CombinatorialAttribute">
-            <summary>
-            Marks a test to use a combinatorial join of any argument data 
-            provided. NUnit will create a test case for every combination of 
-            the arguments provided. This can result in a large number of test
-            cases and so should be used judiciously. This is the default join
-            type, so the attribute need not be used except as documentation.
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.PropertyAttribute">
-            <summary>
-            PropertyAttribute is used to attach information to a test as a name/value pair..
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.PropertyAttribute.#ctor(System.String,System.String)">
-            <summary>
-            Construct a PropertyAttribute with a name and string value
-            </summary>
-            <param name="propertyName">The name of the property</param>
-            <param name="propertyValue">The property value</param>
-        </member>
-        <member name="M:NUnit.Framework.PropertyAttribute.#ctor(System.String,System.Int32)">
-            <summary>
-            Construct a PropertyAttribute with a name and int value
-            </summary>
-            <param name="propertyName">The name of the property</param>
-            <param name="propertyValue">The property value</param>
-        </member>
-        <member name="M:NUnit.Framework.PropertyAttribute.#ctor(System.String,System.Double)">
-            <summary>
-            Construct a PropertyAttribute with a name and double value
-            </summary>
-            <param name="propertyName">The name of the property</param>
-            <param name="propertyValue">The property value</param>
-        </member>
-        <member name="M:NUnit.Framework.PropertyAttribute.#ctor">
-            <summary>
-            Constructor for derived classes that set the
-            property dictionary directly.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.PropertyAttribute.#ctor(System.Object)">
-            <summary>
-            Constructor for use by derived classes that use the
-            name of the type as the property name. Derived classes
-            must ensure that the Type of the property value is
-            a standard type supported by the BCL. Any custom
-            types will cause a serialization Exception when
-            in the client.
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.PropertyAttribute.Properties">
-            <summary>
-            Gets the property dictionary for this attribute
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.CombinatorialAttribute.#ctor">
-            <summary>
-            Default constructor
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.PairwiseAttribute">
-            <summary>
-            Marks a test to use pairwise join of any argument data provided. 
-            NUnit will attempt too excercise every pair of argument values at 
-            least once, using as small a number of test cases as it can. With
-            only two arguments, this is the same as a combinatorial join.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.PairwiseAttribute.#ctor">
-            <summary>
-            Default constructor
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.SequentialAttribute">
-            <summary>
-            Marks a test to use a sequential join of any argument data
-            provided. NUnit will use arguements for each parameter in
-            sequence, generating test cases up to the largest number
-            of argument values provided and using null for any arguments
-            for which it runs out of values. Normally, this should be
-            used with the same number of arguments for each parameter.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.SequentialAttribute.#ctor">
-            <summary>
-            Default constructor
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.MaxTimeAttribute">
-            <summary>
-            Summary description for MaxTimeAttribute.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.MaxTimeAttribute.#ctor(System.Int32)">
-            <summary>
-            Construct a MaxTimeAttribute, given a time in milliseconds.
-            </summary>
-            <param name="milliseconds">The maximum elapsed time in milliseconds</param>
-        </member>
-        <member name="T:NUnit.Framework.RandomAttribute">
-            <summary>
-            RandomAttribute is used to supply a set of random values
-            to a single parameter of a parameterized test.
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.ValuesAttribute">
-            <summary>
-            ValuesAttribute is used to provide literal arguments for
-            an individual parameter of a test.
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.ParameterDataAttribute">
-            <summary>
-            Abstract base class for attributes that apply to parameters 
-            and supply data for the parameter.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.ParameterDataAttribute.GetData(System.Reflection.ParameterInfo)">
-            <summary>
-            Gets the data to be provided to the specified parameter
-            </summary>
-        </member>
-        <member name="F:NUnit.Framework.ValuesAttribute.data">
-            <summary>
-            The collection of data to be returned. Must
-            be set by any derived attribute classes.
-            We use an object[] so that the individual
-            elements may have their type changed in GetData
-            if necessary.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.ValuesAttribute.#ctor(System.Object)">
-            <summary>
-            Construct with one argument
-            </summary>
-            <param name="arg1"></param>
-        </member>
-        <member name="M:NUnit.Framework.ValuesAttribute.#ctor(System.Object,System.Object)">
-            <summary>
-            Construct with two arguments
-            </summary>
-            <param name="arg1"></param>
-            <param name="arg2"></param>
-        </member>
-        <member name="M:NUnit.Framework.ValuesAttribute.#ctor(System.Object,System.Object,System.Object)">
-            <summary>
-            Construct with three arguments
-            </summary>
-            <param name="arg1"></param>
-            <param name="arg2"></param>
-            <param name="arg3"></param>
-        </member>
-        <member name="M:NUnit.Framework.ValuesAttribute.#ctor(System.Object[])">
-            <summary>
-            Construct with an array of arguments
-            </summary>
-            <param name="args"></param>
-        </member>
-        <member name="M:NUnit.Framework.ValuesAttribute.GetData(System.Reflection.ParameterInfo)">
-            <summary>
-            Get the collection of values to be used as arguments
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.RandomAttribute.#ctor(System.Int32)">
-            <summary>
-            Construct a set of doubles from 0.0 to 1.0,
-            specifying only the count.
-            </summary>
-            <param name="count"></param>
-        </member>
-        <member name="M:NUnit.Framework.RandomAttribute.#ctor(System.Double,System.Double,System.Int32)">
-            <summary>
-            Construct a set of doubles from min to max
-            </summary>
-            <param name="min"></param>
-            <param name="max"></param>
-            <param name="count"></param>
-        </member>
-        <member name="M:NUnit.Framework.RandomAttribute.#ctor(System.Int32,System.Int32,System.Int32)">
-            <summary>
-            Construct a set of ints from min to max
-            </summary>
-            <param name="min"></param>
-            <param name="max"></param>
-            <param name="count"></param>
-        </member>
-        <member name="M:NUnit.Framework.RandomAttribute.GetData(System.Reflection.ParameterInfo)">
-            <summary>
-            Get the collection of values to be used as arguments
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.RangeAttribute">
-            <summary>
-            RangeAttribute is used to supply a range of values to an
-            individual parameter of a parameterized test.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.RangeAttribute.#ctor(System.Int32,System.Int32)">
-            <summary>
-            Construct a range of ints using default step of 1
-            </summary>
-            <param name="from"></param>
-            <param name="to"></param>
-        </member>
-        <member name="M:NUnit.Framework.RangeAttribute.#ctor(System.Int32,System.Int32,System.Int32)">
-            <summary>
-            Construct a range of ints specifying the step size 
-            </summary>
-            <param name="from"></param>
-            <param name="to"></param>
-            <param name="step"></param>
-        </member>
-        <member name="M:NUnit.Framework.RangeAttribute.#ctor(System.Int64,System.Int64,System.Int64)">
-            <summary>
-            Construct a range of longs
-            </summary>
-            <param name="from"></param>
-            <param name="to"></param>
-            <param name="step"></param>
-        </member>
-        <member name="M:NUnit.Framework.RangeAttribute.#ctor(System.Double,System.Double,System.Double)">
-            <summary>
-            Construct a range of doubles
-            </summary>
-            <param name="from"></param>
-            <param name="to"></param>
-            <param name="step"></param>
-        </member>
-        <member name="M:NUnit.Framework.RangeAttribute.#ctor(System.Single,System.Single,System.Single)">
-            <summary>
-            Construct a range of floats
-            </summary>
-            <param name="from"></param>
-            <param name="to"></param>
-            <param name="step"></param>
-        </member>
-        <member name="T:NUnit.Framework.RepeatAttribute">
-            <summary>
-            RepeatAttribute may be applied to test case in order
-            to run it multiple times.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.RepeatAttribute.#ctor(System.Int32)">
-            <summary>
-            Construct a RepeatAttribute
-            </summary>
-            <param name="count">The number of times to run the test</param>
-        </member>
-        <member name="T:NUnit.Framework.RequiredAddinAttribute">
-            <summary>
-            RequiredAddinAttribute may be used to indicate the names of any addins
-            that must be present in order to run some or all of the tests in an
-            assembly. If the addin is not loaded, the entire assembly is marked
-            as NotRunnable.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.RequiredAddinAttribute.#ctor(System.String)">
-            <summary>
-            Initializes a new instance of the <see cref="T:RequiredAddinAttribute"/> class.
-            </summary>
-            <param name="requiredAddin">The required addin.</param>
-        </member>
-        <member name="P:NUnit.Framework.RequiredAddinAttribute.RequiredAddin">
-            <summary>
-            Gets the name of required addin.
-            </summary>
-            <value>The required addin name.</value>
-        </member>
-        <member name="T:NUnit.Framework.SetCultureAttribute">
-            <summary>
-            Summary description for SetCultureAttribute.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.SetCultureAttribute.#ctor(System.String)">
-            <summary>
-            Construct given the name of a culture
-            </summary>
-            <param name="culture"></param>
-        </member>
-        <member name="T:NUnit.Framework.SetUICultureAttribute">
-            <summary>
-            Summary description for SetUICultureAttribute.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.SetUICultureAttribute.#ctor(System.String)">
-            <summary>
-            Construct given the name of a culture
-            </summary>
-            <param name="culture"></param>
-        </member>
-        <member name="T:NUnit.Framework.SetUpAttribute">
-            <summary>
-            Attribute used to mark a class that contains one-time SetUp 
-            and/or TearDown methods that apply to all the tests in a
-            namespace or an assembly.
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.SetUpFixtureAttribute">
-            <summary>
-            SetUpFixtureAttribute is used to identify a SetUpFixture
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.SuiteAttribute">
-            <summary>
-            Attribute used to mark a static (shared in VB) property
-            that returns a list of tests.
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.TearDownAttribute">
-            <summary>
-            Attribute used to identify a method that is called 
-            immediately after each test is run. The method is 
-            guaranteed to be called, even if an exception is thrown.
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.TestAttribute">
-            <summary>
-            Adding this attribute to a method within a <seealso cref="T:NUnit.Framework.TestFixtureAttribute"/> 
-            class makes the method callable from the NUnit test runner. There is a property 
-            called Description which is optional which you can provide a more detailed test
-            description. This class cannot be inherited.
-            </summary>
-            
-            <example>
-            [TestFixture]
-            public class Fixture
-            {
-              [Test]
-              public void MethodToTest()
-              {}
-              
-              [Test(Description = "more detailed description")]
-              publc void TestDescriptionMethod()
-              {}
-            }
-            </example>
-            
-        </member>
-        <member name="P:NUnit.Framework.TestAttribute.Description">
-            <summary>
-            Descriptive text for this test
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.TestCaseAttribute">
-            <summary>
-            TestCaseAttribute is used to mark parameterized test cases
-            and provide them with their arguments.
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.ITestCaseData">
-            <summary>
-            The ITestCaseData interface is implemented by a class
-            that is able to return complete testcases for use by
-            a parameterized test method.
-            
-            NOTE: This interface is used in both the framework
-            and the core, even though that results in two different
-            types. However, sharing the source code guarantees that
-            the various implementations will be compatible and that
-            the core is able to reflect successfully over the
-            framework implementations of ITestCaseData.
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.ITestCaseData.Arguments">
-            <summary>
-            Gets the argument list to be provided to the test
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.ITestCaseData.Result">
-            <summary>
-            Gets the expected result
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.ITestCaseData.ExpectedException">
-            <summary>
-             Gets the expected exception Type
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.ITestCaseData.ExpectedExceptionName">
-            <summary>
-            Gets the FullName of the expected exception
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.ITestCaseData.TestName">
-            <summary>
-            Gets the name to be used for the test
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.ITestCaseData.Description">
-            <summary>
-            Gets the description of the test
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.ITestCaseData.Ignored">
-            <summary>
-            Gets a value indicating whether this <see cref="T:NUnit.Framework.ITestCaseData"/> is ignored.
-            </summary>
-            <value><c>true</c> if ignored; otherwise, <c>false</c>.</value>
-        </member>
-        <member name="P:NUnit.Framework.ITestCaseData.IgnoreReason">
-            <summary>
-            Gets the ignore reason.
-            </summary>
-            <value>The ignore reason.</value>
-        </member>
-        <member name="M:NUnit.Framework.TestCaseAttribute.#ctor(System.Object[])">
-            <summary>
-            Construct a TestCaseAttribute with a list of arguments.
-            This constructor is not CLS-Compliant
-            </summary>
-            <param name="arguments"></param>
-        </member>
-        <member name="M:NUnit.Framework.TestCaseAttribute.#ctor(System.Object)">
-            <summary>
-            Construct a TestCaseAttribute with a single argument
-            </summary>
-            <param name="arg"></param>
-        </member>
-        <member name="M:NUnit.Framework.TestCaseAttribute.#ctor(System.Object,System.Object)">
-            <summary>
-            Construct a TestCaseAttribute with a two arguments
-            </summary>
-            <param name="arg1"></param>
-            <param name="arg2"></param>
-        </member>
-        <member name="M:NUnit.Framework.TestCaseAttribute.#ctor(System.Object,System.Object,System.Object)">
-            <summary>
-            Construct a TestCaseAttribute with a three arguments
-            </summary>
-            <param name="arg1"></param>
-            <param name="arg2"></param>
-            <param name="arg3"></param>
-        </member>
-        <member name="P:NUnit.Framework.TestCaseAttribute.Arguments">
-            <summary>
-            Gets the list of arguments to a test case
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.TestCaseAttribute.Result">
-            <summary>
-            Gets or sets the expected result.
-            </summary>
-            <value>The result.</value>
-        </member>
-        <member name="P:NUnit.Framework.TestCaseAttribute.ExpectedException">
-            <summary>
-            Gets or sets the expected exception.
-            </summary>
-            <value>The expected exception.</value>
-        </member>
-        <member name="P:NUnit.Framework.TestCaseAttribute.ExpectedExceptionName">
-            <summary>
-            Gets or sets the name the expected exception.
-            </summary>
-            <value>The expected name of the exception.</value>
-        </member>
-        <member name="P:NUnit.Framework.TestCaseAttribute.ExpectedMessage">
-            <summary>
-            Gets or sets the expected message of the expected exception
-            </summary>
-            <value>The expected message of the exception.</value>
-        </member>
-        <member name="P:NUnit.Framework.TestCaseAttribute.MatchType">
-            <summary>
-             Gets or sets the type of match to be performed on the expected message
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.TestCaseAttribute.Description">
-            <summary>
-            Gets or sets the description.
-            </summary>
-            <value>The description.</value>
-        </member>
-        <member name="P:NUnit.Framework.TestCaseAttribute.TestName">
-            <summary>
-            Gets or sets the name of the test.
-            </summary>
-            <value>The name of the test.</value>
-        </member>
-        <member name="P:NUnit.Framework.TestCaseAttribute.Ignore">
-            <summary>
-            Gets or sets the ignored status of the test
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.TestCaseAttribute.Ignored">
-            <summary>
-            Gets or sets the ignored status of the test
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.TestCaseAttribute.IgnoreReason">
-            <summary>
-            Gets the ignore reason.
-            </summary>
-            <value>The ignore reason.</value>
-        </member>
-        <member name="T:NUnit.Framework.TestCaseSourceAttribute">
-            <summary>
-            FactoryAttribute indicates the source to be used to
-            provide test cases for a test method.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.TestCaseSourceAttribute.#ctor(System.String)">
-            <summary>
-            Construct with the name of the factory - for use with languages
-            that don't support params arrays.
-            </summary>
-            <param name="sourceName">An array of the names of the factories that will provide data</param>
-        </member>
-        <member name="M:NUnit.Framework.TestCaseSourceAttribute.#ctor(System.Type,System.String)">
-            <summary>
-            Construct with a Type and name - for use with languages
-            that don't support params arrays.
-            </summary>
-            <param name="sourceType">The Type that will provide data</param>
-            <param name="sourceName">The name of the method, property or field that will provide data</param>
-        </member>
-        <member name="P:NUnit.Framework.TestCaseSourceAttribute.SourceName">
-            <summary>
-            The name of a the method, property or fiend to be used as a source
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.TestCaseSourceAttribute.SourceType">
-            <summary>
-            A Type to be used as a source
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.TestFixtureAttribute">
-            <example>
-            [TestFixture]
-            public class ExampleClass 
-            {}
-            </example>
-        </member>
-        <member name="M:NUnit.Framework.TestFixtureAttribute.#ctor">
-            <summary>
-            Default constructor
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.TestFixtureAttribute.#ctor(System.Object[])">
-            <summary>
-            Construct with a object[] representing a set of arguments. 
-            In .NET 2.0, the arguments may later be separated into
-            type arguments and constructor arguments.
-            </summary>
-            <param name="arguments"></param>
-        </member>
-        <member name="P:NUnit.Framework.TestFixtureAttribute.Description">
-            <summary>
-            Descriptive text for this fixture
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.TestFixtureAttribute.Arguments">
-            <summary>
-            The arguments originally provided to the attribute
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.TestFixtureAttribute.Ignore">
-            <summary>
-            Gets or sets a value indicating whether this <see cref="T:NUnit.Framework.TestFixtureAttribute"/> should be ignored.
-            </summary>
-            <value><c>true</c> if ignore; otherwise, <c>false</c>.</value>
-        </member>
-        <member name="P:NUnit.Framework.TestFixtureAttribute.IgnoreReason">
-            <summary>
-            Gets or sets the ignore reason. May set Ignored as a side effect.
-            </summary>
-            <value>The ignore reason.</value>
-        </member>
-        <member name="T:NUnit.Framework.TestFixtureSetUpAttribute">
-            <summary>
-            Attribute used to identify a method that is 
-            called before any tests in a fixture are run.
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.TestFixtureTearDownAttribute">
-            <summary>
-            Attribute used to identify a method that is called after
-            all the tests in a fixture have run. The method is 
-            guaranteed to be called, even if an exception is thrown.
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.TheoryAttribute">
-            <summary>
-            Adding this attribute to a method within a <seealso cref="T:NUnit.Framework.TestFixtureAttribute"/> 
-            class makes the method callable from the NUnit test runner. There is a property 
-            called Description which is optional which you can provide a more detailed test
-            description. This class cannot be inherited.
-            </summary>
-            
-            <example>
-            [TestFixture]
-            public class Fixture
-            {
-              [Test]
-              public void MethodToTest()
-              {}
-              
-              [Test(Description = "more detailed description")]
-              publc void TestDescriptionMethod()
-              {}
-            }
-            </example>
-            
-        </member>
-        <member name="T:NUnit.Framework.TimeoutAttribute">
-            <summary>
-            WUsed on a method, marks the test with a timeout value in milliseconds. 
-            The test will be run in a separate thread and is cancelled if the timeout 
-            is exceeded. Used on a method or assembly, sets the default timeout 
-            for all contained test methods.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.TimeoutAttribute.#ctor(System.Int32)">
-            <summary>
-            Construct a TimeoutAttribute given a time in milliseconds
-            </summary>
-            <param name="timeout">The timeout value in milliseconds</param>
-        </member>
-        <member name="T:NUnit.Framework.RequiresSTAAttribute">
-            <summary>
-            Marks a test that must run in the STA, causing it
-            to run in a separate thread if necessary.
-            
-            On methods, you may also use STAThreadAttribute
-            to serve the same purpose.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.RequiresSTAAttribute.#ctor">
-            <summary>
-            Construct a RequiresSTAAttribute
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.RequiresMTAAttribute">
-            <summary>
-            Marks a test that must run in the MTA, causing it
-            to run in a separate thread if necessary.
-            
-            On methods, you may also use MTAThreadAttribute
-            to serve the same purpose.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.RequiresMTAAttribute.#ctor">
-            <summary>
-            Construct a RequiresMTAAttribute
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.RequiresThreadAttribute">
-            <summary>
-            Marks a test that must run on a separate thread.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.RequiresThreadAttribute.#ctor">
-            <summary>
-            Construct a RequiresThreadAttribute
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.RequiresThreadAttribute.#ctor(System.Threading.ApartmentState)">
-            <summary>
-            Construct a RequiresThreadAttribute, specifying the apartment
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.ValueSourceAttribute">
-            <summary>
-            ValueSourceAttribute indicates the source to be used to
-            provide data for one parameter of a test method.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.ValueSourceAttribute.#ctor(System.String)">
-            <summary>
-            Construct with the name of the factory - for use with languages
-            that don't support params arrays.
-            </summary>
-            <param name="sourceName">The name of the data source to be used</param>
-        </member>
-        <member name="M:NUnit.Framework.ValueSourceAttribute.#ctor(System.Type,System.String)">
-            <summary>
-            Construct with a Type and name - for use with languages
-            that don't support params arrays.
-            </summary>
-            <param name="sourceType">The Type that will provide data</param>
-            <param name="sourceName">The name of the method, property or field that will provide data</param>
-        </member>
-        <member name="P:NUnit.Framework.ValueSourceAttribute.SourceName">
-            <summary>
-            The name of a the method, property or fiend to be used as a source
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.ValueSourceAttribute.SourceType">
-            <summary>
-            A Type to be used as a source
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.AttributeExistsConstraint">
-            <summary>
-            AttributeExistsConstraint tests for the presence of a
-            specified attribute on  a Type.
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.Constraint">
-            <summary>
-            The Constraint class is the base of all built-in constraints
-            within NUnit. It provides the operator overloads used to combine 
-            constraints.
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.IResolveConstraint">
-            <summary>
-            The IConstraintExpression interface is implemented by all
-            complete and resolvable constraints and expressions.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.IResolveConstraint.Resolve">
-            <summary>
-            Return the top-level constraint for this expression
-            </summary>
-            <returns></returns>
-        </member>
-        <member name="F:NUnit.Framework.Constraints.Constraint.UNSET">
-            <summary>
-            Static UnsetObject used to detect derived constraints
-            failing to set the actual value.
-            </summary>
-        </member>
-        <member name="F:NUnit.Framework.Constraints.Constraint.actual">
-            <summary>
-            The actual value being tested against a constraint
-            </summary>
-        </member>
-        <member name="F:NUnit.Framework.Constraints.Constraint.displayName">
-            <summary>
-            The display name of this Constraint for use by ToString()
-            </summary>
-        </member>
-        <member name="F:NUnit.Framework.Constraints.Constraint.argcnt">
-            <summary>
-            Argument fields used by ToString();
-            </summary>
-        </member>
-        <member name="F:NUnit.Framework.Constraints.Constraint.builder">
-            <summary>
-            The builder holding this constraint
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.Constraint.#ctor">
-            <summary>
-            Construct a constraint with no arguments
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.Constraint.#ctor(System.Object)">
-            <summary>
-            Construct a constraint with one argument
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.Constraint.#ctor(System.Object,System.Object)">
-            <summary>
-            Construct a constraint with two arguments
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.Constraint.SetBuilder(NUnit.Framework.Constraints.ConstraintBuilder)">
-            <summary>
-            Sets the ConstraintBuilder holding this constraint
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.Constraint.WriteMessageTo(NUnit.Framework.Constraints.MessageWriter)">
-            <summary>
-            Write the failure message to the MessageWriter provided
-            as an argument. The default implementation simply passes
-            the constraint and the actual value to the writer, which
-            then displays the constraint description and the value.
-            
-            Constraints that need to provide additional details,
-            such as where the error occured can override this.
-            </summary>
-            <param name="writer">The MessageWriter on which to display the message</param>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.Constraint.Matches(System.Object)">
-            <summary>
-            Test whether the constraint is satisfied by a given value
-            </summary>
-            <param name="actual">The value to be tested</param>
-            <returns>True for success, false for failure</returns>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.Constraint.Matches(NUnit.Framework.Constraints.ActualValueDelegate)">
-            <summary>
-            Test whether the constraint is satisfied by an
-            ActualValueDelegate that returns the value to be tested.
-            The default implementation simply evaluates the delegate
-            but derived classes may override it to provide for delayed 
-            processing.
-            </summary>
-            <param name="del">An ActualValueDelegate</param>
-            <returns>True for success, false for failure</returns>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.Constraint.Matches(System.Boolean@)">
-            <summary>
-            Test whether the constraint is satisfied by a given bool reference.
-            The default implementation simply dereferences the value but
-            derived classes may override it to provide for delayed processing.
-            </summary>
-            <param name="actual">A reference to the value to be tested</param>
-            <returns>True for success, false for failure</returns>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.Constraint.WriteDescriptionTo(NUnit.Framework.Constraints.MessageWriter)">
-            <summary>
-            Write the constraint description to a MessageWriter
-            </summary>
-            <param name="writer">The writer on which the description is displayed</param>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.Constraint.WriteActualValueTo(NUnit.Framework.Constraints.MessageWriter)">
-            <summary>
-            Write the actual value for a failing constraint test to a
-            MessageWriter. The default implementation simply writes
-            the raw value of actual, leaving it to the writer to
-            perform any formatting.
-            </summary>
-            <param name="writer">The writer on which the actual value is displayed</param>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.Constraint.ToString">
-            <summary>
-            Default override of ToString returns the constraint DisplayName
-            followed by any arguments within angle brackets.
-            </summary>
-            <returns></returns>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.Constraint.GetStringRepresentation">
-            <summary>
-            Returns the string representation of this constraint
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.Constraint.op_BitwiseAnd(NUnit.Framework.Constraints.Constraint,NUnit.Framework.Constraints.Constraint)">
-            <summary>
-            This operator creates a constraint that is satisfied only if both 
-            argument constraints are satisfied.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.Constraint.op_BitwiseOr(NUnit.Framework.Constraints.Constraint,NUnit.Framework.Constraints.Constraint)">
-            <summary>
-            This operator creates a constraint that is satisfied if either 
-            of the argument constraints is satisfied.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.Constraint.op_LogicalNot(NUnit.Framework.Constraints.Constraint)">
-            <summary>
-            This operator creates a constraint that is satisfied if the 
-            argument constraint is not satisfied.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.Constraint.After(System.Int32)">
-            <summary>
-            Returns a DelayedConstraint with the specified delay time.
-            </summary>
-            <param name="delayInMilliseconds">The delay in milliseconds.</param>
-            <returns></returns>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.Constraint.After(System.Int32,System.Int32)">
-            <summary>
-            Returns a DelayedConstraint with the specified delay time
-            and polling interval.
-            </summary>
-            <param name="delayInMilliseconds">The delay in milliseconds.</param>
-            <param name="pollingInterval">The interval at which to test the constraint.</param>
-            <returns></returns>
-        </member>
-        <member name="P:NUnit.Framework.Constraints.Constraint.DisplayName">
-            <summary>
-            The display name of this Constraint for use by ToString().
-            The default value is the name of the constraint with
-            trailing "Constraint" removed. Derived classes may set
-            this to another name in their constructors.
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.Constraints.Constraint.And">
-            <summary>
-            Returns a ConstraintExpression by appending And
-            to the current constraint.
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.Constraints.Constraint.With">
-            <summary>
-            Returns a ConstraintExpression by appending And
-            to the current constraint.
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.Constraints.Constraint.Or">
-            <summary>
-            Returns a ConstraintExpression by appending Or
-            to the current constraint.
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.Constraint.UnsetObject">
-            <summary>
-            Class used to detect any derived constraints
-            that fail to set the actual value in their
-            Matches override.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.AttributeExistsConstraint.#ctor(System.Type)">
-            <summary>
-            Constructs an AttributeExistsConstraint for a specific attribute Type
-            </summary>
-            <param name="type"></param>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.AttributeExistsConstraint.Matches(System.Object)">
-            <summary>
-            Tests whether the object provides the expected attribute.
-            </summary>
-            <param name="actual">A Type, MethodInfo, or other ICustomAttributeProvider</param>
-            <returns>True if the expected attribute is present, otherwise false</returns>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.AttributeExistsConstraint.WriteDescriptionTo(NUnit.Framework.Constraints.MessageWriter)">
-            <summary>
-            Writes the description of the constraint to the specified writer
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.AttributeConstraint">
-            <summary>
-            AttributeConstraint tests that a specified attribute is present
-            on a Type or other provider and that the value of the attribute
-            satisfies some other constraint.
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.PrefixConstraint">
-            <summary>
-            Abstract base class used for prefixes
-            </summary>
-        </member>
-        <member name="F:NUnit.Framework.Constraints.PrefixConstraint.baseConstraint">
-            <summary>
-            The base constraint
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.PrefixConstraint.#ctor(NUnit.Framework.Constraints.IResolveConstraint)">
-            <summary>
-            Construct given a base constraint
-            </summary>
-            <param name="resolvable"></param>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.AttributeConstraint.#ctor(System.Type,NUnit.Framework.Constraints.Constraint)">
-            <summary>
-            Constructs an AttributeConstraint for a specified attriute
-            Type and base constraint.
-            </summary>
-            <param name="type"></param>
-            <param name="baseConstraint"></param>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.AttributeConstraint.Matches(System.Object)">
-            <summary>
-            Determines whether the Type or other provider has the 
-            expected attribute and if its value matches the
-            additional constraint specified.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.AttributeConstraint.WriteDescriptionTo(NUnit.Framework.Constraints.MessageWriter)">
-            <summary>
-            Writes a description of the attribute to the specified writer.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.AttributeConstraint.WriteActualValueTo(NUnit.Framework.Constraints.MessageWriter)">
-            <summary>
-            Writes the actual value supplied to the specified writer.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.AttributeConstraint.GetStringRepresentation">
-            <summary>
-            Returns a string representation of the constraint.
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.BasicConstraint">
-            <summary>
-            BasicConstraint is the abstract base for constraints that
-            perform a simple comparison to a constant value.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.BasicConstraint.#ctor(System.Object,System.String)">
-            <summary>
-            Initializes a new instance of the <see cref="T:BasicConstraint"/> class.
-            </summary>
-            <param name="expected">The expected.</param>
-            <param name="description">The description.</param>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.BasicConstraint.Matches(System.Object)">
-            <summary>
-            Test whether the constraint is satisfied by a given value
-            </summary>
-            <param name="actual">The value to be tested</param>
-            <returns>True for success, false for failure</returns>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.BasicConstraint.WriteDescriptionTo(NUnit.Framework.Constraints.MessageWriter)">
-            <summary>
-            Write the constraint description to a MessageWriter
-            </summary>
-            <param name="writer">The writer on which the description is displayed</param>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.NullConstraint">
-            <summary>
-            NullConstraint tests that the actual value is null
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.NullConstraint.#ctor">
-            <summary>
-            Initializes a new instance of the <see cref="T:NullConstraint"/> class.
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.TrueConstraint">
-            <summary>
-            TrueConstraint tests that the actual value is true
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.TrueConstraint.#ctor">
-            <summary>
-            Initializes a new instance of the <see cref="T:TrueConstraint"/> class.
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.FalseConstraint">
-            <summary>
-            FalseConstraint tests that the actual value is false
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.FalseConstraint.#ctor">
-            <summary>
-            Initializes a new instance of the <see cref="T:FalseConstraint"/> class.
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.NaNConstraint">
-            <summary>
-            NaNConstraint tests that the actual value is a double or float NaN
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.NaNConstraint.Matches(System.Object)">
-            <summary>
-            Test that the actual value is an NaN
-            </summary>
-            <param name="actual"></param>
-            <returns></returns>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.NaNConstraint.WriteDescriptionTo(NUnit.Framework.Constraints.MessageWriter)">
-            <summary>
-            Write the constraint description to a specified writer
-            </summary>
-            <param name="writer"></param>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.BinaryConstraint">
-            <summary>
-            BinaryConstraint is the abstract base of all constraints
-            that combine two other constraints in some fashion.
-            </summary>
-        </member>
-        <member name="F:NUnit.Framework.Constraints.BinaryConstraint.left">
-            <summary>
-            The first constraint being combined
-            </summary>
-        </member>
-        <member name="F:NUnit.Framework.Constraints.BinaryConstraint.right">
-            <summary>
-            The second constraint being combined
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.BinaryConstraint.#ctor(NUnit.Framework.Constraints.Constraint,NUnit.Framework.Constraints.Constraint)">
-            <summary>
-            Construct a BinaryConstraint from two other constraints
-            </summary>
-            <param name="left">The first constraint</param>
-            <param name="right">The second constraint</param>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.AndConstraint">
-            <summary>
-            AndConstraint succeeds only if both members succeed.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.AndConstraint.#ctor(NUnit.Framework.Constraints.Constraint,NUnit.Framework.Constraints.Constraint)">
-            <summary>
-            Create an AndConstraint from two other constraints
-            </summary>
-            <param name="left">The first constraint</param>
-            <param name="right">The second constraint</param>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.AndConstraint.Matches(System.Object)">
-            <summary>
-            Apply both member constraints to an actual value, succeeding 
-            succeeding only if both of them succeed.
-            </summary>
-            <param name="actual">The actual value</param>
-            <returns>True if the constraints both succeeded</returns>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.AndConstraint.WriteDescriptionTo(NUnit.Framework.Constraints.MessageWriter)">
-            <summary>
-            Write a description for this contraint to a MessageWriter
-            </summary>
-            <param name="writer">The MessageWriter to receive the description</param>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.AndConstraint.WriteActualValueTo(NUnit.Framework.Constraints.MessageWriter)">
-            <summary>
-            Write the actual value for a failing constraint test to a
-            MessageWriter. The default implementation simply writes
-            the raw value of actual, leaving it to the writer to
-            perform any formatting.
-            </summary>
-            <param name="writer">The writer on which the actual value is displayed</param>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.OrConstraint">
-            <summary>
-            OrConstraint succeeds if either member succeeds
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.OrConstraint.#ctor(NUnit.Framework.Constraints.Constraint,NUnit.Framework.Constraints.Constraint)">
-            <summary>
-            Create an OrConstraint from two other constraints
-            </summary>
-            <param name="left">The first constraint</param>
-            <param name="right">The second constraint</param>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.OrConstraint.Matches(System.Object)">
-            <summary>
-            Apply the member constraints to an actual value, succeeding 
-            succeeding as soon as one of them succeeds.
-            </summary>
-            <param name="actual">The actual value</param>
-            <returns>True if either constraint succeeded</returns>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.OrConstraint.WriteDescriptionTo(NUnit.Framework.Constraints.MessageWriter)">
-            <summary>
-            Write a description for this contraint to a MessageWriter
-            </summary>
-            <param name="writer">The MessageWriter to receive the description</param>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.CollectionConstraint">
-            <summary>
-            CollectionConstraint is the abstract base class for
-            constraints that operate on collections.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionConstraint.#ctor">
-            <summary>
-            Construct an empty CollectionConstraint
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionConstraint.#ctor(System.Object)">
-            <summary>
-            Construct a CollectionConstraint
-            </summary>
-            <param name="arg"></param>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionConstraint.IsEmpty(System.Collections.IEnumerable)">
-            <summary>
-            Determines whether the specified enumerable is empty.
-            </summary>
-            <param name="enumerable">The enumerable.</param>
-            <returns>
-            	<c>true</c> if the specified enumerable is empty; otherwise, <c>false</c>.
-            </returns>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionConstraint.Matches(System.Object)">
-            <summary>
-            Test whether the constraint is satisfied by a given value
-            </summary>
-            <param name="actual">The value to be tested</param>
-            <returns>True for success, false for failure</returns>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionConstraint.doMatch(System.Collections.IEnumerable)">
-            <summary>
-            Protected method to be implemented by derived classes
-            </summary>
-            <param name="collection"></param>
-            <returns></returns>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.CollectionItemsEqualConstraint">
-            <summary>
-            CollectionItemsEqualConstraint is the abstract base class for all
-            collection constraints that apply some notion of item equality
-            as a part of their operation.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionItemsEqualConstraint.#ctor">
-            <summary>
-            Construct an empty CollectionConstraint
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionItemsEqualConstraint.#ctor(System.Object)">
-            <summary>
-            Construct a CollectionConstraint
-            </summary>
-            <param name="arg"></param>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionItemsEqualConstraint.Using(System.Collections.IComparer)">
-            <summary>
-            Flag the constraint to use the supplied IComparer object.
-            </summary>
-            <param name="comparer">The IComparer object to use.</param>
-            <returns>Self.</returns>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionItemsEqualConstraint.ItemsEqual(System.Object,System.Object)">
-            <summary>
-            Compares two collection members for equality
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionItemsEqualConstraint.Tally(System.Collections.IEnumerable)">
-            <summary>
-            Return a new CollectionTally for use in making tests
-            </summary>
-            <param name="c">The collection to be included in the tally</param>
-        </member>
-        <member name="P:NUnit.Framework.Constraints.CollectionItemsEqualConstraint.IgnoreCase">
-            <summary>
-            Flag the constraint to ignore case and return self.
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.EmptyCollectionConstraint">
-            <summary>
-            EmptyCollectionConstraint tests whether a collection is empty. 
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.EmptyCollectionConstraint.doMatch(System.Collections.IEnumerable)">
-            <summary>
-            Check that the collection is empty
-            </summary>
-            <param name="collection"></param>
-            <returns></returns>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.EmptyCollectionConstraint.WriteDescriptionTo(NUnit.Framework.Constraints.MessageWriter)">
-            <summary>
-            Write the constraint description to a MessageWriter
-            </summary>
-            <param name="writer"></param>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.UniqueItemsConstraint">
-            <summary>
-            UniqueItemsConstraint tests whether all the items in a 
-            collection are unique.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.UniqueItemsConstraint.doMatch(System.Collections.IEnumerable)">
-            <summary>
-            Check that all items are unique.
-            </summary>
-            <param name="actual"></param>
-            <returns></returns>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.UniqueItemsConstraint.WriteDescriptionTo(NUnit.Framework.Constraints.MessageWriter)">
-            <summary>
-            Write a description of this constraint to a MessageWriter
-            </summary>
-            <param name="writer"></param>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.CollectionContainsConstraint">
-            <summary>
-            CollectionContainsConstraint is used to test whether a collection
-            contains an expected object as a member.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionContainsConstraint.#ctor(System.Object)">
-            <summary>
-            Construct a CollectionContainsConstraint
-            </summary>
-            <param name="expected"></param>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionContainsConstraint.doMatch(System.Collections.IEnumerable)">
-            <summary>
-            Test whether the expected item is contained in the collection
-            </summary>
-            <param name="actual"></param>
-            <returns></returns>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionContainsConstraint.WriteDescriptionTo(NUnit.Framework.Constraints.MessageWriter)">
-            <summary>
-            Write a descripton of the constraint to a MessageWriter
-            </summary>
-            <param name="writer"></param>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.CollectionEquivalentConstraint">
-            <summary>
-            CollectionEquivalentCOnstraint is used to determine whether two
-            collections are equivalent.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionEquivalentConstraint.#ctor(System.Collections.IEnumerable)">
-            <summary>
-            Construct a CollectionEquivalentConstraint
-            </summary>
-            <param name="expected"></param>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionEquivalentConstraint.doMatch(System.Collections.IEnumerable)">
-            <summary>
-            Test whether two collections are equivalent
-            </summary>
-            <param name="actual"></param>
-            <returns></returns>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionEquivalentConstraint.WriteDescriptionTo(NUnit.Framework.Constraints.MessageWriter)">
-            <summary>
-            Write a description of this constraint to a MessageWriter
-            </summary>
-            <param name="writer"></param>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.CollectionSubsetConstraint">
-            <summary>
-            CollectionSubsetConstraint is used to determine whether
-            one collection is a subset of another
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionSubsetConstraint.#ctor(System.Collections.IEnumerable)">
-            <summary>
-            Construct a CollectionSubsetConstraint
-            </summary>
-            <param name="expected">The collection that the actual value is expected to be a subset of</param>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionSubsetConstraint.doMatch(System.Collections.IEnumerable)">
-            <summary>
-            Test whether the actual collection is a subset of 
-            the expected collection provided.
-            </summary>
-            <param name="actual"></param>
-            <returns></returns>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionSubsetConstraint.WriteDescriptionTo(NUnit.Framework.Constraints.MessageWriter)">
-            <summary>
-            Write a description of this constraint to a MessageWriter
-            </summary>
-            <param name="writer"></param>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.CollectionOrderedConstraint">
-            <summary>
-            CollectionOrderedConstraint is used to test whether a collection is ordered.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionOrderedConstraint.#ctor">
-            <summary>
-            Construct a CollectionOrderedConstraint
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionOrderedConstraint.Using(System.Collections.IComparer)">
-            <summary>
-            Modifies the constraint to use an IComparer and returns self.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionOrderedConstraint.By(System.String)">
-            <summary>
-            Modifies the constraint to test ordering by the value of
-            a specified property and returns self.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionOrderedConstraint.doMatch(System.Collections.IEnumerable)">
-            <summary>
-            Test whether the collection is ordered
-            </summary>
-            <param name="actual"></param>
-            <returns></returns>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionOrderedConstraint.WriteDescriptionTo(NUnit.Framework.Constraints.MessageWriter)">
-            <summary>
-            Write a description of the constraint to a MessageWriter
-            </summary>
-            <param name="writer"></param>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionOrderedConstraint.GetStringRepresentation">
-            <summary>
-            Returns the string representation of the constraint.
-            </summary>
-            <returns></returns>
-        </member>
-        <member name="P:NUnit.Framework.Constraints.CollectionOrderedConstraint.Descending">
-            <summary>
-             If used performs a reverse comparison
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.CollectionTally">
-            <summary>
-            CollectionTally counts (tallies) the number of
-            occurences of each object in one or more enumerations.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionTally.#ctor(NUnit.Framework.Constraints.NUnitEqualityComparer,System.Collections.IEnumerable)">
-            <summary>
-            Construct a CollectionTally object from a comparer and a collection
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionTally.TryRemove(System.Object)">
-            <summary>
-            Try to remove an object from the tally
-            </summary>
-            <param name="o">The object to remove</param>
-            <returns>True if successful, false if the object was not found</returns>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionTally.TryRemove(System.Collections.IEnumerable)">
-            <summary>
-            Try to remove a set of objects from the tally
-            </summary>
-            <param name="c">The objects to remove</param>
-            <returns>True if successful, false if any object was not found</returns>
-        </member>
-        <member name="P:NUnit.Framework.Constraints.CollectionTally.Count">
-            <summary>
-            The number of objects remaining in the tally
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.ComparisonAdapter">
-            <summary>
-            ComparisonAdapter class centralizes all comparisons of
-            values in NUnit, adapting to the use of any provided
-            IComparer, IComparer&lt;T&gt; or Comparison&lt;T&gt;
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.ComparisonAdapter.For(System.Collections.IComparer)">
-            <summary>
-            Returns a ComparisonAdapter that wraps an IComparer
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.ComparisonAdapter.Compare(System.Object,System.Object)">
-            <summary>
-            Compares two objects
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.Constraints.ComparisonAdapter.Default">
-            <summary>
-            Gets the default ComparisonAdapter, which wraps an
-            NUnitComparer object.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.ComparisonAdapter.ComparerAdapter.#ctor(System.Collections.IComparer)">
-            <summary>
-            Construct a ComparisonAdapter for an IComparer
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.ComparisonAdapter.ComparerAdapter.Compare(System.Object,System.Object)">
-            <summary>
-            Compares two objects
-            </summary>
-            <param name="expected"></param>
-            <param name="actual"></param>
-            <returns></returns>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.ComparisonAdapter.DefaultComparisonAdapter.#ctor">
-            <summary>
-            Construct a default ComparisonAdapter
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.ComparisonConstraint">
-            <summary>
-            Abstract base class for constraints that compare values to
-            determine if one is greater than, equal to or less than
-            the other.
-            </summary>
-        </member>
-        <member name="F:NUnit.Framework.Constraints.ComparisonConstraint.expected">
-            <summary>
-            The value against which a comparison is to be made
-            </summary>
-        </member>
-        <member name="F:NUnit.Framework.Constraints.ComparisonConstraint.ltOK">
-            <summary>
-            If true, less than returns success
-            </summary>
-        </member>
-        <member name="F:NUnit.Framework.Constraints.ComparisonConstraint.eqOK">
-            <summary>
-            if true, equal returns success
-            </summary>
-        </member>
-        <member name="F:NUnit.Framework.Constraints.ComparisonConstraint.gtOK">
-            <summary>
-            if true, greater than returns success
-            </summary>
-        </member>
-        <member name="F:NUnit.Framework.Constraints.ComparisonConstraint.predicate">
-            <summary>
-            The predicate used as a part of the description
-            </summary>
-        </member>
-        <member name="F:NUnit.Framework.Constraints.ComparisonConstraint.comparer">
-            <summary>
-            ComparisonAdapter to be used in making the comparison
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.ComparisonConstraint.#ctor(System.Object,System.Boolean,System.Boolean,System.Boolean,System.String)">
-            <summary>
-            Initializes a new instance of the <see cref="T:ComparisonConstraint"/> class.
-            </summary>
-            <param name="value">The value against which to make a comparison.</param>
-            <param name="ltOK">if set to <c>true</c> less succeeds.</param>
-            <param name="eqOK">if set to <c>true</c> equal succeeds.</param>
-            <param name="gtOK">if set to <c>true</c> greater succeeds.</param>
-            <param name="predicate">String used in describing the constraint.</param>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.ComparisonConstraint.Matches(System.Object)">
-            <summary>
-            Test whether the constraint is satisfied by a given value
-            </summary>
-            <param name="actual">The value to be tested</param>
-            <returns>True for success, false for failure</returns>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.ComparisonConstraint.WriteDescriptionTo(NUnit.Framework.Constraints.MessageWriter)">
-            <summary>
-            Write the constraint description to a MessageWriter
-            </summary>
-            <param name="writer">The writer on which the description is displayed</param>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.ComparisonConstraint.Using(System.Collections.IComparer)">
-            <summary>
-            Modifies the constraint to use an IComparer and returns self
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.GreaterThanConstraint">
-            <summary>
-            Tests whether a value is greater than the value supplied to its constructor
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.GreaterThanConstraint.#ctor(System.Object)">
-            <summary>
-            Initializes a new instance of the <see cref="T:GreaterThanConstraint"/> class.
-            </summary>
-            <param name="expected">The expected value.</param>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.GreaterThanOrEqualConstraint">
-            <summary>
-            Tests whether a value is greater than or equal to the value supplied to its constructor
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.GreaterThanOrEqualConstraint.#ctor(System.Object)">
-            <summary>
-            Initializes a new instance of the <see cref="T:GreaterThanOrEqualConstraint"/> class.
-            </summary>
-            <param name="expected">The expected value.</param>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.LessThanConstraint">
-            <summary>
-            Tests whether a value is less than the value supplied to its constructor
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.LessThanConstraint.#ctor(System.Object)">
-            <summary>
-            Initializes a new instance of the <see cref="T:LessThanConstraint"/> class.
-            </summary>
-            <param name="expected">The expected value.</param>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.LessThanOrEqualConstraint">
-            <summary>
-            Tests whether a value is less than or equal to the value supplied to its constructor
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.LessThanOrEqualConstraint.#ctor(System.Object)">
-            <summary>
-            Initializes a new instance of the <see cref="T:LessThanOrEqualConstraint"/> class.
-            </summary>
-            <param name="expected">The expected value.</param>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.ActualValueDelegate">
-            <summary>
-            Delegate used to delay evaluation of the actual value
-            to be used in evaluating a constraint
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.ConstraintBuilder">
-            <summary>
-            ConstraintBuilder maintains the stacks that are used in
-            processing a ConstraintExpression. An OperatorStack
-            is used to hold operators that are waiting for their
-            operands to be reognized. a ConstraintStack holds 
-            input constraints as well as the results of each
-            operator applied.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.ConstraintBuilder.#ctor">
-            <summary>
-            Initializes a new instance of the <see cref="T:ConstraintBuilder"/> class.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.ConstraintBuilder.Append(NUnit.Framework.Constraints.ConstraintOperator)">
-            <summary>
-            Appends the specified operator to the expression by first
-            reducing the operator stack and then pushing the new
-            operator on the stack.
-            </summary>
-            <param name="op">The operator to push.</param>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.ConstraintBuilder.Append(NUnit.Framework.Constraints.Constraint)">
-            <summary>
-            Appends the specified constraint to the expresson by pushing
-            it on the constraint stack.
-            </summary>
-            <param name="constraint">The constraint to push.</param>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.ConstraintBuilder.SetTopOperatorRightContext(System.Object)">
-            <summary>
-            Sets the top operator right context.
-            </summary>
-            <param name="rightContext">The right context.</param>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.ConstraintBuilder.ReduceOperatorStack(System.Int32)">
-            <summary>
-            Reduces the operator stack until the topmost item
-            precedence is greater than or equal to the target precedence.
-            </summary>
-            <param name="targetPrecedence">The target precedence.</param>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.ConstraintBuilder.Resolve">
-            <summary>
-            Resolves this instance, returning a Constraint. If the builder
-            is not currently in a resolvable state, an exception is thrown.
-            </summary>
-            <returns>The resolved constraint</returns>
-        </member>
-        <member name="P:NUnit.Framework.Constraints.ConstraintBuilder.IsResolvable">
-            <summary>
-            Gets a value indicating whether this instance is resolvable.
-            </summary>
-            <value>
-            	<c>true</c> if this instance is resolvable; otherwise, <c>false</c>.
-            </value>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.ConstraintBuilder.OperatorStack">
-            <summary>
-            OperatorStack is a type-safe stack for holding ConstraintOperators
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.ConstraintBuilder.OperatorStack.#ctor(NUnit.Framework.Constraints.ConstraintBuilder)">
-            <summary>
-            Initializes a new instance of the <see cref="T:OperatorStack"/> class.
-            </summary>
-            <param name="builder">The builder.</param>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.ConstraintBuilder.OperatorStack.Push(NUnit.Framework.Constraints.ConstraintOperator)">
-            <summary>
-            Pushes the specified operator onto the stack.
-            </summary>
-            <param name="op">The op.</param>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.ConstraintBuilder.OperatorStack.Pop">
-            <summary>
-            Pops the topmost operator from the stack.
-            </summary>
-            <returns></returns>
-        </member>
-        <member name="P:NUnit.Framework.Constraints.ConstraintBuilder.OperatorStack.Empty">
-            <summary>
-            Gets a value indicating whether this <see cref="T:OpStack"/> is empty.
-            </summary>
-            <value><c>true</c> if empty; otherwise, <c>false</c>.</value>
-        </member>
-        <member name="P:NUnit.Framework.Constraints.ConstraintBuilder.OperatorStack.Top">
-            <summary>
-            Gets the topmost operator without modifying the stack.
-            </summary>
-            <value>The top.</value>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.ConstraintBuilder.ConstraintStack">
-            <summary>
-            ConstraintStack is a type-safe stack for holding Constraints
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.ConstraintBuilder.ConstraintStack.#ctor(NUnit.Framework.Constraints.ConstraintBuilder)">
-            <summary>
-            Initializes a new instance of the <see cref="T:ConstraintStack"/> class.
-            </summary>
-            <param name="builder">The builder.</param>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.ConstraintBuilder.ConstraintStack.Push(NUnit.Framework.Constraints.Constraint)">
-            <summary>
-            Pushes the specified constraint. As a side effect,
-            the constraint's builder field is set to the 
-            ConstraintBuilder owning this stack.
-            </summary>
-            <param name="constraint">The constraint.</param>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.ConstraintBuilder.ConstraintStack.Pop">
-            <summary>
-            Pops this topmost constrait from the stack.
-            As a side effect, the constraint's builder
-            field is set to null.
-            </summary>
-            <returns>

<TRUNCATED>
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/framework/nunit.mocks.dll
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/framework/nunit.mocks.dll b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/framework/nunit.mocks.dll
deleted file mode 100644
index 2250c0c..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/framework/nunit.mocks.dll and /dev/null differ


[03/51] [abbrv] [partial] Cleaning up and getting ready to development towards v4.8

Posted by sy...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/src/Lucene.Net.Codecs/Pulsing/PulsingPostingsFormat.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Codecs/Pulsing/PulsingPostingsFormat.cs b/src/Lucene.Net.Codecs/Pulsing/PulsingPostingsFormat.cs
new file mode 100644
index 0000000..552ecbc
--- /dev/null
+++ b/src/Lucene.Net.Codecs/Pulsing/PulsingPostingsFormat.cs
@@ -0,0 +1,127 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+
+
+namespace Lucene.Net.Codecs.Pulsing
+{
+    using System;
+    using System.Diagnostics;
+    using Lucene.Net.Index;
+    using Lucene.Net.Util;
+
+    /// <summary>
+    /// This postings format "inlines" the postings for terms that have
+    /// low docFreq.  It wraps another postings format, which is used for
+    /// writing the non-inlined terms.
+    /// @lucene.experimental 
+    /// </summary>
+    public abstract class PulsingPostingsFormat : PostingsFormat
+    {
+
+        private readonly int _freqCutoff;
+        private readonly int _minBlockSize;
+        private readonly int _maxBlockSize;
+        private readonly PostingsBaseFormat _wrappedPostingsBaseFormat;
+
+        public int FreqCutoff
+        {
+            get { return _freqCutoff; }
+        }
+
+        protected PulsingPostingsFormat(String name, PostingsBaseFormat wrappedPostingsBaseFormat, int freqCutoff) :
+            this(name, wrappedPostingsBaseFormat, freqCutoff, BlockTreeTermsWriter.DEFAULT_MIN_BLOCK_SIZE,
+            BlockTreeTermsWriter.DEFAULT_MAX_BLOCK_SIZE)
+        {
+        }
+
+        /// <summary>Terms with freq <= freqCutoff are inlined into terms dict.</summary>
+        protected PulsingPostingsFormat(String name, PostingsBaseFormat wrappedPostingsBaseFormat, int freqCutoff,
+            int minBlockSize, int maxBlockSize) : base(name)
+        {
+            Debug.Debug.Assert((minBlockSize > 1);
+
+            _freqCutoff = freqCutoff;
+            _minBlockSize = minBlockSize;
+            _maxBlockSize = maxBlockSize;
+            _wrappedPostingsBaseFormat = wrappedPostingsBaseFormat;
+        }
+
+        public override String ToString()
+        {
+            return string.Format("{0} (freqCutoff={1}, minBlockSize={2}, maxBlockSize={3})", Name, _freqCutoff, _minBlockSize, _maxBlockSize);
+        }
+
+        public override FieldsConsumer FieldsConsumer(SegmentWriteState state)
+        {
+            PostingsWriterBase docsWriter = null;
+
+            // Terms that have <= freqCutoff number of docs are
+            // "pulsed" (inlined):
+            PostingsWriterBase pulsingWriter = null;
+
+            // Terms dict
+            bool success = false;
+            try
+            {
+                docsWriter = _wrappedPostingsBaseFormat.PostingsWriterBase(state);
+
+                // Terms that have <= freqCutoff number of docs are
+                // "pulsed" (inlined):
+                pulsingWriter = new PulsingPostingsWriter(state, _freqCutoff, docsWriter);
+                FieldsConsumer ret = new BlockTreeTermsWriter(state, pulsingWriter, _minBlockSize, _maxBlockSize);
+                success = true;
+                return ret;
+            }
+            finally
+            {
+                if (!success)
+                {
+                    IOUtils.CloseWhileHandlingException(docsWriter, pulsingWriter);
+                }
+            }
+        }
+
+        public override FieldsProducer FieldsProducer(SegmentReadState state)
+        {
+            PostingsReaderBase docsReader = null;
+            PostingsReaderBase pulsingReader = null;
+
+            bool success = false;
+            try
+            {
+                docsReader = _wrappedPostingsBaseFormat.PostingsReaderBase(state);
+                pulsingReader = new PulsingPostingsReader(state, docsReader);
+                FieldsProducer ret = new BlockTreeTermsReader(
+                    state.Directory, state.FieldInfos, state.SegmentInfo,
+                    pulsingReader,
+                    state.Context,
+                    state.SegmentSuffix,
+                    state.TermsIndexDivisor);
+                success = true;
+                return ret;
+            }
+            finally
+            {
+                if (!success)
+                {
+                    IOUtils.CloseWhileHandlingException(docsReader, pulsingReader);
+                }
+            }
+        }
+    }
+}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/src/Lucene.Net.Codecs/Pulsing/PulsingPostingsReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Codecs/Pulsing/PulsingPostingsReader.cs b/src/Lucene.Net.Codecs/Pulsing/PulsingPostingsReader.cs
new file mode 100644
index 0000000..9f4599b
--- /dev/null
+++ b/src/Lucene.Net.Codecs/Pulsing/PulsingPostingsReader.cs
@@ -0,0 +1,780 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+namespace Lucene.Net.Codecs.Pulsing
+{
+
+    using System;
+    using System.Collections.Generic;
+    using System.Diagnostics;
+    using Lucene.Net.Index;
+    using Lucene.Net.Store;
+    using Lucene.Net.Util;
+
+    /// <summary>
+    /// Concrete class that reads the current doc/freq/skip postings format 
+    /// 
+    /// @lucene.experimental
+    /// 
+    /// TODO: -- should we switch "hasProx" higher up?  and
+    /// create two separate docs readers, one that also reads
+    /// prox and one that doesn't?
+    /// </summary>
+    public class PulsingPostingsReader : PostingsReaderBase
+    {
+
+        // Fallback reader for non-pulsed terms:
+        private readonly PostingsReaderBase _wrappedPostingsReader;
+        private readonly SegmentReadState segmentState;
+        private int maxPositions;
+        private int version;
+        private SortedDictionary<int, int> fields;
+
+        public PulsingPostingsReader(SegmentReadState state, PostingsReaderBase wrappedPostingsReader)
+        {
+            this._wrappedPostingsReader = wrappedPostingsReader;
+            this.segmentState = state;
+        }
+
+        public override void Init(IndexInput termsIn)
+        {
+            version = CodecUtil.CheckHeader(termsIn, PulsingPostingsWriter.CODEC,
+                PulsingPostingsWriter.VERSION_START,
+                PulsingPostingsWriter.VERSION_CURRENT);
+
+            maxPositions = termsIn.ReadVInt();
+            _wrappedPostingsReader.Init(termsIn);
+
+            if (_wrappedPostingsReader is PulsingPostingsReader || version < PulsingPostingsWriter.VERSION_META_ARRAY)
+            {
+                fields = null;
+            }
+            else
+            {
+                fields = new SortedDictionary<int, int>();
+                String summaryFileName = IndexFileNames.SegmentFileName(segmentState.SegmentInfo.Name,
+                    segmentState.SegmentSuffix, PulsingPostingsWriter.SUMMARY_EXTENSION);
+                IndexInput input = null;
+
+                try
+                {
+                    input =
+                        segmentState.Directory.OpenInput(summaryFileName, segmentState.Context);
+                    CodecUtil.CheckHeader(input,
+                        PulsingPostingsWriter.CODEC,
+                        version,
+                        PulsingPostingsWriter.VERSION_CURRENT);
+
+                    int numField = input.ReadVInt();
+                    for (int i = 0; i < numField; i++)
+                    {
+                        int fieldNum = input.ReadVInt();
+                        int longsSize = input.ReadVInt();
+                        fields.Add(fieldNum, longsSize);
+                    }
+                }
+                finally
+                {
+                    IOUtils.CloseWhileHandlingException(input);
+                }
+            }
+        }
+
+        public override BlockTermState NewTermState()
+        {
+            var state = new PulsingTermState {WrappedTermState = _wrappedPostingsReader.NewTermState()};
+            return state;
+        }
+
+        public override void DecodeTerm(long[] empty, DataInput input, FieldInfo fieldInfo, BlockTermState _termState,
+            bool absolute)
+        {
+            PulsingTermState termState = (PulsingTermState) _termState;
+
+            Debug.Debug.Assert((empty.Length == 0);
+            termState.Absolute = termState.Absolute || absolute;
+            // if we have positions, its total TF, otherwise its computed based on docFreq.
+            // TODO Double check this is right..
+            long count = FieldInfo.IndexOptions_e.DOCS_AND_FREQS_AND_POSITIONS.CompareTo(fieldInfo.IndexOptions) <= 0
+                ? termState.TotalTermFreq
+                : termState.DocFreq;
+            //System.out.println("  count=" + count + " threshold=" + maxPositions);
+
+            if (count <= maxPositions)
+            {
+                // Inlined into terms dict -- just read the byte[] blob in,
+                // but don't decode it now (we only decode when a DocsEnum
+                // or D&PEnum is pulled):
+                termState.PostingsSize = input.ReadVInt();
+                if (termState.Postings == null || termState.Postings.Length < termState.PostingsSize)
+                {
+                    termState.Postings = new byte[ArrayUtil.Oversize(termState.PostingsSize, 1)];
+                }
+                // TODO: sort of silly to copy from one big byte[]
+                // (the blob holding all inlined terms' blobs for
+                // current term block) into another byte[] (just the
+                // blob for this term)...
+                input.ReadBytes(termState.Postings, 0, termState.PostingsSize);
+                //System.out.println("  inlined bytes=" + termState.postingsSize);
+                termState.Absolute = termState.Absolute || absolute;
+            }
+            else
+            {
+                int longsSize = fields == null ? 0 : fields[fieldInfo.Number];
+                if (termState.Longs == null)
+                {
+                    termState.Longs = new long[longsSize];
+                }
+                for (int i = 0; i < longsSize; i++)
+                {
+                    termState.Longs[i] = input.ReadVLong();
+                }
+                termState.PostingsSize = -1;
+                termState.WrappedTermState.DocFreq = termState.DocFreq;
+                termState.WrappedTermState.TotalTermFreq = termState.TotalTermFreq;
+                _wrappedPostingsReader.DecodeTerm(termState.Longs, input, fieldInfo,
+                    termState.WrappedTermState,
+                    termState.Absolute);
+                termState.Absolute = false;
+            }
+        }
+
+        public override DocsEnum Docs(FieldInfo field, BlockTermState _termState, Bits liveDocs, DocsEnum reuse,
+            int flags)
+        {
+            PulsingTermState termState = (PulsingTermState) _termState;
+            if (termState.PostingsSize != -1)
+            {
+                PulsingDocsEnum postings;
+                if (reuse is PulsingDocsEnum)
+                {
+                    postings = (PulsingDocsEnum) reuse;
+                    if (!postings.CanReuse(field))
+                    {
+                        postings = new PulsingDocsEnum(field);
+                    }
+                }
+                else
+                {
+                    // the 'reuse' is actually the wrapped enum
+                    PulsingDocsEnum previous = (PulsingDocsEnum) GetOther(reuse);
+                    if (previous != null && previous.CanReuse(field))
+                    {
+                        postings = previous;
+                    }
+                    else
+                    {
+                        postings = new PulsingDocsEnum(field);
+                    }
+                }
+                if (reuse != postings)
+                {
+                    SetOther(postings, reuse); // postings.other = reuse
+                }
+                return postings.Reset(liveDocs, termState);
+            }
+            else
+            {
+                if (reuse is PulsingDocsEnum)
+                {
+                    DocsEnum wrapped = _wrappedPostingsReader.Docs(field, termState.WrappedTermState, liveDocs,
+                        GetOther(reuse), flags);
+                    SetOther(wrapped, reuse); // wrapped.other = reuse
+                    return wrapped;
+                }
+                else
+                {
+                    return _wrappedPostingsReader.Docs(field, termState.WrappedTermState, liveDocs, reuse, flags);
+                }
+            }
+        }
+
+        public override DocsAndPositionsEnum DocsAndPositions(FieldInfo field, BlockTermState _termState, Bits liveDocs,
+            DocsAndPositionsEnum reuse,
+            int flags)
+        {
+
+            PulsingTermState termState = (PulsingTermState) _termState;
+
+            if (termState.PostingsSize != -1)
+            {
+                PulsingDocsAndPositionsEnum postings;
+                if (reuse is PulsingDocsAndPositionsEnum)
+                {
+                    postings = (PulsingDocsAndPositionsEnum) reuse;
+                    if (!postings.CanReuse(field))
+                    {
+                        postings = new PulsingDocsAndPositionsEnum(field);
+                    }
+                }
+                else
+                {
+                    // the 'reuse' is actually the wrapped enum
+                    PulsingDocsAndPositionsEnum previous = (PulsingDocsAndPositionsEnum) GetOther(reuse);
+                    if (previous != null && previous.CanReuse(field))
+                    {
+                        postings = previous;
+                    }
+                    else
+                    {
+                        postings = new PulsingDocsAndPositionsEnum(field);
+                    }
+                }
+                if (reuse != postings)
+                {
+                    SetOther(postings, reuse); // postings.other = reuse 
+                }
+                return postings.reset(liveDocs, termState);
+            }
+            else
+            {
+                if (reuse is PulsingDocsAndPositionsEnum)
+                {
+                    DocsAndPositionsEnum wrapped = _wrappedPostingsReader.DocsAndPositions(field,
+                        termState.WrappedTermState,
+                        liveDocs, (DocsAndPositionsEnum) GetOther(reuse),
+                        flags);
+                    SetOther(wrapped, reuse); // wrapped.other = reuse
+                    return wrapped;
+                }
+                else
+                {
+                    return _wrappedPostingsReader.DocsAndPositions(field, termState.WrappedTermState, liveDocs, reuse,
+                        flags);
+                }
+            }
+        }
+
+        public override long RamBytesUsed()
+        {
+            return ((_wrappedPostingsReader != null) ? _wrappedPostingsReader.RamBytesUsed() : 0);
+        }
+
+        public override void CheckIntegrity()
+        {
+            _wrappedPostingsReader.CheckIntegrity();
+        }
+
+        protected override void Dispose(bool disposing)
+        {
+            if (!disposing)
+                _wrappedPostingsReader.Dispose();
+        }
+        
+        /// <summary>
+        /// for a docsenum, gets the 'other' reused enum.
+        /// Example: Pulsing(Standard).
+        /// when doing a term range query you are switching back and forth
+        /// between Pulsing and Standard
+        ///  
+        /// The way the reuse works is that Pulsing.other = Standard and
+        /// Standard.other = Pulsing.
+        /// </summary>
+        private DocsEnum GetOther(DocsEnum de)
+        {
+            if (de == null)
+            {
+                return null;
+            }
+            else
+            {
+                AttributeSource atts = de.Attributes();
+                return atts.AddAttribute(PulsingEnumAttribute.Enums().get(this);
+            }
+        }
+
+        /// <summary>
+        /// for a docsenum, sets the 'other' reused enum.
+        /// see GetOther for an example.
+        /// </summary>
+        private DocsEnum SetOther(DocsEnum de, DocsEnum other)
+        {
+            AttributeSource atts = de.Attributes();
+            return atts.AddAttribute(PulsingEnumAttributeImpl.Enums().put(this, other));
+        }
+
+        ///<summary>
+        /// A per-docsenum attribute that stores additional reuse information
+        /// so that pulsing enums can keep a reference to their wrapped enums,
+        /// and vice versa. this way we can always reuse.
+        /// 
+        /// @lucene.internal 
+        /// </summary>
+        public interface IPulsingEnumAttribute : IAttribute
+        {
+            Dictionary<PulsingPostingsReader, DocsEnum> Enums();
+        }
+
+        internal class PulsingTermState : BlockTermState
+        {
+            public bool Absolute { get; set; }
+            public long[] Longs { get; set; }
+            public byte[] Postings { get; set; }
+            public int PostingsSize { get; set; } // -1 if this term was not inlined
+            public BlockTermState WrappedTermState { get; set; }
+
+            public override object Clone()
+            {
+                PulsingTermState clone = (PulsingTermState) base.Clone();
+                if (PostingsSize != -1)
+                {
+                    clone.Postings = new byte[PostingsSize];
+                    Array.Copy(Postings, 0, clone.Postings, 0, PostingsSize);
+                }
+                else
+                {
+                    Debug.Debug.Assert((WrappedTermState != null);
+                    clone.WrappedTermState = (BlockTermState) WrappedTermState.Clone();
+                    clone.Absolute = Absolute;
+                    if (Longs != null)
+                    {
+                        clone.Longs = new long[Longs.Length];
+                        Array.Copy(Longs, 0, clone.Longs, 0, Longs.Length);
+                    }
+                }
+                return clone;
+            }
+
+            public override void CopyFrom(TermState other)
+            {
+                base.CopyFrom(other);
+                var _other = (PulsingTermState) other;
+                PostingsSize = _other.PostingsSize;
+                if (_other.PostingsSize != -1)
+                {
+                    if (Postings == null || Postings.Length < _other.PostingsSize)
+                    {
+                        Postings = new byte[ArrayUtil.Oversize(_other.PostingsSize, 1)];
+                    }
+                    System.Array.Copy(_other.Postings, 0, Postings, 0, _other.PostingsSize);
+                }
+                else
+                {
+                    WrappedTermState.CopyFrom(_other.WrappedTermState);
+                }
+            }
+
+            public override String ToString()
+            {
+                if (PostingsSize == -1)
+                {
+                    return "PulsingTermState: not inlined: wrapped=" + WrappedTermState;
+                }
+                else
+                {
+                    return "PulsingTermState: inlined size=" + PostingsSize + " " + base.ToString();
+                }
+            }
+        }
+
+        internal class PulsingDocsEnum : DocsEnum
+        {
+            private byte[] postingsBytes;
+            private readonly ByteArrayDataInput postings = new ByteArrayDataInput();
+            private readonly FieldInfo.IndexOptions_e? indexOptions;
+            private readonly bool storePayloads;
+            private readonly bool storeOffsets;
+            private Bits liveDocs;
+
+            private int docID = -1;
+            private int accum;
+            private int freq;
+            private int payloadLength;
+            private int cost;
+
+            public PulsingDocsEnum(FieldInfo fieldInfo)
+            {
+                indexOptions = fieldInfo.IndexOptions;
+                storePayloads = fieldInfo.HasPayloads();
+                storeOffsets = indexOptions.Value.CompareTo(FieldInfo.IndexOptions_e.DOCS_AND_FREQS_AND_POSITIONS_AND_OFFSETS) >= 0;
+            }
+
+            public PulsingDocsEnum Reset(Bits liveDocs, PulsingTermState termState)
+            {
+                Debug.Debug.Assert((termState.PostingsSize != -1);
+
+                // Must make a copy of termState's byte[] so that if
+                // app does TermsEnum.next(), this DocsEnum is not affected
+                if (postingsBytes == null)
+                {
+                    postingsBytes = new byte[termState.PostingsSize];
+                }
+                else if (postingsBytes.Length < termState.PostingsSize)
+                {
+                    postingsBytes = ArrayUtil.Grow(postingsBytes, termState.PostingsSize);
+                }
+                System.Array.Copy(termState.Postings, 0, postingsBytes, 0, termState.PostingsSize);
+                postings.Reset(postingsBytes, 0, termState.PostingsSize);
+                docID = -1;
+                accum = 0;
+                freq = 1;
+                cost = termState.DocFreq;
+                payloadLength = 0;
+                this.liveDocs = liveDocs;
+                return this;
+            }
+
+            public bool CanReuse(FieldInfo fieldInfo)
+            {
+                return indexOptions == fieldInfo.IndexOptions && storePayloads == fieldInfo.HasPayloads();
+            }
+
+            public override int DocID()
+            {
+                return docID;
+            }
+
+            public override int NextDoc()
+            {
+                //System.out.println("PR nextDoc this= "+ this);
+                while (true)
+                {
+                    if (postings.Eof())
+                    {
+                        return docID = NO_MORE_DOCS;
+                    }
+
+                    int code = postings.ReadVInt();
+                    if (indexOptions == FieldInfo.IndexOptions_e.DOCS_ONLY)
+                    {
+                        accum += code;
+                    }
+                    else
+                    {
+                        accum += (int)((uint)code >> 1); ; // shift off low bit
+                        if ((code & 1) != 0)
+                        {
+                            // if low bit is set
+                            freq = 1; // freq is one
+                        }
+                        else
+                        {
+                            freq = postings.ReadVInt(); // else read freq
+                        }
+
+                        if (indexOptions.Value.CompareTo(FieldInfo.IndexOptions_e.DOCS_AND_FREQS_AND_POSITIONS) >= 0)
+                        {
+                            // Skip positions
+                            if (storePayloads)
+                            {
+                                for (int pos = 0; pos < freq; pos++)
+                                {
+                                    int posCode = postings.ReadVInt();
+                                    if ((posCode & 1) != 0)
+                                    {
+                                        payloadLength = postings.ReadVInt();
+                                    }
+                                    if (storeOffsets && (postings.ReadVInt() & 1) != 0)
+                                    {
+                                        // new offset length
+                                        postings.ReadVInt();
+                                    }
+                                    if (payloadLength != 0)
+                                    {
+                                        postings.SkipBytes(payloadLength);
+                                    }
+                                }
+                            }
+                            else
+                            {
+                                for (int pos = 0; pos < freq; pos++)
+                                {
+                                    // TODO: skipVInt
+                                    postings.ReadVInt();
+                                    if (storeOffsets && (postings.ReadVInt() & 1) != 0)
+                                    {
+                                        // new offset length
+                                        postings.ReadVInt();
+                                    }
+                                }
+                            }
+                        }
+                    }
+
+                    if (liveDocs == null || liveDocs.Get(accum))
+                    {
+                        return (docID = accum);
+                    }
+
+                }
+            }
+
+            public override int Advance(int target)
+            {
+                return docID = SlowAdvance(target);
+            }
+
+            public override long Cost()
+            {
+                return cost;
+            }
+
+            public override int Freq()
+            {
+                return freq;
+            }
+        }
+
+        internal class PulsingDocsAndPositionsEnum : DocsAndPositionsEnum
+        {
+            private byte[] postingsBytes;
+            private readonly ByteArrayDataInput postings = new ByteArrayDataInput();
+            private readonly bool storePayloads;
+            private readonly bool storeOffsets;
+            // note: we could actually reuse across different options, if we passed this to reset()
+            // and re-init'ed storeOffsets accordingly (made it non-final)
+            private readonly FieldInfo.IndexOptions_e? indexOptions;
+
+            private Bits liveDocs;
+            private int docID = -1;
+            private int accum;
+            private int freq;
+            private int posPending;
+            private int position;
+            private int payloadLength;
+            private BytesRef payload;
+            private int startOffset;
+            private int offsetLength;
+
+            private bool payloadRetrieved;
+            private int cost;
+
+            public PulsingDocsAndPositionsEnum(FieldInfo fieldInfo)
+            {
+                indexOptions = fieldInfo.IndexOptions;
+                storePayloads = fieldInfo.HasPayloads();
+                storeOffsets =
+                    indexOptions.Value.CompareTo(FieldInfo.IndexOptions_e.DOCS_AND_FREQS_AND_POSITIONS_AND_OFFSETS) >= 0;
+            }
+
+            public PulsingDocsAndPositionsEnum reset(Bits liveDocs, PulsingTermState termState)
+            {
+                Debug.Debug.Assert((termState.PostingsSize != -1);
+
+                if (postingsBytes == null)
+                {
+                    postingsBytes = new byte[termState.PostingsSize];
+                }
+                else if (postingsBytes.Length < termState.PostingsSize)
+                {
+                    postingsBytes = ArrayUtil.Grow(postingsBytes, termState.PostingsSize);
+                }
+
+                System.Array.Copy(termState.Postings, 0, postingsBytes, 0, termState.PostingsSize);
+                postings.Reset(postingsBytes, 0, termState.PostingsSize);
+                this.liveDocs = liveDocs;
+                payloadLength = 0;
+                posPending = 0;
+                docID = -1;
+                accum = 0;
+                cost = termState.DocFreq;
+                startOffset = storeOffsets ? 0 : -1; // always return -1 if no offsets are stored
+                offsetLength = 0;
+                //System.out.println("PR d&p reset storesPayloads=" + storePayloads + " bytes=" + bytes.length + " this=" + this);
+                return this;
+            }
+
+            public bool CanReuse(FieldInfo fieldInfo)
+            {
+                return indexOptions == fieldInfo.IndexOptions && storePayloads == fieldInfo.HasPayloads();
+            }
+
+            public override int NextDoc()
+            {
+
+                while (true)
+                {
+
+                    SkipPositions();
+
+                    if (postings.Eof())
+                    {
+                        return docID = NO_MORE_DOCS;
+                    }
+
+                    int code = postings.ReadVInt();
+                    accum += (int)((uint)code >> 1); // shift off low bit 
+                    if ((code & 1) != 0)
+                    {
+                        // if low bit is set
+                        freq = 1; // freq is one
+                    }
+                    else
+                    {
+                        freq = postings.ReadVInt(); // else read freq
+                    }
+                    posPending = freq;
+                    startOffset = storeOffsets ? 0 : -1; // always return -1 if no offsets are stored
+
+                    if (liveDocs == null || liveDocs.Get(accum))
+                    {
+                        position = 0;
+                        return (docID = accum);
+                    }
+                }
+            }
+
+            public override int Freq()
+            {
+                return freq;
+            }
+
+            public override int DocID()
+            {
+                return docID;
+            }
+
+            public override int Advance(int target)
+            {
+                return docID = SlowAdvance(target);
+            }
+
+            public override int NextPosition()
+            {
+                Debug.Debug.Assert((posPending > 0);
+
+                posPending--;
+
+                if (storePayloads)
+                {
+                    if (!payloadRetrieved)
+                    {
+                        postings.SkipBytes(payloadLength);
+                    }
+                    int code = postings.ReadVInt();
+                    if ((code & 1) != 0)
+                    {
+                        payloadLength = postings.ReadVInt();
+                    }
+                    position += (int)((uint)code >> 1);
+                    payloadRetrieved = false;
+                }
+                else
+                {
+                    position += postings.ReadVInt();
+                }
+
+                if (storeOffsets)
+                {
+                    int offsetCode = postings.ReadVInt();
+                    if ((offsetCode & 1) != 0)
+                    {
+                        // new offset length
+                        offsetLength = postings.ReadVInt();
+                    }
+                    startOffset += (int)((uint)offsetCode >> 1);
+                }
+
+                return position;
+            }
+
+            public override int StartOffset()
+            {
+                return startOffset;
+            }
+
+            public override int EndOffset()
+            {
+                return startOffset + offsetLength;
+            }
+
+            public override BytesRef Payload
+            {
+                get
+                {
+                    if (payloadRetrieved)
+                    {
+                        return payload;
+                    }
+                    else if (storePayloads && payloadLength > 0)
+                    {
+                        payloadRetrieved = true;
+                        if (payload == null)
+                        {
+                            payload = new BytesRef(payloadLength);
+                        }
+                        else
+                        {
+                            payload.Grow(payloadLength);
+                        }
+                        postings.ReadBytes(payload.Bytes, 0, payloadLength);
+                        payload.Length = payloadLength;
+                        return payload;
+                    }
+                    else
+                    {
+                        return null;
+                    }
+                }
+            }
+
+            private void SkipPositions()
+            {
+                while (posPending != 0)
+                {
+                    NextPosition();
+                }
+                if (storePayloads && !payloadRetrieved)
+                {
+                    postings.SkipBytes(payloadLength);
+                    payloadRetrieved = true;
+                }
+            }
+            
+            public override long Cost()
+            {
+                return cost;
+            }
+        }
+        
+        /// <summary>
+        /// Implementation of {@link PulsingEnumAttribute} for reuse of
+        /// wrapped postings readers underneath pulsing.
+        /// 
+        /// @lucene.internal
+        /// </summary>
+        internal sealed class PulsingEnumAttributeImpl : AttributeImpl, IPulsingEnumAttribute
+        {
+            // we could store 'other', but what if someone 'chained' multiple postings readers,
+            // this could cause problems?
+            // TODO: we should consider nuking this map and just making it so if you do this,
+            // you don't reuse? and maybe pulsingPostingsReader should throw an exc if it wraps
+            // another pulsing, because this is just stupid and wasteful. 
+            // we still have to be careful in case someone does Pulsing(Stomping(Pulsing(...
+            private readonly Dictionary<PulsingPostingsReader, DocsEnum> _enums = new Dictionary<PulsingPostingsReader, DocsEnum>();
+
+            public Dictionary<PulsingPostingsReader, DocsEnum> Enums()
+            {
+                return _enums;
+            }
+            public override void Clear()
+            {
+                // our state is per-docsenum, so this makes no sense.
+                // its best not to clear, in case a wrapped enum has a per-doc attribute or something
+                // and is calling clearAttributes(), so they don't nuke the reuse information!
+            }
+
+            public override void CopyTo(AttributeImpl target)
+            {
+                // this makes no sense for us, because our state is per-docsenum.
+                // we don't want to copy any stuff over to another docsenum ever!
+            }
+
+        }
+
+    }
+}

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/src/Lucene.Net.Codecs/Pulsing/PulsingPostingsWriter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Codecs/Pulsing/PulsingPostingsWriter.cs b/src/Lucene.Net.Codecs/Pulsing/PulsingPostingsWriter.cs
new file mode 100644
index 0000000..528f8de
--- /dev/null
+++ b/src/Lucene.Net.Codecs/Pulsing/PulsingPostingsWriter.cs
@@ -0,0 +1,511 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+using System;
+using System.Collections.Generic;
+using System.Diagnostics;
+using Lucene.Net.Index;
+using Lucene.Net.Store;
+using Lucene.Net.Util;
+
+namespace Lucene.Net.Codecs.Pulsing
+{
+
+    /// <summary>
+    /// TODO: we now inline based on total TF of the term,
+    /// but it might be better to inline by "net bytes used"
+    /// so that a term that has only 1 posting but a huge
+    /// payload would not be inlined.  Though this is
+    /// presumably rare in practice...
+    /// 
+    /// Writer for the pulsing format. 
+    ///
+    /// Wraps another postings implementation and decides 
+    /// (based on total number of occurrences), whether a terms 
+    /// postings should be inlined into the term dictionary,
+    /// or passed through to the wrapped writer.
+    ///
+    /// @lucene.experimental
+    /// </summary>
+    public sealed class PulsingPostingsWriter : PostingsWriterBase
+    {
+
+        internal static readonly String CODEC = "PulsedPostingsWriter";
+        internal static readonly String SUMMARY_EXTENSION = "smy";         // recording field summary
+        
+        // To add a new version, increment from the last one, and
+        // change VERSION_CURRENT to point to your new version:
+        internal static readonly int VERSION_START = 0;
+        internal static readonly int VERSION_META_ARRAY = 1;
+        internal static readonly int VERSION_CURRENT = VERSION_META_ARRAY;
+
+        private SegmentWriteState segmentState;
+        private IndexOutput termsOut;
+        private List<FieldMetaData> fields;
+        private FieldInfo.IndexOptions_e? indexOptions;
+        private bool storePayloads;
+
+        // information for wrapped PF, in current field
+        private int longsSize;
+        private long[] longs;
+        private bool absolute;
+
+        private class PulsingTermState : BlockTermState
+        {
+            internal byte[] bytes;
+            internal BlockTermState wrappedState;
+
+            public override String ToString()
+            {
+                if (bytes != null)
+                {
+                    return "inlined";
+                }
+                return "not inlined wrapped=" + wrappedState;
+            }
+        }
+
+        // one entry per position
+        private Position[] pending;
+        private int pendingCount = 0;   // -1 once we've hit too many positions
+        private Position currentDoc;    // first Position entry of current doc
+
+        private sealed class Position
+        {
+            internal BytesRef payload;
+            internal int termFreq; // only incremented on first position for a given doc
+            internal int pos;
+            internal int docID;
+            internal int startOffset;
+            internal int endOffset;
+        }
+
+        private class FieldMetaData
+        {
+            public int FieldNumber { get; private set; }
+            public int LongsSize { get; private set; }
+
+            public FieldMetaData(int number, int size)
+            {
+                FieldNumber = number;
+                LongsSize = size;
+            }
+        }
+
+        // TODO: -- lazy init this?  ie, if every single term
+        // was inlined (eg for a "primary key" field) then we
+        // never need to use this fallback?  Fallback writer for
+        // non-inlined terms:
+        private readonly PostingsWriterBase _wrappedPostingsWriter;
+
+        /// <summary>
+        /// If the total number of positions (summed across all docs
+        /// for this term) is <= maxPositions, then the postings are
+        /// inlined into terms dict
+        /// </summary>
+        public PulsingPostingsWriter(SegmentWriteState state, int maxPositions, PostingsWriterBase wrappedPostingsWriter)
+        {
+
+            pending = new Position[maxPositions];
+            for (int i = 0; i < maxPositions; i++)
+            {
+                pending[i] = new Position();
+            }
+            fields = new List<FieldMetaData>();
+
+            // We simply wrap another postings writer, but only call
+            // on it when tot positions is >= the cutoff:
+            this._wrappedPostingsWriter = wrappedPostingsWriter;
+            this.segmentState = state;
+        }
+
+        public override void Init(IndexOutput termsOut)
+        {
+            this.termsOut = termsOut;
+            CodecUtil.WriteHeader(termsOut, CODEC, VERSION_CURRENT);
+            termsOut.WriteVInt(pending.Length); // encode maxPositions in header
+            _wrappedPostingsWriter.Init(termsOut);
+        }
+
+        public override BlockTermState NewTermState()
+        {
+            PulsingTermState state = new PulsingTermState();
+            state.wrappedState = _wrappedPostingsWriter.NewTermState();
+            return state;
+        }
+
+        public override void StartTerm()
+        {
+            Debug.Debug.Assert((pendingCount == 0);
+        }
+
+        /// <summary>
+        /// TODO: -- should we NOT reuse across fields?  would
+        /// be cleaner
+        /// Currently, this instance is re-used across fields, so
+        /// our parent calls setField whenever the field changes
+        /// </summary>
+        /// <param name="fieldInfo"></param>
+        /// <returns></returns>
+        public override int SetField(FieldInfo fieldInfo)
+        {
+            this.indexOptions = fieldInfo.IndexOptions;
+            storePayloads = fieldInfo.HasPayloads();
+            absolute = false;
+            longsSize = _wrappedPostingsWriter.SetField(fieldInfo);
+            longs = new long[longsSize];
+            fields.Add(new FieldMetaData(fieldInfo.Number, longsSize));
+            return 0;
+        }
+
+        public override void StartDoc(int docID, int termDocFreq)
+        {
+            Debug.Debug.Assert((docID >= 0, "Got DocID=" + docID);
+
+            if (pendingCount == pending.Length)
+            {
+                push();
+                _wrappedPostingsWriter.FinishDoc();
+            }
+
+            if (pendingCount != -1)
+            {
+                Debug.Debug.Assert((pendingCount < pending.Length);
+                currentDoc = pending[pendingCount];
+                currentDoc.docID = docID;
+                if (indexOptions == FieldInfo.IndexOptions_e.DOCS_ONLY)
+                {
+                    pendingCount++;
+                }
+                else if (indexOptions == FieldInfo.IndexOptions_e.DOCS_AND_FREQS)
+                {
+                    pendingCount++;
+                    currentDoc.termFreq = termDocFreq;
+                }
+                else
+                {
+                    currentDoc.termFreq = termDocFreq;
+                }
+            }
+            else
+            {
+                // We've already seen too many docs for this term --
+                // just forward to our fallback writer
+                _wrappedPostingsWriter.StartDoc(docID, termDocFreq);
+            }
+        }
+
+        public override void AddPosition(int position, BytesRef payload, int startOffset, int endOffset)
+        {
+
+            if (pendingCount == pending.Length)
+            {
+                push();
+            }
+
+            if (pendingCount == -1)
+            {
+                // We've already seen too many docs for this term --
+                // just forward to our fallback writer
+                _wrappedPostingsWriter.AddPosition(position, payload, startOffset, endOffset);
+            }
+            else
+            {
+                // buffer up
+                Position pos = pending[pendingCount++];
+                pos.pos = position;
+                pos.startOffset = startOffset;
+                pos.endOffset = endOffset;
+                pos.docID = currentDoc.docID;
+                if (payload != null && payload.Length > 0)
+                {
+                    if (pos.payload == null)
+                    {
+                        pos.payload = BytesRef.DeepCopyOf(payload);
+                    }
+                    else
+                    {
+                        pos.payload.CopyBytes(payload);
+                    }
+                }
+                else if (pos.payload != null)
+                {
+                    pos.payload.Length = 0;
+                }
+            }
+        }
+
+        public override void FinishDoc()
+        {
+            if (pendingCount == -1)
+            {
+                _wrappedPostingsWriter.FinishDoc();
+            }
+        }
+
+        private readonly RAMOutputStream buffer = new RAMOutputStream();
+
+        /// <summary>
+        /// Called when we are done adding docs to this term
+        /// </summary>
+        /// <param name="_state"></param>
+        public override void FinishTerm(BlockTermState _state)
+        {
+            PulsingTermState state = (PulsingTermState) _state;
+
+            Debug.Debug.Assert((pendingCount > 0 || pendingCount == -1);
+
+            if (pendingCount == -1)
+            {
+                state.wrappedState.DocFreq = state.DocFreq;
+                state.wrappedState.TotalTermFreq = state.TotalTermFreq;
+                state.bytes = null;
+                _wrappedPostingsWriter.FinishTerm(state.wrappedState);
+            }
+            else
+            {
+                // There were few enough total occurrences for this
+                // term, so we fully inline our postings data into
+                // terms dict, now:
+
+                // TODO: it'd be better to share this encoding logic
+                // in some inner codec that knows how to write a
+                // single doc / single position, etc.  This way if a
+                // given codec wants to store other interesting
+                // stuff, it could use this pulsing codec to do so
+
+                if (indexOptions.Value.CompareTo(FieldInfo.IndexOptions_e.DOCS_AND_FREQS_AND_POSITIONS) >= 0)
+                {
+                    int lastDocID = 0;
+                    int pendingIDX = 0;
+                    int lastPayloadLength = -1;
+                    int lastOffsetLength = -1;
+                    while (pendingIDX < pendingCount)
+                    {
+                        Position doc = pending[pendingIDX];
+
+                        int delta = doc.docID - lastDocID;
+                        lastDocID = doc.docID;
+
+                        // if (DEBUG) System.out.println("  write doc=" + doc.docID + " freq=" + doc.termFreq);
+
+                        if (doc.termFreq == 1)
+                        {
+                            buffer.WriteVInt((delta << 1) | 1);
+                        }
+                        else
+                        {
+                            buffer.WriteVInt(delta << 1);
+                            buffer.WriteVInt(doc.termFreq);
+                        }
+
+                        int lastPos = 0;
+                        int lastOffset = 0;
+                        for (int posIDX = 0; posIDX < doc.termFreq; posIDX++)
+                        {
+                            Position pos = pending[pendingIDX++];
+                            Debug.Debug.Assert((pos.docID == doc.docID);
+                            int posDelta = pos.pos - lastPos;
+                            lastPos = pos.pos;
+                            
+                            int payloadLength = pos.payload == null ? 0 : pos.payload.Length;
+                            if (storePayloads)
+                            {
+                                if (payloadLength != lastPayloadLength)
+                                {
+                                    buffer.WriteVInt((posDelta << 1) | 1);
+                                    buffer.WriteVInt(payloadLength);
+                                    lastPayloadLength = payloadLength;
+                                }
+                                else
+                                {
+                                    buffer.WriteVInt(posDelta << 1);
+                                }
+                            }
+                            else
+                            {
+                                buffer.WriteVInt(posDelta);
+                            }
+
+                            if (indexOptions.Value.CompareTo(FieldInfo.IndexOptions_e.DOCS_AND_FREQS_AND_POSITIONS_AND_OFFSETS) >= 0)
+                            {
+                                //System.out.println("write=" + pos.startOffset + "," + pos.endOffset);
+                                int offsetDelta = pos.startOffset - lastOffset;
+                                int offsetLength = pos.endOffset - pos.startOffset;
+                                if (offsetLength != lastOffsetLength)
+                                {
+                                    buffer.WriteVInt(offsetDelta << 1 | 1);
+                                    buffer.WriteVInt(offsetLength);
+                                }
+                                else
+                                {
+                                    buffer.WriteVInt(offsetDelta << 1);
+                                }
+                                lastOffset = pos.startOffset;
+                                lastOffsetLength = offsetLength;
+                            }
+
+                            if (payloadLength > 0)
+                            {
+                                Debug.Debug.Assert((storePayloads);
+                                buffer.WriteBytes(pos.payload.Bytes, 0, pos.payload.Length);
+                            }
+                        }
+                    }
+                }
+                else if (indexOptions == FieldInfo.IndexOptions_e.DOCS_AND_FREQS)
+                {
+                    int lastDocID = 0;
+                    for (int posIDX = 0; posIDX < pendingCount; posIDX++)
+                    {
+                        Position doc = pending[posIDX];
+                        int delta = doc.docID - lastDocID;
+                        Debug.Debug.Assert((doc.termFreq != 0);
+
+                        if (doc.termFreq == 1)
+                        {
+                            buffer.WriteVInt((delta << 1) | 1);
+                        }
+                        else
+                        {
+                            buffer.WriteVInt(delta << 1);
+                            buffer.WriteVInt(doc.termFreq);
+                        }
+                        lastDocID = doc.docID;
+                    }
+                }
+                else if (indexOptions == FieldInfo.IndexOptions_e.DOCS_ONLY)
+                {
+                    int lastDocID = 0;
+                    for (int posIDX = 0; posIDX < pendingCount; posIDX++)
+                    {
+                        Position doc = pending[posIDX];
+                        buffer.WriteVInt(doc.docID - lastDocID);
+                        lastDocID = doc.docID;
+                    }
+                }
+
+                state.bytes = new byte[(int) buffer.FilePointer];
+                buffer.WriteTo((sbyte[])(Array)state.bytes, 0);
+                buffer.Reset();
+            }
+            pendingCount = 0;
+        }
+
+        public override void EncodeTerm(long[] empty, DataOutput output, FieldInfo fieldInfo, BlockTermState _state,
+            bool absolute)
+        {
+            PulsingTermState state = (PulsingTermState) _state;
+            Debug.Debug.Assert((empty.Length == 0);
+            this.absolute = this.absolute || absolute;
+            if (state.bytes == null)
+            {
+                _wrappedPostingsWriter.EncodeTerm(longs, buffer, fieldInfo, state.wrappedState, this.absolute);
+                for (int i = 0; i < longsSize; i++)
+                {
+                    output.WriteVLong(longs[i]);
+                }
+                buffer.WriteTo(output);
+                buffer.Reset();
+                this.absolute = false;
+            }
+            else
+            {
+                output.WriteVInt(state.bytes.Length);
+                output.WriteBytes(state.bytes, 0, state.bytes.Length);
+                this.absolute = this.absolute || absolute;
+            }
+        }
+
+        protected override void Dispose(bool disposing)
+        {
+            _wrappedPostingsWriter.Dispose();
+
+            if (_wrappedPostingsWriter is PulsingPostingsWriter ||
+                VERSION_CURRENT < VERSION_META_ARRAY)
+            {
+                return;
+            }
+
+            String summaryFileName = IndexFileNames.SegmentFileName(segmentState.SegmentInfo.Name,
+                segmentState.SegmentSuffix, SUMMARY_EXTENSION);
+            IndexOutput output = null;
+            try
+            {
+                output =
+                    segmentState.Directory.CreateOutput(summaryFileName, segmentState.Context);
+                CodecUtil.WriteHeader(output, CODEC, VERSION_CURRENT);
+                output.WriteVInt(fields.Count);
+                foreach (FieldMetaData field in fields)
+                {
+                    output.WriteVInt(field.FieldNumber);
+                    output.WriteVInt(field.LongsSize);
+                }
+                output.Dispose();
+            }
+            finally
+            {
+                IOUtils.CloseWhileHandlingException(output);
+            }
+        }
+
+        // Pushes pending positions to the wrapped codec
+        private void push()
+        {
+            // if (DEBUG) System.out.println("PW now push @ " + pendingCount + " wrapped=" + wrappedPostingsWriter);
+            Debug.Debug.Assert((pendingCount == pending.Length);
+
+            _wrappedPostingsWriter.StartTerm();
+
+            // Flush all buffered docs
+            if (indexOptions.Value.CompareTo(FieldInfo.IndexOptions_e.DOCS_AND_FREQS_AND_POSITIONS) >= 0)
+            {
+                Position doc = null;
+
+                foreach(Position pos in pending)
+                {
+                    if (doc == null)
+                    {
+                        doc = pos;
+                        // if (DEBUG) System.out.println("PW: wrapped.startDoc docID=" + doc.docID + " tf=" + doc.termFreq);
+                        _wrappedPostingsWriter.StartDoc(doc.docID, doc.termFreq);
+                    }
+                    else if (doc.docID != pos.docID)
+                    {
+                        Debug.Debug.Assert((pos.docID > doc.docID);
+                        // if (DEBUG) System.out.println("PW: wrapped.finishDoc");
+                        _wrappedPostingsWriter.FinishDoc();
+                        doc = pos;
+                        // if (DEBUG) System.out.println("PW: wrapped.startDoc docID=" + doc.docID + " tf=" + doc.termFreq);
+                        _wrappedPostingsWriter.StartDoc(doc.docID, doc.termFreq);
+                    }
+                    // if (DEBUG) System.out.println("PW:   wrapped.addPos pos=" + pos.pos);
+                    _wrappedPostingsWriter.AddPosition(pos.pos, pos.payload, pos.startOffset, pos.endOffset);
+                }
+                //wrappedPostingsWriter.finishDoc();
+            }
+            else
+            {
+                foreach(Position doc in pending)
+                {
+                    _wrappedPostingsWriter.StartDoc(doc.docID, indexOptions == FieldInfo.IndexOptions_e.DOCS_ONLY ? 0 : doc.termFreq);
+                }
+            }
+            pendingCount = -1;
+        }
+    }
+}

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/src/Lucene.Net.Codecs/Sep/IntIndexInput.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Codecs/Sep/IntIndexInput.cs b/src/Lucene.Net.Codecs/Sep/IntIndexInput.cs
new file mode 100644
index 0000000..ebe0d27
--- /dev/null
+++ b/src/Lucene.Net.Codecs/Sep/IntIndexInput.cs
@@ -0,0 +1,59 @@
+package org.apache.lucene.codecs.sep;
+
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+import java.io.Closeable;
+import java.io.IOException;
+
+import org.apache.lucene.store.DataInput;
+
+/** Defines basic API for writing ints to an IndexOutput.
+ *  IntBlockCodec interacts with this API. @see
+ *  IntBlockReader
+ *
+ * @lucene.experimental */
+public abstract class IntIndexInput implements Closeable {
+
+  public abstract Reader reader() ;
+
+  @Override
+  public abstract void close() ;
+
+  public abstract Index index() ;
+  
+  /** Records a single skip-point in the {@link IntIndexInput.Reader}. */
+  public abstract static class Index {
+
+    public abstract void read(DataInput indexIn, bool absolute) ;
+
+    /** Seeks primary stream to the last read offset */
+    public abstract void seek(IntIndexInput.Reader stream) ;
+
+    public abstract void copyFrom(Index other);
+    
+    @Override
+    public abstract Index clone();
+  }
+
+  /** Reads int values. */
+  public abstract static class Reader {
+
+    /** Reads next single int */
+    public abstract int next() ;
+  }
+}

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/src/Lucene.Net.Codecs/Sep/IntIndexOutput.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Codecs/Sep/IntIndexOutput.cs b/src/Lucene.Net.Codecs/Sep/IntIndexOutput.cs
new file mode 100644
index 0000000..3f608d5
--- /dev/null
+++ b/src/Lucene.Net.Codecs/Sep/IntIndexOutput.cs
@@ -0,0 +1,61 @@
+package org.apache.lucene.codecs.sep;
+
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+// TODO: we may want tighter integration w/ IndexOutput --
+// may give better perf:
+
+import org.apache.lucene.store.DataOutput;
+
+import java.io.IOException;
+import java.io.Closeable;
+
+/** Defines basic API for writing ints to an IndexOutput.
+ *  IntBlockCodec interacts with this API. @see
+ *  IntBlockReader.
+ *
+ * <p>NOTE: block sizes could be variable
+ *
+ * @lucene.experimental */
+public abstract class IntIndexOutput implements Closeable {
+
+  /** Write an int to the primary file.  The value must be
+   * >= 0.  */
+  public abstract void write(int v) ;
+
+  /** Records a single skip-point in the IndexOutput. */
+  public abstract static class Index {
+
+    /** Internally records the current location */
+    public abstract void mark() ;
+
+    /** Copies index from other */
+    public abstract void copyFrom(Index other, bool copyLast) ;
+
+    /** Writes "location" of current output pointer of primary
+     *  output to different output (out) */
+    public abstract void write(DataOutput indexOut, bool absolute) ;
+  }
+
+  /** If you are indexing the primary output file, call
+   *  this and interact with the returned IndexWriter. */
+  public abstract Index index();
+
+  @Override
+  public abstract void close() ;
+}

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/src/Lucene.Net.Codecs/Sep/IntStreamFactory.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Codecs/Sep/IntStreamFactory.cs b/src/Lucene.Net.Codecs/Sep/IntStreamFactory.cs
new file mode 100644
index 0000000..a6d42ba
--- /dev/null
+++ b/src/Lucene.Net.Codecs/Sep/IntStreamFactory.cs
@@ -0,0 +1,36 @@
+package org.apache.lucene.codecs.sep;
+
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+import org.apache.lucene.store.Directory;
+import org.apache.lucene.store.IOContext;
+
+import java.io.IOException;
+
+/** Provides int reader and writer to specified files.
+ *
+ * @lucene.experimental */
+public abstract class IntStreamFactory {
+  /** Create an {@link IntIndexInput} on the provided
+   *  fileName. */
+  public abstract IntIndexInput openInput(Directory dir, String fileName, IOContext context) ;
+
+  /** Create an {@link IntIndexOutput} on the provided
+   *  fileName. */
+  public abstract IntIndexOutput createOutput(Directory dir, String fileName, IOContext context) ;
+}

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/src/Lucene.Net.Codecs/Sep/SepPostingsReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Codecs/Sep/SepPostingsReader.cs b/src/Lucene.Net.Codecs/Sep/SepPostingsReader.cs
new file mode 100644
index 0000000..3aa45fa
--- /dev/null
+++ b/src/Lucene.Net.Codecs/Sep/SepPostingsReader.cs
@@ -0,0 +1,714 @@
+package org.apache.lucene.codecs.sep;
+
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+import java.io.IOException;
+
+import org.apache.lucene.codecs.BlockTermState;
+import org.apache.lucene.codecs.CodecUtil;
+import org.apache.lucene.codecs.PostingsReaderBase;
+import org.apache.lucene.index.DocsAndPositionsEnum;
+import org.apache.lucene.index.DocsEnum;
+import org.apache.lucene.index.FieldInfo.IndexOptions;
+import org.apache.lucene.index.FieldInfo;
+import org.apache.lucene.index.FieldInfos;
+import org.apache.lucene.index.IndexFileNames;
+import org.apache.lucene.index.SegmentInfo;
+import org.apache.lucene.index.TermState;
+import org.apache.lucene.store.ByteArrayDataInput;
+import org.apache.lucene.store.DataInput;
+import org.apache.lucene.store.Directory;
+import org.apache.lucene.store.IOContext;
+import org.apache.lucene.store.IndexInput;
+import org.apache.lucene.util.ArrayUtil;
+import org.apache.lucene.util.Bits;
+import org.apache.lucene.util.BytesRef;
+import org.apache.lucene.util.IOUtils;
+
+/** Concrete class that reads the current doc/freq/skip
+ *  postings format.    
+ *
+ * @lucene.experimental
+ */
+
+// TODO: -- should we switch "hasProx" higher up?  and
+// create two separate docs readers, one that also reads
+// prox and one that doesn't?
+
+public class SepPostingsReader extends PostingsReaderBase {
+
+  final IntIndexInput freqIn;
+  final IntIndexInput docIn;
+  final IntIndexInput posIn;
+  final IndexInput payloadIn;
+  final IndexInput skipIn;
+
+  int skipInterval;
+  int maxSkipLevels;
+  int skipMinimum;
+
+  public SepPostingsReader(Directory dir, FieldInfos fieldInfos, SegmentInfo segmentInfo, IOContext context, IntStreamFactory intFactory, String segmentSuffix)  {
+    bool success = false;
+    try {
+
+      final String docFileName = IndexFileNames.segmentFileName(segmentInfo.name, segmentSuffix, SepPostingsWriter.DOC_EXTENSION);
+      docIn = intFactory.openInput(dir, docFileName, context);
+
+      skipIn = dir.openInput(IndexFileNames.segmentFileName(segmentInfo.name, segmentSuffix, SepPostingsWriter.SKIP_EXTENSION), context);
+
+      if (fieldInfos.hasFreq()) {
+        freqIn = intFactory.openInput(dir, IndexFileNames.segmentFileName(segmentInfo.name, segmentSuffix, SepPostingsWriter.FREQ_EXTENSION), context);        
+      } else {
+        freqIn = null;
+      }
+      if (fieldInfos.hasProx()) {
+        posIn = intFactory.openInput(dir, IndexFileNames.segmentFileName(segmentInfo.name, segmentSuffix, SepPostingsWriter.POS_EXTENSION), context);
+        payloadIn = dir.openInput(IndexFileNames.segmentFileName(segmentInfo.name, segmentSuffix, SepPostingsWriter.PAYLOAD_EXTENSION), context);
+      } else {
+        posIn = null;
+        payloadIn = null;
+      }
+      success = true;
+    } finally {
+      if (!success) {
+        close();
+      }
+    }
+  }
+
+  @Override
+  public void init(IndexInput termsIn)  {
+    // Make sure we are talking to the matching past writer
+    CodecUtil.checkHeader(termsIn, SepPostingsWriter.CODEC,
+      SepPostingsWriter.VERSION_START, SepPostingsWriter.VERSION_START);
+    skipInterval = termsIn.readInt();
+    maxSkipLevels = termsIn.readInt();
+    skipMinimum = termsIn.readInt();
+  }
+
+  @Override
+  public void close()  {
+    IOUtils.close(freqIn, docIn, skipIn, posIn, payloadIn);
+  }
+
+  private static final class SepTermState extends BlockTermState {
+    // We store only the seek point to the docs file because
+    // the rest of the info (freqIndex, posIndex, etc.) is
+    // stored in the docs file:
+    IntIndexInput.Index docIndex;
+    IntIndexInput.Index posIndex;
+    IntIndexInput.Index freqIndex;
+    long payloadFP;
+    long skipFP;
+
+    @Override
+    public SepTermState clone() {
+      SepTermState other = new SepTermState();
+      other.copyFrom(this);
+      return other;
+    }
+
+    @Override
+    public void copyFrom(TermState _other) {
+      super.copyFrom(_other);
+      SepTermState other = (SepTermState) _other;
+      if (docIndex == null) {
+        docIndex = other.docIndex.clone();
+      } else {
+        docIndex.copyFrom(other.docIndex);
+      }
+      if (other.freqIndex != null) {
+        if (freqIndex == null) {
+          freqIndex = other.freqIndex.clone();
+        } else {
+          freqIndex.copyFrom(other.freqIndex);
+        }
+      } else {
+        freqIndex = null;
+      }
+      if (other.posIndex != null) {
+        if (posIndex == null) {
+          posIndex = other.posIndex.clone();
+        } else {
+          posIndex.copyFrom(other.posIndex);
+        }
+      } else {
+        posIndex = null;
+      }
+      payloadFP = other.payloadFP;
+      skipFP = other.skipFP;
+    }
+
+    @Override
+    public String toString() {
+      return super.toString() + " docIndex=" + docIndex + " freqIndex=" + freqIndex + " posIndex=" + posIndex + " payloadFP=" + payloadFP + " skipFP=" + skipFP;
+    }
+  }
+
+  @Override
+  public BlockTermState newTermState()  {
+    final SepTermState state = new SepTermState();
+    state.docIndex = docIn.index();
+    if (freqIn != null) {
+      state.freqIndex = freqIn.index();
+    }
+    if (posIn != null) {
+      state.posIndex = posIn.index();
+    }
+    return state;
+  }
+
+  @Override
+  public void decodeTerm(long[] empty, DataInput in, FieldInfo fieldInfo, BlockTermState _termState, bool absolute) 
+     {
+    final SepTermState termState = (SepTermState) _termState;
+    termState.docIndex.read(in, absolute);
+    if (fieldInfo.getIndexOptions() != IndexOptions.DOCS_ONLY) {
+      termState.freqIndex.read(in, absolute);
+      if (fieldInfo.getIndexOptions() == IndexOptions.DOCS_AND_FREQS_AND_POSITIONS) {
+        //System.out.println("  freqIndex=" + termState.freqIndex);
+        termState.posIndex.read(in, absolute);
+        //System.out.println("  posIndex=" + termState.posIndex);
+        if (fieldInfo.hasPayloads()) {
+          if (absolute) {
+            termState.payloadFP = in.readVLong();
+          } else {
+            termState.payloadFP += in.readVLong();
+          }
+          //System.out.println("  payloadFP=" + termState.payloadFP);
+        }
+      }
+    }
+
+    if (termState.docFreq >= skipMinimum) {
+      //System.out.println("   readSkip @ " + in.getPosition());
+      if (absolute) {
+        termState.skipFP = in.readVLong();
+      } else {
+        termState.skipFP += in.readVLong();
+      }
+      //System.out.println("  skipFP=" + termState.skipFP);
+    } else if (absolute) {
+      termState.skipFP = 0;
+    }
+  }
+
+  @Override
+  public DocsEnum docs(FieldInfo fieldInfo, BlockTermState _termState, Bits liveDocs, DocsEnum reuse, int flags)  {
+    final SepTermState termState = (SepTermState) _termState;
+    SepDocsEnum docsEnum;
+    if (reuse == null || !(reuse instanceof SepDocsEnum)) {
+      docsEnum = new SepDocsEnum();
+    } else {
+      docsEnum = (SepDocsEnum) reuse;
+      if (docsEnum.startDocIn != docIn) {
+        // If you are using ParellelReader, and pass in a
+        // reused DocsAndPositionsEnum, it could have come
+        // from another reader also using sep codec
+        docsEnum = new SepDocsEnum();        
+      }
+    }
+
+    return docsEnum.init(fieldInfo, termState, liveDocs);
+  }
+
+  @Override
+  public DocsAndPositionsEnum docsAndPositions(FieldInfo fieldInfo, BlockTermState _termState, Bits liveDocs,
+                                               DocsAndPositionsEnum reuse, int flags)
+     {
+
+    Debug.Assert( fieldInfo.getIndexOptions() == IndexOptions.DOCS_AND_FREQS_AND_POSITIONS;
+    final SepTermState termState = (SepTermState) _termState;
+    SepDocsAndPositionsEnum postingsEnum;
+    if (reuse == null || !(reuse instanceof SepDocsAndPositionsEnum)) {
+      postingsEnum = new SepDocsAndPositionsEnum();
+    } else {
+      postingsEnum = (SepDocsAndPositionsEnum) reuse;
+      if (postingsEnum.startDocIn != docIn) {
+        // If you are using ParellelReader, and pass in a
+        // reused DocsAndPositionsEnum, it could have come
+        // from another reader also using sep codec
+        postingsEnum = new SepDocsAndPositionsEnum();        
+      }
+    }
+
+    return postingsEnum.init(fieldInfo, termState, liveDocs);
+  }
+
+  class SepDocsEnum extends DocsEnum {
+    int docFreq;
+    int doc = -1;
+    int accum;
+    int count;
+    int freq;
+    long freqStart;
+
+    // TODO: -- should we do omitTF with 2 different enum classes?
+    private bool omitTF;
+    private IndexOptions indexOptions;
+    private bool storePayloads;
+    private Bits liveDocs;
+    private final IntIndexInput.Reader docReader;
+    private final IntIndexInput.Reader freqReader;
+    private long skipFP;
+
+    private final IntIndexInput.Index docIndex;
+    private final IntIndexInput.Index freqIndex;
+    private final IntIndexInput.Index posIndex;
+    private final IntIndexInput startDocIn;
+
+    // TODO: -- should we do hasProx with 2 different enum classes?
+
+    bool skipped;
+    SepSkipListReader skipper;
+
+    SepDocsEnum()  {
+      startDocIn = docIn;
+      docReader = docIn.reader();
+      docIndex = docIn.index();
+      if (freqIn != null) {
+        freqReader = freqIn.reader();
+        freqIndex = freqIn.index();
+      } else {
+        freqReader = null;
+        freqIndex = null;
+      }
+      if (posIn != null) {
+        posIndex = posIn.index();                 // only init this so skipper can read it
+      } else {
+        posIndex = null;
+      }
+    }
+
+    SepDocsEnum init(FieldInfo fieldInfo, SepTermState termState, Bits liveDocs)  {
+      this.liveDocs = liveDocs;
+      this.indexOptions = fieldInfo.getIndexOptions();
+      omitTF = indexOptions == IndexOptions.DOCS_ONLY;
+      storePayloads = fieldInfo.hasPayloads();
+
+      // TODO: can't we only do this if consumer
+      // skipped consuming the previous docs?
+      docIndex.copyFrom(termState.docIndex);
+      docIndex.seek(docReader);
+
+      if (!omitTF) {
+        freqIndex.copyFrom(termState.freqIndex);
+        freqIndex.seek(freqReader);
+      }
+
+      docFreq = termState.docFreq;
+      // NOTE: unused if docFreq < skipMinimum:
+      skipFP = termState.skipFP;
+      count = 0;
+      doc = -1;
+      accum = 0;
+      freq = 1;
+      skipped = false;
+
+      return this;
+    }
+
+    @Override
+    public int nextDoc()  {
+
+      while(true) {
+        if (count == docFreq) {
+          return doc = NO_MORE_DOCS;
+        }
+
+        count++;
+
+        // Decode next doc
+        //System.out.println("decode docDelta:");
+        accum += docReader.next();
+          
+        if (!omitTF) {
+          //System.out.println("decode freq:");
+          freq = freqReader.next();
+        }
+
+        if (liveDocs == null || liveDocs.get(accum)) {
+          break;
+        }
+      }
+      return (doc = accum);
+    }
+
+    @Override
+    public int freq()  {
+      return freq;
+    }
+
+    @Override
+    public int docID() {
+      return doc;
+    }
+
+    @Override
+    public int advance(int target)  {
+
+      if ((target - skipInterval) >= doc && docFreq >= skipMinimum) {
+
+        // There are enough docs in the posting to have
+        // skip data, and its not too close
+
+        if (skipper == null) {
+          // This DocsEnum has never done any skipping
+          skipper = new SepSkipListReader(skipIn.clone(),
+                                          freqIn,
+                                          docIn,
+                                          posIn,
+                                          maxSkipLevels, skipInterval);
+
+        }
+
+        if (!skipped) {
+          // We haven't yet skipped for this posting
+          skipper.init(skipFP,
+                       docIndex,
+                       freqIndex,
+                       posIndex,
+                       0,
+                       docFreq,
+                       storePayloads);
+          skipper.setIndexOptions(indexOptions);
+
+          skipped = true;
+        }
+
+        final int newCount = skipper.skipTo(target); 
+
+        if (newCount > count) {
+
+          // Skipper did move
+          if (!omitTF) {
+            skipper.getFreqIndex().seek(freqReader);
+          }
+          skipper.getDocIndex().seek(docReader);
+          count = newCount;
+          doc = accum = skipper.getDoc();
+        }
+      }
+        
+      // Now, linear scan for the rest:
+      do {
+        if (nextDoc() == NO_MORE_DOCS) {
+          return NO_MORE_DOCS;
+        }
+      } while (target > doc);
+
+      return doc;
+    }
+    
+    @Override
+    public long cost() {
+      return docFreq;
+    }
+  }
+
+  class SepDocsAndPositionsEnum extends DocsAndPositionsEnum {
+    int docFreq;
+    int doc = -1;
+    int accum;
+    int count;
+    int freq;
+    long freqStart;
+
+    private bool storePayloads;
+    private Bits liveDocs;
+    private final IntIndexInput.Reader docReader;
+    private final IntIndexInput.Reader freqReader;
+    private final IntIndexInput.Reader posReader;
+    private final IndexInput payloadIn;
+    private long skipFP;
+
+    private final IntIndexInput.Index docIndex;
+    private final IntIndexInput.Index freqIndex;
+    private final IntIndexInput.Index posIndex;
+    private final IntIndexInput startDocIn;
+
+    private long payloadFP;
+
+    private int pendingPosCount;
+    private int position;
+    private int payloadLength;
+    private long pendingPayloadBytes;
+
+    private bool skipped;
+    private SepSkipListReader skipper;
+    private bool payloadPending;
+    private bool posSeekPending;
+
+    SepDocsAndPositionsEnum()  {
+      startDocIn = docIn;
+      docReader = docIn.reader();
+      docIndex = docIn.index();
+      freqReader = freqIn.reader();
+      freqIndex = freqIn.index();
+      posReader = posIn.reader();
+      posIndex = posIn.index();
+      payloadIn = SepPostingsReader.this.payloadIn.clone();
+    }
+
+    SepDocsAndPositionsEnum init(FieldInfo fieldInfo, SepTermState termState, Bits liveDocs)  {
+      this.liveDocs = liveDocs;
+      storePayloads = fieldInfo.hasPayloads();
+      //System.out.println("Sep D&P init");
+
+      // TODO: can't we only do this if consumer
+      // skipped consuming the previous docs?
+      docIndex.copyFrom(termState.docIndex);
+      docIndex.seek(docReader);
+      //System.out.println("  docIndex=" + docIndex);
+
+      freqIndex.copyFrom(termState.freqIndex);
+      freqIndex.seek(freqReader);
+      //System.out.println("  freqIndex=" + freqIndex);
+
+      posIndex.copyFrom(termState.posIndex);
+      //System.out.println("  posIndex=" + posIndex);
+      posSeekPending = true;
+      payloadPending = false;
+
+      payloadFP = termState.payloadFP;
+      skipFP = termState.skipFP;
+      //System.out.println("  skipFP=" + skipFP);
+
+      docFreq = termState.docFreq;
+      count = 0;
+      doc = -1;
+      accum = 0;
+      pendingPosCount = 0;
+      pendingPayloadBytes = 0;
+      skipped = false;
+
+      return this;
+    }
+
+    @Override
+    public int nextDoc()  {
+
+      while(true) {
+        if (count == docFreq) {
+          return doc = NO_MORE_DOCS;
+        }
+
+        count++;
+
+        // TODO: maybe we should do the 1-bit trick for encoding
+        // freq=1 case?
+
+        // Decode next doc
+        //System.out.println("  sep d&p read doc");
+        accum += docReader.next();
+
+        //System.out.println("  sep d&p read freq");
+        freq = freqReader.next();
+
+        pendingPosCount += freq;
+
+        if (liveDocs == null || liveDocs.get(accum)) {
+          break;
+        }
+      }
+
+      position = 0;
+      return (doc = accum);
+    }
+
+    @Override
+    public int freq()  {
+      return freq;
+    }
+
+    @Override
+    public int docID() {
+      return doc;
+    }
+
+    @Override
+    public int advance(int target)  {
+      //System.out.println("SepD&P advance target=" + target + " vs current=" + doc + " this=" + this);
+
+      if ((target - skipInterval) >= doc && docFreq >= skipMinimum) {
+
+        // There are enough docs in the posting to have
+        // skip data, and its not too close
+
+        if (skipper == null) {
+          //System.out.println("  create skipper");
+          // This DocsEnum has never done any skipping
+          skipper = new SepSkipListReader(skipIn.clone(),
+                                          freqIn,
+                                          docIn,
+                                          posIn,
+                                          maxSkipLevels, skipInterval);
+        }
+
+        if (!skipped) {
+          //System.out.println("  init skip data skipFP=" + skipFP);
+          // We haven't yet skipped for this posting
+          skipper.init(skipFP,
+                       docIndex,
+                       freqIndex,
+                       posIndex,
+                       payloadFP,
+                       docFreq,
+                       storePayloads);
+          skipper.setIndexOptions(IndexOptions.DOCS_AND_FREQS_AND_POSITIONS);
+          skipped = true;
+        }
+        final int newCount = skipper.skipTo(target); 
+        //System.out.println("  skip newCount=" + newCount + " vs " + count);
+
+        if (newCount > count) {
+
+          // Skipper did move
+          skipper.getFreqIndex().seek(freqReader);
+          skipper.getDocIndex().seek(docReader);
+          //System.out.println("  doc seek'd to " + skipper.getDocIndex());
+          // NOTE: don't seek pos here; do it lazily
+          // instead.  Eg a PhraseQuery may skip to many
+          // docs before finally asking for positions...
+          posIndex.copyFrom(skipper.getPosIndex());
+          posSeekPending = true;
+          count = newCount;
+          doc = accum = skipper.getDoc();
+          //System.out.println("    moved to doc=" + doc);
+          //payloadIn.seek(skipper.getPayloadPointer());
+          payloadFP = skipper.getPayloadPointer();
+          pendingPosCount = 0;
+          pendingPayloadBytes = 0;
+          payloadPending = false;
+          payloadLength = skipper.getPayloadLength();
+          //System.out.println("    move payloadLen=" + payloadLength);
+        }
+      }
+        
+      // Now, linear scan for the rest:
+      do {
+        if (nextDoc() == NO_MORE_DOCS) {
+          //System.out.println("  advance nextDoc=END");
+          return NO_MORE_DOCS;
+        }
+        //System.out.println("  advance nextDoc=" + doc);
+      } while (target > doc);
+
+      //System.out.println("  return doc=" + doc);
+      return doc;
+    }
+
+    @Override
+    public int nextPosition()  {
+      if (posSeekPending) {
+        posIndex.seek(posReader);
+        payloadIn.seek(payloadFP);
+        posSeekPending = false;
+      }
+
+      // scan over any docs that were iterated without their
+      // positions
+      while (pendingPosCount > freq) {
+        final int code = posReader.next();
+        if (storePayloads && (code & 1) != 0) {
+          // Payload length has changed
+          payloadLength = posReader.next();
+          Debug.Assert( payloadLength >= 0;
+        }
+        pendingPosCount--;
+        position = 0;
+        pendingPayloadBytes += payloadLength;
+      }
+
+      final int code = posReader.next();
+
+      if (storePayloads) {
+        if ((code & 1) != 0) {
+          // Payload length has changed
+          payloadLength = posReader.next();
+          Debug.Assert( payloadLength >= 0;
+        }
+        position += code >>> 1;
+        pendingPayloadBytes += payloadLength;
+        payloadPending = payloadLength > 0;
+      } else {
+        position += code;
+      }
+    
+      pendingPosCount--;
+      Debug.Assert( pendingPosCount >= 0;
+      return position;
+    }
+
+    @Override
+    public int startOffset() {
+      return -1;
+    }
+
+    @Override
+    public int endOffset() {
+      return -1;
+    }
+
+    private BytesRef payload;
+
+    @Override
+    public BytesRef getPayload()  {
+      if (!payloadPending) {
+        return null;
+      }
+      
+      if (pendingPayloadBytes == 0) {
+        return payload;
+      }
+
+      Debug.Assert( pendingPayloadBytes >= payloadLength;
+
+      if (pendingPayloadBytes > payloadLength) {
+        payloadIn.seek(payloadIn.getFilePointer() + (pendingPayloadBytes - payloadLength));
+      }
+
+      if (payload == null) {
+        payload = new BytesRef();
+        payload.bytes = new byte[payloadLength];
+      } else if (payload.bytes.length < payloadLength) {
+        payload.grow(payloadLength);
+      }
+
+      payloadIn.readBytes(payload.bytes, 0, payloadLength);
+      payload.length = payloadLength;
+      pendingPayloadBytes = 0;
+      return payload;
+    }
+    
+    @Override
+    public long cost() {
+      return docFreq;
+    }
+  }
+
+  @Override
+  public long ramBytesUsed() {
+    return 0;
+  }
+
+  @Override
+  public void checkIntegrity()  {
+    // TODO: remove sep layout, its fallen behind on features...
+  }
+}


[33/51] [abbrv] [partial] Cleaning up and getting ready to development towards v4.8

Posted by sy...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/MbUnit.Compatibility.xml
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/MbUnit.Compatibility.xml b/lib/Gallio.3.2.750/tools/MbUnit.Compatibility.xml
deleted file mode 100644
index 28c95fe..0000000
--- a/lib/Gallio.3.2.750/tools/MbUnit.Compatibility.xml
+++ /dev/null
@@ -1,3419 +0,0 @@
-<?xml version="1.0"?>
-<doc>
-    <assembly>
-        <name>MbUnit.Compatibility</name>
-    </assembly>
-    <members>
-        <member name="T:MbUnit.Framework.OldArrayAssert">
-            <summary>
-            Array Assertion class
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldArrayAssert.AreEqual(System.Boolean[],System.Boolean[])">
-            <summary>
-            Verifies that both array have the same dimension and elements.
-            </summary>
-            <param name="expected">The expected values.</param>
-            <param name="actual">The actual values.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldArrayAssert.IsArrayType(System.Object)">
-            <summary>
-            Checks whether an object is of an <see cref="T:System.Array"/> type.
-            </summary>
-            <param name="obj">Object instance to check as an array.</param>
-            <returns>True if <see cref="T:System.Array"/> Type, False otherwise.</returns>
-        </member>
-        <member name="T:MbUnit.Framework.OldAssert">
-            <summary>
-            Assertion class
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.Equals(System.Object,System.Object)">
-            <summary>
-            The Equals method throws an AssertionException. This is done
-            to make sure there is no mistake by calling this function.
-            </summary>
-            <param name="a">The first object.</param>
-            <param name="b">The second object.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.ReferenceEquals(System.Object,System.Object)">
-            <summary>
-            override the default ReferenceEquals to throw an AssertionException. This
-            implementation makes sure there is no mistake in calling this function
-            as part of Assert.
-            </summary>
-            <param name="a">The first object.</param>
-            <param name="b">The second object.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.IsNumericType(System.Object)">
-            <summary>
-            Checks the type of the object, returning true if
-            the object is a numeric type.
-            </summary>
-            <param name="obj">The object to check.</param>
-            <returns>true if the object is a numeric type.</returns>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.ObjectsEqual(System.Object,System.Object)">
-            <summary>
-            Used to compare numeric types.  Comparisons between
-            same types are fine (Int32 to Int32, or Int64 to Int64),
-            but the Equals method fails across different types.
-            This method was added to allow any numeric type to
-            be handled correctly, by using <c>ToString</c> and
-            comparing the result
-            </summary>
-            <param name="expected">The expected value.</param>
-            <param name="actual">The actual value.</param>
-            <returns></returns>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.IsTrue(System.Boolean,System.String,System.Object[])">
-            <summary>
-            Asserts that a condition is true. If the condition is false the method throws
-            an <see cref="T:Gallio.Framework.Assertions.AssertionException"/>.
-            </summary>
-            <param name="condition">The evaluated condition.</param>
-            <param name="format">
-            The format of the message to display if the condition is false,
-            containing zero or more format items.
-            </param>
-            <param name="args">
-            An <see cref="T:System.Object"/> array containing zero or more objects to format.
-            </param>
-            <remarks>
-            <para>
-            The error message is formatted using <see cref="M:System.String.Format(System.String,System.Object[])"/>.
-            </para>
-            </remarks>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.IsTrue(System.Boolean)">
-            <summary>
-            Asserts that a condition is true. If the condition is false the method throws
-            an <see cref="T:Gallio.Framework.Assertions.AssertionException"/>.
-            </summary>
-            <param name="condition">The evaluated condition.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.IsFalse(System.Boolean,System.String,System.Object[])">
-            <summary>
-            Asserts that a condition is false. If the condition is true the method throws
-            an <see cref="T:Gallio.Framework.Assertions.AssertionException"/>.
-            </summary>
-            <param name="condition">The evaluated condition.</param>
-            <param name="format">
-            The format of the message to display if the condition is false,
-            containing zero or more format items.
-            </param>
-            <param name="args">
-            An <see cref="T:System.Object"/> array containing zero or more objects to format.
-            </param>
-            <remarks>
-            <para>
-            The error message is formatted using <see cref="M:System.String.Format(System.String,System.Object[])"/>.
-            </para>
-            </remarks>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.IsFalse(System.Boolean)">
-            <summary>
-            Asserts that a condition is false. If the condition is true the method throws
-            an <see cref="T:Gallio.Framework.Assertions.AssertionException"/>.
-            </summary>
-            <param name="condition">The evaluated condition.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.AreEqual(System.Double,System.Double,System.Double,System.String)">
-            <summary>
-            Verifies that two doubles are equal considering a delta. If the
-            expected value is infinity then the delta value is ignored. If
-            they are not equals then an <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is
-            thrown.
-            </summary>
-            <param name="expected">The expected value.</param>
-            <param name="actual">The actual value.</param>
-            <param name="delta">The maximum acceptable difference between the
-            the expected and the actual.</param>
-            <param name="message">The message printed out upon failure.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.AreEqual(System.Double,System.Double,System.Double)">
-            <summary>
-            Verifies that two doubles are equal considering a delta. If the
-            expected value is infinity then the delta value is ignored. If
-            they are not equals then an <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is
-            thrown.
-            </summary>
-            <param name="expected">The expected value.</param>
-            <param name="actual">The actual value.</param>
-            <param name="delta">The maximum acceptable difference between the
-            the expected and the actual.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.AreEqual(System.Single,System.Single,System.Single,System.String)">
-            <summary>
-            Verifies that two floats are equal considering a delta. If the
-            expected value is infinity then the delta value is ignored. If
-            they are not equals then an <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is
-            thrown.
-            </summary>
-            <param name="message">The message printed out upon failure.</param>
-            <param name="expected">The expected value.</param>
-            <param name="actual">The actual value.</param>
-            <param name="delta">The maximum acceptable difference between the
-            the expected and the actual.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.AreEqual(System.Single,System.Single,System.Single)">
-            <summary>
-            Verifies that two floats are equal considering a delta. If the
-            expected value is infinity then the delta value is ignored. If
-            they are not equals then an <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is
-            thrown.
-            </summary>
-            <param name="expected">The expected value.</param>
-            <param name="actual">The actual value.</param>
-            <param name="delta">The maximum acceptable difference between the
-            the expected and the actual.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.AreEqual(System.Decimal,System.Decimal,System.String)">
-            <summary>
-            Verifies that two decimals are equal. If
-            they are not equals then an <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is
-            thrown.
-            </summary>
-            <param name="message">The message printed out upon failure.</param>
-            <param name="expected">The expected value.</param>
-            <param name="actual">The actual value.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.AreEqual(System.Decimal,System.Decimal,System.String,System.Object[])">
-            <summary>
-            Verifies that two decimals are equal. If
-            they are not equals then an <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is
-            thrown.
-            </summary>
-            <param name="expected">The expected value.</param>
-            <param name="actual">The actual value.</param>
-            <param name="format">
-            The format of the message to display if the assertion fails,
-            containing zero or more format items.
-            </param>
-            <param name="args">
-            An <see cref="T:System.Object"/> array containing zero or more objects to format.
-            </param>
-            <remarks>
-            <para>
-            The error message is formatted using <see cref="M:System.String.Format(System.String,System.Object[])"/>.
-            </para>
-            </remarks>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.AreEqual(System.Decimal,System.Decimal)">
-            <summary>
-            Verifies that two decimals are equal. If
-            they are not equals then an <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is
-            thrown.
-            </summary>
-            <param name="expected">The expected value.</param>
-            <param name="actual">The actual value.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.AreEqual(System.Int32,System.Int32,System.String)">
-            <summary>
-            Verifies that two ints are equal. If
-            they are not equals then an <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is
-            thrown.
-            </summary>
-            <param name="message">The message printed out upon failure.</param>
-            <param name="expected">The expected value.</param>
-            <param name="actual">The actual value.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.AreEqual(System.Int32,System.Int32,System.String,System.Object[])">
-            <summary>
-            Verifies that two ints are equal. If
-            they are not equals then an <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is
-            thrown.
-            </summary>
-            <param name="expected">The expected value.</param>
-            <param name="actual">The actual value.</param>
-            <param name="format">
-            The format of the message to display if the assertion fails,
-            containing zero or more format items.
-            </param>
-            <param name="args">
-            An <see cref="T:System.Object"/> array containing zero or more objects to format.
-            </param>
-            <remarks>
-            <para>
-            The error message is formatted using <see cref="M:System.String.Format(System.String,System.Object[])"/>.
-            </para>
-            </remarks>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.AreEqual(System.Int32,System.Int32)">
-            <summary>
-            Verifies that two ints are equal. If
-            they are not equals then an <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is
-            thrown.
-            </summary>
-            <param name="expected">The expected value.</param>
-            <param name="actual">The actual value.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.AreEqual(System.Object,System.Object,System.String,System.Object[])">
-            <summary>
-            Verifies that two objects are equal.  Two objects are considered
-            equal if both are null, or if both have the same value.  All
-            non-numeric types are compared by using the <c>Equals</c> method.
-            If they are not equal an <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is thrown.
-            </summary>
-            <param name="expected">The value that is expected.</param>
-            <param name="actual">The actual value.</param>
-            <param name="format">
-            The format of the message to display if the assertion fails,
-            containing zero or more format items.
-            </param>
-            <param name="args">
-            An <see cref="T:System.Object"/> array containing zero or more objects to format.
-            </param>
-            <remarks>
-            <para>
-            The error message is formatted using <see cref="M:System.String.Format(System.String,System.Object[])"/>.
-            </para>
-            </remarks>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.AreEqual(System.Object,System.Object,System.String)">
-            <summary>
-            Verifies that two objects are equal.  Two objects are considered
-            equal if both are null, or if both have the same value.  All
-            non-numeric types are compared by using the <c>Equals</c> method.
-            If they are not equal an <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is thrown.
-            </summary>
-            <param name="expected">The value that is expected.</param>
-            <param name="actual">The actual value.</param>
-            <param name="message">The message to display if objects are not equal.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.AreEqual(System.Object,System.Object)">
-            <summary>
-            Verifies that two objects are equal.  Two objects are considered
-            equal if both are null, or if both have the same value.  All
-            non-numeric types are compared by using the <c>Equals</c> method.
-            If they are not equal an <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is thrown.
-            </summary>
-            <param name="expected">The value that is expected.</param>
-            <param name="actual">The actual value.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.AreValueEqual(System.Reflection.PropertyInfo,System.Object,System.Object,System.Object[])">
-            <summary>
-            Verifies that the value of the property described by <paramref name="pi"/> is the same
-            in both ojects.
-            </summary>
-            <param name="pi">
-            Property describing the value to test
-            </param>
-            <param name="expected">
-            Reference object
-            </param>
-            <param name="actual">
-            Actual object
-            </param>
-            <param name="indices">
-            Index of the property.
-            </param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.AreNotEqual(System.Object,System.Object,System.String,System.Object[])">
-            <summary>
-            Asserts that two objects are not equal. If they are equal
-            an <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is thrown.
-            </summary>
-            <param name="expected">The expected object.</param>
-            <param name="actual">The actual object.</param>
-            <param name="message">The message to be displayed when the two objects are the same object.</param>
-            <param name="args">Arguments to be used in formatting the message.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.AreNotEqual(System.Object,System.Object,System.String)">
-            <summary>
-            Asserts that two objects are not equal. If they are equal
-            an <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is thrown.
-            </summary>
-            <param name="expected">The expected object.</param>
-            <param name="actual">The actual object.</param>
-            <param name="message">The message to be displayed when the objects are the same.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.AreNotEqual(System.Object,System.Object)">
-            <summary>
-            Asserts that two objects are not equal. If they are equal
-            an <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is thrown.
-            </summary>
-            <param name="expected">The expected object.</param>
-            <param name="actual">The actual object.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.AreNotEqual(System.Int32,System.Int32,System.String,System.Object[])">
-            <summary>
-            Asserts that two ints are not equal. If they are equal
-            an <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is thrown.
-            </summary>
-            <param name="expected">The expected object.</param>
-            <param name="actual">The actual object.</param>
-            <param name="message">The message to be displayed when the two objects are the same object.</param>
-            <param name="args">Arguments to be used in formatting the message.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.AreNotEqual(System.Int32,System.Int32,System.String)">
-            <summary>
-            Asserts that two ints are not equal. If they are equal
-            an <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is thrown.
-            </summary>
-            <param name="expected">The expected object.</param>
-            <param name="actual">The actual object.</param>
-            <param name="message">The message to be displayed when the objects are the same.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.AreNotEqual(System.Int32,System.Int32)">
-            <summary>
-            Asserts that two ints are not equal. If they are equal
-            an <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is thrown.
-            </summary>
-            <param name="expected">The expected object.</param>
-            <param name="actual">The actual object.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.AreNotEqual(System.UInt32,System.UInt32,System.String,System.Object[])">
-            <summary>
-            Asserts that two uints are not equal. If they are equal
-            an <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is thrown.
-            </summary>
-            <param name="expected">The expected object.</param>
-            <param name="actual">The actual object.</param>
-            <param name="message">The message to be displayed when the two objects are the same object.</param>
-            <param name="args">Arguments to be used in formatting the message.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.AreNotEqual(System.UInt32,System.UInt32,System.String)">
-            <summary>
-            Asserts that two uints are not equal. If they are equal
-            an <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is thrown.
-            </summary>
-            <param name="expected">The expected object.</param>
-            <param name="actual">The actual object.</param>
-            <param name="message">The message to be displayed when the objects are the same.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.AreNotEqual(System.UInt32,System.UInt32)">
-            <summary>
-            Asserts that two uints are not equal. If they are equal
-            an <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is thrown.
-            </summary>
-            <param name="expected">The expected object.</param>
-            <param name="actual">The actual object.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.AreNotEqual(System.Decimal,System.Decimal,System.String,System.Object[])">
-            <summary>
-            Asserts that two decimals are not equal. If they are equal
-            an <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is thrown.
-            </summary>
-            <param name="expected">The expected object.</param>
-            <param name="actual">The actual object.</param>
-            <param name="message">The message to be displayed when the two objects are the same object.</param>
-            <param name="args">Arguments to be used in formatting the message.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.AreNotEqual(System.Decimal,System.Decimal,System.String)">
-            <summary>
-            Asserts that two decimals are not equal. If they are equal
-            an <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is thrown.
-            </summary>
-            <param name="expected">The expected object.</param>
-            <param name="actual">The actual object.</param>
-            <param name="message">The message to be displayed when the objects are the same.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.AreNotEqual(System.Decimal,System.Decimal)">
-            <summary>
-            Asserts that two decimals are not equal. If they are equal
-            an <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is thrown.
-            </summary>
-            <param name="expected">The expected object.</param>
-            <param name="actual">The actual object.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.AreNotEqual(System.Single,System.Single,System.String,System.Object[])">
-            <summary>
-            Asserts that two floats are not equal. If they are equal
-            an <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is thrown.
-            </summary>
-            <param name="expected">The expected object.</param>
-            <param name="actual">The actual object.</param>
-            <param name="message">The message to be displayed when the two objects are the same object.</param>
-            <param name="args">Arguments to be used in formatting the message.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.AreNotEqual(System.Single,System.Single,System.String)">
-            <summary>
-            Asserts that two floats are not equal. If they are equal
-            an <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is thrown.
-            </summary>
-            <param name="expected">The expected object.</param>
-            <param name="actual">The actual object.</param>
-            <param name="message">The message to be displayed when the objects are the same.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.AreNotEqual(System.Single,System.Single)">
-            <summary>
-            Asserts that two floats are not equal. If they are equal
-            an <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is thrown.
-            </summary>
-            <param name="expected">The expected object.</param>
-            <param name="actual">The actual object.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.AreNotEqual(System.Double,System.Double,System.String,System.Object[])">
-            <summary>
-            Asserts that two doubles are not equal. If they are equal
-            an <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is thrown.
-            </summary>
-            <param name="expected">The expected object.</param>
-            <param name="actual">The actual object.</param>
-            <param name="message">The message to be displayed when the two objects are the same object.</param>
-            <param name="args">Arguments to be used in formatting the message.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.AreNotEqual(System.Double,System.Double,System.String)">
-            <summary>
-            Asserts that two doubles are not equal. If they are equal
-            an <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is thrown.
-            </summary>
-            <param name="expected">The expected object.</param>
-            <param name="actual">The actual object.</param>
-            <param name="message">The message to be displayed when the objects are the same.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.AreNotEqual(System.Double,System.Double)">
-            <summary>
-            Asserts that two doubles are not equal. If they are equal
-            an <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is thrown.
-            </summary>
-            <param name="expected">The expected object.</param>
-            <param name="actual">The actual object.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.IsNotNull(System.Object,System.String,System.Object[])">
-            <summary>
-            Verifies that the object that is passed in is not equal to <code>null</code>
-            If the object is not <code>null</code> then an <see cref="T:Gallio.Framework.Assertions.AssertionException"/>
-            is thrown.
-            </summary>
-            <param name="anObject">The object that is to be tested.</param>
-            <param name="format">
-            The format of the message to display if the assertion fails,
-            containing zero or more format items.
-            </param>
-            <param name="args">
-            An <see cref="T:System.Object"/> array containing zero or more objects to format.
-            </param>
-            <remarks>
-            <para>
-            The error message is formatted using <see cref="M:System.String.Format(System.String,System.Object[])"/>.
-            </para>
-            </remarks>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.IsNotNull(System.Object,System.String)">
-            <summary>
-            Verifies that the object that is passed in is not equal to <code>null</code>
-            If the object is <code>null</code> then an <see cref="T:Gallio.Framework.Assertions.AssertionException"/>
-            is thrown with the message that is passed in.
-            </summary>
-            <param name="anObject">The object that is to be tested.</param>
-            <param name="message">The message to initialize the <see cref="T:Gallio.Framework.Assertions.AssertionException"/> with.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.IsNotNull(System.Object)">
-            <summary>
-            Verifies that the object that is passed in is not equal to <code>null</code>
-            If the object is not <code>null</code> then an <see cref="T:Gallio.Framework.Assertions.AssertionException"/>
-            is thrown.
-            </summary>
-            <param name="anObject">The object that is to be tested.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.IsNull(System.Object,System.String,System.Object[])">
-            <summary>
-            Verifies that the object that is passed in is equal to <code>null</code>
-            If the object is <code>null</code> then an <see cref="T:Gallio.Framework.Assertions.AssertionException"/>
-            is thrown.
-            </summary>
-            <param name="anObject">The object that is to be tested.</param>
-            <param name="format">
-            The format of the message to display if the assertion fails,
-            containing zero or more format items.
-            </param>
-            <param name="args">
-            An <see cref="T:System.Object"/> array containing zero or more objects to format.
-            </param>
-            <remarks>
-            <para>
-            The error message is formatted using <see cref="M:System.String.Format(System.String,System.Object[])"/>.
-            </para>
-            </remarks>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.IsNull(System.Object,System.String)">
-            <summary>
-            Verifies that the object that is passed in is equal to <code>null</code>
-            If the object is <code>null</code> then an <see cref="T:Gallio.Framework.Assertions.AssertionException"/>
-            is thrown with the message that is passed in.
-            </summary>
-            <param name="anObject">The object that is to be tested.</param>
-            <param name="message">The message to initialize the <see cref="T:Gallio.Framework.Assertions.AssertionException"/> with.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.IsNull(System.Object)">
-            <summary>
-            Verifies that the object that is passed in is equal to <code>null</code>
-            If the object is <code>null</code> then an <see cref="T:Gallio.Framework.Assertions.AssertionException"/>
-            is thrown.
-            </summary>
-            <param name="anObject">The object that is to be tested.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.AreSame(System.Object,System.Object,System.String)">
-            <summary>
-            Asserts that two objects refer to the same object. If they
-            are not the same an <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is thrown.
-            </summary>
-            <param name="message">The message to be printed when the two objects are not the same object.</param>
-            <param name="expected">The expected object.</param>
-            <param name="actual">The actual object.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.AreSame(System.Object,System.Object,System.String,System.Object[])">
-            <summary>
-            Asserts that two objects refer to the same object. If they
-            are not the same an <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is thrown.
-            </summary>
-            <param name="expected">The expected object.</param>
-            <param name="actual">The actual object.</param>
-            <param name="format">
-            The format of the message to display if the assertion fails,
-            containing zero or more format items.
-            </param>
-            <param name="args">
-            An <see cref="T:System.Object"/> array containing zero or more objects to format.
-            </param>
-            <remarks>
-            <para>
-            The error message is formatted using <see cref="M:System.String.Format(System.String,System.Object[])"/>.
-            </para>
-            </remarks>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.AreSame(System.Object,System.Object)">
-            <summary>
-            Asserts that two objects refer to the same object. If they
-            are not the same an <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is thrown.
-            </summary>
-            <param name="expected">The expected object.</param>
-            <param name="actual">The actual object.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.Fail(System.String,System.Object[])">
-            <summary>
-            Throws an <see cref="T:Gallio.Framework.Assertions.AssertionException"/> with the message that is
-            passed in. This is used by the other Assert functions.
-            </summary>
-            <param name="format">
-            The format of the message to initialize the <see cref="T:Gallio.Framework.Assertions.AssertionException"/> with.
-            </param>
-            <param name="args">
-            An <see cref="T:System.Object"/> array containing zero or more objects to format.
-            </param>
-            <remarks>
-            <para>
-            The error message is formatted using <see cref="M:System.String.Format(System.String,System.Object[])"/>.
-            </para>
-            </remarks>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.Fail(System.String)">
-            <summary>
-            Throws an <see cref="T:Gallio.Framework.Assertions.AssertionException"/> with the message that is
-            passed in. This is used by the other Assert functions.
-            </summary>
-            <param name="message">The message to initialize the <see cref="T:Gallio.Framework.Assertions.AssertionException"/> with.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.Fail">
-            <summary>
-            Throws an <see cref="T:Gallio.Framework.Assertions.AssertionException"/> with the message that is
-            passed in. This is used by the other Assert functions.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.LowerThan(System.Int32,System.Int32)">
-            <summary>
-            Verifies that <paramref name="left"/> is strictly lower than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.LowerThan(System.Int32,System.Int32,System.String)">
-            <summary>
-            Verifies that <paramref name="left"/> is strictly lower than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.LowerThan(System.Int32,System.Int32,System.String,System.Object[])">
-            <summary>
-            Verifies that <paramref name="left"/> is strictly lower than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.LowerThan(System.Int16,System.Int16)">
-            <summary>
-            Verifies that <paramref name="left"/> is strictly lower than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.LowerThan(System.Int16,System.Int16,System.String)">
-            <summary>
-            Verifies that <paramref name="left"/> is strictly lower than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.LowerThan(System.Int16,System.Int16,System.String,System.Object[])">
-            <summary>
-            Verifies that <paramref name="left"/> is strictly lower than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.LowerThan(System.Byte,System.Byte)">
-            <summary>
-            Verifies that <paramref name="left"/> is strictly lower than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.LowerThan(System.Byte,System.Byte,System.String)">
-            <summary>
-            Verifies that <paramref name="left"/> is strictly lower than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.LowerThan(System.Byte,System.Byte,System.String,System.Object[])">
-            <summary>
-            Verifies that <paramref name="left"/> is strictly lower than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.LowerThan(System.Int64,System.Int64)">
-            <summary>
-            Verifies that <paramref name="left"/> is strictly lower than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.LowerThan(System.Int64,System.Int64,System.String)">
-            <summary>
-            Verifies that <paramref name="left"/> is strictly lower than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.LowerThan(System.Int64,System.Int64,System.String,System.Object[])">
-            <summary>
-            Verifies that <paramref name="left"/> is strictly lower than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.LowerThan(System.Double,System.Double)">
-            <summary>
-            Verifies that <paramref name="left"/> is strictly lower than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.LowerThan(System.Double,System.Double,System.String)">
-            <summary>
-            Verifies that <paramref name="left"/> is strictly lower than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.LowerThan(System.Double,System.Double,System.String,System.Object[])">
-            <summary>
-            Verifies that <paramref name="left"/> is strictly lower than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.LowerThan(System.Single,System.Single)">
-            <summary>
-            Verifies that <paramref name="left"/> is strictly lower than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.LowerThan(System.Single,System.Single,System.String)">
-            <summary>
-            Verifies that <paramref name="left"/> is strictly lower than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.LowerThan(System.Single,System.Single,System.String,System.Object[])">
-            <summary>
-            Verifies that <paramref name="left"/> is strictly lower than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.LowerThan(System.IComparable,System.IComparable)">
-            <summary>
-            Verifies that <paramref name="left"/> is strictly lower than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.LowerThan(System.IComparable,System.IComparable,System.String)">
-            <summary>
-            Verifies that <paramref name="left"/> is strictly lower than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.LowerThan(System.IComparable,System.IComparable,System.String,System.Object[])">
-            <summary>
-            Verifies that <paramref name="left"/> is strictly lower than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.LowerEqualThan(System.Int32,System.Int32)">
-            <summary>
-            Verifies that <paramref name="left"/> is strictly lower than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.LowerEqualThan(System.Int32,System.Int32,System.String)">
-            <summary>
-            Verifies that <paramref name="left"/> is strictly lower than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.LowerEqualThan(System.Int32,System.Int32,System.String,System.Object[])">
-            <summary>
-            Verifies that <paramref name="left"/> is strictly lower than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.LowerEqualThan(System.Int16,System.Int16)">
-            <summary>
-            Verifies that <paramref name="left"/> is strictly lower than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.LowerEqualThan(System.Int16,System.Int16,System.String)">
-            <summary>
-            Verifies that <paramref name="left"/> is strictly lower than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.LowerEqualThan(System.Int16,System.Int16,System.String,System.Object[])">
-            <summary>
-            Verifies that <paramref name="left"/> is strictly lower than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.LowerEqualThan(System.Byte,System.Byte)">
-            <summary>
-            Verifies that <paramref name="left"/> is strictly lower than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.LowerEqualThan(System.Byte,System.Byte,System.String)">
-            <summary>
-            Verifies that <paramref name="left"/> is strictly lower than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.LowerEqualThan(System.Byte,System.Byte,System.String,System.Object[])">
-            <summary>
-            Verifies that <paramref name="left"/> is strictly lower than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.LowerEqualThan(System.Int64,System.Int64)">
-            <summary>
-            Verifies that <paramref name="left"/> is strictly lower than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.LowerEqualThan(System.Int64,System.Int64,System.String)">
-            <summary>
-            Verifies that <paramref name="left"/> is strictly lower than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.LowerEqualThan(System.Int64,System.Int64,System.String,System.Object[])">
-            <summary>
-            Verifies that <paramref name="left"/> is strictly lower than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.LowerEqualThan(System.Double,System.Double)">
-            <summary>
-            Verifies that <paramref name="left"/> is strictly lower than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.LowerEqualThan(System.Double,System.Double,System.String)">
-            <summary>
-            Verifies that <paramref name="left"/> is strictly lower than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.LowerEqualThan(System.Double,System.Double,System.String,System.Object[])">
-            <summary>
-            Verifies that <paramref name="left"/> is strictly lower than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.LowerEqualThan(System.Single,System.Single)">
-            <summary>
-            Verifies that <paramref name="left"/> is strictly lower than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.LowerEqualThan(System.Single,System.Single,System.String)">
-            <summary>
-            Verifies that <paramref name="left"/> is strictly lower than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.LowerEqualThan(System.Single,System.Single,System.String,System.Object[])">
-            <summary>
-            Verifies that <paramref name="left"/> is strictly lower than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.LowerEqualThan(System.IComparable,System.IComparable)">
-            <summary>
-            Verifies that <paramref name="left"/> is lower equal than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.LowerEqualThan(System.IComparable,System.IComparable,System.String)">
-            <summary>
-            Verifies that <paramref name="left"/> is lower equal than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.LowerEqualThan(System.IComparable,System.IComparable,System.String,System.Object[])">
-            <summary>
-            Verifies that <paramref name="left"/> is lower equal than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.Less(System.Int32,System.Int32,System.String,System.Object[])">
-            <summary>
-            Verifies that the first value is less than the second
-            value. If it is not, then an
-            <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is thrown.
-            </summary>
-            <param name="arg1">The first value, expected to be less.</param>
-            <param name="arg2">The second value, expected to be greater.</param>
-            <param name="message">The message that will be displayed on failure.</param>
-            <param name="args">Arguments to be used in formatting the message.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.Less(System.Int32,System.Int32,System.String)">
-            <summary>
-            Verifies that the first value is less than the second
-            value. If it is not, then an
-            <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is thrown.
-            </summary>
-            <param name="arg1">The first value, expected to be less.</param>
-            <param name="arg2">The second value, expected to be greater.</param>
-            <param name="message">The message that will be displayed on failure.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.Less(System.Int32,System.Int32)">
-            <summary>
-            Verifies that the first value is less than the second
-            value. If it is not, then an
-            <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is thrown.
-            </summary>
-            <param name="arg1">The first value, expected to be less.</param>
-            <param name="arg2">The second value, expected to be greater.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.Less(System.UInt32,System.UInt32,System.String,System.Object[])">
-            <summary>
-            Verifies that the first value is less than the second
-            value. If it is not, then an
-            <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is thrown.
-            </summary>
-            <param name="arg1">The first value, expected to be less.</param>
-            <param name="arg2">The second value, expected to be greater.</param>
-            <param name="message">The message that will be displayed on failure.</param>
-            <param name="args">Arguments to be used in formatting the message.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.Less(System.UInt32,System.UInt32,System.String)">
-            <summary>
-            Verifies that the first value is less than the second
-            value. If it is not, then an
-            <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is thrown.
-            </summary>
-            <param name="arg1">The first value, expected to be less.</param>
-            <param name="arg2">The second value, expected to be greater.</param>
-            <param name="message">The message that will be displayed on failure.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.Less(System.UInt32,System.UInt32)">
-            <summary>
-            Verifies that the first value is less than the second
-            value. If it is not, then an
-            <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is thrown.
-            </summary>
-            <param name="arg1">The first value, expected to be less.</param>
-            <param name="arg2">The second value, expected to be greater.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.Less(System.Decimal,System.Decimal,System.String,System.Object[])">
-            <summary>
-            Verifies that the first value is less than the second
-            value. If it is not, then an
-            <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is thrown.
-            </summary>
-            <param name="arg1">The first value, expected to be less.</param>
-            <param name="arg2">The second value, expected to be greater.</param>
-            <param name="message">The message that will be displayed on failure.</param>
-            <param name="args">Arguments to be used in formatting the message.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.Less(System.Decimal,System.Decimal,System.String)">
-            <summary>
-            Verifies that the first value is less than the second
-            value. If it is not, then an
-            <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is thrown.
-            </summary>
-            <param name="arg1">The first value, expected to be less.</param>
-            <param name="arg2">The second value, expected to be greater.</param>
-            <param name="message">The message that will be displayed on failure.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.Less(System.Decimal,System.Decimal)">
-            <summary>
-            Verifies that the first value is less than the second
-            value. If it is not, then an
-            <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is thrown.
-            </summary>
-            <param name="arg1">The first value, expected to be less.</param>
-            <param name="arg2">The second value, expected to be greater.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.Less(System.Int64,System.Int64,System.String,System.Object[])">
-            <summary>
-            Verifies that the first value is less than the second
-            value. If it is not, then an
-            <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is thrown.
-            </summary>
-            <param name="arg1">The first value, expected to be less.</param>
-            <param name="arg2">The second value, expected to be greater.</param>
-            <param name="message">The message that will be displayed on failure.</param>
-            <param name="args">Arguments to be used in formatting the message.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.Less(System.Int64,System.Int64,System.String)">
-            <summary>
-            Verifies that the first value is less than the second
-            value. If it is not, then an
-            <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is thrown.
-            </summary>
-            <param name="arg1">The first value, expected to be less.</param>
-            <param name="arg2">The second value, expected to be greater.</param>
-            <param name="message">The message that will be displayed on failure.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.Less(System.Int64,System.Int64)">
-            <summary>
-            Verifies that the first value is less than the second
-            value. If it is not, then an
-            <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is thrown.
-            </summary>
-            <param name="arg1">The first value, expected to be less.</param>
-            <param name="arg2">The second value, expected to be greater.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.Less(System.Double,System.Double,System.String,System.Object[])">
-            <summary>
-            Verifies that the first value is less than the second
-            value. If it is not, then an
-            <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is thrown.
-            </summary>
-            <param name="arg1">The first value, expected to be less.</param>
-            <param name="arg2">The second value, expected to be greater.</param>
-            <param name="message">The message that will be displayed on failure.</param>
-            <param name="args">Arguments to be used in formatting the message.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.Less(System.Double,System.Double,System.String)">
-            <summary>
-            Verifies that the first value is less than the second
-            value. If it is not, then an
-            <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is thrown.
-            </summary>
-            <param name="arg1">The first value, expected to be less.</param>
-            <param name="arg2">The second value, expected to be greater.</param>
-            <param name="message">The message that will be displayed on failure.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.Less(System.Double,System.Double)">
-            <summary>
-            Verifies that the first value is less than the second
-            value. If it is not, then an
-            <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is thrown.
-            </summary>
-            <param name="arg1">The first value, expected to be less.</param>
-            <param name="arg2">The second value, expected to be greater.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.Less(System.Single,System.Single,System.String,System.Object[])">
-            <summary>
-            Verifies that the first value is less than the second
-            value. If it is not, then an
-            <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is thrown.
-            </summary>
-            <param name="arg1">The first value, expected to be less.</param>
-            <param name="arg2">The second value, expected to be greater.</param>
-            <param name="message">The message that will be displayed on failure.</param>
-            <param name="args">Arguments to be used in formatting the message.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.Less(System.Single,System.Single,System.String)">
-            <summary>
-            Verifies that the first value is less than the second
-            value. If it is not, then an
-            <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is thrown.
-            </summary>
-            <param name="arg1">The first value, expected to be less.</param>
-            <param name="arg2">The second value, expected to be greater.</param>
-            <param name="message">The message that will be displayed on failure.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.Less(System.Single,System.Single)">
-            <summary>
-            Verifies that the first value is less than the second
-            value. If it is not, then an
-            <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is thrown.
-            </summary>
-            <param name="arg1">The first value, expected to be less.</param>
-            <param name="arg2">The second value, expected to be greater.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.Less(System.IComparable,System.IComparable,System.String,System.Object[])">
-            <summary>
-            Verifies that the first value is less than the second
-            value. If it is not, then an
-            <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is thrown.
-            </summary>
-            <param name="arg1">The first value, expected to be less.</param>
-            <param name="arg2">The second value, expected to be greater.</param>
-            <param name="message">The message that will be displayed on failure.</param>
-            <param name="args">Arguments to be used in formatting the message.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.Less(System.IComparable,System.IComparable,System.String)">
-            <summary>
-            Verifies that the first value is less than the second
-            value. If it is not, then an
-            <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is thrown.
-            </summary>
-            <param name="arg1">The first value, expected to be less.</param>
-            <param name="arg2">The second value, expected to be greater.</param>
-            <param name="message">The message that will be displayed on failure.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.Less(System.IComparable,System.IComparable)">
-            <summary>
-            Verifies that the first value is less than the second
-            value. If it is not, then an
-            <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is thrown.
-            </summary>
-            <param name="arg1">The first value, expected to be less.</param>
-            <param name="arg2">The second value, expected to be greater.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.GreaterThan(System.Int32,System.Int32)">
-            <summary>
-            Verifies that <paramref name="left"/> is strictly greater than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.GreaterThan(System.Int32,System.Int32,System.String)">
-            <summary>
-            Verifies that <paramref name="left"/> is strictly greater than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.GreaterThan(System.Int32,System.Int32,System.String,System.Object[])">
-            <summary>
-            Verifies that <paramref name="left"/> is strictly greater than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.GreaterThan(System.Int16,System.Int16)">
-            <summary>
-            Verifies that <paramref name="left"/> is strictly greater than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.GreaterThan(System.Int16,System.Int16,System.String)">
-            <summary>
-            Verifies that <paramref name="left"/> is strictly greater than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.GreaterThan(System.Int16,System.Int16,System.String,System.Object[])">
-            <summary>
-            Verifies that <paramref name="left"/> is strictly greater than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.GreaterThan(System.Byte,System.Byte)">
-            <summary>
-            Verifies that <paramref name="left"/> is strictly greater than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.GreaterThan(System.Byte,System.Byte,System.String)">
-            <summary>
-            Verifies that <paramref name="left"/> is strictly greater than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.GreaterThan(System.Byte,System.Byte,System.String,System.Object[])">
-            <summary>
-            Verifies that <paramref name="left"/> is strictly greater than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.GreaterThan(System.Int64,System.Int64)">
-            <summary>
-            Verifies that <paramref name="left"/> is strictly greater than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.GreaterThan(System.Int64,System.Int64,System.String)">
-            <summary>
-            Verifies that <paramref name="left"/> is strictly greater than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.GreaterThan(System.Int64,System.Int64,System.String,System.Object[])">
-            <summary>
-            Verifies that <paramref name="left"/> is strictly greater than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.GreaterThan(System.Double,System.Double)">
-            <summary>
-            Verifies that <paramref name="left"/> is strictly greater than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.GreaterThan(System.Double,System.Double,System.String)">
-            <summary>
-            Verifies that <paramref name="left"/> is strictly greater than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.GreaterThan(System.Double,System.Double,System.String,System.Object[])">
-            <summary>
-            Verifies that <paramref name="left"/> is strictly greater than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.GreaterThan(System.Single,System.Single)">
-            <summary>
-            Verifies that <paramref name="left"/> is strictly greater than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.GreaterThan(System.Single,System.Single,System.String)">
-            <summary>
-            Verifies that <paramref name="left"/> is strictly greater than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.GreaterThan(System.Single,System.Single,System.String,System.Object[])">
-            <summary>
-            Verifies that <paramref name="left"/> is strictly greater than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.GreaterThan(System.IComparable,System.IComparable)">
-            <summary>
-            Verifies that <paramref name="left"/> is strictly greater than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.GreaterThan(System.IComparable,System.IComparable,System.String)">
-            <summary>
-            Verifies that <paramref name="left"/> is strictly greater than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.GreaterThan(System.IComparable,System.IComparable,System.String,System.Object[])">
-            <summary>
-            Verifies that <paramref name="left"/> is strictly greater than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.Greater(System.Int32,System.Int32,System.String,System.Object[])">
-            <summary>
-            Verifies that the first value is greater than the second
-            value. If they are not, then an
-            <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is thrown.
-            </summary>
-            <param name="arg1">The first value, expected to be greater.</param>
-            <param name="arg2">The second value, expected to be less.</param>
-            <param name="message">The message that will be displayed on failure.</param>
-            <param name="args">Arguments to be used in formatting the message.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.Greater(System.Int32,System.Int32,System.String)">
-            <summary>
-            Verifies that the first value is greater than the second
-            value. If they are not, then an
-            <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is thrown.
-            </summary>
-            <param name="arg1">The first value, expected to be greater.</param>
-            <param name="arg2">The second value, expected to be less.</param>
-            <param name="message">The message that will be displayed on failure.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.Greater(System.Int32,System.Int32)">
-            <summary>
-            Verifies that the first value is greater than the second
-            value. If they are not, then an
-            <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is thrown.
-            </summary>
-            <param name="arg1">The first value, expected to be greater.</param>
-            <param name="arg2">The second value, expected to be less.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.Greater(System.UInt32,System.UInt32,System.String,System.Object[])">
-            <summary>
-            Verifies that the first value is greater than the second
-            value. If they are not, then an
-            <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is thrown.
-            </summary>
-            <param name="arg1">The first value, expected to be greater.</param>
-            <param name="arg2">The second value, expected to be less.</param>
-            <param name="message">The message that will be displayed on failure.</param>
-            <param name="args">Arguments to be used in formatting the message.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.Greater(System.UInt32,System.UInt32,System.String)">
-            <summary>
-            Verifies that the first value is greater than the second
-            value. If they are not, then an
-            <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is thrown.
-            </summary>
-            <param name="arg1">The first value, expected to be greater.</param>
-            <param name="arg2">The second value, expected to be less.</param>
-            <param name="message">The message that will be displayed on failure.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.Greater(System.UInt32,System.UInt32)">
-            <summary>
-            Verifies that the first value is greater than the second
-            value. If they are not, then an
-            <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is thrown.
-            </summary>
-            <param name="arg1">The first value, expected to be greater.</param>
-            <param name="arg2">The second value, expected to be less.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.Greater(System.Decimal,System.Decimal,System.String,System.Object[])">
-            <summary>
-            Verifies that the first value is greater than the second
-            value. If they are not, then an
-            <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is thrown.
-            </summary>
-            <param name="arg1">The first value, expected to be greater.</param>
-            <param name="arg2">The second value, expected to be less.</param>
-            <param name="message">The message that will be displayed on failure.</param>
-            <param name="args">Arguments to be used in formatting the message.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.Greater(System.Decimal,System.Decimal,System.String)">
-            <summary>
-            Verifies that the first value is greater than the second
-            value. If they are not, then an
-            <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is thrown.
-            </summary>
-            <param name="arg1">The first value, expected to be greater.</param>
-            <param name="arg2">The second value, expected to be less.</param>
-            <param name="message">The message that will be displayed on failure.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.Greater(System.Decimal,System.Decimal)">
-            <summary>
-            Verifies that the first value is greater than the second
-            value. If they are not, then an
-            <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is thrown.
-            </summary>
-            <param name="arg1">The first value, expected to be greater.</param>
-            <param name="arg2">The second value, expected to be less.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.Greater(System.Int64,System.Int64,System.String,System.Object[])">
-            <summary>
-            Verifies that the first value is greater than the second
-            value. If they are not, then an
-            <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is thrown.
-            </summary>
-            <param name="arg1">The first value, expected to be greater.</param>
-            <param name="arg2">The second value, expected to be less.</param>
-            <param name="message">The message that will be displayed on failure.</param>
-            <param name="args">Arguments to be used in formatting the message.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.Greater(System.Int64,System.Int64,System.String)">
-            <summary>
-            Verifies that the first value is greater than the second
-            value. If they are not, then an
-            <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is thrown.
-            </summary>
-            <param name="arg1">The first value, expected to be greater.</param>
-            <param name="arg2">The second value, expected to be less.</param>
-            <param name="message">The message that will be displayed on failure.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.Greater(System.Int64,System.Int64)">
-            <summary>
-            Verifies that the first value is greater than the second
-            value. If they are not, then an
-            <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is thrown.
-            </summary>
-            <param name="arg1">The first value, expected to be greater.</param>
-            <param name="arg2">The second value, expected to be less.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.Greater(System.Double,System.Double,System.String,System.Object[])">
-            <summary>
-            Verifies that the first value is greater than the second
-            value. If they are not, then an
-            <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is thrown.
-            </summary>
-            <param name="arg1">The first value, expected to be greater.</param>
-            <param name="arg2">The second value, expected to be less.</param>
-            <param name="message">The message that will be displayed on failure.</param>
-            <param name="args">Arguments to be used in formatting the message.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.Greater(System.Double,System.Double,System.String)">
-            <summary>
-            Verifies that the first value is greater than the second
-            value. If they are not, then an
-            <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is thrown.
-            </summary>
-            <param name="arg1">The first value, expected to be greater.</param>
-            <param name="arg2">The second value, expected to be less.</param>
-            <param name="message">The message that will be displayed on failure.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.Greater(System.Double,System.Double)">
-            <summary>
-            Verifies that the first value is greater than the second
-            value. If they are not, then an
-            <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is thrown.
-            </summary>
-            <param name="arg1">The first value, expected to be greater.</param>
-            <param name="arg2">The second value, expected to be less.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.Greater(System.Single,System.Single,System.String,System.Object[])">
-            <summary>
-            Verifies that the first value is greater than the second
-            value. If they are not, then an
-            <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is thrown.
-            </summary>
-            <param name="arg1">The first value, expected to be greater.</param>
-            <param name="arg2">The second value, expected to be less.</param>
-            <param name="message">The message that will be displayed on failure.</param>
-            <param name="args">Arguments to be used in formatting the message.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.Greater(System.Single,System.Single,System.String)">
-            <summary>
-            Verifies that the first value is greater than the second
-            value. If they are not, then an
-            <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is thrown.
-            </summary>
-            <param name="arg1">The first value, expected to be greater.</param>
-            <param name="arg2">The second value, expected to be less.</param>
-            <param name="message">The message that will be displayed on failure.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.Greater(System.Single,System.Single)">
-            <summary>
-            Verifies that the first value is greater than the second
-            value. If they are not, then an
-            <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is thrown.
-            </summary>
-            <param name="arg1">The first value, expected to be greater.</param>
-            <param name="arg2">The second value, expected to be less.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.Greater(System.IComparable,System.IComparable,System.String,System.Object[])">
-            <summary>
-            Verifies that the first value is greater than the second
-            value. If they are not, then an
-            <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is thrown.
-            </summary>
-            <param name="arg1">The first value, expected to be greater.</param>
-            <param name="arg2">The second value, expected to be less.</param>
-            <param name="message">The message that will be displayed on failure.</param>
-            <param name="args">Arguments to be used in formatting the message.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.Greater(System.IComparable,System.IComparable,System.String)">
-            <summary>
-            Verifies that the first value is greater than the second
-            value. If they are not, then an
-            <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is thrown.
-            </summary>
-            <param name="arg1">The first value, expected to be greater.</param>
-            <param name="arg2">The second value, expected to be less.</param>
-            <param name="message">The message that will be displayed on failure.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.Greater(System.IComparable,System.IComparable)">
-            <summary>
-            Verifies that the first value is greater than the second
-            value. If they are not, then an
-            <see cref="T:Gallio.Framework.Assertions.AssertionException"/> is thrown.
-            </summary>
-            <param name="arg1">The first value, expected to be greater.</param>
-            <param name="arg2">The second value, expected to be less.</param>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.GreaterEqualThan(System.Int32,System.Int32)">
-            <summary>
-            Verifies that <paramref name="left"/> is greater than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.GreaterEqualThan(System.Int32,System.Int32,System.String)">
-            <summary>
-            Verifies that <paramref name="left"/> is greater than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.GreaterEqualThan(System.Int32,System.Int32,System.String,System.Object[])">
-            <summary>
-            Verifies that <paramref name="left"/> is greater than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.GreaterEqualThan(System.Int16,System.Int16)">
-            <summary>
-            Verifies that <paramref name="left"/> is greater than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.GreaterEqualThan(System.Int16,System.Int16,System.String)">
-            <summary>
-            Verifies that <paramref name="left"/> is greater than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.GreaterEqualThan(System.Int16,System.Int16,System.String,System.Object[])">
-            <summary>
-            Verifies that <paramref name="left"/> is greater than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.GreaterEqualThan(System.Byte,System.Byte)">
-            <summary>
-            Verifies that <paramref name="left"/> is greater than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.GreaterEqualThan(System.Byte,System.Byte,System.String)">
-            <summary>
-            Verifies that <paramref name="left"/> is greater than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.GreaterEqualThan(System.Byte,System.Byte,System.String,System.Object[])">
-            <summary>
-            Verifies that <paramref name="left"/> is greater than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.GreaterEqualThan(System.Int64,System.Int64)">
-            <summary>
-            Verifies that <paramref name="left"/> is greater than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.GreaterEqualThan(System.Int64,System.Int64,System.String)">
-            <summary>
-            Verifies that <paramref name="left"/> is greater than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.GreaterEqualThan(System.Int64,System.Int64,System.String,System.Object[])">
-            <summary>
-            Verifies that <paramref name="left"/> is greater than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.GreaterEqualThan(System.Double,System.Double)">
-            <summary>
-            Verifies that <paramref name="left"/> is greater than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.GreaterEqualThan(System.Double,System.Double,System.String)">
-            <summary>
-            Verifies that <paramref name="left"/> is greater than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.GreaterEqualThan(System.Double,System.Double,System.String,System.Object[])">
-            <summary>
-            Verifies that <paramref name="left"/> is greater than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.GreaterEqualThan(System.Single,System.Single)">
-            <summary>
-            Verifies that <paramref name="left"/> is greater than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.GreaterEqualThan(System.Single,System.Single,System.String)">
-            <summary>
-            Verifies that <paramref name="left"/> is greater than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.GreaterEqualThan(System.Single,System.Single,System.String,System.Object[])">
-            <summary>
-            Verifies that <paramref name="left"/> is greater than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.GreaterEqualThan(System.IComparable,System.IComparable)">
-            <summary>
-            Verifies that <paramref name="left"/> is strictly greater than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.GreaterEqualThan(System.IComparable,System.IComparable,System.String)">
-            <summary>
-            Verifies that <paramref name="left"/> is strictly greater than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.GreaterEqualThan(System.IComparable,System.IComparable,System.String,System.Object[])">
-            <summary>
-            Verifies that <paramref name="left"/> is strictly greater than
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.Between(System.Int32,System.Int32,System.Int32)">
-            <summary>
-            Asserts that <paramref name="test"/> is between <paramref name="left"/> and
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.Between(System.Int32,System.Int32,System.Int32,System.String)">
-            <summary>
-            Asserts that <paramref name="test"/> is between <paramref name="left"/> and
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.Between(System.Int32,System.Int32,System.Int32,System.String,System.Object[])">
-            <summary>
-            Asserts that <paramref name="test"/> is between <paramref name="left"/> and
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.Between(System.Int16,System.Int16,System.Int16)">
-            <summary>
-            Asserts that <paramref name="test"/> is between <paramref name="left"/> and
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.Between(System.Int16,System.Int16,System.Int16,System.String)">
-            <summary>
-            Asserts that <paramref name="test"/> is between <paramref name="left"/> and
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.Between(System.Int16,System.Int16,System.Int16,System.String,System.Object[])">
-            <summary>
-            Asserts that <paramref name="test"/> is between <paramref name="left"/> and
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.Between(System.Byte,System.Byte,System.Byte)">
-            <summary>
-            Asserts that <paramref name="test"/> is between <paramref name="left"/> and
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.Between(System.Byte,System.Byte,System.Byte,System.String)">
-            <summary>
-            Asserts that <paramref name="test"/> is between <paramref name="left"/> and
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.OldAssert.Between(System.Byte,System.Byte,System.Byte,System.String,System.Object[])">
-            <summary>
-            Asserts that <paramref name="test"/> is between <paramref name="left"/> and
-            <paramref name="right"/>.
-            </summary>
-        </member>
-        <member name="M:MbUni

<TRUNCATED>
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/MbUnit.dll
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/MbUnit.dll b/lib/Gallio.3.2.750/tools/MbUnit.dll
deleted file mode 100644
index 09a5b5c..0000000
Binary files a/lib/Gallio.3.2.750/tools/MbUnit.dll and /dev/null differ


[50/51] [abbrv] [partial] Cleaning up and getting ready to development towards v4.8

Posted by sy...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/.gitattributes
----------------------------------------------------------------------
diff --git a/.gitattributes b/.gitattributes
new file mode 100644
index 0000000..412eeda
--- /dev/null
+++ b/.gitattributes
@@ -0,0 +1,22 @@
+# Auto detect text files and perform LF normalization
+* text=auto
+
+# Custom for Visual Studio
+*.cs     diff=csharp
+*.sln    merge=union
+*.csproj merge=union
+*.vbproj merge=union
+*.fsproj merge=union
+*.dbproj merge=union
+
+# Standard to msysgit
+*.doc	 diff=astextplain
+*.DOC	 diff=astextplain
+*.docx diff=astextplain
+*.DOCX diff=astextplain
+*.dot  diff=astextplain
+*.DOT  diff=astextplain
+*.pdf  diff=astextplain
+*.PDF	 diff=astextplain
+*.rtf	 diff=astextplain
+*.RTF	 diff=astextplain

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/.gitignore
----------------------------------------------------------------------
diff --git a/.gitignore b/.gitignore
index d4e145a..1e9e614 100644
--- a/.gitignore
+++ b/.gitignore
@@ -1,18 +1,33 @@
-# This is the git pattern ignore file for the project.
-# Git can be used with svn http://code.google.com/p/msysgit/
-bin
-Bin
-obj
-*.user
-*.suo
-*.bak
-*.vs10x
-*.VisualState.xml
-*.userprefs
-*.pidb
-test-results
-build/artifacts
-build/bin
-_ReSharper*
-*.orig
+# this is the git pattern ignore file for the project.
+# Git can be used with svn http://code.google.com/p/msysgit/
+bin
+Bin
+obj
+*.user
+*.suo
+*.bak
+*.vs10x
+*.VisualState.xml
+*.userprefs
+*.pidb
+test-results
+build/artifacts
+build/bin
+_ReSharper*
+*.orig
+*.cache
+src/core/Messages/
+test/core/Messages/
+src/core/QueryParser/
+test/core/QueryParser/
+src/contrib/
+test/contrib/
+src/core/obj/
+src/core/bin/
+test/core/obj/
+test/core/bin/
+bin/
+obj/
+doc/
+src/demo/
 packages/
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/ACKNOWLEDGEMENTS.txt
----------------------------------------------------------------------
diff --git a/ACKNOWLEDGEMENTS.txt b/ACKNOWLEDGEMENTS.txt
index 8b45b38..1ba84cc 100644
--- a/ACKNOWLEDGEMENTS.txt
+++ b/ACKNOWLEDGEMENTS.txt
@@ -1,3 +1,6 @@
+Contributors to this port of Lucene 4.8.0 to C# were Russell Trupiano and David Wan.
+All changes are to be submitted under the apache 2.0 license.
+
 The snowball stemmers in contrib/Snowball.Net/Snowball.Net/SF/Snowball
 were developed by Martin Porter and Richard Boulton.
 
@@ -6,5 +9,4 @@ The full snowball package is available from http://snowball.tartarus.org/
 Apache Lucene.Net is a port of Jakarta Lucene to C#.  
 The port from Java to C# of version 1.4.0, 1.4.3, 1.9, 1.9.1, 2.0 and 2.1 were done 
 primary by George Aroush. To contact George Aroush please visit http://www.aroush.net/.
-Much thanks to George
-
+Much thanks to George
\ No newline at end of file


[43/51] [abbrv] [partial] Cleaning up and getting ready to development towards v4.8

Posted by sy...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/vs2012/test/Contrib.All.Test.sln
----------------------------------------------------------------------
diff --git a/build/vs2012/test/Contrib.All.Test.sln b/build/vs2012/test/Contrib.All.Test.sln
deleted file mode 100644
index d7e30b6..0000000
--- a/build/vs2012/test/Contrib.All.Test.sln
+++ /dev/null
@@ -1,296 +0,0 @@
-
-Microsoft Visual Studio Solution File, Format Version 12.00
-# Visual Studio 2012
-#
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-#
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net", "..\..\..\src\core\Lucene.Net.csproj", "{5D4AD9BE-1FFB-41AB-9943-25737971BF57}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Core", "..\..\..\src\contrib\Core\Contrib.Core.csproj", "{FEF899EB-610C-4D3C-A556-A01F56F4AFE0}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Analyzers", "..\..\..\src\contrib\Analyzers\Contrib.Analyzers.csproj", "{4286E961-9143-4821-B46D-3D39D3736386}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.FastVectorHighlighter", "..\..\..\src\contrib\FastVectorHighlighter\Contrib.FastVectorHighlighter.csproj", "{9D2E3153-076F-49C5-B83D-FB2573536B5F}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Highlighter", "..\..\..\src\contrib\Highlighter\Contrib.Highlighter.csproj", "{901D5415-383C-4AA6-A256-879558841BEA}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Queries", "..\..\..\src\contrib\Queries\Contrib.Queries.csproj", "{481CF6E3-52AF-4621-9DEB-022122079AF6}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Snowball", "..\..\..\src\contrib\Snowball\Contrib.Snowball.csproj", "{8F9D7A92-F122-413E-9D8D-027E4ECD327C}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Spatial", "..\..\..\src\contrib\Spatial\Contrib.Spatial.csproj", "{35C347F4-24B2-4BE5-8117-A0E3001551CE}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.SpellChecker", "..\..\..\src\contrib\SpellChecker\Contrib.SpellChecker.csproj", "{FF45EE91-9CA3-443D-8231-75E9FA1AF40E}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Analyzers.Test", "..\..\..\test\contrib\Analyzers\Contrib.Analyzers.Test.csproj", "{67D27628-F1D5-4499-9818-B669731925C8}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net.Test", "..\..\..\test\core\Lucene.Net.Test.csproj", "{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Core.Test", "..\..\..\test\contrib\Core\Contrib.Core.Test.csproj", "{A065904B-1EBA-48DA-8D3D-D92A85BA41FC}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.FastVectorHighlighter.Test", "..\..\..\test\contrib\FastVectorHighlighter\Contrib.FastVectorHighlighter.Test.csproj", "{33ED01FD-A87C-4208-BA49-2586EFE32974}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Highlighter.Test", "..\..\..\test\contrib\Highlighter\Contrib.Highlighter.Test.csproj", "{31E10ECB-1385-4C06-970B-2C030FBD4893}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Queries.Test", "..\..\..\test\contrib\Queries\Contrib.Queries.Test.csproj", "{8685A826-9B7A-42C8-88F3-EEE6B41D6D81}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Snowball.Test", "..\..\..\test\contrib\Snowball\Contrib.Snowball.Test.csproj", "{992216FA-372D-4412-8D7C-E252AE042F48}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Spatial.Tests", "..\..\..\test\contrib\Spatial\Contrib.Spatial.Tests.csproj", "{19FC2A6B-4DE9-403F-8CEF-10850F57B96E}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.SpellChecker.Test", "..\..\..\test\contrib\SpellChecker\Contrib.SpellChecker.Test.csproj", "{4DCB81AA-ECC1-4B3D-A0C9-28E54F5B125C}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Demo.Common", "..\..\..\src\demo\Demo.Common\Demo.Common.csproj", "{F04CA2F4-E182-46A8-B914-F46AF5319E83}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Regex.Test", "..\..\..\test\contrib\Regex\Contrib.Regex.Test.csproj", "{F1875552-0E59-46AA-976E-6183733FD2AB}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Regex", "..\..\..\src\contrib\Regex\Contrib.Regex.csproj", "{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "SimpleFacetedSearch", "..\..\..\src\contrib\SimpleFacetedSearch\SimpleFacetedSearch.csproj", "{66772190-FB3F-48F5-8E05-0B302BACEA73}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "SimpleFacetedSearch.Test", "..\..\..\test\contrib\SimpleFacetedSearch\SimpleFacetedSearch.Test.csproj", "{D8CC9461-64E0-416E-BA6E-1DF6FA66CBF5}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Memory", "..\..\..\src\contrib\Memory\Contrib.Memory.csproj", "{112B9A7C-29CC-4539-8F5A-45669C07CD4D}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Memory.Test", "..\..\..\test\contrib\Memory\Contrib.Memory.Test.csproj", "{66C13054-FF41-4C1D-BD0D-8DA009D1DFFD}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Spatial.NTS", "..\..\..\src\contrib\Spatial\Contrib.Spatial.NTS.csproj", "{02D030D0-C7B5-4561-8BDD-41408B2E2F41}"
-EndProject
-Global
-	GlobalSection(SolutionConfigurationPlatforms) = preSolution
-		Debug|Any CPU = Debug|Any CPU
-		Debug35|Any CPU = Debug35|Any CPU
-		Release|Any CPU = Release|Any CPU
-		Release35|Any CPU = Release35|Any CPU
-	EndGlobalSection
-	GlobalSection(ProjectConfigurationPlatforms) = postSolution
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.Build.0 = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{FEF899EB-610C-4D3C-A556-A01F56F4AFE0}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{FEF899EB-610C-4D3C-A556-A01F56F4AFE0}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{FEF899EB-610C-4D3C-A556-A01F56F4AFE0}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{FEF899EB-610C-4D3C-A556-A01F56F4AFE0}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{FEF899EB-610C-4D3C-A556-A01F56F4AFE0}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{FEF899EB-610C-4D3C-A556-A01F56F4AFE0}.Release|Any CPU.Build.0 = Release|Any CPU
-		{FEF899EB-610C-4D3C-A556-A01F56F4AFE0}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{FEF899EB-610C-4D3C-A556-A01F56F4AFE0}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{4286E961-9143-4821-B46D-3D39D3736386}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{4286E961-9143-4821-B46D-3D39D3736386}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{4286E961-9143-4821-B46D-3D39D3736386}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{4286E961-9143-4821-B46D-3D39D3736386}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{4286E961-9143-4821-B46D-3D39D3736386}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{4286E961-9143-4821-B46D-3D39D3736386}.Release|Any CPU.Build.0 = Release|Any CPU
-		{4286E961-9143-4821-B46D-3D39D3736386}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{4286E961-9143-4821-B46D-3D39D3736386}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{9D2E3153-076F-49C5-B83D-FB2573536B5F}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{9D2E3153-076F-49C5-B83D-FB2573536B5F}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{9D2E3153-076F-49C5-B83D-FB2573536B5F}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{9D2E3153-076F-49C5-B83D-FB2573536B5F}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{9D2E3153-076F-49C5-B83D-FB2573536B5F}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{9D2E3153-076F-49C5-B83D-FB2573536B5F}.Release|Any CPU.Build.0 = Release|Any CPU
-		{9D2E3153-076F-49C5-B83D-FB2573536B5F}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{9D2E3153-076F-49C5-B83D-FB2573536B5F}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{901D5415-383C-4AA6-A256-879558841BEA}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{901D5415-383C-4AA6-A256-879558841BEA}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{901D5415-383C-4AA6-A256-879558841BEA}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{901D5415-383C-4AA6-A256-879558841BEA}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{901D5415-383C-4AA6-A256-879558841BEA}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{901D5415-383C-4AA6-A256-879558841BEA}.Release|Any CPU.Build.0 = Release|Any CPU
-		{901D5415-383C-4AA6-A256-879558841BEA}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{901D5415-383C-4AA6-A256-879558841BEA}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{481CF6E3-52AF-4621-9DEB-022122079AF6}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{481CF6E3-52AF-4621-9DEB-022122079AF6}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{481CF6E3-52AF-4621-9DEB-022122079AF6}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{481CF6E3-52AF-4621-9DEB-022122079AF6}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{481CF6E3-52AF-4621-9DEB-022122079AF6}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{481CF6E3-52AF-4621-9DEB-022122079AF6}.Release|Any CPU.Build.0 = Release|Any CPU
-		{481CF6E3-52AF-4621-9DEB-022122079AF6}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{481CF6E3-52AF-4621-9DEB-022122079AF6}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{8F9D7A92-F122-413E-9D8D-027E4ECD327C}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{8F9D7A92-F122-413E-9D8D-027E4ECD327C}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{8F9D7A92-F122-413E-9D8D-027E4ECD327C}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{8F9D7A92-F122-413E-9D8D-027E4ECD327C}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{8F9D7A92-F122-413E-9D8D-027E4ECD327C}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{8F9D7A92-F122-413E-9D8D-027E4ECD327C}.Release|Any CPU.Build.0 = Release|Any CPU
-		{8F9D7A92-F122-413E-9D8D-027E4ECD327C}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{8F9D7A92-F122-413E-9D8D-027E4ECD327C}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{35C347F4-24B2-4BE5-8117-A0E3001551CE}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{35C347F4-24B2-4BE5-8117-A0E3001551CE}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{35C347F4-24B2-4BE5-8117-A0E3001551CE}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{35C347F4-24B2-4BE5-8117-A0E3001551CE}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{35C347F4-24B2-4BE5-8117-A0E3001551CE}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{35C347F4-24B2-4BE5-8117-A0E3001551CE}.Release|Any CPU.Build.0 = Release|Any CPU
-		{35C347F4-24B2-4BE5-8117-A0E3001551CE}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{35C347F4-24B2-4BE5-8117-A0E3001551CE}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{FF45EE91-9CA3-443D-8231-75E9FA1AF40E}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{FF45EE91-9CA3-443D-8231-75E9FA1AF40E}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{FF45EE91-9CA3-443D-8231-75E9FA1AF40E}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{FF45EE91-9CA3-443D-8231-75E9FA1AF40E}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{FF45EE91-9CA3-443D-8231-75E9FA1AF40E}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{FF45EE91-9CA3-443D-8231-75E9FA1AF40E}.Release|Any CPU.Build.0 = Release|Any CPU
-		{FF45EE91-9CA3-443D-8231-75E9FA1AF40E}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{FF45EE91-9CA3-443D-8231-75E9FA1AF40E}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{67D27628-F1D5-4499-9818-B669731925C8}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{67D27628-F1D5-4499-9818-B669731925C8}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{67D27628-F1D5-4499-9818-B669731925C8}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{67D27628-F1D5-4499-9818-B669731925C8}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{67D27628-F1D5-4499-9818-B669731925C8}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{67D27628-F1D5-4499-9818-B669731925C8}.Release|Any CPU.Build.0 = Release|Any CPU
-		{67D27628-F1D5-4499-9818-B669731925C8}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{67D27628-F1D5-4499-9818-B669731925C8}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Release|Any CPU.Build.0 = Release|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{A065904B-1EBA-48DA-8D3D-D92A85BA41FC}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{A065904B-1EBA-48DA-8D3D-D92A85BA41FC}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{A065904B-1EBA-48DA-8D3D-D92A85BA41FC}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{A065904B-1EBA-48DA-8D3D-D92A85BA41FC}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{A065904B-1EBA-48DA-8D3D-D92A85BA41FC}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{A065904B-1EBA-48DA-8D3D-D92A85BA41FC}.Release|Any CPU.Build.0 = Release|Any CPU
-		{A065904B-1EBA-48DA-8D3D-D92A85BA41FC}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{A065904B-1EBA-48DA-8D3D-D92A85BA41FC}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{33ED01FD-A87C-4208-BA49-2586EFE32974}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{33ED01FD-A87C-4208-BA49-2586EFE32974}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{33ED01FD-A87C-4208-BA49-2586EFE32974}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{33ED01FD-A87C-4208-BA49-2586EFE32974}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{33ED01FD-A87C-4208-BA49-2586EFE32974}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{33ED01FD-A87C-4208-BA49-2586EFE32974}.Release|Any CPU.Build.0 = Release|Any CPU
-		{33ED01FD-A87C-4208-BA49-2586EFE32974}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{33ED01FD-A87C-4208-BA49-2586EFE32974}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{31E10ECB-1385-4C06-970B-2C030FBD4893}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{31E10ECB-1385-4C06-970B-2C030FBD4893}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{31E10ECB-1385-4C06-970B-2C030FBD4893}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{31E10ECB-1385-4C06-970B-2C030FBD4893}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{31E10ECB-1385-4C06-970B-2C030FBD4893}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{31E10ECB-1385-4C06-970B-2C030FBD4893}.Release|Any CPU.Build.0 = Release|Any CPU
-		{31E10ECB-1385-4C06-970B-2C030FBD4893}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{31E10ECB-1385-4C06-970B-2C030FBD4893}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{8685A826-9B7A-42C8-88F3-EEE6B41D6D81}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{8685A826-9B7A-42C8-88F3-EEE6B41D6D81}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{8685A826-9B7A-42C8-88F3-EEE6B41D6D81}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{8685A826-9B7A-42C8-88F3-EEE6B41D6D81}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{8685A826-9B7A-42C8-88F3-EEE6B41D6D81}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{8685A826-9B7A-42C8-88F3-EEE6B41D6D81}.Release|Any CPU.Build.0 = Release|Any CPU
-		{8685A826-9B7A-42C8-88F3-EEE6B41D6D81}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{8685A826-9B7A-42C8-88F3-EEE6B41D6D81}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{992216FA-372D-4412-8D7C-E252AE042F48}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{992216FA-372D-4412-8D7C-E252AE042F48}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{992216FA-372D-4412-8D7C-E252AE042F48}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{992216FA-372D-4412-8D7C-E252AE042F48}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{992216FA-372D-4412-8D7C-E252AE042F48}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{992216FA-372D-4412-8D7C-E252AE042F48}.Release|Any CPU.Build.0 = Release|Any CPU
-		{992216FA-372D-4412-8D7C-E252AE042F48}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{992216FA-372D-4412-8D7C-E252AE042F48}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{19FC2A6B-4DE9-403F-8CEF-10850F57B96E}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{19FC2A6B-4DE9-403F-8CEF-10850F57B96E}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{19FC2A6B-4DE9-403F-8CEF-10850F57B96E}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{19FC2A6B-4DE9-403F-8CEF-10850F57B96E}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{19FC2A6B-4DE9-403F-8CEF-10850F57B96E}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{19FC2A6B-4DE9-403F-8CEF-10850F57B96E}.Release|Any CPU.Build.0 = Release|Any CPU
-		{19FC2A6B-4DE9-403F-8CEF-10850F57B96E}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{19FC2A6B-4DE9-403F-8CEF-10850F57B96E}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{4DCB81AA-ECC1-4B3D-A0C9-28E54F5B125C}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{4DCB81AA-ECC1-4B3D-A0C9-28E54F5B125C}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{4DCB81AA-ECC1-4B3D-A0C9-28E54F5B125C}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{4DCB81AA-ECC1-4B3D-A0C9-28E54F5B125C}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{4DCB81AA-ECC1-4B3D-A0C9-28E54F5B125C}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{4DCB81AA-ECC1-4B3D-A0C9-28E54F5B125C}.Release|Any CPU.Build.0 = Release|Any CPU
-		{4DCB81AA-ECC1-4B3D-A0C9-28E54F5B125C}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{4DCB81AA-ECC1-4B3D-A0C9-28E54F5B125C}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Release|Any CPU.Build.0 = Release|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{F1875552-0E59-46AA-976E-6183733FD2AB}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{F1875552-0E59-46AA-976E-6183733FD2AB}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{F1875552-0E59-46AA-976E-6183733FD2AB}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{F1875552-0E59-46AA-976E-6183733FD2AB}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{F1875552-0E59-46AA-976E-6183733FD2AB}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{F1875552-0E59-46AA-976E-6183733FD2AB}.Release|Any CPU.Build.0 = Release|Any CPU
-		{F1875552-0E59-46AA-976E-6183733FD2AB}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{F1875552-0E59-46AA-976E-6183733FD2AB}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Release|Any CPU.Build.0 = Release|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Release|Any CPU.Build.0 = Release|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{D8CC9461-64E0-416E-BA6E-1DF6FA66CBF5}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{D8CC9461-64E0-416E-BA6E-1DF6FA66CBF5}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{D8CC9461-64E0-416E-BA6E-1DF6FA66CBF5}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{D8CC9461-64E0-416E-BA6E-1DF6FA66CBF5}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{D8CC9461-64E0-416E-BA6E-1DF6FA66CBF5}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{D8CC9461-64E0-416E-BA6E-1DF6FA66CBF5}.Release|Any CPU.Build.0 = Release|Any CPU
-		{D8CC9461-64E0-416E-BA6E-1DF6FA66CBF5}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{D8CC9461-64E0-416E-BA6E-1DF6FA66CBF5}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Release|Any CPU.Build.0 = Release|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{66C13054-FF41-4C1D-BD0D-8DA009D1DFFD}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{66C13054-FF41-4C1D-BD0D-8DA009D1DFFD}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{66C13054-FF41-4C1D-BD0D-8DA009D1DFFD}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{66C13054-FF41-4C1D-BD0D-8DA009D1DFFD}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{66C13054-FF41-4C1D-BD0D-8DA009D1DFFD}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{66C13054-FF41-4C1D-BD0D-8DA009D1DFFD}.Release|Any CPU.Build.0 = Release|Any CPU
-		{66C13054-FF41-4C1D-BD0D-8DA009D1DFFD}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{66C13054-FF41-4C1D-BD0D-8DA009D1DFFD}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{02D030D0-C7B5-4561-8BDD-41408B2E2F41}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{02D030D0-C7B5-4561-8BDD-41408B2E2F41}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{02D030D0-C7B5-4561-8BDD-41408B2E2F41}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{02D030D0-C7B5-4561-8BDD-41408B2E2F41}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{02D030D0-C7B5-4561-8BDD-41408B2E2F41}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{02D030D0-C7B5-4561-8BDD-41408B2E2F41}.Release|Any CPU.Build.0 = Release|Any CPU
-		{02D030D0-C7B5-4561-8BDD-41408B2E2F41}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{02D030D0-C7B5-4561-8BDD-41408B2E2F41}.Release35|Any CPU.Build.0 = Release35|Any CPU
-	EndGlobalSection
-	GlobalSection(SolutionProperties) = preSolution
-		HideSolutionNode = FALSE
-	EndGlobalSection
-EndGlobal

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/vs2012/test/Contrib.Analyzers.Test.sln
----------------------------------------------------------------------
diff --git a/build/vs2012/test/Contrib.Analyzers.Test.sln b/build/vs2012/test/Contrib.Analyzers.Test.sln
deleted file mode 100644
index 63647e9..0000000
--- a/build/vs2012/test/Contrib.Analyzers.Test.sln
+++ /dev/null
@@ -1,86 +0,0 @@
-
-Microsoft Visual Studio Solution File, Format Version 12.00
-# Visual Studio 2012
-#
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-#
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net", "..\..\..\src\core\Lucene.Net.csproj", "{5D4AD9BE-1FFB-41AB-9943-25737971BF57}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Analyzers", "..\..\..\src\contrib\Analyzers\Contrib.Analyzers.csproj", "{4286E961-9143-4821-B46D-3D39D3736386}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Analyzers.Test", "..\..\..\test\contrib\Analyzers\Contrib.Analyzers.Test.csproj", "{67D27628-F1D5-4499-9818-B669731925C8}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net.Test", "..\..\..\test\core\Lucene.Net.Test.csproj", "{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Demo.Common", "..\..\..\src\demo\Demo.Common\Demo.Common.csproj", "{F04CA2F4-E182-46A8-B914-F46AF5319E83}"
-EndProject
-Global
-	GlobalSection(SolutionConfigurationPlatforms) = preSolution
-		Debug35|Any CPU = Debug35|Any CPU
-		Debug|Any CPU = Debug|Any CPU
-		Release35|Any CPU = Release35|Any CPU
-		Release|Any CPU = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(ProjectConfigurationPlatforms) = postSolution
-		{4286E961-9143-4821-B46D-3D39D3736386}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{4286E961-9143-4821-B46D-3D39D3736386}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{4286E961-9143-4821-B46D-3D39D3736386}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{4286E961-9143-4821-B46D-3D39D3736386}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{4286E961-9143-4821-B46D-3D39D3736386}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{4286E961-9143-4821-B46D-3D39D3736386}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{4286E961-9143-4821-B46D-3D39D3736386}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{4286E961-9143-4821-B46D-3D39D3736386}.Release|Any CPU.Build.0 = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.Build.0 = Release|Any CPU
-		{67D27628-F1D5-4499-9818-B669731925C8}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{67D27628-F1D5-4499-9818-B669731925C8}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{67D27628-F1D5-4499-9818-B669731925C8}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{67D27628-F1D5-4499-9818-B669731925C8}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{67D27628-F1D5-4499-9818-B669731925C8}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{67D27628-F1D5-4499-9818-B669731925C8}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{67D27628-F1D5-4499-9818-B669731925C8}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{67D27628-F1D5-4499-9818-B669731925C8}.Release|Any CPU.Build.0 = Release|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Release|Any CPU.Build.0 = Release|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Release|Any CPU.Build.0 = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(SolutionProperties) = preSolution
-		HideSolutionNode = FALSE
-	EndGlobalSection
-EndGlobal

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/vs2012/test/Contrib.Core.Test.sln
----------------------------------------------------------------------
diff --git a/build/vs2012/test/Contrib.Core.Test.sln b/build/vs2012/test/Contrib.Core.Test.sln
deleted file mode 100644
index dde4c9f..0000000
--- a/build/vs2012/test/Contrib.Core.Test.sln
+++ /dev/null
@@ -1,66 +0,0 @@
-
-Microsoft Visual Studio Solution File, Format Version 12.00
-# Visual Studio 2012
-#
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-#
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net", "..\..\..\src\core\Lucene.Net.csproj", "{5D4AD9BE-1FFB-41AB-9943-25737971BF57}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Core", "..\..\..\src\contrib\Core\Contrib.Core.csproj", "{FEF899EB-610C-4D3C-A556-A01F56F4AFE0}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Core.Test", "..\..\..\test\contrib\Core\Contrib.Core.Test.csproj", "{A065904B-1EBA-48DA-8D3D-D92A85BA41FC}"
-EndProject
-Global
-	GlobalSection(SolutionConfigurationPlatforms) = preSolution
-		Debug35|Any CPU = Debug35|Any CPU
-		Debug|Any CPU = Debug|Any CPU
-		Release35|Any CPU = Release35|Any CPU
-		Release|Any CPU = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(ProjectConfigurationPlatforms) = postSolution
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.Build.0 = Release|Any CPU
-		{A065904B-1EBA-48DA-8D3D-D92A85BA41FC}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{A065904B-1EBA-48DA-8D3D-D92A85BA41FC}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{A065904B-1EBA-48DA-8D3D-D92A85BA41FC}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{A065904B-1EBA-48DA-8D3D-D92A85BA41FC}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{A065904B-1EBA-48DA-8D3D-D92A85BA41FC}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{A065904B-1EBA-48DA-8D3D-D92A85BA41FC}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{A065904B-1EBA-48DA-8D3D-D92A85BA41FC}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{A065904B-1EBA-48DA-8D3D-D92A85BA41FC}.Release|Any CPU.Build.0 = Release|Any CPU
-		{FEF899EB-610C-4D3C-A556-A01F56F4AFE0}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{FEF899EB-610C-4D3C-A556-A01F56F4AFE0}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{FEF899EB-610C-4D3C-A556-A01F56F4AFE0}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{FEF899EB-610C-4D3C-A556-A01F56F4AFE0}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{FEF899EB-610C-4D3C-A556-A01F56F4AFE0}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{FEF899EB-610C-4D3C-A556-A01F56F4AFE0}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{FEF899EB-610C-4D3C-A556-A01F56F4AFE0}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{FEF899EB-610C-4D3C-A556-A01F56F4AFE0}.Release|Any CPU.Build.0 = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(SolutionProperties) = preSolution
-		HideSolutionNode = FALSE
-	EndGlobalSection
-EndGlobal

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/vs2012/test/Contrib.FastVectorHighlighter.Test.sln
----------------------------------------------------------------------
diff --git a/build/vs2012/test/Contrib.FastVectorHighlighter.Test.sln b/build/vs2012/test/Contrib.FastVectorHighlighter.Test.sln
deleted file mode 100644
index 641128f..0000000
--- a/build/vs2012/test/Contrib.FastVectorHighlighter.Test.sln
+++ /dev/null
@@ -1,66 +0,0 @@
-
-Microsoft Visual Studio Solution File, Format Version 12.00
-# Visual Studio 2012
-#
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-#
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net", "..\..\..\src\core\Lucene.Net.csproj", "{5D4AD9BE-1FFB-41AB-9943-25737971BF57}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.FastVectorHighlighter", "..\..\..\src\contrib\FastVectorHighlighter\Contrib.FastVectorHighlighter.csproj", "{9D2E3153-076F-49C5-B83D-FB2573536B5F}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.FastVectorHighlighter.Test", "..\..\..\test\contrib\FastVectorHighlighter\Contrib.FastVectorHighlighter.Test.csproj", "{33ED01FD-A87C-4208-BA49-2586EFE32974}"
-EndProject
-Global
-	GlobalSection(SolutionConfigurationPlatforms) = preSolution
-		Debug35|Any CPU = Debug35|Any CPU
-		Debug|Any CPU = Debug|Any CPU
-		Release35|Any CPU = Release35|Any CPU
-		Release|Any CPU = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(ProjectConfigurationPlatforms) = postSolution
-		{33ED01FD-A87C-4208-BA49-2586EFE32974}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{33ED01FD-A87C-4208-BA49-2586EFE32974}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{33ED01FD-A87C-4208-BA49-2586EFE32974}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{33ED01FD-A87C-4208-BA49-2586EFE32974}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{33ED01FD-A87C-4208-BA49-2586EFE32974}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{33ED01FD-A87C-4208-BA49-2586EFE32974}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{33ED01FD-A87C-4208-BA49-2586EFE32974}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{33ED01FD-A87C-4208-BA49-2586EFE32974}.Release|Any CPU.Build.0 = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.Build.0 = Release|Any CPU
-		{9D2E3153-076F-49C5-B83D-FB2573536B5F}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{9D2E3153-076F-49C5-B83D-FB2573536B5F}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{9D2E3153-076F-49C5-B83D-FB2573536B5F}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{9D2E3153-076F-49C5-B83D-FB2573536B5F}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{9D2E3153-076F-49C5-B83D-FB2573536B5F}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{9D2E3153-076F-49C5-B83D-FB2573536B5F}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{9D2E3153-076F-49C5-B83D-FB2573536B5F}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{9D2E3153-076F-49C5-B83D-FB2573536B5F}.Release|Any CPU.Build.0 = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(SolutionProperties) = preSolution
-		HideSolutionNode = FALSE
-	EndGlobalSection
-EndGlobal

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/vs2012/test/Contrib.Highlighter.Test.sln
----------------------------------------------------------------------
diff --git a/build/vs2012/test/Contrib.Highlighter.Test.sln b/build/vs2012/test/Contrib.Highlighter.Test.sln
deleted file mode 100644
index a1678df..0000000
--- a/build/vs2012/test/Contrib.Highlighter.Test.sln
+++ /dev/null
@@ -1,106 +0,0 @@
-
-Microsoft Visual Studio Solution File, Format Version 12.00
-# Visual Studio 2012
-#
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-#
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net", "..\..\..\src\core\Lucene.Net.csproj", "{5D4AD9BE-1FFB-41AB-9943-25737971BF57}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Highlighter", "..\..\..\src\contrib\Highlighter\Contrib.Highlighter.csproj", "{901D5415-383C-4AA6-A256-879558841BEA}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Highlighter.Test", "..\..\..\test\contrib\Highlighter\Contrib.Highlighter.Test.csproj", "{31E10ECB-1385-4C06-970B-2C030FBD4893}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Memory", "..\..\..\src\contrib\Memory\Contrib.Memory.csproj", "{112B9A7C-29CC-4539-8F5A-45669C07CD4D}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Regex", "..\..\..\src\contrib\Regex\Contrib.Regex.csproj", "{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net.Test", "..\..\..\test\core\Lucene.Net.Test.csproj", "{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Demo.Common", "..\..\..\src\demo\Demo.Common\Demo.Common.csproj", "{F04CA2F4-E182-46A8-B914-F46AF5319E83}"
-EndProject
-Global
-	GlobalSection(SolutionConfigurationPlatforms) = preSolution
-		Debug35|Any CPU = Debug35|Any CPU
-		Debug|Any CPU = Debug|Any CPU
-		Release35|Any CPU = Release35|Any CPU
-		Release|Any CPU = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(ProjectConfigurationPlatforms) = postSolution
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Release|Any CPU.Build.0 = Release|Any CPU
-		{31E10ECB-1385-4C06-970B-2C030FBD4893}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{31E10ECB-1385-4C06-970B-2C030FBD4893}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{31E10ECB-1385-4C06-970B-2C030FBD4893}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{31E10ECB-1385-4C06-970B-2C030FBD4893}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{31E10ECB-1385-4C06-970B-2C030FBD4893}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{31E10ECB-1385-4C06-970B-2C030FBD4893}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{31E10ECB-1385-4C06-970B-2C030FBD4893}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{31E10ECB-1385-4C06-970B-2C030FBD4893}.Release|Any CPU.Build.0 = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.Build.0 = Release|Any CPU
-		{901D5415-383C-4AA6-A256-879558841BEA}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{901D5415-383C-4AA6-A256-879558841BEA}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{901D5415-383C-4AA6-A256-879558841BEA}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{901D5415-383C-4AA6-A256-879558841BEA}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{901D5415-383C-4AA6-A256-879558841BEA}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{901D5415-383C-4AA6-A256-879558841BEA}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{901D5415-383C-4AA6-A256-879558841BEA}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{901D5415-383C-4AA6-A256-879558841BEA}.Release|Any CPU.Build.0 = Release|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Release|Any CPU.Build.0 = Release|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Release|Any CPU.Build.0 = Release|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Release|Any CPU.Build.0 = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(SolutionProperties) = preSolution
-		HideSolutionNode = FALSE
-	EndGlobalSection
-EndGlobal

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/vs2012/test/Contrib.Memory.Test.sln
----------------------------------------------------------------------
diff --git a/build/vs2012/test/Contrib.Memory.Test.sln b/build/vs2012/test/Contrib.Memory.Test.sln
deleted file mode 100644
index 2e64ca3..0000000
--- a/build/vs2012/test/Contrib.Memory.Test.sln
+++ /dev/null
@@ -1,86 +0,0 @@
-
-Microsoft Visual Studio Solution File, Format Version 12.00
-# Visual Studio 2012
-#
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-#
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net", "..\..\..\src\core\Lucene.Net.csproj", "{5D4AD9BE-1FFB-41AB-9943-25737971BF57}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Memory", "..\..\..\src\contrib\Memory\Contrib.Memory.csproj", "{112B9A7C-29CC-4539-8F5A-45669C07CD4D}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Memory.Test", "..\..\..\test\contrib\Memory\Contrib.Memory.Test.csproj", "{66C13054-FF41-4C1D-BD0D-8DA009D1DFFD}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net.Test", "..\..\..\test\core\Lucene.Net.Test.csproj", "{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Demo.Common", "..\..\..\src\demo\Demo.Common\Demo.Common.csproj", "{F04CA2F4-E182-46A8-B914-F46AF5319E83}"
-EndProject
-Global
-	GlobalSection(SolutionConfigurationPlatforms) = preSolution
-		Debug35|Any CPU = Debug35|Any CPU
-		Debug|Any CPU = Debug|Any CPU
-		Release35|Any CPU = Release35|Any CPU
-		Release|Any CPU = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(ProjectConfigurationPlatforms) = postSolution
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Release|Any CPU.Build.0 = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.Build.0 = Release|Any CPU
-		{66C13054-FF41-4C1D-BD0D-8DA009D1DFFD}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{66C13054-FF41-4C1D-BD0D-8DA009D1DFFD}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{66C13054-FF41-4C1D-BD0D-8DA009D1DFFD}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{66C13054-FF41-4C1D-BD0D-8DA009D1DFFD}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{66C13054-FF41-4C1D-BD0D-8DA009D1DFFD}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{66C13054-FF41-4C1D-BD0D-8DA009D1DFFD}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{66C13054-FF41-4C1D-BD0D-8DA009D1DFFD}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{66C13054-FF41-4C1D-BD0D-8DA009D1DFFD}.Release|Any CPU.Build.0 = Release|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Release|Any CPU.Build.0 = Release|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Release|Any CPU.Build.0 = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(SolutionProperties) = preSolution
-		HideSolutionNode = FALSE
-	EndGlobalSection
-EndGlobal

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/vs2012/test/Contrib.Queries.Test.sln
----------------------------------------------------------------------
diff --git a/build/vs2012/test/Contrib.Queries.Test.sln b/build/vs2012/test/Contrib.Queries.Test.sln
deleted file mode 100644
index 19ee673..0000000
--- a/build/vs2012/test/Contrib.Queries.Test.sln
+++ /dev/null
@@ -1,86 +0,0 @@
-
-Microsoft Visual Studio Solution File, Format Version 12.00
-# Visual Studio 2012
-#
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-#
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net", "..\..\..\src\core\Lucene.Net.csproj", "{5D4AD9BE-1FFB-41AB-9943-25737971BF57}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Queries", "..\..\..\src\contrib\Queries\Contrib.Queries.csproj", "{481CF6E3-52AF-4621-9DEB-022122079AF6}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net.Test", "..\..\..\test\core\Lucene.Net.Test.csproj", "{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Queries.Test", "..\..\..\test\contrib\Queries\Contrib.Queries.Test.csproj", "{8685A826-9B7A-42C8-88F3-EEE6B41D6D81}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Demo.Common", "..\..\..\src\demo\Demo.Common\Demo.Common.csproj", "{F04CA2F4-E182-46A8-B914-F46AF5319E83}"
-EndProject
-Global
-	GlobalSection(SolutionConfigurationPlatforms) = preSolution
-		Debug35|Any CPU = Debug35|Any CPU
-		Debug|Any CPU = Debug|Any CPU
-		Release35|Any CPU = Release35|Any CPU
-		Release|Any CPU = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(ProjectConfigurationPlatforms) = postSolution
-		{481CF6E3-52AF-4621-9DEB-022122079AF6}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{481CF6E3-52AF-4621-9DEB-022122079AF6}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{481CF6E3-52AF-4621-9DEB-022122079AF6}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{481CF6E3-52AF-4621-9DEB-022122079AF6}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{481CF6E3-52AF-4621-9DEB-022122079AF6}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{481CF6E3-52AF-4621-9DEB-022122079AF6}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{481CF6E3-52AF-4621-9DEB-022122079AF6}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{481CF6E3-52AF-4621-9DEB-022122079AF6}.Release|Any CPU.Build.0 = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.Build.0 = Release|Any CPU
-		{8685A826-9B7A-42C8-88F3-EEE6B41D6D81}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{8685A826-9B7A-42C8-88F3-EEE6B41D6D81}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{8685A826-9B7A-42C8-88F3-EEE6B41D6D81}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{8685A826-9B7A-42C8-88F3-EEE6B41D6D81}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{8685A826-9B7A-42C8-88F3-EEE6B41D6D81}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{8685A826-9B7A-42C8-88F3-EEE6B41D6D81}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{8685A826-9B7A-42C8-88F3-EEE6B41D6D81}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{8685A826-9B7A-42C8-88F3-EEE6B41D6D81}.Release|Any CPU.Build.0 = Release|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Release|Any CPU.Build.0 = Release|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Release|Any CPU.Build.0 = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(SolutionProperties) = preSolution
-		HideSolutionNode = FALSE
-	EndGlobalSection
-EndGlobal

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/vs2012/test/Contrib.Regex.Test.sln
----------------------------------------------------------------------
diff --git a/build/vs2012/test/Contrib.Regex.Test.sln b/build/vs2012/test/Contrib.Regex.Test.sln
deleted file mode 100644
index b6b6739..0000000
--- a/build/vs2012/test/Contrib.Regex.Test.sln
+++ /dev/null
@@ -1,86 +0,0 @@
-
-Microsoft Visual Studio Solution File, Format Version 12.00
-# Visual Studio 2012
-#
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-#
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net", "..\..\..\src\core\Lucene.Net.csproj", "{5D4AD9BE-1FFB-41AB-9943-25737971BF57}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net.Test", "..\..\..\test\core\Lucene.Net.Test.csproj", "{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Demo.Common", "..\..\..\src\demo\Demo.Common\Demo.Common.csproj", "{F04CA2F4-E182-46A8-B914-F46AF5319E83}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Regex", "..\..\..\src\contrib\Regex\Contrib.Regex.csproj", "{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Regex.Test", "..\..\..\test\contrib\Regex\Contrib.Regex.Test.csproj", "{F1875552-0E59-46AA-976E-6183733FD2AB}"
-EndProject
-Global
-	GlobalSection(SolutionConfigurationPlatforms) = preSolution
-		Debug35|Any CPU = Debug35|Any CPU
-		Debug|Any CPU = Debug|Any CPU
-		Release35|Any CPU = Release35|Any CPU
-		Release|Any CPU = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(ProjectConfigurationPlatforms) = postSolution
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.Build.0 = Release|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Release|Any CPU.Build.0 = Release|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Release|Any CPU.Build.0 = Release|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Release|Any CPU.Build.0 = Release|Any CPU
-		{F1875552-0E59-46AA-976E-6183733FD2AB}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{F1875552-0E59-46AA-976E-6183733FD2AB}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{F1875552-0E59-46AA-976E-6183733FD2AB}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{F1875552-0E59-46AA-976E-6183733FD2AB}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{F1875552-0E59-46AA-976E-6183733FD2AB}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{F1875552-0E59-46AA-976E-6183733FD2AB}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{F1875552-0E59-46AA-976E-6183733FD2AB}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{F1875552-0E59-46AA-976E-6183733FD2AB}.Release|Any CPU.Build.0 = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(SolutionProperties) = preSolution
-		HideSolutionNode = FALSE
-	EndGlobalSection
-EndGlobal

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/vs2012/test/Contrib.SimpleFacetedSearch.Test.sln
----------------------------------------------------------------------
diff --git a/build/vs2012/test/Contrib.SimpleFacetedSearch.Test.sln b/build/vs2012/test/Contrib.SimpleFacetedSearch.Test.sln
deleted file mode 100644
index cfdbb9f..0000000
--- a/build/vs2012/test/Contrib.SimpleFacetedSearch.Test.sln
+++ /dev/null
@@ -1,110 +0,0 @@
-
-Microsoft Visual Studio Solution File, Format Version 12.00
-# Visual Studio 2012
-#
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-#
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "SimpleFacetedSearch.Test", "..\..\..\test\contrib\SimpleFacetedSearch\SimpleFacetedSearch.Test.csproj", "{D8CC9461-64E0-416E-BA6E-1DF6FA66CBF5}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "SimpleFacetedSearch", "..\..\..\src\contrib\SimpleFacetedSearch\SimpleFacetedSearch.csproj", "{66772190-FB3F-48F5-8E05-0B302BACEA73}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net", "..\..\..\src\core\Lucene.Net.csproj", "{5D4AD9BE-1FFB-41AB-9943-25737971BF57}"
-EndProject
-Global
-	GlobalSection(SolutionConfigurationPlatforms) = preSolution
-		Debug35|Any CPU = Debug35|Any CPU
-		Debug35|Mixed Platforms = Debug35|Mixed Platforms
-		Debug35|x86 = Debug35|x86
-		Debug|Any CPU = Debug|Any CPU
-		Debug|Mixed Platforms = Debug|Mixed Platforms
-		Debug|x86 = Debug|x86
-		Release35|Any CPU = Release35|Any CPU
-		Release35|Mixed Platforms = Release35|Mixed Platforms
-		Release35|x86 = Release35|x86
-		Release|Any CPU = Release|Any CPU
-		Release|Mixed Platforms = Release|Mixed Platforms
-		Release|x86 = Release|x86
-	EndGlobalSection
-	GlobalSection(ProjectConfigurationPlatforms) = postSolution
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Mixed Platforms.ActiveCfg = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Mixed Platforms.Build.0 = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|x86.ActiveCfg = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Mixed Platforms.ActiveCfg = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Mixed Platforms.Build.0 = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|x86.ActiveCfg = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.ActiveCfg = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.Build.0 = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Mixed Platforms.ActiveCfg = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Mixed Platforms.Build.0 = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|x86.ActiveCfg = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.Build.0 = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Mixed Platforms.ActiveCfg = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Mixed Platforms.Build.0 = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|x86.ActiveCfg = Release|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Debug35|Mixed Platforms.ActiveCfg = Debug35|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Debug35|Mixed Platforms.Build.0 = Debug35|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Debug35|x86.ActiveCfg = Debug35|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Debug|Mixed Platforms.ActiveCfg = Debug|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Debug|Mixed Platforms.Build.0 = Debug|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Debug|x86.ActiveCfg = Debug|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Release35|Any CPU.ActiveCfg = Release|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Release35|Any CPU.Build.0 = Release|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Release35|Mixed Platforms.ActiveCfg = Release35|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Release35|Mixed Platforms.Build.0 = Release35|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Release35|x86.ActiveCfg = Release|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Release|Any CPU.Build.0 = Release|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Release|Mixed Platforms.ActiveCfg = Release|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Release|Mixed Platforms.Build.0 = Release|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Release|x86.ActiveCfg = Release|Any CPU
-		{D8CC9461-64E0-416E-BA6E-1DF6FA66CBF5}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{D8CC9461-64E0-416E-BA6E-1DF6FA66CBF5}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{D8CC9461-64E0-416E-BA6E-1DF6FA66CBF5}.Debug35|Mixed Platforms.ActiveCfg = Debug35|Any CPU
-		{D8CC9461-64E0-416E-BA6E-1DF6FA66CBF5}.Debug35|Mixed Platforms.Build.0 = Debug35|Any CPU
-		{D8CC9461-64E0-416E-BA6E-1DF6FA66CBF5}.Debug35|x86.ActiveCfg = Debug35|Any CPU
-		{D8CC9461-64E0-416E-BA6E-1DF6FA66CBF5}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{D8CC9461-64E0-416E-BA6E-1DF6FA66CBF5}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{D8CC9461-64E0-416E-BA6E-1DF6FA66CBF5}.Debug|Mixed Platforms.ActiveCfg = Debug|Any CPU
-		{D8CC9461-64E0-416E-BA6E-1DF6FA66CBF5}.Debug|Mixed Platforms.Build.0 = Debug|Any CPU
-		{D8CC9461-64E0-416E-BA6E-1DF6FA66CBF5}.Debug|x86.ActiveCfg = Debug|Any CPU
-		{D8CC9461-64E0-416E-BA6E-1DF6FA66CBF5}.Release35|Any CPU.ActiveCfg = Release|Any CPU
-		{D8CC9461-64E0-416E-BA6E-1DF6FA66CBF5}.Release35|Any CPU.Build.0 = Release|Any CPU
-		{D8CC9461-64E0-416E-BA6E-1DF6FA66CBF5}.Release35|Mixed Platforms.ActiveCfg = Release35|Any CPU
-		{D8CC9461-64E0-416E-BA6E-1DF6FA66CBF5}.Release35|Mixed Platforms.Build.0 = Release35|Any CPU
-		{D8CC9461-64E0-416E-BA6E-1DF6FA66CBF5}.Release35|x86.ActiveCfg = Release|Any CPU
-		{D8CC9461-64E0-416E-BA6E-1DF6FA66CBF5}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{D8CC9461-64E0-416E-BA6E-1DF6FA66CBF5}.Release|Any CPU.Build.0 = Release|Any CPU
-		{D8CC9461-64E0-416E-BA6E-1DF6FA66CBF5}.Release|Mixed Platforms.ActiveCfg = Release|Any CPU
-		{D8CC9461-64E0-416E-BA6E-1DF6FA66CBF5}.Release|Mixed Platforms.Build.0 = Release|Any CPU
-		{D8CC9461-64E0-416E-BA6E-1DF6FA66CBF5}.Release|x86.ActiveCfg = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(SolutionProperties) = preSolution
-		HideSolutionNode = FALSE
-	EndGlobalSection
-EndGlobal

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/vs2012/test/Contrib.Snowball.Test.sln
----------------------------------------------------------------------
diff --git a/build/vs2012/test/Contrib.Snowball.Test.sln b/build/vs2012/test/Contrib.Snowball.Test.sln
deleted file mode 100644
index 03051a2..0000000
--- a/build/vs2012/test/Contrib.Snowball.Test.sln
+++ /dev/null
@@ -1,86 +0,0 @@
-
-Microsoft Visual Studio Solution File, Format Version 12.00
-# Visual Studio 2012
-#
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-#
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net", "..\..\..\src\core\Lucene.Net.csproj", "{5D4AD9BE-1FFB-41AB-9943-25737971BF57}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Snowball", "..\..\..\src\contrib\Snowball\Contrib.Snowball.csproj", "{8F9D7A92-F122-413E-9D8D-027E4ECD327C}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Snowball.Test", "..\..\..\test\contrib\Snowball\Contrib.Snowball.Test.csproj", "{992216FA-372D-4412-8D7C-E252AE042F48}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net.Test", "..\..\..\test\core\Lucene.Net.Test.csproj", "{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Demo.Common", "..\..\..\src\demo\Demo.Common\Demo.Common.csproj", "{F04CA2F4-E182-46A8-B914-F46AF5319E83}"
-EndProject
-Global
-	GlobalSection(SolutionConfigurationPlatforms) = preSolution
-		Debug35|Any CPU = Debug35|Any CPU
-		Debug|Any CPU = Debug|Any CPU
-		Release35|Any CPU = Release35|Any CPU
-		Release|Any CPU = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(ProjectConfigurationPlatforms) = postSolution
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.Build.0 = Release|Any CPU
-		{8F9D7A92-F122-413E-9D8D-027E4ECD327C}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{8F9D7A92-F122-413E-9D8D-027E4ECD327C}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{8F9D7A92-F122-413E-9D8D-027E4ECD327C}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{8F9D7A92-F122-413E-9D8D-027E4ECD327C}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{8F9D7A92-F122-413E-9D8D-027E4ECD327C}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{8F9D7A92-F122-413E-9D8D-027E4ECD327C}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{8F9D7A92-F122-413E-9D8D-027E4ECD327C}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{8F9D7A92-F122-413E-9D8D-027E4ECD327C}.Release|Any CPU.Build.0 = Release|Any CPU
-		{992216FA-372D-4412-8D7C-E252AE042F48}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{992216FA-372D-4412-8D7C-E252AE042F48}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{992216FA-372D-4412-8D7C-E252AE042F48}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{992216FA-372D-4412-8D7C-E252AE042F48}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{992216FA-372D-4412-8D7C-E252AE042F48}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{992216FA-372D-4412-8D7C-E252AE042F48}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{992216FA-372D-4412-8D7C-E252AE042F48}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{992216FA-372D-4412-8D7C-E252AE042F48}.Release|Any CPU.Build.0 = Release|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Release|Any CPU.Build.0 = Release|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Release|Any CPU.Build.0 = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(SolutionProperties) = preSolution
-		HideSolutionNode = FALSE
-	EndGlobalSection
-EndGlobal

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/vs2012/test/Contrib.Spatial.Test.sln
----------------------------------------------------------------------
diff --git a/build/vs2012/test/Contrib.Spatial.Test.sln b/build/vs2012/test/Contrib.Spatial.Test.sln
deleted file mode 100644
index 092ed29..0000000
--- a/build/vs2012/test/Contrib.Spatial.Test.sln
+++ /dev/null
@@ -1,76 +0,0 @@
-
-Microsoft Visual Studio Solution File, Format Version 12.00
-# Visual Studio 2012
-#
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-#
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net", "..\..\..\src\core\Lucene.Net.csproj", "{5D4AD9BE-1FFB-41AB-9943-25737971BF57}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Spatial", "..\..\..\src\contrib\Spatial\Contrib.Spatial.csproj", "{35C347F4-24B2-4BE5-8117-A0E3001551CE}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Spatial.Tests", "..\..\..\test\contrib\Spatial\Contrib.Spatial.Tests.csproj", "{19FC2A6B-4DE9-403F-8CEF-10850F57B96E}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Spatial.NTS", "..\..\..\src\contrib\Spatial\Contrib.Spatial.NTS.csproj", "{02D030D0-C7B5-4561-8BDD-41408B2E2F41}"
-EndProject
-Global
-	GlobalSection(SolutionConfigurationPlatforms) = preSolution
-		Debug35|Any CPU = Debug35|Any CPU
-		Debug|Any CPU = Debug|Any CPU
-		Release35|Any CPU = Release35|Any CPU
-		Release|Any CPU = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(ProjectConfigurationPlatforms) = postSolution
-		{02D030D0-C7B5-4561-8BDD-41408B2E2F41}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{02D030D0-C7B5-4561-8BDD-41408B2E2F41}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{02D030D0-C7B5-4561-8BDD-41408B2E2F41}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{02D030D0-C7B5-4561-8BDD-41408B2E2F41}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{02D030D0-C7B5-4561-8BDD-41408B2E2F41}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{02D030D0-C7B5-4561-8BDD-41408B2E2F41}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{02D030D0-C7B5-4561-8BDD-41408B2E2F41}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{02D030D0-C7B5-4561-8BDD-41408B2E2F41}.Release|Any CPU.Build.0 = Release|Any CPU
-		{19FC2A6B-4DE9-403F-8CEF-10850F57B96E}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{19FC2A6B-4DE9-403F-8CEF-10850F57B96E}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{19FC2A6B-4DE9-403F-8CEF-10850F57B96E}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{19FC2A6B-4DE9-403F-8CEF-10850F57B96E}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{19FC2A6B-4DE9-403F-8CEF-10850F57B96E}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{19FC2A6B-4DE9-403F-8CEF-10850F57B96E}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{19FC2A6B-4DE9-403F-8CEF-10850F57B96E}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{19FC2A6B-4DE9-403F-8CEF-10850F57B96E}.Release|Any CPU.Build.0 = Release|Any CPU
-		{35C347F4-24B2-4BE5-8117-A0E3001551CE}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{35C347F4-24B2-4BE5-8117-A0E3001551CE}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{35C347F4-24B2-4BE5-8117-A0E3001551CE}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{35C347F4-24B2-4BE5-8117-A0E3001551CE}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{35C347F4-24B2-4BE5-8117-A0E3001551CE}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{35C347F4-24B2-4BE5-8117-A0E3001551CE}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{35C347F4-24B2-4BE5-8117-A0E3001551CE}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{35C347F4-24B2-4BE5-8117-A0E3001551CE}.Release|Any CPU.Build.0 = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.Build.0 = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(SolutionProperties) = preSolution
-		HideSolutionNode = FALSE
-	EndGlobalSection
-EndGlobal

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/vs2012/test/Contrib.SpellChecker.Test.sln
----------------------------------------------------------------------
diff --git a/build/vs2012/test/Contrib.SpellChecker.Test.sln b/build/vs2012/test/Contrib.SpellChecker.Test.sln
deleted file mode 100644
index 058ded9..0000000
--- a/build/vs2012/test/Contrib.SpellChecker.Test.sln
+++ /dev/null
@@ -1,66 +0,0 @@
-
-Microsoft Visual Studio Solution File, Format Version 12.00
-# Visual Studio 2012
-#
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-#
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net", "..\..\..\src\core\Lucene.Net.csproj", "{5D4AD9BE-1FFB-41AB-9943-25737971BF57}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.SpellChecker", "..\..\..\src\contrib\SpellChecker\Contrib.SpellChecker.csproj", "{FF45EE91-9CA3-443D-8231-75E9FA1AF40E}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.SpellChecker.Test", "..\..\..\test\contrib\SpellChecker\Contrib.SpellChecker.Test.csproj", "{4DCB81AA-ECC1-4B3D-A0C9-28E54F5B125C}"
-EndProject
-Global
-	GlobalSection(SolutionConfigurationPlatforms) = preSolution
-		Debug35|Any CPU = Debug35|Any CPU
-		Debug|Any CPU = Debug|Any CPU
-		Release35|Any CPU = Release35|Any CPU
-		Release|Any CPU = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(ProjectConfigurationPlatforms) = postSolution
-		{4DCB81AA-ECC1-4B3D-A0C9-28E54F5B125C}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{4DCB81AA-ECC1-4B3D-A0C9-28E54F5B125C}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{4DCB81AA-ECC1-4B3D-A0C9-28E54F5B125C}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{4DCB81AA-ECC1-4B3D-A0C9-28E54F5B125C}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{4DCB81AA-ECC1-4B3D-A0C9-28E54F5B125C}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{4DCB81AA-ECC1-4B3D-A0C9-28E54F5B125C}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{4DCB81AA-ECC1-4B3D-A0C9-28E54F5B125C}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{4DCB81AA-ECC1-4B3D-A0C9-28E54F5B125C}.Release|Any CPU.Build.0 = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.Build.0 = Release|Any CPU
-		{FF45EE91-9CA3-443D-8231-75E9FA1AF40E}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{FF45EE91-9CA3-443D-8231-75E9FA1AF40E}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{FF45EE91-9CA3-443D-8231-75E9FA1AF40E}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{FF45EE91-9CA3-443D-8231-75E9FA1AF40E}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{FF45EE91-9CA3-443D-8231-75E9FA1AF40E}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{FF45EE91-9CA3-443D-8231-75E9FA1AF40E}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{FF45EE91-9CA3-443D-8231-75E9FA1AF40E}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{FF45EE91-9CA3-443D-8231-75E9FA1AF40E}.Release|Any CPU.Build.0 = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(SolutionProperties) = preSolution
-		HideSolutionNode = FALSE
-	EndGlobalSection
-EndGlobal


[09/51] [abbrv] [partial] Cleaning up and getting ready to development towards v4.8

Posted by sy...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/src/Lucene.Net.Codecs/BlockTerms/BlockTermsReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Codecs/BlockTerms/BlockTermsReader.cs b/src/Lucene.Net.Codecs/BlockTerms/BlockTermsReader.cs
new file mode 100644
index 0000000..1cbf8c3
--- /dev/null
+++ b/src/Lucene.Net.Codecs/BlockTerms/BlockTermsReader.cs
@@ -0,0 +1,877 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+using System;
+using Lucene.Net.Codecs;
+using Lucene.Net.Store;
+using Lucene.Net.Util;
+
+namespace Lucene.Net.Codecs.BlockTerms
+{
+    
+
+    /// <summary>
+    /// Handles a terms dict, but decouples all details of
+    /// doc/freqs/positions reading to an instance of {@link
+    /// PostingsReaderBase}.  This class is reusable for
+    /// codecs that use a different format for
+    /// docs/freqs/positions (though codecs are also free to
+    /// make their own terms dict impl).
+    ///
+    /// This class also interacts with an instance of {@link
+    /// TermsIndexReaderBase}, to abstract away the specific
+    /// implementation of the terms dict index. 
+    /// 
+    /// @lucene.experimental
+    /// </summary>
+public class BlockTermsReader : FieldsProducer {
+  // Open input to the main terms dict file (_X.tis)
+  private readonly IndexInput input;
+
+  // Reads the terms dict entries, to gather state to
+  // produce DocsEnum on demand
+  private readonly PostingsReaderBase postingsReader;
+
+  private readonly TreeMap<String,BlockTreeTermsReader.FieldReader> fields = new TreeMap<>();
+
+  // Reads the terms index
+  private TermsIndexReaderBase indexReader;
+
+  // keeps the dirStart offset
+  private long dirOffset;
+  
+  private const int version; 
+
+  // Used as key for the terms cache
+  private static class FieldAndTerm extends DoubleBarrelLRUCache.CloneableKey {
+    String field;
+    BytesRef term;
+
+    public FieldAndTerm() {
+    }
+
+    public FieldAndTerm(FieldAndTerm other) {
+      field = other.field;
+      term = BytesRef.deepCopyOf(other.term);
+    }
+
+    @Override
+    public bool equals(Object _other) {
+      FieldAndTerm other = (FieldAndTerm) _other;
+      return other.field.equals(field) && term.bytesEquals(other.term);
+    }
+
+    @Override
+    public FieldAndTerm clone() {
+      return new FieldAndTerm(this);
+    }
+
+    @Override
+    public int hashCode() {
+      return field.hashCode() * 31 + term.hashCode();
+    }
+  }
+  
+  // private String segment;
+  
+  public BlockTermsReader(TermsIndexReaderBase indexReader, Directory dir, FieldInfos fieldInfos, SegmentInfo info, PostingsReaderBase postingsReader, IOContext context,
+                          String segmentSuffix)
+     {
+    
+    this.postingsReader = postingsReader;
+
+    // this.segment = segment;
+    in = dir.openInput(IndexFileNames.segmentFileName(info.name, segmentSuffix, BlockTermsWriter.TERMS_EXTENSION),
+                       context);
+
+    bool success = false;
+    try {
+      version = readHeader(in);
+
+      // Have PostingsReader init itself
+      postingsReader.init(in);
+
+      // Read per-field details
+      seekDir(in, dirOffset);
+
+      final int numFields = in.readVInt();
+      if (numFields < 0) {
+        throw new CorruptIndexException("invalid number of fields: " + numFields + " (resource=" + in + ")");
+      }
+      for(int i=0;i<numFields;i++) {
+        final int field = in.readVInt();
+        final long numTerms = in.readVLong();
+        Debug.Assert( numTerms >= 0;
+        final long termsStartPointer = in.readVLong();
+        final FieldInfo fieldInfo = fieldInfos.fieldInfo(field);
+        final long sumTotalTermFreq = fieldInfo.getIndexOptions() == IndexOptions.DOCS_ONLY ? -1 : in.readVLong();
+        final long sumDocFreq = in.readVLong();
+        final int docCount = in.readVInt();
+        final int longsSize = version >= BlockTermsWriter.VERSION_META_ARRAY ? in.readVInt() : 0;
+        if (docCount < 0 || docCount > info.getDocCount()) { // #docs with field must be <= #docs
+          throw new CorruptIndexException("invalid docCount: " + docCount + " maxDoc: " + info.getDocCount() + " (resource=" + in + ")");
+        }
+        if (sumDocFreq < docCount) {  // #postings must be >= #docs with field
+          throw new CorruptIndexException("invalid sumDocFreq: " + sumDocFreq + " docCount: " + docCount + " (resource=" + in + ")");
+        }
+        if (sumTotalTermFreq != -1 && sumTotalTermFreq < sumDocFreq) { // #positions must be >= #postings
+          throw new CorruptIndexException("invalid sumTotalTermFreq: " + sumTotalTermFreq + " sumDocFreq: " + sumDocFreq + " (resource=" + in + ")");
+        }
+        FieldReader previous = fields.put(fieldInfo.name, new FieldReader(fieldInfo, numTerms, termsStartPointer, sumTotalTermFreq, sumDocFreq, docCount, longsSize));
+        if (previous != null) {
+          throw new CorruptIndexException("duplicate fields: " + fieldInfo.name + " (resource=" + in + ")");
+        }
+      }
+      success = true;
+    } finally {
+      if (!success) {
+        in.close();
+      }
+    }
+
+    this.indexReader = indexReader;
+  }
+
+  private int readHeader(IndexInput input)  {
+    int version = CodecUtil.checkHeader(input, BlockTermsWriter.CODEC_NAME,
+                          BlockTermsWriter.VERSION_START,
+                          BlockTermsWriter.VERSION_CURRENT);
+    if (version < BlockTermsWriter.VERSION_APPEND_ONLY) {
+      dirOffset = input.readLong();
+    }
+    return version;
+  }
+  
+  private void seekDir(IndexInput input, long dirOffset)  {
+    if (version >= BlockTermsWriter.VERSION_CHECKSUM) {
+      input.seek(input.length() - CodecUtil.footerLength() - 8);
+      dirOffset = input.readLong();
+    } else if (version >= BlockTermsWriter.VERSION_APPEND_ONLY) {
+      input.seek(input.length() - 8);
+      dirOffset = input.readLong();
+    }
+    input.seek(dirOffset);
+  }
+  
+  @Override
+  public void close()  {
+    try {
+      try {
+        if (indexReader != null) {
+          indexReader.close();
+        }
+      } finally {
+        // null so if an app hangs on to us (ie, we are not
+        // GCable, despite being closed) we still free most
+        // ram
+        indexReader = null;
+        if (in != null) {
+          in.close();
+        }
+      }
+    } finally {
+      if (postingsReader != null) {
+        postingsReader.close();
+      }
+    }
+  }
+
+  @Override
+  public Iterator<String> iterator() {
+    return Collections.unmodifiableSet(fields.keySet()).iterator();
+  }
+
+  @Override
+  public Terms terms(String field)  {
+    Debug.Assert( field != null;
+    return fields.get(field);
+  }
+
+  @Override
+  public int size() {
+    return fields.size();
+  }
+
+  private class FieldReader extends Terms {
+    final long numTerms;
+    final FieldInfo fieldInfo;
+    final long termsStartPointer;
+    final long sumTotalTermFreq;
+    final long sumDocFreq;
+    final int docCount;
+    final int longsSize;
+
+    FieldReader(FieldInfo fieldInfo, long numTerms, long termsStartPointer, long sumTotalTermFreq, long sumDocFreq, int docCount, int longsSize) {
+      Debug.Assert( numTerms > 0;
+      this.fieldInfo = fieldInfo;
+      this.numTerms = numTerms;
+      this.termsStartPointer = termsStartPointer;
+      this.sumTotalTermFreq = sumTotalTermFreq;
+      this.sumDocFreq = sumDocFreq;
+      this.docCount = docCount;
+      this.longsSize = longsSize;
+    }
+
+    @Override
+    public Comparator<BytesRef> getComparator() {
+      return BytesRef.getUTF8SortedAsUnicodeComparator();
+    }
+
+    @Override
+    public TermsEnum iterator(TermsEnum reuse)  {
+      return new SegmentTermsEnum();
+    }
+
+    @Override
+    public bool hasFreqs() {
+      return fieldInfo.getIndexOptions().compareTo(IndexOptions.DOCS_AND_FREQS) >= 0;
+    }
+
+    @Override
+    public bool hasOffsets() {
+      return fieldInfo.getIndexOptions().compareTo(IndexOptions.DOCS_AND_FREQS_AND_POSITIONS_AND_OFFSETS) >= 0;
+    }
+
+    @Override
+    public bool hasPositions() {
+      return fieldInfo.getIndexOptions().compareTo(IndexOptions.DOCS_AND_FREQS_AND_POSITIONS) >= 0;
+    }
+    
+    @Override
+    public bool hasPayloads() {
+      return fieldInfo.hasPayloads();
+    }
+
+    @Override
+    public long size() {
+      return numTerms;
+    }
+
+    @Override
+    public long getSumTotalTermFreq() {
+      return sumTotalTermFreq;
+    }
+
+    @Override
+    public long getSumDocFreq()  {
+      return sumDocFreq;
+    }
+
+    @Override
+    public int getDocCount()  {
+      return docCount;
+    }
+
+    // Iterates through terms in this field
+    private final class SegmentTermsEnum extends TermsEnum {
+      private final IndexInput in;
+      private final BlockTermState state;
+      private final bool doOrd;
+      private final FieldAndTerm fieldTerm = new FieldAndTerm();
+      private final TermsIndexReaderBase.FieldIndexEnum indexEnum;
+      private final BytesRef term = new BytesRef();
+
+      /* This is true if indexEnum is "still" seek'd to the index term
+         for the current term. We set it to true on seeking, and then it
+         remains valid until next() is called enough times to load another
+         terms block: */
+      private bool indexIsCurrent;
+
+      /* True if we've already called .next() on the indexEnum, to "bracket"
+         the current block of terms: */
+      private bool didIndexNext;
+
+      /* Next index term, bracketing the current block of terms; this is
+         only valid if didIndexNext is true: */
+      private BytesRef nextIndexTerm;
+
+      /* True after seekExact(TermState), do defer seeking.  If the app then
+         calls next() (which is not "typical"), then we'll do the real seek */
+      private bool seekPending;
+
+      /* How many blocks we've read since last seek.  Once this
+         is >= indexEnum.getDivisor() we set indexIsCurrent to false (since
+         the index can no long bracket seek-within-block). */
+      private int blocksSinceSeek;
+
+      private byte[] termSuffixes;
+      private ByteArrayDataInput termSuffixesReader = new ByteArrayDataInput();
+
+      /* Common prefix used for all terms in this block. */
+      private int termBlockPrefix;
+
+      /* How many terms in current block */
+      private int blockTermCount;
+
+      private byte[] docFreqBytes;
+      private final ByteArrayDataInput freqReader = new ByteArrayDataInput();
+      private int metaDataUpto;
+
+      private long[] longs;
+      private byte[] bytes;
+      private ByteArrayDataInput bytesReader;
+
+      public SegmentTermsEnum()  {
+        in = BlockTermsReader.this.in.clone();
+        in.seek(termsStartPointer);
+        indexEnum = indexReader.getFieldEnum(fieldInfo);
+        doOrd = indexReader.supportsOrd();
+        fieldTerm.field = fieldInfo.name;
+        state = postingsReader.newTermState();
+        state.totalTermFreq = -1;
+        state.ord = -1;
+
+        termSuffixes = new byte[128];
+        docFreqBytes = new byte[64];
+        //System.out.println("BTR.enum init this=" + this + " postingsReader=" + postingsReader);
+        longs = new long[longsSize];
+      }
+
+      @Override
+      public Comparator<BytesRef> getComparator() {
+        return BytesRef.getUTF8SortedAsUnicodeComparator();
+      }
+
+      // TODO: we may want an alternate mode here which is
+      // "if you are about to return NOT_FOUND I won't use
+      // the terms data from that"; eg FuzzyTermsEnum will
+      // (usually) just immediately call seek again if we
+      // return NOT_FOUND so it's a waste for us to fill in
+      // the term that was actually NOT_FOUND
+      @Override
+      public SeekStatus seekCeil(final BytesRef target)  {
+
+        if (indexEnum == null) {
+          throw new IllegalStateException("terms index was not loaded");
+        }
+   
+        //System.out.println("BTR.seek seg=" + segment + " target=" + fieldInfo.name + ":" + target.utf8ToString() + " " + target + " current=" + term().utf8ToString() + " " + term() + " indexIsCurrent=" + indexIsCurrent + " didIndexNext=" + didIndexNext + " seekPending=" + seekPending + " divisor=" + indexReader.getDivisor() + " this="  + this);
+        if (didIndexNext) {
+          if (nextIndexTerm == null) {
+            //System.out.println("  nextIndexTerm=null");
+          } else {
+            //System.out.println("  nextIndexTerm=" + nextIndexTerm.utf8ToString());
+          }
+        }
+
+        bool doSeek = true;
+
+        // See if we can avoid seeking, because target term
+        // is after current term but before next index term:
+        if (indexIsCurrent) {
+
+          final int cmp = BytesRef.getUTF8SortedAsUnicodeComparator().compare(term, target);
+
+          if (cmp == 0) {
+            // Already at the requested term
+            return SeekStatus.FOUND;
+          } else if (cmp < 0) {
+
+            // Target term is after current term
+            if (!didIndexNext) {
+              if (indexEnum.next() == -1) {
+                nextIndexTerm = null;
+              } else {
+                nextIndexTerm = indexEnum.term();
+              }
+              //System.out.println("  now do index next() nextIndexTerm=" + (nextIndexTerm == null ? "null" : nextIndexTerm.utf8ToString()));
+              didIndexNext = true;
+            }
+
+            if (nextIndexTerm == null || BytesRef.getUTF8SortedAsUnicodeComparator().compare(target, nextIndexTerm) < 0) {
+              // Optimization: requested term is within the
+              // same term block we are now in; skip seeking
+              // (but do scanning):
+              doSeek = false;
+              //System.out.println("  skip seek: nextIndexTerm=" + (nextIndexTerm == null ? "null" : nextIndexTerm.utf8ToString()));
+            }
+          }
+        }
+
+        if (doSeek) {
+          //System.out.println("  seek");
+
+          // Ask terms index to find biggest indexed term (=
+          // first term in a block) that's <= our text:
+          in.seek(indexEnum.seek(target));
+          bool result = nextBlock();
+
+          // Block must exist since, at least, the indexed term
+          // is in the block:
+          Debug.Assert( result;
+
+          indexIsCurrent = true;
+          didIndexNext = false;
+          blocksSinceSeek = 0;          
+
+          if (doOrd) {
+            state.ord = indexEnum.ord()-1;
+          }
+
+          term.copyBytes(indexEnum.term());
+          //System.out.println("  seek: term=" + term.utf8ToString());
+        } else {
+          //System.out.println("  skip seek");
+          if (state.termBlockOrd == blockTermCount && !nextBlock()) {
+            indexIsCurrent = false;
+            return SeekStatus.END;
+          }
+        }
+
+        seekPending = false;
+
+        int common = 0;
+
+        // Scan within block.  We could do this by calling
+        // _next() and testing the resulting term, but this
+        // is wasteful.  Instead, we first confirm the
+        // target matches the common prefix of this block,
+        // and then we scan the term bytes directly from the
+        // termSuffixesreader's byte[], saving a copy into
+        // the BytesRef term per term.  Only when we return
+        // do we then copy the bytes into the term.
+
+        while(true) {
+
+          // First, see if target term matches common prefix
+          // in this block:
+          if (common < termBlockPrefix) {
+            final int cmp = (term.bytes[common]&0xFF) - (target.bytes[target.offset + common]&0xFF);
+            if (cmp < 0) {
+
+              // TODO: maybe we should store common prefix
+              // in block header?  (instead of relying on
+              // last term of previous block)
+
+              // Target's prefix is after the common block
+              // prefix, so term cannot be in this block
+              // but it could be in next block.  We
+              // must scan to end-of-block to set common
+              // prefix for next block:
+              if (state.termBlockOrd < blockTermCount) {
+                while(state.termBlockOrd < blockTermCount-1) {
+                  state.termBlockOrd++;
+                  state.ord++;
+                  termSuffixesReader.skipBytes(termSuffixesReader.readVInt());
+                }
+                final int suffix = termSuffixesReader.readVInt();
+                term.length = termBlockPrefix + suffix;
+                if (term.bytes.length < term.length) {
+                  term.grow(term.length);
+                }
+                termSuffixesReader.readBytes(term.bytes, termBlockPrefix, suffix);
+              }
+              state.ord++;
+              
+              if (!nextBlock()) {
+                indexIsCurrent = false;
+                return SeekStatus.END;
+              }
+              common = 0;
+
+            } else if (cmp > 0) {
+              // Target's prefix is before the common prefix
+              // of this block, so we position to start of
+              // block and return NOT_FOUND:
+              Debug.Assert( state.termBlockOrd == 0;
+
+              final int suffix = termSuffixesReader.readVInt();
+              term.length = termBlockPrefix + suffix;
+              if (term.bytes.length < term.length) {
+                term.grow(term.length);
+              }
+              termSuffixesReader.readBytes(term.bytes, termBlockPrefix, suffix);
+              return SeekStatus.NOT_FOUND;
+            } else {
+              common++;
+            }
+
+            continue;
+          }
+
+          // Test every term in this block
+          while (true) {
+            state.termBlockOrd++;
+            state.ord++;
+
+            final int suffix = termSuffixesReader.readVInt();
+            
+            // We know the prefix matches, so just compare the new suffix:
+            final int termLen = termBlockPrefix + suffix;
+            int bytePos = termSuffixesReader.getPosition();
+
+            bool next = false;
+            final int limit = target.offset + (termLen < target.length ? termLen : target.length);
+            int targetPos = target.offset + termBlockPrefix;
+            while(targetPos < limit) {
+              final int cmp = (termSuffixes[bytePos++]&0xFF) - (target.bytes[targetPos++]&0xFF);
+              if (cmp < 0) {
+                // Current term is still before the target;
+                // keep scanning
+                next = true;
+                break;
+              } else if (cmp > 0) {
+                // Done!  Current term is after target. Stop
+                // here, fill in real term, return NOT_FOUND.
+                term.length = termBlockPrefix + suffix;
+                if (term.bytes.length < term.length) {
+                  term.grow(term.length);
+                }
+                termSuffixesReader.readBytes(term.bytes, termBlockPrefix, suffix);
+                //System.out.println("  NOT_FOUND");
+                return SeekStatus.NOT_FOUND;
+              }
+            }
+
+            if (!next && target.length <= termLen) {
+              term.length = termBlockPrefix + suffix;
+              if (term.bytes.length < term.length) {
+                term.grow(term.length);
+              }
+              termSuffixesReader.readBytes(term.bytes, termBlockPrefix, suffix);
+
+              if (target.length == termLen) {
+                // Done!  Exact match.  Stop here, fill in
+                // real term, return FOUND.
+                //System.out.println("  FOUND");
+                return SeekStatus.FOUND;
+              } else {
+                //System.out.println("  NOT_FOUND");
+                return SeekStatus.NOT_FOUND;
+              }
+            }
+
+            if (state.termBlockOrd == blockTermCount) {
+              // Must pre-fill term for next block's common prefix
+              term.length = termBlockPrefix + suffix;
+              if (term.bytes.length < term.length) {
+                term.grow(term.length);
+              }
+              termSuffixesReader.readBytes(term.bytes, termBlockPrefix, suffix);
+              break;
+            } else {
+              termSuffixesReader.skipBytes(suffix);
+            }
+          }
+
+          // The purpose of the terms dict index is to seek
+          // the enum to the closest index term before the
+          // term we are looking for.  So, we should never
+          // cross another index term (besides the first
+          // one) while we are scanning:
+
+          Debug.Assert( indexIsCurrent;
+
+          if (!nextBlock()) {
+            //System.out.println("  END");
+            indexIsCurrent = false;
+            return SeekStatus.END;
+          }
+          common = 0;
+        }
+      }
+
+      @Override
+      public BytesRef next()  {
+        //System.out.println("BTR.next() seekPending=" + seekPending + " pendingSeekCount=" + state.termBlockOrd);
+
+        // If seek was previously called and the term was cached,
+        // usually caller is just going to pull a D/&PEnum or get
+        // docFreq, etc.  But, if they then call next(),
+        // this method catches up all internal state so next()
+        // works properly:
+        if (seekPending) {
+          Debug.Assert( !indexIsCurrent;
+          in.seek(state.blockFilePointer);
+          final int pendingSeekCount = state.termBlockOrd;
+          bool result = nextBlock();
+
+          final long savOrd = state.ord;
+
+          // Block must exist since seek(TermState) was called w/ a
+          // TermState previously returned by this enum when positioned
+          // on a real term:
+          Debug.Assert( result;
+
+          while(state.termBlockOrd < pendingSeekCount) {
+            BytesRef nextResult = _next();
+            Debug.Assert( nextResult != null;
+          }
+          seekPending = false;
+          state.ord = savOrd;
+        }
+        return _next();
+      }
+
+      /* Decodes only the term bytes of the next term.  If caller then asks for
+         metadata, ie docFreq, totalTermFreq or pulls a D/&PEnum, we then (lazily)
+         decode all metadata up to the current term. */
+      private BytesRef _next()  {
+        //System.out.println("BTR._next seg=" + segment + " this=" + this + " termCount=" + state.termBlockOrd + " (vs " + blockTermCount + ")");
+        if (state.termBlockOrd == blockTermCount && !nextBlock()) {
+          //System.out.println("  eof");
+          indexIsCurrent = false;
+          return null;
+        }
+
+        // TODO: cutover to something better for these ints!  simple64?
+        final int suffix = termSuffixesReader.readVInt();
+        //System.out.println("  suffix=" + suffix);
+
+        term.length = termBlockPrefix + suffix;
+        if (term.bytes.length < term.length) {
+          term.grow(term.length);
+        }
+        termSuffixesReader.readBytes(term.bytes, termBlockPrefix, suffix);
+        state.termBlockOrd++;
+
+        // NOTE: meaningless in the non-ord case
+        state.ord++;
+
+        //System.out.println("  return term=" + fieldInfo.name + ":" + term.utf8ToString() + " " + term + " tbOrd=" + state.termBlockOrd);
+        return term;
+      }
+
+      @Override
+      public BytesRef term() {
+        return term;
+      }
+
+      @Override
+      public int docFreq()  {
+        //System.out.println("BTR.docFreq");
+        decodeMetaData();
+        //System.out.println("  return " + state.docFreq);
+        return state.docFreq;
+      }
+
+      @Override
+      public long totalTermFreq()  {
+        decodeMetaData();
+        return state.totalTermFreq;
+      }
+
+      @Override
+      public DocsEnum docs(Bits liveDocs, DocsEnum reuse, int flags)  {
+        //System.out.println("BTR.docs this=" + this);
+        decodeMetaData();
+        //System.out.println("BTR.docs:  state.docFreq=" + state.docFreq);
+        return postingsReader.docs(fieldInfo, state, liveDocs, reuse, flags);
+      }
+
+      @Override
+      public DocsAndPositionsEnum docsAndPositions(Bits liveDocs, DocsAndPositionsEnum reuse, int flags)  {
+        if (fieldInfo.getIndexOptions().compareTo(IndexOptions.DOCS_AND_FREQS_AND_POSITIONS) < 0) {
+          // Positions were not indexed:
+          return null;
+        }
+
+        decodeMetaData();
+        return postingsReader.docsAndPositions(fieldInfo, state, liveDocs, reuse, flags);
+      }
+
+      @Override
+      public void seekExact(BytesRef target, TermState otherState) {
+        //System.out.println("BTR.seekExact termState target=" + target.utf8ToString() + " " + target + " this=" + this);
+        Debug.Assert( otherState != null && otherState instanceof BlockTermState;
+        Debug.Assert( !doOrd || ((BlockTermState) otherState).ord < numTerms;
+        state.copyFrom(otherState);
+        seekPending = true;
+        indexIsCurrent = false;
+        term.copyBytes(target);
+      }
+      
+      @Override
+      public TermState termState()  {
+        //System.out.println("BTR.termState this=" + this);
+        decodeMetaData();
+        TermState ts = state.clone();
+        //System.out.println("  return ts=" + ts);
+        return ts;
+      }
+
+      @Override
+      public void seekExact(long ord)  {
+        //System.out.println("BTR.seek by ord ord=" + ord);
+        if (indexEnum == null) {
+          throw new IllegalStateException("terms index was not loaded");
+        }
+
+        Debug.Assert( ord < numTerms;
+
+        // TODO: if ord is in same terms block and
+        // after current ord, we should avoid this seek just
+        // like we do in the seek(BytesRef) case
+        in.seek(indexEnum.seek(ord));
+        bool result = nextBlock();
+
+        // Block must exist since ord < numTerms:
+        Debug.Assert( result;
+
+        indexIsCurrent = true;
+        didIndexNext = false;
+        blocksSinceSeek = 0;
+        seekPending = false;
+
+        state.ord = indexEnum.ord()-1;
+        Debug.Assert( state.ord >= -1: "ord=" + state.ord;
+        term.copyBytes(indexEnum.term());
+
+        // Now, scan:
+        int left = (int) (ord - state.ord);
+        while(left > 0) {
+          final BytesRef term = _next();
+          Debug.Assert( term != null;
+          left--;
+          Debug.Assert( indexIsCurrent;
+        }
+      }
+
+      @Override
+      public long ord() {
+        if (!doOrd) {
+          throw new UnsupportedOperationException();
+        }
+        return state.ord;
+      }
+
+      /* Does initial decode of next block of terms; this
+         doesn't actually decode the docFreq, totalTermFreq,
+         postings details (frq/prx offset, etc.) metadata;
+         it just loads them as byte[] blobs which are then      
+         decoded on-demand if the metadata is ever requested
+         for any term in this block.  This enables terms-only
+         intensive consumes (eg certain MTQs, respelling) to
+         not pay the price of decoding metadata they won't
+         use. */
+      private bool nextBlock()  {
+
+        // TODO: we still lazy-decode the byte[] for each
+        // term (the suffix), but, if we decoded
+        // all N terms up front then seeking could do a fast
+        // bsearch w/in the block...
+
+        //System.out.println("BTR.nextBlock() fp=" + in.getFilePointer() + " this=" + this);
+        state.blockFilePointer = in.getFilePointer();
+        blockTermCount = in.readVInt();
+        //System.out.println("  blockTermCount=" + blockTermCount);
+        if (blockTermCount == 0) {
+          return false;
+        }
+        termBlockPrefix = in.readVInt();
+
+        // term suffixes:
+        int len = in.readVInt();
+        if (termSuffixes.length < len) {
+          termSuffixes = new byte[ArrayUtil.oversize(len, 1)];
+        }
+        //System.out.println("  termSuffixes len=" + len);
+        in.readBytes(termSuffixes, 0, len);
+        termSuffixesReader.reset(termSuffixes, 0, len);
+
+        // docFreq, totalTermFreq
+        len = in.readVInt();
+        if (docFreqBytes.length < len) {
+          docFreqBytes = new byte[ArrayUtil.oversize(len, 1)];
+        }
+        //System.out.println("  freq bytes len=" + len);
+        in.readBytes(docFreqBytes, 0, len);
+        freqReader.reset(docFreqBytes, 0, len);
+
+        // metadata
+        len = in.readVInt();
+        if (bytes == null) {
+          bytes = new byte[ArrayUtil.oversize(len, 1)];
+          bytesReader = new ByteArrayDataInput();
+        } else if (bytes.length < len) {
+          bytes = new byte[ArrayUtil.oversize(len, 1)];
+        }
+        in.readBytes(bytes, 0, len);
+        bytesReader.reset(bytes, 0, len);
+
+        metaDataUpto = 0;
+        state.termBlockOrd = 0;
+
+        blocksSinceSeek++;
+        indexIsCurrent = indexIsCurrent && (blocksSinceSeek < indexReader.getDivisor());
+        //System.out.println("  indexIsCurrent=" + indexIsCurrent);
+
+        return true;
+      }
+     
+      private void decodeMetaData()  {
+        //System.out.println("BTR.decodeMetadata mdUpto=" + metaDataUpto + " vs termCount=" + state.termBlockOrd + " state=" + state);
+        if (!seekPending) {
+          // TODO: cutover to random-access API
+          // here.... really stupid that we have to decode N
+          // wasted term metadata just to get to the N+1th
+          // that we really need...
+
+          // lazily catch up on metadata decode:
+          final int limit = state.termBlockOrd;
+          bool absolute = metaDataUpto == 0;
+          // TODO: better API would be "jump straight to term=N"???
+          while (metaDataUpto < limit) {
+            //System.out.println("  decode mdUpto=" + metaDataUpto);
+            // TODO: we could make "tiers" of metadata, ie,
+            // decode docFreq/totalTF but don't decode postings
+            // metadata; this way caller could get
+            // docFreq/totalTF w/o paying decode cost for
+            // postings
+
+            // TODO: if docFreq were bulk decoded we could
+            // just skipN here:
+
+            // docFreq, totalTermFreq
+            state.docFreq = freqReader.readVInt();
+            //System.out.println("    dF=" + state.docFreq);
+            if (fieldInfo.getIndexOptions() != IndexOptions.DOCS_ONLY) {
+              state.totalTermFreq = state.docFreq + freqReader.readVLong();
+              //System.out.println("    totTF=" + state.totalTermFreq);
+            }
+            // metadata
+            for (int i = 0; i < longs.length; i++) {
+              longs[i] = bytesReader.readVLong();
+            }
+            postingsReader.decodeTerm(longs, bytesReader, fieldInfo, state, absolute);
+            metaDataUpto++;
+            absolute = false;
+          }
+        } else {
+          //System.out.println("  skip! seekPending");
+        }
+      }
+    }
+  }
+
+  @Override
+  public long ramBytesUsed() {
+    long sizeInBytes = (postingsReader!=null) ? postingsReader.ramBytesUsed() : 0;
+    sizeInBytes += (indexReader!=null) ? indexReader.ramBytesUsed() : 0;
+    return sizeInBytes;
+  }
+
+  @Override
+  public void checkIntegrity()  {   
+    // verify terms
+    if (version >= BlockTermsWriter.VERSION_CHECKSUM) {
+      CodecUtil.checksumEntireFile(in);
+    }
+    // verify postings
+    postingsReader.checkIntegrity();
+  }
+}

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/src/Lucene.Net.Codecs/BlockTerms/BlockTermsWriter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Codecs/BlockTerms/BlockTermsWriter.cs b/src/Lucene.Net.Codecs/BlockTerms/BlockTermsWriter.cs
new file mode 100644
index 0000000..3c20376
--- /dev/null
+++ b/src/Lucene.Net.Codecs/BlockTerms/BlockTermsWriter.cs
@@ -0,0 +1,346 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+namespace Lucene.Net.Codecs.BlockTerms
+{
+    
+}
+
+// TODO: currently we encode all terms between two indexed
+// terms as a block; but, we could decouple the two, ie
+// allow several blocks in between two indexed terms
+
+/**
+ * Writes terms dict, block-encoding (column stride) each
+ * term's metadata for each set of terms between two
+ * index terms.
+ *
+ * @lucene.experimental
+ */
+
+public class BlockTermsWriter extends FieldsConsumer {
+
+  final static String CODEC_NAME = "BLOCK_TERMS_DICT";
+
+  // Initial format
+  public static final int VERSION_START = 0;
+  public static final int VERSION_APPEND_ONLY = 1;
+  public static final int VERSION_META_ARRAY = 2;
+  public static final int VERSION_CHECKSUM = 3;
+  public static final int VERSION_CURRENT = VERSION_CHECKSUM;
+
+  /** Extension of terms file */
+  static final String TERMS_EXTENSION = "tib";
+
+  protected IndexOutput out;
+  final PostingsWriterBase postingsWriter;
+  final FieldInfos fieldInfos;
+  FieldInfo currentField;
+  private final TermsIndexWriterBase termsIndexWriter;
+
+  private static class FieldMetaData {
+    public final FieldInfo fieldInfo;
+    public final long numTerms;
+    public final long termsStartPointer;
+    public final long sumTotalTermFreq;
+    public final long sumDocFreq;
+    public final int docCount;
+    public final int longsSize;
+
+    public FieldMetaData(FieldInfo fieldInfo, long numTerms, long termsStartPointer, long sumTotalTermFreq, long sumDocFreq, int docCount, int longsSize) {
+      Debug.Assert( numTerms > 0;
+      this.fieldInfo = fieldInfo;
+      this.termsStartPointer = termsStartPointer;
+      this.numTerms = numTerms;
+      this.sumTotalTermFreq = sumTotalTermFreq;
+      this.sumDocFreq = sumDocFreq;
+      this.docCount = docCount;
+      this.longsSize = longsSize;
+    }
+  }
+
+  private final List<FieldMetaData> fields = new ArrayList<>();
+
+  // private final String segment;
+
+  public BlockTermsWriter(TermsIndexWriterBase termsIndexWriter,
+      SegmentWriteState state, PostingsWriterBase postingsWriter)
+       {
+    final String termsFileName = IndexFileNames.segmentFileName(state.segmentInfo.name, state.segmentSuffix, TERMS_EXTENSION);
+    this.termsIndexWriter = termsIndexWriter;
+    out = state.directory.createOutput(termsFileName, state.context);
+    bool success = false;
+    try {
+      fieldInfos = state.fieldInfos;
+      writeHeader(out);
+      currentField = null;
+      this.postingsWriter = postingsWriter;
+      // segment = state.segmentName;
+      
+      //System.out.println("BTW.init seg=" + state.segmentName);
+      
+      postingsWriter.init(out); // have consumer write its format/header
+      success = true;
+    } finally {
+      if (!success) {
+        IOUtils.closeWhileHandlingException(out);
+      }
+    }
+  }
+  
+  private void writeHeader(IndexOutput out)  {
+    CodecUtil.writeHeader(out, CODEC_NAME, VERSION_CURRENT);     
+  }
+
+  @Override
+  public TermsConsumer addField(FieldInfo field)  {
+    //System.out.println("\nBTW.addField seg=" + segment + " field=" + field.name);
+    Debug.Assert( currentField == null || currentField.name.compareTo(field.name) < 0;
+    currentField = field;
+    TermsIndexWriterBase.FieldWriter fieldIndexWriter = termsIndexWriter.addField(field, out.getFilePointer());
+    return new TermsWriter(fieldIndexWriter, field, postingsWriter);
+  }
+
+  @Override
+  public void close()  {
+    if (out != null) {
+      try {
+        final long dirStart = out.getFilePointer();
+        
+        out.writeVInt(fields.size());
+        for(FieldMetaData field : fields) {
+          out.writeVInt(field.fieldInfo.number);
+          out.writeVLong(field.numTerms);
+          out.writeVLong(field.termsStartPointer);
+          if (field.fieldInfo.getIndexOptions() != IndexOptions.DOCS_ONLY) {
+            out.writeVLong(field.sumTotalTermFreq);
+          }
+          out.writeVLong(field.sumDocFreq);
+          out.writeVInt(field.docCount);
+          if (VERSION_CURRENT >= VERSION_META_ARRAY) {
+            out.writeVInt(field.longsSize);
+          }
+        }
+        writeTrailer(dirStart);
+        CodecUtil.writeFooter(out);
+      } finally {
+        IOUtils.close(out, postingsWriter, termsIndexWriter);
+        out = null;
+      }
+    }
+  }
+
+  private void writeTrailer(long dirStart)  {
+    out.writeLong(dirStart);    
+  }
+  
+  private static class TermEntry {
+    public final BytesRef term = new BytesRef();
+    public BlockTermState state;
+  }
+
+  class TermsWriter extends TermsConsumer {
+    private final FieldInfo fieldInfo;
+    private final PostingsWriterBase postingsWriter;
+    private final long termsStartPointer;
+    private long numTerms;
+    private final TermsIndexWriterBase.FieldWriter fieldIndexWriter;
+    long sumTotalTermFreq;
+    long sumDocFreq;
+    int docCount;
+    int longsSize;
+
+    private TermEntry[] pendingTerms;
+
+    private int pendingCount;
+
+    TermsWriter(
+        TermsIndexWriterBase.FieldWriter fieldIndexWriter,
+        FieldInfo fieldInfo,
+        PostingsWriterBase postingsWriter) 
+    {
+      this.fieldInfo = fieldInfo;
+      this.fieldIndexWriter = fieldIndexWriter;
+      pendingTerms = new TermEntry[32];
+      for(int i=0;i<pendingTerms.length;i++) {
+        pendingTerms[i] = new TermEntry();
+      }
+      termsStartPointer = out.getFilePointer();
+      this.postingsWriter = postingsWriter;
+      this.longsSize = postingsWriter.setField(fieldInfo);
+    }
+    
+    @Override
+    public Comparator<BytesRef> getComparator() {
+      return BytesRef.getUTF8SortedAsUnicodeComparator();
+    }
+
+    @Override
+    public PostingsConsumer startTerm(BytesRef text)  {
+      //System.out.println("BTW: startTerm term=" + fieldInfo.name + ":" + text.utf8ToString() + " " + text + " seg=" + segment);
+      postingsWriter.startTerm();
+      return postingsWriter;
+    }
+
+    private final BytesRef lastPrevTerm = new BytesRef();
+
+    @Override
+    public void finishTerm(BytesRef text, TermStats stats)  {
+
+      Debug.Assert( stats.docFreq > 0;
+      //System.out.println("BTW: finishTerm term=" + fieldInfo.name + ":" + text.utf8ToString() + " " + text + " seg=" + segment + " df=" + stats.docFreq);
+
+      final bool isIndexTerm = fieldIndexWriter.checkIndexTerm(text, stats);
+
+      if (isIndexTerm) {
+        if (pendingCount > 0) {
+          // Instead of writing each term, live, we gather terms
+          // in RAM in a pending buffer, and then write the
+          // entire block in between index terms:
+          flushBlock();
+        }
+        fieldIndexWriter.add(text, stats, out.getFilePointer());
+        //System.out.println("  index term!");
+      }
+
+      if (pendingTerms.length == pendingCount) {
+        final TermEntry[] newArray = new TermEntry[ArrayUtil.oversize(pendingCount+1, RamUsageEstimator.NUM_BYTES_OBJECT_REF)];
+        System.arraycopy(pendingTerms, 0, newArray, 0, pendingCount);
+        for(int i=pendingCount;i<newArray.length;i++) {
+          newArray[i] = new TermEntry();
+        }
+        pendingTerms = newArray;
+      }
+      final TermEntry te = pendingTerms[pendingCount];
+      te.term.copyBytes(text);
+      te.state = postingsWriter.newTermState();
+      te.state.docFreq = stats.docFreq;
+      te.state.totalTermFreq = stats.totalTermFreq;
+      postingsWriter.finishTerm(te.state);
+
+      pendingCount++;
+      numTerms++;
+    }
+
+    // Finishes all terms in this field
+    @Override
+    public void finish(long sumTotalTermFreq, long sumDocFreq, int docCount)  {
+      if (pendingCount > 0) {
+        flushBlock();
+      }
+      // EOF marker:
+      out.writeVInt(0);
+
+      this.sumTotalTermFreq = sumTotalTermFreq;
+      this.sumDocFreq = sumDocFreq;
+      this.docCount = docCount;
+      fieldIndexWriter.finish(out.getFilePointer());
+      if (numTerms > 0) {
+        fields.add(new FieldMetaData(fieldInfo,
+                                     numTerms,
+                                     termsStartPointer,
+                                     sumTotalTermFreq,
+                                     sumDocFreq,
+                                     docCount,
+                                     longsSize));
+      }
+    }
+
+    private int sharedPrefix(BytesRef term1, BytesRef term2) {
+      Debug.Assert( term1.offset == 0;
+      Debug.Assert( term2.offset == 0;
+      int pos1 = 0;
+      int pos1End = pos1 + Math.min(term1.length, term2.length);
+      int pos2 = 0;
+      while(pos1 < pos1End) {
+        if (term1.bytes[pos1] != term2.bytes[pos2]) {
+          return pos1;
+        }
+        pos1++;
+        pos2++;
+      }
+      return pos1;
+    }
+
+    private final RAMOutputStream bytesWriter = new RAMOutputStream();
+    private final RAMOutputStream bufferWriter = new RAMOutputStream();
+
+    private void flushBlock()  {
+      //System.out.println("BTW.flushBlock seg=" + segment + " pendingCount=" + pendingCount + " fp=" + out.getFilePointer());
+
+      // First pass: compute common prefix for all terms
+      // in the block, against term before first term in
+      // this block:
+      int commonPrefix = sharedPrefix(lastPrevTerm, pendingTerms[0].term);
+      for(int termCount=1;termCount<pendingCount;termCount++) {
+        commonPrefix = Math.min(commonPrefix,
+                                sharedPrefix(lastPrevTerm,
+                                             pendingTerms[termCount].term));
+      }        
+
+      out.writeVInt(pendingCount);
+      out.writeVInt(commonPrefix);
+
+      // 2nd pass: write suffixes, as separate byte[] blob
+      for(int termCount=0;termCount<pendingCount;termCount++) {
+        final int suffix = pendingTerms[termCount].term.length - commonPrefix;
+        // TODO: cutover to better intblock codec, instead
+        // of interleaving here:
+        bytesWriter.writeVInt(suffix);
+        bytesWriter.writeBytes(pendingTerms[termCount].term.bytes, commonPrefix, suffix);
+      }
+      out.writeVInt((int) bytesWriter.getFilePointer());
+      bytesWriter.writeTo(out);
+      bytesWriter.reset();
+
+      // 3rd pass: write the freqs as byte[] blob
+      // TODO: cutover to better intblock codec.  simple64?
+      // write prefix, suffix first:
+      for(int termCount=0;termCount<pendingCount;termCount++) {
+        final BlockTermState state = pendingTerms[termCount].state;
+        Debug.Assert( state != null;
+        bytesWriter.writeVInt(state.docFreq);
+        if (fieldInfo.getIndexOptions() != IndexOptions.DOCS_ONLY) {
+          bytesWriter.writeVLong(state.totalTermFreq-state.docFreq);
+        }
+      }
+      out.writeVInt((int) bytesWriter.getFilePointer());
+      bytesWriter.writeTo(out);
+      bytesWriter.reset();
+
+      // 4th pass: write the metadata 
+      long[] longs = new long[longsSize];
+      bool absolute = true;
+      for(int termCount=0;termCount<pendingCount;termCount++) {
+        final BlockTermState state = pendingTerms[termCount].state;
+        postingsWriter.encodeTerm(longs, bufferWriter, fieldInfo, state, absolute);
+        for (int i = 0; i < longsSize; i++) {
+          bytesWriter.writeVLong(longs[i]);
+        }
+        bufferWriter.writeTo(bytesWriter);
+        bufferWriter.reset();
+        absolute = false;
+      }
+      out.writeVInt((int) bytesWriter.getFilePointer());
+      bytesWriter.writeTo(out);
+      bytesWriter.reset();
+
+      lastPrevTerm.copyBytes(pendingTerms[pendingCount-1].term);
+      pendingCount = 0;
+    }
+  }
+}

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/src/Lucene.Net.Codecs/BlockTerms/FixedGapTermsIndexReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Codecs/BlockTerms/FixedGapTermsIndexReader.cs b/src/Lucene.Net.Codecs/BlockTerms/FixedGapTermsIndexReader.cs
new file mode 100644
index 0000000..effd850
--- /dev/null
+++ b/src/Lucene.Net.Codecs/BlockTerms/FixedGapTermsIndexReader.cs
@@ -0,0 +1,433 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+namespace Lucene.Net.Codecs.BlockTerms
+{
+    
+}
+
+/** 
+ * TermsIndexReader for simple every Nth terms indexes.
+ *
+ * @see FixedGapTermsIndexWriter
+ * @lucene.experimental 
+ */
+public class FixedGapTermsIndexReader extends TermsIndexReaderBase {
+
+  // NOTE: long is overkill here, since this number is 128
+  // by default and only indexDivisor * 128 if you change
+  // the indexDivisor at search time.  But, we use this in a
+  // number of places to multiply out the actual ord, and we
+  // will overflow int during those multiplies.  So to avoid
+  // having to upgrade each multiple to long in multiple
+  // places (error prone), we use long here:
+  private long totalIndexInterval;
+
+  private int indexDivisor;
+  final private int indexInterval;
+
+  // Closed if indexLoaded is true:
+  private IndexInput in;
+  private volatile bool indexLoaded;
+
+  private final Comparator<BytesRef> termComp;
+
+  private final static int PAGED_BYTES_BITS = 15;
+
+  // all fields share this single logical byte[]
+  private final PagedBytes termBytes = new PagedBytes(PAGED_BYTES_BITS);
+  private PagedBytes.Reader termBytesReader;
+
+  final HashMap<FieldInfo,FieldIndexData> fields = new HashMap<>();
+  
+  // start of the field info data
+  private long dirOffset;
+  
+  private final int version;
+
+  public FixedGapTermsIndexReader(Directory dir, FieldInfos fieldInfos, String segment, int indexDivisor, Comparator<BytesRef> termComp, String segmentSuffix, IOContext context)
+     {
+
+    this.termComp = termComp;
+
+    Debug.Assert( indexDivisor == -1 || indexDivisor > 0;
+
+    in = dir.openInput(IndexFileNames.segmentFileName(segment, segmentSuffix, FixedGapTermsIndexWriter.TERMS_INDEX_EXTENSION), context);
+    
+    bool success = false;
+
+    try {
+      
+      version = readHeader(in);
+      
+      if (version >= FixedGapTermsIndexWriter.VERSION_CHECKSUM) {
+        CodecUtil.checksumEntireFile(in);
+      }
+      
+      indexInterval = in.readInt();
+      if (indexInterval < 1) {
+        throw new CorruptIndexException("invalid indexInterval: " + indexInterval + " (resource=" + in + ")");
+      }
+      this.indexDivisor = indexDivisor;
+
+      if (indexDivisor < 0) {
+        totalIndexInterval = indexInterval;
+      } else {
+        // In case terms index gets loaded, later, on demand
+        totalIndexInterval = indexInterval * indexDivisor;
+      }
+      Debug.Assert( totalIndexInterval > 0;
+      
+      seekDir(in, dirOffset);
+
+      // Read directory
+      final int numFields = in.readVInt();     
+      if (numFields < 0) {
+        throw new CorruptIndexException("invalid numFields: " + numFields + " (resource=" + in + ")");
+      }
+      //System.out.println("FGR: init seg=" + segment + " div=" + indexDivisor + " nF=" + numFields);
+      for(int i=0;i<numFields;i++) {
+        final int field = in.readVInt();
+        final int numIndexTerms = in.readVInt();
+        if (numIndexTerms < 0) {
+          throw new CorruptIndexException("invalid numIndexTerms: " + numIndexTerms + " (resource=" + in + ")");
+        }
+        final long termsStart = in.readVLong();
+        final long indexStart = in.readVLong();
+        final long packedIndexStart = in.readVLong();
+        final long packedOffsetsStart = in.readVLong();
+        if (packedIndexStart < indexStart) {
+          throw new CorruptIndexException("invalid packedIndexStart: " + packedIndexStart + " indexStart: " + indexStart + "numIndexTerms: " + numIndexTerms + " (resource=" + in + ")");
+        }
+        final FieldInfo fieldInfo = fieldInfos.fieldInfo(field);
+        FieldIndexData previous = fields.put(fieldInfo, new FieldIndexData(fieldInfo, numIndexTerms, indexStart, termsStart, packedIndexStart, packedOffsetsStart));
+        if (previous != null) {
+          throw new CorruptIndexException("duplicate field: " + fieldInfo.name + " (resource=" + in + ")");
+        }
+      }
+      success = true;
+    } finally {
+      if (!success) {
+        IOUtils.closeWhileHandlingException(in);
+      }
+      if (indexDivisor > 0) {
+        in.close();
+        in = null;
+        if (success) {
+          indexLoaded = true;
+        }
+        termBytesReader = termBytes.freeze(true);
+      }
+    }
+  }
+  
+  @Override
+  public int getDivisor() {
+    return indexDivisor;
+  }
+
+  private int readHeader(IndexInput input)  {
+    int version = CodecUtil.checkHeader(input, FixedGapTermsIndexWriter.CODEC_NAME,
+      FixedGapTermsIndexWriter.VERSION_START, FixedGapTermsIndexWriter.VERSION_CURRENT);
+    if (version < FixedGapTermsIndexWriter.VERSION_APPEND_ONLY) {
+      dirOffset = input.readLong();
+    }
+    return version;
+  }
+
+  private class IndexEnum extends FieldIndexEnum {
+    private final FieldIndexData.CoreFieldIndex fieldIndex;
+    private final BytesRef term = new BytesRef();
+    private long ord;
+
+    public IndexEnum(FieldIndexData.CoreFieldIndex fieldIndex) {
+      this.fieldIndex = fieldIndex;
+    }
+
+    @Override
+    public BytesRef term() {
+      return term;
+    }
+
+    @Override
+    public long seek(BytesRef target) {
+      int lo = 0;          // binary search
+      int hi = fieldIndex.numIndexTerms - 1;
+      Debug.Assert( totalIndexInterval > 0 : "totalIndexInterval=" + totalIndexInterval;
+
+      while (hi >= lo) {
+        int mid = (lo + hi) >>> 1;
+
+        final long offset = fieldIndex.termOffsets.get(mid);
+        final int length = (int) (fieldIndex.termOffsets.get(1+mid) - offset);
+        termBytesReader.fillSlice(term, fieldIndex.termBytesStart + offset, length);
+
+        int delta = termComp.compare(target, term);
+        if (delta < 0) {
+          hi = mid - 1;
+        } else if (delta > 0) {
+          lo = mid + 1;
+        } else {
+          Debug.Assert( mid >= 0;
+          ord = mid*totalIndexInterval;
+          return fieldIndex.termsStart + fieldIndex.termsDictOffsets.get(mid);
+        }
+      }
+
+      if (hi < 0) {
+        Debug.Assert( hi == -1;
+        hi = 0;
+      }
+
+      final long offset = fieldIndex.termOffsets.get(hi);
+      final int length = (int) (fieldIndex.termOffsets.get(1+hi) - offset);
+      termBytesReader.fillSlice(term, fieldIndex.termBytesStart + offset, length);
+
+      ord = hi*totalIndexInterval;
+      return fieldIndex.termsStart + fieldIndex.termsDictOffsets.get(hi);
+    }
+
+    @Override
+    public long next() {
+      final int idx = 1 + (int) (ord / totalIndexInterval);
+      if (idx >= fieldIndex.numIndexTerms) {
+        return -1;
+      }
+      ord += totalIndexInterval;
+
+      final long offset = fieldIndex.termOffsets.get(idx);
+      final int length = (int) (fieldIndex.termOffsets.get(1+idx) - offset);
+      termBytesReader.fillSlice(term, fieldIndex.termBytesStart + offset, length);
+      return fieldIndex.termsStart + fieldIndex.termsDictOffsets.get(idx);
+    }
+
+    @Override
+    public long ord() {
+      return ord;
+    }
+
+    @Override
+    public long seek(long ord) {
+      int idx = (int) (ord / totalIndexInterval);
+      // caller must ensure ord is in bounds
+      Debug.Assert( idx < fieldIndex.numIndexTerms;
+      final long offset = fieldIndex.termOffsets.get(idx);
+      final int length = (int) (fieldIndex.termOffsets.get(1+idx) - offset);
+      termBytesReader.fillSlice(term, fieldIndex.termBytesStart + offset, length);
+      this.ord = idx * totalIndexInterval;
+      return fieldIndex.termsStart + fieldIndex.termsDictOffsets.get(idx);
+    }
+  }
+
+  @Override
+  public bool supportsOrd() {
+    return true;
+  }
+
+  private final class FieldIndexData {
+
+    volatile CoreFieldIndex coreIndex;
+
+    private final long indexStart;
+    private final long termsStart;
+    private final long packedIndexStart;
+    private final long packedOffsetsStart;
+
+    private final int numIndexTerms;
+
+    public FieldIndexData(FieldInfo fieldInfo, int numIndexTerms, long indexStart, long termsStart, long packedIndexStart,
+                          long packedOffsetsStart)  {
+
+      this.termsStart = termsStart;
+      this.indexStart = indexStart;
+      this.packedIndexStart = packedIndexStart;
+      this.packedOffsetsStart = packedOffsetsStart;
+      this.numIndexTerms = numIndexTerms;
+
+      if (indexDivisor > 0) {
+        loadTermsIndex();
+      }
+    }
+
+    private void loadTermsIndex()  {
+      if (coreIndex == null) {
+        coreIndex = new CoreFieldIndex(indexStart, termsStart, packedIndexStart, packedOffsetsStart, numIndexTerms);
+      }
+    }
+
+    private final class CoreFieldIndex {
+
+      // where this field's terms begin in the packed byte[]
+      // data
+      final long termBytesStart;
+
+      // offset into index termBytes
+      final PackedInts.Reader termOffsets;
+
+      // index pointers into main terms dict
+      final PackedInts.Reader termsDictOffsets;
+
+      final int numIndexTerms;
+      final long termsStart;
+
+      public CoreFieldIndex(long indexStart, long termsStart, long packedIndexStart, long packedOffsetsStart, int numIndexTerms)  {
+
+        this.termsStart = termsStart;
+        termBytesStart = termBytes.getPointer();
+
+        IndexInput clone = in.clone();
+        clone.seek(indexStart);
+
+        // -1 is passed to mean "don't load term index", but
+        // if we are then later loaded it's overwritten with
+        // a real value
+        Debug.Assert( indexDivisor > 0;
+
+        this.numIndexTerms = 1+(numIndexTerms-1) / indexDivisor;
+
+        Debug.Assert( this.numIndexTerms  > 0: "numIndexTerms=" + numIndexTerms + " indexDivisor=" + indexDivisor;
+
+        if (indexDivisor == 1) {
+          // Default (load all index terms) is fast -- slurp in the images from disk:
+          
+          try {
+            final long numTermBytes = packedIndexStart - indexStart;
+            termBytes.copy(clone, numTermBytes);
+
+            // records offsets into main terms dict file
+            termsDictOffsets = PackedInts.getReader(clone);
+            Debug.Assert( termsDictOffsets.size() == numIndexTerms;
+
+            // records offsets into byte[] term data
+            termOffsets = PackedInts.getReader(clone);
+            Debug.Assert( termOffsets.size() == 1+numIndexTerms;
+          } finally {
+            clone.close();
+          }
+        } else {
+          // Get packed iterators
+          final IndexInput clone1 = in.clone();
+          final IndexInput clone2 = in.clone();
+
+          try {
+            // Subsample the index terms
+            clone1.seek(packedIndexStart);
+            final PackedInts.ReaderIterator termsDictOffsetsIter = PackedInts.getReaderIterator(clone1, PackedInts.DEFAULT_BUFFER_SIZE);
+
+            clone2.seek(packedOffsetsStart);
+            final PackedInts.ReaderIterator termOffsetsIter = PackedInts.getReaderIterator(clone2,  PackedInts.DEFAULT_BUFFER_SIZE);
+
+            // TODO: often we can get by w/ fewer bits per
+            // value, below.. .but this'd be more complex:
+            // we'd have to try @ fewer bits and then grow
+            // if we overflowed it.
+
+            PackedInts.Mutable termsDictOffsetsM = PackedInts.getMutable(this.numIndexTerms, termsDictOffsetsIter.getBitsPerValue(), PackedInts.DEFAULT);
+            PackedInts.Mutable termOffsetsM = PackedInts.getMutable(this.numIndexTerms+1, termOffsetsIter.getBitsPerValue(), PackedInts.DEFAULT);
+
+            termsDictOffsets = termsDictOffsetsM;
+            termOffsets = termOffsetsM;
+
+            int upto = 0;
+
+            long termOffsetUpto = 0;
+
+            while(upto < this.numIndexTerms) {
+              // main file offset copies straight over
+              termsDictOffsetsM.set(upto, termsDictOffsetsIter.next());
+
+              termOffsetsM.set(upto, termOffsetUpto);
+
+              long termOffset = termOffsetsIter.next();
+              long nextTermOffset = termOffsetsIter.next();
+              final int numTermBytes = (int) (nextTermOffset - termOffset);
+
+              clone.seek(indexStart + termOffset);
+              Debug.Assert( indexStart + termOffset < clone.length() : "indexStart=" + indexStart + " termOffset=" + termOffset + " len=" + clone.length();
+              Debug.Assert( indexStart + termOffset + numTermBytes < clone.length();
+
+              termBytes.copy(clone, numTermBytes);
+              termOffsetUpto += numTermBytes;
+
+              upto++;
+              if (upto == this.numIndexTerms) {
+                break;
+              }
+
+              // skip terms:
+              termsDictOffsetsIter.next();
+              for(int i=0;i<indexDivisor-2;i++) {
+                termOffsetsIter.next();
+                termsDictOffsetsIter.next();
+              }
+            }
+            termOffsetsM.set(upto, termOffsetUpto);
+
+          } finally {
+            clone1.close();
+            clone2.close();
+            clone.close();
+          }
+        }
+      }
+      
+      /** Returns approximate RAM bytes Used */
+      public long ramBytesUsed() {
+        return ((termOffsets!=null)? termOffsets.ramBytesUsed() : 0) +
+            ((termsDictOffsets!=null)? termsDictOffsets.ramBytesUsed() : 0);
+      }
+    }
+  }
+
+  @Override
+  public FieldIndexEnum getFieldEnum(FieldInfo fieldInfo) {
+    final FieldIndexData fieldData = fields.get(fieldInfo);
+    if (fieldData.coreIndex == null) {
+      return null;
+    } else {
+      return new IndexEnum(fieldData.coreIndex);
+    }
+  }
+
+  @Override
+  public void close()  {
+    if (in != null && !indexLoaded) {
+      in.close();
+    }
+  }
+
+  private void seekDir(IndexInput input, long dirOffset)  {
+    if (version >= FixedGapTermsIndexWriter.VERSION_CHECKSUM) {
+      input.seek(input.length() - CodecUtil.footerLength() - 8);
+      dirOffset = input.readLong();
+    } else if (version >= FixedGapTermsIndexWriter.VERSION_APPEND_ONLY) {
+      input.seek(input.length() - 8);
+      dirOffset = input.readLong();
+    }
+    input.seek(dirOffset);
+  }
+  
+  @Override
+  public long ramBytesUsed() {
+    long sizeInBytes = ((termBytes!=null) ? termBytes.ramBytesUsed() : 0) +
+        ((termBytesReader!=null)? termBytesReader.ramBytesUsed() : 0);
+    for(FieldIndexData entry : fields.values()) {
+      sizeInBytes += entry.coreIndex.ramBytesUsed();
+    }
+    return sizeInBytes;
+  }
+}

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/src/Lucene.Net.Codecs/BlockTerms/FixedGapTermsIndexWriter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Codecs/BlockTerms/FixedGapTermsIndexWriter.cs b/src/Lucene.Net.Codecs/BlockTerms/FixedGapTermsIndexWriter.cs
new file mode 100644
index 0000000..ba0bbf9
--- /dev/null
+++ b/src/Lucene.Net.Codecs/BlockTerms/FixedGapTermsIndexWriter.cs
@@ -0,0 +1,294 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHoutput WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+namespace Lucene.Net.Codecs.BlockTerms
+{
+
+    using System;
+    using System.Collections.Generic;
+    using System.Diagnostics;
+    using Lucene.Net.Index;
+    using Lucene.Net.Store;
+    using Lucene.Net.Util;
+    using Lucene.Net.Util.Packed;
+
+    /// <summary>
+    /// Selects every Nth term as and index term, and hold term
+    /// bytes (mostly) fully expanded in memory.  This terms index
+    /// supports seeking by ord.  See {@link
+    /// VariableGapTermsIndexWriter} for a more memory efficient
+    /// terms index that does not support seeking by ord.
+    ///
+    /// @lucene.experimental */    
+    /// </summary>
+    public class FixedGapTermsIndexWriter : TermsIndexWriterBase
+    {
+        protected IndexOutput output;
+
+        /** Extension of terms index file */
+        private static readonly String TERMS_INDEX_EXTENSION = "tii";
+        private static readonly String CODEC_NAME = "SIMPLE_STANDARD_TERMS_INDEX";
+        private static readonly int VERSION_START = 0;
+        private static readonly int VERSION_APPEND_ONLY = 1;
+
+        private static readonly int VERSION_CHECKSUM = 1000;
+
+        // 4.x "skipped" trunk's monotonic addressing: give any user a nice exception
+        private static readonly int VERSION_CURRENT = VERSION_CHECKSUM;
+        private readonly int termIndexInterval;
+        private readonly List<SimpleFieldWriter> fields = new List<SimpleFieldWriter>();
+        private readonly FieldInfos fieldInfos;  //@SuppressWarnings("unused") 
+
+        public FixedGapTermsIndexWriter(SegmentWriteState state)
+        {
+            String indexFileName = IndexFileNames.SegmentFileName(state.SegmentInfo.Name, state.SegmentSuffix,
+                TERMS_INDEX_EXTENSION);
+            termIndexInterval = state.TermIndexInterval;
+            output = state.Directory.CreateOutput(indexFileName, state.Context);
+            bool success = false;
+            try
+            {
+                fieldInfos = state.FieldInfos;
+                WriteHeader(output);
+                output.WriteInt(termIndexInterval);
+                success = true;
+            }
+            finally
+            {
+                if (!success)
+                {
+                    IOUtils.CloseWhileHandlingException(output);
+                }
+            }
+        }
+
+        private void WriteHeader(IndexOutput output)
+        {
+            CodecUtil.WriteHeader(output, CODEC_NAME, VERSION_CURRENT);
+        }
+
+        public override FieldWriter AddField(FieldInfo field, long termsFilePointer)
+        {
+            //System.output.println("FGW: addFfield=" + field.name);
+            SimpleFieldWriter writer = new SimpleFieldWriter(field, termsFilePointer);
+            fields.Add(writer);
+            return writer;
+        }
+
+        /// <remarks>
+        /// NOTE: if your codec does not sort in unicode code
+        /// point order, you must override this method, to simply
+        /// return indexedTerm.length.
+        /// </remarks>
+        protected int IndexedTermPrefixLength(BytesRef priorTerm, BytesRef indexedTerm)
+        {
+            // As long as codec sorts terms in unicode codepoint
+            // order, we can safely strip off the non-distinguishing
+            // suffix to save RAM in the loaded terms index.
+            int idxTermOffset = indexedTerm.Offset;
+            int priorTermOffset = priorTerm.Offset;
+            int limit = Math.Min(priorTerm.Length, indexedTerm.Length);
+            for (int byteIdx = 0; byteIdx < limit; byteIdx++)
+            {
+                if (priorTerm.Bytes[priorTermOffset + byteIdx] != indexedTerm.Bytes[idxTermOffset + byteIdx])
+                {
+                    return byteIdx + 1;
+                }
+            }
+            return Math.Min(1 + priorTerm.Length, indexedTerm.Length);
+        }
+
+        public void Dispose()
+        {
+            if (output != null)
+            {
+                bool success = false;
+                try
+                {
+                    long dirStart = output.FilePointer;
+                    int fieldCount = fields.Count;
+
+                    int nonNullFieldCount = 0;
+                    for (int i = 0; i < fieldCount; i++)
+                    {
+                        SimpleFieldWriter field = fields[i];
+                        if (field.numIndexTerms > 0)
+                        {
+                            nonNullFieldCount++;
+                        }
+                    }
+
+                    output.WriteVInt(nonNullFieldCount);
+                    for (int i = 0; i < fieldCount; i++)
+                    {
+                        SimpleFieldWriter field = fields[i];
+                        if (field.numIndexTerms > 0)
+                        {
+                            output.WriteVInt(field.fieldInfo.Number);
+                            output.WriteVInt(field.numIndexTerms);
+                            output.WriteVLong(field.termsStart);
+                            output.WriteVLong(field.indexStart);
+                            output.WriteVLong(field.packedIndexStart);
+                            output.WriteVLong(field.packedOffsetsStart);
+                        }
+                    }
+                    WriteTrailer(dirStart);
+                    CodecUtil.WriteFooter(output);
+                    success = true;
+                }
+                finally
+                {
+                    if (success)
+                    {
+                        IOUtils.Close(output);
+                    }
+                    else
+                    {
+                        IOUtils.CloseWhileHandlingException(output);
+                    }
+                    output = null;
+                }
+            }
+        }
+
+        private void WriteTrailer(long dirStart)
+        {
+            output.WriteLong(dirStart);
+        }
+
+
+        private class SimpleFieldWriter : FieldWriter
+        {
+            public readonly FieldInfo fieldInfo;
+            public int numIndexTerms;
+            public readonly long indexStart;
+            public readonly long termsStart;
+            public long packedIndexStart;
+            public long packedOffsetsStart;
+            private long numTerms;
+
+            // TODO: we could conceivably make a PackedInts wrapper
+            // that auto-grows... then we wouldn't force 6 bytes RAM
+            // per index term:
+            private short[] termLengths;
+            private int[] termsPointerDeltas;
+            private long lastTermsPointer;
+            private long totTermLength;
+
+            private readonly BytesRef lastTerm = new BytesRef();
+
+            public SimpleFieldWriter(FieldInfo fieldInfo, long termsFilePointer)
+            {
+                this.fieldInfo = fieldInfo;
+                indexStart = output.FilePointer;
+                termsStart = lastTermsPointer = termsFilePointer;
+                termLengths = new short[0];
+                termsPointerDeltas = new int[0];
+            }
+
+            public override bool CheckIndexTerm(BytesRef text, TermStats stats)
+            {
+                // First term is first indexed term:
+                //System.output.println("FGW: checkIndexTerm text=" + text.utf8ToString());
+                if (0 == (numTerms++ % termIndexInterval))
+                {
+                    return true;
+                }
+                else
+                {
+                    if (0 == numTerms % termIndexInterval)
+                    {
+                        // save last term just before next index term so we
+                        // can compute wasted suffix
+                        lastTerm.CopyBytes(text);
+                    }
+                    return false;
+                }
+            }
+
+            public override void Add(BytesRef text, TermStats stats, long termsFilePointer)
+            {
+                int indexedTermLength = IndexedTermPrefixLength(lastTerm, text);
+                //System.output.println("FGW: add text=" + text.utf8ToString() + " " + text + " fp=" + termsFilePointer);
+
+                // write only the min prefix that shows the diff
+                // against prior term
+                output.WriteBytes(text.Bytes, text.Offset, indexedTermLength);
+
+                if (termLengths.Length == numIndexTerms)
+                {
+                    termLengths = ArrayUtil.Grow(termLengths);
+                }
+                if (termsPointerDeltas.Length == numIndexTerms)
+                {
+                    termsPointerDeltas = ArrayUtil.Grow(termsPointerDeltas);
+                }
+
+                // save delta terms pointer
+                termsPointerDeltas[numIndexTerms] = (int)(termsFilePointer - lastTermsPointer);
+                lastTermsPointer = termsFilePointer;
+
+                // save term length (in bytes)
+                Debug.Assert(indexedTermLength <= Short.MAX_VALUE);
+                termLengths[numIndexTerms] = (short)indexedTermLength;
+                totTermLength += indexedTermLength;
+
+                lastTerm.CopyBytes(text);
+                numIndexTerms++;
+            }
+
+            public override void Finish(long termsFilePointer)
+            {
+
+                // write primary terms dict offsets
+                packedIndexStart = output.FilePointer;
+
+                PackedInts.Writer w = PackedInts.GetWriter(output, numIndexTerms,
+                    PackedInts.BitsRequired(termsFilePointer),
+                    PackedInts.DEFAULT);
+
+                // relative to our indexStart
+                long upto = 0;
+                for (int i = 0; i < numIndexTerms; i++)
+                {
+                    upto += termsPointerDeltas[i];
+                    w.Add(upto);
+                }
+                w.Finish();
+
+                packedOffsetsStart = output.FilePointer;
+
+                // write offsets into the byte[] terms
+                w = PackedInts.GetWriter(output, 1 + numIndexTerms, PackedInts.BitsRequired(totTermLength),
+                    PackedInts.DEFAULT);
+                upto = 0;
+                for (int i = 0; i < numIndexTerms; i++)
+                {
+                    w.Add(upto);
+                    upto += termLengths[i];
+                }
+                w.Add(upto);
+                w.Finish();
+
+                // our referrer holds onto us, while other fields are
+                // being written, so don't tie up this RAM:
+                termLengths = null;
+                termsPointerDeltas = null;
+            }
+        }
+    }
+}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/src/Lucene.Net.Codecs/BlockTerms/TermsIndexReaderBase.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Codecs/BlockTerms/TermsIndexReaderBase.cs b/src/Lucene.Net.Codecs/BlockTerms/TermsIndexReaderBase.cs
new file mode 100644
index 0000000..aa15e4e
--- /dev/null
+++ b/src/Lucene.Net.Codecs/BlockTerms/TermsIndexReaderBase.cs
@@ -0,0 +1,88 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+using System;
+using Lucene.Net.Index;
+using Lucene.Net.Util;
+
+namespace Lucene.Net.Codecs.BlockTerms
+{
+
+
+    /// <summary>
+    /// TODO
+    ///   - allow for non-regular index intervals?  eg with a
+    ///     long string of rare terms, you don't need such
+    ///     frequent indexing
+    /// 
+    /// {@link BlockTermsReader} interacts with an instance of this class
+    /// to manage its terms index.  The writer must accept
+    /// indexed terms (many pairs of BytesRef text + long
+    /// fileOffset), and then this reader must be able to
+    /// retrieve the nearest index term to a provided term
+    /// text. 
+    ///
+    ///  @lucene.experimental */
+    /// </summary>
+    public abstract class TermsIndexReaderBase : IDisposable
+    {
+
+        public abstract FieldIndexEnum GetFieldEnum(FieldInfo fieldInfo);
+
+        public abstract void Dispose();
+
+        public abstract bool SupportsOrd();
+
+        public abstract int GetDivisor();
+
+        /// <summary>
+        /// Similar to TermsEnum, except, the only "metadata" it
+        /// reports for a given indexed term is the long fileOffset
+        /// into the main terms dictionary file.
+        /// </summary>
+        public abstract class FieldIndexEnum
+        {
+
+            /// <summary> 
+            /// Seeks to "largest" indexed term that's <=
+            ///  term; returns file pointer index (into the main
+            /// terms index file) for that term 
+            /// </summary>
+            public abstract long Seek(BytesRef term);
+
+            /** Returns -1 at end */
+            public abstract long Next();
+
+            public abstract BytesRef Term();
+
+            /// <summary></summary>
+            /// <remarks>Only implemented if {@link TermsIndexReaderBase.supportsOrd()} 
+            /// returns true</remarks>
+            /// <returns></returns>
+            public abstract long Seek(long ord);
+
+            /// <summary></summary>
+            /// <remarks>Only implemented if {@link TermsIndexReaderBase.supportsOrd()} 
+            /// returns true</remarks>
+            /// <returns></returns>
+            public abstract long Ord();
+        }
+
+        /// <summary>Returns approximate RAM bytes used</summary>
+        public abstract long RamBytesUsed();
+    }
+}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/src/Lucene.Net.Codecs/BlockTerms/TermsIndexWriterBase.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Codecs/BlockTerms/TermsIndexWriterBase.cs b/src/Lucene.Net.Codecs/BlockTerms/TermsIndexWriterBase.cs
new file mode 100644
index 0000000..bd20e4e
--- /dev/null
+++ b/src/Lucene.Net.Codecs/BlockTerms/TermsIndexWriterBase.cs
@@ -0,0 +1,51 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+using System;
+using Lucene.Net.Index;
+using Lucene.Net.Util;
+
+namespace Lucene.Net.Codecs.BlockTerms
+{
+
+    /// <summary>
+    ///  Base class for terms index implementations to plug
+    /// into {@link BlockTermsWriter}.
+    /// 
+    /// @see TermsIndexReaderBase
+    /// @lucene.experimental 
+    /// </summary>
+    public abstract class TermsIndexWriterBase : IDisposable
+    {
+
+        public abstract FieldWriter AddField(FieldInfo fieldInfo, long termsFilePointer);
+
+        public void Dispose()
+        {
+            //
+        }
+
+
+        /// <summary>Terms index API for a single field</summary>
+        public abstract class FieldWriter
+        {
+            public abstract bool CheckIndexTerm(BytesRef text, TermStats stats);
+            public abstract void Add(BytesRef text, TermStats stats, long termsFilePointer);
+            public abstract void Finish(long termsFilePointer);
+        }
+    }
+}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/src/Lucene.Net.Codecs/BlockTerms/VariableGapTermsIndexReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Codecs/BlockTerms/VariableGapTermsIndexReader.cs b/src/Lucene.Net.Codecs/BlockTerms/VariableGapTermsIndexReader.cs
new file mode 100644
index 0000000..0c97779
--- /dev/null
+++ b/src/Lucene.Net.Codecs/BlockTerms/VariableGapTermsIndexReader.cs
@@ -0,0 +1,315 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+namespace Lucene.Net.Codecs.BlockTerms
+{
+
+    using System;
+    using System.Collections.Generic;
+    using System.Diagnostics;
+    using Lucene.Net.Index;
+    using Lucene.Net.Store;
+    using Lucene.Net.Util;
+    using Lucene.Net.Util.Fst;
+
+/** See {@link VariableGapTermsIndexWriter}
+ * 
+ * @lucene.experimental */
+
+    public class VariableGapTermsIndexReader : TermsIndexReaderBase
+    {
+
+        private readonly PositiveIntOutputs fstOutputs = PositiveIntOutputs.Singleton;
+        private readonly int indexDivisor;
+        private readonly IndexInput input;       // Closed if indexLoaded is true:
+        private volatile bool indexLoaded;
+
+        private readonly Dictionary<FieldInfo, FieldIndexData> fields = new Dictionary<FieldInfo, FieldIndexData>();
+
+        private long dirOffset;                 // start of the field info data
+        private readonly int version;
+        private readonly String segment;
+
+        public VariableGapTermsIndexReader(Directory dir, FieldInfos fieldInfos, String segment, int indexDivisor,
+            String segmentSuffix, IOContext context)
+        {
+            input =
+                dir.OpenInput(
+                    IndexFileNames.SegmentFileName(segment, segmentSuffix,
+                        VariableGapTermsIndexWriter.TERMS_INDEX_EXTENSION), new IOContext(context, true));
+            this.segment = segment;
+            bool success = false;
+
+            Debug.Debug.Assert((indexDivisor == -1 || indexDivisor > 0);
+
+            try
+            {
+
+                version = readHeader(input);
+                this.indexDivisor = indexDivisor;
+
+                if (version >= VariableGapTermsIndexWriter.VERSION_CHECKSUM)
+                {
+                    CodecUtil.ChecksumEntireFile(input);
+                }
+
+                SeekDir(in,
+                dirOffset)
+                ;
+
+                // Read directory
+                int numFields = input.ReadVInt();
+                if (numFields < 0)
+                {
+                    throw new CorruptIndexException("invalid numFields: " + numFields + " (resource=" + input + ")");
+                }
+
+                for (int i = 0; i < numFields; i++)
+                {
+                    final
+                    int field = in.
+                    readVInt();
+                    final
+                    long indexStart = in.
+                    readVLong();
+                    final
+                    FieldInfo fieldInfo = fieldInfos.fieldInfo(field);
+                    FieldIndexData previous = fields.put(fieldInfo, new FieldIndexData(fieldInfo, indexStart));
+                    if (previous != null)
+                    {
+                        throw new CorruptIndexException("duplicate field: " + fieldInfo.name + " (resource=" +in + ")" )
+                        ;
+                    }
+                }
+                success = true;
+            }
+            finally
+            {
+                if (indexDivisor > 0)
+                {
+                in.
+                    close();
+                    in =
+                    null;
+                    if (success)
+                    {
+                        indexLoaded = true;
+                    }
+                }
+            }
+        }
+
+
+        private int ReadHeader(IndexInput input)
+        {
+            int version = CodecUtil.CheckHeader(input, VariableGapTermsIndexWriter.CODEC_NAME,
+                VariableGapTermsIndexWriter.VERSION_START, VariableGapTermsIndexWriter.VERSION_CURRENT);
+            if (version < VariableGapTermsIndexWriter.VERSION_APPEND_ONLY)
+            {
+                dirOffset = input.ReadLong();
+            }
+            return version;
+        }
+
+        public override void Dispose()
+        {
+            throw new NotImplementedException();
+        }
+
+        public override bool SupportsOrd()
+        {
+            return false;
+        }
+
+        public override int GetDivisor()
+        {
+            return indexDivisor;
+        }
+
+        public override FieldIndexEnum GetFieldEnum(FieldInfo fieldInfo)
+        {
+            FieldIndexData fieldData = fields[fieldInfo];
+            if (fieldData.Fst == null)
+            {
+                return null;
+            }
+            else
+            {
+                return new IndexEnum(fieldData.Fst);
+            }
+        }
+
+        public override void Close()
+        {
+            if (input !=
+                null && !indexLoaded)
+            {
+                input.Close();
+            }
+        }
+
+        private void SeekDir(IndexInput input, long dirOffset)
+        {
+            if (version >= VariableGapTermsIndexWriter.VERSION_CHECKSUM)
+            {
+                input.Seek(input.Length() - CodecUtil.FooterLength() - 8);
+                dirOffset = input.ReadLong();
+            }
+            else if (version >= VariableGapTermsIndexWriter.VERSION_APPEND_ONLY)
+            {
+                input.Seek(input.Length() - 8);
+                dirOffset = input.ReadLong();
+            }
+            input.Seek(dirOffset);
+        }
+
+        public override long RamBytesUsed()
+        {
+            long sizeInBytes = 0;
+
+            foreach (var entry in fields.Values)
+            {
+                sizeInBytes += entry.RamBytesUsed();
+            }
+
+            return sizeInBytes;
+        }
+
+
+        internal class FieldIndexData
+        {
+
+            private readonly long indexStart;
+            // Set only if terms index is loaded:
+            public volatile FST<long> Fst;
+
+            public FieldIndexData(FieldInfo fieldInfo, long indexStart)
+            {
+                this.indexStart = indexStart;
+
+                if (indexDivisor > 0)
+                {
+                    loadTermsIndex();
+                }
+            }
+
+            private void loadTermsIndex()
+            {
+                if (Fst == null)
+                {
+                    IndexInput clone = input.Clone();
+                    clone.Seek(indexStart);
+                    Fst = new FST<>(clone, fstOutputs);
+                    clone.Close();
+
+                    /*
+        final String dotFileName = segment + "_" + fieldInfo.name + ".dot";
+        Writer w = new OutputStreamWriter(new FileOutputStream(dotFileName));
+        Util.toDot(fst, w, false, false);
+        System.out.println("FST INDEX: SAVED to " + dotFileName);
+        w.close();
+        */
+
+                    if (indexDivisor > 1)
+                    {
+                        // subsample
+                        IntsRef scratchIntsRef = new IntsRef();
+                        PositiveIntOutputs outputs = PositiveIntOutputs.GetSingleton();
+                        Builder<long> builder = new Builder<long>(FST.INPUT_TYPE.BYTE1, outputs);
+                        BytesRefFSTEnum<long> fstEnum = new BytesRefFSTEnum<long>(fst);
+                        BytesRefFSTEnum.InputOutput<long> result;
+                        int count = indexDivisor;
+                        while ((result = fstEnum.Next()) != null)
+                        {
+                            if (count == indexDivisor)
+                            {
+                                builder.Add(Util.ToIntsRef(result.Input, scratchIntsRef), result.Output);
+                                count = 0;
+                            }
+                            count++;
+                        }
+                        Fst = builder.Finish();
+                    }
+                }
+            }
+
+            /** Returns approximate RAM bytes used */
+
+            public long RamBytesUsed()
+            {
+                return Fst == null ? 0 : Fst.SizeInBytes();
+            }
+        }
+
+        internal class IndexEnum : FieldIndexEnum
+        {
+            private readonly BytesRefFSTEnum<long> fstEnum;
+            private BytesRefFSTEnum<long>.InputOutput<long> current;
+
+            public IndexEnum(FST<long> fst)
+            {
+                fstEnum = new BytesRefFSTEnum<long>(fst);
+            }
+
+            public override BytesRef Term()
+            {
+                if (current == null)
+                {
+                    return null;
+                }
+                else
+                {
+                    return current.Input;
+                }
+            }
+
+            public override long Seek(BytesRef target)
+            {
+                //System.out.println("VGR: seek field=" + fieldInfo.name + " target=" + target);
+                current = fstEnum.SeekFloor(target);
+                //System.out.println("  got input=" + current.input + " output=" + current.output);
+                return current.Output;
+            }
+
+            public override long Next()
+            {
+                //System.out.println("VGR: next field=" + fieldInfo.name);
+                current = fstEnum.Next();
+                if (current == null)
+                {
+                    //System.out.println("  eof");
+                    return -1;
+                }
+                else
+                {
+                    return current.Output;
+                }
+            }
+
+            public override long Ord()
+            {
+                throw new NotImplementedException();
+            }
+
+            public override long Seek(long ord)
+            {
+                throw new NotImplementedException();
+            }
+        }
+
+    }
+}


[16/51] [abbrv] [partial] Cleaning up and getting ready to development towards v4.8

Posted by sy...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/releaseNotes.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/releaseNotes.html b/lib/NUnit.org/NUnit/2.5.9/doc/releaseNotes.html
deleted file mode 100644
index 0e1638d..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/releaseNotes.html
+++ /dev/null
@@ -1,1370 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - ReleaseNotes</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<style><!--
-li { padding-bottom: .5em; }
-ul ul li { padding-bottom: 0; }
-dt { font-weight: bold }
---></style>
-
-<h2>Release Notes</h2>
-
-<style><!--
-li { padding-bottom: .5em; }
-ul ul li { padding-bottom: 0; }
-dt { font-weight: bold }
---></style>
-
-<h3>NUnit 2.5.9 - Version 2.5.9.10348 - December 14, 2010</h3>
-
-<h4>Bug Fixes</h4>
-
-<ul>
-<li>423611 	Bug 686560 AppDomainUnloadedException not fixed
-<li>498664 	SetUp failure reported as FailureSite.Test
-<li>602761 	nunit-agent hangs after tests complete
-<li>612052 	NUnit-agent should be reused on reload
-<li>655882 	Make CategoryAttribute inherited
-<li>666800 	Throws.Nothing doesn't work properly
-<li>669317 	Loading test in separate process causes exception under Mono+Linux
-<li>669684 	Change Menu text from "Recent Files" to "Recent Projects"
-<li>669689 	Info from last run remains while loading a new project
-<li>671349	Add doc page for SetUICultureAttribute
-<li>671432	Upgrade NAnt to 0.90 or 0.91
-<li>673691 	nunit.exe session degrades with ever-lengthening "Reloading..." phase when test project is recompiled
-<li>674718	Reload when assembly changes setting disabled on Linux
-<li>674860	Using() modifier missing on NUnit.Framework.Contains.Item()
-<li>684513 	NUnit 2.5.8 Build Problems
-<li>684598 	Number of asserts in XML result file always stays 0
-<li>684821 	ResultSummarizer doesn't count tests with [RequiresSTA]
-</ul>
-<style><!--
-li { padding-bottom: .5em; }
-ul ul li { padding-bottom: 0; }
-dt { font-weight: bold }
---></style>
-
-<h3>NUnit 2.5.8 - Version 2.5.8.10295 - October 22, 2010</h3>
-
-<h4>General</h4>
-
-<ul>
-<li>The test file mock-assembly.dll has been enhanced to contain examples of all
-types of test suites for use in development of custom test reports.
-</ul>
-
-<h4>Framework</h4>
-
-<ul>
-<li>SubDirectoryConstraint has been removed and is replaced by SubPathConstraint, which operates on paths without the need to access the underlying directories.
-<li>Custom attributes may now be derived from ExplicitAttribute.
-<li>New key words "Windows7" and "Windows2008ServerR2" are recognized by the PlatformAttribute.
-<li>A warning is now given if a test changes the current directory.
-</ul>
-
-<h4>Console Runner</h4>
-
-<ul>
-<li>A new /trace option may be used to set NUnit's internal trace level for a console run.
-</ul>
-
-<h4>Gui Runner</h4>
-
-<ul>
-<li>Stability problems with the NUnit Gui under Linux have been resolved and NUnit 2.5.8 is the recommended release for all platforms. Various cosmetic fixes have been made under Linux as well, so that the Gui functions in the same way as it does under Windows.
-<li>A new setting dialog allows control of NUnit's InternalTrace facility, which was previously controlled by an entry in the config file.
-<li>Tests run out of process may be debugged by attaching to the nunit-agent process once,
-since the same process is now used across multiple reloads of the test assembly.
-</ul>
-
-<h4>Bug Fixes</h4>
-
-<ul>
-<li>487999  	 RequiresThreadAttribute not working on Windows 7 64-bit
-<li>491300  	 Self containing enumerables cause stack overflow when compared for equality
-<li>524474  	 NUnit GUI issue: /exclude categories are saved each time
-<li>602761  	 nunit-agent hangs after tests complete
-<li>603088  	 NUnit Gui: Project Config Change from Menu Does Not Change AssemblyWatcher
-<li>608897  	 Incorrect program name in Test Assemblies display under Mono
-<li>612052  	 NUnit-agent should be reused on reload
-<li>613031  	 Subclasses of ExplicitAttribute ignored
-<li>615340  	 Give warning if CurrentDirectory is changed
-<li>624603  	 Outdated copyright notice
-<li>631620  	 UnauthorizedAccessException in DirectoryAssert
-<li>631809  	 Misleading doc of CollectionAssert.AreEqual() and .AreEquivalent()
-<li>633884  	 TestCaseSource does not use Arguments, Categories etc as described in documentation for 2.5.7
-<li>641423  	 Timeout test fails under Mono on Linux
-<li>644252  	 Memory leak in ParameterizedMethodSuite
-<li>644643  	 NUnit uses fonts which may not be present on Linux
-<li>644682  	 Tab text not properly aligned under linux
-<li>644684  	 Tree display text is sometimes centered under linux
-<li>645430  	 Status bar panels not sized correctly under Linux
-<li>650598  	 Exception thrown when nunit-console run from networked drive on unit-tests built with .Net 4
-<li>654788  	 TestContext is null when the test/fixture has a timeout attribute
-<li>655674  	 New Fixture Object Suite requires pre-constructed objects to have a no-arg constructor
-<li>657797  	 Remove InternalTrace settings from config file
-<li>664081  	 Add Server2008 R2 and Windows 7 to PlatformAttribute
-<li>665236  	 Support for Mono 4.0 profile not detected in Linux
-</ul>
-<style><!--
-li { padding-bottom: .5em; }
-ul ul li { padding-bottom: 0; }
-dt { font-weight: bold }
---></style>
-
-<h3>NUnit 2.5.7 - Version 2.5.7.10213 - August 1, 2010</h3>
-
-<h4>Features</h4>
-
-<ul>
-<li>The new <b>TestContext</b> class allows tests to
-access information about themselves. The following properties
-are supported:
-<ul>
-<li><b>TestName</b> gets the name of the test
-<li><b>Properties</b> gets the test properties dictionary
-<li><b>State</b> gets the TestState
-<li><b>Status</b> gets the TestStatus
-</ul>
-<br><b>Notes:</b> 
-<ol>
-<li>This is an experimental feature and could change in future releases. It is not included in the docs at this time.
-<li><b>TestState</b> and <b>TestStatus</b> are intended for use in a TearDown method. Consult the intellisense for values of each enumeration. 
-<li><b>TestStatus</b> should preferred over <b>TestState</b> for compatibility with future releases.
-</ol>
-</ul>
-
-<h4>Bug Fixes</h4>
-
-<ul>
-<li>570162  FileNotFoundException when loading .nunit file
-<li>595683  NUnit console runner fails to load assemblies
-<li>611325  Allow Teardown to detect if last test failed
-<li>611938  Generic Test Instances disappear
-</ul>
-<style><!--
-li { padding-bottom: .5em; }
-ul ul li { padding-bottom: 0; }
-dt { font-weight: bold }
---></style>
-
-<h3>NUnit 2.5.6 - Version 2.5.6.10205 - July 24, 2010</h3>
-
-<h4>Features</h4>
-
-<ul>
-<li><b>ReusableConstraint</b> provides reusability of constraint
-expressions within the test code. This feature is experimental.
-<li>The <b>Mono 4.0</b> profile is now listed in the Gui when support for it is detected.
-<li>Multiple test names may be supplied to the console <b>/run</b> option.
-<li><b>Dictionaries</b> and <b>Hashtables</b> may be tested for equality without regard to order of entries.
-<li><b>PNunit</b> has been updated to match the latest release available.
-<li><b>DirectoryAssert</b>, xxxx and xxx are now marked as Obsolete.
-</ul>
-
-<h4>Bug Fixes</h4>
-
-<ul>
-<li>441022 	Setup not called when test method inherited
-<li>498656 	TestCase should show array values in GUI
-<li>532488 	Constraints from ConstraintExpression/ConstraintBuilder are not reusable
-<li>548841  [Explicit] does not get overridden if there is another category exclude
-<li>570162 	FileNotFoundException when loading .nunit file
-<li>571256 	NUnit 2.5.5 Console Runner Requires /framework flag to run with .NET 4
-<li>574408 	DirectoryAssert fails to recognise the sub folder using IsWithin
-<li>590717 	Category contains dash or trail spaces is not selectable
-<li>590970 	Static TestFixtureSetUp/TestFixtureTearDown methods in base classes are not run
-<li>591622 	When SetUp method fails, no clear indication in GUI
-<li>595996 	Missing files in source package
-<li>600554 	NUnit uses wrong priority-scheme for addins
-<li>600555 	NullReferenceException when ISuiteBuilder.BuildFrom(Type) returns null
-<li>600627 	Assertion message formatted poorly by PropertyConstraint
-<li>601108 	Duplicate test using abstract test fixtures
-<li>601129 	Mono 4.0 not supported
-<li>601645 	Parameterized test should try to convert data type from source to parameter
-<li>602798 	NUnitConfiguration.MonoExePath returns wrong path
-<li>604861 	Console runner /run option should allow multiple test names
-<li>605432  ToString not working properly for some properties
-<li>605793 	Multiple instances of Nunit runners, which use nunit-agent, cannot be run in parallel
-<li>607924 	PNUnit is out of date
-<li>608875 	NUnit Equality Comparer incorrectly defines equality for Dictionary objects
-<li>606548 	Deprecate Directory Assert
-<li>609509  Test assembly file lock in version 2.5.5 
-</ul>
-<style><!--
-li { padding-bottom: .5em; }
-ul ul li { padding-bottom: 0; }
-dt { font-weight: bold }
---></style>
-
-<h3>NUnit 2.5.5 - Version 2.5.5.10112 - April 22, 2010</h3>
-
-<h4>Features</h4>
-
-<ul>
-<li>The Runtime Version dropdown on the <b>Project Editor</b> dialog
-now includes only major and minor version numbers like 2.0 or 4.0.
-When loading the tests, these versions are resolved to the highest 
-version of the particular runtime available on your system. You may
-still enter a complete version number in the text box if desired.
-<li>The <b>DatapointsAttribute</b> may now be specified on properties
-and methods as well as fields. For parameters of type T, the attribute
-now supports members of Type <b>IEnumerable&lt;T&gt;</b> in addition
-to arrays of the parameter Type.
-<li>Timeouts are now suppressed when running under a debugger.
-</ul>
-
-<h4>Bug Fixes</h4>
-
-<ul>
-<li>FileNotFoundException when test assembly is built for x64 platform.
-<li>Config files not found with /domain:Multiple.
-<li>SetCultureAttribute ignored on parameterized test methods.
-<li>NUnit not recognizing .NET 4.0 RC or Final Release.
-<li>TestFixtureTearDown in static class not executed
-<li>Failing tests in sample files AssertSyntaxTests.cs and AssertSyntaxTests.vb.
-<li>Invalid XML character in TestResult.xml when a test case string argument
-uses certain control or unicode characters.
-</ul>
-<style><!--
-li { padding-bottom: .5em; }
-ul ul li { padding-bottom: 0; }
-dt { font-weight: bold }
---></style>
-
-<h3>NUnit 2.5.4 - Version 2.5.4.10098 - April 8, 2010</h3>
-
-<h4>Features</h4>
-
-<ul>
-<li>NUnit now defaults to running an assembly under the runtime version for
-which it was built. If that version is not available, a higher version may be
-used. See the <a href="runtimeSelection.html">Runtime Selection</a> 
-page for details.
-<li><b>ProjectEditor</b> now provides a 'Default' selection for the runtime
-version to be used.
-<li>The XML result file format has been enhanced to provide additional information
-needed to identify and report on theories and also includes extended result states
-such as Inconclusive, Invalid, Error and Cancelled.
-<li>The <b>EmptyConstraint</b> (Is.Empty) may now be used with a <b>DirectoryInfo</b>
-to test whether the directory is empty.
-<li>Datapoints for <b>boolean</b> and <b>enum</b> arguments are now generated 
-automatically for theories.
-<li>The cache path for shadow copying is now saved in the NUnit settings file
-rather than in the config files. The settings dialog may be used to change it
-if necessary.
-</ul>
-
-<h4>Bug Fixes</h4>
-
-<ul>
-<li>NUnit crashing when a message contains ']]>'
-<li>Replace compile-time exclusion of code from Mono with run-time test
-<li>Message associated with Assert.Inconclusive() not shown in XML
-<li>Category on test case clashes with category on the test method
-<li>Console crash when specifying /domain:Single with multiple assemblies
-<li>Incorrect relative path causing problems in saving projects
-<li>Message associated with Assert.Pass() not shown in XML
-<li>Tests with ExpectedException compiled against NUnit 2.4 always pass under 2.5
-<li>Datapoints with a null value were not being passed correctly to theories
-<li>Error in XML output with FSharp.Net
-<li>Documentation refers to files missing from Windows install
-<li>Parameterized test fixtures with null parameters not handled correctly
-<li>Theories now work as designed, failing when no data satisfies the assumptions
-<li>Target framework of net-3.5 was causing console to crash
-<li>Mono stack traces are now parsed correctly in the Gui
-<li>Test failures under .NET 1.1
-<li>Thread CurentPrincipal set in TestFixtureSetUp not maintained between tests
-</ul>
-<style><!--
-li { padding-bottom: .5em; }
-ul ul li { padding-bottom: 0; }
-dt { font-weight: bold }
---></style>
-
-<h3>NUnit 2.5.3 - Version 2.5.3.9345 - December 11, 2009</h3>
-
-<p><b>Note:</b> This is the first release of NUnit on Launchpad.
-   
-<h4>Features</h4>
-
-<ul>
-<li>Test execution under .NET 4.0 is now supported. It may be selected
-    in the Gui runner or using the console runner /framework option.
-	NUnit test projects may specify .NET 4.0 as the required framework
-	to be used for loading the the project. PlatformAttribute allows 
-	testing for .NET 4.0.
-<li>The distribution now includes nunit-agent-x86.exe, which is used
-    for running tests in a separate process under nunit-x86.exe
-	or nunit-console-x86.exe when the target framework is .NET 2.0
-	or greater.
-<li>Static methods Contains.Substring() and Contains.Item() have been
-    added to the NUnit syntax for compatibility with NUnitLite.
-<li>Non-public test fixtures are now allowed in all cases, 
-    whether the TestFixtureAttribute is present or not.
-<li>Abstract classes may now be marked with TestFixtureAttribute
-    to indicate that derived classes are to be treated as 
-	test fixtures. The abstract class is no longer marked as invalid.
-<li>Fixtures without tests are no longer shown as non-runnable but
-    are simply executed. If the fixture setup or teardown does not cause
-	an error, they are reported as inconclusive.
-</ul>
-
-<h4>Bug Fixes</h4>
-
-<ul>
-<li>Reloading tests in the Gui no longer uses the default runtime if
-    a different runtime was previously selected.
-<li>Thread principal is now saved before each test and restored afterward
-    eliminating failures under .NET 4.0.
-<li>Assume.That() overload with a message no longer results in test failure.
-<li>An expected Result of null is now handled correctly on parameterized tests.
-<li>Duplicate caching of metadata has been eliminated, resolving a
-    load performance problem when many methods are inherited from
-	a base class.
-<li>The names of nested generic and non-generic classes are now displayed 
-    correctly.
-<li>Assert.Catch&lt;T&gt; now correctly returns exception type T rather than
-    System.Exception.
-<li>ValueSourceAttribute now works correctly when used with an external type.
-<li>The /domain=None option on nunit-console once again works correctly.
-<li>Parameterized test fixture names are now displayed with the actual
-    arguments used so that failures may be associated with the correct
-	instantiation of the fixture.
-<li>Test labels for generics are now displayed correctly by the console
-    runner and in the Gui text output tab.
-<li>Generic fixtures without type attributes provided are now shown
-    as non-runnable rather than causing a runtime error. (1)
-<li>Use of an unknown file type in the console command line no longer causes
-    an error. (2)
-<li>A number of tests that ran incorrectly under Linux have been fixed.
-<li>A number of tests failing under .NET 4.0 have been fixed.
-</ul>
-
-<h4>Notes</h4>
-
-<ol>
-<li>As a side effect of this fix, TestFixtureAttribute on a base class is
-    overridden by a TestFixtureAttribute on the derived class. 
-<li>This was originally reported as "crash when using /option in linux."
-</ol>
-<style><!--
-li { padding-bottom: .5em; }
-ul ul li { padding-bottom: 0; }
-dt { font-weight: bold }
---></style>
-
-<h3>NUnit 2.5.2 - Version 2.5.2.9222 - August 10, 2009</h3>
-
-<p><b>Note:</b> This is the last release of NUnit using source code
-   maintained on Sourceforge. The CVS repository there will be kept,
-   but no longer updated. After this release, the source is being
-   maintained on Launchpad at http://launchpad.net/nunit-2.5.
-
-<h4>Framework</h4>
-
-<ul>
-<li>The new <b>SetUICultureAttribute</b> allows setting CurrentUICulture
-    for the duration of a test method, fixture or assembly.
-<li>The <b>TestFixture</b>, <b>TestCase</b> and <b>TestCaseData</b> attributes
-    have been enhanced to allow ignoring an individual fixture instance or
-	test case. Two new named parameters are provided:
-	<ul>
-	<li><b>Ignore</b> may be set to true to ignore an item.
-	<li><b>IgnoreReason</b> may be set to specify the reason for ignoring
-	    the item. If IgnoreReason is set to a non-empty string, then setting
-		Ignore is optional.
-	</ul>
-<li><b>Assert.Catch</b> has been added with several overloads. It differs
-    from <b>Assert.Throws</b> in accepting exceptions derived from the one
-	that is specified. Like <b>Assert.Throws</b>, it returns the exception
-	thrown when it succeeds so that further tests can be made on it.
-<li>The <b>Throws</b> syntax has a number of new additions:
-    <ul>
-	<li><b>ThrowsTargetInvocationException</b>, <b>ThrowsArgumentException</b>
-	    and <b>Throws.InvalidOperationException</b> provide a shorter syntax
-		for testing for these common exception types.
-	<li><b>Throws.InnerException</b> applies any constraints to the InnerException 
-	    of the exception that was thrown rather than to the exception itself.
-	<li><b>InnerException</b> can also be used in constraint expressions - see
-	    the documentation for an example.
-	</ul>
-</ul>
-
-<h4>Bug Fixes</h4>
-
-<ul>
-<li>Data from a TestCaseSource in a separate class from the tests
-    is now handled correctly.
-<li>Arguments specified using TestCaseData are now used correctly.
-<li>Comparing the a stream to itself no longer causes an error.
-<li>TimeoutAttribute is now permitted on an assembly as documented.
-<li>Clear All and Clear Failures buttons are now displayed correctly
-    depending on whether Checkboxes are displayed in the Gui.
-<li>The console runner option descriptions have been revised to
-    more clearly indicate what each option does.
-<li>Running special tests that do not use the nunit.framework assembly
-    no longer causes a null reference exception.
-<li>Console Runner option descriptions have been edited for accuracy.
-<li>Gui TreeView now updates correctly when the order of tests has changed.
-<li>An exception in TearDown now displays the actual exception
-    at the top of the stack rather than a TargetInvocationException.
-</ul>
-<style><!--
-li { padding-bottom: .5em; }
-ul ul li { padding-bottom: 0; }
-dt { font-weight: bold }
---></style>
-
-<h3>NUnit 2.5.1 - Version 2.5.1.9189 - July 8, 2009</h3>
-
-<h4>Framework</h4>
-
-<ul>
-<li>A new <b>TestResult</b> state has been defined for tests cancelled by the
-    user. Results with <b>ResultState.Cancelled</b> are reported as a type of
-	failure and no longer generate an ApplicationException.
-<li>Parameterized test fixtures with <b>TestCaseSource</b> or <b>ValueSource</b> 
-	data are now constructed using the appropriate parameterized constructor 
-	when test cases are being created. This avoids the need for a default
-	constructor and permits use of member data initialized from
-	the fixture parameters in creating the test data.
-<li>The <b>TestCaseData</b> class now supports use of a string or other
-    array type as the sole argument value, without the need to nest
-	that array in an object array.
-<li>Abstract classes marked with <b>TestFixtureAttribute</b> are no longer
-    reported as ignored or non-runnable.
-	<br><br>
-	<b>Note:</b> This was changed in 2.5 but was omitted from the release notes.
-<li>The methods in the <b>Text</b> class are now marked as obsolete. For string 
-	constraints, use one of the following at the start of an expression:
-	<ul>
-	<li><b>Is.StringContaining</b>
-	<li><b>Is.StringStarting</b>
-	<li><b>Is.StringEnding</b>
-	<li><b>Is.StringMatching</b>
-	</ul>
-	Within an expression (afer Not, Some, All, And, Or, etc.) you may use
-	<ul>
-	<li><b>Contains</b> or <b>ContainsSubstring</b>
-	<li><b>StartsWith</b>
-	<li><b>EndsWith</b>
-	<li><b>Matches</b>	
-	</ul>
-<li><b>ThrowsConstraint</b> now has a constructor taking an <b>ActualValueDelegate</b>
-    in addition to the constructor that takes a <b>TestDelegate</b>. This allows
-	simpler use of Lambda expressions under C# 3.0, but requires users of pre-3.0
-	compilers to disambiguate their delegates by use of an explicit return
-	expression.
-</ul>
-
-<h4>Core</h4>
-
-<ul>
-<li>Individual test cases under a parameterized test are
-    no longer sorted by name within the test group but are
-	run (and shown in the Gui) in the order in which the
-	data is retrieved.
-	<br><br>
-	<b>Note:</b> Since the order of retrieval of custom
-	attributes is not guaranteed by the CLR, the order
-	of test cases will not necessarily match the textual
-	ordering of attributes in the source code. The order
-	of tests will vary across different compilers and
-	CLR versions as well.
-<li>The XML test result file now contains a count of 
-	inconclusive results.
-</ul>
-
-<h4>Gui</h4>
-
-<ul>
-<li>The default icons in the Gui tree have been updated.
-<li>Alternative icons placed by the user in the directory containing
-    nunit.uikit.dll may now be in PNG format. Icons are now recognized
-	for Skipped and Inconclusive status in addition to Success, Failure
-	and Ignored.
-<li>A new setting option allows the user to disable checking for the 
-    existence of files in the Recent Files list before listing them. This
-    prevents NUnit from appearing to freeze when the file is on a network
-    path that is no longer connected.
-</ul>
-
-<h4>Extensibility</h4>
-
-<ul>
-<li>The <b>ITestCaseProvider2</b> and <b>IDatapointProvider2</b> interfaces
-    extend <b>ITestCaseProvider</b> and <b>IDatapointProvider</b>
-    with methods that include the fixture for which the test case is being
-    built. Providers may implement either the old or the new interface, 
-	but the new interface is required if the data source is contained in
-	the test fixture itself so that the fixture may be constructed with
-	the proper parameters in the case of a parameterized fixture.
-</ul>
-
-<h4>Bug Fixes</h4>
-
-<ul>
-<li>Lambda in Throws constraint was not compiling correctly.
-<li>Null reference exception is no longer thrown when adding an assembly to a 
-    new project that has not yet been saved.
-<li>Dispose is now called on disposable types created while loading test case 
-    parameters.
-<li>Installations that copy NUnit to a single folder (no lib or framework folders) 
-    now work correctly.
-<li>Test Assemblies menu item is no longer enabled when no test was loaded
-<li>The Text Output tab of the Settings dialog no longer causes an exception
-    when invoked from the mini-gui.
-<li>Errors in various copyright statements were fixed and the year updated to 2009.
-<li>Control characters in test arguments are now escaped in the display.
-<li>Additional control characters are now escaped in error messages.
-<li>Miscellaneous typographic corrections were made to the documentation.
-</ul>
-<h3>NUnit 2.5 Final Release - Version 2.5.0.9122 - May 2, 2009</h3>
-
-<h4>Framework</h4>
-
-<ul>
-<li>A new syntax element, <b>Matches(Constraint)</b>, allows use of
-custom constraints, predicates or lambda expressions in constraint expressions.
-
-<li>The <b>MessageMatch</b> enum used with <b>ExpectedExceptionAttribute</b>
-has been extended with a new value <b>StartsWith</b>, indicating that the
-exception message must start with the string provided.
-
-<li><b>TestCaseAttribute</b> now supports a <b>MessageMatch</b>
-property.
-</ul>
-
-<h4>Gui</h4>
-
-<ul>
-<li>The File menu now allows selecting an alternate runtime,
-such as Mono, on a machine with multiple CLR implementations
-installed. This feature is still considered experimental and
-may change in the future.
-
-<li>The combo box in the Project Editor allowing selection of
-a particular runtime type such as Mono for loading the test
-has been re-enabled.
-</ul>
-
-<h4>Bug Fixes</h4>
-
-<ul>
-<li>Provided a workaround to a Mono 2.4 bug in handling remote 
-references to an interface, where the provider is running under
-MS .NET and the implementation is explicit.
-
-<li>Fixed a problem with the display of line numbers from a German
-language stack trace, with lines terminating in a period.
-
-<li> The Console Runner display now shows the settings for ProcessModel,
-DomainUsage and RuntimeFramework actually provided, before resolution
-of any defaults.
-
-<li> Removed references in the docs to pages that no longer exist.
-</ul>
-
-<h3>NUnit 2.5 Release Candidate - Version 2.5.0.9117 - April 27, 2009</h3>
-
-<h4>General</h4>
-
-<ul>
-<li>The installation now uses a 'lib' subdirectory to hold dlls.
-
-<li>The build script target names have been changed to make more sense.
-In particular, 'package' now builds the default package and
-targets not intended to be called directly are no longer listed
-as 'Main Targets' by the -projecthelp option.
-</ul>
-
-<h4>Framework</h4>
-
-<ul>
-<li>The following Constraints now use the NUnit definition
-of equality in comparing items, which may lead to changed behavior 
-of some tests.
-   <ul><b>
-   <li>UniqueItemsConstraint
-   <li>CollectionContainsConstraint
-   <li>CollectionEquivalentConstraint
-   <li>CollectionSubsetConstraint
-   </b></ul>
-The constraints listed now accept the <b>IgnoreCase</b> and <b>Using</b>
-modifiers, which work exactly as they do with <b>EqualConstraint</b>
-</ul>
-
-<h4>Core</h4>
-
-<ul>
-<li>Caching is now used to reduce the time required to load tests.
-</ul>
-
-<h4>Gui</h4>
-
-<ul>
-<li>A new submenu under <b>File</b> allows selecting a runtime version
-under which to reload the tests. Reloading in this way does not affect
-any runtime version setting in the project file.
-
-<li>The project editor now provides a combo box listing known versions
-of the runtime. Other versions may still be entered in the edit box.
-Cross-CLR execution (for example, running Mono from .NET) has
-been disabled in the Gui, since it isn't yet implemented.
-
-<li>The new stack trace display now follows the NUnit Font settings.
-The stack display uses the general gui font, while the source code
-display uses the fixed font.
-
-<li>The separate settings for Recent Files under .NET 1.1
-and .NET 2.0 have been combined, since the Gui now runs exclusively
-under .NET 2.0.
-
-<li>The time required to restore the visual state of the tree after
-reloading has been substantially reduced, especially for large numbers
-of tests.
-</ul>
-
-<h4>Bug Fixes</h4>
-
-<ul>
-<li>Use of a long assembly name for the ApplicationName of the AppDomain
-was causing excessively long paths in the shadow cache.
-
-<li>The <b>Using</b> modifier of <b>EqualConstraint</b> now works as
-expected for string operands.
-
-<li><b>TestCaseAttribute.ExpectedExceptionMessage</b> is no longer ignored.
-
-<li>The max number of files setting was not being saved when modified
-in the Gui Settings dialog.
-
-<li>As a temporary fix, the pnunit.tests.dll has been moved to the 
-same directory as pnunit-agent.exe and pnunit-launcher.exe, since
-pnunit tests don't allow for setting an appbase separate from the
-location of the test assembly.
-</ul>
-
-<h3>NUnit 2.5 Beta 3 Release - Version 2.5.0.9096 - April 6, 2009</h3>
-
-<h4>General</h4>
-
-<ul>
-<li>The Gui is now built against .NET 2.0 only. Tests may still
-be run under .NET 1.x by running in a separate process.
-
-<li>The Visual Studio 2003 solution has been removed. Framework
-and other components may still be built under .NET 1.x through
-the NAnt script.
-
-<li>The nunit.framework.extensions assembly has been removed
-from the build.
-</ul>
-
-<h4>Framework</h4>
-
-<ul>
-<li><b>EqualConstraint</b> has been enhanced with
-    several new modifiers, which may be used immediately after
-	the Within(...) modifier to indicate how a numeric tolerance value
-	should be interpreted.
-	<ul>
-	<li><b>Ulps</b> = as units in the last place (floating point only)
-	<li><b>Percent</b> = as a percentage of expected value
-	<li><b>Days</b> =  as a TimeSpan in days
-	<li><b>Hours</b> = as a TimeSpan in hours
-	<li><b>Minutes</b> = as a TimeSpan in minutes
-	<li><b>Seconds</b> = as a TimeSpan in seconds
-	<li><b>Milliseconds</b> = as a TimeSpan in milliseconds
-	<li><b>Ticks</b> = as a TimeSpan in ticks
-	</ul>
-
-<li>The comparison constraints (<b>GreaterThan</b>, <b>LessThan</b>, etc.),
-    <b>RangeConstraint</b> and <b>CollectionOrderedConstraint</b> may now be used 
-	with 	objects that implement <b>IComparable&lt;T&gt;</b>.
-    
-<li>The syntax used for specifying that a collection is ordered has changed.
-    <b>Is.Ordered</b> is now a property. The property name to use for ordering
-	is specified using <b>Is.Ordered.By(name)</b>.
-	
-<li>The following constraints now accept a <b>Using</b> modifier to indicate
-    that a user-specified comparer should be used:
-	<ul><b>
-	<li>EqualConstraint
-	<li>GreaterThanConstraint
-	<li>GreaterThanOrEqualConstraint
-	<li>LessThanConstraint
-	<li>LessThanOrEqualConstraint
-	<li>RangeConstraint
-	<li>CollectionOrderedConstraint
-	</b></ul>
-	The provided comparer may be any of the following:
-	<ul><b>
-	<li>IComparer
-	<li>IComparer&lt;T&gt;
-	<li>Comparison&lt;T&gt;
-	</b></ul>
-	In addition, <b>EqualConstraint</b> may use:
-	<ul><b>
-	<li>IEqualityComparer
-	<li>IEqualityComparer&lt;T&gt;
-	</b></ul>
-</ul>
-
-<h3>NUnit 2.5 Beta 2 Release - Version 2.5.0.9015 - January 15, 2009</h3>
-
-<h4>Framework</h4>
-
-<ul>
-<li>NUnit now includes an implementation of <b>Theories</b>, similar to what
-    is found in JUnit. Support for Theories is provided by the
-	<b>Theory</b>, <b>Datapoint</b> and <b>Datapoints</b> attributes and by
-	the <b>Assume.That</b> method. For more information and further links, 
-	see the <a href="theory.html">TheoryAttribute</a> 
-	documentation page.
-<li>AssertionHelper has been updated so that the Expect overloads now
-    include the signatures newly introduced for Assert.That.
-<li>The code for Assert is now generated. This is in addition to the files 
-    that were generated in beta-1.
-<li><b>AfterConstraint</b> has been renamed to <b>DelayedConstraint</b>.
-</ul>
-
-<h4>Console</h4>
-
-<ul>
-<li>The console runner now supports a <b>/framework</b> option, which
-    allows running the tests under a different version of the CLR.
-</ul>
-
-<h4>Gui</h4>
-
-<ul>
-<li>The Gui is now able to display the source code for test or production
-    code from the stack trace, provided the assemblies contain source code
-    information and the source code is available. Contributed by Ir�n�e Hottier.
-<li>Reloading the tests after changing settings in a way that modifies
-    the shape of the tree is now handled correctly.
-<li>The Settings Dialog now opens to the page that was last viewed.
-</ul>
-
-<h3>NUnit 2.5 Beta 1 Release - Version 2.5.0.8332 - November 27, 2008</h3>
-
-<h4>General</h4>
-
-<ul>
-<li>Most of the code for elements of the constraint
-    syntax is now generated. This allows us to more rapidly deploy new 
-	constraints with their corresponding syntax. The file <b>SyntaxElements.txt</b>
-	contains the specifications used in generating the code. At this time,
-	we are including both this file and the generated files with the NUnit source,
-	so that those working in other areas of the code don't have to regenerate 
-	them each time they make changes.
-<li>The nunit.core.extensions assembly has been removed from the build. Features
-    that were previously in that assembly are now in the nunit.core assembly.
-<li>All third-party addins have been removed from the build and must be
-    downloaded separately from their own sites. An index of such
-	addins is maintained on the NUnit site.
-</ul>
-
-<h4>Framework</h4>
-<ul>
-<li>New attributes are provided to control use of threads by tests. All of
-   the following may be used on methods, classes or assemblies:
-   <ul>
-   <li><b>RequiresThreadAttribute</b> forces creation of a new thread and
-       may optionally indicate the desired ApartmentState for the thread.
-   <li><b>RequiresSTAAttribute</b> causes the test to run in the STA. A
-       new thread is created only if the parent is not in the STA. On
-	   methods, the .NET-provided STAThreadAttribute may also be used.
-   <li><b>RequiresMTAAttribute</b> causes the test to run in the MTA. A
-       new thread is created only if the parent is not in the MTA. On
-	   methods, the .NET-provided MTAThreadAttribute may also be used.
-   <li><b>TimeoutAttribute</b> is used to set the timeout for tests. When
-       used on classes or assemblies, the timeout value is used as the
-	   default timeout for all subordinate test cases. Test cases with
-	   a timeout value run on a separate thread and return a failure
-	   message if the timeout is exceeded.
-   </ul>
-<li>The <b>MaxTimeAttribute</b> specifies a miximum elapsed time for a
-	test case. If the test takes longer, it is reported as a failure.
-	This attribute was previously available as an extension.
-	<br><br>
-	<b>Note:</b> Unlike <b>TimeoutAttribute</b>, <b>MaxTimeAttribute</b>
-	does not cause the test to be cancelled, but merely times it.
-<li><b>RepeatAttribute</b> causes a test case to be executed multiple
-    times. This attribute was previously available as an extension.
-<li><b>PairwiseAttribute</b> now works, generating all pairs of each
-    argument value. [In earlier betas, it was unimpemented and simply
-	generated all combinations.]
-<li><b>PropertyAttribute</b> has been modified internally to use a dictionary
-    of name/value pairs rather than just a single name and value. This feature
-	is not exposed for direct use, but may be accessed by derived attributes
-	that want to apply multiple named values to the test. For a simple 
-	example of usage, see the code for <b>RequiredThreadAttribute</b>.
-<li>The presence of <b>TestCaseSourceAttribute</b> on a method is now
-    sufficient to identify it as a test. As with <b>TestCaseAttribute</b>,
-	use of <b>TestAttribute</b> is optional.
-<li><b>Assert.That</b> has been extended to allow a delegate or a reference 
-	as the argument. By default, these are evaluated before being used by
-	the constraint supplied but some constraints may delay evaluation. The
-	new <b>AfterConstraint</b> is an example.
-<li>An additional overload of <b>Assert.Throws</b> allows passing a
-    constraint or constraint expression as the first argument.
-<li>The syntax for AttributeConstraints has been enhanced so that further
-    tests may be applied to properties of the attribute rather than just
-	checking for its existence.
-<li><b>AfterConstraint</b> allows delaying the application of a constraint
-    until a certain time has passed. In it's simplest form, it replaces
-	use of a Sleep in the code but it also supports polling, which may
-	allow use of a longer maximum time while still keeping the tests as
-	fast as possible. The <b>After</b> modifier is permitted on any
-	constraint, but the delay applies to the entire expression up to the
-	point where <b>After</b> appears. 
-	<br><br>
-	<b>Note:</b> Use of After with a simple value makes no sense, since
-	the value will be extracted at the point of call. It's intended use
-	is with delegates and references. If a delegate is used with polling,
-	it may be called multiple times so only methods without side effects
-	should be used in this way.
-</ul>
-
-<h4>Core</h4>
-
-<ul>
-<li>NUnit now supports running tests in a separate process or in
-    multiple processes per assembly. In addition, tests run in
-	a separate process may use a different runtime version
-	from that under which NUnit is running.
-	<br><br>
-	<b>Note:</b> In the Beta release, execution of tests under Mono 
-	from a copy of NUnit that is running under .NET is not yet supported.
-</ul>
-
-<h4>Console</h4>
-
-<ul>
-<li>The new <b>/process:xxxxx</b> command line option is used to run
-    tests in a separate process or in multiple processes per assembly.
-<li>A new commandline option, <b>/timeout:nnnn</b> allows you to specify a
-    default timeout value, which is applied to each test case in the run without
-    a Timeout specified.
-</ul>
-
-<h4>Gui</h4>
-
-<ul>
-<li>The Assembly Info display now uses a scrolling text box and has
-    been enhanced to show information about the Process and AppDomain
-	in which the test is running and the runtime version under that
-	is being used.
-<li>The Project Editor now allows setting the ProcessModel and
-    DomainUsage for a project to control how that project is
-	loaded and run. It also supports setting a target runtime
-	framework for each configuration. If the target runtime is
-	different from the runtime under which NUnit is running, the
-	tests will be run automatically in a separate process under
-	the target runtime.
-<li>The Project Editor no longer reloads the tests as each
-    individual change is made. Tests are reloaded after the
-	editor is closed and only if changes have been made to
-	the overall project configuration or to the active
-	configuration.
-<li>The "Options" dialog is now called "Settings."
-</ul>
-
-<h4>Extensibility</h4>
-
-<ul>
-<li>The implementation of constraints has been changed so that it is no
-    longer necessary to create an additional "Modifier" class when a
-	custom constraint takes modifiers. If you simply implement each modifier
-	as a property or method returning the object itself, it will be 
-	usable in the full range of constraint expressions.
-	<br><br>
-	<b>Note:</b> Although you can readily create custom constraints,
-	this release of NUnit still lacks the ability to create new syntactic
-	elements without rebuilding the framework.
-</ul>
-
-<h4>Bug Fixes</h4>
-
-<ul>
-<li>Loading a single assembly and then adding another assembly using
-    the Add Assembly menu item was not working correctly.
-<li>Reloading tests after settings changes was failing when the
-    new settings changed the shape of the tree in such a way
-	that the new tests didn't match the old ones correctly.
-<li>The Reload Project menu item was followed by a prompt asking
-    if the current project state should be saved first and making
-	the reload work in an unexpected way if you answered yes.
-<li>A class without a TestFixture attribute, containing only
-    TestCase methods, without any Tests, was not recognized as
-	a test fixture.
-<li>Assert.DoesNotThrow was failing to display a user message.
-<li>Xml documentation for Assert.IsNotEmpty and Assert.AreEqual
-    was incorrect.
-<li>CollectionAssert.AreEqual and EqualConstraint were not
-    working with IEnumerables that were not also Collections.
-<li>PlatformAttribute now distinguishes correctly between
-    Vista and Windows 2008 Server.
-</ul>
-
-<h3>NUnit 2.5 Alpha 4 Release - Version 2.5.0.8528 - September 14, 2008</h3>
-
-<h4>Framework</h4>
-<ul>
-<li>Use of the TestFixtureAttribute is now optional in designating
-    classes that contain tests.
-<li>More than one method may now be marked with the <b>SetUp</b>, <b>TearDown</b>,
-	<b>TestFixtureSetUp</b> and <b>TestFixtureTearDown</b> attributes. Setups
-	in a base class are executed before those in a derived class and teardowns
-	are executed in the reverse order. If there are multiple setups or teardowns
-	defined at the same level, the order is unspecified so this practice is
-	not generally recommended.
-<li>The <b>FactoryAttribute</b> and <b>TestCaseFactoryAttribute</b> introduced 
-   in alhpa-3 have been removed. The new <b>TestCaseSourceAttribute</b> allows
-	specification of the name of the source of test cases and - optionally - the 
-	type providing the source if it is not the same as the type that contains the 
-	test. Only one source may be specified per attribute but the attribute may be 
-	applied more than once to indicate multiple sources.
-<li>It is now possibe to specify Categories and Properties on test cases
-    defined using the TestCaseData class.
-<li>Named fields, properties or methods may be used to provide values for
-    individual method parameters using the new <b>ValueSourceAttribute</b>.
-<li>New constraints and corresponding syntactic constructs are provided: 
-	<ul>
-	<li><b>Is.InRange</b> tests that a value lies within a specified range.
-	<li><b>Has.Attribute()</b> tests for the presence of a specified attribute
-		on a type.
-	<li><b>Is.AssignableTo</b> allows reversing the operands of AssignableFrom 
-		for increased clarity in the code and in any error messages when the
-		actual value is of the derived type.
-	<li><b>Throws.Exception</b> allows testing the exception thrown by a
-	    delegate in place and provides the ability to make arbitrary tests
-		on the caught exception. <b>Throws.TypeOf()</b> and <b>Throws.InstanceOf()</b>
-		are provided as shorthand for the commonly used <b>Throws.Exception.TypeOf()</b>
-		and <b>Throws.Exception.InstanceOf</b>.
-	<li><b>Throws.Nothing</b> provides for testing that a delegate does
-	    not throw. While it doesn't do much, it serves the purpose of
-		converting an unexpected error into a test failure.
-	</ul>
-<li>The parsing of constraint expressions written using the fluent interface
-    has been reorganized internally, with the following benefits:
-    <ul>
-	<li>Meaningless sequences like "...Null.Null..." or "...And.Or..."
-	    will no longer compile - the NUnit tests actually verify this
-		by attempting to compile them.
-	<li>Syntax modifiers like <b>Within</b> and <b>IgnoreCase</b> are
-	    now only accepted - and shown by intellisense - on constraints that
-	    actually make use of them.
-    <li>New <b>And</b> and <b>Or</b> infix operators are provided.
-	<li>The <b>With</b> provides some ability to group constraints.
-    </ul>	
-    
-	<p><p><b>Note:</b> Operators are evaluated in the following order:
-	<ol>
-	<li>Postfix modifiers (highest)
-	<li>Not Operator
-	<li>And operator (see below)
-	<li>Or operator  (see below)
-	<li>With operator
-	<li>Some, None and All operators
-	<li>And operator when followed directly by Some, None or All
-	<li>Or operator when followed directly by Some, None or All
-	<li>Overloaded operator &amp;
-	<li>Overloaded operator | (lowest)
-	</ol>
-	Operators of equal precedence associate left to right.
-	
-<li>The "syntax helper" classes, <b>Is</b>, <b>Has</b>, <b>Text</b> and
-    <b>List</b> have been moved to the NUnit.Framework namespace, since they 
-	seem to have entered the mainstream.
-<li>NUnit 2.5 is able to recognize, load and run NUnitLite tests.
-<li>PropertyConstraint now works with Types when testing for the
-    existence of a named property.
-</ul>
-
-<h4>Core</h4>
-<ul>
-<li>Experimental support is provided for running tests in a separate process.
-    Currently, this is only exposed in the Gui runner.
-<li>NUnit recognizes a special attribute on
-    the config element of the nunit project file, <b>runtimeFramework</b>,
-	which may be set to "net-1.1" or "net-2.0." This causes use of the
-	appropriate runner if tests are run in a separate process.
-	<p><p>
-	<b>Note:</b> Both of the above features are experimental and
-	somewhat fragile. Results are expected to vary for different
-	installations and we ask that problems be reported.
-</ul>
-
-<h4>Gui</h4>
-
-<ul>
-<li>The Addin Dialog now shows an error message for any addin that
-    fails to load.  (from 2.4.8)
-<li>The TestLoader settings dialog provides an option for running tests
-    in a separate process.
-<li>The Assembly Info display now shows two runtime versions for each
-    test assembly: the one for which it was built and the one under
-	which it is currently loaded.
-</ul>
-
-<h4>Extensibility</h4>
-
-<ul>
-<li>The <b>RequiredAddinAttribute</b> is now only permitted at the assembly level.
-</ul>
-
-<h4>Bug Fixes</h4>
-
-<ul>
-<li>The Gui output panes were failing to use a fixed font. (from 2.4.8)
-</ul>
-
-<h3>NUnit 2.5 Alpha 3 Release - Version 2.5.0.8189 - July 7, 2008</h3>
-
-<h4>General</h4>
-
-<ul>
-<li>NUnit now uses a new version numbering scheme. The first three
-    dot-separated values represent the release level, as before, while 
-	the fourth is a build number tied to the date of the release. This 
-	alpha release, for example, is numbered 2.5.0.8189.
-<li>The NUnit source now includes a VS2008 project, in addition to
-    the existing VS2005 and VS2003 projects
-</ul>
-
-<h4>Framework</h4>
-
-<ul>
-<li><b>DataSourceAttribute</b> has been replaced with <b>FactoryAttribute</b>.
-    The new attribute may refer to any field, method or property that 
-	provides test cases consistent with the signature of the method on which
-	it appears. The naming of this attribute is still a bit unsatisfactory
-	and it may change in the final release. 
-<li>The new <b>TestCaseFactoryAttribute</b> class may be used to mark a
-    field, method or property that provides test cases. It specifies the
-	argument types of the test cases that will be provided and is used
-	to identify the cases to be used when the name of a factory is not
-	specified.
-<li>Data may be specified for individual arguments of a parameterized test
-    using the new attributes: <b>ValuesAttribute</b>, <b>RangeAttribute</b>
-	and <b>RandomAttribute</b>. By default, test cases are created using
-	every possible combination of the items provided. Attributes on the
-	test method may specify how data is combined. This release includes
-	<b>SequentialAttribute</b>, <b>CombinatorialAttribute</b> (the default) and 
-	<b>PairwiseAttribute</b>. However, Pairwise combination is not yet
-	implemented, so that attribute is currently ignored.
-<li><b>TestFixture</b> classes may now be generic. They must be marked with
-    or or more instances of <b>TextFixtureAttribute</b> using the new
-	constructor that takes an array of Types. NUnit will instantiate
-	the fixture multiple times, using the type arguments provided.
-<li>Parameterized test methods may now be generic. NUnit will deduce
-    the correct implementation to use based on the types of the
-	parameters provided.
-<li>The new <b>RequiredAddinAttribute</b> may be used to mark tests,
-    fixtures or assemblies, indicating the name of any addin that is
-	required to run the tests. If the addin is not present, the test,
-	fixture or assembly is marked NotRunnable.
-<li>A new assertion and corresponding constraint <b>IsOrdered</b>
-    has been added. (contributed by Simone Busoli)
-<li><b>PlatformAttribute</b> has been extended to accept the new keywords
-    <b>NT6</b>, <b>Vista</b> and <b>Win2008Server</b>.
-	<br><br>
-	<b>Note:</b> In the current alpha release, NUnit is unable to 
-	distintuish between Vista and Windows 2008 Server. Either
-	of them will match all the above values.
-</ul>
-
-<h4>Gui</h4>
-
-<ul>
-<li>Properties with a collection for a value are now displayed
-displayed as a comma-separated list in the properties window.
-</ul>
-
-<h4>Extensibility</h4>
-
-<ul>
-<li>The <b>IParameterProvider</b> interface has been replaced with
-    <b>ITestCaseProvider</b>. The ParameterProviders extension point
-	has been renamed to TestCaseProviders.
-<li>A new extension point, <b>DataPointProviders</b>, has been
-    added to support extensions that provide data for individual
-	test parameters. Extensions must implement the <b>IDataPointProvider</b>
-	interface.
-<li>A simpler method of providing new data point extensions based
-    on attributes applied to the parameter itself is also available.
-    Such attributes may be derived from <b>ValuesAttribute</b> and
-    do not require any special addin in order to work.
-</ul>
-
-<h4>Bug Fixes</h4>
-
-<ul>
-<li>NUnit tests of AssertThrows were not working on systems using
-    non-English cultures.
-<li>Domains were not unloading correctly in some circumstances. Unloading
-    is now done on a separate thread.
-<li>An NUnitSettings.xml file of zero length was causing a crash. (from 2.4.8)
-<li>Invoking the gui with /exclude:XXX, where XXX is a non-existent
-    category, was causing all tests to be excluded. (from 2.4.8)
-<li>Categories were not working properly on repeated tests. (from 2.4.8)
-<li>A serious memory leak was fixed in the NUnit test runners. (from 2.4.8)
-<li>Static SetUp and TearDown methods were not being called in a SetUpFixture.
-<li>The current directory used when executing addins that load tests was
-    not correctly set.
-</ul>
-
-<h3>NUnit 2.5 Alpha 2 Release - May 7, 2008</h3>
-
-<p><b>Note:</b> Since this is an alpha level release, the
-features are not complete and some features present in
-this release may be removed or changed in future releases.
-
-<h4>General</h4>
-
-<ul>
-<li>This release includes pNUnit, an extended NUnit runner for distributed
-    parallel tests. The pNUnit program was developed at Codice Software
-	for use in testing the Plastic SCM and has been contributed to NUnit.
-	For more info about using pNUnit see the 
-	<a href="http://www.codicesoftware.com/opdownloads2/oppnunit.aspx">pNUnit site</a>.
-<li>The install now offers Typical, Complete and Custom options. Selecting
-    Typical gets you the NUnit framework, core, console runner and Gui.
-    To install pNUnit, any of the bundled addins or the NUnit tests,
-	select Complete or Custom.
-</ul>
-
-<h4>Extensibility</h4>
-
-<ul>
-<li>The RowTestExtension, which was merged into the nunit extension dlls
-	in Alpha-1, is now provided as a separate addin. This is the general
-	approach we plan to take with regard to any bundled addins, since it
-	permits the creator of an addin to provide updates separately from
-	the NUnit release.
-<li>This release includes the CSUnitAddin extension, which allows the running of 
-    CSUnit tests under NUnit. The csunit.dll must be available in order to
-	run the tests.
-</ul>
-
-<h3>NUnit 2.5 Alpha 1 Release - April 18, 2008</h3>
-
-<h4>General</h4>
-
-<ul>
-<li>There are no longer separate distributed packages for .NET 1.1 an 2.0.
-    Both the binary zip and msi packages contain subdirectories for .NET
-	1.1 and 2.0. In the case of the msi, the user may elect to install either
-	or both of them.
-<li>The Visual Studio solutions and projects are now in a directory tree that 
-	is parallel to the source tree. This eliminates problems where the VS2003 
-	and VS2005 builds were interfering with one another and makes room for 
-	adding VS2008.
-<li>NUnit is now built using NAnt 0.86 beta 1
-<li>The windows installer is now created using WiX 2.0.5085
-</ul>
-
-<h4>Framework</h4>
-
-<ul>
-<li>Two new attributes have been added to support passing arguments
-	to test methods:
-	<ul>
-	<li><b>TestCaseAttribute</b> allows the programmer to
-		specify the arguments and a number of optional parameters inline.
-	<li><b>DataSourceAttribute</b> identifies a static property that 
-		will provide the arguments and other parameters.
-	</ul>
-
-<li>Two new constraints have been added to permit testing of
-	application-created paths, without requiring that they exist in
-	the file system. The following syntax is supported:
-	<ul>
-	<li><b>Is.SamePath(string)</b>
-	<li><b>Is.SamePathOrUnder(string)</b>
-	</ul>
-	
-<li>The DirectoryAssert class has been added, providing the following Methods:
-	<ul>
-	<li><b>AreEqual(DirectoryInfo, DirectoryInfo)</b>
-	<li><b>AreEqual(string, string)</b>
-	<li><b>AreNotEqual(DirectoryInfo, DirectoryInfo)</b>
-	<li><b>AreNotEqual(string, string)</b>
-	<li><b>IsEmpty(DirectoryInfo, DirectoryInfo)</b>
-	<li><b>IsEmpty(string, string)</b>
-	<li><b>IsNotEmpty(DirectoryInfo, DirectoryInfo)</b>
-	<li><b>IsNotEmpty(string, string)</b>
-	<li><b>IsWithin(DirectoryInfo, DirectoryInfo)</b>
-	<li><b>IsWithin(string, string)</b>
-	<li><b>IsNotWithin(DirectoryInfo, DirectoryInfo)</b>
-	<li><b>IsNotWithin(string, string)</b>
-	</ul>
-	
-<li>The method <b>Assert.Throws(Type expectedException, TestSnippet code)</b> 
-	has been added to provide more control over tests of expected exceptions. 
-	<b>TestSnippet</b> is a delegate, which may of course be supplied 
-	anonymously under .NET 2.0. If the correct exception type is thrown,
-	the actual exception is returned from the method, allowing further
-	verification to be performed.
-	
-<li>The <b>Assert.DoesNotThrow</b> method may be used to verify that a
-	delegate does not throw an exception.
-	
-<li>The <b>Assert.Pass</b> method allows early termination of a test with a
-    successful result. 
-
-<li>The <b>Assert.Inconclusive</b> method allows returning
-	the new Inconclusive result state.
-
-<li>NUnit now includes added funtionality in the .NET 2.0 build of
-	the framework. The following additional features are supported:
-	<ul>
-	<li>All Asserts and Constraints work with nullable types. 
-	<li>Some Asserts allow an alternate generic syntax for convenience:
-		<ul>
-		<li><b>Assert.IsInstanceOf&lt;T&gt;(object actual);</b>
-		<li><b>Assert.IsNotInstanceOf&lt;T&gt;(object actual);</b>
-		<li><b>Assert.IsAssignableFrom&lt;T&gt;(object actual);</b>
-		<li><b>Assert.IsNotAssignableFrom&lt;T&gt;(object actual);</b>
-		<li><b>Assert.Throws&lt;T&gt(TypeSnippet code);</b>
-		</ul>
-	</ul>
-	
-<li>The following obsolete interfaces, classes and methods have been removed:
-<ul>
-	<li>The <b>IAsserter</b> interface
-	<li>The <b>AbstractAsserter</b> class
-	<li>The <b>Assertion</b> class
-	<li>The <b>AssertionFailureMessage</b> class
-	<li>The old <b>NUnit.Framework.TestCase</b> class used for inheriting test classes
-	<li>The <b>Assert.DoAssert()</b> method
-	<li>Two <b>ExpectedExceptionAttribute(Type, string)</b> constructor
-	<li>Two <b>ExpectedExceptionAttribute(string, string)</b> constructor
-</ul>
-
-<li>The syntactic constructs in the <b>SyntaxHelpers</b> namespace have been
-	moved to the <b>NUnit.Framework.Syntax.CSharp</b> namespace. The old
-	namespace may still be used for existing classes, but will not be 
-	supported after the 2.5 release.
-	
-</ul>
-
-<h4>Core</h4>
-
-<ul>
-<li>NUnit now allows use of static methods as tests and for SetUp, TearDown, 
-    TestFixtureSetUp and TestFixtureTearDown.
-<li>Failures and Errors are now distinquished internally and in summary reports.
-    Methods that are not run because they are invalid are also reported separately.
-</ul>
-
-<h4>Console</h4>
-
-<ul>
-<li>The summary report now displays Errors, Failures, Inconclusive, Ignored and Skipped tests 
-	separately. More detailed information on non-runnable tests and setup failures
-	is provided.
-<li>The console summary report is no longer created using a stylesheet, which
-	renders the <b>/transform</b> option meaningless. The option has been removed.
-</ul>
-
-<h4>Gui</h4>
-
-<ul>
-<li>The default gui display now uses a single tab for all text output. For
-	users upgrading from an earlier release, the current settings are
-	honored. If you wish to change to the new default, use the Restore Defaults
-	button on the Text Output settings dialog.
-
-<li>The final test run display shows a more detailed summary: passed tests,
-    errors, failures, inconclusive, non-runnable, skipped and ignored.
-
-<li>The status bar now displays errors and failures separately in.
-
-<li>The tree display shows non-runnable tests in red and inconclusive tests
-	in orange. Inconclusive tests are temporarily listed
-	on the Tests Not Run tab for this alpha release.
-</ul>
-
-<h4>Extensibility</h4>
-
-<ul>
-<li>A new extension point <b>ParameterProviders</b> allows addins to 
-	provide data for parameterized tests.
-	
-<li>The following extensions are included in the nunit.core.extensions
-	and nunit.framework.extensions assemblies:
-	<ul>
-	<li>The MaxTime extension, which was previously a sample.
-	<li>The RowTest extension, which remains an alternative to NUnit's
-		native TestCase syntax.
-	<li>The XmlConstraint extension, which allows comparing two xml files
-	</ul> 
-</ul>
-
-
-<h3>Earlier Releases</h3>
-
-<ul>
-<li>Release Notes for <a href="http://www.nunit.org/?p=releaseNotes&r=2.4.8">NUnit 2.4 through 2.4.8</a>
-<li>Release Notes for <a href="http://www.nunit.org/?p=releaseNotes&r=2.2.10">NUnit 2.0 through 2.2.10</a>
-</ul>
-
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li id="current"><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/repeat.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/repeat.html b/lib/NUnit.org/NUnit/2.5.9/doc/repeat.html
deleted file mode 100644
index 415643d..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/repeat.html
+++ /dev/null
@@ -1,99 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - Repeat</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h3>RepeatAttribute (NUnit 2.5)</h3>
-
-<p><b>RepeatAttribute</b> is used on a test case to specify that it should be 
-   executed multiple times. If any repetition fails, the remaining ones are
-   not run and a failure is reported.
-   
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<ul>
-<li><a href="category.html">Category</a></li>
-<li><a href="combinatorial.html">Combinatorial</a></li>
-<li><a href="culture.html">Culture</a></li>
-<li><a href="datapoint.html">Datapoint(s)</a></li>
-<li><a href="description.html">Description</a></li>
-<li><a href="exception.html">Exception</a></li>
-<li><a href="explicit.html">Explicit</a></li>
-<li><a href="ignore.html">Ignore</a></li>
-<li><a href="maxtime.html">Maxtime</a></li>
-<li><a href="pairwise.html">Pairwise</a></li>
-<li><a href="platform.html">Platform</a></li>
-<li><a href="property.html">Property</a></li>
-<li><a href="random.html">Random</a></li>
-<li><a href="range.html">Range</a></li>
-<li id="current"><a href="repeat.html">Repeat</a></li>
-<li><a href="requiredAddin.html">RequiredAddin</a></li>
-<li><a href="requiresMTA.html">Requires&nbsp;MTA</a></li>
-<li><a href="requiresSTA.html">Requires&nbsp;STA</a></li>
-<li><a href="requiresThread.html">Requires&nbsp;Thread</a></li>
-<li><a href="sequential.html">Sequential</a></li>
-<li><a href="setCulture.html">SetCulture</a></li>
-<li><a href="setup.html">Setup</a></li>
-<li><a href="setupFixture.html">SetupFixture</a></li>
-<li><a href="suite.html">Suite</a></li>
-<li><a href="teardown.html">Teardown</a></li>
-<li><a href="test.html">Test</a></li>
-<li><a href="testCase.html">TestCase</a></li>
-<li><a href="testCaseSource.html">TestCaseSource</a></li>
-<li><a href="testFixture.html">TestFixture</a></li>
-<li><a href="fixtureSetup.html">TestFixtureSetUp</a></li>
-<li><a href="fixtureTeardown.html">TestFixtureTearDown</a></li>
-<li><a href="theory.html">Theory</a></li>
-<li><a href="timeout.html">Timeout</a></li>
-<li><a href="values.html">Values</a></li>
-<li><a href="valueSource.html">ValueSource</a></li>
-</ul>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/requiredAddin.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/requiredAddin.html b/lib/NUnit.org/NUnit/2.5.9/doc/requiredAddin.html
deleted file mode 100644
index dc711c7..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/requiredAddin.html
+++ /dev/null
@@ -1,148 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - RequiredAddin</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h3>RequiredAddinAttribute (NUnit 2.5)</h3>
-
-<p>The RequiredAddin attribute is used to indicate that an
-   assembly requires a particular addin in order to function correctly. If
-   that addin is not installed, the entire assembly is marked as non-runnable.
-   
-<p><b>Note:</b> In the Alpha-3 release, this attribute may be applied to
-classes or methods as well. This is of limited utility, for two reasons:
-<ol>
-<li>If the method or class is not recognized as a test, due to the addin
-being missing, then NUnit will never process it.
-<li>If the method or class is handled by some a different addin, that
-addin may not recognize the attribute.
-</ol>
-<p>The attribute will be limited to assemblies only in the next release.
-   
-<h4>Example</h4>
-
-<In the 
-
-<div class="code"><pre>
-[assembly: RequiredAddin("MyTestFixtureAddin")]
-[assembly: RequiredAddin("MyTestAddin")]
-[assembly: RequiredAddin("MyDecoratorAddin")]
-
-...
-
-namespace NUnit.Tests
-{
-  using System;
-  using NUnit.Framework;
-
-  [MyTestFixture]
-  public class MyTests
-  {
-    [MyTest]
-	public void SomeTest()
-	{
-	  ...
-	}
-  }
-  
-  [TestFixture, MyDecorator]
-  public class MoreTests
-  {
-    [Test, MyDecorator]
-	public void AnotherTest()
-	{
-	  ...
-	}
-  }
-}
-</pre>
-</div>
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<ul>
-<li><a href="category.html">Category</a></li>
-<li><a href="combinatorial.html">Combinatorial</a></li>
-<li><a href="culture.html">Culture</a></li>
-<li><a href="datapoint.html">Datapoint(s)</a></li>
-<li><a href="description.html">Description</a></li>
-<li><a href="exception.html">Exception</a></li>
-<li><a href="explicit.html">Explicit</a></li>
-<li><a href="ignore.html">Ignore</a></li>
-<li><a href="maxtime.html">Maxtime</a></li>
-<li><a href="pairwise.html">Pairwise</a></li>
-<li><a href="platform.html">Platform</a></li>
-<li><a href="property.html">Property</a></li>
-<li><a href="random.html">Random</a></li>
-<li><a href="range.html">Range</a></li>
-<li><a href="repeat.html">Repeat</a></li>
-<li id="current"><a href="requiredAddin.html">RequiredAddin</a></li>
-<li><a href="requiresMTA.html">Requires&nbsp;MTA</a></li>
-<li><a href="requiresSTA.html">Requires&nbsp;STA</a></li>
-<li><a href="requiresThread.html">Requires&nbsp;Thread</a></li>
-<li><a href="sequential.html">Sequential</a></li>
-<li><a href="setCulture.html">SetCulture</a></li>
-<li><a href="setup.html">Setup</a></li>
-<li><a href="setupFixture.html">SetupFixture</a></li>
-<li><a href="suite.html">Suite</a></li>
-<li><a href="teardown.html">Teardown</a></li>
-<li><a href="test.html">Test</a></li>
-<li><a href="testCase.html">TestCase</a></li>
-<li><a href="testCaseSource.html">TestCaseSource</a></li>
-<li><a href="testFixture.html">TestFixture</a></li>
-<li><a href="fixtureSetup.html">TestFixtureSetUp</a></li>
-<li><a href="fixtureTeardown.html">TestFixtureTearDown</a></li>
-<li><a href="theory.html">Theory</a></li>
-<li><a href="timeout.html">Timeout</a></li>
-<li><a href="values.html">Values</a></li>
-<li><a href="valueSource.html">ValueSource</a></li>
-</ul>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/requiresMTA.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/requiresMTA.html b/lib/NUnit.org/NUnit/2.5.9/doc/requiresMTA.html
deleted file mode 100644
index 1a17f80..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/requiresMTA.html
+++ /dev/null
@@ -1,147 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - RequiresMTA</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h3>RequiresMTAAttribute (NUnit 2.5)</h3>
-
-<p>The <b>RequiresMTAAttribute</b> is used on a test method, class or assembly
-   to specify that the tests should be run in the multi-threaded apartment.
-   It causes creation of a new thread if the parent test is not already running
-   in the MTA.
-   
-<p><b>Note:</b> On test methods, you may also use the <b>MTAThreadAttribute</b>.
-   Although the runtime only recognizes this attribute on the entrypoint of 
-   an executable assembly, many users have expected it to work on tests, so
-   we treat it as a synonym.
-
-<h4>Examples</h4>
-   
-<div class="code">
-
-<pre>
-
-// An MTA thread will be created and used to run
-// all the tests in the assembly
-[assembly:RequiresMTA]
-
-...
-
-// TestFixture requiring a separate thread
-[TestFixture, RequiresMTA]
-public class FixtureRequiringMTA
-{
-  // An MTA thread will be created and all
-  // tests in the fixture will run on it
-  // unless the containing assembly is
-  // already running on an MTA Thread
-}
-
-[TestFixture]
-public class AnotherFixture
-{
-  [Test, RequiresMTA]
-  public void TestRequiringMTA()
-  {
-    // A separate thread will be created for this test
-	// unless the containing fixture is already running 
-	// in the MTA.
-  }
-}
-
-</pre>
-
-</div>
-
-<h4>See also...</h4>
-<ul>
-<li><a href="requiresThread.html">RequiresThreadAttribute</a><li><a href="requiresSTA.html">RequiresSTAAttribute</a></ul>
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<ul>
-<li><a href="category.html">Category</a></li>
-<li><a href="combinatorial.html">Combinatorial</a></li>
-<li><a href="culture.html">Culture</a></li>
-<li><a href="datapoint.html">Datapoint(s)</a></li>
-<li><a href="description.html">Description</a></li>
-<li><a href="exception.html">Exception</a></li>
-<li><a href="explicit.html">Explicit</a></li>
-<li><a href="ignore.html">Ignore</a></li>
-<li><a href="maxtime.html">Maxtime</a></li>
-<li><a href="pairwise.html">Pairwise</a></li>
-<li><a href="platform.html">Platform</a></li>
-<li><a href="property.html">Property</a></li>
-<li><a href="random.html">Random</a></li>
-<li><a href="range.html">Range</a></li>
-<li><a href="repeat.html">Repeat</a></li>
-<li><a href="requiredAddin.html">RequiredAddin</a></li>
-<li id="current"><a href="requiresMTA.html">Requires&nbsp;MTA</a></li>
-<li><a href="requiresSTA.html">Requires&nbsp;STA</a></li>
-<li><a href="requiresThread.html">Requires&nbsp;Thread</a></li>
-<li><a href="sequential.html">Sequential</a></li>
-<li><a href="setCulture.html">SetCulture</a></li>
-<li><a href="setup.html">Setup</a></li>
-<li><a href="setupFixture.html">SetupFixture</a></li>
-<li><a href="suite.html">Suite</a></li>
-<li><a href="teardown.html">Teardown</a></li>
-<li><a href="test.html">Test</a></li>
-<li><a href="testCase.html">TestCase</a></li>
-<li><a href="testCaseSource.html">TestCaseSource</a></li>
-<li><a href="testFixture.html">TestFixture</a></li>
-<li><a href="fixtureSetup.html">TestFixtureSetUp</a></li>
-<li><a href="fixtureTeardown.html">TestFixtureTearDown</a></li>
-<li><a href="theory.html">Theory</a></li>
-<li><a href="timeout.html">Timeout</a></li>
-<li><a href="values.html">Values</a></li>
-<li><a href="valueSource.html">ValueSource</a></li>
-</ul>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/requiresSTA.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/requiresSTA.html b/lib/NUnit.org/NUnit/2.5.9/doc/requiresSTA.html
deleted file mode 100644
index 5688390..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/requiresSTA.html
+++ /dev/null
@@ -1,148 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - RequiresSTA</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h3>RequiresSTAAttribute (NUnit 2.5)</h3>
-
-<p>The <b>RequiresSTAAttribute</b> is used on a test method, class or assembly
-   to specify that the tests should be run in the Single-threaded apartment.
-   It causes creation of a new thread if the parent test is not already running
-   in the STA.
-   
-<p><b>Note:</b> On test methods, you may also use the <b>STAThreadAttribute</b>.
-   Although the runtime only recognizes this attribute on the entrypoint of 
-   an executable assembly, many users have expected it to work on tests, so
-   we treat it as a synonym.
-
-<h4>Examples</h4>
-   
-<div class="code">
-
-<pre>
-
-// An STA thread will be created and used to run
-// all the tests in the assembly
-[assembly:RequiresSTA]
-
-...
-
-// TestFixture requiring a separate thread
-[TestFixture, RequiresSTA]
-public class FixtureRequiringSTA
-{
-  // An STA thread will be created and all
-  // tests in the fixture will run on it
-  // unless the containing assembly is
-  // already running on an STA Thread
-}
-
-[TestFixture]
-public class AnotherFixture
-{
-  [Test, RequiresSTA]
-  public void TestRequiringSTA()
-  {
-    // A separate thread will be created for this test
-	// unless the containing fixture is already running 
-	// in the STA.
-  }
-}
-
-</pre>
-
-</div>
-
-<h4>See also...</h4>
-<ul>
-<li><a href="requiresThread.html">RequiresThreadAttribute</a><li><a href="requiresMTA.html">RequiresMTAAttribute</a></ul>
-   
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<ul>
-<li><a href="category.html">Category</a></li>
-<li><a href="combinatorial.html">Combinatorial</a></li>
-<li><a href="culture.html">Culture</a></li>
-<li><a href="datapoint.html">Datapoint(s)</a></li>
-<li><a href="description.html">Description</a></li>
-<li><a href="exception.html">Exception</a></li>
-<li><a href="explicit.html">Explicit</a></li>
-<li><a href="ignore.html">Ignore</a></li>
-<li><a href="maxtime.html">Maxtime</a></li>
-<li><a href="pairwise.html">Pairwise</a></li>
-<li><a href="platform.html">Platform</a></li>
-<li><a href="property.html">Property</a></li>
-<li><a href="random.html">Random</a></li>
-<li><a href="range.html">Range</a></li>
-<li><a href="repeat.html">Repeat</a></li>
-<li><a href="requiredAddin.html">RequiredAddin</a></li>
-<li><a href="requiresMTA.html">Requires&nbsp;MTA</a></li>
-<li id="current"><a href="requiresSTA.html">Requires&nbsp;STA</a></li>
-<li><a href="requiresThread.html">Requires&nbsp;Thread</a></li>
-<li><a href="sequential.html">Sequential</a></li>
-<li><a href="setCulture.html">SetCulture</a></li>
-<li><a href="setup.html">Setup</a></li>
-<li><a href="setupFixture.html">SetupFixture</a></li>
-<li><a href="suite.html">Suite</a></li>
-<li><a href="teardown.html">Teardown</a></li>
-<li><a href="test.html">Test</a></li>
-<li><a href="testCase.html">TestCase</a></li>
-<li><a href="testCaseSource.html">TestCaseSource</a></li>
-<li><a href="testFixture.html">TestFixture</a></li>
-<li><a href="fixtureSetup.html">TestFixtureSetUp</a></li>
-<li><a href="fixtureTeardown.html">TestFixtureTearDown</a></li>
-<li><a href="theory.html">Theory</a></li>
-<li><a href="timeout.html">Timeout</a></li>
-<li><a href="values.html">Values</a></li>
-<li><a href="valueSource.html">ValueSource</a></li>
-</ul>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/requiresThread.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/requiresThread.html b/lib/NUnit.org/NUnit/2.5.9/doc/requiresThread.html
deleted file mode 100644
index cd04cd6..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/requiresThread.html
+++ /dev/null
@@ -1,148 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - RequiresThread</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h3>RequiresThreadAttribute (NUnit 2.5)</h3>
-
-<p>The <b>RequiresThreadAttribute</b> is used to indicate that a test method, 
-   class or assembly should be run on a separate thread. Optionally, the 
-   desired apartment for the thread may be specified in the constructor.
-   
-<p><b>Note:</b> This attribute, used with or without an ApartmentState
-   argument will <b>always</b> result in creation of a new thread. To
-   create a thread only if the current ApartmentState is not appropriate,
-   use <b>RequiresSTAAttribute</b> or <b>RequiresMTAAttribute</b>.
-   
-<h4>Examples</h4>
-   
-<div class="code">
-
-<pre>
-
-// A thread will be created and used to run
-// all the tests in the assembly
-[assembly:RequiresThread]
-
-...
-
-// TestFixture requiring a separate thread
-[TestFixture, RequiresThread]
-public class FixtureOnThread
-{
-  // A separate thread will be created and all
-  // tests in the fixture will run on it.
-}
-
-[TestFixture]
-public class AnotherFixture
-{
-  [Test, RequiresThread]
-  public void TestRequiringThread()
-  {
-    // A separate thread will be created for this test
-  }
-  
-  [Test, RequiresThread(ApartmentState.STA)]
-  public void TestRequiringSTAThread()
-  {
-    // A separate STA thread will be created for tnis test.
-  }
-}
-
-</pre>
-
-</div>
-
-<h4>See also...</h4>
-<ul>
-<li><a href="requiresSTA.html">RequiresSTAAttribute</a><li><a href="requiresMTA.html">RequiresMTAAttribute</a></ul>
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<ul>
-<li><a href="category.html">Category</a></li>
-<li><a href="combinatorial.html">Combinatorial</a></li>
-<li><a href="culture.html">Culture</a></li>
-<li><a href="datapoint.html">Datapoint(s)</a></li>
-<li><a href="description.html">Description</a></li>
-<li><a href="exception.html">Exception</a></li>
-<li><a href="explicit.html">Explicit</a></li>
-<li><a href="ignore.html">Ignore</a></li>
-<li><a href="maxtime.html">Maxtime</a></li>
-<li><a href="pairwise.html">Pairwise</a></li>
-<li><a href="platform.html">Platform</a></li>
-<li><a href="property.html">Property</a></li>
-<li><a href="random.html">Random</a></li>
-<li><a href="range.html">Range</a></li>
-<li><a href="repeat.html">Repeat</a></li>
-<li><a href="requiredAddin.html">RequiredAddin</a></li>
-<li><a href="requiresMTA.html">Requires&nbsp;MTA</a></li>
-<li><a href="requiresSTA.html">Requires&nbsp;STA</a></li>
-<li id="current"><a href="requiresThread.html">Requires&nbsp;Thread</a></li>
-<li><a href="sequential.html">Sequential</a></li>
-<li><a href="setCulture.html">SetCulture</a></li>
-<li><a href="setup.html">Setup</a></li>
-<li><a href="setupFixture.html">SetupFixture</a></li>
-<li><a href="suite.html">Suite</a></li>
-<li><a href="teardown.html">Teardown</a></li>
-<li><a href="test.html">Test</a></li>
-<li><a href="testCase.html">TestCase</a></li>
-<li><a href="testCaseSource.html">TestCaseSource</a></li>
-<li><a href="testFixture.html">TestFixture</a></li>
-<li><a href="fixtureSetup.html">TestFixtureSetUp</a></li>
-<li><a href="fixtureTeardown.html">TestFixtureTearDown</a></li>
-<li><a href="theory.html">Theory</a></li>
-<li><a href="timeout.html">Timeout</a></li>
-<li><a href="values.html">Values</a></li>
-<li><a href="valueSource.html">ValueSource</a></li>
-</ul>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/reusableConstraint.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/reusableConstraint.html b/lib/NUnit.org/NUnit/2.5.9/doc/reusableConstraint.html
deleted file mode 100644
index 2e39c87..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/reusableConstraint.html
+++ /dev/null
@@ -1,161 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - ReusableConstraint</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h2>ReusableConstraint (NUnit 2.5.6)</h2>
-
-<p>Normally constraints just work. However, attempting to reuse the 
-same constraint in several places can lead to unexpected results.
-
-<p>Consider the following code as an example:
-
-<code><pre>
-    Constraint myConstraint = Is.Not.Null;
-    Assert.That("not a null", myConstraint); // Passes, of course
-    Assert.That("not a null", myConstraint); // Fails! What's that about?
-</pre></code>
-
-<p>We'll save the technical explanation for later and show the
-solution first:
-
-<code><pre>
-    ReusableConstraint myConstraint = Is.Not.Null;
-    Assert.That("not a null", myConstraint); // Passes
-    Assert.That("not a null", myConstraint); // Passes
-</pre></code>
-
-Or alternatively..
-
-<code><pre>
-    var myConstraint = new ReusableConstraint(Is.Not.Null);
-    Assert.That("not a null", myConstraint); // Passes
-    Assert.That("not a null", myConstraint); // Passes
-</pre></code>
-
-<h3>Technical Explanation</h3>
-
-<p>In the original example, the value assigned to myConstraint is
-known as an <b>unresolved</b> constraint. In fact, it's an
-unresolved NullConstraint, because that was the last constraint 
-encountered in the expression. It's associated with a <b>Not</b>
-operator that has not yet been applied.
-
-<p>That's OK for use with Assert.That(), because the method
-knows how to resolve a constraint before using it. Assert.That()
-resolves this constraint to a NotConstraint referencing the
-original NullConstraint.
-
-<p>Of course, the original reference in myConstraint is left
-unchanged in all of this. But the EqualConstraint it points
-to has now been resolved. It is now a <b>resolved</b> constraint
-and can't be resolved again by the second Assert.That(), which
-only sees the NullConstraint and not the NotConstraint.
-
-<p>So, for reusability, what we want to save is the result
-of resolving the constraint, in this case
-
-<pre>    NotConstraint => NullConstraint</pre>
-
-That's what <b>ReusableConstraint</b> does for us. It resolves
-the full expression and saves the result. Then it passes all
-operations on to that saved result.
-
-<h3>When to Use It</h3>
-
-<p>Use this constraint any time you want to reuse a constraint
-expression and you'll be safe.
-
-<p>If you like to take chances, you'll find that you can
-avoid using it in the following cases...
-
-<ol>
-<li> With a simple constraint involving no operators, like...
-
-<pre>
-    Constraint myConstraint = Is.Null;
-    Constraint myConstraint = Is.EqualTo(42);
-</pre>
-
-<li> With any constraint you construct using new, without
-using the "dotted" constraint syntax...
-
-<pre>
-    Constraint myConstraint = new NotConstraint(new NullConstraint());
-    Constraint myConstraint = new AndConstraint(
-        new GreaterThanConstraint(0), 
-        new LessThanConstraint(100));
-</pre>
-
-<p>However, there is no significant penalty to using <b>ReusableConstraint</b>.
-It makes your intent much clearer and the exceptions listed are accidents of
-the internal implementation and could disappear in future releases.
-
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<ul>
-<li><a href="equalConstraint.html">Equal&nbsp;Constraint</a></li>
-<li><a href="sameasConstraint.html">SameAs&nbsp;Constraint</a></li>
-<li><a href="conditionConstraints.html">Condition&nbsp;Constraints</a></li>
-<li><a href="comparisonConstraints.html">Comparison&nbsp;Constrants</a></li>
-<li><a href="pathConstraints.html">Path&nbsp;Constraints</a></li>
-<li><a href="typeConstraints.html">Type&nbsp;Constraints</a></li>
-<li><a href="stringConstraints.html">String&nbsp;Constraints</a></li>
-<li><a href="collectionConstraints.html">Collection&nbsp;Constraints</a></li>
-<li><a href="propertyConstraint.html">Property&nbsp;Constraint</a></li>
-<li><a href="throwsConstraint.html">Throws&nbsp;Constraint</a></li>
-<li><a href="compoundConstraints.html">Compound&nbsp;Constraints</a></li>
-<li><a href="delayedConstraint.html">Delayed&nbsp;Constraint</a></li>
-<li><a href="listMapper.html">List&nbsp;Mapper</a></li>
-<li id="current"><a href="reusableConstraint.html">Reusable&nbsp;Constraint</a></li>
-</ul>
-<li><a href="attributes.html">Attributes</a></li>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>


[24/51] [abbrv] [partial] Cleaning up and getting ready to development towards v4.8

Posted by sy...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/framework/pnunit.framework.dll
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/framework/pnunit.framework.dll b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/framework/pnunit.framework.dll
deleted file mode 100644
index 5b9a2c0..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/framework/pnunit.framework.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/launcher.log.conf
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/launcher.log.conf b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/launcher.log.conf
deleted file mode 100644
index 4bd90ca..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/launcher.log.conf
+++ /dev/null
@@ -1,18 +0,0 @@
-<log4net>
-	<!-- A1 is set to be a ConsoleAppender -->
-	<appender name="A1" type="log4net.Appender.ConsoleAppender">
-
-		<!-- A1 uses PatternLayout -->
-		<layout type="log4net.Layout.PatternLayout">
-			<!-- Print the date in ISO 8601 format -->
-			<conversionPattern value="%-5level %logger - %message%newline" />
-		</layout>
-	</appender>
-	
-	<!-- Set root logger level to DEBUG and its only appender to A1 -->
-	<root>
-		<level value="DEBUG" />
-		<appender-ref ref="A1" />
-	</root>
-
-</log4net>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/lib/fit.dll
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/lib/fit.dll b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/lib/fit.dll
deleted file mode 100644
index 40bbef0..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/lib/fit.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/lib/log4net.dll
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/lib/log4net.dll b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/lib/log4net.dll
deleted file mode 100644
index 20a2e1c..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/lib/log4net.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/lib/nunit-console-runner.dll
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/lib/nunit-console-runner.dll b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/lib/nunit-console-runner.dll
deleted file mode 100644
index 5daee5a..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/lib/nunit-console-runner.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/lib/nunit.core.dll
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/lib/nunit.core.dll b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/lib/nunit.core.dll
deleted file mode 100644
index 5eb6124..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/lib/nunit.core.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/lib/nunit.core.interfaces.dll
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/lib/nunit.core.interfaces.dll b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/lib/nunit.core.interfaces.dll
deleted file mode 100644
index eb5c2a1..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/lib/nunit.core.interfaces.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/lib/nunit.fixtures.dll
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/lib/nunit.fixtures.dll b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/lib/nunit.fixtures.dll
deleted file mode 100644
index e5d3cec..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/lib/nunit.fixtures.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/lib/nunit.util.dll
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/lib/nunit.util.dll b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/lib/nunit.util.dll
deleted file mode 100644
index 9f4bace..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/lib/nunit.util.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/nunit-agent.exe
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/nunit-agent.exe b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/nunit-agent.exe
deleted file mode 100644
index 3ba23ea..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/nunit-agent.exe and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/nunit-agent.exe.config
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/nunit-agent.exe.config b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/nunit-agent.exe.config
deleted file mode 100644
index d840f37..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/nunit-agent.exe.config
+++ /dev/null
@@ -1,69 +0,0 @@
-<?xml version="1.0" encoding="utf-8"?>
-<configuration>
-  
-  <runtime>
-    <!-- We need this so test exceptions don't crash NUnit -->
-    <legacyUnhandledExceptionPolicy enabled="1" />
-
-    <!-- Look for addins in the addins directory for now -->
-    <assemblyBinding xmlns="urn:schemas-microsoft-com:asm.v1">
-      <probing privatePath="lib;addins"/>
-   </assemblyBinding>
-
-    <!--
-    The following <assemblyBinding> section allows running nunit under 
-    .NET 1.0 by redirecting assemblies. The appliesTo attribute
-    causes the section to be ignored except under .NET 1.0
-    on a machine with only the .NET version 1.0 runtime installed.
-    If application and its tests were built for .NET 1.1 you will
-    also need to redirect system assemblies in the test config file,
-    which controls loading of the tests.
-   -->
-    <assemblyBinding xmlns="urn:schemas-microsoft-com:asm.v1"
-			appliesTo="v1.0.3705">
-
-      <dependentAssembly> 
-        <assemblyIdentity name="System" 
-                          publicKeyToken="b77a5c561934e089" 
-                          culture="neutral"/>
-        <bindingRedirect  oldVersion="1.0.5000.0" 
-                          newVersion="1.0.3300.0"/>
-      </dependentAssembly>
-
-      <dependentAssembly> 
-        <assemblyIdentity name="System.Data" 
-                          publicKeyToken="b77a5c561934e089" 
-                          culture="neutral"/>
-        <bindingRedirect  oldVersion="1.0.5000.0" 
-                          newVersion="1.0.3300.0"/>
-      </dependentAssembly>
-
-      <dependentAssembly> 
-        <assemblyIdentity name="System.Drawing" 
-                          publicKeyToken="b03f5f7f11d50a3a" 
-                          culture="neutral"/>
-        <bindingRedirect  oldVersion="1.0.5000.0" 
-                          newVersion="1.0.3300.0"/>
-      </dependentAssembly>
-
-      <dependentAssembly> 
-        <assemblyIdentity name="System.Windows.Forms" 
-                          publicKeyToken="b77a5c561934e089" 
-                          culture="neutral"/>
-        <bindingRedirect  oldVersion="1.0.5000.0" 
-                          newVersion="1.0.3300.0"/>
-      </dependentAssembly>
-
-      <dependentAssembly> 
-        <assemblyIdentity name="System.Xml" 
-                          publicKeyToken="b77a5c561934e089" 
-                          culture="neutral"/>
-        <bindingRedirect  oldVersion="1.0.5000.0" 
-                          newVersion="1.0.3300.0"/>
-      </dependentAssembly>
-
-    </assemblyBinding>
-  
-  </runtime>
-  
-</configuration>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/nunit-console.exe
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/nunit-console.exe b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/nunit-console.exe
deleted file mode 100644
index c5492b0..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/nunit-console.exe and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/nunit-console.exe.config
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/nunit-console.exe.config b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/nunit-console.exe.config
deleted file mode 100644
index fa0a262..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/nunit-console.exe.config
+++ /dev/null
@@ -1,69 +0,0 @@
-<?xml version="1.0" encoding="utf-8"?>
-<configuration>
-
-  <runtime>
-    <!-- We need this so test exceptions don't crash NUnit -->
-    <legacyUnhandledExceptionPolicy enabled="1" />
-
-    <!-- Look for addins in the addins directory for now -->
-    <assemblyBinding xmlns="urn:schemas-microsoft-com:asm.v1">
-      <probing privatePath="lib;addins"/>
-   </assemblyBinding>
-
-   <!--
-    The following <assemblyBinding> section allows running nunit under 
-    .NET 1.0 by redirecting assemblies. The appliesTo attribute
-    causes the section to be ignored except under .NET 1.0
-    on a machine with only the .NET version 1.0 runtime installed.
-    If application and its tests were built for .NET 1.1 you will
-    also need to redirect system assemblies in the test config file,
-    which controls loading of the tests.
-   -->
-   <assemblyBinding xmlns="urn:schemas-microsoft-com:asm.v1"
-			appliesTo="v1.0.3705">
-
-      <dependentAssembly> 
-        <assemblyIdentity name="System" 
-                          publicKeyToken="b77a5c561934e089" 
-                          culture="neutral"/>
-        <bindingRedirect  oldVersion="1.0.5000.0" 
-                          newVersion="1.0.3300.0"/>
-      </dependentAssembly>
-
-      <dependentAssembly> 
-        <assemblyIdentity name="System.Data" 
-                          publicKeyToken="b77a5c561934e089" 
-                          culture="neutral"/>
-        <bindingRedirect  oldVersion="1.0.5000.0" 
-                          newVersion="1.0.3300.0"/>
-      </dependentAssembly>
-
-      <dependentAssembly> 
-        <assemblyIdentity name="System.Drawing" 
-                          publicKeyToken="b03f5f7f11d50a3a" 
-                          culture="neutral"/>
-        <bindingRedirect  oldVersion="1.0.5000.0" 
-                          newVersion="1.0.3300.0"/>
-      </dependentAssembly>
-
-      <dependentAssembly> 
-        <assemblyIdentity name="System.Windows.Forms" 
-                          publicKeyToken="b77a5c561934e089" 
-                          culture="neutral"/>
-        <bindingRedirect  oldVersion="1.0.5000.0" 
-                          newVersion="1.0.3300.0"/>
-      </dependentAssembly>
-
-      <dependentAssembly> 
-        <assemblyIdentity name="System.Xml" 
-                          publicKeyToken="b77a5c561934e089" 
-                          culture="neutral"/>
-        <bindingRedirect  oldVersion="1.0.5000.0" 
-                          newVersion="1.0.3300.0"/>
-      </dependentAssembly>
-
-    </assemblyBinding>
-
-  </runtime>
-  
-</configuration>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/nunit.framework.dll
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/nunit.framework.dll b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/nunit.framework.dll
deleted file mode 100644
index 105213c..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/nunit.framework.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/pnunit-agent.exe
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/pnunit-agent.exe b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/pnunit-agent.exe
deleted file mode 100644
index 91ba0af..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/pnunit-agent.exe and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/pnunit-agent.exe.config
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/pnunit-agent.exe.config b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/pnunit-agent.exe.config
deleted file mode 100644
index 0bf29b3..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/pnunit-agent.exe.config
+++ /dev/null
@@ -1,77 +0,0 @@
-<?xml version="1.0" encoding="Windows-1252"?>
-<configuration>
-
-  <!-- Set the level for tracing NUnit itself -->
-  <!-- 0=Off 1=Error 2=Warning 3=Info 4=Debug -->
-  <system.diagnostics>
-	  <switches>
-      <add name="NTrace" value="0" />
-	  </switches>
-  </system.diagnostics>
-  
-  <runtime>
-    <!-- We need this so test exceptions don't crash NUnit -->
-    <legacyUnhandledExceptionPolicy enabled="1" />
-
-    <!-- Look for addins in the addins directory for now -->
-    <assemblyBinding xmlns="urn:schemas-microsoft-com:asm.v1">
-      <probing privatePath="framework;lib;addins"/>
-   </assemblyBinding>
-
-    <!--
-    The following <assemblyBinding> section allows running nunit under 
-    .NET 1.0 by redirecting assemblies. The appliesTo attribute
-    causes the section to be ignored except under .NET 1.0
-    on a machine with only the .NET version 1.0 runtime installed.
-    If application and its tests were built for .NET 1.1 you will
-    also need to redirect system assemblies in the test config file,
-    which controls loading of the tests.
-   -->
-    <assemblyBinding xmlns="urn:schemas-microsoft-com:asm.v1"
-			appliesTo="v1.0.3705">
-
-      <dependentAssembly> 
-        <assemblyIdentity name="System" 
-                          publicKeyToken="b77a5c561934e089" 
-                          culture="neutral"/>
-        <bindingRedirect  oldVersion="1.0.5000.0" 
-                          newVersion="1.0.3300.0"/>
-      </dependentAssembly>
-
-      <dependentAssembly> 
-        <assemblyIdentity name="System.Data" 
-                          publicKeyToken="b77a5c561934e089" 
-                          culture="neutral"/>
-        <bindingRedirect  oldVersion="1.0.5000.0" 
-                          newVersion="1.0.3300.0"/>
-      </dependentAssembly>
-
-      <dependentAssembly> 
-        <assemblyIdentity name="System.Drawing" 
-                          publicKeyToken="b03f5f7f11d50a3a" 
-                          culture="neutral"/>
-        <bindingRedirect  oldVersion="1.0.5000.0" 
-                          newVersion="1.0.3300.0"/>
-      </dependentAssembly>
-
-      <dependentAssembly> 
-        <assemblyIdentity name="System.Windows.Forms" 
-                          publicKeyToken="b77a5c561934e089" 
-                          culture="neutral"/>
-        <bindingRedirect  oldVersion="1.0.5000.0" 
-                          newVersion="1.0.3300.0"/>
-      </dependentAssembly>
-
-      <dependentAssembly> 
-        <assemblyIdentity name="System.Xml" 
-                          publicKeyToken="b77a5c561934e089" 
-                          culture="neutral"/>
-        <bindingRedirect  oldVersion="1.0.5000.0" 
-                          newVersion="1.0.3300.0"/>
-      </dependentAssembly>
-
-    </assemblyBinding>
-  
-  </runtime>
-  
-</configuration>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/pnunit-launcher.exe
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/pnunit-launcher.exe b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/pnunit-launcher.exe
deleted file mode 100644
index cbc361c..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/pnunit-launcher.exe and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/pnunit-launcher.exe.config
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/pnunit-launcher.exe.config b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/pnunit-launcher.exe.config
deleted file mode 100644
index 0bf29b3..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/pnunit-launcher.exe.config
+++ /dev/null
@@ -1,77 +0,0 @@
-<?xml version="1.0" encoding="Windows-1252"?>
-<configuration>
-
-  <!-- Set the level for tracing NUnit itself -->
-  <!-- 0=Off 1=Error 2=Warning 3=Info 4=Debug -->
-  <system.diagnostics>
-	  <switches>
-      <add name="NTrace" value="0" />
-	  </switches>
-  </system.diagnostics>
-  
-  <runtime>
-    <!-- We need this so test exceptions don't crash NUnit -->
-    <legacyUnhandledExceptionPolicy enabled="1" />
-
-    <!-- Look for addins in the addins directory for now -->
-    <assemblyBinding xmlns="urn:schemas-microsoft-com:asm.v1">
-      <probing privatePath="framework;lib;addins"/>
-   </assemblyBinding>
-
-    <!--
-    The following <assemblyBinding> section allows running nunit under 
-    .NET 1.0 by redirecting assemblies. The appliesTo attribute
-    causes the section to be ignored except under .NET 1.0
-    on a machine with only the .NET version 1.0 runtime installed.
-    If application and its tests were built for .NET 1.1 you will
-    also need to redirect system assemblies in the test config file,
-    which controls loading of the tests.
-   -->
-    <assemblyBinding xmlns="urn:schemas-microsoft-com:asm.v1"
-			appliesTo="v1.0.3705">
-
-      <dependentAssembly> 
-        <assemblyIdentity name="System" 
-                          publicKeyToken="b77a5c561934e089" 
-                          culture="neutral"/>
-        <bindingRedirect  oldVersion="1.0.5000.0" 
-                          newVersion="1.0.3300.0"/>
-      </dependentAssembly>
-
-      <dependentAssembly> 
-        <assemblyIdentity name="System.Data" 
-                          publicKeyToken="b77a5c561934e089" 
-                          culture="neutral"/>
-        <bindingRedirect  oldVersion="1.0.5000.0" 
-                          newVersion="1.0.3300.0"/>
-      </dependentAssembly>
-
-      <dependentAssembly> 
-        <assemblyIdentity name="System.Drawing" 
-                          publicKeyToken="b03f5f7f11d50a3a" 
-                          culture="neutral"/>
-        <bindingRedirect  oldVersion="1.0.5000.0" 
-                          newVersion="1.0.3300.0"/>
-      </dependentAssembly>
-
-      <dependentAssembly> 
-        <assemblyIdentity name="System.Windows.Forms" 
-                          publicKeyToken="b77a5c561934e089" 
-                          culture="neutral"/>
-        <bindingRedirect  oldVersion="1.0.5000.0" 
-                          newVersion="1.0.3300.0"/>
-      </dependentAssembly>
-
-      <dependentAssembly> 
-        <assemblyIdentity name="System.Xml" 
-                          publicKeyToken="b77a5c561934e089" 
-                          culture="neutral"/>
-        <bindingRedirect  oldVersion="1.0.5000.0" 
-                          newVersion="1.0.3300.0"/>
-      </dependentAssembly>
-
-    </assemblyBinding>
-  
-  </runtime>
-  
-</configuration>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/pnunit.framework.dll
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/pnunit.framework.dll b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/pnunit.framework.dll
deleted file mode 100644
index 5b9a2c0..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/pnunit.framework.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/pnunit.tests.dll
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/pnunit.tests.dll b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/pnunit.tests.dll
deleted file mode 100644
index 9d482ce..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/pnunit.tests.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/runFile.exe
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/runFile.exe b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/runFile.exe
deleted file mode 100644
index a794458..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/runFile.exe and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/runFile.exe.config
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/runFile.exe.config b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/runFile.exe.config
deleted file mode 100644
index f58f099..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/runFile.exe.config
+++ /dev/null
@@ -1,43 +0,0 @@
-<?xml version="1.0" encoding="utf-8" ?>
-<configuration>
-  <startup>
-	  <supportedRuntime version="v2.0.50727" />
-	  <supportedRuntime version="v2.0.50215" />
-	  <supportedRuntime version="v2.0.40607" />
-	  <supportedRuntime version="v1.1.4322" />
-	  <supportedRuntime version="v1.0.3705" />
-	
-	  <requiredRuntime version="v1.0.3705" />
-  </startup>
-
-<!--
-     The following <runtime> section allows running nunit tests under 
-     .NET 1.0 by redirecting assemblies. The appliesTo attribute
-     causes the section to be ignored except under .NET 1.0.
-	-->
-	<runtime>
-		<assemblyBinding xmlns="urn:schemas-microsoft-com:asm.v1"
-				appliesTo="v1.0.3705">
-			<dependentAssembly>
-				<assemblyIdentity name="System" publicKeyToken="b77a5c561934e089" culture="" />
-				<bindingRedirect oldVersion="1.0.5000.0" newVersion="1.0.3300.0" />
-			</dependentAssembly>
-			<dependentAssembly>
-				<assemblyIdentity name="System.Data" publicKeyToken="b77a5c561934e089" culture="" />
-				<bindingRedirect oldVersion="1.0.5000.0" newVersion="1.0.3300.0" />
-			</dependentAssembly>
-			<dependentAssembly>
-				<assemblyIdentity name="System.Drawing" publicKeyToken="b03f5f7f11d50a3a" culture="" />
-				<bindingRedirect oldVersion="1.0.5000.0" newVersion="1.0.3300.0" />
-			</dependentAssembly>
-			<dependentAssembly>
-				<assemblyIdentity name="System.Windows.Forms" publicKeyToken="b77a5c561934e089" culture="" />
-				<bindingRedirect oldVersion="1.0.5000.0" newVersion="1.0.3300.0" />
-			</dependentAssembly>
-			<dependentAssembly>
-				<assemblyIdentity name="System.Xml" publicKeyToken="b77a5c561934e089" culture="" />
-				<bindingRedirect oldVersion="1.0.5000.0" newVersion="1.0.3300.0" />
-			</dependentAssembly>
-		</assemblyBinding>
-	</runtime>
-</configuration>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/runpnunit.bat
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/runpnunit.bat b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/runpnunit.bat
deleted file mode 100644
index a05cbb7..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/runpnunit.bat
+++ /dev/null
@@ -1,2 +0,0 @@
-start pnunit-agent agent.conf
-pnunit-launcher test.conf
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/test.conf
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/test.conf b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/test.conf
deleted file mode 100644
index 14cd113..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/test.conf
+++ /dev/null
@@ -1,24 +0,0 @@
-<TestGroup>
-    <ParallelTests>
-
-        <ParallelTest>
-            <Name>Testing</Name>
-            <Tests>
-                <TestConf>
-                    <Name>Testing</Name>
-                    <Assembly>pnunit.tests.dll</Assembly>
-                    <TestToRun>TestLibraries.Testing.EqualTo19</TestToRun>
-                    <Machine>localhost:8080</Machine>
-                    <TestParams>
-                        <string>..\server</string> <!-- server dir -->
-			<string></string> <!-- database server -->
-			<string></string><!-- conn string -->
-                    </TestParams>                                                                                
-                </TestConf>
-
-            </Tests>
-        </ParallelTest>
-
-
-    </ParallelTests>
-</TestGroup>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/tests/loadtest-assembly.dll
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/tests/loadtest-assembly.dll b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/tests/loadtest-assembly.dll
deleted file mode 100644
index 3c33dd6..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/tests/loadtest-assembly.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/tests/mock-assembly.dll
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/tests/mock-assembly.dll b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/tests/mock-assembly.dll
deleted file mode 100644
index bfb3b26..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/tests/mock-assembly.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/tests/nonamespace-assembly.dll
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/tests/nonamespace-assembly.dll b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/tests/nonamespace-assembly.dll
deleted file mode 100644
index 4d11b60..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/tests/nonamespace-assembly.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/tests/nunit-console.tests.dll
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/tests/nunit-console.tests.dll b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/tests/nunit-console.tests.dll
deleted file mode 100644
index 4d9c49b..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/tests/nunit-console.tests.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/tests/nunit.core.tests.dll
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/tests/nunit.core.tests.dll b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/tests/nunit.core.tests.dll
deleted file mode 100644
index a91217d..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/tests/nunit.core.tests.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/tests/nunit.fixtures.tests.dll
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/tests/nunit.fixtures.tests.dll b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/tests/nunit.fixtures.tests.dll
deleted file mode 100644
index fc624de..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/tests/nunit.fixtures.tests.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/tests/nunit.framework.dll
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/tests/nunit.framework.dll b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/tests/nunit.framework.dll
deleted file mode 100644
index 105213c..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/tests/nunit.framework.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/tests/nunit.framework.tests.dll
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/tests/nunit.framework.tests.dll b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/tests/nunit.framework.tests.dll
deleted file mode 100644
index e6b8be7..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/tests/nunit.framework.tests.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/tests/nunit.mocks.tests.dll
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/tests/nunit.mocks.tests.dll b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/tests/nunit.mocks.tests.dll
deleted file mode 100644
index 0771c38..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/tests/nunit.mocks.tests.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/tests/nunit.util.tests.dll
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/tests/nunit.util.tests.dll b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/tests/nunit.util.tests.dll
deleted file mode 100644
index a816c2a..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/tests/nunit.util.tests.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/tests/test-assembly.dll
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/tests/test-assembly.dll b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/tests/test-assembly.dll
deleted file mode 100644
index c61e0c4..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/tests/test-assembly.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/tests/test-utilities.dll
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/tests/test-utilities.dll b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/tests/test-utilities.dll
deleted file mode 100644
index 697418b..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/tests/test-utilities.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/tests/timing-tests.dll
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/tests/timing-tests.dll b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/tests/timing-tests.dll
deleted file mode 100644
index bf1ae70..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/tests/timing-tests.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/NUnitFitTests.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/NUnitFitTests.html b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/NUnitFitTests.html
deleted file mode 100644
index ca5cd4f..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/NUnitFitTests.html
+++ /dev/null
@@ -1,277 +0,0 @@
-<!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0 Transitional//EN">
-<html>
-	<body>
-		<h1>NUnit Acceptance Tests</h1>
-		<p>
-		Developers love self-referential programs! Hence, NUnit has always run all it's 
-		own tests, even those that are not really unit tests.
-		<p>Now, beginning with NUnit 2.4, NUnit has top-level tests using Ward Cunningham's 
-			FIT framework. At this time, the tests are pretty rudimentary, but it's a start 
-			and it's a framework for doing more.
-			<h2>Running the Tests</h2>
-		<p>Open a console or shell window and navigate to the NUnit bin directory, which 
-			contains this file. To run the test under Microsoft .Net, enter the command
-			<pre>    runFile NUnitFitTests.html TestResults.html .</pre>
-			To run it under Mono, enter
-			<pre>    mono runFile.exe NUnitFitTests.html TestResults.html .</pre>
-			Note the space and dot at the end of each command. The results of your test 
-			will be in TestResults.html in the same directory.
-			<h2>Platform and CLR Version</h2>
-			<table BORDER cellSpacing="0" cellPadding="5">
-				<tr>
-					<td colspan="2">NUnit.Fixtures.PlatformInfo</td>
-				</tr>
-			</table>
-			<h2>Verify Unit Tests</h2>
-		<p>
-		Load and run the NUnit unit tests, verifying that the results are as expected. 
-		When these tests are run on different platforms, different numbers of tests may 
-		be skipped, so the values for Skipped and Run tests are informational only.
-		<p>
-		The number of tests in each assembly should be constant across all platforms - 
-		any discrepancy usually means that one of the test source files was not 
-		compiled on the platform. There should be no failures and no tests ignored.
-		<p><b>Note:</b>
-		At the moment, the nunit.extensions.tests assembly is failing because the 
-		fixture doesn't initialize addins in the test domain.
-		<p>
-			<table BORDER cellSpacing="0" cellPadding="5">
-				<tr>
-					<td colspan="6">NUnit.Fixtures.AssemblyRunner</td>
-				</tr>
-				<tr>
-					<td>Assembly</td>
-					<td>Tests()</td>
-					<td>Run()</td>
-					<td>Skipped()</td>
-					<td>Ignored()</td>
-					<td>Failures()</td>
-				</tr>
-				<tr>
-					<td>nunit.framework.tests.dll</td>
-					<td>397</td>
-					<td>&nbsp;</td>
-					<td>&nbsp;</td>
-					<td>0</td>
-					<td>0</td>
-				</tr>
-				<tr>
-					<td>nunit.core.tests.dll</td>
-					<td>355</td>
-					<td>&nbsp;</td>
-					<td>&nbsp;</td>
-					<td>0</td>
-					<td>0</td>
-				</tr>
-				<tr>
-					<td>nunit.util.tests.dll</td>
-					<td>238</td>
-					<td>&nbsp;</td>
-					<td>&nbsp;</td>
-					<td>0</td>
-					<td>0</td>
-				</tr>
-				<tr>
-					<td>nunit.mocks.tests.dll</td>
-					<td>43</td>
-					<td>&nbsp;</td>
-					<td>&nbsp;</td>
-					<td>0</td>
-					<td>0</td>
-				</tr>
-				<tr>
-					<td>nunit.extensions.tests.dll</td>
-					<td>5</td>
-					<td>&nbsp;</td>
-					<td>&nbsp;</td>
-					<td>0</td>
-					<td>0</td>
-				</tr>
-				<tr>
-					<td>nunit-console.tests.dll</td>
-					<td>40</td>
-					<td>&nbsp;</td>
-					<td>&nbsp;</td>
-					<td>0</td>
-					<td>0</td>
-				</tr>
-				<tr>
-					<td>nunit.uikit.tests.dll</td>
-					<td>34</td>
-					<td>&nbsp;</td>
-					<td>&nbsp;</td>
-					<td>0</td>
-					<td>0</td>
-				</tr>
-				<tr>
-					<td>nunit-gui.tests.dll</td>
-					<td>15</td>
-					<td>&nbsp;</td>
-					<td>&nbsp;</td>
-					<td>0</td>
-					<td>0</td>
-				</tr>
-				<tr>
-					<td>nunit.fixtures.tests.dll</td>
-					<td>6</td>
-					<td>&nbsp;</td>
-					<td>&nbsp;</td>
-					<td>0</td>
-					<td>0</td>
-				</tr>
-			</table>
-			<h2>Code Snippet Tests</h2>
-		<p>
-		These tests create a test assembly from a snippet of code and then load and run 
-		the tests that it contains, verifying that the structure of the loaded tests is 
-		as expected and that the number of tests run, skipped, ignored or failed is 
-		correct.
-		<p>
-			<table BORDER cellSpacing="0" cellPadding="5">
-				<tr>
-					<td colspan="6">NUnit.Fixtures.SnippetRunner</td>
-				</tr>
-				<tr>
-					<td>Code</td>
-					<td>Tree()</td>
-					<td>Run()</td>
-					<td>Skipped()</td>
-					<td>Ignored()</td>
-					<td>Failures()</td>
-				</tr>
-				<tr>
-					<td><pre>public class TestClass
-{
-}</pre>
-					</td>
-					<td>EMPTY</td>
-					<td>0</td>
-					<td>0</td>
-					<td>0</td>
-					<td>0</td>
-				</tr>
-				<tr>
-					<td><pre>using NUnit.Framework;
-
-[TestFixture]
-public class TestClass
-{
-}</pre>
-					</td>
-					<td>TestClass</td>
-					<td>0</td>
-					<td>0</td>
-					<td>0</td>
-					<td>0</td>
-				</tr>
-				<tr>
-					<td><pre>using NUnit.Framework;
-
-[TestFixture]
-public class TestClass
-{
-    [Test]
-    public void T1() { }
-    [Test]
-    public void T2() { }
-    [Test]
-    public void T3() { }
-}</pre>
-					</td>
-					<td><pre>TestClass
-&gt;T1
-&gt;T2
-&gt;T3</pre>
-					</td>
-					<td>3</td>
-					<td>0</td>
-					<td>0</td>
-					<td>0</td>
-				</tr>
-				<tr>
-					<td><pre>using NUnit.Framework;
-
-[TestFixture]
-public class TestClass1
-{
-    [Test]
-    public void T1() { }
-}
-
-[TestFixture]
-public class TestClass2
-{
-    [Test]
-    public void T2() { }
-    [Test]
-    public void T3() { }
-}</pre>
-					</td>
-					<td><pre>TestClass1
-&gt;T1
-TestClass2
-&gt;T2
-&gt;T3</pre>
-					</td>
-					<td>3</td>
-					<td>0</td>
-					<td>0</td>
-					<td>0</td>
-				</tr>
-				<tr>
-					<td><pre>using NUnit.Framework;
-
-[TestFixture]
-public class TestClass
-{
-    [Test]
-    public void T1() { }
-    [Test, Ignore]
-    public void T2() { }
-    [Test]
-    public void T3() { }
-}</pre>
-					</td>
-					<td><pre>TestClass
-&gt;T1
-&gt;T2
-&gt;T3</pre>
-					</td>
-					<td>2</td>
-					<td>0</td>
-					<td>1</td>
-					<td>0</td>
-				</tr>
-				<tr>
-					<td><pre>using NUnit.Framework;
-
-[TestFixture]
-public class TestClass
-{
-    [Test]
-    public void T1() { }
-    [Test, Explicit]
-    public void T2() { }
-    [Test]
-    public void T3() { }
-}</pre>
-					</td>
-					<td><pre>TestClass
-&gt;T1
-&gt;T2
-&gt;T3</pre>
-					</td>
-					<td>2</td>
-					<td>1</td>
-					<td>0</td>
-					<td>0</td>
-				</tr>
-			</table>
-			<h2>Summary Information</h2>
-			<table BORDER cellSpacing="0" cellPadding="5">
-				<tr>
-					<td colspan="2">fit.Summary</td>
-				</tr>
-			</table>
-	</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/NUnitTests.config
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/NUnitTests.config b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/NUnitTests.config
deleted file mode 100644
index fb15771..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/NUnitTests.config
+++ /dev/null
@@ -1,85 +0,0 @@
-<?xml version="1.0" encoding="utf-8" ?>
-<configuration>
-<!--
-	 This is the configuration file for the NUnitTests.nunit test project. You may
-	 need to create a similar configuration file for your own test project. 
- -->	 
-
-<!--
-	 The <NUnit> section is only needed if you want to use a non-default value
-	 for any of the settings. It is commented out below. If you are going to use
-   it, you must deifne the NUnit section group and the sections you need.
- 
-   The syntax shown here works for most runtimes. If NUnit fails at startup, you
-   can try specifying the name of the assembly containing the NameValueSectionHandler:
-   
-      <section name="TestCaseBuilder" type="System.Configuration.NameValueSectionHandler, System" />
-      
-   If that fails, try the fully qualified name of the assembly:
-   
-      <section name="TestCaseBuilder" type="System.Configuration.NameValueSectionHandler, System, 
-             Version=2.0.50727.832, Culture=neutral, PublicKeyToken=b77a5c561934e089" />
-             
-   Unfortunately, this last approach makes your config file non-portable across runtimes.
-   -->
-
-<!--
-  <configSections>
-		<sectionGroup name="NUnit">
-			<section name="TestCaseBuilder" type="System.Configuration.NameValueSectionHandler"/>
-			<section name="TestRunner" type="System.Configuration.NameValueSectionHandler"/>
-		</sectionGroup>
-	</configSections>
- -->
-
-  <appSettings>
-		<!--   User application and configured property settings go here.-->
-		<!--   Example: <add key="settingName" value="settingValue"/> -->
-		<add key="test.setting" value="54321" />
-	</appSettings>
-
-<!-- Sample NUnit section group showing all default values -->
-<!--
-	<NUnit>
-		<TestCaseBuilder>
-			<add key="OldStyleTestCases" value="false" />
-		</TestCaseBuilder>
-		<TestRunner>
-			<add key="ApartmentState" value="MTA" />
-			<add key="ThreadPriority" value="Normal" />
-      <add key="DefaultLogThreshold" value="Info" />
-		</TestRunner>
-	</NUnit>
--->
-  
-   <!--
-    The following <runtime> section allows running nunit tests under 
-    .NET 1.0 by redirecting assemblies. The appliesTo attribute
-    causes the section to be ignored except under .NET 1.0.
-   --> 
-	<runtime>
-		<assemblyBinding xmlns="urn:schemas-microsoft-com:asm.v1"
-				appliesTo="v1.0.3705">
-			<dependentAssembly>
-				<assemblyIdentity name="System" publicKeyToken="b77a5c561934e089" culture="" />
-				<bindingRedirect oldVersion="1.0.5000.0" newVersion="1.0.3300.0" />
-			</dependentAssembly>
-			<dependentAssembly>
-				<assemblyIdentity name="System.Data" publicKeyToken="b77a5c561934e089" culture="" />
-				<bindingRedirect oldVersion="1.0.5000.0" newVersion="1.0.3300.0" />
-			</dependentAssembly>
-			<dependentAssembly>
-				<assemblyIdentity name="System.Drawing" publicKeyToken="b03f5f7f11d50a3a" culture="" />
-				<bindingRedirect oldVersion="1.0.5000.0" newVersion="1.0.3300.0" />
-			</dependentAssembly>
-			<dependentAssembly>
-				<assemblyIdentity name="System.Windows.Forms" publicKeyToken="b77a5c561934e089" culture="" />
-				<bindingRedirect oldVersion="1.0.5000.0" newVersion="1.0.3300.0" />
-			</dependentAssembly>
-			<dependentAssembly>
-				<assemblyIdentity name="System.Xml" publicKeyToken="b77a5c561934e089" culture="" />
-				<bindingRedirect oldVersion="1.0.5000.0" newVersion="1.0.3300.0" />
-			</dependentAssembly>
-		</assemblyBinding>
-	</runtime>
-</configuration> 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/NUnitTests.nunit
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/NUnitTests.nunit b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/NUnitTests.nunit
deleted file mode 100644
index e7bb7f4..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/NUnitTests.nunit
+++ /dev/null
@@ -1,14 +0,0 @@
-<NUnitProject>
-  <Settings appbase="."/>
-  <Config name="Default" binpath="lib;tests;framework" runtimeFramework="v2.0">
-    <assembly path="tests/nunit.framework.tests.dll" />
-    <assembly path="tests/nunit.core.tests.dll" />
-    <assembly path="tests/nunit.util.tests.dll" />
-    <assembly path="tests/nunit.mocks.tests.dll" />
-    <assembly path="tests/nunit-console.tests.dll" />
-    <assembly path="tests/nunit.uiexception.tests.dll" />
-    <assembly path="tests/nunit.uikit.tests.dll" />
-    <assembly path="tests/nunit-gui.tests.dll" />
-    <assembly path="tests/nunit.fixtures.tests.dll" />
-  </Config>
-</NUnitProject>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/agent.conf
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/agent.conf b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/agent.conf
deleted file mode 100644
index ddbcd8e..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/agent.conf
+++ /dev/null
@@ -1,4 +0,0 @@
-<AgentConfig>
-  <Port>8080</Port>
-  <PathToAssemblies>.</PathToAssemblies>
-</AgentConfig>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/agent.log.conf
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/agent.log.conf b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/agent.log.conf
deleted file mode 100644
index 4bd90ca..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/agent.log.conf
+++ /dev/null
@@ -1,18 +0,0 @@
-<log4net>
-	<!-- A1 is set to be a ConsoleAppender -->
-	<appender name="A1" type="log4net.Appender.ConsoleAppender">
-
-		<!-- A1 uses PatternLayout -->
-		<layout type="log4net.Layout.PatternLayout">
-			<!-- Print the date in ISO 8601 format -->
-			<conversionPattern value="%-5level %logger - %message%newline" />
-		</layout>
-	</appender>
-	
-	<!-- Set root logger level to DEBUG and its only appender to A1 -->
-	<root>
-		<level value="DEBUG" />
-		<appender-ref ref="A1" />
-	</root>
-
-</log4net>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/framework/nunit.framework.dll
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/framework/nunit.framework.dll b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/framework/nunit.framework.dll
deleted file mode 100644
index 875e098..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/framework/nunit.framework.dll and /dev/null differ


[02/51] [abbrv] [partial] Cleaning up and getting ready to development towards v4.8

Posted by sy...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/src/Lucene.Net.Codecs/Sep/SepPostingsWriter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Codecs/Sep/SepPostingsWriter.cs b/src/Lucene.Net.Codecs/Sep/SepPostingsWriter.cs
new file mode 100644
index 0000000..ced150e
--- /dev/null
+++ b/src/Lucene.Net.Codecs/Sep/SepPostingsWriter.cs
@@ -0,0 +1,371 @@
+package org.apache.lucene.codecs.sep;
+
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+import java.io.IOException;
+
+import org.apache.lucene.codecs.BlockTermState;
+import org.apache.lucene.codecs.CodecUtil;
+import org.apache.lucene.codecs.PostingsWriterBase;
+import org.apache.lucene.index.CorruptIndexException;
+import org.apache.lucene.index.DocsEnum;
+import org.apache.lucene.index.FieldInfo;
+import org.apache.lucene.index.FieldInfo.IndexOptions;
+import org.apache.lucene.index.IndexFileNames;
+import org.apache.lucene.index.SegmentWriteState;
+import org.apache.lucene.store.DataOutput;
+import org.apache.lucene.store.IndexOutput;
+import org.apache.lucene.store.RAMOutputStream;
+import org.apache.lucene.util.BytesRef;
+import org.apache.lucene.util.IOUtils;
+
+/** Writes frq to .frq, docs to .doc, pos to .pos, payloads
+ *  to .pyl, skip data to .skp
+ *
+ * @lucene.experimental */
+public final class SepPostingsWriter extends PostingsWriterBase {
+  final static String CODEC = "SepPostingsWriter";
+
+  final static String DOC_EXTENSION = "doc";
+  final static String SKIP_EXTENSION = "skp";
+  final static String FREQ_EXTENSION = "frq";
+  final static String POS_EXTENSION = "pos";
+  final static String PAYLOAD_EXTENSION = "pyl";
+
+  // Increment version to change it:
+  final static int VERSION_START = 0;
+  final static int VERSION_CURRENT = VERSION_START;
+
+  IntIndexOutput freqOut;
+  IntIndexOutput.Index freqIndex;
+
+  IntIndexOutput posOut;
+  IntIndexOutput.Index posIndex;
+
+  IntIndexOutput docOut;
+  IntIndexOutput.Index docIndex;
+
+  IndexOutput payloadOut;
+
+  IndexOutput skipOut;
+
+  final SepSkipListWriter skipListWriter;
+  /** Expert: The fraction of TermDocs entries stored in skip tables,
+   * used to accelerate {@link DocsEnum#advance(int)}.  Larger values result in
+   * smaller indexes, greater acceleration, but fewer accelerable cases, while
+   * smaller values result in bigger indexes, less acceleration and more
+   * accelerable cases. More detailed experiments would be useful here. */
+  final int skipInterval;
+  static final int DEFAULT_SKIP_INTERVAL = 16;
+  
+  /**
+   * Expert: minimum docFreq to write any skip data at all
+   */
+  final int skipMinimum;
+
+  /** Expert: The maximum number of skip levels. Smaller values result in 
+   * slightly smaller indexes, but slower skipping in big posting lists.
+   */
+  final int maxSkipLevels = 10;
+
+  final int totalNumDocs;
+
+  bool storePayloads;
+  IndexOptions indexOptions;
+
+  FieldInfo fieldInfo;
+
+  int lastPayloadLength;
+  int lastPosition;
+  long payloadStart;
+  int lastDocID;
+  int df;
+
+  SepTermState lastState;
+  long lastPayloadFP;
+  long lastSkipFP;
+
+  public SepPostingsWriter(SegmentWriteState state, IntStreamFactory factory)  {
+    this(state, factory, DEFAULT_SKIP_INTERVAL);
+  }
+
+  public SepPostingsWriter(SegmentWriteState state, IntStreamFactory factory, int skipInterval)  {
+    freqOut = null;
+    freqIndex = null;
+    posOut = null;
+    posIndex = null;
+    payloadOut = null;
+    bool success = false;
+    try {
+      this.skipInterval = skipInterval;
+      this.skipMinimum = skipInterval; /* set to the same for now */
+      final String docFileName = IndexFileNames.segmentFileName(state.segmentInfo.name, state.segmentSuffix, DOC_EXTENSION);
+
+      docOut = factory.createOutput(state.directory, docFileName, state.context);
+      docIndex = docOut.index();
+
+      if (state.fieldInfos.hasFreq()) {
+        final String frqFileName = IndexFileNames.segmentFileName(state.segmentInfo.name, state.segmentSuffix, FREQ_EXTENSION);
+        freqOut = factory.createOutput(state.directory, frqFileName, state.context);
+        freqIndex = freqOut.index();
+      }
+
+      if (state.fieldInfos.hasProx()) {      
+        final String posFileName = IndexFileNames.segmentFileName(state.segmentInfo.name, state.segmentSuffix, POS_EXTENSION);
+        posOut = factory.createOutput(state.directory, posFileName, state.context);
+        posIndex = posOut.index();
+        
+        // TODO: -- only if at least one field stores payloads?
+        final String payloadFileName = IndexFileNames.segmentFileName(state.segmentInfo.name, state.segmentSuffix, PAYLOAD_EXTENSION);
+        payloadOut = state.directory.createOutput(payloadFileName, state.context);
+      }
+
+      final String skipFileName = IndexFileNames.segmentFileName(state.segmentInfo.name, state.segmentSuffix, SKIP_EXTENSION);
+      skipOut = state.directory.createOutput(skipFileName, state.context);
+      
+      totalNumDocs = state.segmentInfo.getDocCount();
+      
+      skipListWriter = new SepSkipListWriter(skipInterval,
+          maxSkipLevels,
+          totalNumDocs,
+          freqOut, docOut,
+          posOut, payloadOut);
+      
+      success = true;
+    } finally {
+      if (!success) {
+        IOUtils.closeWhileHandlingException(docOut, skipOut, freqOut, posOut, payloadOut);
+      }
+    }
+  }
+
+  @Override
+  public void init(IndexOutput termsOut)  {
+    CodecUtil.writeHeader(termsOut, CODEC, VERSION_CURRENT);
+    // TODO: -- just ask skipper to "start" here
+    termsOut.writeInt(skipInterval);                // write skipInterval
+    termsOut.writeInt(maxSkipLevels);               // write maxSkipLevels
+    termsOut.writeInt(skipMinimum);                 // write skipMinimum
+  }
+
+  @Override
+  public BlockTermState newTermState() {
+    return new SepTermState();
+  }
+
+  @Override
+  public void startTerm()  {
+    docIndex.mark();
+    //System.out.println("SEPW: startTerm docIndex=" + docIndex);
+
+    if (indexOptions != IndexOptions.DOCS_ONLY) {
+      freqIndex.mark();
+    }
+    
+    if (indexOptions == IndexOptions.DOCS_AND_FREQS_AND_POSITIONS) {
+      posIndex.mark();
+      payloadStart = payloadOut.getFilePointer();
+      lastPayloadLength = -1;
+    }
+
+    skipListWriter.resetSkip(docIndex, freqIndex, posIndex);
+  }
+
+  // Currently, this instance is re-used across fields, so
+  // our parent calls setField whenever the field changes
+  @Override
+  public int setField(FieldInfo fieldInfo) {
+    this.fieldInfo = fieldInfo;
+    this.indexOptions = fieldInfo.getIndexOptions();
+    if (indexOptions.compareTo(IndexOptions.DOCS_AND_FREQS_AND_POSITIONS_AND_OFFSETS) >= 0) {
+      throw new UnsupportedOperationException("this codec cannot index offsets");
+    }
+    skipListWriter.setIndexOptions(indexOptions);
+    storePayloads = indexOptions == IndexOptions.DOCS_AND_FREQS_AND_POSITIONS && fieldInfo.hasPayloads();
+    lastPayloadFP = 0;
+    lastSkipFP = 0;
+    lastState = setEmptyState();
+    return 0;
+  }
+
+  private SepTermState setEmptyState() {
+    SepTermState emptyState = new SepTermState();
+    emptyState.docIndex = docOut.index();
+    if (indexOptions != IndexOptions.DOCS_ONLY) {
+      emptyState.freqIndex = freqOut.index();
+      if (indexOptions == IndexOptions.DOCS_AND_FREQS_AND_POSITIONS) {
+        emptyState.posIndex = posOut.index();
+      }
+    }
+    emptyState.payloadFP = 0;
+    emptyState.skipFP = 0;
+    return emptyState;
+  }
+
+  /** Adds a new doc in this term.  If this returns null
+   *  then we just skip consuming positions/payloads. */
+  @Override
+  public void startDoc(int docID, int termDocFreq)  {
+
+    final int delta = docID - lastDocID;
+    //System.out.println("SEPW: startDoc: write doc=" + docID + " delta=" + delta + " out.fp=" + docOut);
+
+    if (docID < 0 || (df > 0 && delta <= 0)) {
+      throw new CorruptIndexException("docs out of order (" + docID + " <= " + lastDocID + " ) (docOut: " + docOut + ")");
+    }
+
+    if ((++df % skipInterval) == 0) {
+      // TODO: -- awkward we have to make these two
+      // separate calls to skipper
+      //System.out.println("    buffer skip lastDocID=" + lastDocID);
+      skipListWriter.setSkipData(lastDocID, storePayloads, lastPayloadLength);
+      skipListWriter.bufferSkip(df);
+    }
+
+    lastDocID = docID;
+    docOut.write(delta);
+    if (indexOptions != IndexOptions.DOCS_ONLY) {
+      //System.out.println("    sepw startDoc: write freq=" + termDocFreq);
+      freqOut.write(termDocFreq);
+    }
+  }
+
+  /** Add a new position & payload */
+  @Override
+  public void addPosition(int position, BytesRef payload, int startOffset, int endOffset)  {
+    Debug.Assert( indexOptions == IndexOptions.DOCS_AND_FREQS_AND_POSITIONS;
+
+    final int delta = position - lastPosition;
+    Debug.Assert( delta >= 0: "position=" + position + " lastPosition=" + lastPosition;            // not quite right (if pos=0 is repeated twice we don't catch it)
+    lastPosition = position;
+
+    if (storePayloads) {
+      final int payloadLength = payload == null ? 0 : payload.length;
+      if (payloadLength != lastPayloadLength) {
+        lastPayloadLength = payloadLength;
+        // TODO: explore whether we get better compression
+        // by not storing payloadLength into prox stream?
+        posOut.write((delta<<1)|1);
+        posOut.write(payloadLength);
+      } else {
+        posOut.write(delta << 1);
+      }
+
+      if (payloadLength > 0) {
+        payloadOut.writeBytes(payload.bytes, payload.offset, payloadLength);
+      }
+    } else {
+      posOut.write(delta);
+    }
+
+    lastPosition = position;
+  }
+
+  /** Called when we are done adding positions & payloads */
+  @Override
+  public void finishDoc() {       
+    lastPosition = 0;
+  }
+
+  private static class SepTermState extends BlockTermState {
+    public IntIndexOutput.Index docIndex;
+    public IntIndexOutput.Index freqIndex;
+    public IntIndexOutput.Index posIndex;
+    public long payloadFP;
+    public long skipFP;
+  }
+
+  /** Called when we are done adding docs to this term */
+  @Override
+  public void finishTerm(BlockTermState _state)  {
+    SepTermState state = (SepTermState)_state;
+    // TODO: -- wasteful we are counting this in two places?
+    Debug.Assert( state.docFreq > 0;
+    Debug.Assert( state.docFreq == df;
+
+    state.docIndex = docOut.index();
+    state.docIndex.copyFrom(docIndex, false);
+    if (indexOptions != IndexOptions.DOCS_ONLY) {
+      state.freqIndex = freqOut.index();
+      state.freqIndex.copyFrom(freqIndex, false);
+      if (indexOptions == IndexOptions.DOCS_AND_FREQS_AND_POSITIONS) {
+        state.posIndex = posOut.index();
+        state.posIndex.copyFrom(posIndex, false);
+      } else {
+        state.posIndex = null;
+      }
+    } else {
+      state.freqIndex = null;
+      state.posIndex = null;
+    }
+
+    if (df >= skipMinimum) {
+      state.skipFP = skipOut.getFilePointer();
+      //System.out.println("  skipFP=" + skipFP);
+      skipListWriter.writeSkip(skipOut);
+      //System.out.println("    numBytes=" + (skipOut.getFilePointer()-skipFP));
+    } else {
+      state.skipFP = -1;
+    }
+    state.payloadFP = payloadStart;
+
+    lastDocID = 0;
+    df = 0;
+  }
+
+  @Override
+  public void encodeTerm(long[] longs, DataOutput out, FieldInfo fieldInfo, BlockTermState _state, bool absolute)  {
+    SepTermState state = (SepTermState)_state;
+    if (absolute) {
+      lastSkipFP = 0;
+      lastPayloadFP = 0;
+      lastState = state;
+    }
+    lastState.docIndex.copyFrom(state.docIndex, false);
+    lastState.docIndex.write(out, absolute);
+    if (indexOptions != IndexOptions.DOCS_ONLY) {
+      lastState.freqIndex.copyFrom(state.freqIndex, false);
+      lastState.freqIndex.write(out, absolute);
+      if (indexOptions == IndexOptions.DOCS_AND_FREQS_AND_POSITIONS) {
+        lastState.posIndex.copyFrom(state.posIndex, false);
+        lastState.posIndex.write(out, absolute);
+        if (storePayloads) {
+          if (absolute) {
+            out.writeVLong(state.payloadFP);
+          } else {
+            out.writeVLong(state.payloadFP - lastPayloadFP);
+          }
+          lastPayloadFP = state.payloadFP;
+        }
+      }
+    }
+    if (state.skipFP != -1) {
+      if (absolute) {
+        out.writeVLong(state.skipFP);
+      } else {
+        out.writeVLong(state.skipFP - lastSkipFP);
+      }
+      lastSkipFP = state.skipFP;
+    }
+  }
+
+  @Override
+  public void close()  {
+    IOUtils.close(docOut, skipOut, freqOut, posOut, payloadOut);
+  }
+}

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/src/Lucene.Net.Codecs/Sep/SepSkipListReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Codecs/Sep/SepSkipListReader.cs b/src/Lucene.Net.Codecs/Sep/SepSkipListReader.cs
new file mode 100644
index 0000000..df6dda1
--- /dev/null
+++ b/src/Lucene.Net.Codecs/Sep/SepSkipListReader.cs
@@ -0,0 +1,209 @@
+package org.apache.lucene.codecs.sep;
+
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+import java.io.IOException;
+import java.util.Arrays;
+
+import org.apache.lucene.store.IndexInput;
+import org.apache.lucene.codecs.MultiLevelSkipListReader;
+import org.apache.lucene.index.FieldInfo.IndexOptions;
+
+/**
+ * Implements the skip list reader for the default posting list format
+ * that stores positions and payloads.
+ *
+ * @lucene.experimental
+ */
+
+// TODO: rewrite this as recursive classes?
+class SepSkipListReader extends MultiLevelSkipListReader {
+  private bool currentFieldStoresPayloads;
+  private IntIndexInput.Index freqIndex[];
+  private IntIndexInput.Index docIndex[];
+  private IntIndexInput.Index posIndex[];
+  private long payloadPointer[];
+  private int payloadLength[];
+
+  private final IntIndexInput.Index lastFreqIndex;
+  private final IntIndexInput.Index lastDocIndex;
+  // TODO: -- make private again
+  final IntIndexInput.Index lastPosIndex;
+  
+  private long lastPayloadPointer;
+  private int lastPayloadLength;
+                           
+  SepSkipListReader(IndexInput skipStream,
+                    IntIndexInput freqIn,
+                    IntIndexInput docIn,
+                    IntIndexInput posIn,
+                    int maxSkipLevels,
+                    int skipInterval)
+     {
+    super(skipStream, maxSkipLevels, skipInterval);
+    if (freqIn != null) {
+      freqIndex = new IntIndexInput.Index[maxSkipLevels];
+    }
+    docIndex = new IntIndexInput.Index[maxSkipLevels];
+    if (posIn != null) {
+      posIndex = new IntIndexInput.Index[maxNumberOfSkipLevels];
+    }
+    for(int i=0;i<maxSkipLevels;i++) {
+      if (freqIn != null) {
+        freqIndex[i] = freqIn.index();
+      }
+      docIndex[i] = docIn.index();
+      if (posIn != null) {
+        posIndex[i] = posIn.index();
+      }
+    }
+    payloadPointer = new long[maxSkipLevels];
+    payloadLength = new int[maxSkipLevels];
+
+    if (freqIn != null) {
+      lastFreqIndex = freqIn.index();
+    } else {
+      lastFreqIndex = null;
+    }
+    lastDocIndex = docIn.index();
+    if (posIn != null) {
+      lastPosIndex = posIn.index();
+    } else {
+      lastPosIndex = null;
+    }
+  }
+  
+  IndexOptions indexOptions;
+
+  void setIndexOptions(IndexOptions v) {
+    indexOptions = v;
+  }
+
+  void init(long skipPointer,
+            IntIndexInput.Index docBaseIndex,
+            IntIndexInput.Index freqBaseIndex,
+            IntIndexInput.Index posBaseIndex,
+            long payloadBasePointer,
+            int df,
+            bool storesPayloads) {
+
+    super.init(skipPointer, df);
+    this.currentFieldStoresPayloads = storesPayloads;
+
+    lastPayloadPointer = payloadBasePointer;
+
+    for(int i=0;i<maxNumberOfSkipLevels;i++) {
+      docIndex[i].copyFrom(docBaseIndex);
+      if (freqIndex != null) {
+        freqIndex[i].copyFrom(freqBaseIndex);
+      }
+      if (posBaseIndex != null) {
+        posIndex[i].copyFrom(posBaseIndex);
+      }
+    }
+    Arrays.fill(payloadPointer, payloadBasePointer);
+    Arrays.fill(payloadLength, 0);
+  }
+
+  long getPayloadPointer() {
+    return lastPayloadPointer;
+  }
+  
+  /** Returns the payload length of the payload stored just before 
+   * the doc to which the last call of {@link MultiLevelSkipListReader#skipTo(int)} 
+   * has skipped.  */
+  int getPayloadLength() {
+    return lastPayloadLength;
+  }
+  
+  @Override
+  protected void seekChild(int level)  {
+    super.seekChild(level);
+    payloadPointer[level] = lastPayloadPointer;
+    payloadLength[level] = lastPayloadLength;
+  }
+  
+  @Override
+  protected void setLastSkipData(int level) {
+    super.setLastSkipData(level);
+
+    lastPayloadPointer = payloadPointer[level];
+    lastPayloadLength = payloadLength[level];
+    if (freqIndex != null) {
+      lastFreqIndex.copyFrom(freqIndex[level]);
+    }
+    lastDocIndex.copyFrom(docIndex[level]);
+    if (lastPosIndex != null) {
+      lastPosIndex.copyFrom(posIndex[level]);
+    }
+
+    if (level > 0) {
+      if (freqIndex != null) {
+        freqIndex[level-1].copyFrom(freqIndex[level]);
+      }
+      docIndex[level-1].copyFrom(docIndex[level]);
+      if (posIndex != null) {
+        posIndex[level-1].copyFrom(posIndex[level]);
+      }
+    }
+  }
+
+  IntIndexInput.Index getFreqIndex() {
+    return lastFreqIndex;
+  }
+
+  IntIndexInput.Index getPosIndex() {
+    return lastPosIndex;
+  }
+
+  IntIndexInput.Index getDocIndex() {
+    return lastDocIndex;
+  }
+
+  @Override
+  protected int readSkipData(int level, IndexInput skipStream)  {
+    int delta;
+    Debug.Assert( indexOptions == IndexOptions.DOCS_AND_FREQS_AND_POSITIONS || !currentFieldStoresPayloads;
+    if (currentFieldStoresPayloads) {
+      // the current field stores payloads.
+      // if the doc delta is odd then we have
+      // to read the current payload length
+      // because it differs from the length of the
+      // previous payload
+      delta = skipStream.readVInt();
+      if ((delta & 1) != 0) {
+        payloadLength[level] = skipStream.readVInt();
+      }
+      delta >>>= 1;
+    } else {
+      delta = skipStream.readVInt();
+    }
+    if (indexOptions != IndexOptions.DOCS_ONLY) {
+      freqIndex[level].read(skipStream, false);
+    }
+    docIndex[level].read(skipStream, false);
+    if (indexOptions == IndexOptions.DOCS_AND_FREQS_AND_POSITIONS) {
+      posIndex[level].read(skipStream, false);
+      if (currentFieldStoresPayloads) {
+        payloadPointer[level] += skipStream.readVInt();
+      }
+    }
+    
+    return delta;
+  }
+}

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/src/Lucene.Net.Codecs/Sep/SepSkipListWriter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Codecs/Sep/SepSkipListWriter.cs b/src/Lucene.Net.Codecs/Sep/SepSkipListWriter.cs
new file mode 100644
index 0000000..7ace983
--- /dev/null
+++ b/src/Lucene.Net.Codecs/Sep/SepSkipListWriter.cs
@@ -0,0 +1,200 @@
+package org.apache.lucene.codecs.sep;
+
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+import java.io.IOException;
+import java.util.Arrays;
+
+import org.apache.lucene.store.IndexOutput;
+import org.apache.lucene.codecs.MultiLevelSkipListWriter;
+import org.apache.lucene.index.FieldInfo.IndexOptions;
+
+// TODO: -- skip data should somehow be more local to the
+// particular stream (doc, freq, pos, payload)
+
+/**
+ * Implements the skip list writer for the default posting list format
+ * that stores positions and payloads.
+ *
+ * @lucene.experimental
+ */
+class SepSkipListWriter extends MultiLevelSkipListWriter {
+  private int[] lastSkipDoc;
+  private int[] lastSkipPayloadLength;
+  private long[] lastSkipPayloadPointer;
+
+  private IntIndexOutput.Index[] docIndex;
+  private IntIndexOutput.Index[] freqIndex;
+  private IntIndexOutput.Index[] posIndex;
+  
+  private IntIndexOutput freqOutput;
+  // TODO: -- private again
+  IntIndexOutput posOutput;
+  // TODO: -- private again
+  IndexOutput payloadOutput;
+
+  private int curDoc;
+  private bool curStorePayloads;
+  private int curPayloadLength;
+  private long curPayloadPointer;
+  
+  SepSkipListWriter(int skipInterval, int numberOfSkipLevels, int docCount,
+                    IntIndexOutput freqOutput,
+                    IntIndexOutput docOutput,
+                    IntIndexOutput posOutput,
+                    IndexOutput payloadOutput)
+     {
+    super(skipInterval, numberOfSkipLevels, docCount);
+
+    this.freqOutput = freqOutput;
+    this.posOutput = posOutput;
+    this.payloadOutput = payloadOutput;
+    
+    lastSkipDoc = new int[numberOfSkipLevels];
+    lastSkipPayloadLength = new int[numberOfSkipLevels];
+    // TODO: -- also cutover normal IndexOutput to use getIndex()?
+    lastSkipPayloadPointer = new long[numberOfSkipLevels];
+
+    freqIndex = new IntIndexOutput.Index[numberOfSkipLevels];
+    docIndex = new IntIndexOutput.Index[numberOfSkipLevels];
+    posIndex = new IntIndexOutput.Index[numberOfSkipLevels];
+
+    for(int i=0;i<numberOfSkipLevels;i++) {
+      if (freqOutput != null) {
+        freqIndex[i] = freqOutput.index();
+      }
+      docIndex[i] = docOutput.index();
+      if (posOutput != null) {
+        posIndex[i] = posOutput.index();
+      }
+    }
+  }
+
+  IndexOptions indexOptions;
+
+  void setIndexOptions(IndexOptions v) {
+    indexOptions = v;
+  }
+
+  void setPosOutput(IntIndexOutput posOutput)  {
+    this.posOutput = posOutput;
+    for(int i=0;i<numberOfSkipLevels;i++) {
+      posIndex[i] = posOutput.index();
+    }
+  }
+
+  void setPayloadOutput(IndexOutput payloadOutput) {
+    this.payloadOutput = payloadOutput;
+  }
+
+  /**
+   * Sets the values for the current skip data. 
+   */
+  // Called @ every index interval (every 128th (by default)
+  // doc)
+  void setSkipData(int doc, bool storePayloads, int payloadLength) {
+    this.curDoc = doc;
+    this.curStorePayloads = storePayloads;
+    this.curPayloadLength = payloadLength;
+    if (payloadOutput != null) {
+      this.curPayloadPointer = payloadOutput.getFilePointer();
+    }
+  }
+
+  // Called @ start of new term
+  protected void resetSkip(IntIndexOutput.Index topDocIndex, IntIndexOutput.Index topFreqIndex, IntIndexOutput.Index topPosIndex)
+     {
+    super.resetSkip();
+
+    Arrays.fill(lastSkipDoc, 0);
+    Arrays.fill(lastSkipPayloadLength, -1);  // we don't have to write the first length in the skip list
+    for(int i=0;i<numberOfSkipLevels;i++) {
+      docIndex[i].copyFrom(topDocIndex, true);
+      if (freqOutput != null) {
+        freqIndex[i].copyFrom(topFreqIndex, true);
+      }
+      if (posOutput != null) {
+        posIndex[i].copyFrom(topPosIndex, true);
+      }
+    }
+    if (payloadOutput != null) {
+      Arrays.fill(lastSkipPayloadPointer, payloadOutput.getFilePointer());
+    }
+  }
+  
+  @Override
+  protected void writeSkipData(int level, IndexOutput skipBuffer)  {
+    // To efficiently store payloads in the posting lists we do not store the length of
+    // every payload. Instead we omit the length for a payload if the previous payload had
+    // the same length.
+    // However, in order to support skipping the payload length at every skip point must be known.
+    // So we use the same length encoding that we use for the posting lists for the skip data as well:
+    // Case 1: current field does not store payloads
+    //           SkipDatum                 --> DocSkip, FreqSkip, ProxSkip
+    //           DocSkip,FreqSkip,ProxSkip --> VInt
+    //           DocSkip records the document number before every SkipInterval th  document in TermFreqs. 
+    //           Document numbers are represented as differences from the previous value in the sequence.
+    // Case 2: current field stores payloads
+    //           SkipDatum                 --> DocSkip, PayloadLength?, FreqSkip,ProxSkip
+    //           DocSkip,FreqSkip,ProxSkip --> VInt
+    //           PayloadLength             --> VInt    
+    //         In this case DocSkip/2 is the difference between
+    //         the current and the previous value. If DocSkip
+    //         is odd, then a PayloadLength encoded as VInt follows,
+    //         if DocSkip is even, then it is assumed that the
+    //         current payload length equals the length at the previous
+    //         skip point
+
+    Debug.Assert( indexOptions == IndexOptions.DOCS_AND_FREQS_AND_POSITIONS || !curStorePayloads;
+
+    if (curStorePayloads) {
+      int delta = curDoc - lastSkipDoc[level];
+      if (curPayloadLength == lastSkipPayloadLength[level]) {
+        // the current payload length equals the length at the previous skip point,
+        // so we don't store the length again
+        skipBuffer.writeVInt(delta << 1);
+      } else {
+        // the payload length is different from the previous one. We shift the DocSkip, 
+        // set the lowest bit and store the current payload length as VInt.
+        skipBuffer.writeVInt(delta << 1 | 1);
+        skipBuffer.writeVInt(curPayloadLength);
+        lastSkipPayloadLength[level] = curPayloadLength;
+      }
+    } else {
+      // current field does not store payloads
+      skipBuffer.writeVInt(curDoc - lastSkipDoc[level]);
+    }
+
+    if (indexOptions != IndexOptions.DOCS_ONLY) {
+      freqIndex[level].mark();
+      freqIndex[level].write(skipBuffer, false);
+    }
+    docIndex[level].mark();
+    docIndex[level].write(skipBuffer, false);
+    if (indexOptions == IndexOptions.DOCS_AND_FREQS_AND_POSITIONS) {
+      posIndex[level].mark();
+      posIndex[level].write(skipBuffer, false);
+      if (curStorePayloads) {
+        skipBuffer.writeVInt((int) (curPayloadPointer - lastSkipPayloadPointer[level]));
+      }
+    }
+
+    lastSkipDoc[level] = curDoc;
+    lastSkipPayloadPointer[level] = curPayloadPointer;
+  }
+}

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/src/Lucene.Net.Codecs/SimpleText/SimpleTextCodec.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Codecs/SimpleText/SimpleTextCodec.cs b/src/Lucene.Net.Codecs/SimpleText/SimpleTextCodec.cs
new file mode 100644
index 0000000..a26ed0e
--- /dev/null
+++ b/src/Lucene.Net.Codecs/SimpleText/SimpleTextCodec.cs
@@ -0,0 +1,89 @@
+package org.apache.lucene.codecs.simpletext;
+
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+import org.apache.lucene.codecs.Codec;
+import org.apache.lucene.codecs.FieldInfosFormat;
+import org.apache.lucene.codecs.LiveDocsFormat;
+import org.apache.lucene.codecs.PostingsFormat;
+import org.apache.lucene.codecs.SegmentInfoFormat;
+import org.apache.lucene.codecs.DocValuesFormat;
+import org.apache.lucene.codecs.NormsFormat;
+import org.apache.lucene.codecs.StoredFieldsFormat;
+import org.apache.lucene.codecs.TermVectorsFormat;
+
+/**
+ * plain text index format.
+ * <p>
+ * <b><font color="red">FOR RECREATIONAL USE ONLY</font></B>
+ * @lucene.experimental
+ */
+public final class SimpleTextCodec extends Codec {
+  private final PostingsFormat postings = new SimpleTextPostingsFormat();
+  private final StoredFieldsFormat storedFields = new SimpleTextStoredFieldsFormat();
+  private final SegmentInfoFormat segmentInfos = new SimpleTextSegmentInfoFormat();
+  private final FieldInfosFormat fieldInfosFormat = new SimpleTextFieldInfosFormat();
+  private final TermVectorsFormat vectorsFormat = new SimpleTextTermVectorsFormat();
+  private final NormsFormat normsFormat = new SimpleTextNormsFormat();
+  private final LiveDocsFormat liveDocs = new SimpleTextLiveDocsFormat();
+  private final DocValuesFormat dvFormat = new SimpleTextDocValuesFormat();
+  
+  public SimpleTextCodec() {
+    super("SimpleText");
+  }
+  
+  @Override
+  public PostingsFormat postingsFormat() {
+    return postings;
+  }
+
+  @Override
+  public StoredFieldsFormat storedFieldsFormat() {
+    return storedFields;
+  }
+  
+  @Override
+  public TermVectorsFormat termVectorsFormat() {
+    return vectorsFormat;
+  }
+  
+  @Override
+  public FieldInfosFormat fieldInfosFormat() {
+    return fieldInfosFormat;
+  }
+
+  @Override
+  public SegmentInfoFormat segmentInfoFormat() {
+    return segmentInfos;
+  }
+
+  @Override
+  public NormsFormat normsFormat() {
+    return normsFormat;
+  }
+  
+  @Override
+  public LiveDocsFormat liveDocsFormat() {
+    return liveDocs;
+  }
+
+  @Override
+  public DocValuesFormat docValuesFormat() {
+    return dvFormat;
+  }
+}

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/src/Lucene.Net.Codecs/SimpleText/SimpleTextDocValuesFormat.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Codecs/SimpleText/SimpleTextDocValuesFormat.cs b/src/Lucene.Net.Codecs/SimpleText/SimpleTextDocValuesFormat.cs
new file mode 100644
index 0000000..83dd776
--- /dev/null
+++ b/src/Lucene.Net.Codecs/SimpleText/SimpleTextDocValuesFormat.cs
@@ -0,0 +1,137 @@
+package org.apache.lucene.codecs.simpletext;
+
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+import java.io.IOException;
+
+import org.apache.lucene.codecs.DocValuesConsumer;
+import org.apache.lucene.codecs.DocValuesProducer;
+import org.apache.lucene.codecs.DocValuesFormat;
+import org.apache.lucene.index.SegmentReadState;
+import org.apache.lucene.index.SegmentWriteState;
+
+/**
+ * plain text doc values format.
+ * <p>
+ * <b><font color="red">FOR RECREATIONAL USE ONLY</font></B>
+ * <p>
+ * the .dat file contains the data.
+ *  for numbers this is a "fixed-width" file, for example a single byte range:
+ *  <pre>
+ *  field myField
+ *    type NUMERIC
+ *    minvalue 0
+ *    pattern 000
+ *  005
+ *  T
+ *  234
+ *  T
+ *  123
+ *  T
+ *  ...
+ *  </pre>
+ *  so a document's value (delta encoded from minvalue) can be retrieved by 
+ *  seeking to startOffset + (1+pattern.length()+2)*docid. The extra 1 is the newline. 
+ *  The extra 2 is another newline and 'T' or 'F': true if the value is real, false if missing.
+ *  
+ *  for bytes this is also a "fixed-width" file, for example:
+ *  <pre>
+ *  field myField
+ *    type BINARY
+ *    maxlength 6
+ *    pattern 0
+ *  length 6
+ *  foobar[space][space]
+ *  T
+ *  length 3
+ *  baz[space][space][space][space][space]
+ *  T
+ *  ...
+ *  </pre>
+ *  so a doc's value can be retrieved by seeking to startOffset + (9+pattern.length+maxlength+2)*doc
+ *  the extra 9 is 2 newlines, plus "length " itself.
+ *  the extra 2 is another newline and 'T' or 'F': true if the value is real, false if missing.
+ *  
+ *  for sorted bytes this is a fixed-width file, for example:
+ *  <pre>
+ *  field myField
+ *    type SORTED
+ *    numvalues 10
+ *    maxLength 8
+ *    pattern 0
+ *    ordpattern 00
+ *  length 6
+ *  foobar[space][space]
+ *  length 3
+ *  baz[space][space][space][space][space]
+ *  ...
+ *  03
+ *  06
+ *  01
+ *  10
+ *  ...
+ *  </pre>
+ *  so the "ord section" begins at startOffset + (9+pattern.length+maxlength)*numValues.
+ *  a document's ord can be retrieved by seeking to "ord section" + (1+ordpattern.length())*docid
+ *  an ord's value can be retrieved by seeking to startOffset + (9+pattern.length+maxlength)*ord
+ *  
+ *  for sorted set this is a fixed-width file very similar to the SORTED case, for example:
+ *  <pre>
+ *  field myField
+ *    type SORTED_SET
+ *    numvalues 10
+ *    maxLength 8
+ *    pattern 0
+ *    ordpattern XXXXX
+ *  length 6
+ *  foobar[space][space]
+ *  length 3
+ *  baz[space][space][space][space][space]
+ *  ...
+ *  0,3,5   
+ *  1,2
+ *  
+ *  10
+ *  ...
+ *  </pre>
+ *  so the "ord section" begins at startOffset + (9+pattern.length+maxlength)*numValues.
+ *  a document's ord list can be retrieved by seeking to "ord section" + (1+ordpattern.length())*docid
+ *  this is a comma-separated list, and its padded with spaces to be fixed width. so trim() and split() it.
+ *  and beware the empty string!
+ *  an ord's value can be retrieved by seeking to startOffset + (9+pattern.length+maxlength)*ord
+ *   
+ *  the reader can just scan this file when it opens, skipping over the data blocks
+ *  and saving the offset/etc for each field. 
+ *  @lucene.experimental
+ */
+public class SimpleTextDocValuesFormat extends DocValuesFormat {
+  
+  public SimpleTextDocValuesFormat() {
+    super("SimpleText");
+  }
+
+  @Override
+  public DocValuesConsumer fieldsConsumer(SegmentWriteState state)  {
+    return new SimpleTextDocValuesWriter(state, "dat");
+  }
+
+  @Override
+  public DocValuesProducer fieldsProducer(SegmentReadState state)  {
+    return new SimpleTextDocValuesReader(state, "dat");
+  }
+}

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/src/Lucene.Net.Codecs/SimpleText/SimpleTextDocValuesReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Codecs/SimpleText/SimpleTextDocValuesReader.cs b/src/Lucene.Net.Codecs/SimpleText/SimpleTextDocValuesReader.cs
new file mode 100644
index 0000000..63c3cf8
--- /dev/null
+++ b/src/Lucene.Net.Codecs/SimpleText/SimpleTextDocValuesReader.cs
@@ -0,0 +1,489 @@
+package org.apache.lucene.codecs.simpletext;
+
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+import static org.apache.lucene.codecs.simpletext.SimpleTextDocValuesWriter.END;
+import static org.apache.lucene.codecs.simpletext.SimpleTextDocValuesWriter.FIELD;
+import static org.apache.lucene.codecs.simpletext.SimpleTextDocValuesWriter.LENGTH;
+import static org.apache.lucene.codecs.simpletext.SimpleTextDocValuesWriter.MAXLENGTH;
+import static org.apache.lucene.codecs.simpletext.SimpleTextDocValuesWriter.MINVALUE;
+import static org.apache.lucene.codecs.simpletext.SimpleTextDocValuesWriter.NUMVALUES;
+import static org.apache.lucene.codecs.simpletext.SimpleTextDocValuesWriter.ORDPATTERN;
+import static org.apache.lucene.codecs.simpletext.SimpleTextDocValuesWriter.PATTERN;
+import static org.apache.lucene.codecs.simpletext.SimpleTextDocValuesWriter.TYPE;
+
+import java.io.IOException;
+import java.math.BigDecimal;
+import java.math.BigInteger;
+import java.nio.charset.StandardCharsets;
+import java.text.DecimalFormat;
+import java.text.DecimalFormatSymbols;
+import java.text.ParseException;
+import java.util.HashMap;
+import java.util.Locale;
+import java.util.Map;
+
+import org.apache.lucene.codecs.DocValuesProducer;
+import org.apache.lucene.index.BinaryDocValues;
+import org.apache.lucene.index.CorruptIndexException;
+import org.apache.lucene.index.DocValues;
+import org.apache.lucene.index.FieldInfo;
+import org.apache.lucene.index.FieldInfo.DocValuesType;
+import org.apache.lucene.index.IndexFileNames;
+import org.apache.lucene.index.NumericDocValues;
+import org.apache.lucene.index.SegmentReadState;
+import org.apache.lucene.index.SortedDocValues;
+import org.apache.lucene.index.SortedSetDocValues;
+import org.apache.lucene.store.BufferedChecksumIndexInput;
+import org.apache.lucene.store.ChecksumIndexInput;
+import org.apache.lucene.store.IndexInput;
+import org.apache.lucene.util.Bits;
+import org.apache.lucene.util.BytesRef;
+import org.apache.lucene.util.StringHelper;
+
+class SimpleTextDocValuesReader extends DocValuesProducer {
+
+  static class OneField {
+    long dataStartFilePointer;
+    String pattern;
+    String ordPattern;
+    int maxLength;
+    bool fixedLength;
+    long minValue;
+    long numValues;
+  }
+
+  final int maxDoc;
+  final IndexInput data;
+  final BytesRef scratch = new BytesRef();
+  final Map<String,OneField> fields = new HashMap<>();
+  
+  public SimpleTextDocValuesReader(SegmentReadState state, String ext)  {
+    // System.out.println("dir=" + state.directory + " seg=" + state.segmentInfo.name + " file=" + IndexFileNames.segmentFileName(state.segmentInfo.name, state.segmentSuffix, ext));
+    data = state.directory.openInput(IndexFileNames.segmentFileName(state.segmentInfo.name, state.segmentSuffix, ext), state.context);
+    maxDoc = state.segmentInfo.getDocCount();
+    while(true) {
+      readLine();
+      //System.out.println("READ field=" + scratch.utf8ToString());
+      if (scratch.equals(END)) {
+        break;
+      }
+      Debug.Assert( startsWith(FIELD) : scratch.utf8ToString();
+      String fieldName = stripPrefix(FIELD);
+      //System.out.println("  field=" + fieldName);
+
+      OneField field = new OneField();
+      fields.put(fieldName, field);
+
+      readLine();
+      Debug.Assert( startsWith(TYPE) : scratch.utf8ToString();
+
+      DocValuesType dvType = DocValuesType.valueOf(stripPrefix(TYPE));
+      Debug.Assert( dvType != null;
+      if (dvType == DocValuesType.NUMERIC) {
+        readLine();
+        Debug.Assert( startsWith(MINVALUE): "got " + scratch.utf8ToString() + " field=" + fieldName + " ext=" + ext;
+        field.minValue = Long.parseLong(stripPrefix(MINVALUE));
+        readLine();
+        Debug.Assert( startsWith(PATTERN);
+        field.pattern = stripPrefix(PATTERN);
+        field.dataStartFilePointer = data.getFilePointer();
+        data.seek(data.getFilePointer() + (1+field.pattern.length()+2) * maxDoc);
+      } else if (dvType == DocValuesType.BINARY) {
+        readLine();
+        Debug.Assert( startsWith(MAXLENGTH);
+        field.maxLength = Integer.parseInt(stripPrefix(MAXLENGTH));
+        readLine();
+        Debug.Assert( startsWith(PATTERN);
+        field.pattern = stripPrefix(PATTERN);
+        field.dataStartFilePointer = data.getFilePointer();
+        data.seek(data.getFilePointer() + (9+field.pattern.length()+field.maxLength+2) * maxDoc);
+      } else if (dvType == DocValuesType.SORTED || dvType == DocValuesType.SORTED_SET) {
+        readLine();
+        Debug.Assert( startsWith(NUMVALUES);
+        field.numValues = Long.parseLong(stripPrefix(NUMVALUES));
+        readLine();
+        Debug.Assert( startsWith(MAXLENGTH);
+        field.maxLength = Integer.parseInt(stripPrefix(MAXLENGTH));
+        readLine();
+        Debug.Assert( startsWith(PATTERN);
+        field.pattern = stripPrefix(PATTERN);
+        readLine();
+        Debug.Assert( startsWith(ORDPATTERN);
+        field.ordPattern = stripPrefix(ORDPATTERN);
+        field.dataStartFilePointer = data.getFilePointer();
+        data.seek(data.getFilePointer() + (9+field.pattern.length()+field.maxLength) * field.numValues + (1+field.ordPattern.length())*maxDoc);
+      } else {
+        throw new Debug.Assert(ionError();
+      }
+    }
+
+    // We should only be called from above if at least one
+    // field has DVs:
+    Debug.Assert( !fields.isEmpty();
+  }
+
+  @Override
+  public NumericDocValues getNumeric(FieldInfo fieldInfo)  {
+    final OneField field = fields.get(fieldInfo.name);
+    Debug.Assert( field != null;
+
+    // SegmentCoreReaders already verifies this field is
+    // valid:
+    Debug.Assert( field != null: "field=" + fieldInfo.name + " fields=" + fields;
+
+    final IndexInput in = data.clone();
+    final BytesRef scratch = new BytesRef();
+    final DecimalFormat decoder = new DecimalFormat(field.pattern, new DecimalFormatSymbols(Locale.ROOT));
+
+    decoder.setParseBigDecimal(true);
+
+    return new NumericDocValues() {
+      @Override
+      public long get(int docID) {
+        try {
+          //System.out.println(Thread.currentThread().getName() + ": get docID=" + docID + " in=" + in);
+          if (docID < 0 || docID >= maxDoc) {
+            throw new IndexOutOfBoundsException("docID must be 0 .. " + (maxDoc-1) + "; got " + docID);
+          }
+          in.seek(field.dataStartFilePointer + (1+field.pattern.length()+2)*docID);
+          SimpleTextUtil.readLine(in, scratch);
+          //System.out.println("parsing delta: " + scratch.utf8ToString());
+          BigDecimal bd;
+          try {
+            bd = (BigDecimal) decoder.parse(scratch.utf8ToString());
+          } catch (ParseException pe) {
+            CorruptIndexException e = new CorruptIndexException("failed to parse BigDecimal value (resource=" + in + ")");
+            e.initCause(pe);
+            throw e;
+          }
+          SimpleTextUtil.readLine(in, scratch); // read the line telling us if its real or not
+          return BigInteger.valueOf(field.minValue).add(bd.toBigIntegerExact()).longValue();
+        } catch (IOException ioe) {
+          throw new RuntimeException(ioe);
+        }
+      }
+    };
+  }
+  
+  private Bits getNumericDocsWithField(FieldInfo fieldInfo)  {
+    final OneField field = fields.get(fieldInfo.name);
+    final IndexInput in = data.clone();
+    final BytesRef scratch = new BytesRef();
+    return new Bits() {
+      @Override
+      public bool get(int index) {
+        try {
+          in.seek(field.dataStartFilePointer + (1+field.pattern.length()+2)*index);
+          SimpleTextUtil.readLine(in, scratch); // data
+          SimpleTextUtil.readLine(in, scratch); // 'T' or 'F'
+          return scratch.bytes[scratch.offset] == (byte) 'T';
+        } catch (IOException e) {
+          throw new RuntimeException(e);
+        }
+      }
+
+      @Override
+      public int length() {
+        return maxDoc;
+      }
+    };
+  }
+
+  @Override
+  public BinaryDocValues getBinary(FieldInfo fieldInfo)  {
+    final OneField field = fields.get(fieldInfo.name);
+
+    // SegmentCoreReaders already verifies this field is
+    // valid:
+    Debug.Assert( field != null;
+
+    final IndexInput in = data.clone();
+    final BytesRef scratch = new BytesRef();
+    final DecimalFormat decoder = new DecimalFormat(field.pattern, new DecimalFormatSymbols(Locale.ROOT));
+
+    return new BinaryDocValues() {
+      @Override
+      public void get(int docID, BytesRef result) {
+        try {
+          if (docID < 0 || docID >= maxDoc) {
+            throw new IndexOutOfBoundsException("docID must be 0 .. " + (maxDoc-1) + "; got " + docID);
+          }
+          in.seek(field.dataStartFilePointer + (9+field.pattern.length() + field.maxLength+2)*docID);
+          SimpleTextUtil.readLine(in, scratch);
+          Debug.Assert( StringHelper.startsWith(scratch, LENGTH);
+          int len;
+          try {
+            len = decoder.parse(new String(scratch.bytes, scratch.offset + LENGTH.length, scratch.length - LENGTH.length, StandardCharsets.UTF_8)).intValue();
+          } catch (ParseException pe) {
+            CorruptIndexException e = new CorruptIndexException("failed to parse int length (resource=" + in + ")");
+            e.initCause(pe);
+            throw e;
+          }
+          result.bytes = new byte[len];
+          result.offset = 0;
+          result.length = len;
+          in.readBytes(result.bytes, 0, len);
+        } catch (IOException ioe) {
+          throw new RuntimeException(ioe);
+        }
+      }
+    };
+  }
+  
+  private Bits getBinaryDocsWithField(FieldInfo fieldInfo)  {
+    final OneField field = fields.get(fieldInfo.name);
+    final IndexInput in = data.clone();
+    final BytesRef scratch = new BytesRef();
+    final DecimalFormat decoder = new DecimalFormat(field.pattern, new DecimalFormatSymbols(Locale.ROOT));
+
+    return new Bits() {
+      @Override
+      public bool get(int index) {
+        try {
+          in.seek(field.dataStartFilePointer + (9+field.pattern.length() + field.maxLength+2)*index);
+          SimpleTextUtil.readLine(in, scratch);
+          Debug.Assert( StringHelper.startsWith(scratch, LENGTH);
+          int len;
+          try {
+            len = decoder.parse(new String(scratch.bytes, scratch.offset + LENGTH.length, scratch.length - LENGTH.length, StandardCharsets.UTF_8)).intValue();
+          } catch (ParseException pe) {
+            CorruptIndexException e = new CorruptIndexException("failed to parse int length (resource=" + in + ")");
+            e.initCause(pe);
+            throw e;
+          }
+          // skip past bytes
+          byte bytes[] = new byte[len];
+          in.readBytes(bytes, 0, len);
+          SimpleTextUtil.readLine(in, scratch); // newline
+          SimpleTextUtil.readLine(in, scratch); // 'T' or 'F'
+          return scratch.bytes[scratch.offset] == (byte) 'T';
+        } catch (IOException ioe) {
+          throw new RuntimeException(ioe);
+        }
+      }
+
+      @Override
+      public int length() {
+        return maxDoc;
+      }
+    };
+  }
+
+  @Override
+  public SortedDocValues getSorted(FieldInfo fieldInfo)  {
+    final OneField field = fields.get(fieldInfo.name);
+
+    // SegmentCoreReaders already verifies this field is
+    // valid:
+    Debug.Assert( field != null;
+
+    final IndexInput in = data.clone();
+    final BytesRef scratch = new BytesRef();
+    final DecimalFormat decoder = new DecimalFormat(field.pattern, new DecimalFormatSymbols(Locale.ROOT));
+    final DecimalFormat ordDecoder = new DecimalFormat(field.ordPattern, new DecimalFormatSymbols(Locale.ROOT));
+
+    return new SortedDocValues() {
+      @Override
+      public int getOrd(int docID) {
+        if (docID < 0 || docID >= maxDoc) {
+          throw new IndexOutOfBoundsException("docID must be 0 .. " + (maxDoc-1) + "; got " + docID);
+        }
+        try {
+          in.seek(field.dataStartFilePointer + field.numValues * (9 + field.pattern.length() + field.maxLength) + docID * (1 + field.ordPattern.length()));
+          SimpleTextUtil.readLine(in, scratch);
+          try {
+            return (int) ordDecoder.parse(scratch.utf8ToString()).longValue()-1;
+          } catch (ParseException pe) {
+            CorruptIndexException e = new CorruptIndexException("failed to parse ord (resource=" + in + ")");
+            e.initCause(pe);
+            throw e;
+          }
+        } catch (IOException ioe) {
+          throw new RuntimeException(ioe);
+        }
+      }
+
+      @Override
+      public void lookupOrd(int ord, BytesRef result) {
+        try {
+          if (ord < 0 || ord >= field.numValues) {
+            throw new IndexOutOfBoundsException("ord must be 0 .. " + (field.numValues-1) + "; got " + ord);
+          }
+          in.seek(field.dataStartFilePointer + ord * (9 + field.pattern.length() + field.maxLength));
+          SimpleTextUtil.readLine(in, scratch);
+          Debug.Assert( StringHelper.startsWith(scratch, LENGTH): "got " + scratch.utf8ToString() + " in=" + in;
+          int len;
+          try {
+            len = decoder.parse(new String(scratch.bytes, scratch.offset + LENGTH.length, scratch.length - LENGTH.length, StandardCharsets.UTF_8)).intValue();
+          } catch (ParseException pe) {
+            CorruptIndexException e = new CorruptIndexException("failed to parse int length (resource=" + in + ")");
+            e.initCause(pe);
+            throw e;
+          }
+          result.bytes = new byte[len];
+          result.offset = 0;
+          result.length = len;
+          in.readBytes(result.bytes, 0, len);
+        } catch (IOException ioe) {
+          throw new RuntimeException(ioe);
+        }
+      }
+
+      @Override
+      public int getValueCount() {
+        return (int)field.numValues;
+      }
+    };
+  }
+
+  @Override
+  public SortedSetDocValues getSortedSet(FieldInfo fieldInfo)  {
+    final OneField field = fields.get(fieldInfo.name);
+
+    // SegmentCoreReaders already verifies this field is
+    // valid:
+    Debug.Assert( field != null;
+
+    final IndexInput in = data.clone();
+    final BytesRef scratch = new BytesRef();
+    final DecimalFormat decoder = new DecimalFormat(field.pattern, new DecimalFormatSymbols(Locale.ROOT));
+    
+    return new SortedSetDocValues() {
+      String[] currentOrds = new String[0];
+      int currentIndex = 0;
+      
+      @Override
+      public long nextOrd() {
+        if (currentIndex == currentOrds.length) {
+          return NO_MORE_ORDS;
+        } else {
+          return Long.parseLong(currentOrds[currentIndex++]);
+        }
+      }
+
+      @Override
+      public void setDocument(int docID) {
+        if (docID < 0 || docID >= maxDoc) {
+          throw new IndexOutOfBoundsException("docID must be 0 .. " + (maxDoc-1) + "; got " + docID);
+        }
+        try {
+          in.seek(field.dataStartFilePointer + field.numValues * (9 + field.pattern.length() + field.maxLength) + docID * (1 + field.ordPattern.length()));
+          SimpleTextUtil.readLine(in, scratch);
+          String ordList = scratch.utf8ToString().trim();
+          if (ordList.isEmpty()) {
+            currentOrds = new String[0];
+          } else {
+            currentOrds = ordList.split(",");
+          }
+          currentIndex = 0;
+        } catch (IOException ioe) {
+          throw new RuntimeException(ioe);
+        }
+      }
+
+      @Override
+      public void lookupOrd(long ord, BytesRef result) {
+        try {
+          if (ord < 0 || ord >= field.numValues) {
+            throw new IndexOutOfBoundsException("ord must be 0 .. " + (field.numValues-1) + "; got " + ord);
+          }
+          in.seek(field.dataStartFilePointer + ord * (9 + field.pattern.length() + field.maxLength));
+          SimpleTextUtil.readLine(in, scratch);
+          Debug.Assert( StringHelper.startsWith(scratch, LENGTH): "got " + scratch.utf8ToString() + " in=" + in;
+          int len;
+          try {
+            len = decoder.parse(new String(scratch.bytes, scratch.offset + LENGTH.length, scratch.length - LENGTH.length, StandardCharsets.UTF_8)).intValue();
+          } catch (ParseException pe) {
+            CorruptIndexException e = new CorruptIndexException("failed to parse int length (resource=" + in + ")");
+            e.initCause(pe);
+            throw e;
+          }
+          result.bytes = new byte[len];
+          result.offset = 0;
+          result.length = len;
+          in.readBytes(result.bytes, 0, len);
+        } catch (IOException ioe) {
+          throw new RuntimeException(ioe);
+        }
+      }
+
+      @Override
+      public long getValueCount() {
+        return field.numValues;
+      }
+    };
+  }
+  
+  @Override
+  public Bits getDocsWithField(FieldInfo field)  {
+    switch (field.getDocValuesType()) {
+      case SORTED_SET:
+        return DocValues.docsWithValue(getSortedSet(field), maxDoc);
+      case SORTED:
+        return DocValues.docsWithValue(getSorted(field), maxDoc);
+      case BINARY:
+        return getBinaryDocsWithField(field);
+      case NUMERIC:
+        return getNumericDocsWithField(field);
+      default:
+        throw new Debug.Assert(ionError();
+    }
+  }
+
+  @Override
+  public void close()  {
+    data.close();
+  }
+
+  /** Used only in ctor: */
+  private void readLine()  {
+    SimpleTextUtil.readLine(data, scratch);
+    //System.out.println("line: " + scratch.utf8ToString());
+  }
+
+  /** Used only in ctor: */
+  private bool startsWith(BytesRef prefix) {
+    return StringHelper.startsWith(scratch, prefix);
+  }
+
+  /** Used only in ctor: */
+  private String stripPrefix(BytesRef prefix)  {
+    return new String(scratch.bytes, scratch.offset + prefix.length, scratch.length - prefix.length, StandardCharsets.UTF_8);
+  }
+
+  @Override
+  public long ramBytesUsed() {
+    return 0;
+  }
+
+  @Override
+  public void checkIntegrity()  {
+    BytesRef scratch = new BytesRef();
+    IndexInput clone = data.clone();
+    clone.seek(0);
+    ChecksumIndexInput input = new BufferedChecksumIndexInput(clone);
+    while(true) {
+      SimpleTextUtil.readLine(input, scratch);
+      if (scratch.equals(END)) {
+        SimpleTextUtil.checkFooter(input);
+        break;
+      }
+    }
+  }
+}

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/src/Lucene.Net.Codecs/SimpleText/SimpleTextDocValuesWriter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Codecs/SimpleText/SimpleTextDocValuesWriter.cs b/src/Lucene.Net.Codecs/SimpleText/SimpleTextDocValuesWriter.cs
new file mode 100644
index 0000000..6f89c10
--- /dev/null
+++ b/src/Lucene.Net.Codecs/SimpleText/SimpleTextDocValuesWriter.cs
@@ -0,0 +1,411 @@
+package org.apache.lucene.codecs.simpletext;
+
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+import java.io.IOException;
+import java.math.BigInteger;
+import java.text.DecimalFormat;
+import java.text.DecimalFormatSymbols;
+import java.util.HashSet;
+import java.util.Iterator;
+import java.util.Locale;
+import java.util.Set;
+
+import org.apache.lucene.codecs.DocValuesConsumer;
+import org.apache.lucene.index.FieldInfo;
+import org.apache.lucene.index.IndexFileNames;
+import org.apache.lucene.index.SegmentWriteState;
+import org.apache.lucene.index.FieldInfo.DocValuesType;
+import org.apache.lucene.store.IndexOutput;
+import org.apache.lucene.util.BytesRef;
+import org.apache.lucene.util.IOUtils;
+
+class SimpleTextDocValuesWriter extends DocValuesConsumer {
+  final static BytesRef END     = new BytesRef("END");
+  final static BytesRef FIELD   = new BytesRef("field ");
+  final static BytesRef TYPE    = new BytesRef("  type ");
+  // used for numerics
+  final static BytesRef MINVALUE = new BytesRef("  minvalue ");
+  final static BytesRef PATTERN  = new BytesRef("  pattern ");
+  // used for bytes
+  final static BytesRef LENGTH = new BytesRef("length ");
+  final static BytesRef MAXLENGTH = new BytesRef("  maxlength ");
+  // used for sorted bytes
+  final static BytesRef NUMVALUES = new BytesRef("  numvalues ");
+  final static BytesRef ORDPATTERN = new BytesRef("  ordpattern ");
+  
+  IndexOutput data;
+  final BytesRef scratch = new BytesRef();
+  final int numDocs;
+  private final Set<String> fieldsSeen = new HashSet<>(); // for Debug.Assert(ing
+  
+  public SimpleTextDocValuesWriter(SegmentWriteState state, String ext)  {
+    // System.out.println("WRITE: " + IndexFileNames.segmentFileName(state.segmentInfo.name, state.segmentSuffix, ext) + " " + state.segmentInfo.getDocCount() + " docs");
+    data = state.directory.createOutput(IndexFileNames.segmentFileName(state.segmentInfo.name, state.segmentSuffix, ext), state.context);
+    numDocs = state.segmentInfo.getDocCount();
+  }
+
+  // for Debug.Assert(ing
+  private bool fieldSeen(String field) {
+    Debug.Assert( !fieldsSeen.contains(field): "field \"" + field + "\" was added more than once during flush";
+    fieldsSeen.add(field);
+    return true;
+  }
+
+  @Override
+  public void addNumericField(FieldInfo field, Iterable<Number> values)  {
+    Debug.Assert( fieldSeen(field.name);
+    Debug.Assert( (field.getDocValuesType() == FieldInfo.DocValuesType.NUMERIC ||
+            field.getNormType() == FieldInfo.DocValuesType.NUMERIC);
+    writeFieldEntry(field, FieldInfo.DocValuesType.NUMERIC);
+
+    // first pass to find min/max
+    long minValue = Long.MAX_VALUE;
+    long maxValue = Long.MIN_VALUE;
+    for(Number n : values) {
+      long v = n == null ? 0 : n.longValue();
+      minValue = Math.min(minValue, v);
+      maxValue = Math.max(maxValue, v);
+    }
+    
+    // write our minimum value to the .dat, all entries are deltas from that
+    SimpleTextUtil.write(data, MINVALUE);
+    SimpleTextUtil.write(data, Long.toString(minValue), scratch);
+    SimpleTextUtil.writeNewline(data);
+    
+    // build up our fixed-width "simple text packed ints"
+    // format
+    BigInteger maxBig = BigInteger.valueOf(maxValue);
+    BigInteger minBig = BigInteger.valueOf(minValue);
+    BigInteger diffBig = maxBig.subtract(minBig);
+    int maxBytesPerValue = diffBig.toString().length();
+    StringBuilder sb = new StringBuilder();
+    for (int i = 0; i < maxBytesPerValue; i++) {
+      sb.append('0');
+    }
+    
+    // write our pattern to the .dat
+    SimpleTextUtil.write(data, PATTERN);
+    SimpleTextUtil.write(data, sb.toString(), scratch);
+    SimpleTextUtil.writeNewline(data);
+
+    final String patternString = sb.toString();
+    
+    final DecimalFormat encoder = new DecimalFormat(patternString, new DecimalFormatSymbols(Locale.ROOT));
+    
+    int numDocsWritten = 0;
+
+    // second pass to write the values
+    for(Number n : values) {
+      long value = n == null ? 0 : n.longValue();
+      Debug.Assert( value >= minValue;
+      Number delta = BigInteger.valueOf(value).subtract(BigInteger.valueOf(minValue));
+      String s = encoder.format(delta);
+      Debug.Assert( s.length() == patternString.length();
+      SimpleTextUtil.write(data, s, scratch);
+      SimpleTextUtil.writeNewline(data);
+      if (n == null) {
+        SimpleTextUtil.write(data, "F", scratch);
+      } else {
+        SimpleTextUtil.write(data, "T", scratch);
+      }
+      SimpleTextUtil.writeNewline(data);
+      numDocsWritten++;
+      Debug.Assert( numDocsWritten <= numDocs;
+    }
+
+    Debug.Assert( numDocs == numDocsWritten: "numDocs=" + numDocs + " numDocsWritten=" + numDocsWritten;
+  }
+
+  @Override
+  public void addBinaryField(FieldInfo field, Iterable<BytesRef> values)  {
+    Debug.Assert( fieldSeen(field.name);
+    Debug.Assert( field.getDocValuesType() == DocValuesType.BINARY;
+    int maxLength = 0;
+    for(BytesRef value : values) {
+      final int length = value == null ? 0 : value.length;
+      maxLength = Math.max(maxLength, length);
+    }
+    writeFieldEntry(field, FieldInfo.DocValuesType.BINARY);
+
+    // write maxLength
+    SimpleTextUtil.write(data, MAXLENGTH);
+    SimpleTextUtil.write(data, Integer.toString(maxLength), scratch);
+    SimpleTextUtil.writeNewline(data);
+    
+    int maxBytesLength = Long.toString(maxLength).length();
+    StringBuilder sb = new StringBuilder();
+    for (int i = 0; i < maxBytesLength; i++) {
+      sb.append('0');
+    }
+    // write our pattern for encoding lengths
+    SimpleTextUtil.write(data, PATTERN);
+    SimpleTextUtil.write(data, sb.toString(), scratch);
+    SimpleTextUtil.writeNewline(data);
+    final DecimalFormat encoder = new DecimalFormat(sb.toString(), new DecimalFormatSymbols(Locale.ROOT));
+
+    int numDocsWritten = 0;
+    for(BytesRef value : values) {
+      // write length
+      final int length = value == null ? 0 : value.length;
+      SimpleTextUtil.write(data, LENGTH);
+      SimpleTextUtil.write(data, encoder.format(length), scratch);
+      SimpleTextUtil.writeNewline(data);
+        
+      // write bytes -- don't use SimpleText.write
+      // because it escapes:
+      if (value != null) {
+        data.writeBytes(value.bytes, value.offset, value.length);
+      }
+
+      // pad to fit
+      for (int i = length; i < maxLength; i++) {
+        data.writeByte((byte)' ');
+      }
+      SimpleTextUtil.writeNewline(data);
+      if (value == null) {
+        SimpleTextUtil.write(data, "F", scratch);
+      } else {
+        SimpleTextUtil.write(data, "T", scratch);
+      }
+      SimpleTextUtil.writeNewline(data);
+      numDocsWritten++;
+    }
+
+    Debug.Assert( numDocs == numDocsWritten;
+  }
+  
+  @Override
+  public void addSortedField(FieldInfo field, Iterable<BytesRef> values, Iterable<Number> docToOrd)  {
+    Debug.Assert( fieldSeen(field.name);
+    Debug.Assert( field.getDocValuesType() == DocValuesType.SORTED;
+    writeFieldEntry(field, FieldInfo.DocValuesType.SORTED);
+
+    int valueCount = 0;
+    int maxLength = -1;
+    for(BytesRef value : values) {
+      maxLength = Math.max(maxLength, value.length);
+      valueCount++;
+    }
+
+    // write numValues
+    SimpleTextUtil.write(data, NUMVALUES);
+    SimpleTextUtil.write(data, Integer.toString(valueCount), scratch);
+    SimpleTextUtil.writeNewline(data);
+    
+    // write maxLength
+    SimpleTextUtil.write(data, MAXLENGTH);
+    SimpleTextUtil.write(data, Integer.toString(maxLength), scratch);
+    SimpleTextUtil.writeNewline(data);
+    
+    int maxBytesLength = Integer.toString(maxLength).length();
+    StringBuilder sb = new StringBuilder();
+    for (int i = 0; i < maxBytesLength; i++) {
+      sb.append('0');
+    }
+    
+    // write our pattern for encoding lengths
+    SimpleTextUtil.write(data, PATTERN);
+    SimpleTextUtil.write(data, sb.toString(), scratch);
+    SimpleTextUtil.writeNewline(data);
+    final DecimalFormat encoder = new DecimalFormat(sb.toString(), new DecimalFormatSymbols(Locale.ROOT));
+    
+    int maxOrdBytes = Long.toString(valueCount+1L).length();
+    sb.setLength(0);
+    for (int i = 0; i < maxOrdBytes; i++) {
+      sb.append('0');
+    }
+    
+    // write our pattern for ords
+    SimpleTextUtil.write(data, ORDPATTERN);
+    SimpleTextUtil.write(data, sb.toString(), scratch);
+    SimpleTextUtil.writeNewline(data);
+    final DecimalFormat ordEncoder = new DecimalFormat(sb.toString(), new DecimalFormatSymbols(Locale.ROOT));
+
+    // for Debug.Assert(s:
+    int valuesSeen = 0;
+
+    for(BytesRef value : values) {
+      // write length
+      SimpleTextUtil.write(data, LENGTH);
+      SimpleTextUtil.write(data, encoder.format(value.length), scratch);
+      SimpleTextUtil.writeNewline(data);
+        
+      // write bytes -- don't use SimpleText.write
+      // because it escapes:
+      data.writeBytes(value.bytes, value.offset, value.length);
+
+      // pad to fit
+      for (int i = value.length; i < maxLength; i++) {
+        data.writeByte((byte)' ');
+      }
+      SimpleTextUtil.writeNewline(data);
+      valuesSeen++;
+      Debug.Assert( valuesSeen <= valueCount;
+    }
+
+    Debug.Assert( valuesSeen == valueCount;
+
+    for(Number ord : docToOrd) {
+      SimpleTextUtil.write(data, ordEncoder.format(ord.longValue()+1), scratch);
+      SimpleTextUtil.writeNewline(data);
+    }
+  }
+
+  @Override
+  public void addSortedSetField(FieldInfo field, Iterable<BytesRef> values, Iterable<Number> docToOrdCount, Iterable<Number> ords)  {
+    Debug.Assert( fieldSeen(field.name);
+    Debug.Assert( field.getDocValuesType() == DocValuesType.SORTED_SET;
+    writeFieldEntry(field, FieldInfo.DocValuesType.SORTED_SET);
+
+    long valueCount = 0;
+    int maxLength = 0;
+    for(BytesRef value : values) {
+      maxLength = Math.max(maxLength, value.length);
+      valueCount++;
+    }
+
+    // write numValues
+    SimpleTextUtil.write(data, NUMVALUES);
+    SimpleTextUtil.write(data, Long.toString(valueCount), scratch);
+    SimpleTextUtil.writeNewline(data);
+    
+    // write maxLength
+    SimpleTextUtil.write(data, MAXLENGTH);
+    SimpleTextUtil.write(data, Integer.toString(maxLength), scratch);
+    SimpleTextUtil.writeNewline(data);
+    
+    int maxBytesLength = Integer.toString(maxLength).length();
+    StringBuilder sb = new StringBuilder();
+    for (int i = 0; i < maxBytesLength; i++) {
+      sb.append('0');
+    }
+    
+    // write our pattern for encoding lengths
+    SimpleTextUtil.write(data, PATTERN);
+    SimpleTextUtil.write(data, sb.toString(), scratch);
+    SimpleTextUtil.writeNewline(data);
+    final DecimalFormat encoder = new DecimalFormat(sb.toString(), new DecimalFormatSymbols(Locale.ROOT));
+    
+    // compute ord pattern: this is funny, we encode all values for all docs to find the maximum length
+    int maxOrdListLength = 0;
+    StringBuilder sb2 = new StringBuilder();
+    Iterator<Number> ordStream = ords.iterator();
+    for (Number n : docToOrdCount) {
+      sb2.setLength(0);
+      int count = n.intValue();
+      for (int i = 0; i < count; i++) {
+        long ord = ordStream.next().longValue();
+        if (sb2.length() > 0) {
+          sb2.append(",");
+        }
+        sb2.append(Long.toString(ord));
+      }
+      maxOrdListLength = Math.max(maxOrdListLength, sb2.length());
+    }
+     
+    sb2.setLength(0);
+    for (int i = 0; i < maxOrdListLength; i++) {
+      sb2.append('X');
+    }
+    
+    // write our pattern for ord lists
+    SimpleTextUtil.write(data, ORDPATTERN);
+    SimpleTextUtil.write(data, sb2.toString(), scratch);
+    SimpleTextUtil.writeNewline(data);
+    
+    // for Debug.Assert(s:
+    long valuesSeen = 0;
+
+    for(BytesRef value : values) {
+      // write length
+      SimpleTextUtil.write(data, LENGTH);
+      SimpleTextUtil.write(data, encoder.format(value.length), scratch);
+      SimpleTextUtil.writeNewline(data);
+        
+      // write bytes -- don't use SimpleText.write
+      // because it escapes:
+      data.writeBytes(value.bytes, value.offset, value.length);
+
+      // pad to fit
+      for (int i = value.length; i < maxLength; i++) {
+        data.writeByte((byte)' ');
+      }
+      SimpleTextUtil.writeNewline(data);
+      valuesSeen++;
+      Debug.Assert( valuesSeen <= valueCount;
+    }
+
+    Debug.Assert( valuesSeen == valueCount;
+
+    ordStream = ords.iterator();
+    
+    // write the ords for each doc comma-separated
+    for(Number n : docToOrdCount) {
+      sb2.setLength(0);
+      int count = n.intValue();
+      for (int i = 0; i < count; i++) {
+        long ord = ordStream.next().longValue();
+        if (sb2.length() > 0) {
+          sb2.append(",");
+        }
+        sb2.append(Long.toString(ord));
+      }
+      // now pad to fit: these are numbers so spaces work well. reader calls trim()
+      int numPadding = maxOrdListLength - sb2.length();
+      for (int i = 0; i < numPadding; i++) {
+        sb2.append(' ');
+      }
+      SimpleTextUtil.write(data, sb2.toString(), scratch);
+      SimpleTextUtil.writeNewline(data);
+    }
+  }
+
+  /** write the header for this field */
+  private void writeFieldEntry(FieldInfo field, FieldInfo.DocValuesType type)  {
+    SimpleTextUtil.write(data, FIELD);
+    SimpleTextUtil.write(data, field.name, scratch);
+    SimpleTextUtil.writeNewline(data);
+    
+    SimpleTextUtil.write(data, TYPE);
+    SimpleTextUtil.write(data, type.toString(), scratch);
+    SimpleTextUtil.writeNewline(data);
+  }
+  
+  @Override
+  public void close()  {
+    if (data != null) {
+      bool success = false;
+      try {
+        Debug.Assert( !fieldsSeen.isEmpty();
+        // TODO: sheisty to do this here?
+        SimpleTextUtil.write(data, END);
+        SimpleTextUtil.writeNewline(data);
+        SimpleTextUtil.writeChecksum(data, scratch);
+        success = true;
+      } finally {
+        if (success) {
+          IOUtils.close(data);
+        } else {
+          IOUtils.closeWhileHandlingException(data);
+        }
+        data = null;
+      }
+    }
+  }
+}

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/src/Lucene.Net.Codecs/SimpleText/SimpleTextFieldInfosFormat.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Codecs/SimpleText/SimpleTextFieldInfosFormat.cs b/src/Lucene.Net.Codecs/SimpleText/SimpleTextFieldInfosFormat.cs
new file mode 100644
index 0000000..9c6b0e3
--- /dev/null
+++ b/src/Lucene.Net.Codecs/SimpleText/SimpleTextFieldInfosFormat.cs
@@ -0,0 +1,45 @@
+package org.apache.lucene.codecs.simpletext;
+
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+import java.io.IOException;
+
+import org.apache.lucene.codecs.FieldInfosFormat;
+import org.apache.lucene.codecs.FieldInfosReader;
+import org.apache.lucene.codecs.FieldInfosWriter;
+
+/**
+ * plaintext field infos format
+ * <p>
+ * <b><font color="red">FOR RECREATIONAL USE ONLY</font></B>
+ * @lucene.experimental
+ */
+public class SimpleTextFieldInfosFormat extends FieldInfosFormat {
+  private final FieldInfosReader reader = new SimpleTextFieldInfosReader();
+  private final FieldInfosWriter writer = new SimpleTextFieldInfosWriter();
+
+  @Override
+  public FieldInfosReader getFieldInfosReader()  {
+    return reader;
+  }
+
+  @Override
+  public FieldInfosWriter getFieldInfosWriter()  {
+    return writer;
+  }
+}

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/src/Lucene.Net.Codecs/SimpleText/SimpleTextFieldInfosReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Codecs/SimpleText/SimpleTextFieldInfosReader.cs b/src/Lucene.Net.Codecs/SimpleText/SimpleTextFieldInfosReader.cs
new file mode 100644
index 0000000..ae01b58
--- /dev/null
+++ b/src/Lucene.Net.Codecs/SimpleText/SimpleTextFieldInfosReader.cs
@@ -0,0 +1,157 @@
+package org.apache.lucene.codecs.simpletext;
+
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+import java.io.IOException;
+import java.nio.charset.StandardCharsets;
+import java.util.Collections;
+import java.util.HashMap;
+import java.util.Map;
+
+import org.apache.lucene.codecs.FieldInfosReader;
+import org.apache.lucene.index.FieldInfo;
+import org.apache.lucene.index.FieldInfo.DocValuesType;
+import org.apache.lucene.index.FieldInfos;
+import org.apache.lucene.index.IndexFileNames;
+import org.apache.lucene.index.FieldInfo.IndexOptions;
+import org.apache.lucene.store.ChecksumIndexInput;
+import org.apache.lucene.store.Directory;
+import org.apache.lucene.store.IOContext;
+import org.apache.lucene.util.BytesRef;
+import org.apache.lucene.util.IOUtils;
+import org.apache.lucene.util.StringHelper;
+
+import static org.apache.lucene.codecs.simpletext.SimpleTextFieldInfosWriter.*;
+
+/**
+ * reads plaintext field infos files
+ * <p>
+ * <b><font color="red">FOR RECREATIONAL USE ONLY</font></B>
+ * @lucene.experimental
+ */
+public class SimpleTextFieldInfosReader extends FieldInfosReader {
+
+  @Override
+  public FieldInfos read(Directory directory, String segmentName, String segmentSuffix, IOContext iocontext)  {
+    final String fileName = IndexFileNames.segmentFileName(segmentName, segmentSuffix, FIELD_INFOS_EXTENSION);
+    ChecksumIndexInput input = directory.openChecksumInput(fileName, iocontext);
+    BytesRef scratch = new BytesRef();
+    
+    bool success = false;
+    try {
+      
+      SimpleTextUtil.readLine(input, scratch);
+      Debug.Assert( StringHelper.startsWith(scratch, NUMFIELDS);
+      final int size = Integer.parseInt(readString(NUMFIELDS.length, scratch));
+      FieldInfo infos[] = new FieldInfo[size];
+
+      for (int i = 0; i < size; i++) {
+        SimpleTextUtil.readLine(input, scratch);
+        Debug.Assert( StringHelper.startsWith(scratch, NAME);
+        String name = readString(NAME.length, scratch);
+        
+        SimpleTextUtil.readLine(input, scratch);
+        Debug.Assert( StringHelper.startsWith(scratch, NUMBER);
+        int fieldNumber = Integer.parseInt(readString(NUMBER.length, scratch));
+
+        SimpleTextUtil.readLine(input, scratch);
+        Debug.Assert( StringHelper.startsWith(scratch, ISINDEXED);
+        bool isIndexed = bool.parsebool(readString(ISINDEXED.length, scratch));
+        
+        final IndexOptions indexOptions;
+        if (isIndexed) {
+          SimpleTextUtil.readLine(input, scratch);
+          Debug.Assert( StringHelper.startsWith(scratch, INDEXOPTIONS);
+          indexOptions = IndexOptions.valueOf(readString(INDEXOPTIONS.length, scratch));          
+        } else {
+          indexOptions = null;
+        }
+        
+        SimpleTextUtil.readLine(input, scratch);
+        Debug.Assert( StringHelper.startsWith(scratch, STORETV);
+        bool storeTermVector = bool.parsebool(readString(STORETV.length, scratch));
+        
+        SimpleTextUtil.readLine(input, scratch);
+        Debug.Assert( StringHelper.startsWith(scratch, PAYLOADS);
+        bool storePayloads = bool.parsebool(readString(PAYLOADS.length, scratch));
+        
+        SimpleTextUtil.readLine(input, scratch);
+        Debug.Assert( StringHelper.startsWith(scratch, NORMS);
+        bool omitNorms = !bool.parsebool(readString(NORMS.length, scratch));
+        
+        SimpleTextUtil.readLine(input, scratch);
+        Debug.Assert( StringHelper.startsWith(scratch, NORMS_TYPE);
+        String nrmType = readString(NORMS_TYPE.length, scratch);
+        final DocValuesType normsType = docValuesType(nrmType);
+        
+        SimpleTextUtil.readLine(input, scratch);
+        Debug.Assert( StringHelper.startsWith(scratch, DOCVALUES);
+        String dvType = readString(DOCVALUES.length, scratch);
+        final DocValuesType docValuesType = docValuesType(dvType);
+        
+        SimpleTextUtil.readLine(input, scratch);
+        Debug.Assert( StringHelper.startsWith(scratch, DOCVALUES_GEN);
+        final long dvGen = Long.parseLong(readString(DOCVALUES_GEN.length, scratch));
+        
+        SimpleTextUtil.readLine(input, scratch);
+        Debug.Assert( StringHelper.startsWith(scratch, NUM_ATTS);
+        int numAtts = Integer.parseInt(readString(NUM_ATTS.length, scratch));
+        Map<String,String> atts = new HashMap<>();
+
+        for (int j = 0; j < numAtts; j++) {
+          SimpleTextUtil.readLine(input, scratch);
+          Debug.Assert( StringHelper.startsWith(scratch, ATT_KEY);
+          String key = readString(ATT_KEY.length, scratch);
+        
+          SimpleTextUtil.readLine(input, scratch);
+          Debug.Assert( StringHelper.startsWith(scratch, ATT_VALUE);
+          String value = readString(ATT_VALUE.length, scratch);
+          atts.put(key, value);
+        }
+
+        infos[i] = new FieldInfo(name, isIndexed, fieldNumber, storeTermVector, 
+          omitNorms, storePayloads, indexOptions, docValuesType, normsType, Collections.unmodifiableMap(atts));
+        infos[i].setDocValuesGen(dvGen);
+      }
+
+      SimpleTextUtil.checkFooter(input);
+      
+      FieldInfos fieldInfos = new FieldInfos(infos);
+      success = true;
+      return fieldInfos;
+    } finally {
+      if (success) {
+        input.close();
+      } else {
+        IOUtils.closeWhileHandlingException(input);
+      }
+    }
+  }
+
+  public DocValuesType docValuesType(String dvType) {
+    if ("false".equals(dvType)) {
+      return null;
+    } else {
+      return DocValuesType.valueOf(dvType);
+    }
+  }
+  
+  private String readString(int offset, BytesRef scratch) {
+    return new String(scratch.bytes, scratch.offset+offset, scratch.length-offset, StandardCharsets.UTF_8);
+  }
+}

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/src/Lucene.Net.Codecs/SimpleText/SimpleTextFieldInfosWriter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Codecs/SimpleText/SimpleTextFieldInfosWriter.cs b/src/Lucene.Net.Codecs/SimpleText/SimpleTextFieldInfosWriter.cs
new file mode 100644
index 0000000..b3bdbed
--- /dev/null
+++ b/src/Lucene.Net.Codecs/SimpleText/SimpleTextFieldInfosWriter.cs
@@ -0,0 +1,149 @@
+package org.apache.lucene.codecs.simpletext;
+
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+import java.io.IOException;
+import java.util.Map;
+
+import org.apache.lucene.codecs.FieldInfosWriter;
+import org.apache.lucene.index.FieldInfo;
+import org.apache.lucene.index.FieldInfo.DocValuesType;
+import org.apache.lucene.index.FieldInfos;
+import org.apache.lucene.index.IndexFileNames;
+import org.apache.lucene.index.FieldInfo.IndexOptions;
+import org.apache.lucene.store.Directory;
+import org.apache.lucene.store.IOContext;
+import org.apache.lucene.store.IndexOutput;
+import org.apache.lucene.util.BytesRef;
+import org.apache.lucene.util.IOUtils;
+
+/**
+ * writes plaintext field infos files
+ * <p>
+ * <b><font color="red">FOR RECREATIONAL USE ONLY</font></B>
+ * @lucene.experimental
+ */
+public class SimpleTextFieldInfosWriter extends FieldInfosWriter {
+  
+  /** Extension of field infos */
+  static final String FIELD_INFOS_EXTENSION = "inf";
+  
+  static final BytesRef NUMFIELDS       =  new BytesRef("number of fields ");
+  static final BytesRef NAME            =  new BytesRef("  name ");
+  static final BytesRef NUMBER          =  new BytesRef("  number ");
+  static final BytesRef ISINDEXED       =  new BytesRef("  indexed ");
+  static final BytesRef STORETV         =  new BytesRef("  term vectors ");
+  static final BytesRef STORETVPOS      =  new BytesRef("  term vector positions ");
+  static final BytesRef STORETVOFF      =  new BytesRef("  term vector offsets ");
+  static final BytesRef PAYLOADS        =  new BytesRef("  payloads ");
+  static final BytesRef NORMS           =  new BytesRef("  norms ");
+  static final BytesRef NORMS_TYPE      =  new BytesRef("  norms type ");
+  static final BytesRef DOCVALUES       =  new BytesRef("  doc values ");
+  static final BytesRef DOCVALUES_GEN   =  new BytesRef("  doc values gen ");
+  static final BytesRef INDEXOPTIONS    =  new BytesRef("  index options ");
+  static final BytesRef NUM_ATTS        =  new BytesRef("  attributes ");
+  final static BytesRef ATT_KEY         =  new BytesRef("    key ");
+  final static BytesRef ATT_VALUE       =  new BytesRef("    value ");
+  
+  @Override
+  public void write(Directory directory, String segmentName, String segmentSuffix, FieldInfos infos, IOContext context)  {
+    final String fileName = IndexFileNames.segmentFileName(segmentName, segmentSuffix, FIELD_INFOS_EXTENSION);
+    IndexOutput out = directory.createOutput(fileName, context);
+    BytesRef scratch = new BytesRef();
+    bool success = false;
+    try {
+      SimpleTextUtil.write(out, NUMFIELDS);
+      SimpleTextUtil.write(out, Integer.toString(infos.size()), scratch);
+      SimpleTextUtil.writeNewline(out);
+      
+      for (FieldInfo fi : infos) {
+        SimpleTextUtil.write(out, NAME);
+        SimpleTextUtil.write(out, fi.name, scratch);
+        SimpleTextUtil.writeNewline(out);
+        
+        SimpleTextUtil.write(out, NUMBER);
+        SimpleTextUtil.write(out, Integer.toString(fi.number), scratch);
+        SimpleTextUtil.writeNewline(out);
+        
+        SimpleTextUtil.write(out, ISINDEXED);
+        SimpleTextUtil.write(out, bool.toString(fi.isIndexed()), scratch);
+        SimpleTextUtil.writeNewline(out);
+        
+        if (fi.isIndexed()) {
+          Debug.Assert( fi.getIndexOptions().compareTo(IndexOptions.DOCS_AND_FREQS_AND_POSITIONS) >= 0 || !fi.hasPayloads();
+          SimpleTextUtil.write(out, INDEXOPTIONS);
+          SimpleTextUtil.write(out, fi.getIndexOptions().toString(), scratch);
+          SimpleTextUtil.writeNewline(out);
+        }
+        
+        SimpleTextUtil.write(out, STORETV);
+        SimpleTextUtil.write(out, bool.toString(fi.hasVectors()), scratch);
+        SimpleTextUtil.writeNewline(out);
+        
+        SimpleTextUtil.write(out, PAYLOADS);
+        SimpleTextUtil.write(out, bool.toString(fi.hasPayloads()), scratch);
+        SimpleTextUtil.writeNewline(out);
+               
+        SimpleTextUtil.write(out, NORMS);
+        SimpleTextUtil.write(out, bool.toString(!fi.omitsNorms()), scratch);
+        SimpleTextUtil.writeNewline(out);
+        
+        SimpleTextUtil.write(out, NORMS_TYPE);
+        SimpleTextUtil.write(out, getDocValuesType(fi.getNormType()), scratch);
+        SimpleTextUtil.writeNewline(out);
+        
+        SimpleTextUtil.write(out, DOCVALUES);
+        SimpleTextUtil.write(out, getDocValuesType(fi.getDocValuesType()), scratch);
+        SimpleTextUtil.writeNewline(out);
+        
+        SimpleTextUtil.write(out, DOCVALUES_GEN);
+        SimpleTextUtil.write(out, Long.toString(fi.getDocValuesGen()), scratch);
+        SimpleTextUtil.writeNewline(out);
+               
+        Map<String,String> atts = fi.attributes();
+        int numAtts = atts == null ? 0 : atts.size();
+        SimpleTextUtil.write(out, NUM_ATTS);
+        SimpleTextUtil.write(out, Integer.toString(numAtts), scratch);
+        SimpleTextUtil.writeNewline(out);
+      
+        if (numAtts > 0) {
+          for (Map.Entry<String,String> entry : atts.entrySet()) {
+            SimpleTextUtil.write(out, ATT_KEY);
+            SimpleTextUtil.write(out, entry.getKey(), scratch);
+            SimpleTextUtil.writeNewline(out);
+          
+            SimpleTextUtil.write(out, ATT_VALUE);
+            SimpleTextUtil.write(out, entry.getValue(), scratch);
+            SimpleTextUtil.writeNewline(out);
+          }
+        }
+      }
+      SimpleTextUtil.writeChecksum(out, scratch);
+      success = true;
+    } finally {
+      if (success) {
+        out.close();
+      } else {
+        IOUtils.closeWhileHandlingException(out);
+      }
+    }
+  }
+  
+  private static String getDocValuesType(DocValuesType type) {
+    return type == null ? "false" : type.toString();
+  }
+}


[48/51] [abbrv] [partial] Cleaning up and getting ready to development towards v4.8

Posted by sy...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/LICENSE.txt
----------------------------------------------------------------------
diff --git a/LICENSE.txt b/LICENSE.txt
index 8669b7c..08a10a0 100644
--- a/LICENSE.txt
+++ b/LICENSE.txt
@@ -136,7 +136,7 @@
       the terms of any separate license agreement you may have executed
       with Licensor regarding such Contributions.
 
-   6. Trademarks. This License does not grant permission to use the trade
+   6. Trademarks. this License does not grant permission to use the trade
       names, trademarks, service marks, or product names of the Licensor,
       except as required for reasonable and customary use in describing the
       origin of the Work and reproducing the content of the NOTICE file.
@@ -213,7 +213,7 @@ Here is the copyright from those sources:
  * 
  * Disclaimer
  * 
- * This source code is provided as is by Unicode, Inc. No claims are
+ * this source code is provided as is by Unicode, Inc. No claims are
  * made as to fitness for any particular purpose. No warranties of any
  * kind are expressed or implied. The recipient agrees to determine
  * applicability of information provided. If this file has been
@@ -221,7 +221,7 @@ Here is the copyright from those sources:
  * sole remedy for any claim will be exchange of defective media
  * within 90 days of receipt.
  * 
- * Limitations on Rights to Redistribute This Code
+ * Limitations on Rights to Redistribute this Code
  * 
  * Unicode, Inc. hereby grants the right to freely use the information
  * supplied in this file in the creation of products supporting the
@@ -259,7 +259,7 @@ modification, are permitted provided that the following conditions are met:
     * may be used to endorse or promote products derived from this software
     * without specific prior written permission.
 
-THIS SOFTWARE IS PROVIDED BY THE COPYRIGHT HOLDERS AND CONTRIBUTORS "AS IS"
+this SOFTWARE IS PROVIDED BY THE COPYRIGHT HOLDERS AND CONTRIBUTORS "AS IS"
 AND ANY EXPRESS OR IMPLIED WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE
 IMPLIED WARRANTIES OF MERCHANTABILITY AND FITNESS FOR A PARTICULAR PURPOSE ARE
 DISCLAIMED. IN NO EVENT SHALL THE COPYRIGHT OWNER OR CONTRIBUTORS BE LIABLE
@@ -268,4 +268,4 @@ DAMAGES (INCLUDING, BUT NOT LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR
 SERVICES; LOSS OF USE, DATA, OR PROFITS; OR BUSINESS INTERRUPTION) HOWEVER
 CAUSED AND ON ANY THEORY OF LIABILITY, WHETHER IN CONTRACT, STRICT LIABILITY,
 OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE) ARISING IN ANY WAY OUT OF THE USE
-OF THIS SOFTWARE, EVEN IF ADVISED OF THE POSSIBILITY OF SUCH DAMAGE.
\ No newline at end of file
+OF this SOFTWARE, EVEN IF ADVISED OF THE POSSIBILITY OF SUCH DAMAGE.

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/Lucene.Net.sln
----------------------------------------------------------------------
diff --git a/Lucene.Net.sln b/Lucene.Net.sln
new file mode 100644
index 0000000..bcb39c8
--- /dev/null
+++ b/Lucene.Net.sln
@@ -0,0 +1,57 @@
+
+Microsoft Visual Studio Solution File, Format Version 12.00
+# Visual Studio 2013
+VisualStudioVersion = 12.0.30110.0
+MinimumVisualStudioVersion = 10.0.40219.1
+Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net", "src\Lucene.Net.Core\Lucene.Net.csproj", "{5D4AD9BE-1FFB-41AB-9943-25737971BF57}"
+EndProject
+Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net.Tests", "src\Lucene.Net.Tests\Lucene.Net.Tests.csproj", "{DE63DB10-975F-460D-AF85-572C17A91284}"
+EndProject
+Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net.TestFramework", "src\Lucene.Net.TestFramework\Lucene.Net.TestFramework.csproj", "{B2C0D749-CE34-4F62-A15E-00CB2FF5DDB3}"
+EndProject
+Global
+	GlobalSection(SolutionConfigurationPlatforms) = preSolution
+		Debug|Any CPU = Debug|Any CPU
+		Debug|Mixed Platforms = Debug|Mixed Platforms
+		Debug|x86 = Debug|x86
+		Release|Any CPU = Release|Any CPU
+		Release|Mixed Platforms = Release|Mixed Platforms
+		Release|x86 = Release|x86
+	EndGlobalSection
+	GlobalSection(ProjectConfigurationPlatforms) = postSolution
+		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.ActiveCfg = Debug|x86
+		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Mixed Platforms.ActiveCfg = Debug|x86
+		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Mixed Platforms.Build.0 = Debug|x86
+		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|x86.ActiveCfg = Debug|x86
+		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|x86.Build.0 = Debug|x86
+		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.ActiveCfg = Release|x86
+		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Mixed Platforms.ActiveCfg = Release|x86
+		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Mixed Platforms.Build.0 = Release|x86
+		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|x86.ActiveCfg = Release|x86
+		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|x86.Build.0 = Release|x86
+		{DE63DB10-975F-460D-AF85-572C17A91284}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
+		{DE63DB10-975F-460D-AF85-572C17A91284}.Debug|Any CPU.Build.0 = Debug|Any CPU
+		{DE63DB10-975F-460D-AF85-572C17A91284}.Debug|Mixed Platforms.ActiveCfg = Debug|Any CPU
+		{DE63DB10-975F-460D-AF85-572C17A91284}.Debug|Mixed Platforms.Build.0 = Debug|Any CPU
+		{DE63DB10-975F-460D-AF85-572C17A91284}.Debug|x86.ActiveCfg = Debug|Any CPU
+		{DE63DB10-975F-460D-AF85-572C17A91284}.Debug|x86.Build.0 = Debug|Any CPU
+		{DE63DB10-975F-460D-AF85-572C17A91284}.Release|Any CPU.ActiveCfg = Release|Any CPU
+		{DE63DB10-975F-460D-AF85-572C17A91284}.Release|Any CPU.Build.0 = Release|Any CPU
+		{DE63DB10-975F-460D-AF85-572C17A91284}.Release|Mixed Platforms.ActiveCfg = Release|Any CPU
+		{DE63DB10-975F-460D-AF85-572C17A91284}.Release|Mixed Platforms.Build.0 = Release|Any CPU
+		{DE63DB10-975F-460D-AF85-572C17A91284}.Release|x86.ActiveCfg = Release|Any CPU
+		{B2C0D749-CE34-4F62-A15E-00CB2FF5DDB3}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
+		{B2C0D749-CE34-4F62-A15E-00CB2FF5DDB3}.Debug|Any CPU.Build.0 = Debug|Any CPU
+		{B2C0D749-CE34-4F62-A15E-00CB2FF5DDB3}.Debug|Mixed Platforms.ActiveCfg = Debug|Any CPU
+		{B2C0D749-CE34-4F62-A15E-00CB2FF5DDB3}.Debug|Mixed Platforms.Build.0 = Debug|Any CPU
+		{B2C0D749-CE34-4F62-A15E-00CB2FF5DDB3}.Debug|x86.ActiveCfg = Debug|Any CPU
+		{B2C0D749-CE34-4F62-A15E-00CB2FF5DDB3}.Release|Any CPU.ActiveCfg = Release|Any CPU
+		{B2C0D749-CE34-4F62-A15E-00CB2FF5DDB3}.Release|Any CPU.Build.0 = Release|Any CPU
+		{B2C0D749-CE34-4F62-A15E-00CB2FF5DDB3}.Release|Mixed Platforms.ActiveCfg = Release|Any CPU
+		{B2C0D749-CE34-4F62-A15E-00CB2FF5DDB3}.Release|Mixed Platforms.Build.0 = Release|Any CPU
+		{B2C0D749-CE34-4F62-A15E-00CB2FF5DDB3}.Release|x86.ActiveCfg = Release|Any CPU
+	EndGlobalSection
+	GlobalSection(SolutionProperties) = preSolution
+		HideSolutionNode = FALSE
+	EndGlobalSection
+EndGlobal

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/Lucene.Net.snk
----------------------------------------------------------------------
diff --git a/Lucene.Net.snk b/Lucene.Net.snk
new file mode 100644
index 0000000..f7f9ee5
Binary files /dev/null and b/Lucene.Net.snk differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/MyGet.bat
----------------------------------------------------------------------
diff --git a/MyGet.bat b/MyGet.bat
new file mode 100644
index 0000000..d538383
--- /dev/null
+++ b/MyGet.bat
@@ -0,0 +1,32 @@
+@echo Off
+set config=%1
+if "%config%" == "" (
+   set config=Release
+)
+
+set version=
+if not "%PackageVersion%" == "" (
+   set version=-Version %PackageVersion%
+)
+
+REM Packages restore
+%nuget% restore
+
+REM Build
+%WINDIR%\Microsoft.NET\Framework\v4.0.30319\msbuild Lucene.Net.sln /p:Configuration="%config%" /m /v:M /fl /flp:LogFile=msbuild.log;Verbosity=Normal /nr:false
+if not "%errorlevel%"=="0" goto failure
+
+REM Unit tests
+"%GallioEcho%" test\bin\%config%\Lucene.Net.Tests.dll
+if not "%errorlevel%"=="0" goto failure
+
+REM Package
+mkdir Build
+cmd /c %nuget% pack "src\core\Lucene.Net.csproj" -symbols -o Build -p Configuration=%config% %version%
+if not "%errorlevel%"=="0" goto failure
+
+:success
+exit 0
+
+:failure
+exit -1

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/NOTICE.txt
----------------------------------------------------------------------
diff --git a/NOTICE.txt b/NOTICE.txt
index 528c8a3..0386fa1 100644
--- a/NOTICE.txt
+++ b/NOTICE.txt
@@ -1,6 +1,6 @@
 Apache Lucene.Net
-Copyright 2006-2012 The Apache Software Foundation
+Copyright 2006-2014 The Apache Software Foundation
 
-This product includes software developed by
+this product includes software developed by
 The Apache Software Foundation (http://www.apache.org/).
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/README.txt
----------------------------------------------------------------------
diff --git a/README.txt b/README.txt
index 3c8ea20..100f8a4 100644
--- a/README.txt
+++ b/README.txt
@@ -15,16 +15,6 @@ Please join the Apache Lucene.Net-User mailing list by sending a message to:
   user-subscribe@lucenenet.apache.org
 
 
-CURRENT WORK
----------------
-The Lucene.NET committers and community are currently working on a version 4.3 port of Lucene that can be found in branch_4x of the git repository.  
-
-The apache source code for Lucene.Net can be found here:
-https://git-wip-us.apache.org/repos/asf/lucenenet.git
-
-
-
-
 FILES
 ---------------
 build/scripts
@@ -48,11 +38,11 @@ test/*
 DOCUMENTATION
 ---------------------
 MSDN style API documentation for Apache Lucene.Net exists.  Those can be found at this site:
-  http://lucenenet.apache.org/docs/3.0.3/Index.html
+  http://incubator.apache.org/lucene.net/docs/2.9.4/Index.html
   
   or 
   
-  http://lucenenet.apache.org/docs/3.0.3/Lucene.Net.chm
+  http://incubator.apache.org/lucene.net/docs/2.9.4/Lucene.Net.chm
   
 ADDITIONAL LIBRARIES
 -----------------------------
@@ -60,12 +50,11 @@ There are a number of additional libraries that various parts of Lucene.Net may
 included in the source distribution
 
 These libraries can be found at:
-	https://svn.apache.org/repos/asf/lucene.net/tags/Lucene.Net_3_0_3_RC1/lib/
+	https://svn.apache.org/repos/asf/incubator/lucene.net/tags/Lucene.Net_2_9_4_RC3/lib/
 	
 Libraries:
-  - Gallio 3.2.750
-  - ICSharpCode
-  - Nuget
-  - NUnit.org
-  - Spatial4n
-  - StyleCop 4.5
\ No newline at end of file
+	- Gallio 3.2.750
+	- ICSharpCode
+	- Nuget
+	- NUnit.org
+	- StyleCop 4.5
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build.cmd
----------------------------------------------------------------------
diff --git a/build.cmd b/build.cmd
deleted file mode 100644
index c6b9284..0000000
--- a/build.cmd
+++ /dev/null
@@ -1,27 +0,0 @@
-@echo off
-REM License Block
-GOTO LicenseEnd
- Licensed to the Apache Software Foundation (ASF) under one or more
- contributor license agreements.  See the NOTICE file distributed with
- this work for additional information regarding copyright ownership.
- The ASF licenses this file to You under the Apache License, Version 2.0
- (the "License"); you may not use this file except in compliance with
- the License.  You may obtain a copy of the License at
-  
- http://www.apache.org/licenses/LICENSE-2.0
-  
- Unless required by applicable law or agreed to in writing, software
- distributed under the License is distributed on an "AS IS" BASIS,
- WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- See the License for the specific language governing permissions and
- limitations under the License.
-:LicenseEnd
-
-SET TARGETS=simple
-SET AREA=all
-SET CONFIGURATION=Release
-IF [%1] NEQ [] SET TARGETS=%1
-IF [%2] NEQ [] SET AREA=%2
-IF [%3] NEQ [] SET CONFIGURATION=%3
-
-%windir%\Microsoft.NET\Framework\v4.0.30319\MSBuild.exe build/scripts/build.targets /t:%TARGETS% /p:BuildArea=%AREA% /p:Configuration=%Configuration% /nologo 
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/scripts/All/Lucene.Net.nuspec
----------------------------------------------------------------------
diff --git a/build/scripts/All/Lucene.Net.nuspec b/build/scripts/All/Lucene.Net.nuspec
deleted file mode 100644
index 997b5b9..0000000
--- a/build/scripts/All/Lucene.Net.nuspec
+++ /dev/null
@@ -1,41 +0,0 @@
-<?xml version="1.0"?>
-<!--
- 
- Licensed to the Apache Software Foundation (ASF) under one or more
- contributor license agreements.  See the NOTICE file distributed with
- this work for additional information regarding copyright ownership.
- The ASF licenses this file to You under the Apache License, Version 2.0
- (the "License"); you may not use this file except in compliance with
- the License.  You may obtain a copy of the License at
-  
- http://www.apache.org/licenses/LICENSE-2.0
-  
- Unless required by applicable law or agreed to in writing, software
- distributed under the License is distributed on an "AS IS" BASIS,
- WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- See the License for the specific language governing permissions and
- limitations under the License.
- 
--->
-<package xmlns="http://schemas.microsoft.com/packaging/2010/07/nuspec.xsd">
-  <metadata>
-    <id>Lucene.Net.All</id>
-    <version>$version$</version>
-    <title>Lucene.Net All</title>
-    <authors>Lucene.Net Community</authors>
-    <owners>The Apache Software Foundation</owners>
-    <iconUrl>http://incubator.apache.org/lucene.net/media/lucene-net-ico-128x128.png</iconUrl>
-    <licenseUrl>http://www.apache.org/licenses/LICENSE-2.0.html</licenseUrl>
-    <projectUrl>http://lucenenet.apache.org/</projectUrl>
-    <requireLicenseAcceptance>false</requireLicenseAcceptance>
-    <description>Lucene.Net is a port of the Lucene search engine library, written in C# and targeted at .NET runtime users.
-
-**This package installs the Lucene.Net.Core &amp; Lucene.Net.Contrib packages.</description>
-    <summary>Lucene.Net is a port of the Lucene search engine library, written in C# and targeted at .NET runtime users.</summary>
-	<tags>lucene.net core search information retrieval lucene apache</tags>
-     <dependencies>
-     	<dependency id="Lucene.Net.Core" version="$version$" />
-     	<dependency id="Lucene.Net.Contrib" version="$version$" />
-     </dependencies>  
-  </metadata>
-</package>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/scripts/All/document.targets
----------------------------------------------------------------------
diff --git a/build/scripts/All/document.targets b/build/scripts/All/document.targets
deleted file mode 100644
index 08e262d..0000000
--- a/build/scripts/All/document.targets
+++ /dev/null
@@ -1,55 +0,0 @@
-<?xml version="1.0" encoding="UTF-8" standalone="no" ?>
-<!--
- 
- Licensed to the Apache Software Foundation (ASF) under one or more
- contributor license agreements.  See the NOTICE file distributed with
- this work for additional information regarding copyright ownership.
- The ASF licenses this file to You under the Apache License, Version 2.0
- (the "License"); you may not use this file except in compliance with
- the License.  You may obtain a copy of the License at
-  
- http://www.apache.org/licenses/LICENSE-2.0
-  
- Unless required by applicable law or agreed to in writing, software
- distributed under the License is distributed on an "AS IS" BASIS,
- WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- See the License for the specific language governing permissions and
- limitations under the License.
- 
--->
-<Project xmlns="http://schemas.microsoft.com/developer/msbuild/2003" ToolsVersion="4.0">
-	<PropertyGroup>
-		<DocumentationSources>
-      		<DocumentationSource sourceFile="..\bin\core\Release\NET40\Lucene.Net.dll" />
-      		<DocumentationSource sourceFile="..\bin\core\Release\NET40\Lucene.Net.XML" />
-  			  <DocumentationSource sourceFile="..\bin\contrib\Analyzers\Release\NET40\Lucene.Net.Contrib.Analyzers.dll" />
-      		<DocumentationSource sourceFile="..\bin\contrib\Analyzers\Release\NET40\Lucene.Net.Contrib.Analyzers.XML" />
-      		<DocumentationSource sourceFile="..\bin\contrib\Core\Release\NET40\Lucene.Net.Contrib.Core.dll" />
-      		<DocumentationSource sourceFile="..\bin\contrib\Core\Release\NET40\Lucene.Net.Contrib.Core.XML" />
-  			  <DocumentationSource sourceFile="..\bin\contrib\FastVectorHighlighter\Release\NET40\Lucene.Net.FastVectorHighlighter.dll" />
-      		<DocumentationSource sourceFile="..\bin\contrib\FastVectorHighlighter\Release\NET40\Lucene.Net.FastVectorHighlighter.XML" />
-      		<DocumentationSource sourceFile="..\bin\contrib\Highlighter\Release\NET40\Lucene.Net.Contrib.Highlighter.dll" />
-      		<DocumentationSource sourceFile="..\bin\contrib\Highlighter\Release\NET40\Lucene.Net.Contrib.Highlighter.XML" />
-      		<DocumentationSource sourceFile="..\bin\contrib\Memory\Release\NET40\Lucene.Net.Contrib.Memory.dll" />
-      		<DocumentationSource sourceFile="..\bin\contrib\Memory\Release\NET40\Lucene.Net.Contrib.Memory.XML" />
-      		<DocumentationSource sourceFile="..\bin\contrib\Queries\Release\NET40\Lucene.Net.Contrib.Queries.dll" />
-      		<DocumentationSource sourceFile="..\bin\contrib\Queries\Release\NET40\Lucene.Net.Contrib.Queries.XML" />
-      		<DocumentationSource sourceFile="..\bin\contrib\Regex\Release\NET40\Contrib.Regex.dll" />
-      		<DocumentationSource sourceFile="..\bin\contrib\Regex\Release\NET40\Contrib.Regex.XML" />
-      		<DocumentationSource sourceFile="..\bin\contrib\SimpleFacetedSearch\Release\NET40\Lucene.Net.Search.SimpleFacetedSearch.dll" />
-      		<DocumentationSource sourceFile="..\bin\contrib\SimpleFacetedSearch\Release\NET40\Lucene.Net.Search.SimpleFacetedSearch.XML" />
-      		<DocumentationSource sourceFile="..\bin\contrib\Similarity\Release\NET40\Lucene.Net.Contrib.Similarity.dll" />
-      		<DocumentationSource sourceFile="..\bin\contrib\Similarity\Release\NET40\Lucene.Net.Contrib.Similarity.XML" />
-      		<DocumentationSource sourceFile="..\bin\contrib\Snowball\Release\NET40\Lucene.Net.Contrib.Snowball.dll" />
-      		<DocumentationSource sourceFile="..\bin\contrib\Snowball\Release\NET40\Lucene.Net.Contrib.Snowball.XML" />
-      		<DocumentationSource sourceFile="..\bin\contrib\Spatial\Release\NET40\Lucene.Net.Contrib.Spatial.dll" />
-      		<DocumentationSource sourceFile="..\bin\contrib\Spatial\Release\NET40\Lucene.Net.Contrib.Spatial.XML" />
-          <DocumentationSource sourceFile="..\bin\contrib\Spatial.NTS\Release\NET40\Lucene.Net.Contrib.Spatial.NTS.dll" />
-          <DocumentationSource sourceFile="..\bin\contrib\Spatial.NTS\Release\NET40\Lucene.Net.Contrib.Spatial.NTS.XML" />
-    	</DocumentationSources>
-    	<HtmlHelpName>Lucene.Net</HtmlHelpName>
-    	<HelpTitle>Lucene.Net Class Libraries</HelpTitle>
-    	<WorkingPath>..\artifacts\all\working\</WorkingPath>
-	    <OutputPath>..\artifacts\all\docs\</OutputPath>
-	</PropertyGroup>
-</Project>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/scripts/All/project.targets
----------------------------------------------------------------------
diff --git a/build/scripts/All/project.targets b/build/scripts/All/project.targets
deleted file mode 100644
index f9ebcc3..0000000
--- a/build/scripts/All/project.targets
+++ /dev/null
@@ -1,54 +0,0 @@
-<?xml version="1.0" encoding="UTF-8" standalone="no" ?>
-<!--
- 
- Licensed to the Apache Software Foundation (ASF) under one or more
- contributor license agreements.  See the NOTICE file distributed with
- this work for additional information regarding copyright ownership.
- The ASF licenses this file to You under the Apache License, Version 2.0
- (the "License"); you may not use this file except in compliance with
- the License.  You may obtain a copy of the License at
-  
- http://www.apache.org/licenses/LICENSE-2.0
-  
- Unless required by applicable law or agreed to in writing, software
- distributed under the License is distributed on an "AS IS" BASIS,
- WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- See the License for the specific language governing permissions and
- limitations under the License.
- 
--->
-<Project xmlns="http://schemas.microsoft.com/developer/msbuild/2003" ToolsVersion="4.0">
-	<!-- 
-		Core Projects Are:
-			Lucene.Net, 
-			Lucene.Net.Test, 
-	-->
-	
-	<PropertyGroup>
-		<AllPackage>Lucene.Net.nuspec</AllPackage>	
-		<ContribPackage>Lucene.Net.Contrib.nuspec</ContribPackage>	
-	</PropertyGroup>
-	
-	<PropertyGroup  Condition="'$(Area)' == 'all'">
-		<ArtifactsFolder>$(BuildFolder)\artifacts\all</ArtifactsFolder>
-	</PropertyGroup>
-	<Target Name="package-contrib">
-		<Exec Command="$(PackageManager) $(ScriptsFolder)\Contrib\$(ContribPackage)  $(PackageManagerOptions) $(ArtifactsFolder)" />
-	</Target>
-	<Target Name="package-all">
-		<Exec Command="$(PackageManager) $(ScriptsFolder)\All\$(AllPackage)  $(PackageManagerOptions) $(ArtifactsFolder)" />
-	</Target>
-	
-	<Import Project="../Core/project.targets"  />
-	<Import Project="../Contrib/project.targets"  />
-		
-	<ItemGroup>
-		<PackageTargets Include="package-contrib" />
-		<PackageTargets Include="package-all" />
-	</ItemGroup>
-
-	<Target Name="BuildAll">
-		<CallTarget Targets="BuildCore" />
-		<CallTarget Targets="BuildContrib" />
-	</Target>
-</Project>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/scripts/Analyzers/document.targets
----------------------------------------------------------------------
diff --git a/build/scripts/Analyzers/document.targets b/build/scripts/Analyzers/document.targets
deleted file mode 100644
index d97452a..0000000
--- a/build/scripts/Analyzers/document.targets
+++ /dev/null
@@ -1,31 +0,0 @@
-<?xml version="1.0" encoding="UTF-8" standalone="no" ?>
-<!--
- 
- Licensed to the Apache Software Foundation (ASF) under one or more
- contributor license agreements.  See the NOTICE file distributed with
- this work for additional information regarding copyright ownership.
- The ASF licenses this file to You under the Apache License, Version 2.0
- (the "License"); you may not use this file except in compliance with
- the License.  You may obtain a copy of the License at
-  
- http://www.apache.org/licenses/LICENSE-2.0
-  
- Unless required by applicable law or agreed to in writing, software
- distributed under the License is distributed on an "AS IS" BASIS,
- WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- See the License for the specific language governing permissions and
- limitations under the License.
- 
--->
-<Project xmlns="http://schemas.microsoft.com/developer/msbuild/2003" ToolsVersion="4.0">
-	<PropertyGroup>
-		 <DocumentationSources>
-      		<DocumentationSource sourceFile="..\bin\contrib\Analyzers\Release\NET40\Lucene.Net.Contrib.Analyzers.dll" />
-      		<DocumentationSource sourceFile="..\bin\contrib\Analyzers\Release\NET40\Lucene.Net.Contrib.Analyzers.XML" />
-    	</DocumentationSources>
-    	<HtmlHelpName>Lucene.Net.Contrib.Analyzers</HtmlHelpName>
-    	<HelpTitle>Analyzers Class Library</HelpTitle>
-    	<WorkingPath>..\artifacts\Analyzers\working\</WorkingPath>
-	    <OutputPath>..\artifacts\Analyzers\docs\</OutputPath>
-	</PropertyGroup>
-</Project>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/scripts/Analyzers/project.targets
----------------------------------------------------------------------
diff --git a/build/scripts/Analyzers/project.targets b/build/scripts/Analyzers/project.targets
deleted file mode 100644
index 85ec04d..0000000
--- a/build/scripts/Analyzers/project.targets
+++ /dev/null
@@ -1,66 +0,0 @@
-<?xml version="1.0" encoding="UTF-8" standalone="no" ?>
-<!--
- 
- Licensed to the Apache Software Foundation (ASF) under one or more
- contributor license agreements.  See the NOTICE file distributed with
- this work for additional information regarding copyright ownership.
- The ASF licenses this file to You under the Apache License, Version 2.0
- (the "License"); you may not use this file except in compliance with
- the License.  You may obtain a copy of the License at
-  
- http://www.apache.org/licenses/LICENSE-2.0
-  
- Unless required by applicable law or agreed to in writing, software
- distributed under the License is distributed on an "AS IS" BASIS,
- WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- See the License for the specific language governing permissions and
- limitations under the License.
- 
--->
-<Project xmlns="http://schemas.microsoft.com/developer/msbuild/2003" ToolsVersion="4.0">
-	<!-- 
-		Core Projects Are:
-			Lucene.Net, 
-			Lucene.Net.Test, 
-	-->
-	<PropertyGroup>
-		<AnalyzersFolder>$(BinFolder)\contrib\Analyzers\$(Configuration)</AnalyzersFolder>
-	</PropertyGroup>
-	<PropertyGroup  Condition="'$(Area)' == 'analyzers'">
-		<LocalBinFolder>$(BinFolder)\contrib\Analyzers\$(Configuration)</LocalBinFolder>
-		<ArtifactsFolder>$(BuildFolder)\artifacts\Analyzers</ArtifactsFolder>
-		<TestFiles>"$(AnalyzersFolder)\**\Lucene.Net.Contrib.Analyzers.Test.dll"</TestFiles>
-	</PropertyGroup>
-	
-	<Target Name="_analyzers_build">
-		<ItemGroup>
-			<AnalyzersProjectFiles Include="$(SourceFolder)\Contrib\Analyzers\*.csproj" />
-			<AnalyzersProjectFiles Include="$(TestFolder)\Contrib\Analyzers\*.csproj" />
-		</ItemGroup>
-		<MSBuild Projects="@(AnalyzersProjectFiles)" Properties="Configuration=$(Configuration);ExternalConstants=$(ExternalConstants)" />
-		<!-- Add "35" to the end of configuration to build .NET35 projects -->
-		<MSBuild Projects="@(AnalyzersProjectFiles)" Properties="Configuration=$(Configuration)35;ExternalConstants=$(ExternalConstants)" />
-	</Target>
-
-	<Target Name="_analyzers_properties">
-		<ItemGroup>
-			<!-- Binaries To Copy in case we which to store all build items -->
-			<BuildItems Include="$(AnalyzersFolder)\**\*.*" /> 
-			
-			<!-- Assemblies To Test -->
-			<TestFiles Include="$(AnalyzersFolder)\**\Lucene.Net.Contrib.Analyzers.Test.dll" />
-					
-			<!-- Files To Release -->
-			<ReleaseFiles Include="$(AnalyzersFolder)\**\Lucene.Net.Contrib.Analyzers.dll" />
-			<ReleaseFiles Include="$(AnalyzersFolder)\**\Lucene.Net.Contrib.Analyzers.XML" />
-		
-			<!-- Files to Analysis -->
-			<AnalysisFiles Include="$(AnalyzersFolder)\**\Lucene.Net.Contrib.Analyzers.dll" />	
-		</ItemGroup>
-	</Target>
-
-	<Target Name="BuildAnalyzers">
-		<CallTarget Targets="_analyzers_build" />
-		<CallTarget Targets="_analyzers_properties" />
-	</Target>
-</Project>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/scripts/Contrib-Core/document.targets
----------------------------------------------------------------------
diff --git a/build/scripts/Contrib-Core/document.targets b/build/scripts/Contrib-Core/document.targets
deleted file mode 100644
index 781abea..0000000
--- a/build/scripts/Contrib-Core/document.targets
+++ /dev/null
@@ -1,31 +0,0 @@
-<?xml version="1.0" encoding="UTF-8" standalone="no" ?>
-<!--
- 
- Licensed to the Apache Software Foundation (ASF) under one or more
- contributor license agreements.  See the NOTICE file distributed with
- this work for additional information regarding copyright ownership.
- The ASF licenses this file to You under the Apache License, Version 2.0
- (the "License"); you may not use this file except in compliance with
- the License.  You may obtain a copy of the License at
-  
- http://www.apache.org/licenses/LICENSE-2.0
-  
- Unless required by applicable law or agreed to in writing, software
- distributed under the License is distributed on an "AS IS" BASIS,
- WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- See the License for the specific language governing permissions and
- limitations under the License.
- 
--->
-<Project xmlns="http://schemas.microsoft.com/developer/msbuild/2003" ToolsVersion="4.0">
-	<PropertyGroup>
-		 <DocumentationSources>
-      		<DocumentationSource sourceFile="..\bin\contrib\Core\Release\NET40\Lucene.Net.Contrib.Core.dll" />
-      		<DocumentationSource sourceFile="..\bin\contrib\Core\Release\NET40\Lucene.Net.Contrib.Core.XML" />
-    	</DocumentationSources>
-    	<HtmlHelpName>Lucene.Net.Contrib.Core</HtmlHelpName>
-    	<HelpTitle>Core Class Library</HelpTitle>
-    	<WorkingPath>..\artifacts\Core\working\</WorkingPath>
-	    <OutputPath>..\artifacts\Core\docs\</OutputPath>
-	</PropertyGroup>
-</Project>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/scripts/Contrib-Core/project.targets
----------------------------------------------------------------------
diff --git a/build/scripts/Contrib-Core/project.targets b/build/scripts/Contrib-Core/project.targets
deleted file mode 100644
index 7cd602f..0000000
--- a/build/scripts/Contrib-Core/project.targets
+++ /dev/null
@@ -1,66 +0,0 @@
-<?xml version="1.0" encoding="UTF-8" standalone="no" ?>
-<!--
- 
- Licensed to the Apache Software Foundation (ASF) under one or more
- contributor license agreements.  See the NOTICE file distributed with
- this work for additional information regarding copyright ownership.
- The ASF licenses this file to You under the Apache License, Version 2.0
- (the "License"); you may not use this file except in compliance with
- the License.  You may obtain a copy of the License at
-  
- http://www.apache.org/licenses/LICENSE-2.0
-  
- Unless required by applicable law or agreed to in writing, software
- distributed under the License is distributed on an "AS IS" BASIS,
- WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- See the License for the specific language governing permissions and
- limitations under the License.
- 
--->
-<Project xmlns="http://schemas.microsoft.com/developer/msbuild/2003" ToolsVersion="4.0">
-	<!-- 
-		Core Projects Are:
-			Lucene.Net, 
-			Lucene.Net.Test, 
-	-->
-	<PropertyGroup>
-		<ContribCoreFolder>$(BinFolder)\contrib\Core\$(Configuration)</ContribCoreFolder>
-	</PropertyGroup>
-	<PropertyGroup  Condition="'$(Area)' == 'contrib-core'">
-		<LocalBinFolder>$(BinFolder)\contrib\Core\$(Configuration)</LocalBinFolder>
-		<ArtifactsFolder>$(BuildFolder)\artifacts\Contrib-Core</ArtifactsFolder>
-	</PropertyGroup>
-
-	<Target Name="_contrib-core_build">
-		<ItemGroup>
-			<ContribCoreProjectFiles Include="$(SourceFolder)\Contrib\Core\*.csproj" />
-			<ContribCoreProjectFiles Include="$(TestFolder)\Contrib\Core\*.csproj" />
-		</ItemGroup>
-
-		<MSBuild Projects="@(ContribCoreProjectFiles)" Properties="Configuration=$(Configuration);ExternalConstants=$(ExternalConstants)" />
-		<!-- Add "35" to the end of configuration to build .NET35 projects -->
-		<MSBuild Projects="@(ContribCoreProjectFiles)" Properties="Configuration=$(Configuration)35;ExternalConstants=$(ExternalConstants)" />
-	</Target>
-
-	<Target Name="_contrib-core_properties">
-		<ItemGroup>
-			<!-- Binaries To Copy in case we which to store all build items -->
-			<BuildItems Include="$(ContribCoreFolder)\**\*.*" /> 
-			
-			<!-- Assemblies To Test -->
-			<TestFiles Include="$(ContribCoreFolder)\**\Lucene.Net.Contrib.Core.Test.dll" />
-			
-			<!-- Files To Release -->
-			<ReleaseFiles Include="$(ContribCoreFolder)\**\Lucene.Net.Contrib.Core.dll" />
-			<ReleaseFiles Include="$(ContribCoreFolder)\**\Lucene.Net.Contrib.Core.XML" />
-		
-			<!-- Files to Analysis -->
-			<AnalysisFiles Include="$(ContribCoreFolder)\**\Lucene.Net.Contrib.Core.dll" />	
-		</ItemGroup>
-	</Target>
-
-	<Target Name="BuildContrib-Core">
-		<CallTarget Targets="_contrib-core_build" />
-		<CallTarget Targets="_contrib-core_properties" />
-	</Target>
-</Project>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/scripts/Contrib/Lucene.Net.Contrib.nuspec
----------------------------------------------------------------------
diff --git a/build/scripts/Contrib/Lucene.Net.Contrib.nuspec b/build/scripts/Contrib/Lucene.Net.Contrib.nuspec
deleted file mode 100644
index 483abb4..0000000
--- a/build/scripts/Contrib/Lucene.Net.Contrib.nuspec
+++ /dev/null
@@ -1,62 +0,0 @@
-<?xml version="1.0"?>
-<!--
- 
- Licensed to the Apache Software Foundation (ASF) under one or more
- contributor license agreements.  See the NOTICE file distributed with
- this work for additional information regarding copyright ownership.
- The ASF licenses this file to You under the Apache License, Version 2.0
- (the "License"); you may not use this file except in compliance with
- the License.  You may obtain a copy of the License at
-  
- http://www.apache.org/licenses/LICENSE-2.0
-  
- Unless required by applicable law or agreed to in writing, software
- distributed under the License is distributed on an "AS IS" BASIS,
- WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- See the License for the specific language governing permissions and
- limitations under the License.
- 
--->
-<package xmlns="http://schemas.microsoft.com/packaging/2010/07/nuspec.xsd">
-  <metadata>
-    <id>Lucene.Net.Contrib</id>
-    <version>$version$</version>
-    <title>Lucene.Net Contrib</title>
-    <authors>Lucene.Net Community</authors>
-    <owners>The Apache Software Foundation</owners>
-    <iconUrl>http://incubator.apache.org/lucene.net/media/lucene-net-ico-128x128.png</iconUrl>
-    <licenseUrl>http://www.apache.org/licenses/LICENSE-2.0.html</licenseUrl>
-    <projectUrl>http://lucenenet.apache.org/</projectUrl>
-    <requireLicenseAcceptance>false</requireLicenseAcceptance>
-    <description>Lucene.Net is a port of the Lucene search engine library, written in C# and targeted at .NET runtime users.
-
-**This package contains only the contrib Lucene.Net assemblies.</description>
-    <summary>Lucene.Net is a port of the Lucene search engine library, written in C# and targeted at .NET runtime users.</summary>
-	<tags>lucene.net core search information retrieval lucene apache</tags>
-     <dependencies>
-     </dependencies>  
-  </metadata>
-  <files>
-        <file src="..\..\bin\contrib\FastVectorHighlighter\Release\**\Lucene.Net.Contrib.FastVectorHighlighter.dll" target="lib" />
-        <file src="..\..\bin\contrib\FastVectorHighlighter\Release\**\Lucene.Net.Contrib.FastVectorHighlighter.XML" target="lib" />
-        <file src="..\..\bin\contrib\Highlighter\Release\**\Lucene.Net.Contrib.Highlighter.dll" target="lib" />
-        <file src="..\..\bin\contrib\Highlighter\Release\**\Lucene.Net.Contrib.Highlighter.XML" target="lib" />
-        <file src="..\..\bin\contrib\Memory\Release\**\Lucene.Net.Contrib.Memory.dll" target="lib" />
-        <file src="..\..\bin\contrib\Memory\Release\**\Lucene.Net.Contrib.Memory.XML" target="lib" />
-        <file src="..\..\bin\contrib\Analyzers\Release\**\Lucene.Net.Contrib.Analyzers.dll" target="lib" />
-        <file src="..\..\bin\contrib\Analyzers\Release\**\Lucene.Net.Contrib.Analyzers.XML" target="lib" />
-        <file src="..\..\bin\contrib\Core\Release\**\Lucene.Net.Contrib.Core.dll" target="lib" />
-        <file src="..\..\bin\contrib\Core\Release\**\Lucene.Net.Contrib.Core.XML" target="lib" />
-        <file src="..\..\bin\contrib\Queries\Release\**\Lucene.Net.Contrib.Queries.dll" target="lib" />
-        <file src="..\..\bin\contrib\Queries\Release\**\Lucene.Net.Contrib.Queries.XML" target="lib" />
-        <file src="..\..\bin\contrib\Regex\Release\**\Lucene.Net.Contrib.Regex.dll" target="lib" />
-        <file src="..\..\bin\contrib\Regex\Release\**\Lucene.Net.Contrib.Regex.XML" target="lib" />
-        <file src="..\..\bin\contrib\SimpleFacetedSearch\Release\**\Lucene.Net.Contrib.SimpleFacetedSearch.dll" target="lib" />
-        <file src="..\..\bin\contrib\SimpleFacetedSearch\Release\**\Lucene.Net.Contrib.SimpleFacetedSearch.XML" target="lib" />
-        <file src="..\..\bin\contrib\Snowball\Release\**\Lucene.Net.Contrib.Snowball.dll" target="lib" />
-        <file src="..\..\bin\contrib\Snowball\Release\**\Lucene.Net.Contrib.Snowball.XML" target="lib" />
-        <file src="..\..\bin\contrib\SpellChecker\Release\**\Lucene.Net.Contrib.SpellChecker.dll" target="lib" />
-        <file src="..\..\bin\contrib\SpellChecker\Release\**\Lucene.Net.Contrib.SpellChecker.XML" target="lib" />
-  </files>
- 
-</package>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/scripts/Contrib/document.targets
----------------------------------------------------------------------
diff --git a/build/scripts/Contrib/document.targets b/build/scripts/Contrib/document.targets
deleted file mode 100644
index 962820c..0000000
--- a/build/scripts/Contrib/document.targets
+++ /dev/null
@@ -1,51 +0,0 @@
-<?xml version="1.0" encoding="UTF-8" standalone="no" ?>
-<!--
- 
- Licensed to the Apache Software Foundation (ASF) under one or more
- contributor license agreements.  See the NOTICE file distributed with
- this work for additional information regarding copyright ownership.
- The ASF licenses this file to You under the Apache License, Version 2.0
- (the "License"); you may not use this file except in compliance with
- the License.  You may obtain a copy of the License at
-  
- http://www.apache.org/licenses/LICENSE-2.0
-  
- Unless required by applicable law or agreed to in writing, software
- distributed under the License is distributed on an "AS IS" BASIS,
- WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- See the License for the specific language governing permissions and
- limitations under the License.
- 
--->
-<Project xmlns="http://schemas.microsoft.com/developer/msbuild/2003" ToolsVersion="4.0">
-	<PropertyGroup>
-		 <DocumentationSources>
-      		<DocumentationSource sourceFile="..\bin\contrib\Analyzers\Release\NET40\Lucene.Net.Contrib.Analyzers.dll" />
-      		<DocumentationSource sourceFile="..\bin\contrib\Analyzers\Release\NET40\Lucene.Net.Contrib.Analyzers.XML" />
-      		<DocumentationSource sourceFile="..\bin\contrib\Core\Release\NET40\Lucene.Net.Contrib.Core.dll" />
-      		<DocumentationSource sourceFile="..\bin\contrib\Core\Release\NET40\Lucene.Net.Contrib.Core.XML" />
-  			  <DocumentationSource sourceFile="..\bin\contrib\FastVectorHighlighter\Release\NET40\Lucene.Net.Contrib.FastVectorHighlighter.dll" />
-      		<DocumentationSource sourceFile="..\bin\contrib\FastVectorHighlighter\Release\NET40\Lucene.Net.Contrib.FastVectorHighlighter.XML" />
-      		<DocumentationSource sourceFile="..\bin\contrib\Highlighter\Release\NET40\Lucene.Net.Contrib.Highlighter.dll" />
-      		<DocumentationSource sourceFile="..\bin\contrib\Highlighter\Release\NET40\Lucene.Net.Contrib.Highlighter.XML" />
-      		<DocumentationSource sourceFile="..\bin\contrib\Memory\Release\NET40\Lucene.Net.Contrib.Memory.dll" />
-      		<DocumentationSource sourceFile="..\bin\contrib\Memory\Release\NET40\Lucene.Net.Contrib.Memory.XML" />
-      		<DocumentationSource sourceFile="..\bin\contrib\Queries\Release\NET40\Lucene.Net.Contrib.Queries.dll" />
-      		<DocumentationSource sourceFile="..\bin\contrib\Queries\Release\NET40\Lucene.Net.Contrib.Queries.XML" />
-      		<DocumentationSource sourceFile="..\bin\contrib\Regex\Release\NET40\Lucene.Net.Contrib.Regex.dll" />
-      		<DocumentationSource sourceFile="..\bin\contrib\Regex\Release\NET40\Lucene.Net.Contrib.Regex.XML" />
-      		<DocumentationSource sourceFile="..\bin\contrib\SimpleFacetedSearch\Release\NET40\Lucene.Net.Contrib.SimpleFacetedSearch.dll" />
-      		<DocumentationSource sourceFile="..\bin\contrib\SimpleFacetedSearch\Release\NET40\Lucene.Net.Contrib.SimpleFacetedSearch.XML" />
-      		<DocumentationSource sourceFile="..\bin\contrib\Similarity\Release\NET40\Lucene.Net.Contrib.Similarity.dll" />
-      		<DocumentationSource sourceFile="..\bin\contrib\Similarity\Release\NET40\Lucene.Net.Contrib.Similarity.XML" />
-      		<DocumentationSource sourceFile="..\bin\contrib\Snowball\Release\NET40\Lucene.Net.Contrib.Snowball.dll" />
-      		<DocumentationSource sourceFile="..\bin\contrib\Snowball\Release\NET40\Lucene.Net.Contrib.Snowball.XML" />
-      		<DocumentationSource sourceFile="..\bin\contrib\Spatial\Release\NET40\Lucene.Net.Contrib.Spatial.dll" />
-      		<DocumentationSource sourceFile="..\bin\contrib\Spatial\Release\NET40\Lucene.Net.Contrib.Spatial.XML" />
-    	</DocumentationSources>
-    	<HtmlHelpName>Lucene.Net.Contrib</HtmlHelpName>
-    	<HelpTitle>Lucene.Net.Contrib Class Libraries</HelpTitle>
-    	<WorkingPath>..\artifacts\contrib\working\</WorkingPath>
-	    <OutputPath>..\artifacts\contrib\docs\</OutputPath>
-	</PropertyGroup>
-</Project>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/scripts/Contrib/project.targets
----------------------------------------------------------------------
diff --git a/build/scripts/Contrib/project.targets b/build/scripts/Contrib/project.targets
deleted file mode 100644
index e8d3a25..0000000
--- a/build/scripts/Contrib/project.targets
+++ /dev/null
@@ -1,72 +0,0 @@
-<?xml version="1.0" encoding="UTF-8" standalone="no" ?>
-<!--
- 
- Licensed to the Apache Software Foundation (ASF) under one or more
- contributor license agreements.  See the NOTICE file distributed with
- this work for additional information regarding copyright ownership.
- The ASF licenses this file to You under the Apache License, Version 2.0
- (the "License"); you may not use this file except in compliance with
- the License.  You may obtain a copy of the License at
-  
- http://www.apache.org/licenses/LICENSE-2.0
-  
- Unless required by applicable law or agreed to in writing, software
- distributed under the License is distributed on an "AS IS" BASIS,
- WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- See the License for the specific language governing permissions and
- limitations under the License.
- 
--->
-<Project xmlns="http://schemas.microsoft.com/developer/msbuild/2003" ToolsVersion="4.0">
-	<!-- 
-		Core Projects Are:
-			Lucene.Net, 
-			Lucene.Net.Test, 
-	-->
-	<PropertyGroup>
-		<ContribPackage>Lucene.Net.Contrib.nuspec</ContribPackage>
-		<SpatialNTSPackage>Lucene.Net.Spatial.NTS.nuspec</SpatialNTSPackage>
-	</PropertyGroup>
-	<PropertyGroup  Condition="'$(Area)' == 'contrib'">
-		<ArtifactsFolder>$(BuildFolder)\artifacts\contrib</ArtifactsFolder>
-	</PropertyGroup>
-	<Target Name="package-contrib">
-		<Exec Command="$(PackageManager) $(ScriptsFolder)\Contrib\$(ContribPackage)  $(PackageManagerOptions) $(ArtifactsFolder)" />
-	</Target>
-	<Target Name="package-spatialnts">
-		<Exec Command="$(PackageManager) $(ScriptsFolder)\Spatial.NTS\$(SpatialNTSPackage)  $(PackageManagerOptions) $(ArtifactsFolder)" />
-	</Target>
-	<ItemGroup>
-		<PackageTargets Include="package-contrib" />
-		<PackageTargets Include="package-spatialnts" />
-	</ItemGroup>
-	
-	<Import Project="../Analyzers/project.targets"  />
-	<Import Project="../Contrib-Core/project.targets"  />
-	<Import Project="../FastVectorHighlighter/project.targets"  />
-	<Import Project="../Highlighter/project.targets"  />
-	<Import Project="../Memory/project.targets"  />
-	<Import Project="../Queries/project.targets"  />
-	<Import Project="../Regex/project.targets"  />
-	<Import Project="../SimpleFacetedSearch/project.targets"  />
-	<Import Project="../Snowball/project.targets"  />
-	<Import Project="../Spatial/project.targets"  />
-	<Import Project="../Spatial.NTS/project.targets"  />
-	<Import Project="../SpellChecker/project.targets"  />
-		
-	<Target Name="BuildContrib">
-		<CallTarget Targets="BuildAnalyzers" />
-		<CallTarget Targets="BuildContrib-Core" />
-		<CallTarget Targets="BuildFastVectorHighlighter" />
-		<CallTarget Targets="BuildHighlighter" />
-		<CallTarget Targets="BuildMemory" />
-		<CallTarget Targets="BuildQueries" />
-		<CallTarget Targets="BuildRegex" />
-		<CallTarget Targets="BuildSimpleFacetedSearch" />
-		<CallTarget Targets="BuildSnowball" />
-		<CallTarget Targets="BuildSpatial" />
-		<CallTarget Targets="BuildSpatialNTS" />
-		<CallTarget Targets="BuildSpellChecker" />
-	</Target>
-	
-</Project>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/scripts/Core/Lucene.Net.Core.nuspec
----------------------------------------------------------------------
diff --git a/build/scripts/Core/Lucene.Net.Core.nuspec b/build/scripts/Core/Lucene.Net.Core.nuspec
deleted file mode 100644
index 2192088..0000000
--- a/build/scripts/Core/Lucene.Net.Core.nuspec
+++ /dev/null
@@ -1,42 +0,0 @@
-<?xml version="1.0"?>
-<!--
- 
- Licensed to the Apache Software Foundation (ASF) under one or more
- contributor license agreements.  See the NOTICE file distributed with
- this work for additional information regarding copyright ownership.
- The ASF licenses this file to You under the Apache License, Version 2.0
- (the "License"); you may not use this file except in compliance with
- the License.  You may obtain a copy of the License at
-  
- http://www.apache.org/licenses/LICENSE-2.0
-  
- Unless required by applicable law or agreed to in writing, software
- distributed under the License is distributed on an "AS IS" BASIS,
- WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- See the License for the specific language governing permissions and
- limitations under the License.
- 
--->
-<package xmlns="http://schemas.microsoft.com/packaging/2010/07/nuspec.xsd">
-  <metadata>
-    <id>Lucene.Net.Core</id>
-    <version>$version$</version>
-    <title>Lucene.Net Core</title>
-    <authors>Lucene.Net Community</authors>
-    <owners>The Apache Software Foundation</owners>
-    <iconUrl>http://incubator.apache.org/lucene.net/media/lucene-net-ico-128x128.png</iconUrl>
-    <licenseUrl>http://www.apache.org/licenses/LICENSE-2.0.html</licenseUrl>
-    <projectUrl>http://lucenenet.apache.org/</projectUrl>
-    <requireLicenseAcceptance>false</requireLicenseAcceptance>
-    <description>Lucene.Net is a port of the Lucene search engine library, written in C# and targeted at .NET runtime users.
-
-This package contains only the core Lucene.Net assembly.</description>
-    <summary>Lucene.Net is a port of the Lucene search engine library, written in C# and targeted at .NET runtime users.</summary>
-	<tags>lucene.net core search information retrieval lucene apache</tags>
-  </metadata>
-  <files>
-        <file src="..\..\bin\core\Release\**\Lucene.Net.dll" target="lib" />
-        <file src="..\..\bin\core\Release\**\Lucene.Net.XML" target="lib" />
-  </files>
- 
-</package>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/scripts/Core/document.targets
----------------------------------------------------------------------
diff --git a/build/scripts/Core/document.targets b/build/scripts/Core/document.targets
deleted file mode 100644
index 797392e..0000000
--- a/build/scripts/Core/document.targets
+++ /dev/null
@@ -1,31 +0,0 @@
-<?xml version="1.0" encoding="UTF-8" standalone="no" ?>
-<!--
- 
- Licensed to the Apache Software Foundation (ASF) under one or more
- contributor license agreements.  See the NOTICE file distributed with
- this work for additional information regarding copyright ownership.
- The ASF licenses this file to You under the Apache License, Version 2.0
- (the "License"); you may not use this file except in compliance with
- the License.  You may obtain a copy of the License at
-  
- http://www.apache.org/licenses/LICENSE-2.0
-  
- Unless required by applicable law or agreed to in writing, software
- distributed under the License is distributed on an "AS IS" BASIS,
- WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- See the License for the specific language governing permissions and
- limitations under the License.
- 
--->
-<Project xmlns="http://schemas.microsoft.com/developer/msbuild/2003" ToolsVersion="4.0">
-	<PropertyGroup>
-		  <DocumentationSources>
-        <DocumentationSource sourceFile="..\bin\core\Release\NET40\Lucene.Net.dll" />
-        <DocumentationSource sourceFile="..\bin\core\Release\NET40\Lucene.Net.XML" />
-    	</DocumentationSources>
-    	<HtmlHelpName>Lucene.Net.Core</HtmlHelpName>
-    	<HelpTitle>Lucene.Net.Core Class Library</HelpTitle>
-    	<WorkingPath>..\artifacts\core\working\</WorkingPath>
-	    <OutputPath>..\artifacts\core\docs\</OutputPath>
-	</PropertyGroup>
-</Project>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/scripts/Core/project.targets
----------------------------------------------------------------------
diff --git a/build/scripts/Core/project.targets b/build/scripts/Core/project.targets
deleted file mode 100644
index f7ab1e1..0000000
--- a/build/scripts/Core/project.targets
+++ /dev/null
@@ -1,75 +0,0 @@
-<?xml version="1.0" encoding="UTF-8" standalone="no" ?>
-<!--
- 
- Licensed to the Apache Software Foundation (ASF) under one or more
- contributor license agreements.  See the NOTICE file distributed with
- this work for additional information regarding copyright ownership.
- The ASF licenses this file to You under the Apache License, Version 2.0
- (the "License"); you may not use this file except in compliance with
- the License.  You may obtain a copy of the License at
-  
- http://www.apache.org/licenses/LICENSE-2.0
-  
- Unless required by applicable law or agreed to in writing, software
- distributed under the License is distributed on an "AS IS" BASIS,
- WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- See the License for the specific language governing permissions and
- limitations under the License.
- 
--->
-<Project xmlns="http://schemas.microsoft.com/developer/msbuild/2003" ToolsVersion="4.0">
-	<!-- 
-		Core Projects Are:
-			Lucene.Net, 
-			Lucene.Net.Test, 
-	-->
-	<PropertyGroup>
-		<CoreFolder>$(BinFolder)\core\$(Configuration)</CoreFolder>
-		<CorePackage>Lucene.Net.Core.nuspec</CorePackage>
-	</PropertyGroup>
-	<PropertyGroup  Condition="'$(Area)' == 'core'">
-		<LocalBinFolder>$(BinFolder)\core\$(Configuration)</LocalBinFolder>
-		<ArtifactsFolder>$(BuildFolder)\artifacts\core</ArtifactsFolder>
-	</PropertyGroup>
-	<Target Name="package-core">
-		<Exec Command="$(PackageManager) $(ScriptsFolder)\Core\$(CorePackage)  $(PackageManagerOptions) $(ArtifactsFolder)" />
-	</Target>
-
-	<Target Name="_core_build">
-		<ItemGroup>
-			<CoreProjectFiles Include="$(SourceFolder)\Core\*.csproj" />
-			<CoreProjectFiles Include="$(TestFolder)\Core\*.csproj" />
-		</ItemGroup>
-		<MSBuild Projects="@(CoreProjectFiles)" Properties="Configuration=$(Configuration);ExternalConstants=$(ExternalConstants)" />
-		<!-- Add "35" to the end of configuration to build .NET35 projects -->
-		<MSBuild Projects="@(CoreProjectFiles)" Properties="Configuration=$(Configuration)35;ExternalConstants=$(ExternalConstants)" />
-	</Target>
-
-	<Target Name="_core_properties">
-
-		<ItemGroup>
-			<!-- Binaries To Copy in case we which to store all build items -->
-			<BuildItems Include="$(CoreFolder)\**\*.*" /> 
-			
-			<!-- Add To The List of Packages to Build -->
-			<PackageTargets Include="package-core" />
-					
-			
-			<!-- Assemblies To Test -->
-			<TestFiles Include="$(CoreFolder)\**\Lucene.Net.Test.dll" />
-			
-			<!-- Files To Release -->
-			<ReleaseFiles Include="$(CoreFolder)\**\Lucene.Net.dll" />
-			<ReleaseFiles Include="$(CoreFolder)\**\Lucene.Net.XML" />
-			<ReleaseFiles Include="$(CoreFolder)\**\ICSharpCode.SharpZipLib.dll" />
-		
-			<!-- Files to Analysis -->
-			<AnalysisFiles Include="$(CoreFolder)\**\Lucene.Net.dll" />	
-		</ItemGroup>
-	</Target>	
-
-	<Target Name="BuildCore">
-		<CallTarget Targets="_core_build" />
-		<CallTarget Targets="_core_properties" />
-	</Target>
-</Project>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/scripts/CustomDictionary.xml
----------------------------------------------------------------------
diff --git a/build/scripts/CustomDictionary.xml b/build/scripts/CustomDictionary.xml
deleted file mode 100644
index e00d9f1..0000000
--- a/build/scripts/CustomDictionary.xml
+++ /dev/null
@@ -1,31 +0,0 @@
-<?xml version="1.0" encoding="UTF-8" ?>
-<!--
-
- Licensed to the Apache Software Foundation (ASF) under one
- or more contributor license agreements.  See the NOTICE file
- distributed with this work for additional information
- regarding copyright ownership.  The ASF licenses this file
- to you under the Apache License, Version 2.0 (the
- "License"); you may not use this file except in compliance
- with the License.  You may obtain a copy of the License at
-
-   http://www.apache.org/licenses/LICENSE-2.0
-
- Unless required by applicable law or agreed to in writing,
- software distributed under the License is distributed on an
- "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- KIND, either express or implied.  See the License for the
- specific language governing permissions and limitations
- under the License.
-
--->
-
-<Dictionary>
-	<Words>
-		 <Recognized>
-            <Word>Lucene</Word>
-            <Word>Util</Word>
-            <Word>Num</Word>
-         </Recognized>
-  	</Words>
-</Dictionary>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/scripts/FastVectorHighlighter/document.targets
----------------------------------------------------------------------
diff --git a/build/scripts/FastVectorHighlighter/document.targets b/build/scripts/FastVectorHighlighter/document.targets
deleted file mode 100644
index 2793a9c..0000000
--- a/build/scripts/FastVectorHighlighter/document.targets
+++ /dev/null
@@ -1,31 +0,0 @@
-<?xml version="1.0" encoding="UTF-8" standalone="no" ?>
-<!--
- 
- Licensed to the Apache Software Foundation (ASF) under one or more
- contributor license agreements.  See the NOTICE file distributed with
- this work for additional information regarding copyright ownership.
- The ASF licenses this file to You under the Apache License, Version 2.0
- (the "License"); you may not use this file except in compliance with
- the License.  You may obtain a copy of the License at
-  
- http://www.apache.org/licenses/LICENSE-2.0
-  
- Unless required by applicable law or agreed to in writing, software
- distributed under the License is distributed on an "AS IS" BASIS,
- WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- See the License for the specific language governing permissions and
- limitations under the License.
- 
--->
-<Project xmlns="http://schemas.microsoft.com/developer/msbuild/2003" ToolsVersion="4.0">
-	<PropertyGroup>
-		 <DocumentationSources>
-      		<DocumentationSource sourceFile="..\bin\contrib\FastVectorHighlighter\Release\NET40\Lucene.Net.Contrib.FastVectorHighlighter.dll" />
-      		<DocumentationSource sourceFile="..\bin\contrib\FastVectorHighlighter\Release\NET40\Lucene.Net.Contrib.FastVectorHighlighter.XML" />
-    	</DocumentationSources>
-    	<HtmlHelpName>Lucene.Net.Contrib.FastVectorHighlighter</HtmlHelpName>
-    	<HelpTitle>FastVectorHighlighter Class Library</HelpTitle>
-    	<WorkingPath>..\artifacts\FastVectorHighlighter\working\</WorkingPath>
-	    <OutputPath>..\artifacts\FastVectorHighlighter\docs\</OutputPath>
-	</PropertyGroup>
-</Project>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/scripts/FastVectorHighlighter/project.targets
----------------------------------------------------------------------
diff --git a/build/scripts/FastVectorHighlighter/project.targets b/build/scripts/FastVectorHighlighter/project.targets
deleted file mode 100644
index 7785329..0000000
--- a/build/scripts/FastVectorHighlighter/project.targets
+++ /dev/null
@@ -1,66 +0,0 @@
-<?xml version="1.0" encoding="UTF-8" standalone="no" ?>
-<!--
- 
- Licensed to the Apache Software Foundation (ASF) under one or more
- contributor license agreements.  See the NOTICE file distributed with
- this work for additional information regarding copyright ownership.
- The ASF licenses this file to You under the Apache License, Version 2.0
- (the "License"); you may not use this file except in compliance with
- the License.  You may obtain a copy of the License at
-  
- http://www.apache.org/licenses/LICENSE-2.0
-  
- Unless required by applicable law or agreed to in writing, software
- distributed under the License is distributed on an "AS IS" BASIS,
- WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- See the License for the specific language governing permissions and
- limitations under the License.
- 
--->
-<Project xmlns="http://schemas.microsoft.com/developer/msbuild/2003" ToolsVersion="4.0">
-	<!-- 
-		Core Projects Are:
-			Lucene.Net, 
-			Lucene.Net.Test, 
-	-->
-	<PropertyGroup>
-		<FastVectorHighlighterFolder>$(BinFolder)\contrib\FastVectorHighlighter\$(Configuration)</FastVectorHighlighterFolder>
-	</PropertyGroup>
-	<PropertyGroup  Condition="'$(Area)' == 'analyzers'">
-		<LocalBinFolder>$(BinFolder)\contrib\FastVectorHighlighter\$(Configuration)</LocalBinFolder>
-		<ArtifactsFolder>$(BuildFolder)\artifacts\FastVectorHighlighter</ArtifactsFolder>
-	</PropertyGroup>
-
-	<Target Name="_fastvectorhighlighter_build">
-		<ItemGroup>
-			<FVHProjectFiles Include="$(SourceFolder)\Contrib\FastVectorHighlighter\*.csproj" />
-			<FVHProjectFiles Include="$(TestFolder)\Contrib\FastVectorHighlighter\*.csproj" />
-		</ItemGroup>
-
-		<MSBuild Projects="@(FVHProjectFiles)" Properties="Configuration=$(Configuration);ExternalConstants=$(ExternalConstants)" />
-		<!-- Add "35" to the end of configuration to build .NET35 projects -->
-		<MSBuild Projects="@(FVHProjectFiles)" Properties="Configuration=$(Configuration)35;ExternalConstants=$(ExternalConstants)" />
-	</Target>
-
-	<Target Name="_fastvectorhighlighter_properties">
-			<ItemGroup>
-		<!-- Binaries To Copy in case we which to store all build items -->
-		<BuildItems Include="$(FastVectorHighlighterFolder)\**\*.*" /> 
-		
-		<!-- Assemblies To Test -->
-		<TestFiles Include="$(FastVectorHighlighterFolder)\**\Lucene.Net.Contrib.FastVectorHighlighter.Test.dll" />
-		
-		<!-- Files To Release -->
-		<ReleaseFiles Include="$(FastVectorHighlighterFolder)\**\Lucene.Net.Contrib.FastVectorHighlighter.dll" />
-		<ReleaseFiles Include="$(FastVectorHighlighterFolder)\**\Lucene.Net.Contrib.FastVectorHighlighter.XML" />
-	
-		<!-- Files to Analysis -->
-		<AnalysisFiles Include="$(FastVectorHighlighterFolder)\**\Lucene.Net.Contrib.FastVectorHighlighter.dll" />	
-	</ItemGroup>
-	</Target>
-
-	<Target Name="BuildFastVectorHighlighter">
-		<CallTarget Targets="_fastvectorhighlighter_build" />
-		<CallTarget Targets="_fastvectorhighlighter_properties" />
-	</Target>
-</Project>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/scripts/Highlighter/document.targets
----------------------------------------------------------------------
diff --git a/build/scripts/Highlighter/document.targets b/build/scripts/Highlighter/document.targets
deleted file mode 100644
index 8e48c12..0000000
--- a/build/scripts/Highlighter/document.targets
+++ /dev/null
@@ -1,31 +0,0 @@
-<?xml version="1.0" encoding="UTF-8" standalone="no" ?>
-<!--
- 
- Licensed to the Apache Software Foundation (ASF) under one or more
- contributor license agreements.  See the NOTICE file distributed with
- this work for additional information regarding copyright ownership.
- The ASF licenses this file to You under the Apache License, Version 2.0
- (the "License"); you may not use this file except in compliance with
- the License.  You may obtain a copy of the License at
-  
- http://www.apache.org/licenses/LICENSE-2.0
-  
- Unless required by applicable law or agreed to in writing, software
- distributed under the License is distributed on an "AS IS" BASIS,
- WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- See the License for the specific language governing permissions and
- limitations under the License.
- 
--->
-<Project xmlns="http://schemas.microsoft.com/developer/msbuild/2003" ToolsVersion="4.0">
-	<PropertyGroup>
-		 <DocumentationSources>
-      		<DocumentationSource sourceFile="..\bin\contrib\Highlighter\Release\NET40\Lucene.Net.Contrib.Highlighter.dll" />
-      		<DocumentationSource sourceFile="..\bin\contrib\Highlighter\Release\NET40\Lucene.Net.Contrib.Highlighter.XML" />
-    	</DocumentationSources>
-    	<HtmlHelpName>Lucene.Net.Contrib.Highlighter</HtmlHelpName>
-    	<HelpTitle>Highlighter Class Library</HelpTitle>
-    	<WorkingPath>..\artifacts\Highlighter\working\</WorkingPath>
-	    <OutputPath>..\artifacts\Highlighter\docs\</OutputPath>
-	</PropertyGroup>
-</Project>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/scripts/Highlighter/project.targets
----------------------------------------------------------------------
diff --git a/build/scripts/Highlighter/project.targets b/build/scripts/Highlighter/project.targets
deleted file mode 100644
index 4802ee8..0000000
--- a/build/scripts/Highlighter/project.targets
+++ /dev/null
@@ -1,65 +0,0 @@
-<?xml version="1.0" encoding="UTF-8" standalone="no" ?>
-<!--
- 
- Licensed to the Apache Software Foundation (ASF) under one or more
- contributor license agreements.  See the NOTICE file distributed with
- this work for additional information regarding copyright ownership.
- The ASF licenses this file to You under the Apache License, Version 2.0
- (the "License"); you may not use this file except in compliance with
- the License.  You may obtain a copy of the License at
-  
- http://www.apache.org/licenses/LICENSE-2.0
-  
- Unless required by applicable law or agreed to in writing, software
- distributed under the License is distributed on an "AS IS" BASIS,
- WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- See the License for the specific language governing permissions and
- limitations under the License.
- 
--->
-<Project xmlns="http://schemas.microsoft.com/developer/msbuild/2003" ToolsVersion="4.0">
-	<!-- 
-		Core Projects Are:
-			Lucene.Net, 
-			Lucene.Net.Test, 
-	-->
-	<PropertyGroup>
-		<HighlighterFolder>$(BinFolder)\contrib\Highlighter\$(Configuration)</HighlighterFolder>
-	</PropertyGroup>
-	<PropertyGroup  Condition="'$(Area)' == 'highlighter'">
-		<LocalBinFolder>$(BinFolder)\contrib\Highlighter\$(Configuration)</LocalBinFolder>
-		<ArtifactsFolder>$(BuildFolder)\artifacts\Highlighter</ArtifactsFolder>
-	</PropertyGroup>
-
-	<Target Name="_highlighter_build">
-		<ItemGroup>
-			<HighligherProjectFiles Include="$(SourceFolder)\Contrib\Highlighter\*.csproj" />
-			<HighligherProjectFiles Include="$(TestFolder)\Contrib\Highlighter\*.csproj" />
-		</ItemGroup>
-		<MSBuild Projects="@(HighligherProjectFiles)" Properties="Configuration=$(Configuration);ExternalConstants=$(ExternalConstants)" />
-		<!-- Add "35" to the end of configuration to build .NET35 projects -->
-		<MSBuild Projects="@(HighligherProjectFiles)" Properties="Configuration=$(Configuration)35;ExternalConstants=$(ExternalConstants)" />
-	</Target>
-
-	<Target Name="_highlighter_properties">
-		<ItemGroup>
-			<!-- Binaries To Copy in case we which to store all build items -->
-			<BuildItems Include="$(HighlighterFolder)\**\*.*" /> 
-			
-			<!-- Assemblies To Test -->
-			<TestFiles Include="$(HighlighterFolder)\**\Lucene.Net.Contrib.Highlighter.Test.dll" />
-			
-			<!-- Files To Release -->
-			<ReleaseFiles Include="$(HighlighterFolder)\**\Lucene.Net.Contrib.Highlighter.dll" />
-			<ReleaseFiles Include="$(HighlighterFolder)\**\Lucene.Net.Contrib.Highlighter.XML" />
-		
-			<!-- Files to Analysis -->
-			<AnalysisFiles Include="$(HighlighterFolder)\**\Lucene.Net.Contrib.Highlighter.dll" />	
-		</ItemGroup>
-	</Target>
-
-	<Target Name="BuildHighlighter">
-		<CallTarget Targets="_highlighter_build" />
-		<CallTarget Targets="_highlighter_properties" />
-	</Target>
-</Project>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/scripts/Memory/document.targets
----------------------------------------------------------------------
diff --git a/build/scripts/Memory/document.targets b/build/scripts/Memory/document.targets
deleted file mode 100644
index 713ffce..0000000
--- a/build/scripts/Memory/document.targets
+++ /dev/null
@@ -1,31 +0,0 @@
-<?xml version="1.0" encoding="UTF-8" standalone="no" ?>
-<!--
- 
- Licensed to the Apache Software Foundation (ASF) under one or more
- contributor license agreements.  See the NOTICE file distributed with
- this work for additional information regarding copyright ownership.
- The ASF licenses this file to You under the Apache License, Version 2.0
- (the "License"); you may not use this file except in compliance with
- the License.  You may obtain a copy of the License at
-  
- http://www.apache.org/licenses/LICENSE-2.0
-  
- Unless required by applicable law or agreed to in writing, software
- distributed under the License is distributed on an "AS IS" BASIS,
- WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- See the License for the specific language governing permissions and
- limitations under the License.
- 
--->
-<Project xmlns="http://schemas.microsoft.com/developer/msbuild/2003" ToolsVersion="4.0">
-	<PropertyGroup>
-		 <DocumentationSources>
-      		<DocumentationSource sourceFile="..\bin\contrib\Memory\Release\NET40\Lucene.Net.Contrib.Memory.dll" />
-      		<DocumentationSource sourceFile="..\bin\contrib\Memory\Release\NET40\Lucene.Net.Contrib.Memory.XML" />
-    	</DocumentationSources>
-    	<HtmlHelpName>Lucene.Net.Contrib.Memory</HtmlHelpName>
-    	<HelpTitle>Memory Class Library</HelpTitle>
-    	<WorkingPath>..\artifacts\Memory\working\</WorkingPath>
-	    <OutputPath>..\artifacts\Memory\docs\</OutputPath>
-	</PropertyGroup>
-</Project>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/scripts/Memory/project.targets
----------------------------------------------------------------------
diff --git a/build/scripts/Memory/project.targets b/build/scripts/Memory/project.targets
deleted file mode 100644
index 8c302e9..0000000
--- a/build/scripts/Memory/project.targets
+++ /dev/null
@@ -1,66 +0,0 @@
-<?xml version="1.0" encoding="UTF-8" standalone="no" ?>
-<!--
- 
- Licensed to the Apache Software Foundation (ASF) under one or more
- contributor license agreements.  See the NOTICE file distributed with
- this work for additional information regarding copyright ownership.
- The ASF licenses this file to You under the Apache License, Version 2.0
- (the "License"); you may not use this file except in compliance with
- the License.  You may obtain a copy of the License at
-  
- http://www.apache.org/licenses/LICENSE-2.0
-  
- Unless required by applicable law or agreed to in writing, software
- distributed under the License is distributed on an "AS IS" BASIS,
- WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- See the License for the specific language governing permissions and
- limitations under the License.
- 
--->
-<Project xmlns="http://schemas.microsoft.com/developer/msbuild/2003" ToolsVersion="4.0">
-	<!-- 
-		Core Projects Are:
-			Lucene.Net, 
-			Lucene.Net.Test, 
-	-->
-	<PropertyGroup>
-		<MemoryFolder>$(BinFolder)\contrib\Memory\$(Configuration)</MemoryFolder>
-	</PropertyGroup>
-	<PropertyGroup  Condition="'$(Area)' == 'memory'">
-		<LocalBinFolder>$(BinFolder)\contrib\Memory\$(Configuration)</LocalBinFolder>
-		<ArtifactsFolder>$(BuildFolder)\artifacts\Memory</ArtifactsFolder>
-	</PropertyGroup>
-		
-	<Target Name="_memory_build">
-		<ItemGroup>
-			<MemoryProjectFiles Include="$(SourceFolder)\Contrib\Memory\*.csproj" />
-			<MemoryProjectFiles Include="$(TestFolder)\Contrib\Memory\*.csproj" />
-		</ItemGroup>
-
-		<MSBuild Projects="@(MemoryProjectFiles)" Properties="Configuration=$(Configuration);ExternalConstants=$(ExternalConstants)" />
-		<!-- Add "35" to the end of configuration to build .NET35 projects -->
-		<MSBuild Projects="@(MemoryProjectFiles)" Properties="Configuration=$(Configuration)35;ExternalConstants=$(ExternalConstants)" />
-	</Target>
-
-	<Target Name="_memory_properties">
-		<ItemGroup>
-			<!-- Binaries To Copy in case we which to store all build items -->
-			<BuildItems Include="$(MemoryFolder)\**\*.*" /> 
-					
-			<!-- Assemblies To Test -->
-			<TestFiles Include="$(MemoryFolder)\**\Lucene.Net.Contrib.Memory.Test.dll" />
-			
-			<!-- Files To Release -->
-			<ReleaseFiles Include="$(MemoryFolder)\**\Lucene.Net.Contrib.Memory.dll" />
-			<ReleaseFiles Include="$(MemoryFolder)\**\Lucene.Net.Contrib.Memory.XML" />
-		
-			<!-- Files to Analysis -->
-			<AnalysisFiles Include="$(MemoryFolder)\**\Lucene.Net.Contrib.Memory.dll" />	
-		</ItemGroup>
-	</Target>
-
-	<Target Name="BuildMemory">
-		<CallTarget Targets="_memory_build" />
-		<CallTarget Targets="_memory_properties" />
-	</Target>
-</Project>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/scripts/Queries/document.targets
----------------------------------------------------------------------
diff --git a/build/scripts/Queries/document.targets b/build/scripts/Queries/document.targets
deleted file mode 100644
index 8209b4f..0000000
--- a/build/scripts/Queries/document.targets
+++ /dev/null
@@ -1,31 +0,0 @@
-<?xml version="1.0" encoding="UTF-8" standalone="no" ?>
-<!--
- 
- Licensed to the Apache Software Foundation (ASF) under one or more
- contributor license agreements.  See the NOTICE file distributed with
- this work for additional information regarding copyright ownership.
- The ASF licenses this file to You under the Apache License, Version 2.0
- (the "License"); you may not use this file except in compliance with
- the License.  You may obtain a copy of the License at
-  
- http://www.apache.org/licenses/LICENSE-2.0
-  
- Unless required by applicable law or agreed to in writing, software
- distributed under the License is distributed on an "AS IS" BASIS,
- WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- See the License for the specific language governing permissions and
- limitations under the License.
- 
--->
-<Project xmlns="http://schemas.microsoft.com/developer/msbuild/2003" ToolsVersion="4.0">
-	<PropertyGroup>
-		 <DocumentationSources>
-      		<DocumentationSource sourceFile="..\bin\contrib\Queries\Release\NET40\Lucene.Net.Contrib.Queries.dll" />
-      		<DocumentationSource sourceFile="..\bin\contrib\Queries\Release\NET40\Lucene.Net.Contrib.Queries.XML" />
-    	</DocumentationSources>
-    	<HtmlHelpName>Lucene.Net.Contrib.Queries</HtmlHelpName>
-    	<HelpTitle>Queries Class Library</HelpTitle>
-    	<WorkingPath>..\artifacts\Queries\working\</WorkingPath>
-	    <OutputPath>..\artifacts\Queries\docs\</OutputPath>
-	</PropertyGroup>
-</Project>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/scripts/Queries/project.targets
----------------------------------------------------------------------
diff --git a/build/scripts/Queries/project.targets b/build/scripts/Queries/project.targets
deleted file mode 100644
index f16fd8c..0000000
--- a/build/scripts/Queries/project.targets
+++ /dev/null
@@ -1,66 +0,0 @@
-<?xml version="1.0" encoding="UTF-8" standalone="no" ?>
-<!--
- 
- Licensed to the Apache Software Foundation (ASF) under one or more
- contributor license agreements.  See the NOTICE file distributed with
- this work for additional information regarding copyright ownership.
- The ASF licenses this file to You under the Apache License, Version 2.0
- (the "License"); you may not use this file except in compliance with
- the License.  You may obtain a copy of the License at
-  
- http://www.apache.org/licenses/LICENSE-2.0
-  
- Unless required by applicable law or agreed to in writing, software
- distributed under the License is distributed on an "AS IS" BASIS,
- WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- See the License for the specific language governing permissions and
- limitations under the License.
- 
--->
-<Project xmlns="http://schemas.microsoft.com/developer/msbuild/2003" ToolsVersion="4.0">
-	<!-- 
-		Core Projects Are:
-			Lucene.Net, 
-			Lucene.Net.Test, 
-	-->
-	<PropertyGroup>
-		<QueriesFolder>$(BinFolder)\contrib\Queries\$(Configuration)</QueriesFolder>
-	</PropertyGroup>
-	<PropertyGroup  Condition="'$(Area)' == 'queries'">
-		<LocalBinFolder>$(BinFolder)\contrib\Queries\$(Configuration)</LocalBinFolder>
-		<ArtifactsFolder>$(BuildFolder)\artifacts\Queries</ArtifactsFolder>
-	</PropertyGroup>
-		
-	<Target Name="_queries_build">
-		<ItemGroup>
-			<QueriesProjectFiles Include="$(SourceFolder)\Contrib\Queries\*.csproj" />
-			<QueriesProjectFiles Include="$(TestFolder)\Contrib\Queries\*.csproj" />
-		</ItemGroup>
-
-		<MSBuild Projects="@(QueriesProjectFiles)" Properties="Configuration=$(Configuration);ExternalConstants=$(ExternalConstants)" />
-		<!-- Add "35" to the end of configuration to build .NET35 projects -->
-		<MSBuild Projects="@(QueriesProjectFiles)" Properties="Configuration=$(Configuration)35;ExternalConstants=$(ExternalConstants)" />
-	</Target>
-
-	<Target Name="_queries_properties">
-		<ItemGroup>
-			<!-- Binaries To Copy in case we which to store all build items -->
-			<BuildItems Include="$(QueriesFolder)\**\*.*" /> 
-			
-			<!-- Assemblies To Test -->
-			<TestFiles Include="$(QueriesFolder)\**\Lucene.Net.Contrib.Queries.Test.dll" />
-			
-			<!-- Files To Release -->
-			<ReleaseFiles Include="$(QueriesFolder)\**\Lucene.Net.Contrib.Queries.dll" />
-			<ReleaseFiles Include="$(QueriesFolder)\**\Lucene.Net.Contrib.Queries.XML" />
-		
-			<!-- Files to Analysis -->
-			<AnalysisFiles Include="$(QueriesFolder)\**\Lucene.Net.Contrib.Queries.dll" />	
-		</ItemGroup>
-	</Target>
-
-	<Target Name="BuildQueries">
-		<CallTarget Targets="_queries_build" />
-		<CallTarget Targets="_queries_properties" />
-	</Target>
-</Project>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/scripts/Regex/document.targets
----------------------------------------------------------------------
diff --git a/build/scripts/Regex/document.targets b/build/scripts/Regex/document.targets
deleted file mode 100644
index 59d721c..0000000
--- a/build/scripts/Regex/document.targets
+++ /dev/null
@@ -1,31 +0,0 @@
-<?xml version="1.0" encoding="UTF-8" standalone="no" ?>
-<!--
- 
- Licensed to the Apache Software Foundation (ASF) under one or more
- contributor license agreements.  See the NOTICE file distributed with
- this work for additional information regarding copyright ownership.
- The ASF licenses this file to You under the Apache License, Version 2.0
- (the "License"); you may not use this file except in compliance with
- the License.  You may obtain a copy of the License at
-  
- http://www.apache.org/licenses/LICENSE-2.0
-  
- Unless required by applicable law or agreed to in writing, software
- distributed under the License is distributed on an "AS IS" BASIS,
- WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- See the License for the specific language governing permissions and
- limitations under the License.
- 
--->
-<Project xmlns="http://schemas.microsoft.com/developer/msbuild/2003" ToolsVersion="4.0">
-	<PropertyGroup>
-		 <DocumentationSources>
-      		<DocumentationSource sourceFile="..\bin\contrib\Regex\Release\NET40\Lucene.Net.Contrib.Regex.dll" />
-      		<DocumentationSource sourceFile="..\bin\contrib\Regex\Release\NET40\Lucene.Net.Contrib.Regex.XML" />
-    	</DocumentationSources>
-    	<HtmlHelpName>Lucene.Net.Contrib.Regex</HtmlHelpName>
-    	<HelpTitle>Regex Class Library</HelpTitle>
-    	<WorkingPath>..\artifacts\Regex\working\</WorkingPath>
-	    <OutputPath>..\artifacts\Regex\docs\</OutputPath>
-	</PropertyGroup>
-</Project>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/scripts/Regex/project.targets
----------------------------------------------------------------------
diff --git a/build/scripts/Regex/project.targets b/build/scripts/Regex/project.targets
deleted file mode 100644
index 7ce0e62..0000000
--- a/build/scripts/Regex/project.targets
+++ /dev/null
@@ -1,66 +0,0 @@
-<?xml version="1.0" encoding="UTF-8" standalone="no" ?>
-<!--
- 
- Licensed to the Apache Software Foundation (ASF) under one or more
- contributor license agreements.  See the NOTICE file distributed with
- this work for additional information regarding copyright ownership.
- The ASF licenses this file to You under the Apache License, Version 2.0
- (the "License"); you may not use this file except in compliance with
- the License.  You may obtain a copy of the License at
-  
- http://www.apache.org/licenses/LICENSE-2.0
-  
- Unless required by applicable law or agreed to in writing, software
- distributed under the License is distributed on an "AS IS" BASIS,
- WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- See the License for the specific language governing permissions and
- limitations under the License.
- 
--->
-<Project xmlns="http://schemas.microsoft.com/developer/msbuild/2003" ToolsVersion="4.0">
-	<!-- 
-		Core Projects Are:
-			Lucene.Net, 
-			Lucene.Net.Test, 
-	-->
-	<PropertyGroup>
-		<RegexFolder>$(BinFolder)\contrib\Regex\$(Configuration)</RegexFolder>
-	</PropertyGroup>
-	<PropertyGroup  Condition="'$(Area)' == 'regex'">
-		<LocalBinFolder>$(BinFolder)\contrib\Regex\$(Configuration)</LocalBinFolder>
-		<ArtifactsFolder>$(BuildFolder)\artifacts\Regex</ArtifactsFolder>
-	</PropertyGroup>
-
-	<Target Name="_regex_build">
-		<ItemGroup>
-			<RegexProjectFiles Include="$(SourceFolder)\Contrib\Regex\*.csproj" />
-			<RegexProjectFiles Include="$(TestFolder)\Contrib\Regex\*.csproj" />
-		</ItemGroup>
-
-		<MSBuild Projects="@(RegexProjectFiles)" Properties="Configuration=$(Configuration);ExternalConstants=$(ExternalConstants)" />
-		<!-- Add "35" to the end of configuration to build .NET35 projects -->
-		<MSBuild Projects="@(RegexProjectFiles)" Properties="Configuration=$(Configuration)35;ExternalConstants=$(ExternalConstants)" />
-	</Target>
-
-	<Target Name="_regex_properties">
-		<ItemGroup>
-			<!-- Binaries To Copy in case we which to store all build items -->
-			<BuildItems Include="$(RegexFolder)\**\*.*" /> 
-			
-			<!-- Assemblies To Test -->
-			<TestFiles Include="$(RegexFolder)\**\Lucene.Net.Contrib.Regex.Test.dll" />
-			
-			<!-- Files To Release -->
-			<ReleaseFiles Include="$(RegexFolder)\**\Lucene.Net.Contrib.Regex.dll" />
-			<ReleaseFiles Include="$(RegexFolder)\**\Lucene.Net.Contrib.Regex.XML" />
-		
-			<!-- Files to Analysis -->
-			<AnalysisFiles Include="$(RegexFolder)\**\Lucene.Net.Contrib.Regex.dll" />	
-		</ItemGroup>
-	</Target>
-
-	<Target Name="BuildRegex">
-		<CallTarget Targets="_regex_build" />
-		<CallTarget Targets="_regex_properties" />
-	</Target>
-</Project>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/scripts/SimpleFacetedSearch/document.targets
----------------------------------------------------------------------
diff --git a/build/scripts/SimpleFacetedSearch/document.targets b/build/scripts/SimpleFacetedSearch/document.targets
deleted file mode 100644
index 115277b..0000000
--- a/build/scripts/SimpleFacetedSearch/document.targets
+++ /dev/null
@@ -1,31 +0,0 @@
-<?xml version="1.0" encoding="UTF-8" standalone="no" ?>
-<!--
- 
- Licensed to the Apache Software Foundation (ASF) under one or more
- contributor license agreements.  See the NOTICE file distributed with
- this work for additional information regarding copyright ownership.
- The ASF licenses this file to You under the Apache License, Version 2.0
- (the "License"); you may not use this file except in compliance with
- the License.  You may obtain a copy of the License at
-  
- http://www.apache.org/licenses/LICENSE-2.0
-  
- Unless required by applicable law or agreed to in writing, software
- distributed under the License is distributed on an "AS IS" BASIS,
- WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- See the License for the specific language governing permissions and
- limitations under the License.
- 
--->
-<Project xmlns="http://schemas.microsoft.com/developer/msbuild/2003" ToolsVersion="4.0">
-	<PropertyGroup>
-		 <DocumentationSources>
-      		<DocumentationSource sourceFile="..\bin\contrib\SimpleFacetedSearch\Release\NET40\Lucene.Net.Contrib.SimpleFacetedSearch.dll" />
-      		<DocumentationSource sourceFile="..\bin\contrib\SimpleFacetedSearch\Release\NET40\Lucene.Net.Contrib.SimpleFacetedSearch.XML" />
-    	</DocumentationSources>
-    	<HtmlHelpName>Lucene.Net.Contrib.SimpleFacetedSearch</HtmlHelpName>
-    	<HelpTitle>SimpleFacetedSearch Class Library</HelpTitle>
-    	<WorkingPath>..\artifacts\SimpleFacetedSearch\working\</WorkingPath>
-	    <OutputPath>..\artifacts\SimpleFacetedSearch\docs\</OutputPath>
-	</PropertyGroup>
-</Project>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/scripts/SimpleFacetedSearch/project.targets
----------------------------------------------------------------------
diff --git a/build/scripts/SimpleFacetedSearch/project.targets b/build/scripts/SimpleFacetedSearch/project.targets
deleted file mode 100644
index 2d7c16f..0000000
--- a/build/scripts/SimpleFacetedSearch/project.targets
+++ /dev/null
@@ -1,66 +0,0 @@
-<?xml version="1.0" encoding="UTF-8" standalone="no" ?>
-<!--
- 
- Licensed to the Apache Software Foundation (ASF) under one or more
- contributor license agreements.  See the NOTICE file distributed with
- this work for additional information regarding copyright ownership.
- The ASF licenses this file to You under the Apache License, Version 2.0
- (the "License"); you may not use this file except in compliance with
- the License.  You may obtain a copy of the License at
-  
- http://www.apache.org/licenses/LICENSE-2.0
-  
- Unless required by applicable law or agreed to in writing, software
- distributed under the License is distributed on an "AS IS" BASIS,
- WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- See the License for the specific language governing permissions and
- limitations under the License.
- 
--->
-<Project xmlns="http://schemas.microsoft.com/developer/msbuild/2003" ToolsVersion="4.0">
-	<!-- 
-		Core Projects Are:
-			Lucene.Net, 
-			Lucene.Net.Test, 
-	-->
-	<PropertyGroup>
-		<SimpleFacetedSearchFolder>$(BinFolder)\contrib\SimpleFacetedSearch\$(Configuration)</SimpleFacetedSearchFolder>
-	</PropertyGroup>
-	<PropertyGroup  Condition="'$(Area)' == 'simplefacetedsearch'">
-		<LocalBinFolder>$(BinFolder)\contrib\SimpleFacetedSearch\$(Configuration)</LocalBinFolder>
-		<ArtifactsFolder>$(BuildFolder)\artifacts\SimpleFacetedSearch</ArtifactsFolder>
-	</PropertyGroup>
-		
-	<Target Name="_simplefacetedsearch_build">
-		<ItemGroup>
-			<SimpleFacetedSearchProjectFiles Include="$(SourceFolder)\Contrib\SimpleFacetedSearch\*.csproj" />
-			<SimpleFacetedSearchProjectFiles Include="$(TestFolder)\Contrib\SimpleFacetedSearch\*.csproj" />
-		</ItemGroup>
-
-		<MSBuild Projects="@(SimpleFacetedSearchProjectFiles)" Properties="Configuration=$(Configuration);ExternalConstants=$(ExternalConstants)" />
-		<!-- Add "35" to the end of configuration to build .NET35 projects -->
-		<MSBuild Projects="@(SimpleFacetedSearchProjectFiles)" Properties="Configuration=$(Configuration)35;ExternalConstants=$(ExternalConstants)" />
-	</Target>
-
-	<Target Name="_simplefacetedsearch_properties">
-		<ItemGroup>
-			<!-- Binaries To Copy in case we which to store all build items -->
-			<BuildItems Include="$(SimpleFacetedSearchFolder)\**\*.*" /> 
-					
-			<!-- Assemblies To Test -->
-			<TestFiles Include="$(SimpleFacetedSearchFolder)\**\Lucene.Net.Contrib.SimpleFacetedSearch.Test.dll" />
-			
-			<!-- Files To Release -->
-			<ReleaseFiles Include="$(SimpleFacetedSearchFolder)\**\Lucene.Net.Contrib.SimpleFacetedSearch.dll" />
-			<ReleaseFiles Include="$(SimpleFacetedSearchFolder)\**\Lucene.Net.Contrib.SimpleFacetedSearch.XML" />
-		
-			<!-- Files to Analysis -->
-			<AnalysisFiles Include="$(SimpleFacetedSearchFolder)\**\Lucene.Net.Contrib.SimpleFacetedSearch.dll" />	
-		</ItemGroup>
-	</Target>
-
-	<Target Name="BuildSimpleFacetedSearch">
-		<CallTarget Targets="_simplefacetedsearch_build" />
-		<CallTarget Targets="_simplefacetedsearch_properties" />
-	</Target>
-</Project>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/scripts/Snowball/document.targets
----------------------------------------------------------------------
diff --git a/build/scripts/Snowball/document.targets b/build/scripts/Snowball/document.targets
deleted file mode 100644
index 9bbb52e..0000000
--- a/build/scripts/Snowball/document.targets
+++ /dev/null
@@ -1,31 +0,0 @@
-<?xml version="1.0" encoding="UTF-8" standalone="no" ?>
-<!--
- 
- Licensed to the Apache Software Foundation (ASF) under one or more
- contributor license agreements.  See the NOTICE file distributed with
- this work for additional information regarding copyright ownership.
- The ASF licenses this file to You under the Apache License, Version 2.0
- (the "License"); you may not use this file except in compliance with
- the License.  You may obtain a copy of the License at
-  
- http://www.apache.org/licenses/LICENSE-2.0
-  
- Unless required by applicable law or agreed to in writing, software
- distributed under the License is distributed on an "AS IS" BASIS,
- WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- See the License for the specific language governing permissions and
- limitations under the License.
- 
--->
-<Project xmlns="http://schemas.microsoft.com/developer/msbuild/2003" ToolsVersion="4.0">
-	<PropertyGroup>
-		 <DocumentationSources>
-      		<DocumentationSource sourceFile="..\bin\contrib\Snowball\Release\NET40\Lucene.Net.Contrib.Snowball.dll" />
-      		<DocumentationSource sourceFile="..\bin\contrib\Snowball\Release\NET40\Lucene.Net.Contrib.Snowball.XML" />
-    	</DocumentationSources>
-    	<HtmlHelpName>Lucene.Net.Contrib.Snowball</HtmlHelpName>
-    	<HelpTitle>Snowball Class Library</HelpTitle>
-    	<WorkingPath>..\artifacts\Snowball\working\</WorkingPath>
-	    <OutputPath>..\artifacts\Snowball\docs\</OutputPath>
-	</PropertyGroup>
-</Project>
\ No newline at end of file


[39/51] [abbrv] [partial] Cleaning up and getting ready to development towards v4.8

Posted by sy...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Gallio.Icarus.plugin
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Gallio.Icarus.plugin b/lib/Gallio.3.2.750/tools/Gallio.Icarus.plugin
deleted file mode 100644
index d2bb1af..0000000
--- a/lib/Gallio.3.2.750/tools/Gallio.Icarus.plugin
+++ /dev/null
@@ -1,177 +0,0 @@
-<?xml version="1.0" encoding="utf-8" ?>
-<plugin pluginId="Gallio.Icarus"
-        recommendedInstallationPath=""
-        xmlns="http://www.gallio.org/">
-  
-  <traits>
-    <name>Gallio Icarus Test Runner</name>
-    <version>3.2.0.0</version>
-    <description>A GUI based test runner.</description>
-    <icon>plugin://Gallio.Icarus/Resources/Gallio.Icarus.ico</icon>
-  </traits>
-
-  <dependencies>
-    <dependency pluginId="Gallio.UI" />
-  </dependencies>
-
-  <files>
-    <file path="Gallio.Icarus.plugin" />
-    <file path="Gallio.Icarus.exe" />
-    <file path="Gallio.Icarus.exe.config" />
-    <file path="Gallio.Icarus.XmlSerializers.dll" />
-    <file path="ICSharpCode.TextEditor.dll" />
-    <file path="Resources\Gallio.Icarus.ico" />
-  </files>
-
-  <services>
-    
-    <service serviceId="Gallio.Icarus.OptionsController" 
-             serviceType="Gallio.Icarus.Controllers.Interfaces.IOptionsController, Gallio.Icarus" />
-
-    <service serviceId="Gallio.Icarus.Package" 
-             serviceType="Gallio.Icarus.IPackage, Gallio.Icarus" />
-			 
-    <service serviceId="Gallio.Icarus.WindowManager.WindowManager" 
-             serviceType="Gallio.Icarus.WindowManager.IWindowManager, Gallio.Icarus" />
-
-    <service serviceId="Gallio.Icarus.WindowManager.MenuManager"
-             serviceType="Gallio.Icarus.WindowManager.IMenuManager, Gallio.Icarus" />
-
-    <service serviceId="Gallio.Icarus.Runtime.PluginScanner" 
-             serviceType="Gallio.Icarus.Runtime.IPluginScanner, Gallio.Icarus" />
-
-    <service serviceId="Gallio.Icarus.TreeBuilders.TreeBuilder"
-             serviceType="Gallio.Icarus.TreeBuilders.ITreeBuilder, Gallio.Icarus" />
-    
-  </services>
-
-  <components>
-  
-    <component componentId="Gallio.Icarus.Controllers.OptionsController" 
-               serviceId="Gallio.Icarus.OptionsController"
-               componentType="Gallio.Icarus.Controllers.OptionsController, Gallio.Icarus" />
-  
-    <component componentId="Gallio.Icarus.WindowManager.WindowManager" 
-               serviceId="Gallio.Icarus.WindowManager.WindowManager"
-               componentType="Gallio.Icarus.WindowManager.WindowManager, Gallio.Icarus" />
-
-    <component componentId="Gallio.Icarus.WindowManager.MenuManager"
-               serviceId="Gallio.Icarus.WindowManager.MenuManager"
-               componentType="Gallio.Icarus.WindowManager.MenuManager, Gallio.Icarus" />
-    
-    <component componentId="Gallio.Icarus.Runtime.DefaultConventionScanner" 
-               serviceId="Gallio.Icarus.Runtime.PluginScanner"
-               componentType="Gallio.Icarus.Runtime.DefaultConventionScanner, Gallio.Icarus" />
-    
-    <!-- Tree builders -->
-
-    <component componentId="Gallio.Icarus.TreeBuilders.NamespaceTreeBuilder"
-               serviceId="Gallio.Icarus.TreeBuilders.TreeBuilder"
-               componentType="Gallio.Icarus.TreeBuilders.NamespaceTreeBuilder, Gallio.Icarus">
-      <traits>
-        <priority>1</priority>
-      </traits>
-    </component>
-
-    <component componentId="Gallio.Icarus.TreeBuilders.MetadataTreeBuilder"
-               serviceId="Gallio.Icarus.TreeBuilders.TreeBuilder"
-               componentType="Gallio.Icarus.TreeBuilders.MetadataTreeBuilder, Gallio.Icarus">
-      <traits>
-        <priority>1</priority>
-      </traits>
-    </component>
-    
-    <!-- Control panel -->
-
-    <component componentId="Gallio.Icarus.ControlPanel.RootPaneProvider"
-               serviceId="Gallio.UI.PreferencePaneProvider">
-      <traits>
-        <path>Icarus</path>
-        <order>-75</order>
-        <icon>plugin://Gallio.Icarus/Resources/Gallio.Icarus.ico</icon>
-      </traits>
-    </component>
-
-    <component componentId="Gallio.Icarus.ControlPanel.TestStatusPaneProvider"
-           serviceId="Gallio.UI.PreferencePaneProvider"
-           componentType="Gallio.Icarus.ControlPanel.TestStatusPaneProvider, Gallio.Icarus">
-      <traits>
-        <path>Icarus/Appearance/Test Status</path>
-        <order>100</order>
-        <icon>plugin://Gallio.Icarus/Resources/Gallio.Icarus.ico</icon>
-      </traits>
-    </component>
-
-    <component componentId="Gallio.Icarus.ControlPanel.StartupPaneProvider"
-           serviceId="Gallio.UI.PreferencePaneProvider"
-           componentType="Gallio.Icarus.ControlPanel.StartupPaneProvider, Gallio.Icarus">
-      <traits>
-        <path>Icarus/Startup</path>
-        <order>200</order>
-        <icon>plugin://Gallio.Icarus/Resources/Gallio.Icarus.ico</icon>
-      </traits>
-    </component>
-
-    <component componentId="Gallio.Icarus.ControlPanel.TestExplorerPaneProvider" 
-               serviceId="Gallio.UI.PreferencePaneProvider" 
-               componentType="Gallio.Icarus.ControlPanel.TestExplorerPaneProvider, Gallio.Icarus">
-      <traits>
-        <path>Icarus/Test Explorer</path>
-        <order>300</order>
-        <icon>plugin://Gallio.Icarus/Resources/Gallio.Icarus.ico</icon>
-      </traits>
-    </component>
-
-    <component componentId="Gallio.Icarus.ControlPanel.TreeViewCategoryPaneProvider" 
-               serviceId="Gallio.UI.PreferencePaneProvider" 
-               componentType="Gallio.Icarus.ControlPanel.TreeViewCategoryPaneProvider, Gallio.Icarus">
-      <traits>
-        <path>Icarus/Test Explorer/Tree View Categories</path>
-        <order>1</order>
-        <icon>plugin://Gallio.Icarus/Resources/Gallio.Icarus.ico</icon>
-      </traits>
-    </component>
-
-    <component componentId="Gallio.Icarus.ControlPanel.ReportsPaneProvider" 
-               serviceId="Gallio.UI.PreferencePaneProvider" 
-               componentType="Gallio.Icarus.ControlPanel.ReportsPaneProvider, Gallio.Icarus">
-      <traits>
-        <path>Icarus/Reports</path>
-        <order>1</order>
-        <icon>plugin://Gallio.Icarus/Resources/Gallio.Icarus.ico</icon>
-      </traits>
-    </component>
-
-    <component componentId="Gallio.Icarus.ControlPanel.ProgressMonitoringPaneProvider" 
-               serviceId="Gallio.UI.PreferencePaneProvider" 
-               componentType="Gallio.Icarus.ControlPanel.ProgressMonitoringPaneProvider, Gallio.Icarus">
-      <traits>
-        <path>Icarus/Appearance/Progress Monitoring</path>
-        <order>1</order>
-        <icon>plugin://Gallio.Icarus/Resources/Gallio.Icarus.ico</icon>
-      </traits>
-    </component>
-
-    <component componentId="Gallio.Icarus.ControlPanel.TestRunnerExtensionsPaneProvider" 
-               serviceId="Gallio.UI.PreferencePaneProvider" 
-               componentType="Gallio.Icarus.ControlPanel.TestRunnerExtensionsPaneProvider, Gallio.Icarus">
-      <traits>
-        <path>Icarus/Runner/Test Runner Extensions</path>
-        <order>1</order>
-        <icon>plugin://Gallio.Icarus/Resources/Gallio.Icarus.ico</icon>
-      </traits>
-    </component>
-
-    <component componentId="Gallio.Icarus.ControlPanel.TestRunnerFactoryPaneProvider" 
-               serviceId="Gallio.UI.PreferencePaneProvider" 
-               componentType="Gallio.Icarus.ControlPanel.TestRunnerFactoryPaneProvider, Gallio.Icarus">
-      <traits>
-        <path>Icarus/Runner/Test Runner Factory</path>
-        <order>1</order>
-        <icon>plugin://Gallio.Icarus/Resources/Gallio.Icarus.ico</icon>
-      </traits>
-    </component>
-
-  </components>
-
-</plugin>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Gallio.MSBuildTasks.dll
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Gallio.MSBuildTasks.dll b/lib/Gallio.3.2.750/tools/Gallio.MSBuildTasks.dll
deleted file mode 100644
index 063f01c..0000000
Binary files a/lib/Gallio.3.2.750/tools/Gallio.MSBuildTasks.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Gallio.MSBuildTasks.plugin
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Gallio.MSBuildTasks.plugin b/lib/Gallio.3.2.750/tools/Gallio.MSBuildTasks.plugin
deleted file mode 100644
index cf72761..0000000
--- a/lib/Gallio.3.2.750/tools/Gallio.MSBuildTasks.plugin
+++ /dev/null
@@ -1,20 +0,0 @@
-<?xml version="1.0" encoding="utf-8" ?>
-<plugin pluginId="Gallio.MSBuildTasks"
-        recommendedInstallationPath=""
-        xmlns="http://www.gallio.org/">
-  <traits>
-    <name>Gallio MSBuild Tasks</name>
-    <version>3.2.0.0</version>
-    <description>Provides MSBuild tasks for running tests with Gallio.</description>
-  </traits>
-
-  <dependencies>
-    <dependency pluginId="Gallio" />
-  </dependencies>
-
-  <files>
-    <file path="Gallio.MSBuildTasks.plugin" />
-    <file path="Gallio.MSBuildTasks.dll" />
-    <file path="Gallio.MSBuildTasks.xml" />
-  </files>
-</plugin>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Gallio.MSBuildTasks.xml
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Gallio.MSBuildTasks.xml b/lib/Gallio.3.2.750/tools/Gallio.MSBuildTasks.xml
deleted file mode 100644
index daa893f..0000000
--- a/lib/Gallio.3.2.750/tools/Gallio.MSBuildTasks.xml
+++ /dev/null
@@ -1,818 +0,0 @@
-<?xml version="1.0"?>
-<doc>
-    <assembly>
-        <name>Gallio.MSBuildTasks</name>
-    </assembly>
-    <members>
-        <member name="T:Gallio.MSBuildTasks.Gallio">
-            <summary>
-            An MSBuild task that provides support for running Gallio tests.
-            </summary>
-            <remarks>
-            In order for MSBuild to find this task, the Gallio.MSBuildTasks.dll has to be loaded with
-            the UsingTask directive:
-            <code>
-            <![CDATA[
-            <UsingTask AssemblyFile="[Path-to-assembly]\Gallio.MSBuildTasks.dll" TaskName="Gallio" />
-            ]]>
-            </code>
-            The AssemblyFile attribute must be set to the path where the Gallio.MSBuildTasks.dll assembly resides,
-            and the TaskName attribute <strong>must</strong> be set to "Gallio", otherwise MSBuild won't load the task.
-            </remarks>
-            <example>
-            The following code is an example build file that shows how to load the task, specify the test files
-            and assemblies and set some of the task's properties:
-            <code>
-            <![CDATA[
-            <Project xmlns="http://schemas.microsoft.com/developer/msbuild/2003">
-                <!-- This is needed by MSBuild to locate the Gallio task -->
-                <UsingTask AssemblyFile="[Path-to-assembly]\Gallio.MSBuildTasks.dll" TaskName="Gallio" />
-                <!-- Specify the test files and assemblies -->
-                <ItemGroup>
-                  <TestFile Include="[Path-to-test-assembly1]/TestAssembly1.dll" />
-                  <TestFile Include="[Path-to-test-assembly2]/TestAssembly2.dll" />
-                  <TestFile Include="[Path-to-test-script1]/TestScript1_spec.rb" />
-                  <TestFile Include="[Path-to-test-script2]/TestScript2.xml" />
-                </ItemGroup>
-                <Target Name="RunTests">
-                    <Gallio IgnoreFailures="true" Filter="Type=SomeFixture" Files="@(TestFile)">
-                        <!-- This tells MSBuild to store the output value of the task's ExitCode property
-                             into the project's ExitCode property -->
-                        <Output TaskParameter="ExitCode" PropertyName="ExitCode"/>
-                    </Gallio>
-                    <Error Text="Tests execution failed" Condition="'$(ExitCode)' != 0" />
-                </Target>
-            </Project>
-            ]]>
-            </code>
-            </example>
-        </member>
-        <member name="M:Gallio.MSBuildTasks.Gallio.#ctor">
-            <summary>
-            Default constructor.
-            </summary>
-        </member>
-        <member name="M:Gallio.MSBuildTasks.Gallio.Execute">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.MSBuildTasks.Gallio.RunLauncher(Gallio.Runner.TestLauncher)">
-            <exclude />
-            <summary>
-            Provided so that the unit tests can override test execution behavior.
-            </summary>
-        </member>
-        <member name="P:Gallio.MSBuildTasks.Gallio.Files">
-            <summary>
-            The list of relative or absolute paths of test files, projects and assemblies to execute.
-            Wildcards may be used.  This is required.
-            </summary>
-            <example>The following example shows how to specify the test files, projects and assemblies
-            (for a more complete example please see the <see cref="T:Gallio.MSBuildTasks.Gallio"/> task documentation):
-            <code>
-            <![CDATA[
-            <!-- Specify the test files, projects and assemblies -->
-            <ItemGroup>
-                <TestFile Include="[Path-to-test-assembly1]/TestAssembly1.dll" />
-                <TestFile Include="[Path-to-test-assembly2]/TestAssembly2.dll" />
-                <TestFile Include="[Path-to-test-script1]/TestScript1_spec.rb" />
-                <TestFile Include="[Path-to-test-script2]/TestScript2.xml" />
-            </ItemGroup>
-            <Target Name="MyTarget">
-                <Gallio Files="@(TestFile)" />
-            </Target>
-            ]]>
-            </code>
-            </example>
-        </member>
-        <member name="P:Gallio.MSBuildTasks.Gallio.HintDirectories">
-            <summary>
-            The list of directories used for loading referenced assemblies and other dependent resources.
-            </summary>
-            <example>The following example shows how to specify the hint directories:
-            <code>
-            <![CDATA[
-            <ItemGroup>
-                <HintDirectory Include="[Path-to-test-hint-directory-1]/" />
-                <HintDirectory Include="[Path-to-test-hint-directory-2]/" />
-            </ItemGroup>
-            <Target Name="MyTarget">
-                <Gallio HintDirectories="@(HintDirectory)" />
-            </Target>
-            ]]>
-            </code>
-            </example>
-        </member>
-        <member name="P:Gallio.MSBuildTasks.Gallio.PluginDirectories">
-            <summary>
-            Additional Gallio plugin directories to search recursively.
-            </summary>
-            <example>The following example shows how to specify the plugins directories:
-            <code>
-            <![CDATA[
-            <ItemGroup>
-                <PluginDirectory Include="[Path-to-test-plugin-directory-1]/" />
-                <PluginDirectory Include="[Path-to-test-plugin-directory-2]/" />
-            </ItemGroup>
-            <Target Name="MyTarget">
-                <Gallio PluginDirectories="@(PluginDirectory)" />
-            </Target>
-            ]]>
-            </code>
-            </example>
-        </member>
-        <member name="P:Gallio.MSBuildTasks.Gallio.ApplicationBaseDirectory">
-            <summary>
-            <para>
-            Gets or sets the relative or absolute path of the application base directory,
-            or null to use a default value selected by the consumer.
-            </para>
-            <para>
-            If relative, the path is based on the current working directory,
-            so a value of "" causes the current working directory to be used.
-            </para>
-            <para>
-            The default is null.
-            </para>
-            </summary>
-        </member>
-        <member name="P:Gallio.MSBuildTasks.Gallio.WorkingDirectory">
-            <summary>
-            <para>
-            Gets or sets the relative or absolute path of the working directory
-            or null to use a default value selected by the consumer.
-            </para>
-            <para>
-            If relative, the path is based on the current working directory,
-            so a value of "" causes the current working directory to be used.
-            </para>
-            <para>
-            The default is null.
-            </para>
-            </summary>
-        </member>
-        <member name="P:Gallio.MSBuildTasks.Gallio.ShadowCopy">
-            <summary>
-            <para>
-            Enables shadow copying when set to true.
-            </para>
-            <para>
-            Shadow copying allows the original assemblies to be modified while the tests are running.
-            However, shadow copying may occasionally cause some tests to fail if they depend on their original location.
-            </para>
-            <para>
-            The default is false.
-            </para>
-            </summary>
-        </member>
-        <member name="P:Gallio.MSBuildTasks.Gallio.Debug">
-            <summary>
-            <para>
-            Attaches the debugger to the test process when set to true.
-            </para>
-            <para>
-            The default is false.
-            </para>
-            </summary>
-        </member>
-        <member name="P:Gallio.MSBuildTasks.Gallio.RuntimeVersion">
-            <summary>
-            <para>
-            Gets or sets the version of the .Net runtime to use for running tests.
-            </para>
-            <para>
-            For the CLR, this must be the name of one of the framework directories in %SystemRoot%\Microsoft.Net\Framework.  eg. 'v2.0.50727'.
-            </para>
-            <para>
-            The default is null which uses the most recent installed and supported framework.
-            </para>
-            </summary>
-        </member>
-        <member name="P:Gallio.MSBuildTasks.Gallio.ReportTypes">
-            <summary>
-            A list of the types of reports to generate, separated by semicolons. 
-            </summary>
-            <remarks>
-            <list type="bullet">
-            <item>The types supported "out of the box" are: Html, Html-Condensed, Text, Text-Condendes, XHtml,
-            XHtml-Condensed, MHtml, MHtml-CondensedXml, and Xml-Inline, but more types could be available as plugins.</item>
-            <item>The report types are not case sensitive.</item>
-            </list>
-            </remarks>
-            <example>
-            In the following example reports will be generated in both HTML and XML format:
-            <code>
-            <![CDATA[
-            <Target Name="MyTarget">
-                <Gallio ReportTypes="html;xml" />
-            </Target>
-            ]]>
-            </code>
-            </example>
-        </member>
-        <member name="P:Gallio.MSBuildTasks.Gallio.ReportArchive">
-            <summary>
-            Sets the report archive mode.
-            </summary>
-            <remarks>
-            <para>
-            The supported modes are:
-            <list type="bullet">
-            <item>Normal (default)</item>
-            <item>Zip</item>
-            </list>
-            </para>
-            </remarks>
-            <example>
-            In the following example, reports will be enclosed in a zip file:
-            <code>
-            <![CDATA[
-            <Target Name="MyTarget">
-                <Gallio ReportArchive="zip" />
-            </Target>
-            ]]>
-            </code>
-            </example>
-        </member>
-        <member name="P:Gallio.MSBuildTasks.Gallio.ReportNameFormat">
-            <summary>
-            Sets the format string to use to generate the reports filenames.
-            </summary>
-            <remarks>
-            Any occurence of {0} will be replaced by the date, and any occurrence of {1} by the time.
-            The default format string is test-report-{0}-{1}.
-            </remarks>
-        </member>
-        <member name="P:Gallio.MSBuildTasks.Gallio.ReportDirectory">
-            <summary>
-            Sets the name of the directory where the reports will be put.
-            </summary>
-            <remarks>
-            The directory will be created if it doesn't exist.  Existing files will be overwritten.
-            The default report directory is "Reports".
-            </remarks>
-        </member>
-        <member name="P:Gallio.MSBuildTasks.Gallio.RunnerType">
-            <summary>
-            Sets the type of test runner to use.
-            </summary>
-            <remarks>
-            <list type="bullet">
-            <item>The types supported "out of the box" are: Local, IsolatedAppDomain
-            and IsolatedProcess (default), but more types could be available as plugins.</item>
-            <item>The runner types are not case sensitive.</item>
-            </list>
-            </remarks>
-        </member>
-        <member name="P:Gallio.MSBuildTasks.Gallio.RunnerExtensions">
-            <summary>
-            <para>
-            Specifies the type, assembly, and parameters of custom test runner
-            extensions to use during the test run in the form:
-            '[Namespace.]Type,Assembly[;Parameters]'.
-            </para>
-            <para>
-            eg. 'FancyLogger,MyCustomExtensions.dll;SomeParameters'
-            </para>
-            </summary>
-            <remarks>
-            Since semicolons are used to delimit multiple property values in MSBuild,
-            it may be necessary to escape semicolons that appear as part of test
-            runner extension specifications to ensure MSBuild does not misinterpret them.
-            An escaped semicolon may be written as "%3B" in the build file.
-            </remarks>
-            <example>
-            The following example runs tests using a custom logger extension:
-            <code>
-            <![CDATA[
-            <Target Name="MyTarget">
-                <Gallio Files="MyTestAssembly.dll" RunnerExtensions="FancyLogger,MyExtensions.dll%3BColorOutput,FancyIndenting" />
-            </Target>
-            ]]>
-            </code>
-            </example>
-        </member>
-        <member name="P:Gallio.MSBuildTasks.Gallio.RunnerProperties">
-            <summary>
-            Specifies option property key/value pairs for the test runner.
-            </summary>
-            <example>
-            The following example specifies some extra NCover arguments.
-            <code>
-            <![CDATA[
-            <gallio>
-            <Target Name="MyTarget">
-                <Gallio Files="MyTestAssembly.dll" RunnerExtensions="NCoverArguments='//eas Gallio'" />
-            </Target>
-            ]]>
-            </code>
-            </example>
-        </member>
-        <member name="P:Gallio.MSBuildTasks.Gallio.ReportFormatterProperties">
-            <summary>
-            Specifies option property key/value pairs for the report formatter.
-            </summary>
-            <example>
-            The following example changes the default attachment content disposition for the reports.
-            <code>
-            <![CDATA[
-            <Target Name="MyTarget">
-                <Gallio Files="MyTestAssembly.dll" RunnerExtensions="AttachmentContentDisposition=Absent" />
-            </Target>
-            ]]>
-            </code>
-            </example>
-        </member>
-        <member name="P:Gallio.MSBuildTasks.Gallio.Filter">
-            <summary>
-            <para>
-      Sets the filter set to apply, which consists of a sequence of one or more inclusion
-      or exclusion filter rules prefixed using 'include' (optional) or 'exclude'.
-    </para>
-            </summary>
-            <remarks>
-            <para>
-      A filter rule consists of zero or more filter expressions
-      that may be combined using 'and', 'or', and 'not' and grouped with
-      parentheses.  A filter expression consists of a filter key followed by one or
-      more comma-delimited matching values in the form 'key: value, "quoted value",
-      /regular expression/'.
-    </para><para>
-      The filter grammar is defined as follows:
-    </para><para>
-      <code><![CDATA[
-     INCLUDE          ::= "include"              # Not case-sensitive
-     EXCLUDE          ::= "exclude"              # Not case-sensitive
-	
-     OR               ::= "or"                   # Not case-sensitive
-     AND              ::= "and"                  # Not case-sensitive
-     NOT              ::= "not"                  # Not case-sensitive
-
-     <unquotedWord>   ::= [^:,*()/\"']+
-    
-     <quotedWord>     ::= '"' .* '"'             # String delimited by double quotation marks
-                      | "'" .* "'"               # String delimited by single quotation marks
-               
-     <word>           ::= <unquotedWord>
-                      | <quotedWord>
-                      
-     <regexWord>      ::= "/" .* "/"             # Regular expression
-                      | "/" .* "/i"              # Case-insensitive regular expression
-                      
-     <key>            ::= <word>
-    
-     <value>          ::= <word>                 # Value specified by exact string
-                      | <regexWord>              # Value specified by regular expression
-    
-     <matchSequence>  ::= <value> (',' <value>)* # One or more comma-separated values
-    
-     <filterExpr>     ::= "*"                    # "Any"
-                      | <key> ":" matchSeq>
-                      | <filterExpr> OR filterExpr>   # Combine filter expressions with OR
-                      | <filterExpr> AND filterExpr>  # Combine filter expressions with AND
-                      | NOT <filterExpr>         # Negate filter expression
-                      | "(" <filterExpr> ")"     # Grouping filter expression
-		      
-     <filterRule>     ::= <filterExpr>           # Inclusion rule (default case)
-                      | INCLUDE <filterExpr>     # Inclusion rule
-                      | EXCLUDE <filterExpr>     # Exclusion rule
-
-     <filterSet>      ::= <filterRule>           # Filter set consists of at least one filter rule.
-                      | <filterRule> <filterSet> # But may be a sequence of rules.
-     ]]></code>
-    </para><list type="bullet">
-      <item>By default this property takes the value "*", which means the "Any" filter will be applied.</item>
-      <item>
-        The operator precedence is, from highest to lowest: NOT, AND, and OR. All these operators are
-        left-associative.
-      </item>
-      <item>
-        The commas used to separate the values are interpreted as OR operators, so "Type:Fixture1,Fixture2"
-        is equivalent to "Type:Fixture1 or Type:Fixture2".
-      </item>
-      <item>
-        White-space is ignored outside quoted strings, so "Type:Fixture1|Type:Fixture2" is equivalent
-        to "Type : Fixture1 | Type : Fixture2".
-      </item>
-      <item>
-        Commas, colons, slashes, backslashes and quotation marks can be escaped with a backslash. For
-        example, \' will be interpreted as '. Using a single backslash in front of any other character
-        is invalid.
-      </item>
-      <item>
-        Currently the following filter keys are recognized:
-        <list type="bullet">
-          <item>Id: Filter by id.</item>
-          <item>Name: Filter by name.</item>
-          <item>Assembly: Filter by assembly name.</item>
-          <item>Namespace: Filter by namespace name.</item>
-          <item>Type: Filter by type name, including inherited types.</item>
-          <item>ExactType: Filter by type name, excluding inherited types.</item>
-          <item>Member: Filter by member name.</item>
-          <item>
-            *: All other names are assumed to correspond to metadata keys. See <see cref="T:Gallio.Model.MetadataKeys"/> for standard metadata keys.  Common keys are: AuthorName, Category, Description, Importance, TestsOn.  <seealso cref="T:Gallio.Model.MetadataKeys"/>
-          </item>
-        </list>
-      </item>      
-    </list>
-            </remarks>
-            <example>
-            <para>
-      Assuming the following fixtures have been defined:
-    </para><code><![CDATA[
-      [TestFixture]
-      [Category("UnitTest")]
-      [Author("AlbertEinstein")]
-      public class Fixture1
-      {
-        [Test]
-        public void Test1()
-        {
-        }
-        [Test]
-        public void Test2()
-        {
-        }
-      }
-
-      [TestFixture]
-      [Category("IntegrationTest")]
-      public class Fixture2
-      {
-        [Test]
-        public void Test1()
-        {
-        }
-        [Test]
-        public void Test2()
-        {
-        }
-      }
-    ]]></code><para>The following filters could be applied:</para><list type="bullet">
-      <item>
-        <term>Type: Fixture1</term>
-        <description>All the tests within Fixture1 will be run.</description>
-      </item>
-
-      <item>
-        <term>Member: Test1</term>
-        <description>Only Fixture1.Test1 and Fixture2.Test1 will be run.</description>
-      </item>
-
-      <item>
-        <term>Type: Fixture1, Fixture2</term>
-        <description>All the tests within Fixture1 or Fixture2 will be run.</description>
-      </item>
-
-      <item>
-        <term>Type:Fixture1 or Type:Fixture2</term>
-        <description>All the tests within Fixture1 or Fixture2 will be run.</description>
-      </item>
-
-      <item>
-        <term>Type:Fixture1, Fixture2 and Member:Test2</term>
-        <description>Only Fixture1.Test2 and Fixture2.Test2 will be run.</description>
-      </item>
-
-      <item>
-        <term>Type:/Fixture*/ and Member:Test2</term>
-        <description>Only Fixture1.Test2 and Fixture2.Test2 will be run.</description>
-      </item>
-
-      <item>
-        <term>AuthorName:AlbertEinstein</term>
-        <description>All the tests within Fixture1 will be run because its author attribute is set to "AlbertEinstein".</description>
-      </item>
-
-      <item>
-        <term>Category: IntegrationTest</term>
-        <description>All the tests within Fixture2 will be run because its category attribute is set to "IntegrationTest".</description>
-      </item>
-
-      <item>
-        <term>("Type": 'Fixture1' and "Member":/Test*/) or (Type : Fixture2 and Member: /Test*/)</term>
-        <description>All the tests will be run. This example also shows that you can enclose key and
-        values with quotation marks, and group expressions with parentheses.</description>
-      </item>
-
-      <item>
-        <term>exclude AuthorName: AlbertEinstein</term>
-        <description>All the tests within Fixture2 will be run because its author attribute is not set to "AlbertEinstein".</description>
-      </item>
-      
-      <item>
-        <term>exclude Type: Fixture2 include Member: Test2</term>
-        <description>Only Fixture1.Test2 will be run because Fixture2 was excluded from consideration before the inclusion rule was applied.</description>
-      </item>
-    </list>
-            </example>
-        </member>
-        <member name="P:Gallio.MSBuildTasks.Gallio.IgnoreFailures">
-            <summary>
-            Sets whether test failures will be ignored and allow the build to proceed.
-            When set to <c>false</c>, test failures will cause the build to fail.
-            </summary>
-        </member>
-        <member name="P:Gallio.MSBuildTasks.Gallio.ShowReports">
-            <summary>
-            Sets whether to show generated reports in a window using the default system application
-            registered to the report file type.
-            </summary>
-        </member>
-        <member name="P:Gallio.MSBuildTasks.Gallio.DoNotRun">
-            <summary>
-            Sets whether to load the tests but not run them.  This option may be used to produce a
-            report that contains test metadata for consumption by other tools.
-            </summary>
-        </member>
-        <member name="P:Gallio.MSBuildTasks.Gallio.IgnoreAnnotations">
-            <summary>
-            <para>
-            Sets whether to ignore annotations when determining the result code.
-            If false (default), then error annotations, usually indicative of broken tests, will cause
-            a failure result to be generated.
-            </para>
-            </summary>
-        </member>
-        <member name="P:Gallio.MSBuildTasks.Gallio.EchoResults">
-            <summary>
-            Sets whether to echo results to the screen as tests finish.  If this option is set
-            to true, the default, test results are echoed to the console
-            in varying detail depending on the current verbosity level.  Otherwise
-            only final summary statistics are displayed.
-            </summary>
-        </member>
-        <member name="P:Gallio.MSBuildTasks.Gallio.RunTimeLimit">
-            <summary>
-            Sets the maximum amount of time (in seconds) the tests can run
-            before they are canceled. The default is an infinite time to run.
-            </summary>
-        </member>
-        <member name="P:Gallio.MSBuildTasks.Gallio.Verbosity">
-            <summary>
-            The verbosity to use when logging.  The default is "Normal".
-            </summary>
-        </member>
-        <member name="P:Gallio.MSBuildTasks.Gallio.ExitCode">
-            <summary>
-            Gets the exit code of the tests execution.
-            </summary>
-            <remarks>
-            This property is only meaningful when the IgnoreFailures property is set to true.
-            </remarks>
-            <example>
-            To use this property, you need to include an Output tag within the
-            Gallio tag to specify a name to reference it:
-            <code>
-            <![CDATA[
-            <Gallio>
-                 <!-- This tells MSBuild that the task's ExitCode output property will
-                      be made available as a property called ExitCode in the project
-                      after the tests have been run: -->
-                <Output TaskParameter="ExitCode" PropertyName="ExitCode"/>
-            </Gallio>
-            <!-- After the exit code be retrieved and used like this: -->
-            <Error Text="The tests execution failed" Condition="'$(ExitCode)' != 0" />
-            ]]>
-            </code>
-            </example>
-        </member>
-        <member name="P:Gallio.MSBuildTasks.Gallio.TestCount">
-            <summary>
-            Gets the total number of test cases run.
-            </summary>
-            <example>
-            To use this property, you need to include an Output tag within the
-            Gallio tag to specify a name to reference it:
-            <code>
-            <![CDATA[
-            <Gallio>
-                 <!-- This tells MSBuild that the task's TestCount output property will
-                      be made available as a property called TestCount in the project
-                      after the tests have been run: -->
-                <Output TaskParameter="TestCount" PropertyName="TestCount" />
-            </Gallio>
-            <!-- After execution the number of test cases run can be retrieved like this: -->
-            <Message Text="$(TestCount) test cases were run." />
-            ]]>
-            </code>
-            </example>
-        </member>
-        <member name="P:Gallio.MSBuildTasks.Gallio.StepCount">
-            <summary>
-            Gets the total number of test steps run.
-            </summary>
-            <example>
-            To use this property, you need to include an Output tag within the
-            Gallio tag to specify a name to reference it:
-            <code>
-            <![CDATA[
-            <Gallio>
-                 <!-- This tells MSBuild that the task's StepCount output property will
-                      be made available as a property called StepCount in the project
-                      after the tests have been run: -->
-                <Output TaskParameter="StepCount" PropertyName="StepCount" />
-            </Gallio>
-            <!-- After execution the number of test steps run can be retrieved like this: -->
-            <Message Text="$(StepCount) test steps were run." />
-            ]]>
-            </code>
-            </example>
-        </member>
-        <member name="P:Gallio.MSBuildTasks.Gallio.PassedCount">
-            <summary>
-            Gets the total number of test cases that were run and passed.
-            </summary>
-            <example>
-            To use this property, you need to include an Output tag within the
-            Gallio tag to specify a name to reference it:
-            <code>
-            <![CDATA[
-            <Gallio>
-                 <!-- This tells MSBuild that the task's PassedCount output property will
-                      be made available as a property called PassedCount in the project
-                      after the tests have been run: -->
-                <Output TaskParameter="PassedCount" PropertyName="PassedCount" />
-            </Gallio>
-            <!-- After execution the number of passed tests can be retrieved like this: -->
-            <Message Text="$(PassedCount) tests passed." />
-            ]]>
-            </code>
-            </example>
-        </member>
-        <member name="P:Gallio.MSBuildTasks.Gallio.FailedCount">
-            <summary>
-            Gets the total number of test cases that were run and failed.
-            </summary>
-            <example>
-            To use this property, you need to include an Output tag within the
-            Gallio tag to specify a name to reference it:
-            <code>
-            <![CDATA[
-            <Gallio>
-                 <!-- This tells MSBuild that the task's FailedCount output property will
-                      be made available as a property called FailedCount in the project
-                      after the tests have been run: -->
-                <Output TaskParameter="FailedCount" PropertyName="FailedCount" />
-            </Gallio>
-            <!-- After execution the number of failed tests can be retrieved like this: -->
-            <Message Text="$(FailedCount) tests passed." />
-            ]]>
-            </code>
-            </example>
-        </member>
-        <member name="P:Gallio.MSBuildTasks.Gallio.InconclusiveCount">
-            <summary>
-            Gets the total number of test cases that ran and were inconclusive.
-            </summary>
-            <example>
-            To use this property, you need to include an Output tag within the
-            Gallio tag to specify a name to reference it:
-            <code>
-            <![CDATA[
-            <Gallio>
-                 <!-- This tells MSBuild that the task's InconclusiveCount output property will
-                      be made available as a property called InconclusiveCount in the project
-                      after the tests have been run: -->
-                <Output TaskParameter="InconclusiveCount" PropertyName="InconclusiveCount" />
-            </Gallio>
-            <!-- After execution the number of inconclusive tests can be retrieved like this: -->
-            <Message Text="$(InconclusiveCount) tests were inconclusive." />
-            ]]>
-            </code>
-            </example>
-        </member>
-        <member name="P:Gallio.MSBuildTasks.Gallio.RunCount">
-            <summary>
-            Gets the total number of test cases that were run.
-            </summary>
-            <example>
-            To use this property, you need to include an Output tag within the
-            Gallio tag to specify a name to reference it:
-            <code>
-            <![CDATA[
-            <Gallio>
-                 <!-- This tells MSBuild that the task's RunCount output property will
-                      be made available as a property called RunCount in the project
-                      after the tests have been run: -->
-                <Output TaskParameter="RunCount" PropertyName="RunCount" />
-            </Gallio>
-            <!-- After execution the number of tests run can be retrieved like this: -->
-            <Message Text="$(RunCount) tests were run." />
-            ]]>
-            </code>
-            </example>
-        </member>
-        <member name="P:Gallio.MSBuildTasks.Gallio.SkippedCount">
-            <summary>
-            Gets the total number of test cases that did not run because they were skipped.
-            </summary>
-            <example>
-            To use this property, you need to include an Output tag within the
-            Gallio tag to specify a name to reference it:
-            <code>
-            <![CDATA[
-            <Gallio>
-                 <!-- This tells MSBuild that the task's SkippedCount output property will
-                      be made available as a property called SkippedCount in the project
-                      after the tests have been run: -->
-                <Output TaskParameter="SkippedCount" PropertyName="SkippedCount" />
-            </Gallio>
-            <!-- After execution the number of skipped tests can be retrieved like this: -->
-            <Message Text="$(SkippedCount) tests were skipped." />
-            ]]>
-            </code>
-            </example>
-        </member>
-        <member name="P:Gallio.MSBuildTasks.Gallio.Duration">
-            <summary>
-            Gets the duration of the tests execution in seconds.
-            </summary>
-            <example>
-            To use this property, you need to include an Output tag within the
-            Gallio tag to specify a name to reference it:
-            <code>
-            <![CDATA[
-            <Gallio>
-                 <!-- This tells MSBuild that the task's Duration output property will
-                      be made available as a property called Duration in the project
-                      after the tests have been run: -->
-                <Output TaskParameter="Duration" PropertyName="Duration" />
-            </Gallio>
-            <!-- After execution the duration can be retrieved like this: -->
-            <Message Text="The tests took $(Duration)s to execute." />
-            ]]>
-            </code>
-            </example>
-        </member>
-        <member name="P:Gallio.MSBuildTasks.Gallio.AssertCount">
-            <summary>
-            Gets the number of assertions evaluated.
-            </summary>
-            <example>
-            To use this property, you need to include an Output tag within the
-            Gallio tag to specify a name to reference it:
-            <code>
-            <![CDATA[
-            <Gallio>
-                 <!-- This tells MSBuild that the task's AssertionCount output property will
-                      be made available as a property called AssertionCount in the project
-                      after the tests have been run: -->
-                <Output TaskParameter="AssertionCount" PropertyName="AssertionCount" />
-            </Gallio>
-            <!-- After execution the number of assertions can be retrieved like this: -->
-            <Message Text="$(AssertionCount) assertions were evaluated." />
-            ]]>
-            </code>
-            </example>
-        </member>
-        <member name="T:Gallio.MSBuildTasks.NamespaceDoc">
-            <summary>
-            The Gallio.MSBuildTasks namespace contains MSBuild tasks for Gallio.
-            </summary>
-        </member>
-        <member name="T:Gallio.MSBuildTasks.TaskLogger">
-            <exclude/>
-            <summary>
-            Logs messages to a <see cref="T:Microsoft.Build.Utilities.TaskLoggingHelper"/> instance.
-            </summary>
-        </member>
-        <member name="T:Gallio.MSBuildTasks.Properties.Resources">
-            <summary>
-              A strongly-typed resource class, for looking up localized strings, etc.
-            </summary>
-        </member>
-        <member name="P:Gallio.MSBuildTasks.Properties.Resources.ResourceManager">
-            <summary>
-              Returns the cached ResourceManager instance used by this class.
-            </summary>
-        </member>
-        <member name="P:Gallio.MSBuildTasks.Properties.Resources.Culture">
-            <summary>
-              Overrides the current thread's CurrentUICulture property for all
-              resource lookups using this strongly typed resource class.
-            </summary>
-        </member>
-        <member name="P:Gallio.MSBuildTasks.Properties.Resources.DefaultReportNameFormat">
-            <summary>
-              Looks up a localized string similar to test-report-{0}-{1}.
-            </summary>
-        </member>
-        <member name="P:Gallio.MSBuildTasks.Properties.Resources.TaskNameAndVersion">
-            <summary>
-              Looks up a localized string similar to Gallio MSBuild Task - Version {0}.
-            </summary>
-        </member>
-        <member name="P:Gallio.MSBuildTasks.Properties.Resources.UnexpectedErrorDuringExecution">
-            <summary>
-              Looks up a localized string similar to An unexpected error occurred during execution of the Gallio task..
-            </summary>
-        </member>
-        <member name="T:Gallio.MSBuildTasks.TaskLogExtension">
-            <exclude/>
-            <summary>
-            Logs messages to a <see cref="T:Microsoft.Build.Utilities.TaskLoggingHelper"/> instance
-            for test results.
-            </summary>
-        </member>
-    </members>
-</doc>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Gallio.Navigator.Readme.txt
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Gallio.Navigator.Readme.txt b/lib/Gallio.3.2.750/tools/Gallio.Navigator.Readme.txt
deleted file mode 100644
index 59f8d51..0000000
--- a/lib/Gallio.3.2.750/tools/Gallio.Navigator.Readme.txt
+++ /dev/null
@@ -1,24 +0,0 @@
-Gallio.Navigator
-================
-
-The Gallio Navigator component enables external applications to navigate to source code
-by clicking on links that are interpreted by a Pluggable Protocol Handler or by loading
-an ActiveX / COM object marked safe for scripting.
-
-These services are intended to present a minimum security risk and specifically do not
-disclose user information to the calling application.
-
-(In the future this mechanism may be used to provide additional Gallio services.)
-
-NavigateTo Service:
-
-  Link Format: gallio:navigateTo?path=<path>&line=<lineNumber>&column=<columnNumber>
-  
-  ActiveX:     Gallio.Navigator.GallioNavigator class
-               bool NavigateTo(string path, int lineNumber, int columnNumber)
-
-  Parameters:
-
-    <path>         - The path of the source file.
-    <lineNumber>   - The 1-based line number, or 0 if unspecified.
-    <columnNumber> - The 1-based column number, or 0 if unspecified.

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Gallio.Navigator.exe
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Gallio.Navigator.exe b/lib/Gallio.3.2.750/tools/Gallio.Navigator.exe
deleted file mode 100644
index df4dffe..0000000
Binary files a/lib/Gallio.3.2.750/tools/Gallio.Navigator.exe and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Gallio.Navigator.exe.config
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Gallio.Navigator.exe.config b/lib/Gallio.3.2.750/tools/Gallio.Navigator.exe.config
deleted file mode 100644
index 5a226ea..0000000
--- a/lib/Gallio.3.2.750/tools/Gallio.Navigator.exe.config
+++ /dev/null
@@ -1,7 +0,0 @@
-<?xml version="1.0" encoding="utf-8" ?>
-<configuration>
-  <startup>
-    <supportedRuntime version="v4.0.30319" />
-    <supportedRuntime version="v2.0.50727" />
-  </startup>
-</configuration>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Gallio.Navigator.plugin
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Gallio.Navigator.plugin b/lib/Gallio.3.2.750/tools/Gallio.Navigator.plugin
deleted file mode 100644
index 031e0a7..0000000
--- a/lib/Gallio.3.2.750/tools/Gallio.Navigator.plugin
+++ /dev/null
@@ -1,22 +0,0 @@
-<?xml version="1.0" encoding="utf-8" ?>
-<plugin pluginId="Gallio.Navigator"
-        recommendedInstallationPath=""
-        xmlns="http://www.gallio.org/">
-  <traits>
-    <name>Gallio Navigator</name>
-    <version>3.2.0.0</version>
-    <description>.</description>
-  </traits>
-
-  <dependencies>
-    <dependency pluginId="Gallio" />
-    <dependency pluginId="Gallio.VisualStudio.Interop" />
-  </dependencies>
-
-  <files>
-    <file path="Gallio.Navigator.plugin" />
-    <file path="Gallio.Navigator.exe" />
-    <file path="Gallio.Navigator.exe.config" />
-    <file path="Gallio.Navigator.Readme.txt" />
-  </files>
-</plugin>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Gallio.PowerShellCommands.dll
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Gallio.PowerShellCommands.dll b/lib/Gallio.3.2.750/tools/Gallio.PowerShellCommands.dll
deleted file mode 100644
index 9572ad4..0000000
Binary files a/lib/Gallio.3.2.750/tools/Gallio.PowerShellCommands.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Gallio.PowerShellCommands.dll-Help.xml
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Gallio.PowerShellCommands.dll-Help.xml b/lib/Gallio.3.2.750/tools/Gallio.PowerShellCommands.dll-Help.xml
deleted file mode 100644
index 39c9858..0000000
--- a/lib/Gallio.3.2.750/tools/Gallio.PowerShellCommands.dll-Help.xml
+++ /dev/null
@@ -1,404 +0,0 @@
-<?xml version="1.0" encoding="utf-8" ?>
-
-<helpItems xmlns="http://msh" schema="maml">
-
-  <command:command xmlns:maml="http://schemas.microsoft.com/maml/2004/10" xmlns:command="http://schemas.microsoft.com/maml/dev/command/2004/10" xmlns:dev="http://schemas.microsoft.com/maml/dev/2004/10">
-    <command:details>
-      <command:name>
-        Run-Gallio
-      </command:name>
-      <maml:description>
-        <maml:para>Runs tests using Gallio.</maml:para>
-      </maml:description>
-      <maml:copyright>
-        <maml:para>Copyright © 2005-2009 Gallio Project - http://www.gallio.org/</maml:para>
-      </maml:copyright>
-      <command:verb>Run</command:verb>
-      <command:noun>Gallio</command:noun>
-      <dev:version></dev:version>
-    </command:details>
-    <maml:description>
-      <maml:para>The Run-Gallio cmdlet runs tests using Gallio.</maml:para>
-    </maml:description>
-    <command:syntax>
-
-      <!-- 
-      
-      Description of the properties used in the command:parameter elements:
-      
-      #  Required
-          * If true, the parameter must appear in all commands that use the parameter set.
-          * If false, the parameter is optional in all commands that use the parameter set.
-
-      # Position
-          * If named, the parameter name is required.
-          * If positional, the parameter name is optional. When it is omitted, the parameter value must be in the specified position in the command. For example, if the value is position="1", the parameter value must be the first or only unnamed parameter value in the command.
-
-      # Pipeline Input
-          * If true (ByValue), you can pipe input to the parameter. The input is associated with ("bound to") the parameter even if the property name and the object type do not match the expected type. The Microsoft® Windows® PowerShell parameter binding components try to convert the input to the correct type and fail the command only when the type cannot be converted. Only one parameter in a parameter set can be associated by value.
-          * If true (ByPropertyName), you can pipe input to the parameter. However, the input is associated with the parameter only when the parameter name matches the name of a property of the input object. For example, if the parameter name is Path, objects piped to the cmdlet are associated with that parameter only when the object has a property named path.
-          * If true (ByValue, ByPropertyName), you can pipe input to the parameter either by property name or by value. Only one parameter in a parameter set can be associated by value.
-          * If false, you cannot pipe input to this parameter.
-
-      # Globbing
-          * If true, the text that the user types for the parameter value can include wildcard characters.
-          * If false, the text that the user types for the parameter value cannot include wildcard characters.
-
-      # VariableLength
-      
-          * It looks this property is meaningless, at least in PowerShell 1.0:
-          
-          ============================================================================
-          Hi Keith
-
-          This attribute is not consumed by our Help formatter in the current release.
-          This is added to comply with MAML command schema.
-
-          Thanks
-          Krishna[MSFT]
-          Windows PowerShell Team
-          Microsoft Corporation
-          This posting is provided "AS IS" with no warranties, and confers no rights.
-          ============================================================================      
-      -->
-      
-      <command:syntaxItem>
-
-        <command:parameter required="false" variableLength="true" globbing="false" pipelineInput="false" position="named">
-          <maml:name>ApplicationBaseDirectory</maml:name>
-          <maml:description>
-            <maml:para>The relative or absolute path of the application base directory to use during test execution instead of the default.</maml:para>
-          </maml:description>
-          <dev:defaultValue>String.Empty</dev:defaultValue>
-        </command:parameter>
-        
-        <maml:name>Run-Gallio</maml:name>
-        <command:parameter required="true" variableLength="true" globbing="false" pipelineInput="false" position="1">
-          <maml:name>Files</maml:name>
-          <maml:description>
-            <maml:para>The list of comma-separated, relative or absolute paths of test files, projects and assemblies to execute.  Wildcards may be used.</maml:para>
-          </maml:description>
-        </command:parameter>
-        
-        <command:parameter required="false" variableLength="true" globbing="false" pipelineInput="false" position="named">
-          <maml:name>DoNotRun</maml:name>
-          <maml:description>
-            <maml:para>Sets whether to load the tests but not run them. This option may be used to produce a report that contains test metadata for consumption by other tools.</maml:para>
-          </maml:description>
-          <dev:defaultValue>false</dev:defaultValue>
-        </command:parameter>
-
-        <command:parameter required="false" variableLength="true" globbing="false" pipelineInput="false" position="named">
-          <maml:name>Filter</maml:name>
-          <maml:description>
-            <maml:para>
-              Sets the filter set to apply, which consists of a sequence of one or more inclusion
-              or exclusion filter rules prefixed using 'include' (optional) or 'exclude'.
-              A filter rule consists of zero or more filter expressions
-              that may be combined using 'and', 'or', and 'not' and grouped with
-              parentheses.  A filter expression consists of a filter key followed by one or
-              more comma-delimited matching values in the form 'key: value, "quoted value",
-              /regular expression/'.
-            </maml:para>
-          </maml:description>
-          <dev:defaultValue>*</dev:defaultValue>
-        </command:parameter>
-
-        <command:parameter required="false" variableLength="true" globbing="false" pipelineInput="false" position="named">
-          <maml:name>HintDirectories</maml:name>
-          <maml:description>
-            <maml:para>The list of directories used for loading referenced assemblies and other dependent resources.</maml:para>
-          </maml:description>
-        </command:parameter>
-
-        <command:parameter required="false" variableLength="true" globbing="false" pipelineInput="false" position="named">
-          <maml:name>NoEchoResults</maml:name>
-          <maml:description>
-            <maml:para>Sets whether to echo results to the screen as tests finish. If this option is specified only the final summary statistics are displayed. Otherwise test results are echoed to the console in varying detail depending on the current verbosity level.</maml:para>
-          </maml:description>
-          <dev:defaultValue>false</dev:defaultValue>
-        </command:parameter>
-
-        <command:parameter required="false" variableLength="true" globbing="false" pipelineInput="false" position="named">
-          <maml:name>NoProgress</maml:name>
-          <maml:description>
-            <maml:para>Sets whether progress information is shown during the execution. If this option is specified, the execution is silent and no progress information is displayed.</maml:para>
-          </maml:description>
-          <dev:defaultValue>false</dev:defaultValue>
-        </command:parameter>
-        
-        <command:parameter required="false" variableLength="true" globbing="false" pipelineInput="false" position="named">
-          <maml:name>PluginDirectories</maml:name>
-          <maml:description>
-            <maml:para>Additional Gallio plugin directories to search recursively.</maml:para>
-          </maml:description>
-        </command:parameter>
-
-        <command:parameter required="false" variableLength="true" globbing="false" pipelineInput="false" position="named">
-          <maml:name>ReportDirectory</maml:name>
-          <maml:description>
-            <maml:para>Sets the name of the directory where the reports will be put.</maml:para>
-          </maml:description>
-          <dev:defaultValue>"Reports"</dev:defaultValue>
-        </command:parameter>
-
-        <command:parameter required="false" variableLength="true" globbing="false" pipelineInput="false" position="named">
-          <maml:name>ReportNameFormat</maml:name>
-          <maml:description>
-            <maml:para>Sets the format string to use to generate the reports filenames.</maml:para>
-          </maml:description>
-          <dev:defaultValue>test-report-{0}-{1}</dev:defaultValue>
-        </command:parameter>
-
-        <command:parameter required="false" variableLength="true" globbing="false" pipelineInput="false" position="named">
-          <maml:name>ReportArchive</maml:name>
-          <maml:description>
-            <maml:para>Indicates whether to enclose the resulting test report in a compressed archive file.</maml:para>
-          </maml:description>
-          <dev:defaultValue>false</dev:defaultValue>
-        </command:parameter>
-
-        <command:parameter required="false" variableLength="true" globbing="false" pipelineInput="false" position="named">
-          <maml:name>ReportTypes</maml:name>
-          <maml:description>
-            <maml:para>A list of the types of reports to generate, separated by semicolons.</maml:para>
-          </maml:description>
-          <dev:defaultValue>String.Empty</dev:defaultValue>
-        </command:parameter>
-
-        <command:parameter required="false" variableLength="true" globbing="false" pipelineInput="false" position="named">
-          <maml:name>RunnerType</maml:name>
-          <maml:description>
-            <maml:para>Sets the type of test runner to use (LocalAppDomain, IsolatedAppDomain or IsolatedProcess, but more could be available as plugins).</maml:para>
-          </maml:description>
-          <dev:defaultValue>IsolatedProcess</dev:defaultValue>
-        </command:parameter>
-
-        <command:parameter required="false" variableLength="true" globbing="false" pipelineInput="false" position="named">
-          <maml:name>ShadowCopy</maml:name>
-          <maml:description>
-            <maml:para>
-              Enables shadow copying when set to true. Shadow copying allows the original assemblies to be modified while the tests are running. However, shadow copying may occasionally cause some tests to fail if they depend on their original location.
-            </maml:para>
-          </maml:description>
-          <dev:defaultValue>false</dev:defaultValue>
-        </command:parameter>
-
-        <command:parameter required="false" variableLength="true" globbing="false" pipelineInput="false" position="named">
-          <maml:name>DebugTests</maml:name>
-          <maml:description>
-            <maml:para>
-              Attaches the debugger to the test process.
-            </maml:para>
-          </maml:description>
-          <dev:defaultValue>false</dev:defaultValue>
-        </command:parameter>
-
-        <command:parameter required="false" variableLength="true" globbing="false" pipelineInput="false" position="named">
-          <maml:name>ShowReports</maml:name>
-          <maml:description>
-            <maml:para>Sets whether to open the generated reports once execution has finished.</maml:para>
-          </maml:description>
-          <dev:defaultValue>false</dev:defaultValue>
-        </command:parameter>
-
-        <command:parameter required="false" variableLength="true" globbing="false" pipelineInput="false" position="named">
-          <maml:name>WorkingDirectory</maml:name>
-          <maml:description>
-            <maml:para>
-              The relative or absolute path of the working directory to use during test execution instead of the default.
-            </maml:para>
-          </maml:description>
-          <dev:defaultValue>String.Empty</dev:defaultValue>
-        </command:parameter>
-
-        <command:parameter required="false" variableLength="true" globbing="false" pipelineInput="false" position="named">
-          <maml:name>RuntimeVersion</maml:name>
-          <maml:description>
-            <maml:para>The version of the .Net runtime to use for running tests.  For the CLR, this must be the name of one of the framework directories in %SystemRoot%\Microsoft.Net\Framework.  eg. 'v2.0.50727'.  The default is null which uses the most recent installed and supported framework.</maml:para>
-          </maml:description>
-        </command:parameter>
-      </command:syntaxItem>
-    </command:syntax>
-
-    <command:parameters>
-
-      <!-- This section is a copy paste of the syntax parameter. The only difference between both sections
-      is that here the parameters can appear only once, whereas in the syntax section they can appear in
-      different parameter sets. -->
-      
-      <command:parameter required="false" variableLength="true" globbing="false" pipelineInput="false" position="named">
-        <maml:name>ApplicationBaseDirectory</maml:name>
-        <maml:description>
-          <maml:para>The relative or absolute path of the application base directory.</maml:para>
-        </maml:description>
-        <dev:defaultValue>String.Empty</dev:defaultValue>
-      </command:parameter>
-
-      <maml:name>Run-Gallio</maml:name>
-      <command:parameter required="true" variableLength="true" globbing="false" pipelineInput="false" position="1">
-        <maml:name>Files</maml:name>
-        <maml:description>
-          <maml:para>The list of comma-separated, relative or absolute paths of test files, projects and assemblies to execute.  Wildcards may be used.</maml:para>
-        </maml:description>
-      </command:parameter>
-
-      <command:parameter required="false" variableLength="true" globbing="false" pipelineInput="false" position="named">
-        <maml:name>DoNotRun</maml:name>
-        <maml:description>
-          <maml:para>Sets whether to load the tests but not run them. This option may be used to produce a report that contains test metadata for consumption by other tools.</maml:para>
-        </maml:description>
-        <dev:defaultValue>false</dev:defaultValue>
-      </command:parameter>
-
-      <command:parameter required="false" variableLength="true" globbing="false" pipelineInput="false" position="named">
-        <maml:name>Filter</maml:name>
-        <maml:description>
-          <maml:para>
-            Sets the filter set to apply, which consists of a sequence of one or more inclusion
-            or exclusion filter rules prefixed using 'include' (optional) or 'exclude'.
-            A filter rule consists of zero or more filter expressions
-            that may be combined using 'and', 'or', and 'not' and grouped with
-            parentheses.  A filter expression consists of a filter key followed by one or
-            more comma-delimited matching values in the form 'key: value, "quoted value",
-            /regular expression/'.
-          </maml:para>
-        </maml:description>
-        <dev:defaultValue>*</dev:defaultValue>
-      </command:parameter>
-
-      <command:parameter required="false" variableLength="true" globbing="false" pipelineInput="false" position="named">
-        <maml:name>HintDirectories</maml:name>
-        <maml:description>
-          <maml:para>The list of directories used for loading referenced assemblies and other dependent resources.</maml:para>
-        </maml:description>
-      </command:parameter>
-
-      <command:parameter required="false" variableLength="true" globbing="false" pipelineInput="false" position="named">
-        <maml:name>NoEchoResults</maml:name>
-        <maml:description>
-          <maml:para>Sets whether to echo results to the screen as tests finish. If this option is specified only the final summary statistics are displayed. Otherwise test results are echoed to the console in varying detail depending on the current verbosity level.</maml:para>
-        </maml:description>
-        <dev:defaultValue>false</dev:defaultValue>
-      </command:parameter>
-
-      <command:parameter required="false" variableLength="true" globbing="false" pipelineInput="false" position="named">
-        <maml:name>NoProgress</maml:name>
-        <maml:description>
-          <maml:para>Sets whether progress information is shown during the execution. If this option is specified, the execution is silent and no progress information is displayed.</maml:para>
-        </maml:description>
-        <dev:defaultValue>false</dev:defaultValue>
-      </command:parameter>
-      
-      <command:parameter required="false" variableLength="true" globbing="false" pipelineInput="false" position="named">
-        <maml:name>PluginDirectories</maml:name>
-        <maml:description>
-          <maml:para>Additional Gallio plugin directories to search recursively.</maml:para>
-        </maml:description>
-      </command:parameter>
-
-      <command:parameter required="false" variableLength="true" globbing="false" pipelineInput="false" position="named">
-        <maml:name>ReportDirectory</maml:name>
-        <maml:description>
-          <maml:para>Sets the name of the directory where the reports will be put.</maml:para>
-        </maml:description>
-        <dev:defaultValue>"Reports"</dev:defaultValue>
-      </command:parameter>
-
-      <command:parameter required="false" variableLength="true" globbing="false" pipelineInput="false" position="named">
-        <maml:name>ReportNameFormat</maml:name>
-        <maml:description>
-          <maml:para>Sets the format string to use to generate the reports filenames.</maml:para>
-        </maml:description>
-        <dev:defaultValue>test-report-{0}-{1}</dev:defaultValue>
-      </command:parameter>
-
-      <command:parameter required="false" variableLength="true" globbing="false" pipelineInput="false" position="named">
-        <maml:name>ReportArchive</maml:name>
-        <maml:description>
-          <maml:para>Indicates whether to enclose the resulting test report in a compressed archive file.</maml:para>
-        </maml:description>
-        <dev:defaultValue>false</dev:defaultValue>
-      </command:parameter>
-
-      <command:parameter required="false" variableLength="true" globbing="false" pipelineInput="false" position="named">
-        <maml:name>ReportTypes</maml:name>
-        <maml:description>
-          <maml:para>A list of the types of reports to generate, separated by semicolons.</maml:para>
-        </maml:description>
-        <dev:defaultValue>String.Empty</dev:defaultValue>
-      </command:parameter>
-
-      <command:parameter required="false" variableLength="true" globbing="false" pipelineInput="false" position="named">
-        <maml:name>RunnerType</maml:name>
-        <maml:description>
-          <maml:para>Sets the type of test runner to use: Local, IsolatedAppDomain, IsolatedProcess, or others that may be provided by plugins.</maml:para>
-        </maml:description>
-        <dev:defaultValue>IsolatedProcess</dev:defaultValue>
-      </command:parameter>
-
-      <command:parameter required="false" variableLength="true" globbing="false" pipelineInput="false" position="named">
-        <maml:name>RunnerExtensions</maml:name>
-        <maml:description>
-          <maml:para>Specifies the type, assembly, and parameters of custom test runner extensions to use during the test run in the form: '[Namespace.]Type,Assembly[;Parameters].  eg. 'FancyLogger,MyExtensions.dll;ColorOutput,FancyIndenting'</maml:para>
-        </maml:description>
-      </command:parameter>
-      
-      <command:parameter required="false" variableLength="true" globbing="false" pipelineInput="false" position="named">
-        <maml:name>ShadowCopy</maml:name>
-        <maml:description>
-          <maml:para>
-            Enables shadow copying when set to true. Shadow copying allows the original assemblies to be modified while the tests are running. However, shadow copying may occasionally cause some tests to fail if they depend on their original location.
-          </maml:para>
-        </maml:description>
-        <dev:defaultValue>false</dev:defaultValue>
-      </command:parameter>
-
-      <command:parameter required="false" variableLength="true" globbing="false" pipelineInput="false" position="named">
-        <maml:name>DebugTests</maml:name>
-        <maml:description>
-          <maml:para>
-            Attaches the debugger to the test process.
-          </maml:para>
-        </maml:description>
-        <dev:defaultValue>false</dev:defaultValue>
-      </command:parameter>
-
-      <command:parameter required="false" variableLength="true" globbing="false" pipelineInput="false" position="named">
-        <maml:name>ShowReports</maml:name>
-        <maml:description>
-          <maml:para>Sets whether to open the generated reports once execution has finished.</maml:para>
-        </maml:description>
-        <dev:defaultValue>false</dev:defaultValue>
-      </command:parameter>
-
-      <command:parameter required="false" variableLength="true" globbing="false" pipelineInput="false" position="named">
-        <maml:name>WorkingDirectory</maml:name>
-        <maml:description>
-          <maml:para>
-            The relative or absolute path of the working directory. If relative, the path is based on the current working directory, so a value of "" (an empty string) causes the current working directory to be used.
-          </maml:para>
-        </maml:description>
-        <dev:defaultValue>String.Empty</dev:defaultValue>
-      </command:parameter>
-
-      <command:parameter required="false" variableLength="true" globbing="false" pipelineInput="false" position="named">
-        <maml:name>RuntimeVersion</maml:name>
-        <maml:description>
-          <maml:para>The version of the .Net runtime to use for running tests.  For the CLR, this must be the name of one of the framework directories in %SystemRoot%\Microsoft.Net\Framework.  eg. 'v2.0.50727'.  The default is null which uses the most recent installed and supported framework.</maml:para>
-        </maml:description>
-      </command:parameter>
-    </command:parameters>
-
-    <command:examples>
-      <command:example>
-        # Makes the Gallio commands available
-        Add-PSSnapIn Gallio
-        # Runs TestAssembly1.dll
-        Run-Gallio "[Path-to-assembly1]\TestAssembly1.dll","[Path-to-assembly2]\TestAssembly2.dll","[Path-to-test-script1]/TestScript1_spec.rb","[Path-to-test-script2]/TestScript2.xml" -f Category:UnitTests -rd C:\build\reports -rf html -ra
-      </command:example>
-    </command:examples>
-
-  </command:command>
-
-</helpItems>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Gallio.PowerShellCommands.plugin
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Gallio.PowerShellCommands.plugin b/lib/Gallio.3.2.750/tools/Gallio.PowerShellCommands.plugin
deleted file mode 100644
index 971300f..0000000
--- a/lib/Gallio.3.2.750/tools/Gallio.PowerShellCommands.plugin
+++ /dev/null
@@ -1,21 +0,0 @@
-<?xml version="1.0" encoding="utf-8" ?>
-<plugin pluginId="Gallio.PowerShellCommands"
-        recommendedInstallationPath=""
-        xmlns="http://www.gallio.org/">
-  <traits>
-    <name>Gallio PowerShell Commands</name>
-    <version>3.2.0.0</version>
-    <description>Provides PowerShell cmdlets for running tests with Gallio.</description>
-  </traits>
-
-  <dependencies>
-    <dependency pluginId="Gallio" />
-  </dependencies>
-
-  <files>
-    <file path="Gallio.PowerShellCommands.plugin" />
-    <file path="Gallio.PowerShellCommands.dll" />
-    <file path="Gallio.PowerShellCommands.dll-Help.xml" />
-    <file path="Gallio.PowerShellCommands.xml" />
-  </files>
-</plugin>
\ No newline at end of file


[51/51] [abbrv] [partial] git commit: Cleaning up and getting ready to development towards v4.8

Posted by sy...@apache.org.
Cleaning up and getting ready to development towards v4.8


Project: http://git-wip-us.apache.org/repos/asf/lucenenet/repo
Commit: http://git-wip-us.apache.org/repos/asf/lucenenet/commit/1da1cb5b
Tree: http://git-wip-us.apache.org/repos/asf/lucenenet/tree/1da1cb5b
Diff: http://git-wip-us.apache.org/repos/asf/lucenenet/diff/1da1cb5b

Branch: refs/heads/master
Commit: 1da1cb5b54e4c1d6acade9c4b7e8244629a6f275
Parents: a850994
Author: Itamar Syn-Hershko <it...@code972.com>
Authored: Sat Sep 6 22:33:06 2014 +0300
Committer: Itamar Syn-Hershko <it...@code972.com>
Committed: Sat Sep 6 22:33:06 2014 +0300

----------------------------------------------------------------------
 .gitattributes                                  |     22 +
 .gitignore                                      |     49 +-
 ACKNOWLEDGEMENTS.txt                            |      6 +-
 CHANGES.txt                                     |   8021 +-
 LICENSE.txt                                     |     10 +-
 Lucene.Net.sln                                  |     57 +
 Lucene.Net.snk                                  |    Bin 0 -> 596 bytes
 MyGet.bat                                       |     32 +
 NOTICE.txt                                      |      4 +-
 README.txt                                      |     27 +-
 build.cmd                                       |     27 -
 build/scripts/All/Lucene.Net.nuspec             |     41 -
 build/scripts/All/document.targets              |     55 -
 build/scripts/All/project.targets               |     54 -
 build/scripts/Analyzers/document.targets        |     31 -
 build/scripts/Analyzers/project.targets         |     66 -
 build/scripts/Contrib-Core/document.targets     |     31 -
 build/scripts/Contrib-Core/project.targets      |     66 -
 build/scripts/Contrib/Lucene.Net.Contrib.nuspec |     62 -
 build/scripts/Contrib/document.targets          |     51 -
 build/scripts/Contrib/project.targets           |     72 -
 build/scripts/Core/Lucene.Net.Core.nuspec       |     42 -
 build/scripts/Core/document.targets             |     31 -
 build/scripts/Core/project.targets              |     75 -
 build/scripts/CustomDictionary.xml              |     31 -
 .../FastVectorHighlighter/document.targets      |     31 -
 .../FastVectorHighlighter/project.targets       |     66 -
 build/scripts/Highlighter/document.targets      |     31 -
 build/scripts/Highlighter/project.targets       |     65 -
 build/scripts/Memory/document.targets           |     31 -
 build/scripts/Memory/project.targets            |     66 -
 build/scripts/Queries/document.targets          |     31 -
 build/scripts/Queries/project.targets           |     66 -
 build/scripts/Regex/document.targets            |     31 -
 build/scripts/Regex/project.targets             |     66 -
 .../SimpleFacetedSearch/document.targets        |     31 -
 .../scripts/SimpleFacetedSearch/project.targets |     66 -
 build/scripts/Snowball/document.targets         |     31 -
 build/scripts/Snowball/project.targets          |     66 -
 .../Spatial.NTS/Lucene.Net.Spatial.NTS.nuspec   |     43 -
 build/scripts/Spatial.NTS/document.targets      |     31 -
 build/scripts/Spatial.NTS/project.targets       |     66 -
 build/scripts/Spatial/Lucene.Net.Spatial.nuspec |     43 -
 build/scripts/Spatial/document.targets          |     31 -
 build/scripts/Spatial/project.targets           |     66 -
 build/scripts/SpellChecker/document.targets     |     31 -
 build/scripts/SpellChecker/project.targets      |     66 -
 build/scripts/build.cmd                         |     25 -
 build/scripts/build.sh                          |     47 -
 build/scripts/build.targets                     |    160 -
 build/scripts/docs.shfbproj                     |     90 -
 build/scripts/dot-net-tools.targets             |    192 -
 build/scripts/mono-tools.targets                |     46 -
 build/scripts/rules.fxcop                       |    143 -
 build/scripts/rules.stylecop                    |     48 -
 build/scripts/template.shfbproj                 |     93 -
 build/scripts/user.targets                      |     92 -
 build/scripts/validate-tool-chain.ps1           |    304 -
 build/scripts/version.targets                   |     25 -
 build/vs2010/contrib/Contrib.All.sln            |    186 -
 build/vs2010/contrib/Contrib.Analyzers.sln      |     56 -
 build/vs2010/contrib/Contrib.Core.sln           |     56 -
 .../contrib/Contrib.FastVectorHighlighter.sln   |     56 -
 build/vs2010/contrib/Contrib.Highlighter.sln    |     66 -
 build/vs2010/contrib/Contrib.Memory.sln         |     56 -
 build/vs2010/contrib/Contrib.Queries.sln        |     56 -
 build/vs2010/contrib/Contrib.Regex.sln          |     56 -
 .../contrib/Contrib.SimpleFacetedSearch.sln     |     56 -
 build/vs2010/contrib/Contrib.Snowball.sln       |     56 -
 build/vs2010/contrib/Contrib.Spatial.sln        |     66 -
 build/vs2010/contrib/Contrib.SpellChecker.sln   |     56 -
 build/vs2010/contrib/Contrib.WordNet.sln        |     76 -
 build/vs2010/core/Lucene.Net.Core.sln           |     46 -
 build/vs2010/demo/Lucene.Net.Demo.sln           |     96 -
 build/vs2010/test/Contrib.All.Test.sln          |    306 -
 build/vs2010/test/Contrib.Analyzers.Test.sln    |     86 -
 build/vs2010/test/Contrib.Core.Test.sln         |     66 -
 .../test/Contrib.FastVectorHighlighter.Test.sln |     66 -
 build/vs2010/test/Contrib.Highlighter.Test.sln  |    106 -
 build/vs2010/test/Contrib.Memory.Test.sln       |     86 -
 build/vs2010/test/Contrib.Queries.Test.sln      |     86 -
 build/vs2010/test/Contrib.Regex.Test.sln        |     86 -
 .../test/Contrib.SimpleFacetedSearch.Test.sln   |    110 -
 build/vs2010/test/Contrib.Snowball.Test.sln     |     85 -
 build/vs2010/test/Contrib.Spatial.Test.sln      |     86 -
 build/vs2010/test/Contrib.SpellChecker.Test.sln |     66 -
 build/vs2010/test/Lucene.Net.Test.sln           |     66 -
 build/vs2012/contrib/Contrib.All.sln            |    196 -
 build/vs2012/contrib/Contrib.Analyzers.sln      |     56 -
 build/vs2012/contrib/Contrib.Core.sln           |     56 -
 .../contrib/Contrib.FastVectorHighlighter.sln   |     56 -
 build/vs2012/contrib/Contrib.Highlighter.sln    |     66 -
 build/vs2012/contrib/Contrib.Memory.sln         |     56 -
 build/vs2012/contrib/Contrib.Queries.sln        |     56 -
 build/vs2012/contrib/Contrib.Regex.sln          |     56 -
 .../contrib/Contrib.SimpleFacetedSearch.sln     |     56 -
 build/vs2012/contrib/Contrib.Snowball.sln       |     56 -
 build/vs2012/contrib/Contrib.Spatial.sln        |     66 -
 build/vs2012/contrib/Contrib.SpellChecker.sln   |     56 -
 build/vs2012/contrib/Contrib.WordNet.sln        |     76 -
 build/vs2012/core/Lucene.Net.Core.sln           |     46 -
 build/vs2012/demo/Lucene.Net.Demo.sln           |     96 -
 build/vs2012/test/Contrib.All.Test.sln          |    296 -
 build/vs2012/test/Contrib.Analyzers.Test.sln    |     86 -
 build/vs2012/test/Contrib.Core.Test.sln         |     66 -
 .../test/Contrib.FastVectorHighlighter.Test.sln |     66 -
 build/vs2012/test/Contrib.Highlighter.Test.sln  |    106 -
 build/vs2012/test/Contrib.Memory.Test.sln       |     86 -
 build/vs2012/test/Contrib.Queries.Test.sln      |     86 -
 build/vs2012/test/Contrib.Regex.Test.sln        |     86 -
 .../test/Contrib.SimpleFacetedSearch.Test.sln   |    110 -
 build/vs2012/test/Contrib.Snowball.Test.sln     |     86 -
 build/vs2012/test/Contrib.Spatial.Test.sln      |     76 -
 build/vs2012/test/Contrib.SpellChecker.Test.sln |     66 -
 build/vs2012/test/Lucene.Net.Test.sln           |     66 -
 lib/Gallio.3.2.750/Gallio License.txt           |     14 -
 .../licenses/CciMetadata.License.txt            |     31 -
 .../licenses/Cecil.FlowAnalysis.license.html    |     37 -
 .../licenses/ICSharpCode.TextEditor.License.txt |    458 -
 .../licenses/Mono.Cecil.license.html            |     36 -
 .../licenses/Mono.GetOptions.license.html       |     38 -
 .../WeifenLuo.WinFormsUI.Docking.License.txt    |      9 -
 lib/Gallio.3.2.750/licenses/db4o.license.html   |    384 -
 .../licenses/objectarx_license.doc              |    Bin 26624 -> 0 bytes
 lib/Gallio.3.2.750/tools/Aga.Controls.dll       |    Bin 147456 -> 0 bytes
 .../tools/Gallio.Ambience.Server.exe            |    Bin 12288 -> 0 bytes
 .../tools/Gallio.Ambience.Server.exe.config     |     19 -
 lib/Gallio.3.2.750/tools/Gallio.Ambience.UI.dll |    Bin 9216 -> 0 bytes
 .../tools/Gallio.Ambience.UI.plugin             |     46 -
 lib/Gallio.3.2.750/tools/Gallio.Ambience.dll    |    Bin 1227264 -> 0 bytes
 lib/Gallio.3.2.750/tools/Gallio.Ambience.pdb    |    Bin 493056 -> 0 bytes
 lib/Gallio.3.2.750/tools/Gallio.Ambience.plugin |     30 -
 lib/Gallio.3.2.750/tools/Gallio.Ambience.xml    |    511 -
 .../tools/Gallio.Common.Splash.dll              |    Bin 66048 -> 0 bytes
 .../tools/Gallio.Common.Splash.xml              |   1346 -
 .../tools/Gallio.ControlPanel.exe               |    Bin 91136 -> 0 bytes
 .../tools/Gallio.ControlPanel.exe.config        |     18 -
 .../tools/Gallio.ControlPanel.plugin            |     18 -
 lib/Gallio.3.2.750/tools/Gallio.Copy.exe        |    Bin 115712 -> 0 bytes
 lib/Gallio.3.2.750/tools/Gallio.Copy.exe.config |     30 -
 lib/Gallio.3.2.750/tools/Gallio.Copy.plugin     |     24 -
 lib/Gallio.3.2.750/tools/Gallio.Echo.exe        |    Bin 145408 -> 0 bytes
 lib/Gallio.3.2.750/tools/Gallio.Echo.exe.config |     29 -
 lib/Gallio.3.2.750/tools/Gallio.Echo.plugin     |     18 -
 .../tools/Gallio.Host.Elevated.exe              |    Bin 15872 -> 0 bytes
 .../tools/Gallio.Host.Elevated.exe.config       |     26 -
 .../tools/Gallio.Host.Elevated.x86.exe          |    Bin 15872 -> 0 bytes
 .../tools/Gallio.Host.Elevated.x86.exe.config   |     26 -
 lib/Gallio.3.2.750/tools/Gallio.Host.exe        |    Bin 15872 -> 0 bytes
 lib/Gallio.3.2.750/tools/Gallio.Host.exe.config |     26 -
 lib/Gallio.3.2.750/tools/Gallio.Host.x86.exe    |    Bin 15872 -> 0 bytes
 .../tools/Gallio.Host.x86.exe.config            |     26 -
 .../tools/Gallio.Icarus.XmlSerializers.dll      |    Bin 36864 -> 0 bytes
 lib/Gallio.3.2.750/tools/Gallio.Icarus.exe      |    Bin 882176 -> 0 bytes
 .../tools/Gallio.Icarus.exe.config              |     31 -
 lib/Gallio.3.2.750/tools/Gallio.Icarus.plugin   |    177 -
 .../tools/Gallio.MSBuildTasks.dll               |    Bin 20480 -> 0 bytes
 .../tools/Gallio.MSBuildTasks.plugin            |     20 -
 .../tools/Gallio.MSBuildTasks.xml               |    818 -
 .../tools/Gallio.Navigator.Readme.txt           |     24 -
 lib/Gallio.3.2.750/tools/Gallio.Navigator.exe   |    Bin 117248 -> 0 bytes
 .../tools/Gallio.Navigator.exe.config           |      7 -
 .../tools/Gallio.Navigator.plugin               |     22 -
 .../tools/Gallio.PowerShellCommands.dll         |    Bin 23040 -> 0 bytes
 .../Gallio.PowerShellCommands.dll-Help.xml      |    404 -
 .../tools/Gallio.PowerShellCommands.plugin      |     21 -
 .../tools/Gallio.PowerShellCommands.xml         |    660 -
 lib/Gallio.3.2.750/tools/Gallio.Reports.dll     |    Bin 17408 -> 0 bytes
 lib/Gallio.3.2.750/tools/Gallio.Reports.plugin  |    241 -
 lib/Gallio.3.2.750/tools/Gallio.Reports.xml     |    229 -
 lib/Gallio.3.2.750/tools/Gallio.UI.dll          |    Bin 262144 -> 0 bytes
 lib/Gallio.3.2.750/tools/Gallio.UI.plugin       |    127 -
 lib/Gallio.3.2.750/tools/Gallio.UI.xml          |   1373 -
 lib/Gallio.3.2.750/tools/Gallio.Utility.exe     |    Bin 73216 -> 0 bytes
 .../tools/Gallio.Utility.exe.config             |     26 -
 lib/Gallio.3.2.750/tools/Gallio.Utility.plugin  |     18 -
 .../tools/Gallio.VisualStudio.Interop.dll       |    Bin 24064 -> 0 bytes
 .../tools/Gallio.VisualStudio.Interop.plugin    |     28 -
 .../tools/Gallio.XmlSerializers.dll             |    Bin 110592 -> 0 bytes
 lib/Gallio.3.2.750/tools/Gallio.dll             |    Bin 2839040 -> 0 bytes
 lib/Gallio.3.2.750/tools/Gallio.pdb             |    Bin 4232704 -> 0 bytes
 lib/Gallio.3.2.750/tools/Gallio.plugin          |    658 -
 lib/Gallio.3.2.750/tools/Gallio.xml             |  44449 ------
 lib/Gallio.3.2.750/tools/Gallio35.dll           |    Bin 26624 -> 0 bytes
 lib/Gallio.3.2.750/tools/Gallio35.pdb           |    Bin 62976 -> 0 bytes
 lib/Gallio.3.2.750/tools/Gallio35.plugin        |     35 -
 lib/Gallio.3.2.750/tools/Gallio35.xml           |    293 -
 lib/Gallio.3.2.750/tools/Gallio40.dll           |    Bin 36352 -> 0 bytes
 lib/Gallio.3.2.750/tools/Gallio40.pdb           |    Bin 132608 -> 0 bytes
 lib/Gallio.3.2.750/tools/Gallio40.plugin        |     29 -
 lib/Gallio.3.2.750/tools/Gallio40.xml           |      8 -
 .../tools/ICSharpCode.TextEditor.dll            |    Bin 352256 -> 0 bytes
 .../tools/MbUnit.Compatibility.dll              |    Bin 59904 -> 0 bytes
 .../tools/MbUnit.Compatibility.pdb              |    Bin 220672 -> 0 bytes
 .../tools/MbUnit.Compatibility.plugin           |     28 -
 .../tools/MbUnit.Compatibility.xml              |   3419 -
 lib/Gallio.3.2.750/tools/MbUnit.dll             |    Bin 339968 -> 0 bytes
 lib/Gallio.3.2.750/tools/MbUnit.dll.tdnet       |      6 -
 lib/Gallio.3.2.750/tools/MbUnit.pdb             |    Bin 865792 -> 0 bytes
 lib/Gallio.3.2.750/tools/MbUnit.plugin          |     56 -
 lib/Gallio.3.2.750/tools/MbUnit.xml             |  12247 --
 lib/Gallio.3.2.750/tools/MbUnit35.dll           |    Bin 5632 -> 0 bytes
 lib/Gallio.3.2.750/tools/MbUnit35.pdb           |    Bin 11776 -> 0 bytes
 lib/Gallio.3.2.750/tools/MbUnit35.plugin        |     30 -
 lib/Gallio.3.2.750/tools/MbUnit35.xml           |     47 -
 lib/Gallio.3.2.750/tools/MbUnit40.dll           |    Bin 5120 -> 0 bytes
 lib/Gallio.3.2.750/tools/MbUnit40.pdb           |    Bin 7680 -> 0 bytes
 lib/Gallio.3.2.750/tools/MbUnit40.plugin        |     30 -
 lib/Gallio.3.2.750/tools/MbUnit40.xml           |      8 -
 .../tools/NCover/Gallio.NCoverIntegration.dll   |    Bin 17408 -> 0 bytes
 .../NCover/Gallio.NCoverIntegration.plugin      |    143 -
 .../tools/NCover/Resources/ncover.ico           |    Bin 1470 -> 0 bytes
 lib/Gallio.3.2.750/tools/NCover3.lic            |      0
 lib/Gallio.3.2.750/tools/NHamcrest.dll          |    Bin 23040 -> 0 bytes
 lib/Gallio.3.2.750/tools/NHamcrest.pdb          |    Bin 128512 -> 0 bytes
 .../NUnit/Latest/Gallio.NUnitAdapterLatest.dll  |    Bin 24576 -> 0 bytes
 .../Latest/Gallio.NUnitAdapterLatest.plugin     |     85 -
 .../tools/NUnit/Latest/Readme.txt               |     12 -
 .../tools/NUnit/Latest/Resources/NUnit.ico      |    Bin 1078 -> 0 bytes
 .../NUnit/Latest/addins/NUnit Addins Readme.txt |      1 -
 .../tools/NUnit/Latest/license.txt              |     15 -
 .../tools/NUnit/Latest/nunit.core.dll           |    Bin 139264 -> 0 bytes
 .../NUnit/Latest/nunit.core.interfaces.dll      |    Bin 57344 -> 0 bytes
 .../tools/NUnit/Latest/nunit.framework.dll      |    Bin 135168 -> 0 bytes
 .../NUnit/Latest/nunit.framework.dll.tdnet      |      6 -
 .../tools/NUnit/Latest/nunit.framework.xml      |  10385 --
 .../tools/NUnit/Latest/nunit.mocks.dll          |    Bin 20480 -> 0 bytes
 .../tools/NUnit/Latest/nunit.util.dll           |    Bin 126976 -> 0 bytes
 lib/Gallio.3.2.750/tools/Resources/Assembly.ico |    Bin 1150 -> 0 bytes
 .../tools/Resources/Container.ico               |    Bin 1150 -> 0 bytes
 lib/Gallio.3.2.750/tools/Resources/Fixture.ico  |    Bin 1150 -> 0 bytes
 .../tools/Resources/Gallio.ControlPanel.ico     |    Bin 80989 -> 0 bytes
 .../tools/Resources/Gallio.Copy.ico             |    Bin 37611 -> 0 bytes
 .../tools/Resources/Gallio.Echo.ico             |    Bin 59899 -> 0 bytes
 .../tools/Resources/Gallio.Icarus.ico           |    Bin 80989 -> 0 bytes
 .../tools/Resources/Gallio.Utility.ico          |    Bin 59899 -> 0 bytes
 lib/Gallio.3.2.750/tools/Resources/Gallio.ico   |    Bin 80989 -> 0 bytes
 lib/Gallio.3.2.750/tools/Resources/MbUnit.ico   |    Bin 90126 -> 0 bytes
 lib/Gallio.3.2.750/tools/Resources/Test.ico     |    Bin 1150 -> 0 bytes
 .../tools/Resources/Unsupported.ico             |    Bin 1150 -> 0 bytes
 .../tools/Resources/css/Gallio-Report.css       |    527 -
 .../tools/Resources/img/Failed.gif              |    Bin 129 -> 0 bytes
 .../tools/Resources/img/FullStop.gif            |    Bin 86 -> 0 bytes
 .../Resources/img/GallioTestReportHeader.png    |    Bin 7509 -> 0 bytes
 .../tools/Resources/img/Ignored.gif             |    Bin 193 -> 0 bytes
 .../tools/Resources/img/Minus.gif               |    Bin 88 -> 0 bytes
 .../tools/Resources/img/Passed.gif              |    Bin 293 -> 0 bytes
 lib/Gallio.3.2.750/tools/Resources/img/Plus.gif |    Bin 88 -> 0 bytes
 .../tools/Resources/img/UnknownTestKind.png     |    Bin 155 -> 0 bytes
 .../tools/Resources/img/header-background.gif   |    Bin 1414 -> 0 bytes
 .../tools/Resources/js/Gallio-Report.js         |    244 -
 .../tools/Resources/js/expressInstall.swf       |    Bin 727 -> 0 bytes
 .../tools/Resources/js/player.swf               |    Bin 51647 -> 0 bytes
 .../tools/Resources/js/swfobject.js             |      4 -
 .../Gallio-Report.ccnet-details-condensed.xsl   |     20 -
 .../xsl/Gallio-Report.ccnet-details.xsl         |     20 -
 .../Resources/xsl/Gallio-Report.common.xsl      |    356 -
 .../Resources/xsl/Gallio-Report.html+xhtml.xsl  |   1060 -
 .../xsl/Gallio-Report.html-condensed.xsl        |     21 -
 .../tools/Resources/xsl/Gallio-Report.html.xsl  |     21 -
 .../Resources/xsl/Gallio-Report.txt-common.xsl  |    228 -
 .../xsl/Gallio-Report.txt-condensed.xsl         |     12 -
 .../tools/Resources/xsl/Gallio-Report.txt.xsl   |     12 -
 .../xsl/Gallio-Report.xhtml-condensed.xsl       |     22 -
 .../tools/Resources/xsl/Gallio-Report.xhtml.xsl |     22 -
 .../tools/TDNet/Gallio.TDNetRunner.UI.dll       |    Bin 22016 -> 0 bytes
 .../tools/TDNet/Gallio.TDNetRunner.UI.plugin    |     57 -
 .../tools/TDNet/Gallio.TDNetRunner.dll          |    Bin 61440 -> 0 bytes
 .../tools/TDNet/Gallio.TDNetRunner.plugin       |     46 -
 .../tools/TDNet/Resources/TestDriven.ico        |    Bin 9158 -> 0 bytes
 .../VisualStudio/Gallio.VisualStudio.Shell.dll  |    Bin 12288 -> 0 bytes
 .../Gallio.VisualStudio.Shell.plugin            |     43 -
 .../v10.0/Gallio.VisualStudio.Shell100.addin    |     16 -
 .../v10.0/Gallio.VisualStudio.Shell100.dll      |    Bin 165376 -> 0 bytes
 .../v10.0/Gallio.VisualStudio.Shell100.plugin   |     49 -
 .../v10.0/Gallio.VisualStudio.Tip100.Proxy.dll  |    Bin 116224 -> 0 bytes
 .../v10.0/Gallio.VisualStudio.Tip100.dll        |    Bin 45056 -> 0 bytes
 .../v10.0/Gallio.VisualStudio.Tip100.plugin     |     51 -
 .../v9.0/Gallio.VisualStudio.Shell90.addin      |     16 -
 .../v9.0/Gallio.VisualStudio.Shell90.dll        |    Bin 164864 -> 0 bytes
 .../v9.0/Gallio.VisualStudio.Shell90.plugin     |     49 -
 .../v9.0/Gallio.VisualStudio.Tip90.Proxy.dll    |    Bin 116224 -> 0 bytes
 .../v9.0/Gallio.VisualStudio.Tip90.dll          |    Bin 41984 -> 0 bytes
 .../v9.0/Gallio.VisualStudio.Tip90.plugin       |     51 -
 .../tools/WeifenLuo.WinFormsUI.Docking.dll      |    Bin 422400 -> 0 bytes
 .../0.85/ICSharpCode.SharpZipLib.dll            |    Bin 192512 -> 0 bytes
 lib/Lucene.Net.snk                              |    Bin 596 -> 0 bytes
 lib/NUnit.org/NUnit/2.5.9/Logo.ico              |    Bin 1078 -> 0 bytes
 lib/NUnit.org/NUnit/2.5.9/NUnitFitTests.html    |    277 -
 .../NUnit/2.5.9/bin/net-1.1/NUnitFitTests.html  |    277 -
 .../NUnit/2.5.9/bin/net-1.1/NUnitTests.config   |     85 -
 .../NUnit/2.5.9/bin/net-1.1/NUnitTests.nunit    |     11 -
 .../NUnit/2.5.9/bin/net-1.1/agent.conf          |      4 -
 .../NUnit/2.5.9/bin/net-1.1/agent.log.conf      |     18 -
 .../bin/net-1.1/framework/nunit.framework.dll   |    Bin 131072 -> 0 bytes
 .../bin/net-1.1/framework/nunit.framework.xml   |   9832 --
 .../2.5.9/bin/net-1.1/framework/nunit.mocks.dll |    Bin 10752 -> 0 bytes
 .../bin/net-1.1/framework/pnunit.framework.dll  |    Bin 6656 -> 0 bytes
 .../NUnit/2.5.9/bin/net-1.1/launcher.log.conf   |     18 -
 .../NUnit/2.5.9/bin/net-1.1/lib/fit.dll         |    Bin 49152 -> 0 bytes
 .../NUnit/2.5.9/bin/net-1.1/lib/log4net.dll     |    Bin 258048 -> 0 bytes
 .../bin/net-1.1/lib/nunit-console-runner.dll    |    Bin 32768 -> 0 bytes
 .../NUnit/2.5.9/bin/net-1.1/lib/nunit.core.dll  |    Bin 131072 -> 0 bytes
 .../bin/net-1.1/lib/nunit.core.interfaces.dll   |    Bin 57344 -> 0 bytes
 .../2.5.9/bin/net-1.1/lib/nunit.fixtures.dll    |    Bin 9728 -> 0 bytes
 .../NUnit/2.5.9/bin/net-1.1/lib/nunit.util.dll  |    Bin 126976 -> 0 bytes
 .../NUnit/2.5.9/bin/net-1.1/nunit-agent.exe     |    Bin 7168 -> 0 bytes
 .../2.5.9/bin/net-1.1/nunit-agent.exe.config    |     69 -
 .../NUnit/2.5.9/bin/net-1.1/nunit-console.exe   |    Bin 4608 -> 0 bytes
 .../2.5.9/bin/net-1.1/nunit-console.exe.config  |     69 -
 .../NUnit/2.5.9/bin/net-1.1/nunit.framework.dll |    Bin 131072 -> 0 bytes
 .../NUnit/2.5.9/bin/net-1.1/pnunit-agent.exe    |    Bin 13824 -> 0 bytes
 .../2.5.9/bin/net-1.1/pnunit-agent.exe.config   |     77 -
 .../NUnit/2.5.9/bin/net-1.1/pnunit-launcher.exe |    Bin 24576 -> 0 bytes
 .../bin/net-1.1/pnunit-launcher.exe.config      |     77 -
 .../2.5.9/bin/net-1.1/pnunit.framework.dll      |    Bin 6656 -> 0 bytes
 .../NUnit/2.5.9/bin/net-1.1/pnunit.tests.dll    |    Bin 4608 -> 0 bytes
 .../NUnit/2.5.9/bin/net-1.1/runFile.exe         |    Bin 3072 -> 0 bytes
 .../NUnit/2.5.9/bin/net-1.1/runFile.exe.config  |     43 -
 .../NUnit/2.5.9/bin/net-1.1/runpnunit.bat       |      2 -
 lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/test.conf |     24 -
 .../bin/net-1.1/tests/loadtest-assembly.dll     |    Bin 53248 -> 0 bytes
 .../2.5.9/bin/net-1.1/tests/mock-assembly.dll   |    Bin 9216 -> 0 bytes
 .../bin/net-1.1/tests/nonamespace-assembly.dll  |    Bin 4608 -> 0 bytes
 .../bin/net-1.1/tests/nunit-console.tests.dll   |    Bin 24576 -> 0 bytes
 .../bin/net-1.1/tests/nunit.core.tests.dll      |    Bin 176128 -> 0 bytes
 .../bin/net-1.1/tests/nunit.fixtures.tests.dll  |    Bin 8192 -> 0 bytes
 .../2.5.9/bin/net-1.1/tests/nunit.framework.dll |    Bin 131072 -> 0 bytes
 .../bin/net-1.1/tests/nunit.framework.tests.dll |    Bin 335872 -> 0 bytes
 .../bin/net-1.1/tests/nunit.mocks.tests.dll     |    Bin 24576 -> 0 bytes
 .../bin/net-1.1/tests/nunit.util.tests.dll      |    Bin 180224 -> 0 bytes
 .../2.5.9/bin/net-1.1/tests/test-assembly.dll   |    Bin 57344 -> 0 bytes
 .../2.5.9/bin/net-1.1/tests/test-utilities.dll  |    Bin 24576 -> 0 bytes
 .../2.5.9/bin/net-1.1/tests/timing-tests.dll    |    Bin 6656 -> 0 bytes
 .../NUnit/2.5.9/bin/net-2.0/NUnitFitTests.html  |    277 -
 .../NUnit/2.5.9/bin/net-2.0/NUnitTests.config   |     85 -
 .../NUnit/2.5.9/bin/net-2.0/NUnitTests.nunit    |     14 -
 .../NUnit/2.5.9/bin/net-2.0/agent.conf          |      4 -
 .../NUnit/2.5.9/bin/net-2.0/agent.log.conf      |     18 -
 .../bin/net-2.0/framework/nunit.framework.dll   |    Bin 135168 -> 0 bytes
 .../bin/net-2.0/framework/nunit.framework.xml   |  10385 --
 .../2.5.9/bin/net-2.0/framework/nunit.mocks.dll |    Bin 20480 -> 0 bytes
 .../bin/net-2.0/framework/pnunit.framework.dll  |    Bin 6656 -> 0 bytes
 .../NUnit/2.5.9/bin/net-2.0/launcher.log.conf   |     18 -
 .../NUnit/2.5.9/bin/net-2.0/lib/Failure.png     |    Bin 1445 -> 0 bytes
 .../NUnit/2.5.9/bin/net-2.0/lib/Ignored.png     |    Bin 1444 -> 0 bytes
 .../2.5.9/bin/net-2.0/lib/Inconclusive.png      |    Bin 1436 -> 0 bytes
 .../NUnit/2.5.9/bin/net-2.0/lib/Skipped.png     |    Bin 1405 -> 0 bytes
 .../NUnit/2.5.9/bin/net-2.0/lib/Success.png     |    Bin 1439 -> 0 bytes
 .../NUnit/2.5.9/bin/net-2.0/lib/fit.dll         |    Bin 49152 -> 0 bytes
 .../NUnit/2.5.9/bin/net-2.0/lib/log4net.dll     |    Bin 258048 -> 0 bytes
 .../bin/net-2.0/lib/nunit-console-runner.dll    |    Bin 32768 -> 0 bytes
 .../2.5.9/bin/net-2.0/lib/nunit-gui-runner.dll  |    Bin 188416 -> 0 bytes
 .../NUnit/2.5.9/bin/net-2.0/lib/nunit.core.dll  |    Bin 139264 -> 0 bytes
 .../bin/net-2.0/lib/nunit.core.interfaces.dll   |    Bin 57344 -> 0 bytes
 .../2.5.9/bin/net-2.0/lib/nunit.fixtures.dll    |    Bin 9728 -> 0 bytes
 .../2.5.9/bin/net-2.0/lib/nunit.uiexception.dll |    Bin 90112 -> 0 bytes
 .../NUnit/2.5.9/bin/net-2.0/lib/nunit.uikit.dll |    Bin 258048 -> 0 bytes
 .../NUnit/2.5.9/bin/net-2.0/lib/nunit.util.dll  |    Bin 126976 -> 0 bytes
 .../NUnit/2.5.9/bin/net-2.0/nunit-agent-x86.exe |    Bin 7680 -> 0 bytes
 .../bin/net-2.0/nunit-agent-x86.exe.config      |     69 -
 .../NUnit/2.5.9/bin/net-2.0/nunit-agent.exe     |    Bin 7680 -> 0 bytes
 .../2.5.9/bin/net-2.0/nunit-agent.exe.config    |     69 -
 .../2.5.9/bin/net-2.0/nunit-console-x86.exe     |    Bin 4608 -> 0 bytes
 .../bin/net-2.0/nunit-console-x86.exe.config    |     69 -
 .../NUnit/2.5.9/bin/net-2.0/nunit-console.exe   |    Bin 4608 -> 0 bytes
 .../2.5.9/bin/net-2.0/nunit-console.exe.config  |     69 -
 .../NUnit/2.5.9/bin/net-2.0/nunit-x86.exe       |    Bin 5632 -> 0 bytes
 .../2.5.9/bin/net-2.0/nunit-x86.exe.config      |     83 -
 lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/nunit.exe |    Bin 5632 -> 0 bytes
 .../NUnit/2.5.9/bin/net-2.0/nunit.exe.config    |     83 -
 .../NUnit/2.5.9/bin/net-2.0/nunit.framework.dll |    Bin 135168 -> 0 bytes
 .../NUnit/2.5.9/bin/net-2.0/pnunit-agent.exe    |    Bin 13824 -> 0 bytes
 .../2.5.9/bin/net-2.0/pnunit-agent.exe.config   |     77 -
 .../NUnit/2.5.9/bin/net-2.0/pnunit-launcher.exe |    Bin 24576 -> 0 bytes
 .../bin/net-2.0/pnunit-launcher.exe.config      |     77 -
 .../2.5.9/bin/net-2.0/pnunit.framework.dll      |    Bin 6656 -> 0 bytes
 .../NUnit/2.5.9/bin/net-2.0/pnunit.tests.dll    |    Bin 4608 -> 0 bytes
 .../NUnit/2.5.9/bin/net-2.0/runFile.exe         |    Bin 3072 -> 0 bytes
 .../NUnit/2.5.9/bin/net-2.0/runFile.exe.config  |     43 -
 .../NUnit/2.5.9/bin/net-2.0/runpnunit.bat       |      2 -
 lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/test.conf |     24 -
 .../bin/net-2.0/tests/loadtest-assembly.dll     |    Bin 40960 -> 0 bytes
 .../2.5.9/bin/net-2.0/tests/mock-assembly.dll   |    Bin 8704 -> 0 bytes
 .../bin/net-2.0/tests/nonamespace-assembly.dll  |    Bin 4608 -> 0 bytes
 .../bin/net-2.0/tests/nunit-console.tests.dll   |    Bin 24576 -> 0 bytes
 .../2.5.9/bin/net-2.0/tests/nunit-gui.tests.dll |    Bin 8704 -> 0 bytes
 .../bin/net-2.0/tests/nunit.core.tests.dll      |    Bin 188416 -> 0 bytes
 .../bin/net-2.0/tests/nunit.fixtures.tests.dll  |    Bin 8192 -> 0 bytes
 .../2.5.9/bin/net-2.0/tests/nunit.framework.dll |    Bin 135168 -> 0 bytes
 .../bin/net-2.0/tests/nunit.framework.tests.dll |    Bin 348160 -> 0 bytes
 .../bin/net-2.0/tests/nunit.mocks.tests.dll     |    Bin 24576 -> 0 bytes
 .../net-2.0/tests/nunit.uiexception.tests.dll   |    Bin 126976 -> 0 bytes
 .../bin/net-2.0/tests/nunit.uikit.tests.dll     |    Bin 36864 -> 0 bytes
 .../bin/net-2.0/tests/nunit.util.tests.dll      |    Bin 180224 -> 0 bytes
 .../2.5.9/bin/net-2.0/tests/test-assembly.dll   |    Bin 57344 -> 0 bytes
 .../2.5.9/bin/net-2.0/tests/test-utilities.dll  |    Bin 24576 -> 0 bytes
 .../2.5.9/bin/net-2.0/tests/timing-tests.dll    |    Bin 6656 -> 0 bytes
 lib/NUnit.org/NUnit/2.5.9/doc/addinsDialog.html |    109 -
 .../NUnit/2.5.9/doc/assemblyIsolation.html      |    112 -
 lib/NUnit.org/NUnit/2.5.9/doc/assertions.html   |    105 -
 lib/NUnit.org/NUnit/2.5.9/doc/attributes.html   |    107 -
 lib/NUnit.org/NUnit/2.5.9/doc/category.html     |    283 -
 lib/NUnit.org/NUnit/2.5.9/doc/codeFuncs.js      |     77 -
 .../NUnit/2.5.9/doc/collectionAssert.html       |    176 -
 .../NUnit/2.5.9/doc/collectionConstraints.html  |    333 -
 .../NUnit/2.5.9/doc/combinatorial.html          |    125 -
 .../NUnit/2.5.9/doc/comparisonAsserts.html      |    269 -
 .../NUnit/2.5.9/doc/comparisonConstraints.html  |    239 -
 .../NUnit/2.5.9/doc/compoundConstraints.html    |     96 -
 .../NUnit/2.5.9/doc/conditionAsserts.html       |    142 -
 .../NUnit/2.5.9/doc/conditionConstraints.html   |    213 -
 lib/NUnit.org/NUnit/2.5.9/doc/configEditor.html |    103 -
 lib/NUnit.org/NUnit/2.5.9/doc/configFiles.html  |    159 -
 .../NUnit/2.5.9/doc/consoleCommandLine.html     |    314 -
 .../NUnit/2.5.9/doc/constraintModel.html        |    167 -
 lib/NUnit.org/NUnit/2.5.9/doc/contextMenu.html  |    116 -
 lib/NUnit.org/NUnit/2.5.9/doc/culture.html      |    273 -
 .../NUnit/2.5.9/doc/customConstraints.html      |    112 -
 lib/NUnit.org/NUnit/2.5.9/doc/datapoint.html    |    142 -
 .../NUnit/2.5.9/doc/datapointProviders.html     |    124 -
 .../NUnit/2.5.9/doc/delayedConstraint.html      |     94 -
 lib/NUnit.org/NUnit/2.5.9/doc/description.html  |    196 -
 .../NUnit/2.5.9/doc/directoryAssert.html        |    168 -
 .../NUnit/2.5.9/doc/equalConstraint.html        |    275 -
 .../NUnit/2.5.9/doc/equalityAsserts.html        |    185 -
 .../NUnit/2.5.9/doc/eventListeners.html         |    105 -
 lib/NUnit.org/NUnit/2.5.9/doc/exception.html    |    316 -
 .../NUnit/2.5.9/doc/exceptionAsserts.html       |    234 -
 lib/NUnit.org/NUnit/2.5.9/doc/explicit.html     |    274 -
 .../NUnit/2.5.9/doc/extensibility.html          |     78 -
 .../NUnit/2.5.9/doc/extensionTips.html          |     95 -
 lib/NUnit.org/NUnit/2.5.9/doc/favicon.ico       |    Bin 766 -> 0 bytes
 lib/NUnit.org/NUnit/2.5.9/doc/fileAssert.html   |    112 -
 .../2.5.9/doc/files/QuickStart.Spanish.doc      |    Bin 39936 -> 0 bytes
 .../NUnit/2.5.9/doc/files/QuickStart.doc        |    Bin 37376 -> 0 bytes
 lib/NUnit.org/NUnit/2.5.9/doc/files/Results.xsd |     70 -
 .../NUnit/2.5.9/doc/files/Summary.xslt          |     47 -
 .../NUnit/2.5.9/doc/files/TestResult.xml        |    135 -
 lib/NUnit.org/NUnit/2.5.9/doc/fixtureSetup.html |    238 -
 .../NUnit/2.5.9/doc/fixtureTeardown.html        |    238 -
 lib/NUnit.org/NUnit/2.5.9/doc/getStarted.html   |     80 -
 .../NUnit/2.5.9/doc/guiCommandLine.html         |    193 -
 .../NUnit/2.5.9/doc/identityAsserts.html        |     97 -
 lib/NUnit.org/NUnit/2.5.9/doc/ignore.html       |    267 -
 .../NUnit/2.5.9/doc/img/addinsDialog.jpg        |    Bin 17912 -> 0 bytes
 .../NUnit/2.5.9/doc/img/advancedSettings.jpg    |    Bin 18568 -> 0 bytes
 .../NUnit/2.5.9/doc/img/assembliesTab.jpg       |    Bin 37489 -> 0 bytes
 .../2.5.9/doc/img/assemblyReloadSettings.jpg    |    Bin 18024 -> 0 bytes
 lib/NUnit.org/NUnit/2.5.9/doc/img/bulletOff.gif |    Bin 73 -> 0 bytes
 lib/NUnit.org/NUnit/2.5.9/doc/img/bulletOn.gif  |    Bin 73 -> 0 bytes
 .../NUnit/2.5.9/doc/img/configEditor.jpg        |    Bin 11372 -> 0 bytes
 .../NUnit/2.5.9/doc/img/console-mock.jpg        |    Bin 67818 -> 0 bytes
 .../NUnit/2.5.9/doc/img/generalSettings.jpg     |    Bin 20514 -> 0 bytes
 .../NUnit/2.5.9/doc/img/generalTab.jpg          |    Bin 40480 -> 0 bytes
 .../NUnit/2.5.9/doc/img/gui-screenshot.jpg      |    Bin 64879 -> 0 bytes
 .../NUnit/2.5.9/doc/img/gui-verify.jpg          |    Bin 67096 -> 0 bytes
 .../2.5.9/doc/img/internalTraceSettings.jpg     |    Bin 20451 -> 0 bytes
 .../NUnit/2.5.9/doc/img/langFilter.gif          |    Bin 863 -> 0 bytes
 lib/NUnit.org/NUnit/2.5.9/doc/img/logo.gif      |    Bin 1467 -> 0 bytes
 lib/NUnit.org/NUnit/2.5.9/doc/img/miniGui.jpg   |    Bin 133413 -> 0 bytes
 .../NUnit/2.5.9/doc/img/testLoadSettings.jpg    |    Bin 22480 -> 0 bytes
 .../NUnit/2.5.9/doc/img/testOutputSettings.jpg  |    Bin 38632 -> 0 bytes
 .../NUnit/2.5.9/doc/img/testProperties.jpg      |    Bin 37348 -> 0 bytes
 .../NUnit/2.5.9/doc/img/testResultSettings.jpg  |    Bin 18880 -> 0 bytes
 .../NUnit/2.5.9/doc/img/textOutputSettings.jpg  |    Bin 22218 -> 0 bytes
 .../NUnit/2.5.9/doc/img/treeDisplaySettings.jpg |    Bin 20694 -> 0 bytes
 .../2.5.9/doc/img/visualStudioSettings.jpg      |    Bin 16326 -> 0 bytes
 lib/NUnit.org/NUnit/2.5.9/doc/index.html        |     77 -
 lib/NUnit.org/NUnit/2.5.9/doc/installation.html |    126 -
 lib/NUnit.org/NUnit/2.5.9/doc/license.html      |     88 -
 lib/NUnit.org/NUnit/2.5.9/doc/listMapper.html   |     99 -
 lib/NUnit.org/NUnit/2.5.9/doc/mainMenu.html     |    276 -
 lib/NUnit.org/NUnit/2.5.9/doc/maxtime.html      |    119 -
 .../NUnit/2.5.9/doc/multiAssembly.html          |    134 -
 lib/NUnit.org/NUnit/2.5.9/doc/nunit-agent.html  |     97 -
 .../NUnit/2.5.9/doc/nunit-console.html          |     94 -
 lib/NUnit.org/NUnit/2.5.9/doc/nunit-gui.html    |    137 -
 lib/NUnit.org/NUnit/2.5.9/doc/nunit.css         |    126 -
 lib/NUnit.org/NUnit/2.5.9/doc/nunitAddins.html  |    223 -
 lib/NUnit.org/NUnit/2.5.9/doc/pairwise.html     |    109 -
 .../NUnit/2.5.9/doc/parameterizedTests.html     |    155 -
 .../NUnit/2.5.9/doc/pathConstraints.html        |    193 -
 lib/NUnit.org/NUnit/2.5.9/doc/platform.html     |    311 -
 lib/NUnit.org/NUnit/2.5.9/doc/pnunit.html       |     99 -
 .../NUnit/2.5.9/doc/projectEditor.html          |    219 -
 lib/NUnit.org/NUnit/2.5.9/doc/property.html     |    243 -
 .../NUnit/2.5.9/doc/propertyConstraint.html     |     88 -
 lib/NUnit.org/NUnit/2.5.9/doc/quickStart.html   |    314 -
 lib/NUnit.org/NUnit/2.5.9/doc/random.html       |    133 -
 lib/NUnit.org/NUnit/2.5.9/doc/range.html        |    144 -
 lib/NUnit.org/NUnit/2.5.9/doc/releaseNotes.html |   1370 -
 lib/NUnit.org/NUnit/2.5.9/doc/repeat.html       |     99 -
 .../NUnit/2.5.9/doc/requiredAddin.html          |    148 -
 lib/NUnit.org/NUnit/2.5.9/doc/requiresMTA.html  |    147 -
 lib/NUnit.org/NUnit/2.5.9/doc/requiresSTA.html  |    148 -
 .../NUnit/2.5.9/doc/requiresThread.html         |    148 -
 .../NUnit/2.5.9/doc/reusableConstraint.html     |    161 -
 lib/NUnit.org/NUnit/2.5.9/doc/runningTests.html |    108 -
 .../NUnit/2.5.9/doc/runtimeSelection.html       |    121 -
 .../NUnit/2.5.9/doc/sameasConstraint.html       |    100 -
 lib/NUnit.org/NUnit/2.5.9/doc/samples.html      |    124 -
 lib/NUnit.org/NUnit/2.5.9/doc/sequential.html   |    127 -
 lib/NUnit.org/NUnit/2.5.9/doc/setCulture.html   |    191 -
 lib/NUnit.org/NUnit/2.5.9/doc/setUICulture.html |    192 -
 .../NUnit/2.5.9/doc/settingsDialog.html         |    320 -
 lib/NUnit.org/NUnit/2.5.9/doc/setup.html        |    239 -
 lib/NUnit.org/NUnit/2.5.9/doc/setupFixture.html |    216 -
 lib/NUnit.org/NUnit/2.5.9/doc/stringAssert.html |    105 -
 .../NUnit/2.5.9/doc/stringConstraints.html      |    243 -
 lib/NUnit.org/NUnit/2.5.9/doc/suite.html        |    238 -
 .../NUnit/2.5.9/doc/suiteBuilders.html          |    101 -
 lib/NUnit.org/NUnit/2.5.9/doc/teardown.html     |    239 -
 lib/NUnit.org/NUnit/2.5.9/doc/test.html         |    215 -
 lib/NUnit.org/NUnit/2.5.9/doc/testCase.html     |    180 -
 .../NUnit/2.5.9/doc/testCaseSource.html         |    325 -
 .../NUnit/2.5.9/doc/testDecorators.html         |    112 -
 lib/NUnit.org/NUnit/2.5.9/doc/testFixture.html  |    413 -
 .../NUnit/2.5.9/doc/testProperties.html         |     86 -
 .../NUnit/2.5.9/doc/testcaseBuilders.html       |    112 -
 .../NUnit/2.5.9/doc/testcaseProviders.html      |    140 -
 lib/NUnit.org/NUnit/2.5.9/doc/theory.html       |    191 -
 .../NUnit/2.5.9/doc/throwsConstraint.html       |    157 -
 lib/NUnit.org/NUnit/2.5.9/doc/timeout.html      |    123 -
 lib/NUnit.org/NUnit/2.5.9/doc/typeAsserts.html  |    129 -
 .../NUnit/2.5.9/doc/typeConstraints.html        |    102 -
 lib/NUnit.org/NUnit/2.5.9/doc/upgrade.html      |     98 -
 .../NUnit/2.5.9/doc/utilityAsserts.html         |    125 -
 lib/NUnit.org/NUnit/2.5.9/doc/valueSource.html  |    157 -
 lib/NUnit.org/NUnit/2.5.9/doc/values.html       |    131 -
 lib/NUnit.org/NUnit/2.5.9/doc/vsSupport.html    |    144 -
 lib/NUnit.org/NUnit/2.5.9/fit-license.txt       |    342 -
 lib/NUnit.org/NUnit/2.5.9/license.txt           |     15 -
 .../Extensibility/Core/CoreExtensibility.sln    |     53 -
 .../Extensibility/Core/Minimal/Minimal.build    |     21 -
 .../Extensibility/Core/Minimal/Minimal.cs       |     36 -
 .../Extensibility/Core/Minimal/Minimal.csproj   |     89 -
 .../Extensibility/Core/Minimal/ReadMe.txt       |     27 -
 .../Core/SampleFixtureExtension/AssemblyInfo.cs |     58 -
 .../Core/SampleFixtureExtension/ReadMe.txt      |     43 -
 .../SampleFixtureExtension.build                |     18 -
 .../SampleFixtureExtension.cs                   |     44 -
 .../SampleFixtureExtension.csproj               |    109 -
 .../SampleFixtureExtensionAttribute.cs          |     18 -
 .../SampleFixtureExtensionBuilder.cs            |     58 -
 .../Tests/AssemblyInfo.cs                       |     58 -
 .../Tests/SampleFixtureExtensionTests.cs        |     48 -
 .../Tests/SampleFixtureExtensionTests.csproj    |     94 -
 .../Core/SampleSuiteExtension/Addin.cs          |     30 -
 .../Core/SampleSuiteExtension/AssemblyInfo.cs   |     58 -
 .../Core/SampleSuiteExtension/ReadMe.txt        |     43 -
 .../SampleSuiteExtension.build                  |     18 -
 .../SampleSuiteExtension.cs                     |     39 -
 .../SampleSuiteExtension.csproj                 |    114 -
 .../SampleSuiteExtensionAttribute.cs            |     18 -
 .../SampleSuiteExtensionBuilder.cs              |     41 -
 .../Tests/SampleSuiteExtensionTests.cs          |     33 -
 .../Tests/SampleSuiteExtensionTests.csproj      |     94 -
 lib/NUnit.org/NUnit/2.5.9/samples/ReadMe.txt    |     69 -
 .../NUnit/2.5.9/samples/cpp/cpp-cli/cpp-cli.sln |     41 -
 .../cpp/cpp-cli/failures/AssemblyInfo.cpp       |     56 -
 .../cpp/cpp-cli/failures/cpp-cli-failures.build |     24 -
 .../cpp-cli/failures/cpp-cli-failures.vcproj    |    208 -
 .../samples/cpp/cpp-cli/failures/cppsample.cpp  |     48 -
 .../samples/cpp/cpp-cli/failures/cppsample.h    |     28 -
 .../samples/cpp/cpp-cli/syntax/AssemblyInfo.cpp |     40 -
 .../cpp/cpp-cli/syntax/cpp-cli-syntax.build     |     11 -
 .../cpp/cpp-cli/syntax/cpp-cli-syntax.cpp       |    641 -
 .../cpp/cpp-cli/syntax/cpp-cli-syntax.vcproj    |    200 -
 .../cpp/managed/failures/AssemblyInfo.cpp       |     56 -
 .../managed/failures/cpp-managed-failures.build |     31 -
 .../failures/cpp-managed-failures.vcproj        |    139 -
 .../samples/cpp/managed/failures/cppsample.cpp  |     48 -
 .../samples/cpp/managed/failures/cppsample.h    |     28 -
 .../2.5.9/samples/cpp/managed/managed-cpp.sln   |     21 -
 .../NUnit/2.5.9/samples/csharp/CSharp.sln       |     37 -
 .../samples/csharp/failures/AssemblyInfo.cs     |     58 -
 .../2.5.9/samples/csharp/failures/CSharpTest.cs |     85 -
 .../samples/csharp/failures/cs-failures.build   |     11 -
 .../samples/csharp/failures/cs-failures.csproj  |     20 -
 .../2.5.9/samples/csharp/money/AssemblyInfo.cs  |     58 -
 .../NUnit/2.5.9/samples/csharp/money/IMoney.cs  |     37 -
 .../NUnit/2.5.9/samples/csharp/money/Money.cs   |    103 -
 .../2.5.9/samples/csharp/money/MoneyBag.cs      |    174 -
 .../2.5.9/samples/csharp/money/MoneyTest.cs     |    321 -
 .../2.5.9/samples/csharp/money/cs-money.build   |     14 -
 .../2.5.9/samples/csharp/money/cs-money.csproj  |     23 -
 .../2.5.9/samples/csharp/syntax/AssemblyInfo.cs |     58 -
 .../samples/csharp/syntax/AssertSyntaxTests.cs  |    828 -
 .../2.5.9/samples/csharp/syntax/cs-syntax.build |     11 -
 .../samples/csharp/syntax/cs-syntax.csproj      |     20 -
 .../samples/jsharp/failures/AssemblyInfo.jsl    |     58 -
 .../samples/jsharp/failures/JSharpTest.jsl      |     65 -
 .../jsharp/failures/jsharp-failures.build       |     11 -
 .../jsharp/failures/jsharp-failures.vjsproj     |     21 -
 .../NUnit/2.5.9/samples/jsharp/jsharp.sln       |     21 -
 .../NUnit/2.5.9/samples/samples.common          |    308 -
 .../2.5.9/samples/vb/failures/AssemblyInfo.vb   |     32 -
 .../2.5.9/samples/vb/failures/SimpleVBTest.vb   |     60 -
 .../2.5.9/samples/vb/failures/vb-failures.build |     11 -
 .../samples/vb/failures/vb-failures.vbproj      |     24 -
 .../2.5.9/samples/vb/money/AssemblyInfo.vb      |     32 -
 .../NUnit/2.5.9/samples/vb/money/IMoney.vb      |     37 -
 .../NUnit/2.5.9/samples/vb/money/Money.vb       |    109 -
 .../NUnit/2.5.9/samples/vb/money/MoneyBag.vb    |    164 -
 .../NUnit/2.5.9/samples/vb/money/MoneyTest.vb   |    216 -
 .../NUnit/2.5.9/samples/vb/money/vb-money.build |     14 -
 .../2.5.9/samples/vb/money/vb-money.vbproj      |     28 -
 .../2.5.9/samples/vb/syntax/AssemblyInfo.vb     |     32 -
 .../samples/vb/syntax/AssertSyntaxTests.vb      |    705 -
 .../2.5.9/samples/vb/syntax/vb-syntax.build     |     11 -
 .../2.5.9/samples/vb/syntax/vb-syntax.vbproj    |     29 -
 .../NUnit/2.5.9/samples/vb/vb-samples.sln       |     37 -
 lib/Nuget/Lucene.Net.Core.2.9.4.1.nupkg         |    Bin 682916 -> 0 bytes
 lib/StyleCop.4.5/Docs/StyleCop.chm              |    Bin 219882 -> 0 bytes
 .../Appending/AppendingCodec.cs                 |     48 +
 .../Appending/AppendingPostingsFormat.cs        |     64 +
 .../Appending/AppendingTermsReader.cs           |     63 +
 .../BlockTerms/BlockTermsFieldAndTerm.cs        |     46 +
 .../BlockTerms/BlockTermsReader.cs              |    877 +
 .../BlockTerms/BlockTermsWriter.cs              |    346 +
 .../BlockTerms/FixedGapTermsIndexReader.cs      |    433 +
 .../BlockTerms/FixedGapTermsIndexWriter.cs      |    294 +
 .../BlockTerms/TermsIndexReaderBase.cs          |     88 +
 .../BlockTerms/TermsIndexWriterBase.cs          |     51 +
 .../BlockTerms/VariableGapTermsIndexReader.cs   |    315 +
 .../BlockTerms/VariableGapTermsIndexWriter.cs   |    366 +
 .../Bloom/BloomFilterFactory.cs                 |     63 +
 .../Bloom/BloomFilteringPostingsFormat.cs       |    547 +
 .../Bloom/DefaultBloomFilterFactory.cs          |     45 +
 src/Lucene.Net.Codecs/Bloom/FuzzySet.cs         |    347 +
 src/Lucene.Net.Codecs/Bloom/HashFunction.cs     |     40 +
 src/Lucene.Net.Codecs/Bloom/MurmurHash2.cs      |    111 +
 .../DiskDV/DiskDocValuesFormat.cs               |     55 +
 .../DiskDV/DiskDocValuesProducer.cs             |     57 +
 src/Lucene.Net.Codecs/DiskDV/DiskNormsFormat.cs |     47 +
 .../Intblock/FixedIntBlockIndexInput.cs         |     68 +
 .../Intblock/FixedIntBlockIndexOutput.cs        |    128 +
 src/Lucene.Net.Codecs/Intblock/IBlockReader.cs  |     29 +
 src/Lucene.Net.Codecs/Intblock/Index.cs         |     81 +
 src/Lucene.Net.Codecs/Intblock/Reader.cs        |     67 +
 .../Intblock/VariableIntBlockIndexInput.cs      |    198 +
 .../Intblock/VariableIntBlockIndexOutput.cs     |    136 +
 src/Lucene.Net.Codecs/Lucene.Net.Codecs.csproj  |    138 +
 src/Lucene.Net.Codecs/Lucene.Net.Codecs.sln     |     26 +
 .../Memory/DirectDocValuesConsumer.cs           |    304 +
 .../Memory/DirectDocValuesFormat.cs             |     83 +
 .../Memory/DirectDocValuesProducer.cs           |    511 +
 .../Memory/DirectPostingsFormat.cs              |   2302 +
 .../Memory/FSTOrdPostingsFormat.cs              |     83 +
 .../Memory/FSTOrdPulsing41PostingsFormat.cs     |     91 +
 .../Memory/FSTOrdTermsReader.cs                 |    860 +
 .../Memory/FSTOrdTermsWriter.cs                 |    374 +
 .../Memory/FSTPostingsFormat.cs                 |     83 +
 .../Memory/FSTPulsing41PostingsFormat.cs        |     92 +
 src/Lucene.Net.Codecs/Memory/FSTTermOutputs.cs  |    331 +
 src/Lucene.Net.Codecs/Memory/FSTTermsReader.cs  |    762 +
 src/Lucene.Net.Codecs/Memory/FSTTermsWriter.cs  |    277 +
 .../Memory/MemoryDocValuesConsumer.cs           |    408 +
 .../Memory/MemoryDocValuesFormat.cs             |     72 +
 .../Memory/MemoryDocValuesProducer.cs           |    658 +
 .../Memory/MemoryPostingsFormat.cs              |    936 +
 .../Properties/AssemblyInfo.cs                  |     36 +
 .../Pulsing/Pulsing41PostingsFormat.cs          |     47 +
 .../Pulsing/PulsingPostingsFormat.cs            |    127 +
 .../Pulsing/PulsingPostingsReader.cs            |    780 +
 .../Pulsing/PulsingPostingsWriter.cs            |    511 +
 src/Lucene.Net.Codecs/Sep/IntIndexInput.cs      |     59 +
 src/Lucene.Net.Codecs/Sep/IntIndexOutput.cs     |     61 +
 src/Lucene.Net.Codecs/Sep/IntStreamFactory.cs   |     36 +
 src/Lucene.Net.Codecs/Sep/SepPostingsReader.cs  |    714 +
 src/Lucene.Net.Codecs/Sep/SepPostingsWriter.cs  |    371 +
 src/Lucene.Net.Codecs/Sep/SepSkipListReader.cs  |    209 +
 src/Lucene.Net.Codecs/Sep/SepSkipListWriter.cs  |    200 +
 .../SimpleText/SimpleTextCodec.cs               |     89 +
 .../SimpleText/SimpleTextDocValuesFormat.cs     |    137 +
 .../SimpleText/SimpleTextDocValuesReader.cs     |    489 +
 .../SimpleText/SimpleTextDocValuesWriter.cs     |    411 +
 .../SimpleText/SimpleTextFieldInfosFormat.cs    |     45 +
 .../SimpleText/SimpleTextFieldInfosReader.cs    |    157 +
 .../SimpleText/SimpleTextFieldInfosWriter.cs    |    149 +
 .../SimpleText/SimpleTextFieldsReader.cs        |    690 +
 .../SimpleText/SimpleTextFieldsWriter.cs        |    191 +
 .../SimpleText/SimpleTextLiveDocsFormat.cs      |    188 +
 .../SimpleText/SimpleTextNormsFormat.cs         |     77 +
 .../SimpleText/SimpleTextPostingsFormat.cs      |     59 +
 .../SimpleText/SimpleTextSegmentInfoFormat.cs   |     45 +
 .../SimpleText/SimpleTextSegmentInfoReader.cs   |    120 +
 .../SimpleText/SimpleTextSegmentInfoWriter.cs   |    121 +
 .../SimpleText/SimpleTextStoredFieldsFormat.cs  |     47 +
 .../SimpleText/SimpleTextStoredFieldsReader.cs  |    208 +
 .../SimpleText/SimpleTextStoredFieldsWriter.cs  |    197 +
 .../SimpleText/SimpleTextTermVectorsFormat.cs   |     47 +
 .../SimpleText/SimpleTextTermVectorsReader.cs   |    558 +
 .../SimpleText/SimpleTextTermVectorsWriter.cs   |    209 +
 .../SimpleText/SimpleTextUtil.cs                |    123 +
 .../Analysis/ASCIIFoldingFilter.cs              |   3285 +
 src/Lucene.Net.Core/Analysis/Analyzer.cs        |    442 +
 src/Lucene.Net.Core/Analysis/AnalyzerWrapper.cs |    118 +
 src/Lucene.Net.Core/Analysis/BaseCharFilter.cs  |    105 +
 .../Analysis/CachingTokenFilter.cs              |    103 +
 src/Lucene.Net.Core/Analysis/CharArraySet.cs    |    517 +
 src/Lucene.Net.Core/Analysis/CharFilter.cs      |     84 +
 src/Lucene.Net.Core/Analysis/CharReader.cs      |     94 +
 src/Lucene.Net.Core/Analysis/CharStream.cs      |     45 +
 src/Lucene.Net.Core/Analysis/CharTokenizer.cs   |    135 +
 .../Analysis/ISOLatin1AccentFilter.cs           |    344 +
 src/Lucene.Net.Core/Analysis/KeywordAnalyzer.cs |     54 +
 .../Analysis/KeywordTokenizer.cs                |     99 +
 src/Lucene.Net.Core/Analysis/LengthFilter.cs    |     60 +
 src/Lucene.Net.Core/Analysis/LetterTokenizer.cs |     57 +
 src/Lucene.Net.Core/Analysis/LowerCaseFilter.cs |     49 +
 .../Analysis/LowerCaseTokenizer.cs              |     60 +
 .../Analysis/MappingCharFilter.cs               |    166 +
 .../Analysis/NormalizeCharMap.cs                |     68 +
 .../Analysis/NumericTokenStream.cs              |    400 +
 .../Analysis/PerFieldAnalyzerWrapper.cs         |    135 +
 .../Analysis/PorterStemFilter.cs                |     62 +
 src/Lucene.Net.Core/Analysis/PorterStemmer.cs   |    746 +
 .../Analysis/ReusableStringReader.cs            |     78 +
 src/Lucene.Net.Core/Analysis/SimpleAnalyzer.cs  |     45 +
 .../Standard/READ_BEFORE_REGENERATING.txt       |     25 +
 .../Analysis/Standard/StandardAnalyzer.cs       |    174 +
 .../Analysis/Standard/StandardFilter.cs         |     88 +
 .../Analysis/Standard/StandardTokenizer.cs      |    232 +
 .../Analysis/Standard/StandardTokenizerImpl.cs  |    707 +
 .../Standard/StandardTokenizerImpl.jflex        |    156 +
 src/Lucene.Net.Core/Analysis/StopAnalyzer.cs    |    141 +
 src/Lucene.Net.Core/Analysis/StopFilter.cs      |    178 +
 .../Analysis/TeeSinkTokenFilter.cs              |    266 +
 src/Lucene.Net.Core/Analysis/Token.cs           |    675 +
 src/Lucene.Net.Core/Analysis/TokenFilter.cs     |     75 +
 src/Lucene.Net.Core/Analysis/TokenStream.cs     |    208 +
 .../Analysis/TokenStreamToAutomaton.cs          |    336 +
 .../Tokenattributes/CharTermAttribute.cs        |    321 +
 .../Analysis/Tokenattributes/FlagsAttribute.cs  |     79 +
 .../Tokenattributes/ICharTermAttribute.cs       |    106 +
 .../Analysis/Tokenattributes/IFlagsAttribute.cs |     38 +
 .../Tokenattributes/IKeywordAttribute.cs        |     40 +
 .../Tokenattributes/IOffsetAttribute.cs         |     53 +
 .../Tokenattributes/IPayloadAttribute.cs        |     45 +
 .../IPositionIncrementAttribute.cs              |     59 +
 .../Tokenattributes/IPositionLengthAttribute.cs |     47 +
 .../Analysis/Tokenattributes/ITermAttribute.cs  |    103 +
 .../Tokenattributes/ITermToBytesRefAttribute.cs |     69 +
 .../Analysis/Tokenattributes/ITypeAttribute.cs  |     40 +
 .../Tokenattributes/KeywordAttribute.cs         |     76 +
 .../Analysis/Tokenattributes/OffsetAttribute.cs |    101 +
 .../Tokenattributes/PayloadAttribute.cs         |    105 +
 .../PositionIncrementAttribute.cs               |     84 +
 .../Tokenattributes/PositionLengthAttribute.cs  |     84 +
 .../Analysis/Tokenattributes/TermAttribute.cs   |    268 +
 .../Tokenattributes/TermToBytesRefAttribute.cs  |     28 +
 .../Analysis/Tokenattributes/TypeAttribute.cs   |     83 +
 src/Lucene.Net.Core/Analysis/Tokenizer.cs       |    146 +
 .../Analysis/WhitespaceAnalyzer.cs              |     43 +
 .../Analysis/WhitespaceTokenizer.cs             |     55 +
 src/Lucene.Net.Core/Analysis/WordlistLoader.cs  |    146 +
 src/Lucene.Net.Core/AssemblyInfo.cs             |     89 +
 src/Lucene.Net.Core/ChangeNotes.txt             |     84 +
 src/Lucene.Net.Core/Codecs/BlockTermState.cs    |     74 +
 .../Codecs/BlockTreeTermsReader.cs              |   3500 +
 .../Codecs/BlockTreeTermsWriter.cs              |   1235 +
 src/Lucene.Net.Core/Codecs/Codec.cs             |    171 +
 src/Lucene.Net.Core/Codecs/CodecUtil.cs         |    275 +
 .../CompressingStoredFieldsFormat.cs            |    116 +
 .../CompressingStoredFieldsIndexReader.cs       |    212 +
 .../CompressingStoredFieldsIndexWriter.cs       |    227 +
 .../CompressingStoredFieldsReader.cs            |    636 +
 .../CompressingStoredFieldsWriter.cs            |    555 +
 .../Compressing/CompressingTermVectorsFormat.cs |     90 +
 .../Compressing/CompressingTermVectorsReader.cs |   1216 +
 .../Compressing/CompressingTermVectorsWriter.cs |    988 +
 .../Codecs/Compressing/CompressionMode.cs       |    317 +
 .../Codecs/Compressing/Compressor.cs            |     40 +
 .../Codecs/Compressing/Decompressor.cs          |     54 +
 src/Lucene.Net.Core/Codecs/Compressing/LZ4.cs   |    639 +
 src/Lucene.Net.Core/Codecs/DocValuesConsumer.cs |   1164 +
 src/Lucene.Net.Core/Codecs/DocValuesFormat.cs   |    133 +
 src/Lucene.Net.Core/Codecs/DocValuesProducer.cs |    102 +
 src/Lucene.Net.Core/Codecs/FieldInfosFormat.cs  |     48 +
 src/Lucene.Net.Core/Codecs/FieldInfosReader.cs  |     45 +
 src/Lucene.Net.Core/Codecs/FieldInfosWriter.cs  |     45 +
 src/Lucene.Net.Core/Codecs/FieldsConsumer.cs    |     88 +
 src/Lucene.Net.Core/Codecs/FieldsProducer.cs    |     56 +
 src/Lucene.Net.Core/Codecs/FilterCodec.cs       |    105 +
 src/Lucene.Net.Core/Codecs/LiveDocsFormat.cs    |     66 +
 .../Codecs/Lucene3x/Lucene3xCodec.cs            |    151 +
 .../Codecs/Lucene3x/Lucene3xFieldInfosFormat.cs |     48 +
 .../Codecs/Lucene3x/Lucene3xFieldInfosReader.cs |    148 +
 .../Codecs/Lucene3x/Lucene3xFields.cs           |   1292 +
 .../Codecs/Lucene3x/Lucene3xNormsFormat.cs      |     43 +
 .../Codecs/Lucene3x/Lucene3xNormsProducer.cs    |    294 +
 .../Codecs/Lucene3x/Lucene3xPostingsFormat.cs   |     68 +
 .../Lucene3x/Lucene3xSegmentInfoFormat.cs       |    104 +
 .../Lucene3x/Lucene3xSegmentInfoReader.cs       |    315 +
 .../Codecs/Lucene3x/Lucene3xSkipListReader.cs   |    144 +
 .../Lucene3x/Lucene3xStoredFieldsFormat.cs      |     42 +
 .../Lucene3x/Lucene3xStoredFieldsReader.cs      |    372 +
 .../Lucene3x/Lucene3xTermVectorsFormat.cs       |     90 +
 .../Lucene3x/Lucene3xTermVectorsReader.cs       |    921 +
 .../Codecs/Lucene3x/SegmentTermDocs.cs          |    291 +
 .../Codecs/Lucene3x/SegmentTermEnum.cs          |    270 +
 .../Codecs/Lucene3x/SegmentTermPositions.cs     |    265 +
 .../Codecs/Lucene3x/TermBuffer.cs               |    151 +
 src/Lucene.Net.Core/Codecs/Lucene3x/TermInfo.cs |     74 +
 .../Codecs/Lucene3x/TermInfosReader.cs          |    443 +
 .../Codecs/Lucene3x/TermInfosReaderIndex.cs     |    284 +
 .../Codecs/Lucene40/BitVector.cs                |    531 +
 .../Codecs/Lucene40/Lucene40Codec.cs            |    126 +
 .../Codecs/Lucene40/Lucene40DocValuesFormat.cs  |    209 +
 .../Codecs/Lucene40/Lucene40DocValuesReader.cs  |    947 +
 .../Codecs/Lucene40/Lucene40FieldInfosFormat.cs |    135 +
 .../Codecs/Lucene40/Lucene40FieldInfosReader.cs |    266 +
 .../Codecs/Lucene40/Lucene40LiveDocsFormat.cs   |    116 +
 .../Codecs/Lucene40/Lucene40NormsFormat.cs      |     60 +
 .../Lucene40/Lucene40PostingsBaseFormat.cs      |     52 +
 .../Codecs/Lucene40/Lucene40PostingsFormat.cs   |    284 +
 .../Codecs/Lucene40/Lucene40PostingsReader.cs   |   1320 +
 .../Lucene40/Lucene40SegmentInfoFormat.cs       |    108 +
 .../Lucene40/Lucene40SegmentInfoReader.cs       |     87 +
 .../Lucene40/Lucene40SegmentInfoWriter.cs       |     84 +
 .../Codecs/Lucene40/Lucene40SkipListReader.cs   |    180 +
 .../Lucene40/Lucene40StoredFieldsFormat.cs      |     96 +
 .../Lucene40/Lucene40StoredFieldsReader.cs      |    306 +
 .../Lucene40/Lucene40StoredFieldsWriter.cs      |    411 +
 .../Lucene40/Lucene40TermVectorsFormat.cs       |    129 +
 .../Lucene40/Lucene40TermVectorsReader.cs       |    896 +
 .../Lucene40/Lucene40TermVectorsWriter.cs       |    522 +
 src/Lucene.Net.Core/Codecs/Lucene41/ForUtil.cs  |    265 +
 .../Codecs/Lucene41/Lucene41Codec.cs            |    149 +
 .../Lucene41/Lucene41PostingsBaseFormat.cs      |     50 +
 .../Codecs/Lucene41/Lucene41PostingsFormat.cs   |    445 +
 .../Codecs/Lucene41/Lucene41PostingsReader.cs   |   1748 +
 .../Codecs/Lucene41/Lucene41PostingsWriter.cs   |    689 +
 .../Codecs/Lucene41/Lucene41SkipReader.cs       |    279 +
 .../Codecs/Lucene41/Lucene41SkipWriter.cs       |    162 +
 .../Lucene41/Lucene41StoredFieldsFormat.cs      |    125 +
 .../Codecs/Lucene42/Lucene42Codec.cs            |    173 +
 .../Codecs/Lucene42/Lucene42DocValuesFormat.cs  |    168 +
 .../Lucene42/Lucene42DocValuesProducer.cs       |    853 +
 .../Codecs/Lucene42/Lucene42FieldInfosFormat.cs |    130 +
 .../Codecs/Lucene42/Lucene42FieldInfosReader.cs |    147 +
 .../Codecs/Lucene42/Lucene42NormsConsumer.cs    |    251 +
 .../Codecs/Lucene42/Lucene42NormsFormat.cs      |     80 +
 .../Lucene42/Lucene42TermVectorsFormat.cs       |    127 +
 .../Codecs/Lucene45/Lucene45Codec.cs            |    163 +
 .../Lucene45/Lucene45DocValuesConsumer.cs       |    692 +
 .../Codecs/Lucene45/Lucene45DocValuesFormat.cs  |    183 +
 .../Lucene45/Lucene45DocValuesProducer.cs       |   1263 +
 .../Codecs/Lucene46/Lucene46Codec.cs            |    157 +
 .../Codecs/Lucene46/Lucene46FieldInfosFormat.cs |    131 +
 .../Codecs/Lucene46/Lucene46FieldInfosReader.cs |    154 +
 .../Codecs/Lucene46/Lucene46FieldInfosWriter.cs |    145 +
 .../Lucene46/Lucene46SegmentInfoFormat.cs       |    100 +
 .../Lucene46/Lucene46SegmentInfoReader.cs       |     91 +
 .../Lucene46/Lucene46SegmentInfoWriter.cs       |     79 +
 .../Codecs/MappingMultiDocsAndPositionsEnum.cs  |    177 +
 .../Codecs/MappingMultiDocsEnum.cs              |    156 +
 .../Codecs/MultiLevelSkipListReader.cs          |    379 +
 .../Codecs/MultiLevelSkipListWriter.cs          |    207 +
 src/Lucene.Net.Core/Codecs/NormsFormat.cs       |     54 +
 .../Codecs/Perfield/PerFieldDocValuesFormat.cs  |    401 +
 .../Codecs/Perfield/PerFieldPostingsFormat.cs   |    290 +
 .../Codecs/PostingsBaseFormat.cs                |     64 +
 src/Lucene.Net.Core/Codecs/PostingsConsumer.cs  |    178 +
 src/Lucene.Net.Core/Codecs/PostingsFormat.cs    |    139 +
 .../Codecs/PostingsReaderBase.cs                |    103 +
 .../Codecs/PostingsWriterBase.cs                |    106 +
 src/Lucene.Net.Core/Codecs/SegmentInfoFormat.cs |     51 +
 src/Lucene.Net.Core/Codecs/SegmentInfoReader.cs |     48 +
 src/Lucene.Net.Core/Codecs/SegmentInfoWriter.cs |     46 +
 .../Codecs/StoredFieldsFormat.cs                |     51 +
 .../Codecs/StoredFieldsReader.cs                |     68 +
 .../Codecs/StoredFieldsWriter.cs                |    163 +
 src/Lucene.Net.Core/Codecs/TermStats.cs         |     49 +
 src/Lucene.Net.Core/Codecs/TermVectorsFormat.cs |     51 +
 src/Lucene.Net.Core/Codecs/TermVectorsReader.cs |     77 +
 src/Lucene.Net.Core/Codecs/TermVectorsWriter.cs |    366 +
 src/Lucene.Net.Core/Codecs/TermsConsumer.cs     |    242 +
 src/Lucene.Net.Core/Document/AbstractField.cs   |    312 +
 .../Document/BinaryDocValuesField.cs            |     66 +
 .../Document/ByteDocValuesField.cs              |     60 +
 .../Document/CompressionTools.cs                |    188 +
 src/Lucene.Net.Core/Document/DateField.cs       |    138 +
 src/Lucene.Net.Core/Document/DateTools.cs       |    310 +
 .../Document/DerefBytesDocValuesField.cs        |     73 +
 src/Lucene.Net.Core/Document/Document.cs        |    301 +
 .../Document/DocumentStoredFieldVisitor.cs      |    121 +
 .../Document/DoubleDocValuesField.cs            |     63 +
 src/Lucene.Net.Core/Document/DoubleField.cs     |    179 +
 src/Lucene.Net.Core/Document/Field.cs           |   1155 +
 src/Lucene.Net.Core/Document/FieldSelector.cs   |     37 +
 .../Document/FieldSelectorResult.cs             |     71 +
 src/Lucene.Net.Core/Document/FieldType.cs       |    424 +
 src/Lucene.Net.Core/Document/Fieldable.cs       |    205 +
 .../Document/FloatDocValuesField.cs             |     62 +
 src/Lucene.Net.Core/Document/FloatField.cs      |    178 +
 .../Document/IntDocValuesField.cs               |     55 +
 src/Lucene.Net.Core/Document/IntField.cs        |    180 +
 .../Document/LoadFirstFieldSelector.cs          |     35 +
 .../Document/LongDocValuesField.cs              |     47 +
 src/Lucene.Net.Core/Document/LongField.cs       |    190 +
 .../Document/MapFieldSelector.cs                |     68 +
 src/Lucene.Net.Core/Document/NumberTools.cs     |    221 +
 .../Document/NumericDocValuesField.cs           |     63 +
 src/Lucene.Net.Core/Document/NumericField.cs    |    301 +
 .../Document/PackedLongDocValuesField.cs        |     48 +
 .../Document/SetBasedFieldSelector.cs           |     69 +
 .../Document/ShortDocValuesField.cs             |     56 +
 .../Document/SortedBytesDocValuesField.cs       |     72 +
 .../Document/SortedDocValuesField.cs            |     65 +
 .../Document/SortedSetDocValuesField.cs         |     66 +
 src/Lucene.Net.Core/Document/StoredField.cs     |    136 +
 .../Document/StraightBytesDocValuesField.cs     |     72 +
 src/Lucene.Net.Core/Document/StringField.cs     |     70 +
 src/Lucene.Net.Core/Document/TextField.cs       |     87 +
 .../Index/AbstractAllTermDocs.cs                |    118 +
 src/Lucene.Net.Core/Index/AllTermDocs.cs        |     45 +
 src/Lucene.Net.Core/Index/AtomicReader.cs       |    332 +
 .../Index/AtomicReaderContext.cs                |     86 +
 src/Lucene.Net.Core/Index/AutomatonTermsEnum.cs |    379 +
 .../Index/BaseCompositeReader.cs                |    219 +
 src/Lucene.Net.Core/Index/BinaryDocValues.cs    |     39 +
 .../Index/BinaryDocValuesFieldUpdates.cs        |    275 +
 .../Index/BinaryDocValuesWriter.cs              |    275 +
 src/Lucene.Net.Core/Index/BitsSlice.cs          |     60 +
 src/Lucene.Net.Core/Index/BufferedDeletes.cs    |    196 +
 src/Lucene.Net.Core/Index/BufferedUpdates.cs    |    335 +
 .../Index/BufferedUpdatesStream.cs              |    719 +
 src/Lucene.Net.Core/Index/ByteBlockPool.cs      |    172 +
 src/Lucene.Net.Core/Index/ByteSliceReader.cs    |    165 +
 src/Lucene.Net.Core/Index/ByteSliceWriter.cs    |     98 +
 src/Lucene.Net.Core/Index/CharBlockPool.cs      |     69 +
 src/Lucene.Net.Core/Index/CheckIndex.cs         |   2468 +
 src/Lucene.Net.Core/Index/CoalescedUpdates.cs   |    181 +
 src/Lucene.Net.Core/Index/CompositeReader.cs    |    124 +
 .../Index/CompositeReaderContext.cs             |    136 +
 src/Lucene.Net.Core/Index/CompoundFileReader.cs |    317 +
 src/Lucene.Net.Core/Index/CompoundFileWriter.cs |    275 +
 .../Index/ConcurrentMergeScheduler.cs           |    756 +
 .../Index/CorruptIndexException.cs              |     35 +
 .../Index/DefaultSkipListReader.cs              |    128 +
 .../Index/DefaultSkipListWriter.cs              |    143 +
 src/Lucene.Net.Core/Index/DirectoryReader.cs    |    469 +
 src/Lucene.Net.Core/Index/DocConsumer.cs        |     30 +
 .../Index/DocConsumerPerThread.cs               |     37 +
 src/Lucene.Net.Core/Index/DocFieldConsumer.cs   |     40 +
 .../Index/DocFieldConsumerPerField.cs           |     30 +
 .../Index/DocFieldConsumerPerThread.cs          |     30 +
 src/Lucene.Net.Core/Index/DocFieldConsumers.cs  |    221 +
 .../Index/DocFieldConsumersPerField.cs          |     56 +
 .../Index/DocFieldConsumersPerThread.cs         |     82 +
 src/Lucene.Net.Core/Index/DocFieldProcessor.cs  |    309 +
 .../Index/DocFieldProcessorPerField.cs          |     64 +
 .../Index/DocFieldProcessorPerThread.cs         |    478 +
 src/Lucene.Net.Core/Index/DocInverter.cs        |     88 +
 .../Index/DocInverterPerField.cs                |    257 +
 .../Index/DocInverterPerThread.cs               |    107 +
 src/Lucene.Net.Core/Index/DocTermOrds.cs        |   1142 +
 src/Lucene.Net.Core/Index/DocValues.cs          |    234 +
 .../Index/DocValuesFieldUpdates.cs              |    177 +
 src/Lucene.Net.Core/Index/DocValuesProcessor.cs |    238 +
 src/Lucene.Net.Core/Index/DocValuesUpdate.cs    |    111 +
 src/Lucene.Net.Core/Index/DocValuesWriter.cs    |     30 +
 .../Index/DocsAndPositionsEnum.cs               |     77 +
 src/Lucene.Net.Core/Index/DocsEnum.cs           |     80 +
 src/Lucene.Net.Core/Index/DocumentsWriter.cs    |    917 +
 .../Index/DocumentsWriterDeleteQueue.cs         |    538 +
 .../Index/DocumentsWriterFlushControl.cs        |    936 +
 .../Index/DocumentsWriterFlushQueue.cs          |    343 +
 .../Index/DocumentsWriterPerThread.cs           |    734 +
 .../Index/DocumentsWriterPerThreadPool.cs       |    405 +
 .../Index/DocumentsWriterStallControl.cs        |    155 +
 .../Index/DocumentsWriterThreadState.cs         |     56 +
 src/Lucene.Net.Core/Index/FieldInfo.cs          |    414 +
 src/Lucene.Net.Core/Index/FieldInfos.cs         |    438 +
 src/Lucene.Net.Core/Index/FieldInvertState.cs   |    197 +
 .../Index/FieldReaderException.cs               |     96 +
 .../Index/FieldSortedTermVectorMapper.cs        |     78 +
 src/Lucene.Net.Core/Index/Fields.cs             |    100 +
 src/Lucene.Net.Core/Index/FieldsReader.cs       |    641 +
 src/Lucene.Net.Core/Index/FieldsWriter.cs       |    290 +
 src/Lucene.Net.Core/Index/FilterAtomicReader.cs |    502 +
 .../Index/FilterDirectoryReader.cs              |    167 +
 src/Lucene.Net.Core/Index/FilterIndexReader.cs  |    388 +
 src/Lucene.Net.Core/Index/FilteredTermsEnum.cs  |    291 +
 .../Index/FlushByRamOrCountsPolicy.cs           |    143 +
 src/Lucene.Net.Core/Index/FlushPolicy.cs        |    157 +
 .../Index/FormatPostingsDocsConsumer.cs         |     36 +
 .../Index/FormatPostingsDocsWriter.cs           |    134 +
 .../Index/FormatPostingsFieldsConsumer.cs       |     39 +
 .../Index/FormatPostingsFieldsWriter.cs         |     71 +
 .../Index/FormatPostingsPositionsConsumer.cs    |     32 +
 .../Index/FormatPostingsPositionsWriter.cs      |    101 +
 .../Index/FormatPostingsTermsConsumer.cs        |     52 +
 .../Index/FormatPostingsTermsWriter.cs          |     77 +
 .../Index/FreqProxFieldMergeState.cs            |    117 +
 .../Index/FreqProxTermsWriter.cs                |    132 +
 .../Index/FreqProxTermsWriterPerField.cs        |    669 +
 .../Index/FreqProxTermsWriterPerThread.cs       |     52 +
 .../Index/FrozenBufferedUpdates.cs              |    275 +
 src/Lucene.Net.Core/Index/IndexCommit.cs        |    150 +
 .../Index/IndexDeletionPolicy.cs                |    114 +
 src/Lucene.Net.Core/Index/IndexFileDeleter.cs   |    855 +
 .../Index/IndexFileNameFilter.cs                |    107 +
 src/Lucene.Net.Core/Index/IndexFileNames.cs     |    249 +
 .../Index/IndexFormatTooNewException.cs         |     59 +
 .../Index/IndexFormatTooOldException.cs         |     84 +
 .../Index/IndexNotFoundException.cs             |     37 +
 src/Lucene.Net.Core/Index/IndexReader.cs        |    674 +
 src/Lucene.Net.Core/Index/IndexReaderContext.cs |     77 +
 src/Lucene.Net.Core/Index/IndexUpgrader.cs      |    214 +
 src/Lucene.Net.Core/Index/IndexWriter.cs        |   5921 +
 src/Lucene.Net.Core/Index/IndexWriterConfig.cs  |    714 +
 src/Lucene.Net.Core/Index/IndexableField.cs     |     99 +
 src/Lucene.Net.Core/Index/IndexableFieldType.cs |    108 +
 src/Lucene.Net.Core/Index/IntBlockPool.cs       |     79 +
 .../Index/InvertedDocConsumer.cs                |     38 +
 .../Index/InvertedDocConsumerPerField.cs        |     41 +
 .../Index/InvertedDocConsumerPerThread.cs       |     30 +
 .../Index/InvertedDocEndConsumer.cs             |     34 +
 .../Index/InvertedDocEndConsumerPerField.cs     |     26 +
 .../Index/InvertedDocEndConsumerPerThread.cs    |     30 +
 .../Index/KeepOnlyLastCommitDeletionPolicy.cs   |     60 +
 .../Index/LiveIndexWriterConfig.cs              |    775 +
 .../Index/LogByteSizeMergePolicy.cs             |    122 +
 src/Lucene.Net.Core/Index/LogDocMergePolicy.cs  |     73 +
 src/Lucene.Net.Core/Index/LogMergePolicy.cs     |    757 +
 src/Lucene.Net.Core/Index/MergeDocIDRemapper.cs |    127 +
 src/Lucene.Net.Core/Index/MergePolicy.cs        |    731 +
 src/Lucene.Net.Core/Index/MergeScheduler.cs     |     59 +
 src/Lucene.Net.Core/Index/MergeState.cs         |    277 +
 src/Lucene.Net.Core/Index/MergeTrigger.cs       |     53 +
 src/Lucene.Net.Core/Index/MultiBits.cs          |    137 +
 src/Lucene.Net.Core/Index/MultiDocValues.cs     |    687 +
 .../Index/MultiDocsAndPositionsEnum.cs          |    244 +
 src/Lucene.Net.Core/Index/MultiDocsEnum.cs      |    219 +
 src/Lucene.Net.Core/Index/MultiFields.cs        |    333 +
 .../Index/MultiLevelSkipListReader.cs           |    341 +
 .../Index/MultiLevelSkipListWriter.cs           |    171 +
 src/Lucene.Net.Core/Index/MultiReader.cs        |    106 +
 src/Lucene.Net.Core/Index/MultiTerms.cs         |    223 +
 src/Lucene.Net.Core/Index/MultiTermsEnum.cs     |    681 +
 .../Index/MultipleTermPositions.cs              |    256 +
 src/Lucene.Net.Core/Index/NoDeletionPolicy.cs   |     51 +
 src/Lucene.Net.Core/Index/NoMergePolicy.cs      |    108 +
 src/Lucene.Net.Core/Index/NoMergeScheduler.cs   |     54 +
 .../Index/NoSuchFileException.cs                |      8 +
 src/Lucene.Net.Core/Index/NormsConsumer.cs      |    101 +
 .../Index/NormsConsumerPerField.cs              |     85 +
 src/Lucene.Net.Core/Index/NormsWriter.cs        |    206 +
 .../Index/NormsWriterPerField.cs                |     90 +
 .../Index/NormsWriterPerThread.cs               |     55 +
 src/Lucene.Net.Core/Index/NumericDocValues.cs   |     39 +
 .../Index/NumericDocValuesFieldUpdates.cs       |    240 +
 .../Index/NumericDocValuesWriter.cs             |    219 +
 src/Lucene.Net.Core/Index/OrdTermState.cs       |     52 +
 .../Index/ParallelAtomicReader.cs               |    404 +
 .../Index/ParallelCompositeReader.cs            |    252 +
 .../Index/ParallelPostingsArray.cs              |     67 +
 src/Lucene.Net.Core/Index/ParallelReader.cs     |    822 +
 src/Lucene.Net.Core/Index/Payload.cs            |    217 +
 .../Index/PersistentSnapshotDeletionPolicy.cs   |    372 +
 .../Index/PositionBasedTermVectorMapper.cs      |    176 +
 src/Lucene.Net.Core/Index/PrefixCodedTerms.cs   |    214 +
 src/Lucene.Net.Core/Index/RandomAccessOrds.cs   |     57 +
 src/Lucene.Net.Core/Index/RawPostingList.cs     |     46 +
 .../Index/ReadOnlyDirectoryReader.cs            |     45 +
 .../Index/ReadOnlySegmentReader.cs              |     42 +
 src/Lucene.Net.Core/Index/ReaderManager.cs      |     87 +
 src/Lucene.Net.Core/Index/ReaderSlice.cs        |     57 +
 src/Lucene.Net.Core/Index/ReaderUtil.cs         |    114 +
 src/Lucene.Net.Core/Index/ReadersAndUpdates.cs  |    961 +
 .../Index/ReusableStringReader.cs               |    136 +
 src/Lucene.Net.Core/Index/SegmentCommitInfo.cs  |    337 +
 src/Lucene.Net.Core/Index/SegmentCoreReaders.cs |    296 +
 src/Lucene.Net.Core/Index/SegmentDocValues.cs   |    135 +
 src/Lucene.Net.Core/Index/SegmentInfo.cs        |    386 +
 src/Lucene.Net.Core/Index/SegmentInfos.cs       |   1497 +
 src/Lucene.Net.Core/Index/SegmentMergeInfo.cs   |    108 +
 src/Lucene.Net.Core/Index/SegmentMergeQueue.cs  |     47 +
 src/Lucene.Net.Core/Index/SegmentMerger.cs      |    481 +
 src/Lucene.Net.Core/Index/SegmentReadState.cs   |    106 +
 src/Lucene.Net.Core/Index/SegmentReader.cs      |    748 +
 src/Lucene.Net.Core/Index/SegmentTermDocs.cs    |    282 +
 src/Lucene.Net.Core/Index/SegmentTermEnum.cs    |    247 +
 .../Index/SegmentTermPositionVector.cs          |     73 +
 .../Index/SegmentTermPositions.cs               |    226 +
 src/Lucene.Net.Core/Index/SegmentTermVector.cs  |    102 +
 src/Lucene.Net.Core/Index/SegmentWriteState.cs  |    138 +
 .../Index/SerialMergeScheduler.cs               |     57 +
 .../Index/SimpleMergedSegmentWarmer.cs          |    101 +
 src/Lucene.Net.Core/Index/SingleTermsEnum.cs    |     53 +
 .../Index/SingletonSortedSetDocValues.cs        |     96 +
 .../Index/SlowCompositeReaderWrapper.cs         |    274 +
 .../Index/SnapshotDeletionPolicy.cs             |    375 +
 src/Lucene.Net.Core/Index/SortedDocValues.cs    |    121 +
 .../Index/SortedDocValuesTermsEnum.cs           |    163 +
 .../Index/SortedDocValuesWriter.cs              |    293 +
 src/Lucene.Net.Core/Index/SortedSetDocValues.cs |    117 +
 .../Index/SortedSetDocValuesTermsEnum.cs        |    163 +
 .../Index/SortedSetDocValuesWriter.cs           |    462 +
 .../Index/SortedTermVectorMapper.cs             |    133 +
 .../Index/StaleReaderException.cs               |     49 +
 .../Index/StandardDirectoryReader.cs            |    599 +
 src/Lucene.Net.Core/Index/StoredFieldVisitor.cs |    113 +
 .../Index/StoredFieldsConsumer.cs               |     32 +
 .../Index/StoredFieldsProcessor.cs              |    183 +
 src/Lucene.Net.Core/Index/StoredFieldsWriter.cs |    266 +
 .../Index/StoredFieldsWriterPerThread.cs        |     93 +
 src/Lucene.Net.Core/Index/Term.cs               |    216 +
 src/Lucene.Net.Core/Index/TermBuffer.cs         |    166 +
 src/Lucene.Net.Core/Index/TermContext.cs        |    190 +
 src/Lucene.Net.Core/Index/TermDocs.cs           |     86 +
 src/Lucene.Net.Core/Index/TermEnum.cs           |     53 +
 src/Lucene.Net.Core/Index/TermFreqVector.cs     |     73 +
 src/Lucene.Net.Core/Index/TermInfo.cs           |     69 +
 src/Lucene.Net.Core/Index/TermInfosReader.cs    |    325 +
 src/Lucene.Net.Core/Index/TermInfosWriter.cs    |    250 +
 src/Lucene.Net.Core/Index/TermPositionVector.cs |     50 +
 src/Lucene.Net.Core/Index/TermPositions.cs      |     79 +
 src/Lucene.Net.Core/Index/TermState.cs          |     56 +
 src/Lucene.Net.Core/Index/TermVectorEntry.cs    |    108 +
 .../TermVectorEntryFreqSortedComparator.cs      |     45 +
 src/Lucene.Net.Core/Index/TermVectorMapper.cs   |    112 +
 .../Index/TermVectorOffsetInfo.cs               |    134 +
 .../Index/TermVectorsConsumer.cs                |    206 +
 .../Index/TermVectorsConsumerPerField.cs        |    366 +
 src/Lucene.Net.Core/Index/TermVectorsReader.cs  |    731 +
 .../Index/TermVectorsTermsWriter.cs             |    380 +
 .../Index/TermVectorsTermsWriterPerField.cs     |    290 +
 .../Index/TermVectorsTermsWriterPerThread.cs    |    106 +
 src/Lucene.Net.Core/Index/TermVectorsWriter.cs  |    246 +
 src/Lucene.Net.Core/Index/Terms.cs              |    171 +
 src/Lucene.Net.Core/Index/TermsEnum.cs          |    355 +
 src/Lucene.Net.Core/Index/TermsHash.cs          |    161 +
 src/Lucene.Net.Core/Index/TermsHashConsumer.cs  |     34 +
 .../Index/TermsHashConsumerPerField.cs          |     44 +
 .../Index/TermsHashConsumerPerThread.cs         |     30 +
 src/Lucene.Net.Core/Index/TermsHashPerField.cs  |    374 +
 src/Lucene.Net.Core/Index/TermsHashPerThread.cs |    140 +
 .../ThreadAffinityDocumentsWriterThreadPool.cs  |     96 +
 src/Lucene.Net.Core/Index/TieredMergePolicy.cs  |    850 +
 .../Index/TrackingIndexWriter.cs                |    278 +
 src/Lucene.Net.Core/Index/TwoPhaseCommit.cs     |     53 +
 src/Lucene.Net.Core/Index/TwoPhaseCommitTool.cs |    149 +
 .../Index/TwoStoredFieldsConsumers.cs           |     78 +
 .../Index/UpgradeIndexMergePolicy.cs            |    182 +
 src/Lucene.Net.Core/LZOCompressor.cs            |    135 +
 .../Lucene.Net.Search.RemoteSearchable.config   |     32 +
 .../Lucene.Net.Search.TestSort.config           |     32 +
 src/Lucene.Net.Core/Lucene.Net.csproj           |    858 +
 src/Lucene.Net.Core/Lucene.Net.ndoc             |     61 +
 src/Lucene.Net.Core/LucenePackage.cs            |     37 +
 src/Lucene.Net.Core/RectangularArrays.cs        |     70 +
 src/Lucene.Net.Core/Search/AutomatonQuery.cs    |    150 +
 .../Search/BitsFilteredDocIdSet.cs              |     64 +
 src/Lucene.Net.Core/Search/BooleanClause.cs     |    177 +
 src/Lucene.Net.Core/Search/BooleanQuery.cs      |    679 +
 src/Lucene.Net.Core/Search/BooleanScorer.cs     |    314 +
 src/Lucene.Net.Core/Search/BooleanScorer2.cs    |    391 +
 src/Lucene.Net.Core/Search/BoostAttribute.cs    |     57 +
 .../Search/BoostAttributeImpl.cs                |     54 +
 src/Lucene.Net.Core/Search/BulkScorer.cs        |     47 +
 src/Lucene.Net.Core/Search/CachingCollector.cs  |    543 +
 src/Lucene.Net.Core/Search/CachingSpanFilter.cs |    124 +
 .../Search/CachingWrapperFilter.cs              |    203 +
 .../Search/CollectionStatistics.cs              |     91 +
 .../Search/CollectionTerminatedException.cs     |     39 +
 src/Lucene.Net.Core/Search/Collector.cs         |    175 +
 .../Search/ComplexExplanation.cs                |     88 +
 src/Lucene.Net.Core/Search/ConjunctionScorer.cs |    181 +
 .../Search/ConstantScoreAutoRewrite.cs          |    270 +
 .../Search/ConstantScoreQuery.cs                |    433 +
 .../Search/ControlledRealTimeReopenThread.cs    |    317 +
 src/Lucene.Net.Core/Search/DefaultSimilarity.cs |    108 +
 .../Search/DisjunctionMaxQuery.cs               |    369 +
 .../Search/DisjunctionMaxScorer.cs              |     92 +
 src/Lucene.Net.Core/Search/DisjunctionScorer.cs |    214 +
 .../Search/DisjunctionSumScorer.cs              |     90 +
 src/Lucene.Net.Core/Search/DocIdSet.cs          |     75 +
 src/Lucene.Net.Core/Search/DocIdSetIterator.cs  |    161 +
 .../Search/DocTermOrdsRangeFilter.cs            |    268 +
 .../Search/DocTermOrdsRewriteMethod.cs          |    256 +
 src/Lucene.Net.Core/Search/ExactPhraseScorer.cs |    367 +
 src/Lucene.Net.Core/Search/Explanation.cs       |    176 +
 src/Lucene.Net.Core/Search/FakeScorer.cs        |     98 +
 src/Lucene.Net.Core/Search/FieldCache.cs        |   1329 +
 .../Search/FieldCacheDocIdSet.cs                |    238 +
 src/Lucene.Net.Core/Search/FieldCacheImpl.cs    |   1950 +
 .../Search/FieldCacheRangeFilter.cs             |   1766 +
 .../Search/FieldCacheRewriteMethod.cs           |    255 +
 .../Search/FieldCacheTermsFilter.cs             |    174 +
 src/Lucene.Net.Core/Search/FieldComparator.cs   |   1548 +
 .../Search/FieldComparatorSource.cs             |     38 +
 src/Lucene.Net.Core/Search/FieldDoc.cs          |     88 +
 .../Search/FieldDocSortedHitQueue.cs            |    148 +
 src/Lucene.Net.Core/Search/FieldValueFilter.cs  |    190 +
 .../Search/FieldValueHitQueue.cs                |    264 +
 src/Lucene.Net.Core/Search/Filter.cs            |     58 +
 src/Lucene.Net.Core/Search/FilterManager.cs     |    203 +
 src/Lucene.Net.Core/Search/FilteredDocIdSet.cs  |    127 +
 .../Search/FilteredDocIdSetIterator.cs          |     97 +
 src/Lucene.Net.Core/Search/FilteredQuery.cs     |    745 +
 src/Lucene.Net.Core/Search/FilteredTermEnum.cs  |    127 +
 .../Search/Function/ByteFieldSource.cs          |    136 +
 .../Search/Function/CustomScoreProvider.cs      |    175 +
 .../Search/Function/CustomScoreQuery.cs         |    579 +
 .../Search/Function/DocValues.cs                |    206 +
 .../Search/Function/FieldCacheSource.cs         |    110 +
 .../Search/Function/FieldScoreQuery.cs          |    139 +
 .../Search/Function/FloatFieldSource.cs         |    131 +
 .../Search/Function/IntFieldSource.cs           |    136 +
 .../Search/Function/OrdFieldSource.cs           |    146 +
 .../Search/Function/ReverseOrdFieldSource.cs    |    158 +
 .../Search/Function/ShortFieldSource.cs         |    136 +
 .../Search/Function/ValueSource.cs              |     69 +
 .../Search/Function/ValueSourceQuery.cs         |    235 +
 src/Lucene.Net.Core/Search/FuzzyQuery.cs        |    289 +
 src/Lucene.Net.Core/Search/FuzzyTermEnum.cs     |    318 +
 src/Lucene.Net.Core/Search/FuzzyTermsEnum.cs    |    542 +
 src/Lucene.Net.Core/Search/HitQueue.cs          |     90 +
 .../Search/IMaxNonCompetitiveBoostAttribute.cs  |     48 +
 src/Lucene.Net.Core/Search/IndexSearcher.cs     |   1037 +
 src/Lucene.Net.Core/Search/LiveFieldValues.cs   |    164 +
 src/Lucene.Net.Core/Search/MatchAllDocsQuery.cs |    187 +
 .../Search/MaxNonCompetitiveBoostAttribute.cs   |     69 +
 .../Search/MinShouldMatchSumScorer.cs           |    499 +
 src/Lucene.Net.Core/Search/MultiCollector.cs    |    145 +
 src/Lucene.Net.Core/Search/MultiPhraseQuery.cs  |    712 +
 src/Lucene.Net.Core/Search/MultiSearcher.cs     |    458 +
 src/Lucene.Net.Core/Search/MultiTermQuery.cs    |    411 +
 .../Search/MultiTermQueryWrapperFilter.cs       |    144 +
 src/Lucene.Net.Core/Search/NGramPhraseQuery.cs  |    114 +
 .../Search/NumericRangeFilter.cs                |    209 +
 src/Lucene.Net.Core/Search/NumericRangeQuery.cs |    621 +
 .../Search/ParallelMultiSearcher.cs             |    199 +
 .../Search/Payloads/AveragePayloadFunction.cs   |     64 +
 .../Search/Payloads/MaxPayloadFunction.cs       |     73 +
 .../Search/Payloads/MinPayloadFunction.cs       |     71 +
 .../Search/Payloads/PayloadFunction.cs          |     67 +
 .../Search/Payloads/PayloadNearQuery.cs         |    301 +
 .../Search/Payloads/PayloadSpanUtil.cs          |    212 +
 .../Search/Payloads/PayloadTermQuery.cs         |    275 +
 src/Lucene.Net.Core/Search/PhrasePositions.cs   |    103 +
 src/Lucene.Net.Core/Search/PhraseQuery.cs       |    523 +
 src/Lucene.Net.Core/Search/PhraseQueue.cs       |     57 +
 src/Lucene.Net.Core/Search/PhraseScorer.cs      |    224 +
 .../Search/PositiveScoresOnlyCollector.cs       |     69 +
 src/Lucene.Net.Core/Search/PrefixFilter.cs      |     54 +
 src/Lucene.Net.Core/Search/PrefixQuery.cs       |    124 +
 src/Lucene.Net.Core/Search/PrefixTermEnum.cs    |     71 +
 src/Lucene.Net.Core/Search/PrefixTermsEnum.cs   |     55 +
 src/Lucene.Net.Core/Search/Query.cs             |    159 +
 src/Lucene.Net.Core/Search/QueryRescorer.cs     |    237 +
 src/Lucene.Net.Core/Search/QueryTermVector.cs   |    167 +
 .../Search/QueryWrapperFilter.cs                |    116 +
 src/Lucene.Net.Core/Search/ReferenceManager.cs  |    372 +
 src/Lucene.Net.Core/Search/RegexpQuery.cs       |    118 +
 src/Lucene.Net.Core/Search/ReqExclScorer.cs     |    156 +
 src/Lucene.Net.Core/Search/ReqOptSumScorer.cs   |    115 +
 src/Lucene.Net.Core/Search/Rescorer.cs          |     56 +
 .../Search/ScoreCachingWrappingScorer.cs        |     94 +
 src/Lucene.Net.Core/Search/ScoreDoc.cs          |     60 +
 src/Lucene.Net.Core/Search/Scorer.cs            |    120 +
 src/Lucene.Net.Core/Search/ScoringRewrite.cs    |    251 +
 src/Lucene.Net.Core/Search/Searchable.cs        |    169 +
 src/Lucene.Net.Core/Search/Searcher.cs          |    192 +
 src/Lucene.Net.Core/Search/SearcherFactory.cs   |     58 +
 .../Search/SearcherLifetimeManager.cs           |    349 +
 src/Lucene.Net.Core/Search/SearcherManager.cs   |    193 +
 .../Search/Similarities/AfterEffect.cs          |     79 +
 .../Search/Similarities/AfterEffectB.cs         |     55 +
 .../Search/Similarities/AfterEffectL.cs         |     51 +
 .../Search/Similarities/BM25Similarity.cs       |    408 +
 .../Search/Similarities/BasicModel.cs           |     66 +
 .../Search/Similarities/BasicModelBE.cs         |     60 +
 .../Search/Similarities/BasicModelD.cs          |     60 +
 .../Search/Similarities/BasicModelG.cs          |     49 +
 .../Search/Similarities/BasicModelIF.cs         |     44 +
 .../Search/Similarities/BasicModelIn.cs         |     55 +
 .../Search/Similarities/BasicModelIne.cs        |     48 +
 .../Search/Similarities/BasicModelP.cs          |     53 +
 .../Search/Similarities/BasicStats.cs           |    197 +
 .../Search/Similarities/DFRSimilarity.cs        |    165 +
 .../Search/Similarities/DefaultSimilarity.cs    |    193 +
 .../Search/Similarities/Distribution.cs         |     54 +
 .../Search/Similarities/DistributionLL.cs       |     47 +
 .../Search/Similarities/DistributionSPL.cs      |     52 +
 .../Search/Similarities/IBSimilarity.cs         |    159 +
 .../Similarities/LMDirichletSimilarity.cs       |    113 +
 .../Similarities/LMJelinekMercerSimilarity.cs   |     89 +
 .../Search/Similarities/LMSimilarity.cs         |    178 +
 .../Search/Similarities/Lambda.cs               |     51 +
 .../Search/Similarities/LambdaDF.cs             |     52 +
 .../Search/Similarities/LambdaTTF.cs            |     52 +
 .../Search/Similarities/MultiSimilarity.cs      |    141 +
 .../Search/Similarities/Normalization.cs        |     91 +
 .../Search/Similarities/NormalizationH1.cs      |     72 +
 .../Search/Similarities/NormalizationH2.cs      |     72 +
 .../Search/Similarities/NormalizationH3.cs      |     65 +
 .../Search/Similarities/NormalizationZ.cs       |     68 +
 .../Similarities/PerFieldSimilarityWrapper.cs   |     84 +
 .../Search/Similarities/Similarity.cs           |    251 +
 .../Search/Similarities/SimilarityBase.cs       |    329 +
 .../Search/Similarities/TFIDFSimilarity.cs      |    826 +
 src/Lucene.Net.Core/Search/Similarity.cs        |    697 +
 .../Search/SimilarityDelegator.cs               |     80 +
 src/Lucene.Net.Core/Search/SingleTermEnum.cs    |     70 +
 .../Search/SloppyPhraseScorer.cs                |    732 +
 src/Lucene.Net.Core/Search/Sort.cs              |    239 +
 src/Lucene.Net.Core/Search/SortField.cs         |    587 +
 src/Lucene.Net.Core/Search/SortRescorer.cs      |    134 +
 src/Lucene.Net.Core/Search/SpanFilter.cs        |     47 +
 src/Lucene.Net.Core/Search/SpanFilterResult.cs  |    116 +
 src/Lucene.Net.Core/Search/SpanQueryFilter.cs   |    109 +
 .../Search/Spans/FieldMaskingSpanQuery.cs       |    168 +
 .../Search/Spans/NearSpansOrdered.cs            |    440 +
 .../Search/Spans/NearSpansUnordered.cs          |    429 +
 .../Search/Spans/SpanFirstQuery.cs              |    106 +
 .../Search/Spans/SpanMultiTermQueryWrapper.cs   |    331 +
 .../Search/Spans/SpanNearPayloadCheckQuery.cs   |    134 +
 .../Search/Spans/SpanNearQuery.cs               |    253 +
 .../Search/Spans/SpanNotQuery.cs                |    333 +
 src/Lucene.Net.Core/Search/Spans/SpanOrQuery.cs |    363 +
 .../Search/Spans/SpanPayloadCheckQuery.cs       |    134 +
 .../Search/Spans/SpanPositionCheckQuery.cs      |    235 +
 .../Search/Spans/SpanPositionRangeQuery.cs      |    120 +
 src/Lucene.Net.Core/Search/Spans/SpanQuery.cs   |     49 +
 src/Lucene.Net.Core/Search/Spans/SpanScorer.cs  |    121 +
 .../Search/Spans/SpanTermQuery.cs               |    185 +
 src/Lucene.Net.Core/Search/Spans/SpanWeight.cs  |    125 +
 src/Lucene.Net.Core/Search/Spans/Spans.cs       |    105 +
 src/Lucene.Net.Core/Search/Spans/TermSpans.cs   |    211 +
 .../Search/TermCollectingRewrite.cs             |    122 +
 src/Lucene.Net.Core/Search/TermQuery.cs         |    259 +
 src/Lucene.Net.Core/Search/TermRangeFilter.cs   |    112 +
 src/Lucene.Net.Core/Search/TermRangeQuery.cs    |    220 +
 src/Lucene.Net.Core/Search/TermRangeTermEnum.cs |    161 +
 .../Search/TermRangeTermsEnum.cs                |    116 +
 src/Lucene.Net.Core/Search/TermScorer.cs        |    100 +
 src/Lucene.Net.Core/Search/TermStatistics.cs    |     67 +
 .../Search/TimeLimitingCollector.cs             |    361 +
 src/Lucene.Net.Core/Search/TopDocs.cs           |    340 +
 src/Lucene.Net.Core/Search/TopDocsCollector.cs  |    188 +
 src/Lucene.Net.Core/Search/TopFieldCollector.cs |   1450 +
 src/Lucene.Net.Core/Search/TopFieldDocs.cs      |     42 +
 .../Search/TopScoreDocCollector.cs              |    352 +
 src/Lucene.Net.Core/Search/TopTermsRewrite.cs   |    287 +
 .../Search/TotalHitCountCollector.cs            |     64 +
 src/Lucene.Net.Core/Search/Weight.cs            |    217 +
 src/Lucene.Net.Core/Search/WildcardQuery.cs     |    137 +
 src/Lucene.Net.Core/Search/WildcardTermEnum.cs  |    196 +
 .../Store/AlreadyClosedException.cs             |     31 +
 src/Lucene.Net.Core/Store/BaseDirectory.cs      |     78 +
 src/Lucene.Net.Core/Store/BufferedChecksum.cs   |    108 +
 .../Store/BufferedChecksumIndexInput.cs         |     92 +
 src/Lucene.Net.Core/Store/BufferedIndexInput.cs |    461 +
 .../Store/BufferedIndexOutput.cs                |    191 +
 src/Lucene.Net.Core/Store/ByteArrayDataInput.cs |    242 +
 .../Store/ByteArrayDataOutput.cs                |     86 +
 .../Store/ByteBufferIndexInput.cs               |    408 +
 src/Lucene.Net.Core/Store/CheckSumIndexInput.cs |     59 +
 .../Store/CheckSumIndexOutput.cs                |    115 +
 .../Store/CompoundFileDirectory.cs              |    469 +
 src/Lucene.Net.Core/Store/CompoundFileWriter.cs |    478 +
 src/Lucene.Net.Core/Store/DataInput.cs          |    362 +
 src/Lucene.Net.Core/Store/DataOutput.cs         |    343 +
 src/Lucene.Net.Core/Store/Directory.cs          |    391 +
 src/Lucene.Net.Core/Store/FSDirectory.cs        |    561 +
 src/Lucene.Net.Core/Store/FSLockFactory.cs      |     62 +
 .../Store/FileSwitchDirectory.cs                |    216 +
 src/Lucene.Net.Core/Store/FilterDirectory.cs    |    165 +
 src/Lucene.Net.Core/Store/FlushInfo.cs          |     85 +
 src/Lucene.Net.Core/Store/IOContext.cs          |    187 +
 src/Lucene.Net.Core/Store/IndexInput.cs         |    100 +
 src/Lucene.Net.Core/Store/IndexOutput.cs        |     78 +
 .../Store/InputStreamDataInput.cs               |     83 +
 src/Lucene.Net.Core/Store/Lock.cs               |    177 +
 src/Lucene.Net.Core/Store/LockFactory.cs        |     82 +
 .../Store/LockObtainFailedException.cs          |     40 +
 .../Store/LockReleaseFailedException.cs         |     31 +
 src/Lucene.Net.Core/Store/LockStressTest.cs     |    159 +
 src/Lucene.Net.Core/Store/LockVerifyServer.cs   |    193 +
 src/Lucene.Net.Core/Store/MMapDirectory.cs      |    370 +
 src/Lucene.Net.Core/Store/MergeInfo.cs          |    101 +
 src/Lucene.Net.Core/Store/NIOFSDirectory.cs     |    274 +
 .../Store/NRTCachingDirectory.cs                |    399 +
 .../Store/NativeFSLockFactory.cs                |    459 +
 src/Lucene.Net.Core/Store/NoLockFactory.cs      |     80 +
 .../Store/NoSuchDirectoryException.cs           |     34 +
 .../Store/OutputStreamDataOutput.cs             |     50 +
 src/Lucene.Net.Core/Store/RAMDirectory.cs       |    258 +
 src/Lucene.Net.Core/Store/RAMFile.cs            |    120 +
 src/Lucene.Net.Core/Store/RAMInputStream.cs     |    141 +
 src/Lucene.Net.Core/Store/RAMOutputStream.cs    |    233 +
 .../Store/RateLimitedDirectoryWrapper.cs        |    163 +
 .../Store/RateLimitedIndexOutput.cs             |    101 +
 src/Lucene.Net.Core/Store/RateLimiter.cs        |    137 +
 src/Lucene.Net.Core/Store/SimpleFSDirectory.cs  |    232 +
 .../Store/SimpleFSLockFactory.cs                |    196 +
 .../Store/SingleInstanceLockFactory.cs          |     99 +
 .../Store/TrackingDirectoryWrapper.cs           |     68 +
 .../Store/VerifyingLockFactory.cs               |    132 +
 src/Lucene.Net.Core/StringHelperClass.cs        |     35 +
 src/Lucene.Net.Core/Support/AppSettings.cs      |    159 +
 src/Lucene.Net.Core/Support/Arrays.cs           |    134 +
 src/Lucene.Net.Core/Support/AtomicBoolean.cs    |     49 +
 src/Lucene.Net.Core/Support/AtomicInteger.cs    |     66 +
 src/Lucene.Net.Core/Support/AtomicLong.cs       |     52 +
 .../Support/AttributeImplItem.cs                |     42 +
 src/Lucene.Net.Core/Support/BitSetSupport.cs    |    249 +
 src/Lucene.Net.Core/Support/Buffer.cs           |    117 +
 .../Support/BufferUnderflowException.cs         |      8 +
 src/Lucene.Net.Core/Support/BuildType.cs        |     32 +
 .../Support/ByteArrayOutputStream.cs            |     23 +
 src/Lucene.Net.Core/Support/ByteBuffer.cs       |    520 +
 src/Lucene.Net.Core/Support/CRC32.cs            |     83 +
 src/Lucene.Net.Core/Support/Character.cs        |    199 +
 .../Support/CloseableThreadLocalProfiler.cs     |     45 +
 .../Support/CollectionsHelper.cs                |    377 +
 src/Lucene.Net.Core/Support/Compare.cs          |     49 +
 .../Compatibility/ConcurrentDictionary.cs       |    306 +
 .../Support/Compatibility/Func.cs               |     12 +
 .../Support/Compatibility/ISet.cs               |     52 +
 .../Support/Compatibility/SetFactory.cs         |     42 +
 .../Support/Compatibility/SortedSet.cs          |    186 +
 .../Support/Compatibility/ThreadLocal.cs        |     55 +
 .../Support/Compatibility/WrappedHashSet.cs     |     43 +
 .../Support/ConcurrentHashMap.cs                |     29 +
 .../Support/ConcurrentHashMapWrapper.cs         |    227 +
 .../Support/ConcurrentHashSet.cs                |    284 +
 src/Lucene.Net.Core/Support/ConcurrentList.cs   |    191 +
 src/Lucene.Net.Core/Support/Cryptography.cs     |     45 +
 src/Lucene.Net.Core/Support/Deflater.cs         |    141 +
 src/Lucene.Net.Core/Support/Double.cs           |     44 +
 src/Lucene.Net.Core/Support/EquatableList.cs    |    351 +
 .../Support/FileStreamExtensions.cs             |     34 +
 src/Lucene.Net.Core/Support/FileSupport.cs      |    121 +
 .../Support/GeneralKeyedCollection.cs           |    114 +
 src/Lucene.Net.Core/Support/HashCodeMerge.cs    |     90 +
 src/Lucene.Net.Core/Support/HashMap.cs          |    469 +
 src/Lucene.Net.Core/Support/ICallable.cs        |      7 +
 src/Lucene.Net.Core/Support/ICharSequence.cs    |     11 +
 src/Lucene.Net.Core/Support/IChecksum.cs        |     35 +
 .../Support/ICompletionService.cs               |     15 +
 .../Support/IDictionaryExtensions.cs            |     25 +
 src/Lucene.Net.Core/Support/IThreadRunnable.cs  |     36 +
 src/Lucene.Net.Core/Support/IdentityComparer.cs |     18 +
 src/Lucene.Net.Core/Support/IdentityHashMap.cs  |     10 +
 src/Lucene.Net.Core/Support/IdentityHashSet.cs  |     17 +
 .../Support/IdentityWeakReference.cs            |     53 +
 src/Lucene.Net.Core/Support/Inflater.cs         |    115 +
 src/Lucene.Net.Core/Support/ListExtensions.cs   |    202 +
 src/Lucene.Net.Core/Support/MathExtension.cs    |     17 +
 .../Support/MemoryMappedFileByteBuffer.cs       |    279 +
 src/Lucene.Net.Core/Support/Number.cs           |    469 +
 src/Lucene.Net.Core/Support/OS.cs               |     62 +
 src/Lucene.Net.Core/Support/PriorityQueue.cs    |    355 +
 src/Lucene.Net.Core/Support/ReentrantLock.cs    |     58 +
 src/Lucene.Net.Core/Support/SetExtensions.cs    |     23 +
 src/Lucene.Net.Core/Support/SharpZipLib.cs      |     51 +
 src/Lucene.Net.Core/Support/Single.cs           |    136 +
 .../Support/StringBuilderExtensions.cs          |     25 +
 .../Support/StringCharSequenceWrapper.cs        |     47 +
 src/Lucene.Net.Core/Support/StringSupport.cs    |     19 +
 src/Lucene.Net.Core/Support/StringTokenizer.cs  |    237 +
 .../Support/TaskSchedulerCompletionService.cs   |     28 +
 .../Support/TextReaderWrapper.cs                |     25 +
 src/Lucene.Net.Core/Support/TextSupport.cs      |     49 +
 src/Lucene.Net.Core/Support/ThreadClass.cs      |    318 +
 src/Lucene.Net.Core/Support/ThreadFactory.cs    |      9 +
 src/Lucene.Net.Core/Support/ThreadLock.cs       |     83 +
 src/Lucene.Net.Core/Support/TimeHelper.cs       |     12 +
 .../Support/UnmodifiableDictionary.cs           |    109 +
 src/Lucene.Net.Core/Support/WeakDictionary.cs   |    302 +
 .../Util/ArrayInPlaceMergeSorter.cs             |     49 +
 src/Lucene.Net.Core/Util/ArrayIntroSorter.cs    |     64 +
 src/Lucene.Net.Core/Util/ArrayTimSorter.cs      |     81 +
 src/Lucene.Net.Core/Util/ArrayUtil.cs           |    899 +
 src/Lucene.Net.Core/Util/Attribute.cs           |    191 +
 src/Lucene.Net.Core/Util/AttributeImpl.cs       |    173 +
 src/Lucene.Net.Core/Util/AttributeSource.cs     |    670 +
 src/Lucene.Net.Core/Util/Automaton/Automaton.cs |    961 +
 .../Util/Automaton/AutomatonProvider.cs         |     48 +
 .../Util/Automaton/BasicAutomata.cs             |    354 +
 .../Util/Automaton/BasicOperations.cs           |   1118 +
 .../Util/Automaton/ByteRunAutomaton.cs          |     55 +
 .../Util/Automaton/CharacterRunAutomaton.cs     |     63 +
 .../Util/Automaton/CompiledAutomaton.cs         |    504 +
 .../Automaton/DaciukMihovAutomatonBuilder.cs    |    366 +
 .../Util/Automaton/Lev1ParametricDescription.cs |    122 +
 .../Automaton/Lev1TParametricDescription.cs     |    125 +
 .../Util/Automaton/Lev2ParametricDescription.cs |    175 +
 .../Automaton/Lev2TParametricDescription.cs     |    192 +
 .../Util/Automaton/LevenshteinAutomata.cs       |    313 +
 .../Util/Automaton/MinimizationOperations.cs    |    321 +
 src/Lucene.Net.Core/Util/Automaton/RegExp.cs    |   1270 +
 .../Util/Automaton/RunAutomaton.cs              |    279 +
 .../Util/Automaton/SortedIntSet.cs              |    426 +
 .../Util/Automaton/SpecialOperations.cs         |    344 +
 src/Lucene.Net.Core/Util/Automaton/State.cs     |    392 +
 src/Lucene.Net.Core/Util/Automaton/StatePair.cs |    113 +
 .../Util/Automaton/Transition.cs                |    304 +
 .../Util/Automaton/UTF32ToUTF8.cs               |    377 +
 .../Util/AverageGuessMemoryModel.cs             |     90 +
 src/Lucene.Net.Core/Util/BitUtil.cs             |    189 +
 src/Lucene.Net.Core/Util/BitVector.cs           |    315 +
 src/Lucene.Net.Core/Util/Bits.cs                |     92 +
 src/Lucene.Net.Core/Util/BroadWord.cs           |    168 +
 src/Lucene.Net.Core/Util/ByteBlockPool.cs       |    422 +
 src/Lucene.Net.Core/Util/BytesRef.cs            |    464 +
 src/Lucene.Net.Core/Util/BytesRefArray.cs       |    240 +
 src/Lucene.Net.Core/Util/BytesRefHash.cs        |    648 +
 src/Lucene.Net.Core/Util/BytesRefIterator.cs    |    160 +
 src/Lucene.Net.Core/Util/Cache/Cache.cs         |    129 +
 .../Util/Cache/SimpleLRUCache.cs                |    166 +
 .../Util/Cache/SimpleMapCache.cs                |    141 +
 src/Lucene.Net.Core/Util/CharsRef.cs            |    401 +
 .../Util/CloseableThreadLocal-old.cs            |    104 +
 .../Util/CloseableThreadLocal.cs                |    177 +
 src/Lucene.Net.Core/Util/CollectionUtil.cs      |    205 +
 src/Lucene.Net.Core/Util/CommandLineUtil.cs     |    117 +
 src/Lucene.Net.Core/Util/Constants.cs           |    207 +
 src/Lucene.Net.Core/Util/Counter.cs             |    102 +
 src/Lucene.Net.Core/Util/DocIdBitSet.cs         |    120 +
 .../Util/DoubleBarrelLRUCache.cs                |    146 +
 .../Util/FieldCacheSanityChecker.cs             |    493 +
 src/Lucene.Net.Core/Util/FilterIterator.cs      |     97 +
 src/Lucene.Net.Core/Util/FixedBitSet.cs         |    742 +
 src/Lucene.Net.Core/Util/Fst/Builder.cs         |    739 +
 .../Util/Fst/ByteSequenceOutputs.cs             |    171 +
 src/Lucene.Net.Core/Util/Fst/BytesRefFSTEnum.cs |    155 +
 src/Lucene.Net.Core/Util/Fst/BytesStore.cs      |    582 +
 .../Util/Fst/CharSequenceOutputs.cs             |    178 +
 src/Lucene.Net.Core/Util/Fst/FST.cs             |   2402 +
 src/Lucene.Net.Core/Util/Fst/FSTEnum.cs         |    623 +
 .../Util/Fst/ForwardBytesReader.cs              |     70 +
 .../Util/Fst/IntSequenceOutputs.cs              |    177 +
 src/Lucene.Net.Core/Util/Fst/IntsRefFSTEnum.cs  |    155 +
 src/Lucene.Net.Core/Util/Fst/NoOutputs.cs       |    122 +
 src/Lucene.Net.Core/Util/Fst/NodeHash.cs        |    203 +
 src/Lucene.Net.Core/Util/Fst/Outputs.cs         |     99 +
 src/Lucene.Net.Core/Util/Fst/PairOutputs.cs     |    193 +
 .../Util/Fst/PositiveIntOutputs.cs              |    149 +
 .../Util/Fst/ReverseBytesReader.cs              |     67 +
 src/Lucene.Net.Core/Util/Fst/Util.cs            |   1170 +
 .../Util/GrowableByteArrayDataOutput.cs         |     61 +
 src/Lucene.Net.Core/Util/IAttribute.cs          |     24 +
 src/Lucene.Net.Core/Util/IAttributeReflector.cs |     12 +
 src/Lucene.Net.Core/Util/IBoostAttribute.cs     |      9 +
 src/Lucene.Net.Core/Util/IOUtils.cs             |    474 +
 src/Lucene.Net.Core/Util/IdentityDictionary.cs  |     64 +
 src/Lucene.Net.Core/Util/InPlaceMergeSorter.cs  |     55 +
 .../Util/IndexableBinaryStringTools.cs          |    260 +
 src/Lucene.Net.Core/Util/InfoStream.cs          |    109 +
 src/Lucene.Net.Core/Util/IntBlockPool.cs        |    431 +
 src/Lucene.Net.Core/Util/IntroSorter.cs         |    123 +
 src/Lucene.Net.Core/Util/IntsRef.cs             |    266 +
 src/Lucene.Net.Core/Util/LongBitSet.cs          |    452 +
 src/Lucene.Net.Core/Util/LongValues.cs          |     41 +
 src/Lucene.Net.Core/Util/LongsRef.cs            |    266 +
 src/Lucene.Net.Core/Util/MapOfSets.cs           |     86 +
 src/Lucene.Net.Core/Util/MathUtil.cs            |    176 +
 src/Lucene.Net.Core/Util/MemoryModel.cs         |     44 +
 src/Lucene.Net.Core/Util/MergedIterator.cs      |    293 +
 .../Util/Mutable/MutableValue.cs                |     87 +
 .../Util/Mutable/MutableValueBool.cs            |     73 +
 .../Util/Mutable/MutableValueDate.cs            |     41 +
 .../Util/Mutable/MutableValueDouble.cs          |     81 +
 .../Util/Mutable/MutableValueFloat.cs           |     76 +
 .../Util/Mutable/MutableValueInt.cs             |     81 +
 .../Util/Mutable/MutableValueLong.cs            |     78 +
 .../Util/Mutable/MutableValueStr.cs             |     74 +
 src/Lucene.Net.Core/Util/MutableBits.cs         |     32 +
 src/Lucene.Net.Core/Util/NamedSPILoader.cs      |    146 +
 src/Lucene.Net.Core/Util/NamedThreadFactory.cs  |     68 +
 src/Lucene.Net.Core/Util/NumericUtils.cs        |    536 +
 src/Lucene.Net.Core/Util/OfflineSorter.cs       |    703 +
 src/Lucene.Net.Core/Util/OpenBitSet.cs          |   1124 +
 src/Lucene.Net.Core/Util/OpenBitSetDISI.cs      |    119 +
 src/Lucene.Net.Core/Util/OpenBitSetIterator.cs  |    177 +
 src/Lucene.Net.Core/Util/PForDeltaDocIdSet.cs   |    616 +
 .../Util/Packed/AbstractAppendingLongBuffer.cs  |    247 +
 .../Util/Packed/AbstractBlockPackedWriter.cs    |    159 +
 .../Util/Packed/AbstractPagedMutable.cs         |    182 +
 .../Packed/AppendingDeltaPackedLongBuffer.cs    |    155 +
 .../Util/Packed/AppendingPackedLongBuffer.cs    |    111 +
 .../Util/Packed/BlockPackedReader.cs            |    103 +
 .../Util/Packed/BlockPackedReaderIterator.cs    |    298 +
 .../Util/Packed/BlockPackedWriter.cs            |    114 +
 .../Util/Packed/BulkOperation.cs                |    123 +
 .../Util/Packed/BulkOperationPacked.cs          |    309 +
 .../Util/Packed/BulkOperationPacked1.cs         |     88 +
 .../Util/Packed/BulkOperationPacked10.cs        |    152 +
 .../Util/Packed/BulkOperationPacked11.cs        |    248 +
 .../Util/Packed/BulkOperationPacked12.cs        |    108 +
 .../Util/Packed/BulkOperationPacked13.cs        |    256 +
 .../Util/Packed/BulkOperationPacked14.cs        |    160 +
 .../Util/Packed/BulkOperationPacked15.cs        |    264 +
 .../Util/Packed/BulkOperationPacked16.cs        |     72 +
 .../Util/Packed/BulkOperationPacked17.cs        |    272 +
 .../Util/Packed/BulkOperationPacked18.cs        |    168 +
 .../Util/Packed/BulkOperationPacked19.cs        |    280 +
 .../Util/Packed/BulkOperationPacked2.cs         |     80 +
 .../Util/Packed/BulkOperationPacked20.cs        |    116 +
 .../Util/Packed/BulkOperationPacked21.cs        |    288 +
 .../Util/Packed/BulkOperationPacked22.cs        |    176 +
 .../Util/Packed/BulkOperationPacked23.cs        |    296 +
 .../Util/Packed/BulkOperationPacked24.cs        |     90 +
 .../Util/Packed/BulkOperationPacked3.cs         |    216 +
 .../Util/Packed/BulkOperationPacked4.cs         |     76 +
 .../Util/Packed/BulkOperationPacked5.cs         |    224 +
 .../Util/Packed/BulkOperationPacked6.cs         |    144 +
 .../Util/Packed/BulkOperationPacked7.cs         |    232 +
 .../Util/Packed/BulkOperationPacked8.cs         |     72 +
 .../Util/Packed/BulkOperationPacked9.cs         |    240 +
 .../Packed/BulkOperationPackedSingleBlock.cs    |    189 +
 src/Lucene.Net.Core/Util/Packed/Direct16.cs     |    125 +
 src/Lucene.Net.Core/Util/Packed/Direct32.cs     |    125 +
 src/Lucene.Net.Core/Util/Packed/Direct64.cs     |    112 +
 src/Lucene.Net.Core/Util/Packed/Direct8.cs      |    122 +
 .../Packed/DirectPacked64SingleBlockReader.cs   |     63 +
 .../Util/Packed/DirectPackedReader.cs           |    120 +
 .../Util/Packed/EliasFanoDecoder.cs             |    558 +
 .../Util/Packed/EliasFanoDocIdSet.cs            |    142 +
 .../Util/Packed/EliasFanoEncoder.cs             |    391 +
 .../Util/Packed/GrowableWriter.cs               |    163 +
 .../Util/Packed/MonotonicAppendingLongBuffer.cs |    189 +
 .../Util/Packed/MonotonicBlockPackedReader.cs   |    108 +
 .../Util/Packed/MonotonicBlockPackedWriter.cs   |    103 +
 .../Util/Packed/Packed16ThreeBlocks.cs          |    137 +
 src/Lucene.Net.Core/Util/Packed/Packed64.cs     |    380 +
 .../Util/Packed/Packed64SingleBlock.cs          |    627 +
 .../Util/Packed/Packed8ThreeBlocks.cs           |    134 +
 .../Util/Packed/PackedDataInput.cs              |     77 +
 .../Util/Packed/PackedDataOutput.cs             |     80 +
 src/Lucene.Net.Core/Util/Packed/PackedInts.cs   |   1569 +
 .../Util/Packed/PackedReaderIterator.cs         |    101 +
 src/Lucene.Net.Core/Util/Packed/PackedWriter.cs |    105 +
 .../Util/Packed/PagedGrowableWriter.cs          |     71 +
 src/Lucene.Net.Core/Util/Packed/PagedMutable.cs |     74 +
 src/Lucene.Net.Core/Util/PagedBytes.cs          |    525 +
 .../Util/PrintStreamInfoStream.cs               |     76 +
 src/Lucene.Net.Core/Util/PriorityQueue.cs       |    316 +
 src/Lucene.Net.Core/Util/QueryBuilder.cs        |    484 +
 src/Lucene.Net.Core/Util/RamUsageEstimator.cs   |    920 +
 src/Lucene.Net.Core/Util/ReaderUtil.cs          |    122 +
 .../Util/RecyclingByteBlockAllocator.cs         |    169 +
 .../Util/RecyclingIntBlockAllocator.cs          |    169 +
 src/Lucene.Net.Core/Util/RefCount.cs            |    109 +
 src/Lucene.Net.Core/Util/RollingBuffer.cs       |    174 +
 src/Lucene.Net.Core/Util/SPIClassIterator.cs    |    252 +
 src/Lucene.Net.Core/Util/ScorerDocQueue.cs      |    275 +
 src/Lucene.Net.Core/Util/SentinelIntSet.cs      |    204 +
 src/Lucene.Net.Core/Util/SetOnce.cs             |     96 +
 .../Util/SimpleStringInterner.cs                |     95 +
 src/Lucene.Net.Core/Util/SloppyMath.cs          |    298 +
 src/Lucene.Net.Core/Util/SmallFloat.cs          |    159 +
 src/Lucene.Net.Core/Util/SortedVIntList.cs      |    289 +
 src/Lucene.Net.Core/Util/Sorter.cs              |    340 +
 src/Lucene.Net.Core/Util/SorterTemplate.cs      |    224 +
 src/Lucene.Net.Core/Util/StringHelper.cs        |    277 +
 src/Lucene.Net.Core/Util/StringInterner.cs      |     44 +
 .../Util/ThreadInterruptedException.cs          |     35 +
 src/Lucene.Net.Core/Util/TimSorter.cs           |    471 +
 src/Lucene.Net.Core/Util/ToStringUtils.cs       |     71 +
 src/Lucene.Net.Core/Util/UnicodeUtil.cs         |    686 +
 src/Lucene.Net.Core/Util/Version.cs             |    216 +
 src/Lucene.Net.Core/Util/VirtualMethod.cs       |    161 +
 src/Lucene.Net.Core/Util/WAH8DocIdSet.cs        |    910 +
 src/Lucene.Net.Core/Util/WeakIdentityMap.cs     |    389 +
 src/Lucene.Net.Core/lucene.net.project.nuspec   |     21 +
 src/Lucene.Net.Core/packages.config             |      4 +
 .../Analysis/BaseTokenStreamTestCase.cs         |   1130 +
 .../Analysis/CannedBinaryTokenStream.cs         |    154 +
 .../Analysis/CannedTokenStream.cs               |     95 +
 .../Analysis/CollationTestBase.cs               |    358 +
 .../Analysis/LookaheadTokenFilter.cs            |    374 +
 .../Analysis/MockAnalyzer.cs                    |    210 +
 .../Analysis/MockBytesAnalyzer.cs               |     35 +
 .../Analysis/MockBytesAttributeFactory.cs       |     37 +
 .../Analysis/MockCharFilter.cs                  |    110 +
 .../Analysis/MockFixedLengthPayloadFilter.cs    |     62 +
 .../Analysis/MockGraphTokenFilter.cs            |    135 +
 .../Analysis/MockHoleInjectingTokenFilter.cs    |     85 +
 .../Analysis/MockPayloadAnalyzer.cs             |     99 +
 .../Analysis/MockRandomLookaheadTokenFilter.cs  |    117 +
 .../Analysis/MockReaderWrapper.cs               |    122 +
 .../Analysis/MockTokenFilter.cs                 |     97 +
 .../Analysis/MockTokenizer.cs                   |    353 +
 .../Analysis/MockUTF16TermAttributeImpl.cs      |     44 +
 .../Analysis/MockVariableLengthPayloadFilter.cs |     60 +
 .../Analysis/TokenStreamToDot.cs                |    186 +
 .../Analysis/ValidatingTokenFilter.cs           |    199 +
 .../Analysis/VocabularyAssert.cs                |     85 +
 .../Codecs/MissingOrdRemapper.cs                |    260 +
 .../Codecs/asserting/AssertingCodec.cs          |     63 +
 .../asserting/AssertingDocValuesFormat.cs       |    344 +
 .../Codecs/asserting/AssertingNormsFormat.cs    |     51 +
 .../Codecs/asserting/AssertingPostingsFormat.cs |    314 +
 .../asserting/AssertingStoredFieldsFormat.cs    |    154 +
 .../asserting/AssertingTermVectorsFormat.cs     |    208 +
 .../Codecs/compressing/CompressingCodec.cs      |    112 +
 .../Codecs/compressing/FastCompressingCodec.cs  |     46 +
 .../FastDecompressionCompressingCodec.cs        |     46 +
 .../HighCompressionCompressingCodec.cs          |     46 +
 .../compressing/dummy/DummyCompressingCodec.cs  |    112 +
 .../Codecs/lucene3x/PreFlexRWCodec.cs           |    107 +
 .../lucene3x/PreFlexRWFieldInfosFormat.cs       |     43 +
 .../lucene3x/PreFlexRWFieldInfosReader.cs       |    132 +
 .../lucene3x/PreFlexRWFieldInfosWriter.cs       |    129 +
 .../Codecs/lucene3x/PreFlexRWFieldsWriter.cs    |    272 +
 .../Codecs/lucene3x/PreFlexRWNormsConsumer.cs   |    112 +
 .../Codecs/lucene3x/PreFlexRWNormsFormat.cs     |     33 +
 .../Codecs/lucene3x/PreFlexRWPostingsFormat.cs  |     90 +
 .../lucene3x/PreFlexRWSegmentInfoFormat.cs      |     35 +
 .../lucene3x/PreFlexRWSegmentInfoWriter.cs      |     45 +
 .../Codecs/lucene3x/PreFlexRWSkipListWriter.cs  |    138 +
 .../lucene3x/PreFlexRWStoredFieldsFormat.cs     |     32 +
 .../lucene3x/PreFlexRWStoredFieldsWriter.cs     |    210 +
 .../lucene3x/PreFlexRWTermVectorsFormat.cs      |     77 +
 .../lucene3x/PreFlexRWTermVectorsWriter.cs      |    239 +
 .../Codecs/lucene3x/TermInfosWriter.cs          |    329 +
 .../Codecs/lucene40/Lucene40DocValuesWriter.cs  |    620 +
 .../Codecs/lucene40/Lucene40FieldInfosWriter.cs |    133 +
 .../Codecs/lucene40/Lucene40PostingsWriter.cs   |    378 +
 .../Codecs/lucene40/Lucene40RWCodec.cs          |     68 +
 .../lucene40/Lucene40RWDocValuesFormat.cs       |     41 +
 .../Codecs/lucene40/Lucene40RWNormsFormat.cs    |     41 +
 .../Codecs/lucene40/Lucene40RWPostingsFormat.cs |     59 +
 .../Codecs/lucene40/Lucene40SkipListWriter.cs   |    168 +
 .../Codecs/lucene41/Lucene41RWCodec.cs          |     79 +
 .../lucene42/Lucene42DocValuesConsumer.cs       |    472 +
 .../Codecs/lucene42/Lucene42FieldInfosWriter.cs |    144 +
 .../Codecs/lucene42/Lucene42RWCodec.cs          |     69 +
 .../lucene42/Lucene42RWDocValuesFormat.cs       |     42 +
 .../Codecs/lucene45/Lucene45RWCodec.cs          |     58 +
 .../Codecs/ramonly/RAMOnlyPostingsFormat.cs     |    726 +
 .../Index/AlcoholicMergePolicy.cs               |     81 +
 .../Index/AllDeletedFilterReader.cs             |     51 +
 .../Index/AssertingAtomicReader.cs              |    781 +
 .../Index/AssertingDirectoryReader.cs           |     60 +
 .../BaseCompressingDocValuesFormatTestCase.cs   |    141 +
 .../Index/BaseDocValuesFormatTestCase.cs        |   3513 +
 .../Index/BaseIndexFileFormatTestCase.cs        |    128 +
 .../Index/BaseMergePolicyTestCase.cs            |     95 +
 .../Index/BasePostingsFormatTestCase.cs         |   1331 +
 .../Index/BaseStoredFieldsFormatTestCase.cs     |    779 +
 .../Index/BaseTermVectorsFormatTestCase.cs      |    948 +
 src/Lucene.Net.TestFramework/Index/DocHelper.cs |    318 +
 .../Index/FieldFilterAtomicReader.cs            |    218 +
 .../Index/MockIndexInput.cs                     |     73 +
 .../Index/MockRandomMergePolicy.cs              |    131 +
 .../Index/RandomCodec.cs                        |    210 +
 .../Index/RandomDocumentsWriterPerThreadPool.cs |    103 +
 .../Index/RandomIndexWriter.cs                  |    556 +
 .../ThreadedIndexingAndSearchingTestCase.cs     |    855 +
 .../JavaCompatibility/LuceneTestCase.cs         |    109 +
 .../JavaCompatibility/LuceneTypesHelpers.cs     |      9 +
 .../JavaCompatibility/RandomHelpers.cs          |     12 +
 .../JavaCompatibility/SystemTypesHelpers.cs     |     56 +
 .../Lucene.Net.TestFramework.csproj             |    492 +
 .../Properties/AssemblyInfo.cs                  |     36 +
 .../Randomized/Attributes/SeedAttribute.cs      |     32 +
 .../Attributes/SeedDecoratorAttribute.cs        |     40 +
 .../Attributes/ThreadLeakScopeAttribute.cs      |     39 +
 .../Randomized/Generators/RandomInts.cs         |     50 +
 .../Randomized/ISeedDecorator.cs                |     28 +
 .../Randomized/IllegalStateException.cs         |     69 +
 .../InternalAssumptionViolatedException.cs      |     38 +
 .../Randomized/MurmurHash3.cs                   |     39 +
 .../Randomized/RandomizedContext.cs             |    173 +
 .../Randomized/RandomizedRunner.cs              |     64 +
 .../Randomized/Randomness.cs                    |     96 +
 .../Randomized/SeedUtils.cs                     |     75 +
 .../Randomized/SingleThreadedRandom.cs          |    130 +
 .../Randomized/ThreadGroup.cs                   |    132 +
 .../Search/AssertingBulkOutOfOrderScorer.cs     |     57 +
 .../Search/AssertingBulkScorer.cs               |     95 +
 .../Search/AssertingCollector.cs                |     81 +
 .../Search/AssertingIndexSearcher.cs            |    124 +
 .../Search/AssertingQuery.cs                    |    109 +
 .../Search/AssertingScorer.cs                   |    154 +
 .../Search/AssertingWeight.cs                   |    117 +
 .../Search/CheckHits.cs                         |    558 +
 .../Search/QueryUtils.cs                        |    532 +
 .../Search/RandomOrderCollector.cs              |    130 +
 .../Search/RandomSimilarityProvider.cs          |    199 +
 .../Search/SearchEquivalenceTestBase.cs         |    219 +
 .../Search/ShardSearchingTestBase.cs            |    779 +
 .../Store/BaseDirectoryWrapper.cs               |     96 +
 .../Store/MockDirectoryWrapper.cs               |   1423 +
 .../Store/MockIndexInputWrapper.cs              |    190 +
 .../Store/MockIndexOutputWrapper.cs             |    214 +
 .../Store/MockLockFactoryWrapper.cs             |    105 +
 .../Store/SlowClosingMockIndexInputWrapper.cs   |     53 +
 .../Store/SlowOpeningMockIndexInputWrapper.cs   |     51 +
 .../Store/TestHelper.cs                         |     79 +
 .../Support/RandomizedTest.cs                   |     48 +
 .../Support/SystemProperties.cs                 |     22 +
 .../Util/AbstractBeforeAfterRule.cs             |     92 +
 .../Util/BaseDocIdSetTestCase.cs                |    235 +
 .../Util/CloseableDirectory.cs                  |     61 +
 src/Lucene.Net.TestFramework/Util/English.cs    |    236 +
 .../Util/FailOnNonBulkMergesInfoStream.cs       |     41 +
 .../Util/FailureMarker.cs                       |     57 +
 .../Util/LineFileDocs.cs                        |    301 +
 .../Util/LuceneTestCase.cs                      |   2757 +
 .../Util/NullInfoStream.cs                      |     45 +
 src/Lucene.Net.TestFramework/Util/Paths.cs      |    197 +
 .../Util/QuickPatchThreadsFilter.cs             |     52 +
 .../Util/RemoveUponClose.cs                     |     69 +
 .../Util/RunListenerPrintReproduceInfo.cs       |    245 +
 .../Util/TestRuleAssertionsRequired.cs          |     71 +
 .../Util/TestRuleDelegate.cs                    |     51 +
 .../Util/TestRuleFieldCacheSanity.cs            |     91 +
 .../Util/TestRuleIgnoreAfterMaxFailures.cs      |     85 +
 .../Util/TestRuleIgnoreTestSuites.cs            |     91 +
 .../Util/TestRuleMarkFailure.cs                 |    152 +
 .../Util/TestRuleSetupAndRestoreClassEnv.cs     |    538 +
 .../Util/TestRuleSetupAndRestoreInstanceEnv.cs  |     42 +
 .../Util/TestRuleSetupTeardownChained.cs        |     77 +
 .../Util/TestRuleStoreClassName.cs              |     90 +
 .../Util/TestRuleThreadAndTestName.cs           |     79 +
 .../Util/TestSecurityManager.cs                 |    109 +
 src/Lucene.Net.TestFramework/Util/TestUtil.cs   |   1432 +
 .../Util/ThrottledIndexOutput.cs                |    183 +
 src/Lucene.Net.TestFramework/Util/TimeUnits.cs  |     40 +
 .../Util/automaton/AutomatonTestUtil.cs         |    573 +
 .../Util/fst/FSTTester.cs                       |    994 +
 src/Lucene.Net.TestFramework/packages.config    |      6 +
 src/Lucene.Net.Tests/Lucene.Net.Tests.csproj    |    604 +
 .../core/Analysis/TestCachingTokenFilter.cs     |    137 +
 .../core/Analysis/TestCharFilter.cs             |     94 +
 .../core/Analysis/TestGraphTokenizers.cs        |    726 +
 .../core/Analysis/TestLookaheadTokenFilter.cs   |    120 +
 .../core/Analysis/TestMockAnalyzer.cs           |    414 +
 .../core/Analysis/TestMockCharFilter.cs         |     59 +
 .../core/Analysis/TestNumericTokenStream.cs     |    144 +
 .../core/Analysis/TestPosition.cs               |     27 +
 .../core/Analysis/TestReusableStringReader.cs   |     67 +
 src/Lucene.Net.Tests/core/Analysis/TestToken.cs |    304 +
 .../TestCharTermAttributeImpl.cs                |    396 +
 .../Tokenattributes/TestSimpleAttributeImpl.cs  |     67 +
 .../core/Analysis/TrivialLookaheadFilter.cs     |    109 +
 src/Lucene.Net.Tests/core/App.config            |     44 +
 src/Lucene.Net.Tests/core/AssemblyInfo.cs       |     82 +
 .../Compressing/AbstractTestCompressionMode.cs  |    179 +
 .../AbstractTestLZ4CompressionMode.cs           |    131 +
 .../TestCompressingStoredFieldsFormat.cs        |    101 +
 .../TestCompressingTermVectorsFormat.cs         |     86 +
 .../Compressing/TestFastCompressionMode.cs      |     32 +
 .../Compressing/TestFastDecompressionMode.cs    |     42 +
 .../Compressing/TestHighCompressionMode.cs      |     32 +
 .../core/Codecs/Lucene3x/TestImpersonation.cs   |     39 +
 .../Lucene3x/TestLucene3xPostingsFormat.cs      |     46 +
 .../Lucene3x/TestLucene3xStoredFieldsFormat.cs  |     51 +
 .../Lucene3x/TestLucene3xTermVectorsFormat.cs   |     49 +
 .../core/Codecs/Lucene3x/TestSurrogates.cs      |    412 +
 .../Codecs/Lucene3x/TestTermInfosReaderIndex.cs |    228 +
 .../core/Codecs/Lucene40/TestBitVector.cs       |    325 +
 .../Lucene40/TestLucene40DocValuesFormat.cs     |     51 +
 .../Lucene40/TestLucene40PostingsFormat.cs      |     45 +
 .../Lucene40/TestLucene40PostingsReader.cs      |    161 +
 .../Lucene40/TestLucene40StoredFieldsFormat.cs  |     40 +
 .../Lucene40/TestLucene40TermVectorsFormat.cs   |     40 +
 .../core/Codecs/Lucene40/TestReuseDocsEnum.cs   |    217 +
 .../Codecs/Lucene41/TestBlockPostingsFormat.cs  |     38 +
 .../Codecs/Lucene41/TestBlockPostingsFormat2.cs |    163 +
 .../Codecs/Lucene41/TestBlockPostingsFormat3.cs |    565 +
 .../core/Codecs/Lucene41/TestForUtil.cs         |     97 +
 .../Lucene41/TestLucene41StoredFieldsFormat.cs  |     40 +
 .../Lucene42/TestLucene42DocValuesFormat.cs     |     50 +
 .../Lucene45/TestLucene45DocValuesFormat.cs     |     38 +
 .../Perfield/TestPerFieldDocValuesFormat.cs     |    156 +
 .../Perfield/TestPerFieldPostingsFormat.cs      |     49 +
 .../Perfield/TestPerFieldPostingsFormat2.cs     |    380 +
 .../core/Document/TestBinaryDocument.cs         |    122 +
 .../core/Document/TestDateTools.cs              |    245 +
 .../core/Document/TestDocument.cs               |    457 +
 src/Lucene.Net.Tests/core/Document/TestField.cs |    594 +
 .../core/Index/BinaryTokenStream.cs             |    100 +
 .../core/Index/Test2BBinaryDocValues.cs         |    165 +
 src/Lucene.Net.Tests/core/Index/Test2BDocs.cs   |     96 +
 .../core/Index/Test2BNumericDocValues.cs        |     91 +
 .../core/Index/Test2BPositions.cs               |    122 +
 .../core/Index/Test2BPostings.cs                |    108 +
 .../core/Index/Test2BPostingsBytes.cs           |    155 +
 .../core/Index/Test2BSortedDocValues.cs         |    161 +
 src/Lucene.Net.Tests/core/Index/Test2BTerms.cs  |    311 +
 .../core/Index/Test4GBStoredFields.cs           |    115 +
 .../core/Index/TestAddIndexes.cs                |   1386 +
 .../Index/TestAllFilesHaveChecksumFooter.cs     |    113 +
 .../core/Index/TestAllFilesHaveCodecHeader.cs   |    118 +
 .../core/Index/TestAtomicUpdate.cs              |    216 +
 .../core/Index/TestBackwardsCompatibility.cs    |   1044 +
 .../core/Index/TestBackwardsCompatibility3x.cs  |   1017 +
 .../core/Index/TestBagOfPositions.cs            |    206 +
 .../core/Index/TestBagOfPostings.cs             |    188 +
 .../core/Index/TestBinaryDocValuesUpdates.cs    |   1737 +
 .../core/Index/TestBinaryTerms.cs               |     87 +
 .../core/Index/TestByteSlices.cs                |    134 +
 .../core/Index/TestCheckIndex.cs                |    128 +
 .../core/Index/TestCodecHoldsOpenFiles.cs       |    110 +
 src/Lucene.Net.Tests/core/Index/TestCodecs.cs   |    921 +
 .../core/Index/TestCompoundFile.cs              |    906 +
 .../core/Index/TestConcurrentMergeScheduler.cs  |    444 +
 .../core/Index/TestConsistentFieldNumbers.cs    |    420 +
 src/Lucene.Net.Tests/core/Index/TestCrash.cs    |    218 +
 .../core/Index/TestCrashCausesCorruptIndex.cs   |    199 +
 .../core/Index/TestCustomNorms.cs               |    141 +
 .../core/Index/TestDeletionPolicy.cs            |    797 +
 .../core/Index/TestDirectoryReader.cs           |   1297 +
 .../core/Index/TestDirectoryReaderReopen.cs     |    782 +
 src/Lucene.Net.Tests/core/Index/TestDoc.cs      |    277 +
 src/Lucene.Net.Tests/core/Index/TestDocCount.cs |     99 +
 .../Index/TestDocInverterPerFieldErrorInfo.cs   |    145 +
 .../core/Index/TestDocTermOrds.cs               |    535 +
 .../core/Index/TestDocValuesFormat.cs           |     42 +
 .../core/Index/TestDocValuesIndexing.cs         |    938 +
 .../core/Index/TestDocValuesWithThreads.cs      |    309 +
 .../core/Index/TestDocsAndPositions.cs          |    429 +
 .../core/Index/TestDocumentWriter.cs            |    408 +
 .../Index/TestDocumentsWriterDeleteQueue.cs     |    298 +
 .../Index/TestDocumentsWriterStallControl.cs    |    463 +
 .../core/Index/TestDuelingCodecs.cs             |    173 +
 .../core/Index/TestExceedMaxTermLength.cs       |    107 +
 .../core/Index/TestFieldInfos.cs                |    126 +
 .../core/Index/TestFieldsReader.cs              |    275 +
 .../core/Index/TestFilterAtomicReader.cs        |    221 +
 src/Lucene.Net.Tests/core/Index/TestFlex.cs     |     96 +
 .../core/Index/TestFlushByRamOrCountsPolicy.cs  |    481 +
 .../core/Index/TestForTooMuchCloning.cs         |     85 +
 .../core/Index/TestForceMergeForever.cs         |    144 +
 .../core/Index/TestIndexCommit.cs               |    191 +
 .../core/Index/TestIndexFileDeleter.cs          |    218 +
 .../core/Index/TestIndexInput.cs                |    185 +
 .../core/Index/TestIndexReaderClose.cs          |    152 +
 .../core/Index/TestIndexWriter.cs               |   2860 +
 .../core/Index/TestIndexWriterCommit.cs         |    739 +
 .../core/Index/TestIndexWriterConfig.cs         |    493 +
 .../core/Index/TestIndexWriterDelete.cs         |   1447 +
 .../core/Index/TestIndexWriterExceptions.cs     |   2601 +
 .../core/Index/TestIndexWriterForceMerge.cs     |    232 +
 .../core/Index/TestIndexWriterLockRelease.cs    |     61 +
 .../core/Index/TestIndexWriterMergePolicy.cs    |    303 +
 .../core/Index/TestIndexWriterMerging.cs        |    479 +
 .../core/Index/TestIndexWriterNRTIsCurrent.cs   |    254 +
 .../core/Index/TestIndexWriterOnDiskFull.cs     |    699 +
 .../core/Index/TestIndexWriterOnJRECrash.cs     |    278 +
 .../TestIndexWriterOutOfFileDescriptors.cs      |    196 +
 .../core/Index/TestIndexWriterReader.cs         |   1419 +
 .../core/Index/TestIndexWriterUnicode.cs        |    387 +
 .../core/Index/TestIndexWriterWithThreads.cs    |    783 +
 .../core/Index/TestIndexableField.cs            |    456 +
 .../core/Index/TestIntBlockPool.cs              |    188 +
 .../core/Index/TestIsCurrent.cs                 |    107 +
 .../core/Index/TestLazyProxSkipping.cs          |    258 +
 .../core/Index/TestLogMergePolicy.cs            |     27 +
 .../core/Index/TestLongPostings.cs              |    566 +
 .../core/Index/TestMaxTermFrequency.cs          |    169 +
 .../core/Index/TestMixedCodecs.cs               |    105 +
 .../core/Index/TestMixedDocValuesUpdates.cs     |    569 +
 .../core/Index/TestMultiDocValues.cs            |    437 +
 .../core/Index/TestMultiFields.cs               |    225 +
 .../core/Index/TestMultiLevelSkipList.cs        |    217 +
 .../core/Index/TestNRTReaderWithThreads.cs      |    142 +
 .../core/Index/TestNRTThreads.cs                |    185 +
 .../core/Index/TestNeverDelete.cs               |    145 +
 .../core/Index/TestNewestSegment.cs             |     39 +
 .../core/Index/TestNoDeletionPolicy.cs          |     91 +
 .../core/Index/TestNoMergePolicy.cs             |     81 +
 .../core/Index/TestNoMergeScheduler.cs          |     70 +
 src/Lucene.Net.Tests/core/Index/TestNorms.cs    |    250 +
 .../core/Index/TestNumericDocValuesUpdates.cs   |   1684 +
 .../core/Index/TestOmitNorms.cs                 |    329 +
 .../core/Index/TestOmitPositions.cs             |    292 +
 src/Lucene.Net.Tests/core/Index/TestOmitTf.cs   |    605 +
 .../core/Index/TestParallelAtomicReader.cs      |    348 +
 .../core/Index/TestParallelCompositeReader.cs   |    646 +
 .../core/Index/TestParallelReaderEmptyIndex.cs  |    162 +
 .../core/Index/TestParallelTermEnum.cs          |    126 +
 src/Lucene.Net.Tests/core/Index/TestPayloads.cs |    729 +
 .../core/Index/TestPayloadsOnVectors.cs         |    161 +
 .../core/Index/TestPerSegmentDeletes.cs         |    318 +
 .../TestPersistentSnapshotDeletionPolicy.cs     |    212 +
 .../core/Index/TestPostingsFormat.cs            |     45 +
 .../core/Index/TestPostingsOffsets.cs           |    572 +
 .../core/Index/TestPrefixCodedTerms.cs          |    142 +
 .../core/Index/TestReaderClosed.cs              |    114 +
 src/Lucene.Net.Tests/core/Index/TestRollback.cs |     66 +
 .../core/Index/TestRollingUpdates.cs            |    274 +
 .../core/Index/TestSameTokenSamePosition.cs     |    109 +
 .../core/Index/TestSegmentMerger.cs             |    205 +
 .../core/Index/TestSegmentReader.cs             |    267 +
 .../core/Index/TestSegmentTermDocs.cs           |    271 +
 .../core/Index/TestSegmentTermEnum.cs           |    149 +
 .../core/Index/TestSizeBoundedForceMerge.cs     |    401 +
 .../core/Index/TestSnapshotDeletionPolicy.cs    |    510 +
 .../core/Index/TestStoredFieldsFormat.cs        |     51 +
 .../core/Index/TestStressAdvance.cs             |    172 +
 .../core/Index/TestStressIndexing.cs            |    215 +
 .../core/Index/TestStressIndexing2.cs           |   1059 +
 .../core/Index/TestStressNRT.cs                 |    529 +
 .../core/Index/TestSumDocFreq.cs                |    111 +
 src/Lucene.Net.Tests/core/Index/TestTerm.cs     |     42 +
 .../core/Index/TestTermVectorsFormat.cs         |     62 +
 .../core/Index/TestTermVectorsReader.cs         |    482 +
 .../core/Index/TestTermVectorsWriter.cs         |    599 +
 .../core/Index/TestTermdocPerf.cs               |    174 +
 .../core/Index/TestTermsEnum.cs                 |   1051 +
 .../core/Index/TestTermsEnum2.cs                |    203 +
 .../core/Index/TestThreadedForceMerge.cs        |    183 +
 .../core/Index/TestTieredMergePolicy.cs         |    275 +
 .../core/Index/TestTransactionRollback.cs       |    273 +
 .../core/Index/TestTransactions.cs              |    316 +
 .../core/Index/TestTryDelete.cs                 |    196 +
 .../core/Index/TestTwoPhaseCommitTool.cs        |    176 +
 .../core/Lucene.Net.Tests.csproj                |    635 +
 src/Lucene.Net.Tests/core/Lucene.Net.snk        |    Bin 0 -> 596 bytes
 src/Lucene.Net.Tests/core/RectangularArrays.cs  |     52 +
 .../core/Search/BaseTestRangeFilter.cs          |    200 +
 .../core/Search/FuzzyTermOnShortTermsTest.cs    |    112 +
 .../core/Search/JustCompileSearch.cs            |    375 +
 src/Lucene.Net.Tests/core/Search/MockFilter.cs  |     44 +
 .../core/Search/MultiCollectorTest.cs           |    119 +
 .../core/Search/Payloads/PayloadHelper.cs       |    157 +
 .../Search/Payloads/TestPayloadExplanations.cs  |    117 +
 .../Search/Payloads/TestPayloadNearQuery.cs     |    385 +
 .../Search/Payloads/TestPayloadTermQuery.cs     |    362 +
 .../core/Search/Similarities/TestSimilarity2.cs |    274 +
 .../Search/Similarities/TestSimilarityBase.cs   |    650 +
 .../core/Search/SingleDocTestFilter.cs          |     44 +
 .../core/Search/Spans/JustCompileSearchSpans.cs |    171 +
 .../core/Search/Spans/MultiSpansWrapper.cs      |    209 +
 .../core/Search/Spans/TestBasics.cs             |    611 +
 .../Search/Spans/TestFieldMaskingSpanQuery.cs   |    321 +
 .../core/Search/Spans/TestNearSpansOrdered.cs   |    201 +
 .../core/Search/Spans/TestPayloadSpans.cs       |    590 +
 .../core/Search/Spans/TestSpanExplanations.cs   |    260 +
 .../Spans/TestSpanExplanationsOfNonMatches.cs   |     37 +
 .../core/Search/Spans/TestSpanFirstQuery.cs     |     72 +
 .../Spans/TestSpanMultiTermQueryWrapper.cs      |    243 +
 .../Search/Spans/TestSpanSearchEquivalence.cs   |    134 +
 .../core/Search/Spans/TestSpans.cs              |    570 +
 .../core/Search/Spans/TestSpansAdvanced.cs      |    170 +
 .../core/Search/Spans/TestSpansAdvanced2.cs     |    124 +
 .../core/Search/TestAutomatonQuery.cs           |    270 +
 .../core/Search/TestAutomatonQueryUnicode.cs    |    137 +
 .../core/Search/TestBoolean2.cs                 |    419 +
 .../core/Search/TestBooleanMinShouldMatch.cs    |    522 +
 .../core/Search/TestBooleanOr.cs                |    257 +
 .../core/Search/TestBooleanQuery.cs             |    405 +
 .../Search/TestBooleanQueryVisitSubscorers.cs   |    211 +
 .../core/Search/TestBooleanScorer.cs            |    344 +
 .../core/Search/TestCachingCollector.cs         |    260 +
 .../core/Search/TestCachingWrapperFilter.cs     |    512 +
 .../core/Search/TestComplexExplanations.cs      |    390 +
 .../TestComplexExplanationsOfNonMatches.cs      |     37 +
 .../core/Search/TestConjunctions.cs             |    162 +
 .../core/Search/TestConstantScoreQuery.cs       |    246 +
 .../TestControlledRealTimeReopenThread.cs       |    721 +
 .../core/Search/TestCustomSearcherSort.cs       |    261 +
 .../core/Search/TestDateFilter.cs               |    163 +
 .../core/Search/TestDateSort.cs                 |    123 +
 .../core/Search/TestDisjunctionMaxQuery.cs      |    569 +
 .../core/Search/TestDocBoost.cs                 |    127 +
 .../core/Search/TestDocIdSet.cs                 |    253 +
 .../core/Search/TestDocTermOrdsRangeFilter.cs   |    148 +
 .../core/Search/TestDocTermOrdsRewriteMethod.cs |    163 +
 .../core/Search/TestDocValuesScoring.cs         |    230 +
 .../core/Search/TestEarlyTermination.cs         |    130 +
 .../core/Search/TestElevationComparator.cs      |    239 +
 .../core/Search/TestExplanations.cs             |    263 +
 .../core/Search/TestFieldCache.cs               |    995 +
 .../core/Search/TestFieldCacheRangeFilter.cs    |    569 +
 .../core/Search/TestFieldCacheRewriteMethod.cs  |     64 +
 .../core/Search/TestFieldCacheTermsFilter.cs    |     79 +
 .../core/Search/TestFieldValueFilter.cs         |    125 +
 .../core/Search/TestFilteredQuery.cs            |    708 +
 .../core/Search/TestFilteredSearch.cs           |    112 +
 .../core/Search/TestFuzzyQuery.cs               |    385 +
 .../core/Search/TestIndexSearcher.cs            |    140 +
 .../core/Search/TestLiveFieldValues.cs          |    256 +
 .../core/Search/TestMatchAllDocsQuery.cs        |    113 +
 .../core/Search/TestMinShouldMatch2.cs          |    424 +
 .../core/Search/TestMultiPhraseQuery.cs         |    623 +
 .../core/Search/TestMultiTermConstantScore.cs   |    551 +
 .../core/Search/TestMultiTermQueryRewrites.cs   |    298 +
 .../core/Search/TestMultiThreadTermVectors.cs   |    243 +
 .../Search/TestMultiValuedNumericRangeQuery.cs  |     91 +
 .../core/Search/TestNGramPhraseQuery.cs         |    109 +
 src/Lucene.Net.Tests/core/Search/TestNot.cs     |     63 +
 .../core/Search/TestNumericRangeQuery32.cs      |    699 +
 .../core/Search/TestNumericRangeQuery64.cs      |    747 +
 .../core/Search/TestPhrasePrefixQuery.cs        |    107 +
 .../core/Search/TestPhraseQuery.cs              |    756 +
 .../core/Search/TestPositionIncrement.cs        |    321 +
 .../Search/TestPositiveScoresOnlyCollector.cs   |    118 +
 .../core/Search/TestPrefixFilter.cs             |    112 +
 .../core/Search/TestPrefixInBooleanQuery.cs     |    121 +
 .../core/Search/TestPrefixQuery.cs              |     73 +
 .../core/Search/TestPrefixRandom.cs             |    157 +
 .../core/Search/TestQueryRescorer.cs            |    612 +
 .../core/Search/TestQueryWrapperFilter.cs       |    166 +
 .../core/Search/TestRegexpQuery.cs              |    159 +
 .../core/Search/TestRegexpRandom.cs             |    160 +
 .../core/Search/TestRegexpRandom2.cs            |    202 +
 .../core/Search/TestSameScoresWithThreads.cs    |    158 +
 .../Search/TestScoreCachingWrappingScorer.cs    |    156 +
 .../core/Search/TestScorerPerf.cs               |    498 +
 .../core/Search/TestSearchAfter.cs              |    338 +
 .../core/Search/TestSearchWithThreads.cs        |    162 +
 .../core/Search/TestSearcherManager.cs          |    631 +
 .../core/Search/TestShardSearching.cs           |    487 +
 .../core/Search/TestSimilarity.cs               |    280 +
 .../core/Search/TestSimilarityProvider.cs       |    239 +
 .../core/Search/TestSimpleExplanations.cs       |    931 +
 .../TestSimpleExplanationsOfNonMatches.cs       |     37 +
 .../core/Search/TestSimpleSearchEquivalence.cs  |    231 +
 .../core/Search/TestSloppyPhraseQuery.cs        |    376 +
 .../core/Search/TestSloppyPhraseQuery2.cs       |    247 +
 src/Lucene.Net.Tests/core/Search/TestSort.cs    |   1929 +
 .../core/Search/TestSortDocValues.cs            |   1025 +
 .../core/Search/TestSortRandom.cs               |    365 +
 .../core/Search/TestSortRescorer.cs             |    218 +
 .../core/Search/TestSubScorerFreqs.cs           |    236 +
 .../core/Search/TestTermRangeFilter.cs          |    181 +
 .../core/Search/TestTermRangeQuery.cs           |    374 +
 .../core/Search/TestTermScorer.cs               |    208 +
 .../core/Search/TestTermVectors.cs              |    268 +
 .../core/Search/TestTopDocsCollector.cs         |    238 +
 .../core/Search/TestTopDocsMerge.cs             |    359 +
 .../core/Search/TestTopFieldCollector.cs        |    254 +
 .../core/Search/TestTopScoreDocCollector.cs     |     73 +
 .../core/Search/TestTotalHitCountCollector.cs   |     56 +
 .../core/Search/TestWildcard.cs                 |    374 +
 .../core/Search/TestWildcardRandom.cs           |    162 +
 .../core/Store/TestBufferedChecksum.cs          |     79 +
 .../core/Store/TestBufferedIndexInput.cs        |    404 +
 .../core/Store/TestByteArrayDataInput.cs        |     39 +
 .../core/Store/TestCopyBytes.cs                 |    200 +
 .../core/Store/TestDirectory.cs                 |    403 +
 .../core/Store/TestFileSwitchDirectory.cs       |    184 +
 .../core/Store/TestFilterDirectory.cs           |     48 +
 .../core/Store/TestHugeRamFile.cs               |    123 +
 src/Lucene.Net.Tests/core/Store/TestLock.cs     |     76 +
 .../core/Store/TestLockFactory.cs               |    503 +
 .../core/Store/TestMockDirectoryWrapper.cs      |    113 +
 .../core/Store/TestMultiMMap.cs                 |    402 +
 .../core/Store/TestNRTCachingDirectory.cs       |    221 +
 .../core/Store/TestRAMDirectory.cs              |    229 +
 .../core/Store/TestRateLimiter.cs               |     49 +
 .../core/Store/TestWindowsMMap.cs               |    116 +
 src/Lucene.Net.Tests/core/Support/BigObject.cs  |     35 +
 .../core/Support/CollisionTester.cs             |     50 +
 .../core/Support/SmallObject.cs                 |     33 +
 src/Lucene.Net.Tests/core/Support/TestCase.cs   |     54 +
 .../core/Support/TestCloseableThreadLocal.cs    |    108 +
 .../core/Support/TestEquatableList.cs           |    167 +
 .../core/Support/TestExceptionSerialization.cs  |    102 +
 .../core/Support/TestHashMap.cs                 |    213 +
 .../core/Support/TestIDisposable.cs             |     67 +
 .../core/Support/TestLRUCache.cs                |     47 +
 .../core/Support/TestOSClass.cs                 |     48 +
 .../core/Support/TestOldPatches.cs              |    292 +
 .../core/Support/TestSerialization.cs           |    102 +
 .../core/Support/TestSupportClass.cs            |     86 +
 .../core/Support/TestThreadClass.cs             |     59 +
 .../core/Support/TestWeakDictionary.cs          |    148 +
 .../core/Support/TestWeakDictionaryBehavior.cs  |    291 +
 .../Support/TestWeakDictionaryPerformance.cs    |    134 +
 .../core/SupportClassException.cs               |     47 +
 src/Lucene.Net.Tests/core/Test.nunit            |     22 +
 src/Lucene.Net.Tests/core/TestAssertions.cs     |     74 +
 src/Lucene.Net.Tests/core/TestDemo.cs           |     84 +
 src/Lucene.Net.Tests/core/TestExternalCodecs.cs |    154 +
 .../core/TestMergeSchedulerExternal.cs          |    179 +
 src/Lucene.Net.Tests/core/TestSearch.cs         |    208 +
 .../core/TestSearchForDuplicates.cs             |    158 +
 .../core/TestWorstCaseTestBehavior.cs           |    149 +
 .../core/Util/Automaton/TestBasicOperations.cs  |    180 +
 .../Util/Automaton/TestCompiledAutomaton.cs     |    147 +
 .../core/Util/Automaton/TestDeterminism.cs      |     92 +
 .../Util/Automaton/TestDeterminizeLexicon.cs    |     72 +
 .../Util/Automaton/TestLevenshteinAutomata.cs   |    435 +
 .../core/Util/Automaton/TestMinimize.cs         |     73 +
 .../Util/Automaton/TestSpecialOperations.cs     |     61 +
 .../core/Util/Automaton/TestUTF32ToUTF8.cs      |    286 +
 .../core/Util/BaseSortTestCase.cs               |     91 +
 .../core/Util/Cache/TestSimpleLRUCache.cs       |     77 +
 src/Lucene.Net.Tests/core/Util/Fst/Test2BFST.cs |    349 +
 .../core/Util/Fst/TestBytesStore.cs             |    429 +
 src/Lucene.Net.Tests/core/Util/Fst/TestFSTs.cs  |   1898 +
 .../core/Util/Junitcompat/SorePoint.cs          |     36 +
 .../core/Util/Junitcompat/SoreType.cs           |     28 +
 .../Junitcompat/TestBeforeAfterOverrides.cs     |    103 +
 .../core/Util/Junitcompat/TestCodecReported.cs  |     56 +
 .../TestExceptionInBeforeClassHooks.cs          |    215 +
 .../Junitcompat/TestFailIfDirectoryNotClosed.cs |     64 +
 .../Junitcompat/TestFailIfUnreferencedFiles.cs  |     80 +
 .../Junitcompat/TestFailOnFieldCacheInsanity.cs |     88 +
 .../core/Util/Junitcompat/TestGroupFiltering.cs |     85 +
 .../core/Util/Junitcompat/TestJUnitRuleOrder.cs |    132 +
 .../Junitcompat/TestLeaveFilesIfTestFails.cs    |     87 +
 .../Util/Junitcompat/TestReproduceMessage.cs    |    389 +
 .../TestReproduceMessageWithRepeated.cs         |     64 +
 .../TestSameRandomnessLocalePassedOrNot.cs      |     91 +
 .../Util/Junitcompat/TestSeedFromUncaught.cs    |     85 +
 .../Junitcompat/TestSetupTeardownChaining.cs    |     96 +
 .../TestSystemPropertiesInvariantRule.cs        |    196 +
 .../core/Util/Junitcompat/WithNestedTests.cs    |    198 +
 .../core/Util/Packed/TestEliasFanoDocIdSet.cs   |     79 +
 .../core/Util/Packed/TestEliasFanoSequence.cs   |    468 +
 .../core/Util/Packed/TestPackedInts.cs          |   1529 +
 .../core/Util/StressRamUsageEstimator.cs        |    188 +
 .../core/Util/Test2BPagedBytes.cs               |     87 +
 src/Lucene.Net.Tests/core/Util/TestArrayUtil.cs |    351 +
 .../core/Util/TestAttributeSource.cs            |    186 +
 src/Lucene.Net.Tests/core/Util/TestBroadWord.cs |    173 +
 .../core/Util/TestByteBlockPool.cs              |     70 +
 src/Lucene.Net.Tests/core/Util/TestBytesRef.cs  |     83 +
 .../core/Util/TestBytesRefArray.cs              |    113 +
 .../core/Util/TestBytesRefHash.cs               |    434 +
 src/Lucene.Net.Tests/core/Util/TestCharsRef.cs  |    211 +
 .../core/Util/TestCloseableThreadLocal.cs       |     69 +
 .../core/Util/TestCollectionUtil.cs             |    116 +
 src/Lucene.Net.Tests/core/Util/TestConstants.cs |     60 +
 .../core/Util/TestDocIdBitSet.cs                |     29 +
 .../core/Util/TestDoubleBarrelLRUCache.cs       |    223 +
 .../core/Util/TestFieldCacheSanityChecker.cs    |    176 +
 .../core/Util/TestFilterIterator.cs             |    252 +
 .../core/Util/TestFixedBitSet.cs                |    455 +
 src/Lucene.Net.Tests/core/Util/TestIOUtils.cs   |    109 +
 .../core/Util/TestIdentityHashSet.cs            |     63 +
 .../core/Util/TestInPlaceMergeSorter.cs         |     41 +
 .../core/Util/TestIndexableBinaryStringTools.cs |    208 +
 .../core/Util/TestIntroSorter.cs                |     37 +
 src/Lucene.Net.Tests/core/Util/TestIntsRef.cs   |     49 +
 .../core/Util/TestLongBitSet.cs                 |    390 +
 src/Lucene.Net.Tests/core/Util/TestMathUtil.cs  |    203 +
 .../core/Util/TestMaxFailuresRule.cs            |    262 +
 .../core/Util/TestMergedIterator.cs             |    175 +
 .../core/Util/TestNamedSPILoader.cs             |     58 +
 .../core/Util/TestNumericUtils.cs               |    536 +
 .../core/Util/TestOfflineSorter.cs              |    226 +
 .../core/Util/TestOpenBitSet.cs                 |    436 +
 .../core/Util/TestPForDeltaDocIdSet.cs          |     42 +
 .../core/Util/TestPagedBytes.cs                 |    221 +
 .../core/Util/TestPriorityQueue.cs              |    128 +
 .../core/Util/TestQueryBuilder.cs               |    436 +
 .../core/Util/TestRamUsageEstimator.cs          |    149 +
 .../Util/TestRamUsageEstimatorOnWildAnimals.cs  |     66 +
 .../Util/TestRecyclingByteBlockAllocator.cs     |    151 +
 .../core/Util/TestRecyclingIntBlockAllocator.cs |    151 +
 .../core/Util/TestRollingBuffer.cs              |    114 +
 .../core/Util/TestSentinelIntSet.cs             |     76 +
 src/Lucene.Net.Tests/core/Util/TestSetOnce.cs   |    115 +
 .../core/Util/TestSloppyMath.cs                 |    133 +
 .../core/Util/TestSmallFloat.cs                 |    159 +
 .../core/Util/TestStringHelper.cs               |     35 +
 src/Lucene.Net.Tests/core/Util/TestTimSorter.cs |     37 +
 .../core/Util/TestUnicodeUtil.cs                |    247 +
 src/Lucene.Net.Tests/core/Util/TestVersion.cs   |     80 +
 .../core/Util/TestVersionComparator.cs          |     59 +
 .../core/Util/TestVirtualMethod.cs              |    142 +
 .../core/Util/TestWAH8DocIdSet.cs               |    125 +
 .../core/Util/TestWeakIdentityMap.cs            |    299 +
 .../lib/ICSharpCode.SharpZipLib.dll             |    Bin 0 -> 200704 bytes
 src/Lucene.Net.Tests/packages.config            |      6 +
 src/contrib/Analyzers/Lucene.Net.snk            |    Bin 596 -> 0 bytes
 src/contrib/Core/Lucene.Net.snk                 |    Bin 596 -> 0 bytes
 .../FastVectorHighlighter/Lucene.Net.snk        |    Bin 596 -> 0 bytes
 src/contrib/Highlighter/Lucene.Net.snk          |    Bin 596 -> 0 bytes
 src/contrib/Memory/Lucene.Net.snk               |    Bin 596 -> 0 bytes
 src/contrib/Queries/Lucene.Net.snk              |    Bin 596 -> 0 bytes
 src/contrib/README.txt                          |      4 +-
 src/contrib/Regex/Lucene.Net.snk                |    Bin 596 -> 0 bytes
 src/contrib/SimpleFacetedSearch/Lucene.Net.snk  |    Bin 596 -> 0 bytes
 src/contrib/Snowball/Lucene.Net.snk             |    Bin 596 -> 0 bytes
 src/contrib/Spatial/BBox/AreaSimilarity.cs      |     46 +-
 src/contrib/Spatial/Lucene.Net.snk              |    Bin 596 -> 0 bytes
 src/contrib/SpellChecker/Lucene.Net.snk         |    Bin 596 -> 0 bytes
 src/core/Analysis/ASCIIFoldingFilter.cs         |   3285 -
 src/core/Analysis/Analyzer.cs                   |    171 -
 src/core/Analysis/BaseCharFilter.cs             |    105 -
 src/core/Analysis/CachingTokenFilter.cs         |     86 -
 src/core/Analysis/CharArraySet.cs               |    517 -
 src/core/Analysis/CharFilter.cs                 |     95 -
 src/core/Analysis/CharReader.cs                 |     94 -
 src/core/Analysis/CharStream.cs                 |     45 -
 src/core/Analysis/CharTokenizer.cs              |    135 -
 src/core/Analysis/ISOLatin1AccentFilter.cs      |    344 -
 src/core/Analysis/KeywordAnalyzer.cs            |     54 -
 src/core/Analysis/KeywordTokenizer.cs           |     99 -
 src/core/Analysis/LengthFilter.cs               |     60 -
 src/core/Analysis/LetterTokenizer.cs            |     57 -
 src/core/Analysis/LowerCaseFilter.cs            |     49 -
 src/core/Analysis/LowerCaseTokenizer.cs         |     60 -
 src/core/Analysis/MappingCharFilter.cs          |    166 -
 src/core/Analysis/NormalizeCharMap.cs           |     68 -
 src/core/Analysis/NumericTokenStream.cs         |    270 -
 src/core/Analysis/PerFieldAnalyzerWrapper.cs    |    135 -
 src/core/Analysis/PorterStemFilter.cs           |     62 -
 src/core/Analysis/PorterStemmer.cs              |    746 -
 src/core/Analysis/SimpleAnalyzer.cs             |     45 -
 .../Standard/READ_BEFORE_REGENERATING.txt       |     25 -
 src/core/Analysis/Standard/StandardAnalyzer.cs  |    174 -
 src/core/Analysis/Standard/StandardFilter.cs    |     88 -
 src/core/Analysis/Standard/StandardTokenizer.cs |    232 -
 .../Analysis/Standard/StandardTokenizerImpl.cs  |    707 -
 .../Standard/StandardTokenizerImpl.jflex        |    156 -
 src/core/Analysis/StopAnalyzer.cs               |    141 -
 src/core/Analysis/StopFilter.cs                 |    178 -
 src/core/Analysis/TeeSinkTokenFilter.cs         |    266 -
 src/core/Analysis/Token.cs                      |    852 -
 src/core/Analysis/TokenFilter.cs                |     72 -
 src/core/Analysis/TokenStream.cs                |    162 -
 .../Analysis/Tokenattributes/FlagsAttribute.cs  |     85 -
 .../Analysis/Tokenattributes/IFlagsAttribute.cs |     41 -
 .../Tokenattributes/IOffsetAttribute.cs         |     48 -
 .../Tokenattributes/IPayloadAttribute.cs        |     31 -
 .../IPositionIncrementAttribute.cs              |     59 -
 .../Analysis/Tokenattributes/ITermAttribute.cs  |    104 -
 .../Analysis/Tokenattributes/ITypeAttribute.cs  |     30 -
 .../Analysis/Tokenattributes/OffsetAttribute.cs |    106 -
 .../Tokenattributes/PayloadAttribute.cs         |    100 -
 .../PositionIncrementAttribute.cs               |    107 -
 .../Analysis/Tokenattributes/TermAttribute.cs   |    268 -
 .../Analysis/Tokenattributes/TypeAttribute.cs   |     85 -
 src/core/Analysis/Tokenizer.cs                  |    112 -
 src/core/Analysis/WhitespaceAnalyzer.cs         |     43 -
 src/core/Analysis/WhitespaceTokenizer.cs        |     55 -
 src/core/Analysis/WordlistLoader.cs             |    146 -
 src/core/AssemblyInfo.cs                        |     91 -
 src/core/Document/AbstractField.cs              |    312 -
 src/core/Document/CompressionTools.cs           |    150 -
 src/core/Document/DateField.cs                  |    138 -
 src/core/Document/DateTools.cs                  |    350 -
 src/core/Document/Document.cs                   |    382 -
 src/core/Document/Field.cs                      |    667 -
 src/core/Document/FieldSelector.cs              |     37 -
 src/core/Document/FieldSelectorResult.cs        |     71 -
 src/core/Document/Fieldable.cs                  |    205 -
 src/core/Document/LoadFirstFieldSelector.cs     |     35 -
 src/core/Document/MapFieldSelector.cs           |     68 -
 src/core/Document/NumberTools.cs                |    221 -
 src/core/Document/NumericField.cs               |    301 -
 src/core/Document/SetBasedFieldSelector.cs      |     69 -
 src/core/Index/AbstractAllTermDocs.cs           |    118 -
 src/core/Index/AllTermDocs.cs                   |     45 -
 src/core/Index/BufferedDeletes.cs               |    196 -
 src/core/Index/ByteBlockPool.cs                 |    172 -
 src/core/Index/ByteSliceReader.cs               |    185 -
 src/core/Index/ByteSliceWriter.cs               |     97 -
 src/core/Index/CharBlockPool.cs                 |     69 -
 src/core/Index/CheckIndex.cs                    |   1017 -
 src/core/Index/CompoundFileReader.cs            |    317 -
 src/core/Index/CompoundFileWriter.cs            |    275 -
 src/core/Index/ConcurrentMergeScheduler.cs      |    504 -
 src/core/Index/CorruptIndexException.cs         |     54 -
 src/core/Index/DefaultSkipListReader.cs         |    128 -
 src/core/Index/DefaultSkipListWriter.cs         |    143 -
 src/core/Index/DirectoryReader.cs               |   1548 -
 src/core/Index/DocConsumer.cs                   |     31 -
 src/core/Index/DocConsumerPerThread.cs          |     37 -
 src/core/Index/DocFieldConsumer.cs              |     56 -
 src/core/Index/DocFieldConsumerPerField.cs      |     30 -
 src/core/Index/DocFieldConsumerPerThread.cs     |     30 -
 src/core/Index/DocFieldConsumers.cs             |    221 -
 src/core/Index/DocFieldConsumersPerField.cs     |     56 -
 src/core/Index/DocFieldConsumersPerThread.cs    |     82 -
 src/core/Index/DocFieldProcessor.cs             |     92 -
 src/core/Index/DocFieldProcessorPerField.cs     |     49 -
 src/core/Index/DocFieldProcessorPerThread.cs    |    478 -
 src/core/Index/DocInverter.cs                   |     97 -
 src/core/Index/DocInverterPerField.cs           |    235 -
 src/core/Index/DocInverterPerThread.cs          |    107 -
 src/core/Index/DocumentsWriter.cs               |   2075 -
 src/core/Index/DocumentsWriterThreadState.cs    |     56 -
 src/core/Index/FieldInfo.cs                     |    136 -
 src/core/Index/FieldInfos.cs                    |    491 -
 src/core/Index/FieldInvertState.cs              |    110 -
 src/core/Index/FieldReaderException.cs          |     96 -
 src/core/Index/FieldSortedTermVectorMapper.cs   |     78 -
 src/core/Index/FieldsReader.cs                  |    641 -
 src/core/Index/FieldsWriter.cs                  |    290 -
 src/core/Index/FilterIndexReader.cs             |    388 -
 src/core/Index/FormatPostingsDocsConsumer.cs    |     36 -
 src/core/Index/FormatPostingsDocsWriter.cs      |    134 -
 src/core/Index/FormatPostingsFieldsConsumer.cs  |     39 -
 src/core/Index/FormatPostingsFieldsWriter.cs    |     71 -
 .../Index/FormatPostingsPositionsConsumer.cs    |     32 -
 src/core/Index/FormatPostingsPositionsWriter.cs |    101 -
 src/core/Index/FormatPostingsTermsConsumer.cs   |     52 -
 src/core/Index/FormatPostingsTermsWriter.cs     |     77 -
 src/core/Index/FreqProxFieldMergeState.cs       |    117 -
 src/core/Index/FreqProxTermsWriter.cs           |    303 -
 src/core/Index/FreqProxTermsWriterPerField.cs   |    196 -
 src/core/Index/FreqProxTermsWriterPerThread.cs  |     52 -
 src/core/Index/IndexCommit.cs                   |    119 -
 src/core/Index/IndexDeletionPolicy.cs           |     99 -
 src/core/Index/IndexFileDeleter.cs              |    808 -
 src/core/Index/IndexFileNameFilter.cs           |    107 -
 src/core/Index/IndexFileNames.cs                |    165 -
 src/core/Index/IndexReader.cs                   |   1374 -
 src/core/Index/IndexWriter.cs                   |   5928 -
 src/core/Index/IntBlockPool.cs                  |     79 -
 src/core/Index/InvertedDocConsumer.cs           |     53 -
 src/core/Index/InvertedDocConsumerPerField.cs   |     46 -
 src/core/Index/InvertedDocConsumerPerThread.cs  |     30 -
 src/core/Index/InvertedDocEndConsumer.cs        |     32 -
 .../Index/InvertedDocEndConsumerPerField.cs     |     28 -
 .../Index/InvertedDocEndConsumerPerThread.cs    |     30 -
 .../Index/KeepOnlyLastCommitDeletionPolicy.cs   |     51 -
 src/core/Index/LogByteSizeMergePolicy.cs        |     99 -
 src/core/Index/LogDocMergePolicy.cs             |     69 -
 src/core/Index/LogMergePolicy.cs                |    580 -
 src/core/Index/MergeDocIDRemapper.cs            |    127 -
 src/core/Index/MergePolicy.cs                   |    340 -
 src/core/Index/MergeScheduler.cs                |     58 -
 src/core/Index/MultiLevelSkipListReader.cs      |    341 -
 src/core/Index/MultiLevelSkipListWriter.cs      |    171 -
 src/core/Index/MultiReader.cs                   |    494 -
 src/core/Index/MultipleTermPositions.cs         |    256 -
 src/core/Index/NormsWriter.cs                   |    206 -
 src/core/Index/NormsWriterPerField.cs           |     90 -
 src/core/Index/NormsWriterPerThread.cs          |     55 -
 src/core/Index/ParallelReader.cs                |    822 -
 src/core/Index/Payload.cs                       |    217 -
 src/core/Index/PositionBasedTermVectorMapper.cs |    176 -
 src/core/Index/RawPostingList.cs                |     46 -
 src/core/Index/ReadOnlyDirectoryReader.cs       |     45 -
 src/core/Index/ReadOnlySegmentReader.cs         |     42 -
 src/core/Index/ReusableStringReader.cs          |    136 -
 src/core/Index/SegmentInfo.cs                   |    875 -
 src/core/Index/SegmentInfos.cs                  |   1074 -
 src/core/Index/SegmentMergeInfo.cs              |    108 -
 src/core/Index/SegmentMergeQueue.cs             |     47 -
 src/core/Index/SegmentMerger.cs                 |    934 -
 src/core/Index/SegmentReader.cs                 |   1692 -
 src/core/Index/SegmentTermDocs.cs               |    282 -
 src/core/Index/SegmentTermEnum.cs               |    247 -
 src/core/Index/SegmentTermPositionVector.cs     |     73 -
 src/core/Index/SegmentTermPositions.cs          |    226 -
 src/core/Index/SegmentTermVector.cs             |    102 -
 src/core/Index/SegmentWriteState.cs             |     53 -
 src/core/Index/SerialMergeScheduler.cs          |     49 -
 src/core/Index/SnapshotDeletionPolicy.cs        |    203 -
 src/core/Index/SortedTermVectorMapper.cs        |    133 -
 src/core/Index/StaleReaderException.cs          |     49 -
 src/core/Index/StoredFieldsWriter.cs            |    266 -
 src/core/Index/StoredFieldsWriterPerThread.cs   |     93 -
 src/core/Index/Term.cs                          |    168 -
 src/core/Index/TermBuffer.cs                    |    166 -
 src/core/Index/TermDocs.cs                      |     86 -
 src/core/Index/TermEnum.cs                      |     53 -
 src/core/Index/TermFreqVector.cs                |     73 -
 src/core/Index/TermInfo.cs                      |     69 -
 src/core/Index/TermInfosReader.cs               |    325 -
 src/core/Index/TermInfosWriter.cs               |    250 -
 src/core/Index/TermPositionVector.cs            |     50 -
 src/core/Index/TermPositions.cs                 |     79 -
 src/core/Index/TermVectorEntry.cs               |    108 -
 .../TermVectorEntryFreqSortedComparator.cs      |     45 -
 src/core/Index/TermVectorMapper.cs              |    112 -
 src/core/Index/TermVectorOffsetInfo.cs          |    134 -
 src/core/Index/TermVectorsReader.cs             |    731 -
 src/core/Index/TermVectorsTermsWriter.cs        |    380 -
 .../Index/TermVectorsTermsWriterPerField.cs     |    290 -
 .../Index/TermVectorsTermsWriterPerThread.cs    |    106 -
 src/core/Index/TermVectorsWriter.cs             |    246 -
 src/core/Index/TermsHash.cs                     |    278 -
 src/core/Index/TermsHashConsumer.cs             |     40 -
 src/core/Index/TermsHashConsumerPerField.cs     |     38 -
 src/core/Index/TermsHashConsumerPerThread.cs    |     30 -
 src/core/Index/TermsHashPerField.cs             |    639 -
 src/core/Index/TermsHashPerThread.cs            |    140 -
 src/core/LZOCompressor.cs                       |    135 -
 .../Lucene.Net.Search.RemoteSearchable.config   |     32 -
 src/core/Lucene.Net.Search.TestSort.config      |     32 -
 src/core/Lucene.Net.csproj                      |    988 -
 src/core/Lucene.Net.ndoc                        |     61 -
 src/core/Lucene.Net.snk                         |    Bin 596 -> 0 bytes
 src/core/LucenePackage.cs                       |     40 -
 src/core/Messages/INLSException.cs              |     36 -
 src/core/Messages/Message.cs                    |     36 -
 src/core/Messages/MessageImpl.cs                |     81 -
 src/core/Messages/NLS.cs                        |    254 -
 src/core/QueryParser/CharStream.cs              |    124 -
 src/core/QueryParser/FastCharStream.cs          |    176 -
 src/core/QueryParser/MultiFieldQueryParser.cs   |    371 -
 src/core/QueryParser/ParseException.cs          |    251 -
 src/core/QueryParser/QueryParser.JJ             |   1381 -
 src/core/QueryParser/QueryParser.cs             |   2113 -
 src/core/QueryParser/QueryParserConstants.cs    |    143 -
 src/core/QueryParser/QueryParserTokenManager.cs |   1539 -
 src/core/QueryParser/Token.cs                   |    133 -
 src/core/QueryParser/TokenMgrError.cs           |    175 -
 src/core/Search/BooleanClause.cs                |    102 -
 src/core/Search/BooleanQuery.cs                 |    621 -
 src/core/Search/BooleanScorer.cs                |    405 -
 src/core/Search/BooleanScorer2.cs               |    417 -
 src/core/Search/CachingSpanFilter.cs            |    124 -
 src/core/Search/CachingWrapperFilter.cs         |    279 -
 src/core/Search/Collector.cs                    |    176 -
 src/core/Search/ComplexExplanation.cs           |     76 -
 src/core/Search/ConjunctionScorer.cs            |    147 -
 src/core/Search/ConstantScoreQuery.cs           |    236 -
 src/core/Search/DefaultSimilarity.cs            |    108 -
 src/core/Search/DisjunctionMaxQuery.cs          |    344 -
 src/core/Search/DisjunctionMaxScorer.cs         |    215 -
 src/core/Search/DisjunctionSumScorer.cs         |    278 -
 src/core/Search/DocIdSet.cs                     |    112 -
 src/core/Search/DocIdSetIterator.cs             |     90 -
 src/core/Search/ExactPhraseScorer.cs            |     67 -
 src/core/Search/Explanation.cs                  |    168 -
 src/core/Search/FieldCache.cs                   |    708 -
 src/core/Search/FieldCacheImpl.cs               |    883 -
 src/core/Search/FieldCacheRangeFilter.cs        |    964 -
 src/core/Search/FieldCacheTermsFilter.cs        |    223 -
 src/core/Search/FieldComparator.cs              |   1065 -
 src/core/Search/FieldComparatorSource.cs        |     45 -
 src/core/Search/FieldDoc.cs                     |    113 -
 src/core/Search/FieldDocSortedHitQueue.cs       |    148 -
 src/core/Search/FieldValueHitQueue.cs           |    235 -
 src/core/Search/Filter.cs                       |     54 -
 src/core/Search/FilterManager.cs                |    203 -
 src/core/Search/FilteredDocIdSet.cs             |    107 -
 src/core/Search/FilteredDocIdSetIterator.cs     |     96 -
 src/core/Search/FilteredQuery.cs                |    293 -
 src/core/Search/FilteredTermEnum.cs             |    127 -
 src/core/Search/Function/ByteFieldSource.cs     |    136 -
 src/core/Search/Function/CustomScoreProvider.cs |    175 -
 src/core/Search/Function/CustomScoreQuery.cs    |    579 -
 src/core/Search/Function/DocValues.cs           |    206 -
 src/core/Search/Function/FieldCacheSource.cs    |    110 -
 src/core/Search/Function/FieldScoreQuery.cs     |    139 -
 src/core/Search/Function/FloatFieldSource.cs    |    131 -
 src/core/Search/Function/IntFieldSource.cs      |    136 -
 src/core/Search/Function/OrdFieldSource.cs      |    146 -
 .../Search/Function/ReverseOrdFieldSource.cs    |    158 -
 src/core/Search/Function/ShortFieldSource.cs    |    136 -
 src/core/Search/Function/ValueSource.cs         |     69 -
 src/core/Search/Function/ValueSourceQuery.cs    |    235 -
 src/core/Search/FuzzyQuery.cs                   |    256 -
 src/core/Search/FuzzyTermEnum.cs                |    318 -
 src/core/Search/HitQueue.cs                     |     95 -
 src/core/Search/IndexSearcher.cs                |    343 -
 src/core/Search/MatchAllDocsQuery.cs            |    198 -
 src/core/Search/MultiPhraseQuery.cs             |    496 -
 src/core/Search/MultiSearcher.cs                |    458 -
 src/core/Search/MultiTermQuery.cs               |    465 -
 src/core/Search/MultiTermQueryWrapperFilter.cs  |    161 -
 src/core/Search/NumericRangeFilter.cs           |    185 -
 src/core/Search/NumericRangeQuery.cs            |    665 -
 src/core/Search/ParallelMultiSearcher.cs        |    199 -
 .../Search/Payloads/AveragePayloadFunction.cs   |     63 -
 src/core/Search/Payloads/MaxPayloadFunction.cs  |     69 -
 src/core/Search/Payloads/MinPayloadFunction.cs  |     67 -
 src/core/Search/Payloads/PayloadFunction.cs     |     78 -
 src/core/Search/Payloads/PayloadNearQuery.cs    |    284 -
 src/core/Search/Payloads/PayloadSpanUtil.cs     |    211 -
 src/core/Search/Payloads/PayloadTermQuery.cs    |    255 -
 src/core/Search/PhrasePositions.cs              |     93 -
 src/core/Search/PhraseQuery.cs                  |    370 -
 src/core/Search/PhraseQueue.cs                  |     44 -
 src/core/Search/PhraseScorer.cs                 |    224 -
 src/core/Search/PositiveScoresOnlyCollector.cs  |     66 -
 src/core/Search/PrefixFilter.cs                 |     51 -
 src/core/Search/PrefixQuery.cs                  |    100 -
 src/core/Search/PrefixTermEnum.cs               |     71 -
 src/core/Search/Query.cs                        |    257 -
 src/core/Search/QueryTermVector.cs              |    167 -
 src/core/Search/QueryWrapperFilter.cs           |    106 -
 src/core/Search/ReqExclScorer.cs                |    140 -
 src/core/Search/ReqOptSumScorer.cs              |     87 -
 src/core/Search/ScoreCachingWrappingScorer.cs   |     88 -
 src/core/Search/ScoreDoc.cs                     |     50 -
 src/core/Search/Scorer.cs                       |    106 -
 src/core/Search/Searchable.cs                   |    169 -
 src/core/Search/Searcher.cs                     |    192 -
 src/core/Search/Similarity.cs                   |    697 -
 src/core/Search/SimilarityDelegator.cs          |     80 -
 src/core/Search/SingleTermEnum.cs               |     70 -
 src/core/Search/SloppyPhraseScorer.cs           |    244 -
 src/core/Search/Sort.cs                         |    214 -
 src/core/Search/SortField.cs                    |    512 -
 src/core/Search/SpanFilter.cs                   |     47 -
 src/core/Search/SpanFilterResult.cs             |    116 -
 src/core/Search/SpanQueryFilter.cs              |    109 -
 src/core/Search/Spans/FieldMaskingSpanQuery.cs  |    162 -
 src/core/Search/Spans/NearSpansOrdered.cs       |    436 -
 src/core/Search/Spans/NearSpansUnordered.cs     |    415 -
 src/core/Search/Spans/SpanFirstQuery.cs         |    211 -
 src/core/Search/Spans/SpanNearQuery.cs          |    230 -
 src/core/Search/Spans/SpanNotQuery.cs           |    260 -
 src/core/Search/Spans/SpanOrQuery.cs            |    345 -
 src/core/Search/Spans/SpanQuery.cs              |     45 -
 src/core/Search/Spans/SpanScorer.cs             |    130 -
 src/core/Search/Spans/SpanTermQuery.cs          |    100 -
 src/core/Search/Spans/SpanWeight.cs             |    138 -
 src/core/Search/Spans/Spans.cs                  |     92 -
 src/core/Search/Spans/TermSpans.cs              |    126 -
 src/core/Search/TermQuery.cs                    |    237 -
 src/core/Search/TermRangeFilter.cs              |    137 -
 src/core/Search/TermRangeQuery.cs               |    238 -
 src/core/Search/TermRangeTermEnum.cs            |    161 -
 src/core/Search/TermScorer.cs                   |    188 -
 src/core/Search/TimeLimitingCollector.cs        |    254 -
 src/core/Search/TopDocs.cs                      |     71 -
 src/core/Search/TopDocsCollector.cs             |    155 -
 src/core/Search/TopFieldCollector.cs            |   1137 -
 src/core/Search/TopFieldDocs.cs                 |     47 -
 src/core/Search/TopScoreDocCollector.cs         |    177 -
 src/core/Search/Weight.cs                       |    127 -
 src/core/Search/WildcardQuery.cs                |    136 -
 src/core/Search/WildcardTermEnum.cs             |    196 -
 src/core/Store/AlreadyClosedException.cs        |     47 -
 src/core/Store/BufferedIndexInput.cs            |    241 -
 src/core/Store/BufferedIndexOutput.cs           |    165 -
 src/core/Store/CheckSumIndexInput.cs            |     89 -
 src/core/Store/CheckSumIndexOutput.cs           |    115 -
 src/core/Store/Directory.cs                     |    264 -
 src/core/Store/FSDirectory.cs                   |    533 -
 src/core/Store/FSLockFactory.cs                 |     52 -
 src/core/Store/FileSwitchDirectory.cs           |    167 -
 src/core/Store/IndexInput.cs                    |    290 -
 src/core/Store/IndexOutput.cs                   |    285 -
 src/core/Store/Lock.cs                          |    163 -
 src/core/Store/LockFactory.cs                   |     71 -
 src/core/Store/LockObtainFailedException.cs     |     52 -
 src/core/Store/LockReleaseFailedException.cs    |     51 -
 src/core/Store/LockStressTest.cs                |    128 -
 src/core/Store/LockVerifyServer.cs              |    110 -
 src/core/Store/MMapDirectory.cs                 |    535 -
 src/core/Store/NIOFSDirectory.cs                |    269 -
 src/core/Store/NativeFSLockFactory.cs           |    440 -
 src/core/Store/NoLockFactory.cs                 |     76 -
 src/core/Store/NoSuchDirectoryException.cs      |     49 -
 src/core/Store/RAMDirectory.cs                  |    262 -
 src/core/Store/RAMFile.cs                       |    147 -
 src/core/Store/RAMInputStream.cs                |    138 -
 src/core/Store/RAMOutputStream.cs               |    191 -
 src/core/Store/SimpleFSDirectory.cs             |    319 -
 src/core/Store/SimpleFSLockFactory.cs           |    232 -
 src/core/Store/SingleInstanceLockFactory.cs     |    107 -
 src/core/Store/VerifyingLockFactory.cs          |    165 -
 src/core/Support/AppSettings.cs                 |    159 -
 src/core/Support/AttributeImplItem.cs           |     41 -
 src/core/Support/BitSetSupport.cs               |     88 -
 src/core/Support/BuildType.cs                   |     32 -
 src/core/Support/CRC32.cs                       |     83 -
 src/core/Support/Character.cs                   |     81 -
 .../Support/CloseableThreadLocalProfiler.cs     |     45 -
 src/core/Support/CollectionsHelper.cs           |    339 -
 src/core/Support/Compare.cs                     |     49 -
 .../Compatibility/ConcurrentDictionary.cs       |    312 -
 src/core/Support/Compatibility/Func.cs          |     29 -
 src/core/Support/Compatibility/ISet.cs          |     59 -
 src/core/Support/Compatibility/SetFactory.cs    |     42 -
 src/core/Support/Compatibility/SortedSet.cs     |    187 -
 src/core/Support/Compatibility/ThreadLocal.cs   |     55 -
 .../Support/Compatibility/WrappedHashSet.cs     |     44 -
 src/core/Support/Cryptography.cs                |     45 -
 src/core/Support/Deflater.cs                    |     97 -
 src/core/Support/Double.cs                      |     44 -
 src/core/Support/EquatableList.cs               |    339 -
 src/core/Support/FileSupport.cs                 |    121 -
 src/core/Support/GeneralKeyedCollection.cs      |     96 -
 src/core/Support/HashMap.cs                     |    449 -
 src/core/Support/IChecksum.cs                   |     32 -
 src/core/Support/IThreadRunnable.cs             |     36 -
 src/core/Support/Inflater.cs                    |     71 -
 src/core/Support/Number.cs                      |    252 -
 src/core/Support/OS.cs                          |     62 -
 src/core/Support/SharpZipLib.cs                 |     51 -
 src/core/Support/Single.cs                      |    131 -
 src/core/Support/TextSupport.cs                 |     49 -
 src/core/Support/ThreadClass.cs                 |    315 -
 src/core/Support/ThreadLock.cs                  |     82 -
 src/core/Support/WeakDictionary.cs              |    296 -
 src/core/Util/ArrayUtil.cs                      |    282 -
 src/core/Util/Attribute.cs                      |    131 -
 src/core/Util/AttributeSource.cs                |    540 -
 src/core/Util/AverageGuessMemoryModel.cs        |     90 -
 src/core/Util/BitUtil.cs                        |    894 -
 src/core/Util/BitVector.cs                      |    315 -
 src/core/Util/Cache/Cache.cs                    |    129 -
 src/core/Util/Cache/SimpleLRUCache.cs           |    166 -
 src/core/Util/Cache/SimpleMapCache.cs           |    141 -
 src/core/Util/CloseableThreadLocal-old.cs       |    104 -
 src/core/Util/CloseableThreadLocal.cs           |    205 -
 src/core/Util/Constants.cs                      |    107 -
 src/core/Util/DocIdBitSet.cs                    |     87 -
 src/core/Util/FieldCacheSanityChecker.cs        |    439 -
 src/core/Util/IAttribute.cs                     |     27 -
 src/core/Util/IdentityDictionary.cs             |     64 -
 src/core/Util/IndexableBinaryStringTools.cs     |    342 -
 src/core/Util/MapOfSets.cs                      |     76 -
 src/core/Util/MemoryModel.cs                    |     44 -
 src/core/Util/NumericUtils.cs                   |    488 -
 src/core/Util/OpenBitSet.cs                     |    944 -
 src/core/Util/OpenBitSetDISI.cs                 |    112 -
 src/core/Util/OpenBitSetIterator.cs             |    233 -
 src/core/Util/PriorityQueue.cs                  |    280 -
 src/core/Util/RamUsageEstimator.cs              |    220 -
 src/core/Util/ReaderUtil.cs                     |    122 -
 src/core/Util/ScorerDocQueue.cs                 |    275 -
 src/core/Util/SimpleStringInterner.cs           |     95 -
 src/core/Util/SmallFloat.cs                     |    152 -
 src/core/Util/SortedVIntList.cs                 |    289 -
 src/core/Util/SorterTemplate.cs                 |    224 -
 src/core/Util/StringHelper.cs                   |     89 -
 src/core/Util/StringInterner.cs                 |     44 -
 src/core/Util/ToStringUtils.cs                  |     40 -
 src/core/Util/UnicodeUtil.cs                    |    505 -
 src/core/Util/Version.cs                        |     89 -
 src/core/lucene.net.project.nuspec              |     21 -
 src/demo/DeleteFiles/App.ico                    |    Bin 1078 -> 0 bytes
 src/demo/DeleteFiles/AssemblyInfo.cs            |     78 -
 src/demo/DeleteFiles/DeleteFiles.cs             |     67 -
 src/demo/DeleteFiles/DeleteFiles.csproj         |    215 -
 src/demo/Demo.Common/AssemblyInfo.cs            |     83 -
 src/demo/Demo.Common/Demo.Common.csproj         |    244 -
 src/demo/Demo.Common/FileDocument.cs            |     67 -
 src/demo/Demo.Common/HTML/Entities.cs           |    346 -
 src/demo/Demo.Common/HTML/HTMLParser.cs         |   1083 -
 src/demo/Demo.Common/HTML/HTMLParser.jj         |    392 -
 .../Demo.Common/HTML/HTMLParserConstants.cs     |     67 -
 .../Demo.Common/HTML/HTMLParserTokenManager.cs  |   1998 -
 src/demo/Demo.Common/HTML/ParseException.cs     |    232 -
 src/demo/Demo.Common/HTML/ParserThread.cs       |     69 -
 src/demo/Demo.Common/HTML/SimpleCharStream.cs   |    460 -
 src/demo/Demo.Common/HTML/Tags.cs               |     65 -
 src/demo/Demo.Common/HTML/Test.cs               |     64 -
 src/demo/Demo.Common/HTML/Token.cs              |     94 -
 src/demo/Demo.Common/HTML/TokenMgrError.cs      |    162 -
 src/demo/Demo.Common/HTMLDocument.cs            |     87 -
 src/demo/Demo.Common/Lucene.Net.snk             |    Bin 596 -> 0 bytes
 src/demo/IndexFiles/App.ico                     |    Bin 1078 -> 0 bytes
 src/demo/IndexFiles/AssemblyInfo.cs             |     78 -
 src/demo/IndexFiles/IndexFiles.cs               |    111 -
 src/demo/IndexFiles/IndexFiles.csproj           |    215 -
 src/demo/IndexHtml/App.ico                      |    Bin 1078 -> 0 bytes
 src/demo/IndexHtml/AssemblyInfo.cs              |     78 -
 src/demo/IndexHtml/IndexHtml.cs                 |    241 -
 src/demo/IndexHtml/IndexHtml.csproj             |    215 -
 src/demo/Search.html                            |     38 -
 src/demo/SearchFiles/App.ico                    |    Bin 1078 -> 0 bytes
 src/demo/SearchFiles/AssemblyInfo.cs            |     78 -
 src/demo/SearchFiles/SearchFiles.cs             |    379 -
 src/demo/SearchFiles/SearchFiles.csproj         |    215 -
 test/contrib/Analyzers/AR/TestArabicAnalyzer.cs |     98 -
 .../AR/TestArabicNormalizationFilter.cs         |    128 -
 .../Analyzers/AR/TestArabicStemFilter.cs        |    169 -
 .../Analyzers/Br/TestBrazilianStemmer.cs        |    179 -
 test/contrib/Analyzers/Cjk/TestCJKTokenizer.cs  |    327 -
 .../Analyzers/Cn/TestChineseTokenizer.cs        |    131 -
 .../Compound/TestCompoundWordTokenFilter.cs     |     39 -
 .../Analyzers/Contrib.Analyzers.Test.csproj     |    245 -
 test/contrib/Analyzers/Cz/TestCzechAnalyzer.cs  |    102 -
 .../contrib/Analyzers/Cz/customStopWordFile.txt |      3 -
 .../Analyzers/De/TestGermanStemFilter.cs        |    144 -
 test/contrib/Analyzers/De/data.txt              |     51 -
 test/contrib/Analyzers/De/data_din2.txt         |     11 -
 test/contrib/Analyzers/El/GreekAnalyzerTest.cs  |    122 -
 .../contrib/Analyzers/Fa/TestPersianAnalyzer.cs |    235 -
 .../Fa/TestPersianNormalizationFilter.cs        |     87 -
 .../Analyzers/Filters/ChainedFilterTest.cs      |    218 -
 test/contrib/Analyzers/Fr/TestElision.cs        |     70 -
 test/contrib/Analyzers/Fr/TestFrenchAnalyzer.cs |    179 -
 .../Analyzers/Hunspell/Dictionaries/en_US.aff   |    207 -
 .../Analyzers/Hunspell/Dictionaries/en_US.dic   |  62120 --------
 .../Hunspell/Dictionaries/fr-moderne.aff        |  11653 --
 .../Hunspell/Dictionaries/fr-moderne.dic        |  67499 ---------
 .../Analyzers/Hunspell/Dictionaries/nl_NL.aff   |    333 -
 .../Analyzers/Hunspell/Dictionaries/nl_NL.dic   | 120758 ----------------
 .../Hunspell/HunspellDictionaryLoader.cs        |     44 -
 .../Hunspell/TestHunspellDictionary.cs          |     42 -
 .../Hunspell/TestHunspellStemFilter.cs          |     92 -
 .../Analyzers/Hunspell/TestHunspellStemmer.cs   |     96 -
 test/contrib/Analyzers/Lucene.Net.snk           |    Bin 596 -> 0 bytes
 .../Miscellaneous/PatternAnalyzerTest.cs        |    172 -
 .../Miscellaneous/TestEmptyTokenStream.cs       |     45 -
 .../TestPrefixAndSuffixAwareTokenFilter.cs      |     51 -
 .../Miscellaneous/TestPrefixAwareTokenFilter.cs |     60 -
 .../Miscellaneous/TestSingleTokenTokenFilter.cs |     60 -
 .../Analyzers/NGram/TestEdgeNGramTokenFilter.cs |    142 -
 .../Analyzers/NGram/TestEdgeNGramTokenizer.cs   |    131 -
 .../Analyzers/NGram/TestNGramTokenFilter.cs     |    123 -
 .../Analyzers/NGram/TestNGramTokenizer.cs       |    114 -
 test/contrib/Analyzers/Nl/TestDutchStemmer.cs   |    199 -
 test/contrib/Analyzers/Nl/customStemDict.txt    |      3 -
 .../Payloads/DelimitedPayloadTokenFilterTest.cs |    162 -
 .../Payloads/NumericPayloadTokenFilterTest.cs   |     96 -
 .../TokenOffsetPayloadTokenFilterTest.cs        |     63 -
 .../Payloads/TypeAsPayloadTokenFilterTest.cs    |     88 -
 .../Analyzers/Position/PositionFilterTest.cs    |    179 -
 .../Analyzers/Properties/AssemblyInfo.cs        |     57 -
 .../Query/QueryAutoStopWordAnalyzerTest.cs      |    233 -
 .../Reverse/TestReverseStringFilter.cs          |     94 -
 .../contrib/Analyzers/Ru/TestRussianAnalyzer.cs |    112 -
 test/contrib/Analyzers/Ru/TestRussianStem.cs    |     77 -
 test/contrib/Analyzers/Ru/resUTF8.txt           |      1 -
 test/contrib/Analyzers/Ru/stemsUTF8.txt         |  49673 -------
 test/contrib/Analyzers/Ru/testUTF8.txt          |      2 -
 test/contrib/Analyzers/Ru/wordsUTF8.txt         |  49673 -------
 .../Shingle/ShingleAnalyzerWrapperTest.cs       |    301 -
 .../Analyzers/Shingle/ShingleFilterTest.cs      |    537 -
 .../Shingle/TestShingleMatrixFilter.cs          |    588 -
 .../Sinks/DateRecognizerSinkTokenizerTest.cs    |     62 -
 .../Sinks/TokenRangeSinkTokenizerTest.cs        |     63 -
 .../Sinks/TokenTypeSinkTokenizerTest.cs         |    100 -
 test/contrib/Analyzers/Th/TestThaiAnalyzer.cs   |     39 -
 .../Core/Analysis/Ext/Analysis.Ext.Test.cs      |    186 -
 test/contrib/Core/Contrib.Core.Test.csproj      |    164 -
 test/contrib/Core/Index/FieldEnumeratorTest.cs  |    290 -
 .../contrib/Core/Index/SegmentsGenCommitTest.cs |    103 -
 .../Core/Index/TermVectorEnumeratorTest.cs      |    138 -
 test/contrib/Core/Properties/AssemblyInfo.cs    |     57 -
 .../contrib/Core/Util/Cache/SegmentCacheTest.cs |    253 -
 .../FastVectorHighlighter/AbstractTestCase.cs   |    473 -
 .../Contrib.FastVectorHighlighter.Test.csproj   |    173 -
 .../FieldPhraseListTest.cs                      |    256 -
 .../FastVectorHighlighter/FieldQueryTest.cs     |    943 -
 .../FastVectorHighlighter/FieldTermStackTest.cs |    228 -
 .../IndexTimeSynonymTest.cs                     |    381 -
 .../Properties/AssemblyInfo.cs                  |     56 -
 .../ScoreOrderFragmentsBuilderTest.cs           |     55 -
 .../SimpleFragListBuilderTest.cs                |    206 -
 .../SimpleFragmentsBuilderTest.cs               |    167 -
 .../FastVectorHighlighter/StringUtilsTest.cs    |     43 -
 test/contrib/FastVectorHighlighter/Support.cs   |     53 -
 test/contrib/Highlighter/AssemblyInfo.cs        |     80 -
 .../Highlighter/Contrib.Highlighter.Test.csproj |    216 -
 .../Highlighter/Contrib.Highlighter.Test.nunit  |     22 -
 test/contrib/Highlighter/HighlighterTest.cs     |   2151 -
 test/contrib/Highlighter/Tokenizer.cs           |    234 -
 test/contrib/Memory/Contrib.Memory.Test.csproj  |    132 -
 test/contrib/Memory/MemoryIndexTest.cs          |    248 -
 test/contrib/Memory/Properties/AssemblyInfo.cs  |     57 -
 test/contrib/Memory/testqueries.txt             |    129 -
 test/contrib/Memory/testqueries2.txt            |      5 -
 test/contrib/Queries/BooleanFilterTest.cs       |    178 -
 test/contrib/Queries/BoostingQueryTest.cs       |     43 -
 .../contrib/Queries/Contrib.Queries.Test.csproj |    169 -
 test/contrib/Queries/DuplicateFilterTest.cs     |    173 -
 test/contrib/Queries/FuzzyLikeThisQueryTest.cs  |    133 -
 test/contrib/Queries/Properties/AssemblyInfo.cs |     57 -
 .../contrib/Queries/Similar/TestMoreLikeThis.cs |    135 -
 test/contrib/Queries/TermsFilterTest.cs         |    102 -
 test/contrib/Regex/Contrib.Regex.Test.csproj    |    121 -
 test/contrib/Regex/Properties/AssemblyInfo.cs   |     55 -
 test/contrib/Regex/TestRegexQuery.cs            |    152 -
 test/contrib/Regex/TestSpanRegexQuery.cs        |    131 -
 .../Properties/AssemblyInfo.cs                  |     56 -
 .../SimpleFacetedSearch.Test.csproj             |    123 -
 .../TestSimpleFacetedSearch.cs                  |    335 -
 .../Snowball/Analysis/Snowball/TestSnowball.cs  |    176 -
 test/contrib/Snowball/AssemblyInfo.cs           |     84 -
 .../Snowball/Contrib.Snowball.Test.csproj       |    215 -
 .../Snowball/Contrib.Snowball.Test.nunit        |     22 -
 .../Analysis/Snowball/TestSnowball.cs           |    156 -
 test/contrib/Spatial/BBox/TestBBoxStrategy.cs   |     65 -
 test/contrib/Spatial/CheckHits.cs               |    257 -
 .../Spatial/Compatibility/TermsFilterTest.cs    |    126 -
 .../Spatial/Compatibility/TestFixedBitSet.cs    |    360 -
 .../Spatial/Contrib.Spatial.Tests.csproj        |    180 -
 test/contrib/Spatial/DistanceStrategyTest.cs    |    131 -
 test/contrib/Spatial/PortedSolr3Test.cs         |    194 -
 test/contrib/Spatial/Prefix/NtsPolygonTest.cs   |     54 -
 .../Prefix/TestRecursivePrefixTreeStrategy.cs   |    209 -
 .../Prefix/TestTermQueryPrefixGridStrategy.cs   |     63 -
 .../Prefix/Tree/SpatialPrefixTreeTest.cs        |     63 -
 test/contrib/Spatial/Properties/AssemblyInfo.cs |     62 -
 .../Spatial/Queries/SpatialArgsParserTest.cs    |     71 -
 test/contrib/Spatial/SpatialMatchConcern.cs     |     35 -
 test/contrib/Spatial/SpatialTestCase.cs         |    197 -
 test/contrib/Spatial/SpatialTestQuery.cs        |    103 -
 test/contrib/Spatial/StrategyTestCase.cs        |    261 -
 test/contrib/Spatial/TestCartesian.cs           |    317 -
 test/contrib/Spatial/TestTestFramework.cs       |     52 -
 .../Spatial/Vector/TestTwoDoublesStrategy.cs    |     64 -
 test/contrib/SpellChecker/AssemblyInfo.cs       |     87 -
 .../Contrib.SpellChecker.Test.csproj            |    230 -
 .../Contrib.SpellChecker.Test.nunit             |     31 -
 .../Test/TestJaroWinklerDistance.cs             |     54 -
 .../Test/TestLevenshteinDistance.cs             |     61 -
 .../SpellChecker/Test/TestLuceneDictionary.cs   |    259 -
 .../SpellChecker/Test/TestNGramDistance.cs      |    144 -
 .../Test/TestPlainTextDictionary.cs             |     49 -
 .../SpellChecker/Test/TestSpellChecker.cs       |    459 -
 test/contrib/SpellChecker/Util/English.cs       |    152 -
 test/core/Analysis/BaseTokenStreamTestCase.cs   |    256 -
 test/core/Analysis/TestASCIIFoldingFilter.cs    |   1920 -
 test/core/Analysis/TestAnalyzers.cs             |    188 -
 test/core/Analysis/TestCachingTokenFilter.cs    |    146 -
 test/core/Analysis/TestCharArraySet.cs          |    146 -
 test/core/Analysis/TestCharFilter.cs            |     85 -
 test/core/Analysis/TestISOLatin1AccentFilter.cs |    119 -
 test/core/Analysis/TestKeywordAnalyzer.cs       |    107 -
 test/core/Analysis/TestLengthFilter.cs          |     46 -
 test/core/Analysis/TestMappingCharFilter.cs     |    183 -
 test/core/Analysis/TestNumericTokenStream.cs    |     75 -
 .../Analysis/TestPerFieldAnalzyerWrapper.cs     |     48 -
 test/core/Analysis/TestStandardAnalyzer.cs      |    261 -
 test/core/Analysis/TestStopAnalyzer.cs          |    111 -
 test/core/Analysis/TestStopFilter.cs            |    162 -
 test/core/Analysis/TestTeeSinkTokenFilter.cs    |    294 -
 test/core/Analysis/TestToken.cs                 |    285 -
 .../Tokenattributes/TestSimpleAttributeImpls.cs |    154 -
 .../Tokenattributes/TestTermAttributeImpl.cs    |    200 -
 test/core/App.config                            |     44 -
 test/core/AssemblyInfo.cs                       |     82 -
 test/core/Document/TestBinaryDocument.cs        |    116 -
 test/core/Document/TestDateTools.cs             |    201 -
 test/core/Document/TestDocument.cs              |    272 -
 test/core/Document/TestNumberTools.cs           |    102 -
 test/core/Index/DocHelper.cs                    |    261 -
 test/core/Index/MockIndexInput.cs               |     73 -
 test/core/Index/TestAddIndexesNoOptimize.cs     |    593 -
 test/core/Index/TestAtomicUpdate.cs             |    243 -
 test/core/Index/TestBackwardsCompatibility.cs   |    741 -
 test/core/Index/TestByteSlices.cs               |    153 -
 test/core/Index/TestCheckIndex.cs               |    123 -
 test/core/Index/TestCompoundFile.cs             |    641 -
 test/core/Index/TestConcurrentMergeScheduler.cs |    256 -
 test/core/Index/TestCrash.cs                    |    204 -
 test/core/Index/TestDeletionPolicy.cs           |    875 -
 test/core/Index/TestDirectoryReader.cs          |    224 -
 test/core/Index/TestDoc.cs                      |    264 -
 test/core/Index/TestDocumentWriter.cs           |    430 -
 test/core/Index/TestFieldInfos.cs               |    103 -
 test/core/Index/TestFieldsReader.cs             |    520 -
 test/core/Index/TestFilterIndexReader.cs        |    155 -
 test/core/Index/TestIndexCommit.cs              |    162 -
 test/core/Index/TestIndexFileDeleter.cs         |    246 -
 test/core/Index/TestIndexInput.cs               |     93 -
 test/core/Index/TestIndexReader.cs              |   1886 -
 test/core/Index/TestIndexReaderClone.cs         |    539 -
 test/core/Index/TestIndexReaderCloneNorms.cs    |    380 -
 test/core/Index/TestIndexReaderReopen.cs        |   1438 -
 test/core/Index/TestIndexWriter.cs              |   5806 -
 test/core/Index/TestIndexWriterDelete.cs        |    914 -
 test/core/Index/TestIndexWriterExceptions.cs    |    300 -
 test/core/Index/TestIndexWriterLockRelease.cs   |    151 -
 test/core/Index/TestIndexWriterMergePolicy.cs   |    287 -
 test/core/Index/TestIndexWriterMerging.cs       |    108 -
 test/core/Index/TestIndexWriterReader.cs        |   1227 -
 test/core/Index/TestIsCurrent.cs                |    120 -
 test/core/Index/TestLazyBug.cs                  |    149 -
 test/core/Index/TestLazyProxSkipping.cs         |    256 -
 test/core/Index/TestMultiLevelSkipList.cs       |    197 -
 test/core/Index/TestMultiReader.cs              |     57 -
 test/core/Index/TestNRTReaderWithThreads.cs     |    146 -
 test/core/Index/TestNewestSegment.cs            |     41 -
 test/core/Index/TestNorms.cs                    |    285 -
 test/core/Index/TestOmitTf.cs                   |    560 -
 test/core/Index/TestParallelReader.cs           |    315 -
 test/core/Index/TestParallelTermEnum.cs         |    188 -
 test/core/Index/TestPayloads.cs                 |    682 -
 .../Index/TestPositionBasedTermVectorMapper.cs  |    115 -
 test/core/Index/TestRollback.cs                 |     69 -
 test/core/Index/TestSegmentMerger.cs            |    139 -
 test/core/Index/TestSegmentReader.cs            |    233 -
 test/core/Index/TestSegmentTermDocs.cs          |    275 -
 test/core/Index/TestSegmentTermEnum.cs          |    129 -
 test/core/Index/TestSnapshotDeletionPolicy.cs   |    304 -
 test/core/Index/TestStressIndexing.cs           |    222 -
 test/core/Index/TestStressIndexing2.cs          |    803 -
 test/core/Index/TestTerm.cs                     |     51 -
 test/core/Index/TestTermVectorsReader.cs        |    539 -
 test/core/Index/TestTermdocPerf.cs              |    167 -
 test/core/Index/TestThreadedOptimize.cs         |    194 -
 test/core/Index/TestTransactionRollback.cs      |    288 -
 test/core/Index/TestTransactions.cs             |    287 -
 test/core/Index/TestWordlistLoader.cs           |     62 -
 test/core/Index/index.19.cfs.zip                |    Bin 2747 -> 0 bytes
 test/core/Index/index.19.nocfs.zip              |    Bin 8528 -> 0 bytes
 test/core/Index/index.20.cfs.zip                |    Bin 2747 -> 0 bytes
 test/core/Index/index.20.nocfs.zip              |    Bin 8528 -> 0 bytes
 test/core/Index/index.21.cfs.zip                |    Bin 2784 -> 0 bytes
 test/core/Index/index.21.nocfs.zip              |    Bin 7705 -> 0 bytes
 test/core/Index/index.22.cfs.zip                |    Bin 1913 -> 0 bytes
 test/core/Index/index.22.nocfs.zip              |    Bin 5226 -> 0 bytes
 test/core/Index/index.23.cfs.zip                |    Bin 2091 -> 0 bytes
 test/core/Index/index.23.nocfs.zip              |    Bin 3375 -> 0 bytes
 test/core/Index/index.24.cfs.zip                |    Bin 3654 -> 0 bytes
 test/core/Index/index.24.nocfs.zip              |    Bin 7254 -> 0 bytes
 test/core/Index/index.29.cfs.zip                |    Bin 4531 -> 0 bytes
 test/core/Index/index.29.nocfs.zip              |    Bin 8733 -> 0 bytes
 test/core/Lucene.Net.Test.csproj                |    635 -
 test/core/Lucene.Net.snk                        |    Bin 596 -> 0 bytes
 test/core/Messages/MessagesTestBundle.cs        |     49 -
 .../Messages/MessagesTestBundle.ja.resources    |    Bin 441 -> 0 bytes
 test/core/Messages/MessagesTestBundle.resources |    Bin 397 -> 0 bytes
 test/core/Messages/TestNLS.cs                   |     91 -
 test/core/QueryParser/TestMultiAnalyzer.cs      |    348 -
 .../QueryParser/TestMultiFieldQueryParser.cs    |    361 -
 test/core/QueryParser/TestQueryParser.cs        |   1197 -
 test/core/Search/BaseTestRangeFilter.cs         |    176 -
 test/core/Search/CachingWrapperFilterHelper.cs  |     82 -
 test/core/Search/CheckHits.cs                   |    545 -
 test/core/Search/Function/FunctionTestSetup.cs  |    174 -
 .../Search/Function/JustCompileSearchSpans.cs   |    102 -
 .../Search/Function/TestCustomScoreQuery.cs     |    358 -
 test/core/Search/Function/TestDocValues.cs      |    122 -
 .../core/Search/Function/TestFieldScoreQuery.cs |    270 -
 test/core/Search/Function/TestOrdValues.cs      |    293 -
 test/core/Search/JustCompileSearch.cs           |    486 -
 test/core/Search/MockFilter.cs                  |     49 -
 test/core/Search/Payloads/PayloadHelper.cs      |    165 -
 .../Search/Payloads/TestPayloadNearQuery.cs     |    347 -
 .../Search/Payloads/TestPayloadTermQuery.cs     |    401 -
 test/core/Search/QueryUtils.cs                  |    529 -
 test/core/Search/SingleDocTestFilter.cs         |     45 -
 .../core/Search/Spans/JustCompileSearchSpans.cs |    149 -
 test/core/Search/Spans/TestBasics.cs            |    388 -
 .../Search/Spans/TestFieldMaskingSpanQuery.cs   |    323 -
 test/core/Search/Spans/TestNearSpansOrdered.cs  |    195 -
 test/core/Search/Spans/TestPayloadSpans.cs      |    616 -
 test/core/Search/Spans/TestSpanExplanations.cs  |    250 -
 .../Spans/TestSpanExplanationsOfNonMatches.cs   |     44 -
 test/core/Search/Spans/TestSpans.cs             |    533 -
 test/core/Search/Spans/TestSpansAdvanced.cs     |    180 -
 test/core/Search/Spans/TestSpansAdvanced2.cs    |    115 -
 test/core/Search/TestBoolean2.cs                |    350 -
 test/core/Search/TestBooleanMinShouldMatch.cs   |    438 -
 test/core/Search/TestBooleanOr.cs               |    162 -
 test/core/Search/TestBooleanPrefixQuery.cs      |    114 -
 test/core/Search/TestBooleanQuery.cs            |    130 -
 test/core/Search/TestBooleanScorer.cs           |    134 -
 test/core/Search/TestCachingSpanFilter.cs       |    129 -
 test/core/Search/TestCachingWrapperFilter.cs    |    296 -
 test/core/Search/TestComplexExplanations.cs     |    305 -
 .../TestComplexExplanationsOfNonMatches.cs      |     49 -
 test/core/Search/TestCustomSearcherSort.cs      |    305 -
 test/core/Search/TestDateFilter.cs              |    158 -
 test/core/Search/TestDateSort.cs                |    120 -
 test/core/Search/TestDisjunctionMaxQuery.cs     |    517 -
 test/core/Search/TestDocBoost.cs                |    126 -
 test/core/Search/TestDocIdSet.cs                |    224 -
 test/core/Search/TestElevationComparator.cs     |    219 -
 test/core/Search/TestExplanations.cs            |    270 -
 test/core/Search/TestFieldCache.cs              |    150 -
 test/core/Search/TestFieldCacheRangeFilter.cs   |    598 -
 test/core/Search/TestFieldCacheTermsFilter.cs   |     83 -
 test/core/Search/TestFilteredQuery.cs           |    228 -
 test/core/Search/TestFilteredSearch.cs          |    131 -
 test/core/Search/TestFuzzyQuery.cs              |    372 -
 test/core/Search/TestMatchAllDocsQuery.cs       |    152 -
 test/core/Search/TestMultiPhraseQuery.cs        |    233 -
 test/core/Search/TestMultiSearcher.cs           |    458 -
 test/core/Search/TestMultiSearcherRanking.cs    |    186 -
 test/core/Search/TestMultiTermConstantScore.cs  |    721 -
 test/core/Search/TestMultiThreadTermVectors.cs  |    213 -
 .../Search/TestMultiValuedNumericRangeQuery.cs  |     87 -
 test/core/Search/TestNot.cs                     |     58 -
 test/core/Search/TestNumericRangeQuery32.cs     |    591 -
 test/core/Search/TestNumericRangeQuery64.cs     |    590 -
 test/core/Search/TestParallelMultiSearcher.cs   |     35 -
 test/core/Search/TestPhrasePrefixQuery.cs       |    102 -
 test/core/Search/TestPhraseQuery.cs             |    609 -
 test/core/Search/TestPositionIncrement.cs       |    426 -
 .../Search/TestPositiveScoresOnlyCollector.cs   |     99 -
 test/core/Search/TestPrefixFilter.cs            |    110 -
 test/core/Search/TestPrefixInBooleanQuery.cs    |    119 -
 test/core/Search/TestPrefixQuery.cs             |     64 -
 test/core/Search/TestQueryTermVector.cs         |     67 -
 test/core/Search/TestQueryWrapperFilter.cs      |     77 -
 .../Search/TestScoreCachingWrappingScorer.cs    |    132 -
 test/core/Search/TestScorerPerf.cs              |    471 -
 test/core/Search/TestSetNorm.cs                 |    118 -
 test/core/Search/TestSimilarity.cs              |    282 -
 test/core/Search/TestSimpleExplanations.cs      |    467 -
 .../TestSimpleExplanationsOfNonMatches.cs       |     49 -
 test/core/Search/TestSloppyPhraseQuery.cs       |    174 -
 test/core/Search/TestSort.cs                    |   1276 -
 test/core/Search/TestSpanQueryFilter.cs         |     95 -
 test/core/Search/TestTermRangeFilter.cs         |    422 -
 test/core/Search/TestTermRangeQuery.cs          |    395 -
 test/core/Search/TestTermScorer.cs              |    214 -
 test/core/Search/TestTermVectors.cs             |    465 -
 test/core/Search/TestThreadSafe.cs              |    216 -
 test/core/Search/TestTimeLimitingCollector.cs   |    415 -
 test/core/Search/TestTopDocsCollector.cs        |    236 -
 test/core/Search/TestTopScoreDocCollector.cs    |     86 -
 test/core/Search/TestWildcard.cs                |    360 -
 test/core/Store/MockRAMDirectory.cs             |    440 -
 test/core/Store/MockRAMInputStream.cs           |     97 -
 test/core/Store/MockRAMOutputStream.cs          |    119 -
 test/core/Store/TestBufferedIndexInput.cs       |    411 -
 test/core/Store/TestDirectory.cs                |    231 -
 test/core/Store/TestFileSwitchDirectory.cs      |     81 -
 test/core/Store/TestHugeRamFile.cs              |    121 -
 test/core/Store/TestLock.cs                     |     78 -
 test/core/Store/TestLockFactory.cs              |    506 -
 test/core/Store/TestMultiMMap.cs                |     39 -
 test/core/Store/TestRAMDirectory.cs             |    219 -
 test/core/Store/TestWindowsMMap.cs              |    137 -
 test/core/Store/_TestHelper.cs                  |     76 -
 test/core/Support/BigObject.cs                  |     35 -
 test/core/Support/CollisionTester.cs            |     50 -
 test/core/Support/SmallObject.cs                |     33 -
 test/core/Support/TestCase.cs                   |     54 -
 test/core/Support/TestCloseableThreadLocal.cs   |    108 -
 test/core/Support/TestEquatableList.cs          |    167 -
 test/core/Support/TestExceptionSerialization.cs |    102 -
 test/core/Support/TestHashMap.cs                |    213 -
 test/core/Support/TestIDisposable.cs            |     67 -
 test/core/Support/TestLRUCache.cs               |     47 -
 test/core/Support/TestOSClass.cs                |     48 -
 test/core/Support/TestOldPatches.cs             |    292 -
 test/core/Support/TestSerialization.cs          |    102 -
 test/core/Support/TestSupportClass.cs           |     86 -
 test/core/Support/TestThreadClass.cs            |     59 -
 test/core/Support/TestWeakDictionary.cs         |    148 -
 test/core/Support/TestWeakDictionaryBehavior.cs |    291 -
 .../Support/TestWeakDictionaryPerformance.cs    |    134 -
 test/core/SupportClassException.cs              |     47 -
 test/core/Test.nunit                            |     22 -
 test/core/TestDemo.cs                           |     84 -
 test/core/TestMergeSchedulerExternal.cs         |    186 -
 test/core/TestSearch.cs                         |    128 -
 test/core/TestSearchForDuplicates.cs            |    161 -
 test/core/Util/ArrayUtilTest.cs                 |     95 -
 test/core/Util/Cache/TestSimpleLRUCache.cs      |     77 -
 test/core/Util/English.cs                       |    154 -
 test/core/Util/LocalizedTestCase.cs             |    140 -
 test/core/Util/LuceneTestCase.cs                |    297 -
 test/core/Util/Paths.cs                         |    186 -
 test/core/Util/TestAttributeSource.cs           |    179 -
 test/core/Util/TestBitVector.cs                 |    311 -
 test/core/Util/TestCloseableThreadLocal.cs      |     83 -
 test/core/Util/TestFieldCacheSanityChecker.cs   |    193 -
 .../core/Util/TestIndexableBinaryStringTools.cs |    182 -
 test/core/Util/TestNumericUtils.cs              |    569 -
 test/core/Util/TestOpenBitSet.cs                |    394 -
 test/core/Util/TestParameter.cs                 |     75 -
 test/core/Util/TestPriorityQueue.cs             |    131 -
 test/core/Util/TestRamUsageEstimator.cs         |     68 -
 test/core/Util/TestSmallFloat.cs                |    134 -
 test/core/Util/TestSortedVIntList.cs            |    244 -
 test/core/Util/TestStringHelper.cs              |     48 -
 test/core/Util/TestStringIntern.cs              |    137 -
 test/core/Util/TestVersion.cs                   |     38 -
 test/core/Util/_TestUtil.cs                     |    183 -
 3150 files changed, 417537 insertions(+), 704507 deletions(-)
----------------------------------------------------------------------



[44/51] [abbrv] [partial] Cleaning up and getting ready to development towards v4.8

Posted by sy...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/vs2010/test/Contrib.SpellChecker.Test.sln
----------------------------------------------------------------------
diff --git a/build/vs2010/test/Contrib.SpellChecker.Test.sln b/build/vs2010/test/Contrib.SpellChecker.Test.sln
deleted file mode 100644
index f93e73c..0000000
--- a/build/vs2010/test/Contrib.SpellChecker.Test.sln
+++ /dev/null
@@ -1,66 +0,0 @@
-
-Microsoft Visual Studio Solution File, Format Version 11.00
-# Visual C# Express 2010
-#
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-#
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net", "..\..\..\src\core\Lucene.Net.csproj", "{5D4AD9BE-1FFB-41AB-9943-25737971BF57}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.SpellChecker", "..\..\..\src\contrib\SpellChecker\Contrib.SpellChecker.csproj", "{FF45EE91-9CA3-443D-8231-75E9FA1AF40E}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.SpellChecker.Test", "..\..\..\test\contrib\SpellChecker\Contrib.SpellChecker.Test.csproj", "{4DCB81AA-ECC1-4B3D-A0C9-28E54F5B125C}"
-EndProject
-Global
-	GlobalSection(SolutionConfigurationPlatforms) = preSolution
-		Debug35|Any CPU = Debug35|Any CPU
-		Debug|Any CPU = Debug|Any CPU
-		Release35|Any CPU = Release35|Any CPU
-		Release|Any CPU = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(ProjectConfigurationPlatforms) = postSolution
-		{4DCB81AA-ECC1-4B3D-A0C9-28E54F5B125C}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{4DCB81AA-ECC1-4B3D-A0C9-28E54F5B125C}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{4DCB81AA-ECC1-4B3D-A0C9-28E54F5B125C}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{4DCB81AA-ECC1-4B3D-A0C9-28E54F5B125C}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{4DCB81AA-ECC1-4B3D-A0C9-28E54F5B125C}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{4DCB81AA-ECC1-4B3D-A0C9-28E54F5B125C}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{4DCB81AA-ECC1-4B3D-A0C9-28E54F5B125C}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{4DCB81AA-ECC1-4B3D-A0C9-28E54F5B125C}.Release|Any CPU.Build.0 = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.Build.0 = Release|Any CPU
-		{FF45EE91-9CA3-443D-8231-75E9FA1AF40E}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{FF45EE91-9CA3-443D-8231-75E9FA1AF40E}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{FF45EE91-9CA3-443D-8231-75E9FA1AF40E}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{FF45EE91-9CA3-443D-8231-75E9FA1AF40E}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{FF45EE91-9CA3-443D-8231-75E9FA1AF40E}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{FF45EE91-9CA3-443D-8231-75E9FA1AF40E}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{FF45EE91-9CA3-443D-8231-75E9FA1AF40E}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{FF45EE91-9CA3-443D-8231-75E9FA1AF40E}.Release|Any CPU.Build.0 = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(SolutionProperties) = preSolution
-		HideSolutionNode = FALSE
-	EndGlobalSection
-EndGlobal

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/vs2010/test/Lucene.Net.Test.sln
----------------------------------------------------------------------
diff --git a/build/vs2010/test/Lucene.Net.Test.sln b/build/vs2010/test/Lucene.Net.Test.sln
deleted file mode 100644
index 317f825..0000000
--- a/build/vs2010/test/Lucene.Net.Test.sln
+++ /dev/null
@@ -1,66 +0,0 @@
-
-Microsoft Visual Studio Solution File, Format Version 11.00
-# Visual C# Express 2010
-#
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-#
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net", "..\..\..\src\core\Lucene.Net.csproj", "{5D4AD9BE-1FFB-41AB-9943-25737971BF57}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net.Test", "..\..\..\test\core\Lucene.Net.Test.csproj", "{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Demo.Common", "..\..\..\src\demo\Demo.Common\Demo.Common.csproj", "{F04CA2F4-E182-46A8-B914-F46AF5319E83}"
-EndProject
-Global
-	GlobalSection(SolutionConfigurationPlatforms) = preSolution
-		Debug35|Any CPU = Debug35|Any CPU
-		Debug|Any CPU = Debug|Any CPU
-		Release35|Any CPU = Release35|Any CPU
-		Release|Any CPU = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(ProjectConfigurationPlatforms) = postSolution
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.Build.0 = Release|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Release|Any CPU.Build.0 = Release|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Release|Any CPU.Build.0 = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(SolutionProperties) = preSolution
-		HideSolutionNode = FALSE
-	EndGlobalSection
-EndGlobal

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/vs2012/contrib/Contrib.All.sln
----------------------------------------------------------------------
diff --git a/build/vs2012/contrib/Contrib.All.sln b/build/vs2012/contrib/Contrib.All.sln
deleted file mode 100644
index 9a707eb..0000000
--- a/build/vs2012/contrib/Contrib.All.sln
+++ /dev/null
@@ -1,196 +0,0 @@
-
-Microsoft Visual Studio Solution File, Format Version 12.00
-# Visual Studio 2012
-#
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-#
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net", "..\..\..\src\core\Lucene.Net.csproj", "{5D4AD9BE-1FFB-41AB-9943-25737971BF57}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Core", "..\..\..\src\contrib\Core\Contrib.Core.csproj", "{FEF899EB-610C-4D3C-A556-A01F56F4AFE0}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Analyzers", "..\..\..\src\contrib\Analyzers\Contrib.Analyzers.csproj", "{4286E961-9143-4821-B46D-3D39D3736386}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.FastVectorHighlighter", "..\..\..\src\contrib\FastVectorHighlighter\Contrib.FastVectorHighlighter.csproj", "{9D2E3153-076F-49C5-B83D-FB2573536B5F}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Highlighter", "..\..\..\src\contrib\Highlighter\Contrib.Highlighter.csproj", "{901D5415-383C-4AA6-A256-879558841BEA}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Queries", "..\..\..\src\contrib\Queries\Contrib.Queries.csproj", "{481CF6E3-52AF-4621-9DEB-022122079AF6}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Snowball", "..\..\..\src\contrib\Snowball\Contrib.Snowball.csproj", "{8F9D7A92-F122-413E-9D8D-027E4ECD327C}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Spatial", "..\..\..\src\contrib\Spatial\Contrib.Spatial.csproj", "{35C347F4-24B2-4BE5-8117-A0E3001551CE}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.SpellChecker", "..\..\..\src\contrib\SpellChecker\Contrib.SpellChecker.csproj", "{FF45EE91-9CA3-443D-8231-75E9FA1AF40E}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.WordNet.SynExpand", "..\..\..\src\contrib\WordNet\SynExpand\Contrib.WordNet.SynExpand.csproj", "{1407C9BA-337C-4C6C-B065-68328D3871B3}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.WordNet.SynLookup", "..\..\..\src\contrib\WordNet\SynLookup\Contrib.WordNet.SynLookup.csproj", "{2CA12E3F-76E1-4FA6-9E87-37079A7B7C69}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.WordNet.Syns2Index", "..\..\..\src\contrib\WordNet\Syns2Index\Contrib.WordNet.Syns2Index.csproj", "{7563D4D9-AE91-42BA-A270-1D264660F6DF}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Regex", "..\..\..\src\contrib\Regex\Contrib.Regex.csproj", "{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "SimpleFacetedSearch", "..\..\..\src\contrib\SimpleFacetedSearch\SimpleFacetedSearch.csproj", "{66772190-FB3F-48F5-8E05-0B302BACEA73}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Memory", "..\..\..\src\contrib\Memory\Contrib.Memory.csproj", "{112B9A7C-29CC-4539-8F5A-45669C07CD4D}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Spatial.NTS", "..\..\..\src\contrib\Spatial\Contrib.Spatial.NTS.csproj", "{02D030D0-C7B5-4561-8BDD-41408B2E2F41}"
-EndProject
-Global
-	GlobalSection(SolutionConfigurationPlatforms) = preSolution
-		Debug|Any CPU = Debug|Any CPU
-		Debug35|Any CPU = Debug35|Any CPU
-		Release|Any CPU = Release|Any CPU
-		Release35|Any CPU = Release35|Any CPU
-	EndGlobalSection
-	GlobalSection(ProjectConfigurationPlatforms) = postSolution
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.Build.0 = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{FEF899EB-610C-4D3C-A556-A01F56F4AFE0}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{FEF899EB-610C-4D3C-A556-A01F56F4AFE0}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{FEF899EB-610C-4D3C-A556-A01F56F4AFE0}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{FEF899EB-610C-4D3C-A556-A01F56F4AFE0}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{FEF899EB-610C-4D3C-A556-A01F56F4AFE0}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{FEF899EB-610C-4D3C-A556-A01F56F4AFE0}.Release|Any CPU.Build.0 = Release|Any CPU
-		{FEF899EB-610C-4D3C-A556-A01F56F4AFE0}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{FEF899EB-610C-4D3C-A556-A01F56F4AFE0}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{4286E961-9143-4821-B46D-3D39D3736386}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{4286E961-9143-4821-B46D-3D39D3736386}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{4286E961-9143-4821-B46D-3D39D3736386}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{4286E961-9143-4821-B46D-3D39D3736386}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{4286E961-9143-4821-B46D-3D39D3736386}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{4286E961-9143-4821-B46D-3D39D3736386}.Release|Any CPU.Build.0 = Release|Any CPU
-		{4286E961-9143-4821-B46D-3D39D3736386}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{4286E961-9143-4821-B46D-3D39D3736386}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{9D2E3153-076F-49C5-B83D-FB2573536B5F}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{9D2E3153-076F-49C5-B83D-FB2573536B5F}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{9D2E3153-076F-49C5-B83D-FB2573536B5F}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{9D2E3153-076F-49C5-B83D-FB2573536B5F}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{9D2E3153-076F-49C5-B83D-FB2573536B5F}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{9D2E3153-076F-49C5-B83D-FB2573536B5F}.Release|Any CPU.Build.0 = Release|Any CPU
-		{9D2E3153-076F-49C5-B83D-FB2573536B5F}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{9D2E3153-076F-49C5-B83D-FB2573536B5F}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{901D5415-383C-4AA6-A256-879558841BEA}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{901D5415-383C-4AA6-A256-879558841BEA}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{901D5415-383C-4AA6-A256-879558841BEA}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{901D5415-383C-4AA6-A256-879558841BEA}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{901D5415-383C-4AA6-A256-879558841BEA}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{901D5415-383C-4AA6-A256-879558841BEA}.Release|Any CPU.Build.0 = Release|Any CPU
-		{901D5415-383C-4AA6-A256-879558841BEA}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{901D5415-383C-4AA6-A256-879558841BEA}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{481CF6E3-52AF-4621-9DEB-022122079AF6}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{481CF6E3-52AF-4621-9DEB-022122079AF6}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{481CF6E3-52AF-4621-9DEB-022122079AF6}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{481CF6E3-52AF-4621-9DEB-022122079AF6}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{481CF6E3-52AF-4621-9DEB-022122079AF6}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{481CF6E3-52AF-4621-9DEB-022122079AF6}.Release|Any CPU.Build.0 = Release|Any CPU
-		{481CF6E3-52AF-4621-9DEB-022122079AF6}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{481CF6E3-52AF-4621-9DEB-022122079AF6}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{8F9D7A92-F122-413E-9D8D-027E4ECD327C}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{8F9D7A92-F122-413E-9D8D-027E4ECD327C}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{8F9D7A92-F122-413E-9D8D-027E4ECD327C}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{8F9D7A92-F122-413E-9D8D-027E4ECD327C}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{8F9D7A92-F122-413E-9D8D-027E4ECD327C}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{8F9D7A92-F122-413E-9D8D-027E4ECD327C}.Release|Any CPU.Build.0 = Release|Any CPU
-		{8F9D7A92-F122-413E-9D8D-027E4ECD327C}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{8F9D7A92-F122-413E-9D8D-027E4ECD327C}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{35C347F4-24B2-4BE5-8117-A0E3001551CE}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{35C347F4-24B2-4BE5-8117-A0E3001551CE}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{35C347F4-24B2-4BE5-8117-A0E3001551CE}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{35C347F4-24B2-4BE5-8117-A0E3001551CE}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{35C347F4-24B2-4BE5-8117-A0E3001551CE}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{35C347F4-24B2-4BE5-8117-A0E3001551CE}.Release|Any CPU.Build.0 = Release|Any CPU
-		{35C347F4-24B2-4BE5-8117-A0E3001551CE}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{35C347F4-24B2-4BE5-8117-A0E3001551CE}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{FF45EE91-9CA3-443D-8231-75E9FA1AF40E}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{FF45EE91-9CA3-443D-8231-75E9FA1AF40E}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{FF45EE91-9CA3-443D-8231-75E9FA1AF40E}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{FF45EE91-9CA3-443D-8231-75E9FA1AF40E}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{FF45EE91-9CA3-443D-8231-75E9FA1AF40E}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{FF45EE91-9CA3-443D-8231-75E9FA1AF40E}.Release|Any CPU.Build.0 = Release|Any CPU
-		{FF45EE91-9CA3-443D-8231-75E9FA1AF40E}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{FF45EE91-9CA3-443D-8231-75E9FA1AF40E}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{1407C9BA-337C-4C6C-B065-68328D3871B3}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{1407C9BA-337C-4C6C-B065-68328D3871B3}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{1407C9BA-337C-4C6C-B065-68328D3871B3}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{1407C9BA-337C-4C6C-B065-68328D3871B3}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{1407C9BA-337C-4C6C-B065-68328D3871B3}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{1407C9BA-337C-4C6C-B065-68328D3871B3}.Release|Any CPU.Build.0 = Release|Any CPU
-		{1407C9BA-337C-4C6C-B065-68328D3871B3}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{1407C9BA-337C-4C6C-B065-68328D3871B3}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{2CA12E3F-76E1-4FA6-9E87-37079A7B7C69}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{2CA12E3F-76E1-4FA6-9E87-37079A7B7C69}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{2CA12E3F-76E1-4FA6-9E87-37079A7B7C69}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{2CA12E3F-76E1-4FA6-9E87-37079A7B7C69}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{2CA12E3F-76E1-4FA6-9E87-37079A7B7C69}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{2CA12E3F-76E1-4FA6-9E87-37079A7B7C69}.Release|Any CPU.Build.0 = Release|Any CPU
-		{2CA12E3F-76E1-4FA6-9E87-37079A7B7C69}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{2CA12E3F-76E1-4FA6-9E87-37079A7B7C69}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{7563D4D9-AE91-42BA-A270-1D264660F6DF}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{7563D4D9-AE91-42BA-A270-1D264660F6DF}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{7563D4D9-AE91-42BA-A270-1D264660F6DF}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{7563D4D9-AE91-42BA-A270-1D264660F6DF}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{7563D4D9-AE91-42BA-A270-1D264660F6DF}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{7563D4D9-AE91-42BA-A270-1D264660F6DF}.Release|Any CPU.Build.0 = Release|Any CPU
-		{7563D4D9-AE91-42BA-A270-1D264660F6DF}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{7563D4D9-AE91-42BA-A270-1D264660F6DF}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Release|Any CPU.Build.0 = Release|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Release|Any CPU.Build.0 = Release|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Release|Any CPU.Build.0 = Release|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{02D030D0-C7B5-4561-8BDD-41408B2E2F41}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{02D030D0-C7B5-4561-8BDD-41408B2E2F41}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{02D030D0-C7B5-4561-8BDD-41408B2E2F41}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{02D030D0-C7B5-4561-8BDD-41408B2E2F41}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{02D030D0-C7B5-4561-8BDD-41408B2E2F41}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{02D030D0-C7B5-4561-8BDD-41408B2E2F41}.Release|Any CPU.Build.0 = Release|Any CPU
-		{02D030D0-C7B5-4561-8BDD-41408B2E2F41}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{02D030D0-C7B5-4561-8BDD-41408B2E2F41}.Release35|Any CPU.Build.0 = Release35|Any CPU
-	EndGlobalSection
-	GlobalSection(SolutionProperties) = preSolution
-		HideSolutionNode = FALSE
-	EndGlobalSection
-EndGlobal

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/vs2012/contrib/Contrib.Analyzers.sln
----------------------------------------------------------------------
diff --git a/build/vs2012/contrib/Contrib.Analyzers.sln b/build/vs2012/contrib/Contrib.Analyzers.sln
deleted file mode 100644
index e44e692..0000000
--- a/build/vs2012/contrib/Contrib.Analyzers.sln
+++ /dev/null
@@ -1,56 +0,0 @@
-
-Microsoft Visual Studio Solution File, Format Version 12.00
-# Visual Studio 2012
-#
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-#
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net", "..\..\..\src\core\Lucene.Net.csproj", "{5D4AD9BE-1FFB-41AB-9943-25737971BF57}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Analyzers", "..\..\..\src\contrib\Analyzers\Contrib.Analyzers.csproj", "{4286E961-9143-4821-B46D-3D39D3736386}"
-EndProject
-Global
-	GlobalSection(SolutionConfigurationPlatforms) = preSolution
-		Debug35|Any CPU = Debug35|Any CPU
-		Debug|Any CPU = Debug|Any CPU
-		Release35|Any CPU = Release35|Any CPU
-		Release|Any CPU = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(ProjectConfigurationPlatforms) = postSolution
-		{4286E961-9143-4821-B46D-3D39D3736386}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{4286E961-9143-4821-B46D-3D39D3736386}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{4286E961-9143-4821-B46D-3D39D3736386}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{4286E961-9143-4821-B46D-3D39D3736386}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{4286E961-9143-4821-B46D-3D39D3736386}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{4286E961-9143-4821-B46D-3D39D3736386}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{4286E961-9143-4821-B46D-3D39D3736386}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{4286E961-9143-4821-B46D-3D39D3736386}.Release|Any CPU.Build.0 = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.Build.0 = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(SolutionProperties) = preSolution
-		HideSolutionNode = FALSE
-	EndGlobalSection
-EndGlobal

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/vs2012/contrib/Contrib.Core.sln
----------------------------------------------------------------------
diff --git a/build/vs2012/contrib/Contrib.Core.sln b/build/vs2012/contrib/Contrib.Core.sln
deleted file mode 100644
index 15e09d6..0000000
--- a/build/vs2012/contrib/Contrib.Core.sln
+++ /dev/null
@@ -1,56 +0,0 @@
-
-Microsoft Visual Studio Solution File, Format Version 12.00
-# Visual Studio 2012
-#
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-#
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net", "..\..\..\src\core\Lucene.Net.csproj", "{5D4AD9BE-1FFB-41AB-9943-25737971BF57}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Core", "..\..\..\src\contrib\Core\Contrib.Core.csproj", "{FEF899EB-610C-4D3C-A556-A01F56F4AFE0}"
-EndProject
-Global
-	GlobalSection(SolutionConfigurationPlatforms) = preSolution
-		Debug35|Any CPU = Debug35|Any CPU
-		Debug|Any CPU = Debug|Any CPU
-		Release35|Any CPU = Release35|Any CPU
-		Release|Any CPU = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(ProjectConfigurationPlatforms) = postSolution
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.Build.0 = Release|Any CPU
-		{FEF899EB-610C-4D3C-A556-A01F56F4AFE0}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{FEF899EB-610C-4D3C-A556-A01F56F4AFE0}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{FEF899EB-610C-4D3C-A556-A01F56F4AFE0}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{FEF899EB-610C-4D3C-A556-A01F56F4AFE0}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{FEF899EB-610C-4D3C-A556-A01F56F4AFE0}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{FEF899EB-610C-4D3C-A556-A01F56F4AFE0}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{FEF899EB-610C-4D3C-A556-A01F56F4AFE0}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{FEF899EB-610C-4D3C-A556-A01F56F4AFE0}.Release|Any CPU.Build.0 = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(SolutionProperties) = preSolution
-		HideSolutionNode = FALSE
-	EndGlobalSection
-EndGlobal

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/vs2012/contrib/Contrib.FastVectorHighlighter.sln
----------------------------------------------------------------------
diff --git a/build/vs2012/contrib/Contrib.FastVectorHighlighter.sln b/build/vs2012/contrib/Contrib.FastVectorHighlighter.sln
deleted file mode 100644
index 21ad549..0000000
--- a/build/vs2012/contrib/Contrib.FastVectorHighlighter.sln
+++ /dev/null
@@ -1,56 +0,0 @@
-
-Microsoft Visual Studio Solution File, Format Version 12.00
-# Visual Studio 2012
-#
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-#
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net", "..\..\..\src\core\Lucene.Net.csproj", "{5D4AD9BE-1FFB-41AB-9943-25737971BF57}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.FastVectorHighlighter", "..\..\..\src\contrib\FastVectorHighlighter\Contrib.FastVectorHighlighter.csproj", "{9D2E3153-076F-49C5-B83D-FB2573536B5F}"
-EndProject
-Global
-	GlobalSection(SolutionConfigurationPlatforms) = preSolution
-		Debug35|Any CPU = Debug35|Any CPU
-		Debug|Any CPU = Debug|Any CPU
-		Release35|Any CPU = Release35|Any CPU
-		Release|Any CPU = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(ProjectConfigurationPlatforms) = postSolution
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.Build.0 = Release|Any CPU
-		{9D2E3153-076F-49C5-B83D-FB2573536B5F}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{9D2E3153-076F-49C5-B83D-FB2573536B5F}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{9D2E3153-076F-49C5-B83D-FB2573536B5F}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{9D2E3153-076F-49C5-B83D-FB2573536B5F}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{9D2E3153-076F-49C5-B83D-FB2573536B5F}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{9D2E3153-076F-49C5-B83D-FB2573536B5F}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{9D2E3153-076F-49C5-B83D-FB2573536B5F}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{9D2E3153-076F-49C5-B83D-FB2573536B5F}.Release|Any CPU.Build.0 = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(SolutionProperties) = preSolution
-		HideSolutionNode = FALSE
-	EndGlobalSection
-EndGlobal

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/vs2012/contrib/Contrib.Highlighter.sln
----------------------------------------------------------------------
diff --git a/build/vs2012/contrib/Contrib.Highlighter.sln b/build/vs2012/contrib/Contrib.Highlighter.sln
deleted file mode 100644
index b20a7cb..0000000
--- a/build/vs2012/contrib/Contrib.Highlighter.sln
+++ /dev/null
@@ -1,66 +0,0 @@
-
-Microsoft Visual Studio Solution File, Format Version 12.00
-# Visual Studio 2012
-#
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-#
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net", "..\..\..\src\core\Lucene.Net.csproj", "{5D4AD9BE-1FFB-41AB-9943-25737971BF57}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Highlighter", "..\..\..\src\contrib\Highlighter\Contrib.Highlighter.csproj", "{901D5415-383C-4AA6-A256-879558841BEA}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Memory", "..\..\..\src\contrib\Memory\Contrib.Memory.csproj", "{112B9A7C-29CC-4539-8F5A-45669C07CD4D}"
-EndProject
-Global
-	GlobalSection(SolutionConfigurationPlatforms) = preSolution
-		Debug35|Any CPU = Debug35|Any CPU
-		Debug|Any CPU = Debug|Any CPU
-		Release35|Any CPU = Release35|Any CPU
-		Release|Any CPU = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(ProjectConfigurationPlatforms) = postSolution
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Release|Any CPU.Build.0 = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.Build.0 = Release|Any CPU
-		{901D5415-383C-4AA6-A256-879558841BEA}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{901D5415-383C-4AA6-A256-879558841BEA}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{901D5415-383C-4AA6-A256-879558841BEA}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{901D5415-383C-4AA6-A256-879558841BEA}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{901D5415-383C-4AA6-A256-879558841BEA}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{901D5415-383C-4AA6-A256-879558841BEA}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{901D5415-383C-4AA6-A256-879558841BEA}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{901D5415-383C-4AA6-A256-879558841BEA}.Release|Any CPU.Build.0 = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(SolutionProperties) = preSolution
-		HideSolutionNode = FALSE
-	EndGlobalSection
-EndGlobal

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/vs2012/contrib/Contrib.Memory.sln
----------------------------------------------------------------------
diff --git a/build/vs2012/contrib/Contrib.Memory.sln b/build/vs2012/contrib/Contrib.Memory.sln
deleted file mode 100644
index 5a8ae6f..0000000
--- a/build/vs2012/contrib/Contrib.Memory.sln
+++ /dev/null
@@ -1,56 +0,0 @@
-
-Microsoft Visual Studio Solution File, Format Version 12.00
-# Visual Studio 2012
-#
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-#
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net", "..\..\..\src\core\Lucene.Net.csproj", "{5D4AD9BE-1FFB-41AB-9943-25737971BF57}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Memory", "..\..\..\src\contrib\Memory\Contrib.Memory.csproj", "{112B9A7C-29CC-4539-8F5A-45669C07CD4D}"
-EndProject
-Global
-	GlobalSection(SolutionConfigurationPlatforms) = preSolution
-		Debug35|Any CPU = Debug35|Any CPU
-		Debug|Any CPU = Debug|Any CPU
-		Release35|Any CPU = Release35|Any CPU
-		Release|Any CPU = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(ProjectConfigurationPlatforms) = postSolution
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Release|Any CPU.Build.0 = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.Build.0 = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(SolutionProperties) = preSolution
-		HideSolutionNode = FALSE
-	EndGlobalSection
-EndGlobal

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/vs2012/contrib/Contrib.Queries.sln
----------------------------------------------------------------------
diff --git a/build/vs2012/contrib/Contrib.Queries.sln b/build/vs2012/contrib/Contrib.Queries.sln
deleted file mode 100644
index dc468f7..0000000
--- a/build/vs2012/contrib/Contrib.Queries.sln
+++ /dev/null
@@ -1,56 +0,0 @@
-
-Microsoft Visual Studio Solution File, Format Version 12.00
-# Visual Studio 2012
-#
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-#
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net", "..\..\..\src\core\Lucene.Net.csproj", "{5D4AD9BE-1FFB-41AB-9943-25737971BF57}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Queries", "..\..\..\src\contrib\Queries\Contrib.Queries.csproj", "{481CF6E3-52AF-4621-9DEB-022122079AF6}"
-EndProject
-Global
-	GlobalSection(SolutionConfigurationPlatforms) = preSolution
-		Debug35|Any CPU = Debug35|Any CPU
-		Debug|Any CPU = Debug|Any CPU
-		Release35|Any CPU = Release35|Any CPU
-		Release|Any CPU = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(ProjectConfigurationPlatforms) = postSolution
-		{481CF6E3-52AF-4621-9DEB-022122079AF6}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{481CF6E3-52AF-4621-9DEB-022122079AF6}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{481CF6E3-52AF-4621-9DEB-022122079AF6}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{481CF6E3-52AF-4621-9DEB-022122079AF6}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{481CF6E3-52AF-4621-9DEB-022122079AF6}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{481CF6E3-52AF-4621-9DEB-022122079AF6}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{481CF6E3-52AF-4621-9DEB-022122079AF6}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{481CF6E3-52AF-4621-9DEB-022122079AF6}.Release|Any CPU.Build.0 = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.Build.0 = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(SolutionProperties) = preSolution
-		HideSolutionNode = FALSE
-	EndGlobalSection
-EndGlobal

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/vs2012/contrib/Contrib.Regex.sln
----------------------------------------------------------------------
diff --git a/build/vs2012/contrib/Contrib.Regex.sln b/build/vs2012/contrib/Contrib.Regex.sln
deleted file mode 100644
index e997043..0000000
--- a/build/vs2012/contrib/Contrib.Regex.sln
+++ /dev/null
@@ -1,56 +0,0 @@
-
-Microsoft Visual Studio Solution File, Format Version 12.00
-# Visual Studio 2012
-#
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-#
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net", "..\..\..\src\core\Lucene.Net.csproj", "{5D4AD9BE-1FFB-41AB-9943-25737971BF57}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Regex", "..\..\..\src\contrib\Regex\Contrib.Regex.csproj", "{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}"
-EndProject
-Global
-	GlobalSection(SolutionConfigurationPlatforms) = preSolution
-		Debug35|Any CPU = Debug35|Any CPU
-		Debug|Any CPU = Debug|Any CPU
-		Release35|Any CPU = Release35|Any CPU
-		Release|Any CPU = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(ProjectConfigurationPlatforms) = postSolution
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.Build.0 = Release|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Release|Any CPU.Build.0 = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(SolutionProperties) = preSolution
-		HideSolutionNode = FALSE
-	EndGlobalSection
-EndGlobal

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/vs2012/contrib/Contrib.SimpleFacetedSearch.sln
----------------------------------------------------------------------
diff --git a/build/vs2012/contrib/Contrib.SimpleFacetedSearch.sln b/build/vs2012/contrib/Contrib.SimpleFacetedSearch.sln
deleted file mode 100644
index 2044986..0000000
--- a/build/vs2012/contrib/Contrib.SimpleFacetedSearch.sln
+++ /dev/null
@@ -1,56 +0,0 @@
-
-Microsoft Visual Studio Solution File, Format Version 12.00
-# Visual Studio 2012
-#
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-#
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "SimpleFacetedSearch", "..\..\..\src\contrib\SimpleFacetedSearch\SimpleFacetedSearch.csproj", "{66772190-FB3F-48F5-8E05-0B302BACEA73}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net", "..\..\..\src\core\Lucene.Net.csproj", "{5D4AD9BE-1FFB-41AB-9943-25737971BF57}"
-EndProject
-Global
-	GlobalSection(SolutionConfigurationPlatforms) = preSolution
-		Debug35|Any CPU = Debug35|Any CPU
-		Debug|Any CPU = Debug|Any CPU
-		Release35|Any CPU = Release35|Any CPU
-		Release|Any CPU = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(ProjectConfigurationPlatforms) = postSolution
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.Build.0 = Release|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Release|Any CPU.Build.0 = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(SolutionProperties) = preSolution
-		HideSolutionNode = FALSE
-	EndGlobalSection
-EndGlobal

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/vs2012/contrib/Contrib.Snowball.sln
----------------------------------------------------------------------
diff --git a/build/vs2012/contrib/Contrib.Snowball.sln b/build/vs2012/contrib/Contrib.Snowball.sln
deleted file mode 100644
index 2a908c4..0000000
--- a/build/vs2012/contrib/Contrib.Snowball.sln
+++ /dev/null
@@ -1,56 +0,0 @@
-
-Microsoft Visual Studio Solution File, Format Version 12.00
-# Visual Studio 2012
-#
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-#
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net", "..\..\..\src\core\Lucene.Net.csproj", "{5D4AD9BE-1FFB-41AB-9943-25737971BF57}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Snowball", "..\..\..\src\contrib\Snowball\Contrib.Snowball.csproj", "{8F9D7A92-F122-413E-9D8D-027E4ECD327C}"
-EndProject
-Global
-	GlobalSection(SolutionConfigurationPlatforms) = preSolution
-		Debug35|Any CPU = Debug35|Any CPU
-		Debug|Any CPU = Debug|Any CPU
-		Release35|Any CPU = Release35|Any CPU
-		Release|Any CPU = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(ProjectConfigurationPlatforms) = postSolution
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.Build.0 = Release|Any CPU
-		{8F9D7A92-F122-413E-9D8D-027E4ECD327C}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{8F9D7A92-F122-413E-9D8D-027E4ECD327C}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{8F9D7A92-F122-413E-9D8D-027E4ECD327C}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{8F9D7A92-F122-413E-9D8D-027E4ECD327C}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{8F9D7A92-F122-413E-9D8D-027E4ECD327C}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{8F9D7A92-F122-413E-9D8D-027E4ECD327C}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{8F9D7A92-F122-413E-9D8D-027E4ECD327C}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{8F9D7A92-F122-413E-9D8D-027E4ECD327C}.Release|Any CPU.Build.0 = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(SolutionProperties) = preSolution
-		HideSolutionNode = FALSE
-	EndGlobalSection
-EndGlobal

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/vs2012/contrib/Contrib.Spatial.sln
----------------------------------------------------------------------
diff --git a/build/vs2012/contrib/Contrib.Spatial.sln b/build/vs2012/contrib/Contrib.Spatial.sln
deleted file mode 100644
index 0c50e46..0000000
--- a/build/vs2012/contrib/Contrib.Spatial.sln
+++ /dev/null
@@ -1,66 +0,0 @@
-
-Microsoft Visual Studio Solution File, Format Version 12.00
-# Visual Studio 2012
-#
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-#
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net", "..\..\..\src\core\Lucene.Net.csproj", "{5D4AD9BE-1FFB-41AB-9943-25737971BF57}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Spatial", "..\..\..\src\contrib\Spatial\Contrib.Spatial.csproj", "{35C347F4-24B2-4BE5-8117-A0E3001551CE}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Spatial.NTS", "..\..\..\src\contrib\Spatial\Contrib.Spatial.NTS.csproj", "{02D030D0-C7B5-4561-8BDD-41408B2E2F41}"
-EndProject
-Global
-	GlobalSection(SolutionConfigurationPlatforms) = preSolution
-		Debug|Any CPU = Debug|Any CPU
-		Debug35|Any CPU = Debug35|Any CPU
-		Release|Any CPU = Release|Any CPU
-		Release35|Any CPU = Release35|Any CPU
-	EndGlobalSection
-	GlobalSection(ProjectConfigurationPlatforms) = postSolution
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.Build.0 = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{35C347F4-24B2-4BE5-8117-A0E3001551CE}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{35C347F4-24B2-4BE5-8117-A0E3001551CE}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{35C347F4-24B2-4BE5-8117-A0E3001551CE}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{35C347F4-24B2-4BE5-8117-A0E3001551CE}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{35C347F4-24B2-4BE5-8117-A0E3001551CE}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{35C347F4-24B2-4BE5-8117-A0E3001551CE}.Release|Any CPU.Build.0 = Release|Any CPU
-		{35C347F4-24B2-4BE5-8117-A0E3001551CE}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{35C347F4-24B2-4BE5-8117-A0E3001551CE}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{02D030D0-C7B5-4561-8BDD-41408B2E2F41}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{02D030D0-C7B5-4561-8BDD-41408B2E2F41}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{02D030D0-C7B5-4561-8BDD-41408B2E2F41}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{02D030D0-C7B5-4561-8BDD-41408B2E2F41}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{02D030D0-C7B5-4561-8BDD-41408B2E2F41}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{02D030D0-C7B5-4561-8BDD-41408B2E2F41}.Release|Any CPU.Build.0 = Release|Any CPU
-		{02D030D0-C7B5-4561-8BDD-41408B2E2F41}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{02D030D0-C7B5-4561-8BDD-41408B2E2F41}.Release35|Any CPU.Build.0 = Release35|Any CPU
-	EndGlobalSection
-	GlobalSection(SolutionProperties) = preSolution
-		HideSolutionNode = FALSE
-	EndGlobalSection
-EndGlobal

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/vs2012/contrib/Contrib.SpellChecker.sln
----------------------------------------------------------------------
diff --git a/build/vs2012/contrib/Contrib.SpellChecker.sln b/build/vs2012/contrib/Contrib.SpellChecker.sln
deleted file mode 100644
index 0117834..0000000
--- a/build/vs2012/contrib/Contrib.SpellChecker.sln
+++ /dev/null
@@ -1,56 +0,0 @@
-
-Microsoft Visual Studio Solution File, Format Version 12.00
-# Visual Studio 2012
-#
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-#
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net", "..\..\..\src\core\Lucene.Net.csproj", "{5D4AD9BE-1FFB-41AB-9943-25737971BF57}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.SpellChecker", "..\..\..\src\contrib\SpellChecker\Contrib.SpellChecker.csproj", "{FF45EE91-9CA3-443D-8231-75E9FA1AF40E}"
-EndProject
-Global
-	GlobalSection(SolutionConfigurationPlatforms) = preSolution
-		Debug35|Any CPU = Debug35|Any CPU
-		Debug|Any CPU = Debug|Any CPU
-		Release35|Any CPU = Release35|Any CPU
-		Release|Any CPU = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(ProjectConfigurationPlatforms) = postSolution
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.Build.0 = Release|Any CPU
-		{FF45EE91-9CA3-443D-8231-75E9FA1AF40E}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{FF45EE91-9CA3-443D-8231-75E9FA1AF40E}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{FF45EE91-9CA3-443D-8231-75E9FA1AF40E}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{FF45EE91-9CA3-443D-8231-75E9FA1AF40E}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{FF45EE91-9CA3-443D-8231-75E9FA1AF40E}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{FF45EE91-9CA3-443D-8231-75E9FA1AF40E}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{FF45EE91-9CA3-443D-8231-75E9FA1AF40E}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{FF45EE91-9CA3-443D-8231-75E9FA1AF40E}.Release|Any CPU.Build.0 = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(SolutionProperties) = preSolution
-		HideSolutionNode = FALSE
-	EndGlobalSection
-EndGlobal

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/vs2012/contrib/Contrib.WordNet.sln
----------------------------------------------------------------------
diff --git a/build/vs2012/contrib/Contrib.WordNet.sln b/build/vs2012/contrib/Contrib.WordNet.sln
deleted file mode 100644
index 18a7a6b..0000000
--- a/build/vs2012/contrib/Contrib.WordNet.sln
+++ /dev/null
@@ -1,76 +0,0 @@
-
-Microsoft Visual Studio Solution File, Format Version 12.00
-# Visual Studio 2012
-#
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-#
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net", "..\..\..\src\core\Lucene.Net.csproj", "{5D4AD9BE-1FFB-41AB-9943-25737971BF57}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.WordNet.SynExpand", "..\..\..\src\contrib\WordNet\SynExpand\Contrib.WordNet.SynExpand.csproj", "{1407C9BA-337C-4C6C-B065-68328D3871B3}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.WordNet.SynLookup", "..\..\..\src\contrib\WordNet\SynLookup\Contrib.WordNet.SynLookup.csproj", "{2CA12E3F-76E1-4FA6-9E87-37079A7B7C69}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.WordNet.Syns2Index", "..\..\..\src\contrib\WordNet\Syns2Index\Contrib.WordNet.Syns2Index.csproj", "{7563D4D9-AE91-42BA-A270-1D264660F6DF}"
-EndProject
-Global
-	GlobalSection(SolutionConfigurationPlatforms) = preSolution
-		Debug35|Any CPU = Debug35|Any CPU
-		Debug|Any CPU = Debug|Any CPU
-		Release35|Any CPU = Release35|Any CPU
-		Release|Any CPU = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(ProjectConfigurationPlatforms) = postSolution
-		{1407C9BA-337C-4C6C-B065-68328D3871B3}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{1407C9BA-337C-4C6C-B065-68328D3871B3}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{1407C9BA-337C-4C6C-B065-68328D3871B3}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{1407C9BA-337C-4C6C-B065-68328D3871B3}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{1407C9BA-337C-4C6C-B065-68328D3871B3}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{1407C9BA-337C-4C6C-B065-68328D3871B3}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{1407C9BA-337C-4C6C-B065-68328D3871B3}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{1407C9BA-337C-4C6C-B065-68328D3871B3}.Release|Any CPU.Build.0 = Release|Any CPU
-		{2CA12E3F-76E1-4FA6-9E87-37079A7B7C69}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{2CA12E3F-76E1-4FA6-9E87-37079A7B7C69}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{2CA12E3F-76E1-4FA6-9E87-37079A7B7C69}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{2CA12E3F-76E1-4FA6-9E87-37079A7B7C69}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{2CA12E3F-76E1-4FA6-9E87-37079A7B7C69}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{2CA12E3F-76E1-4FA6-9E87-37079A7B7C69}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{2CA12E3F-76E1-4FA6-9E87-37079A7B7C69}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{2CA12E3F-76E1-4FA6-9E87-37079A7B7C69}.Release|Any CPU.Build.0 = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.Build.0 = Release|Any CPU
-		{7563D4D9-AE91-42BA-A270-1D264660F6DF}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{7563D4D9-AE91-42BA-A270-1D264660F6DF}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{7563D4D9-AE91-42BA-A270-1D264660F6DF}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{7563D4D9-AE91-42BA-A270-1D264660F6DF}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{7563D4D9-AE91-42BA-A270-1D264660F6DF}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{7563D4D9-AE91-42BA-A270-1D264660F6DF}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{7563D4D9-AE91-42BA-A270-1D264660F6DF}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{7563D4D9-AE91-42BA-A270-1D264660F6DF}.Release|Any CPU.Build.0 = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(SolutionProperties) = preSolution
-		HideSolutionNode = FALSE
-	EndGlobalSection
-EndGlobal

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/vs2012/core/Lucene.Net.Core.sln
----------------------------------------------------------------------
diff --git a/build/vs2012/core/Lucene.Net.Core.sln b/build/vs2012/core/Lucene.Net.Core.sln
deleted file mode 100644
index 53a0b3f..0000000
--- a/build/vs2012/core/Lucene.Net.Core.sln
+++ /dev/null
@@ -1,46 +0,0 @@
-
-Microsoft Visual Studio Solution File, Format Version 12.00
-# Visual Studio 2012
-#
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-#
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net", "..\..\..\src\core\Lucene.Net.csproj", "{5D4AD9BE-1FFB-41AB-9943-25737971BF57}"
-EndProject
-Global
-	GlobalSection(SolutionConfigurationPlatforms) = preSolution
-		Debug35|Any CPU = Debug35|Any CPU
-		Debug|Any CPU = Debug|Any CPU
-		Release35|Any CPU = Release35|Any CPU
-		Release|Any CPU = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(ProjectConfigurationPlatforms) = postSolution
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.Build.0 = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(SolutionProperties) = preSolution
-		HideSolutionNode = FALSE
-	EndGlobalSection
-EndGlobal

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/vs2012/demo/Lucene.Net.Demo.sln
----------------------------------------------------------------------
diff --git a/build/vs2012/demo/Lucene.Net.Demo.sln b/build/vs2012/demo/Lucene.Net.Demo.sln
deleted file mode 100644
index 2d5da0b..0000000
--- a/build/vs2012/demo/Lucene.Net.Demo.sln
+++ /dev/null
@@ -1,96 +0,0 @@
-
-Microsoft Visual Studio Solution File, Format Version 12.00
-# Visual Studio 2012
-#
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-#
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net", "..\..\..\src\core\Lucene.Net.csproj", "{5D4AD9BE-1FFB-41AB-9943-25737971BF57}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Demo.Common", "..\..\..\src\demo\Demo.Common\Demo.Common.csproj", "{F04CA2F4-E182-46A8-B914-F46AF5319E83}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "DeleteFiles", "..\..\..\src\demo\DeleteFiles\DeleteFiles.csproj", "{BA3A94CC-6D1E-4AA8-9C95-8C6FD896810E}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "IndexFiles", "..\..\..\src\demo\IndexFiles\IndexFiles.csproj", "{3E561192-4292-4998-BC67-8C1B82A56108}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "IndexHtml", "..\..\..\src\demo\IndexHtml\IndexHtml.csproj", "{2B86751C-0D3A-486E-A176-E995C63EB653}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "SearchFiles", "..\..\..\src\demo\SearchFiles\SearchFiles.csproj", "{5CF56C9F-F8DF-471E-B73A-C736464948C0}"
-EndProject
-Global
-	GlobalSection(SolutionConfigurationPlatforms) = preSolution
-		Debug35|Any CPU = Debug35|Any CPU
-		Debug|Any CPU = Debug|Any CPU
-		Release35|Any CPU = Release35|Any CPU
-		Release|Any CPU = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(ProjectConfigurationPlatforms) = postSolution
-		{2B86751C-0D3A-486E-A176-E995C63EB653}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{2B86751C-0D3A-486E-A176-E995C63EB653}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{2B86751C-0D3A-486E-A176-E995C63EB653}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{2B86751C-0D3A-486E-A176-E995C63EB653}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{2B86751C-0D3A-486E-A176-E995C63EB653}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{2B86751C-0D3A-486E-A176-E995C63EB653}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{2B86751C-0D3A-486E-A176-E995C63EB653}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{2B86751C-0D3A-486E-A176-E995C63EB653}.Release|Any CPU.Build.0 = Release|Any CPU
-		{3E561192-4292-4998-BC67-8C1B82A56108}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{3E561192-4292-4998-BC67-8C1B82A56108}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{3E561192-4292-4998-BC67-8C1B82A56108}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{3E561192-4292-4998-BC67-8C1B82A56108}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{3E561192-4292-4998-BC67-8C1B82A56108}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{3E561192-4292-4998-BC67-8C1B82A56108}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{3E561192-4292-4998-BC67-8C1B82A56108}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{3E561192-4292-4998-BC67-8C1B82A56108}.Release|Any CPU.Build.0 = Release|Any CPU
-		{5CF56C9F-F8DF-471E-B73A-C736464948C0}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{5CF56C9F-F8DF-471E-B73A-C736464948C0}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{5CF56C9F-F8DF-471E-B73A-C736464948C0}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{5CF56C9F-F8DF-471E-B73A-C736464948C0}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{5CF56C9F-F8DF-471E-B73A-C736464948C0}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{5CF56C9F-F8DF-471E-B73A-C736464948C0}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{5CF56C9F-F8DF-471E-B73A-C736464948C0}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{5CF56C9F-F8DF-471E-B73A-C736464948C0}.Release|Any CPU.Build.0 = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.Build.0 = Release|Any CPU
-		{BA3A94CC-6D1E-4AA8-9C95-8C6FD896810E}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{BA3A94CC-6D1E-4AA8-9C95-8C6FD896810E}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{BA3A94CC-6D1E-4AA8-9C95-8C6FD896810E}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{BA3A94CC-6D1E-4AA8-9C95-8C6FD896810E}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{BA3A94CC-6D1E-4AA8-9C95-8C6FD896810E}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{BA3A94CC-6D1E-4AA8-9C95-8C6FD896810E}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{BA3A94CC-6D1E-4AA8-9C95-8C6FD896810E}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{BA3A94CC-6D1E-4AA8-9C95-8C6FD896810E}.Release|Any CPU.Build.0 = Release|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Release|Any CPU.Build.0 = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(SolutionProperties) = preSolution
-		HideSolutionNode = FALSE
-	EndGlobalSection
-EndGlobal


[23/51] [abbrv] [partial] Cleaning up and getting ready to development towards v4.8

Posted by sy...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/framework/nunit.framework.xml
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/framework/nunit.framework.xml b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/framework/nunit.framework.xml
deleted file mode 100644
index b9e1dd0..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/framework/nunit.framework.xml
+++ /dev/null
@@ -1,10385 +0,0 @@
-<?xml version="1.0"?>
-<doc>
-    <assembly>
-        <name>nunit.framework</name>
-    </assembly>
-    <members>
-        <member name="T:NUnit.Framework.CategoryAttribute">
-            <summary>
-            Attribute used to apply a category to a test
-            </summary>
-        </member>
-        <member name="F:NUnit.Framework.CategoryAttribute.categoryName">
-            <summary>
-            The name of the category
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.CategoryAttribute.#ctor(System.String)">
-            <summary>
-            Construct attribute for a given category based on
-            a name. The name may not contain the characters ',',
-            '+', '-' or '!'. However, this is not checked in the
-            constructor since it would cause an error to arise at
-            as the test was loaded without giving a clear indication
-            of where the problem is located. The error is handled
-            in NUnitFramework.cs by marking the test as not
-            runnable.
-            </summary>
-            <param name="name">The name of the category</param>
-        </member>
-        <member name="M:NUnit.Framework.CategoryAttribute.#ctor">
-            <summary>
-            Protected constructor uses the Type name as the name
-            of the category.
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.CategoryAttribute.Name">
-            <summary>
-            The name of the category
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.DatapointAttribute">
-            <summary>
-            Used to mark a field for use as a datapoint when executing a theory
-            within the same fixture that requires an argument of the field's Type.
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.DatapointsAttribute">
-            <summary>
-            Used to mark an array as containing a set of datapoints to be used
-            executing a theory within the same fixture that requires an argument 
-            of the Type of the array elements.
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.DescriptionAttribute">
-            <summary>
-            Attribute used to provide descriptive text about a 
-            test case or fixture.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.DescriptionAttribute.#ctor(System.String)">
-            <summary>
-            Construct the attribute
-            </summary>
-            <param name="description">Text describing the test</param>
-        </member>
-        <member name="P:NUnit.Framework.DescriptionAttribute.Description">
-            <summary>
-            Gets the test description
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.MessageMatch">
-            <summary>
-            Enumeration indicating how the expected message parameter is to be used
-            </summary>
-        </member>
-        <member name="F:NUnit.Framework.MessageMatch.Exact">
-            Expect an exact match
-        </member>
-        <member name="F:NUnit.Framework.MessageMatch.Contains">
-            Expect a message containing the parameter string
-        </member>
-        <member name="F:NUnit.Framework.MessageMatch.Regex">
-            Match the regular expression provided as a parameter
-        </member>
-        <member name="F:NUnit.Framework.MessageMatch.StartsWith">
-            Expect a message that starts with the parameter string
-        </member>
-        <member name="T:NUnit.Framework.ExpectedExceptionAttribute">
-            <summary>
-            ExpectedExceptionAttribute
-            </summary>
-            
-        </member>
-        <member name="M:NUnit.Framework.ExpectedExceptionAttribute.#ctor">
-            <summary>
-            Constructor for a non-specific exception
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.ExpectedExceptionAttribute.#ctor(System.Type)">
-            <summary>
-            Constructor for a given type of exception
-            </summary>
-            <param name="exceptionType">The type of the expected exception</param>
-        </member>
-        <member name="M:NUnit.Framework.ExpectedExceptionAttribute.#ctor(System.String)">
-            <summary>
-            Constructor for a given exception name
-            </summary>
-            <param name="exceptionName">The full name of the expected exception</param>
-        </member>
-        <member name="P:NUnit.Framework.ExpectedExceptionAttribute.ExpectedException">
-            <summary>
-            Gets or sets the expected exception type
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.ExpectedExceptionAttribute.ExpectedExceptionName">
-            <summary>
-            Gets or sets the full Type name of the expected exception
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.ExpectedExceptionAttribute.ExpectedMessage">
-            <summary>
-            Gets or sets the expected message text
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.ExpectedExceptionAttribute.UserMessage">
-            <summary>
-            Gets or sets the user message displayed in case of failure
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.ExpectedExceptionAttribute.MatchType">
-            <summary>
-             Gets or sets the type of match to be performed on the expected message
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.ExpectedExceptionAttribute.Handler">
-            <summary>
-             Gets the name of a method to be used as an exception handler
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.ExplicitAttribute">
-            <summary>
-            ExplicitAttribute marks a test or test fixture so that it will
-            only be run if explicitly executed from the gui or command line
-            or if it is included by use of a filter. The test will not be
-            run simply because an enclosing suite is run.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.ExplicitAttribute.#ctor">
-            <summary>
-            Default constructor
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.ExplicitAttribute.#ctor(System.String)">
-            <summary>
-            Constructor with a reason
-            </summary>
-            <param name="reason">The reason test is marked explicit</param>
-        </member>
-        <member name="P:NUnit.Framework.ExplicitAttribute.Reason">
-            <summary>
-            The reason test is marked explicit
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.IgnoreAttribute">
-            <summary>
-            Attribute used to mark a test that is to be ignored.
-            Ignored tests result in a warning message when the
-            tests are run.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.IgnoreAttribute.#ctor">
-            <summary>
-            Constructs the attribute without giving a reason 
-            for ignoring the test.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.IgnoreAttribute.#ctor(System.String)">
-            <summary>
-            Constructs the attribute giving a reason for ignoring the test
-            </summary>
-            <param name="reason">The reason for ignoring the test</param>
-        </member>
-        <member name="P:NUnit.Framework.IgnoreAttribute.Reason">
-            <summary>
-            The reason for ignoring a test
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.IncludeExcludeAttribute">
-            <summary>
-            Abstract base for Attributes that are used to include tests
-            in the test run based on environmental settings.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.IncludeExcludeAttribute.#ctor">
-            <summary>
-            Constructor with no included items specified, for use
-            with named property syntax.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.IncludeExcludeAttribute.#ctor(System.String)">
-            <summary>
-            Constructor taking one or more included items
-            </summary>
-            <param name="include">Comma-delimited list of included items</param>
-        </member>
-        <member name="P:NUnit.Framework.IncludeExcludeAttribute.Include">
-            <summary>
-            Name of the item that is needed in order for
-            a test to run. Multiple itemss may be given,
-            separated by a comma.
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.IncludeExcludeAttribute.Exclude">
-            <summary>
-            Name of the item to be excluded. Multiple items
-            may be given, separated by a comma.
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.IncludeExcludeAttribute.Reason">
-            <summary>
-            The reason for including or excluding the test
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.PlatformAttribute">
-            <summary>
-            PlatformAttribute is used to mark a test fixture or an
-            individual method as applying to a particular platform only.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.PlatformAttribute.#ctor">
-            <summary>
-            Constructor with no platforms specified, for use
-            with named property syntax.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.PlatformAttribute.#ctor(System.String)">
-            <summary>
-            Constructor taking one or more platforms
-            </summary>
-            <param name="platforms">Comma-deliminted list of platforms</param>
-        </member>
-        <member name="T:NUnit.Framework.CultureAttribute">
-            <summary>
-            CultureAttribute is used to mark a test fixture or an
-            individual method as applying to a particular Culture only.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.CultureAttribute.#ctor">
-            <summary>
-            Constructor with no cultures specified, for use
-            with named property syntax.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.CultureAttribute.#ctor(System.String)">
-            <summary>
-            Constructor taking one or more cultures
-            </summary>
-            <param name="cultures">Comma-deliminted list of cultures</param>
-        </member>
-        <member name="T:NUnit.Framework.CombinatorialAttribute">
-            <summary>
-            Marks a test to use a combinatorial join of any argument data 
-            provided. NUnit will create a test case for every combination of 
-            the arguments provided. This can result in a large number of test
-            cases and so should be used judiciously. This is the default join
-            type, so the attribute need not be used except as documentation.
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.PropertyAttribute">
-            <summary>
-            PropertyAttribute is used to attach information to a test as a name/value pair..
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.PropertyAttribute.#ctor(System.String,System.String)">
-            <summary>
-            Construct a PropertyAttribute with a name and string value
-            </summary>
-            <param name="propertyName">The name of the property</param>
-            <param name="propertyValue">The property value</param>
-        </member>
-        <member name="M:NUnit.Framework.PropertyAttribute.#ctor(System.String,System.Int32)">
-            <summary>
-            Construct a PropertyAttribute with a name and int value
-            </summary>
-            <param name="propertyName">The name of the property</param>
-            <param name="propertyValue">The property value</param>
-        </member>
-        <member name="M:NUnit.Framework.PropertyAttribute.#ctor(System.String,System.Double)">
-            <summary>
-            Construct a PropertyAttribute with a name and double value
-            </summary>
-            <param name="propertyName">The name of the property</param>
-            <param name="propertyValue">The property value</param>
-        </member>
-        <member name="M:NUnit.Framework.PropertyAttribute.#ctor">
-            <summary>
-            Constructor for derived classes that set the
-            property dictionary directly.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.PropertyAttribute.#ctor(System.Object)">
-            <summary>
-            Constructor for use by derived classes that use the
-            name of the type as the property name. Derived classes
-            must ensure that the Type of the property value is
-            a standard type supported by the BCL. Any custom
-            types will cause a serialization Exception when
-            in the client.
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.PropertyAttribute.Properties">
-            <summary>
-            Gets the property dictionary for this attribute
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.CombinatorialAttribute.#ctor">
-            <summary>
-            Default constructor
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.PairwiseAttribute">
-            <summary>
-            Marks a test to use pairwise join of any argument data provided. 
-            NUnit will attempt too excercise every pair of argument values at 
-            least once, using as small a number of test cases as it can. With
-            only two arguments, this is the same as a combinatorial join.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.PairwiseAttribute.#ctor">
-            <summary>
-            Default constructor
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.SequentialAttribute">
-            <summary>
-            Marks a test to use a sequential join of any argument data
-            provided. NUnit will use arguements for each parameter in
-            sequence, generating test cases up to the largest number
-            of argument values provided and using null for any arguments
-            for which it runs out of values. Normally, this should be
-            used with the same number of arguments for each parameter.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.SequentialAttribute.#ctor">
-            <summary>
-            Default constructor
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.MaxTimeAttribute">
-            <summary>
-            Summary description for MaxTimeAttribute.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.MaxTimeAttribute.#ctor(System.Int32)">
-            <summary>
-            Construct a MaxTimeAttribute, given a time in milliseconds.
-            </summary>
-            <param name="milliseconds">The maximum elapsed time in milliseconds</param>
-        </member>
-        <member name="T:NUnit.Framework.RandomAttribute">
-            <summary>
-            RandomAttribute is used to supply a set of random values
-            to a single parameter of a parameterized test.
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.ValuesAttribute">
-            <summary>
-            ValuesAttribute is used to provide literal arguments for
-            an individual parameter of a test.
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.ParameterDataAttribute">
-            <summary>
-            Abstract base class for attributes that apply to parameters 
-            and supply data for the parameter.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.ParameterDataAttribute.GetData(System.Reflection.ParameterInfo)">
-            <summary>
-            Gets the data to be provided to the specified parameter
-            </summary>
-        </member>
-        <member name="F:NUnit.Framework.ValuesAttribute.data">
-            <summary>
-            The collection of data to be returned. Must
-            be set by any derived attribute classes.
-            We use an object[] so that the individual
-            elements may have their type changed in GetData
-            if necessary.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.ValuesAttribute.#ctor(System.Object)">
-            <summary>
-            Construct with one argument
-            </summary>
-            <param name="arg1"></param>
-        </member>
-        <member name="M:NUnit.Framework.ValuesAttribute.#ctor(System.Object,System.Object)">
-            <summary>
-            Construct with two arguments
-            </summary>
-            <param name="arg1"></param>
-            <param name="arg2"></param>
-        </member>
-        <member name="M:NUnit.Framework.ValuesAttribute.#ctor(System.Object,System.Object,System.Object)">
-            <summary>
-            Construct with three arguments
-            </summary>
-            <param name="arg1"></param>
-            <param name="arg2"></param>
-            <param name="arg3"></param>
-        </member>
-        <member name="M:NUnit.Framework.ValuesAttribute.#ctor(System.Object[])">
-            <summary>
-            Construct with an array of arguments
-            </summary>
-            <param name="args"></param>
-        </member>
-        <member name="M:NUnit.Framework.ValuesAttribute.GetData(System.Reflection.ParameterInfo)">
-            <summary>
-            Get the collection of values to be used as arguments
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.RandomAttribute.#ctor(System.Int32)">
-            <summary>
-            Construct a set of doubles from 0.0 to 1.0,
-            specifying only the count.
-            </summary>
-            <param name="count"></param>
-        </member>
-        <member name="M:NUnit.Framework.RandomAttribute.#ctor(System.Double,System.Double,System.Int32)">
-            <summary>
-            Construct a set of doubles from min to max
-            </summary>
-            <param name="min"></param>
-            <param name="max"></param>
-            <param name="count"></param>
-        </member>
-        <member name="M:NUnit.Framework.RandomAttribute.#ctor(System.Int32,System.Int32,System.Int32)">
-            <summary>
-            Construct a set of ints from min to max
-            </summary>
-            <param name="min"></param>
-            <param name="max"></param>
-            <param name="count"></param>
-        </member>
-        <member name="M:NUnit.Framework.RandomAttribute.GetData(System.Reflection.ParameterInfo)">
-            <summary>
-            Get the collection of values to be used as arguments
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.RangeAttribute">
-            <summary>
-            RangeAttribute is used to supply a range of values to an
-            individual parameter of a parameterized test.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.RangeAttribute.#ctor(System.Int32,System.Int32)">
-            <summary>
-            Construct a range of ints using default step of 1
-            </summary>
-            <param name="from"></param>
-            <param name="to"></param>
-        </member>
-        <member name="M:NUnit.Framework.RangeAttribute.#ctor(System.Int32,System.Int32,System.Int32)">
-            <summary>
-            Construct a range of ints specifying the step size 
-            </summary>
-            <param name="from"></param>
-            <param name="to"></param>
-            <param name="step"></param>
-        </member>
-        <member name="M:NUnit.Framework.RangeAttribute.#ctor(System.Int64,System.Int64,System.Int64)">
-            <summary>
-            Construct a range of longs
-            </summary>
-            <param name="from"></param>
-            <param name="to"></param>
-            <param name="step"></param>
-        </member>
-        <member name="M:NUnit.Framework.RangeAttribute.#ctor(System.Double,System.Double,System.Double)">
-            <summary>
-            Construct a range of doubles
-            </summary>
-            <param name="from"></param>
-            <param name="to"></param>
-            <param name="step"></param>
-        </member>
-        <member name="M:NUnit.Framework.RangeAttribute.#ctor(System.Single,System.Single,System.Single)">
-            <summary>
-            Construct a range of floats
-            </summary>
-            <param name="from"></param>
-            <param name="to"></param>
-            <param name="step"></param>
-        </member>
-        <member name="T:NUnit.Framework.RepeatAttribute">
-            <summary>
-            RepeatAttribute may be applied to test case in order
-            to run it multiple times.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.RepeatAttribute.#ctor(System.Int32)">
-            <summary>
-            Construct a RepeatAttribute
-            </summary>
-            <param name="count">The number of times to run the test</param>
-        </member>
-        <member name="T:NUnit.Framework.RequiredAddinAttribute">
-            <summary>
-            RequiredAddinAttribute may be used to indicate the names of any addins
-            that must be present in order to run some or all of the tests in an
-            assembly. If the addin is not loaded, the entire assembly is marked
-            as NotRunnable.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.RequiredAddinAttribute.#ctor(System.String)">
-            <summary>
-            Initializes a new instance of the <see cref="T:RequiredAddinAttribute"/> class.
-            </summary>
-            <param name="requiredAddin">The required addin.</param>
-        </member>
-        <member name="P:NUnit.Framework.RequiredAddinAttribute.RequiredAddin">
-            <summary>
-            Gets the name of required addin.
-            </summary>
-            <value>The required addin name.</value>
-        </member>
-        <member name="T:NUnit.Framework.SetCultureAttribute">
-            <summary>
-            Summary description for SetCultureAttribute.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.SetCultureAttribute.#ctor(System.String)">
-            <summary>
-            Construct given the name of a culture
-            </summary>
-            <param name="culture"></param>
-        </member>
-        <member name="T:NUnit.Framework.SetUICultureAttribute">
-            <summary>
-            Summary description for SetUICultureAttribute.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.SetUICultureAttribute.#ctor(System.String)">
-            <summary>
-            Construct given the name of a culture
-            </summary>
-            <param name="culture"></param>
-        </member>
-        <member name="T:NUnit.Framework.SetUpAttribute">
-            <summary>
-            Attribute used to mark a class that contains one-time SetUp 
-            and/or TearDown methods that apply to all the tests in a
-            namespace or an assembly.
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.SetUpFixtureAttribute">
-            <summary>
-            SetUpFixtureAttribute is used to identify a SetUpFixture
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.SuiteAttribute">
-            <summary>
-            Attribute used to mark a static (shared in VB) property
-            that returns a list of tests.
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.TearDownAttribute">
-            <summary>
-            Attribute used to identify a method that is called 
-            immediately after each test is run. The method is 
-            guaranteed to be called, even if an exception is thrown.
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.TestAttribute">
-            <summary>
-            Adding this attribute to a method within a <seealso cref="T:NUnit.Framework.TestFixtureAttribute"/> 
-            class makes the method callable from the NUnit test runner. There is a property 
-            called Description which is optional which you can provide a more detailed test
-            description. This class cannot be inherited.
-            </summary>
-            
-            <example>
-            [TestFixture]
-            public class Fixture
-            {
-              [Test]
-              public void MethodToTest()
-              {}
-              
-              [Test(Description = "more detailed description")]
-              publc void TestDescriptionMethod()
-              {}
-            }
-            </example>
-            
-        </member>
-        <member name="P:NUnit.Framework.TestAttribute.Description">
-            <summary>
-            Descriptive text for this test
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.TestCaseAttribute">
-            <summary>
-            TestCaseAttribute is used to mark parameterized test cases
-            and provide them with their arguments.
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.ITestCaseData">
-            <summary>
-            The ITestCaseData interface is implemented by a class
-            that is able to return complete testcases for use by
-            a parameterized test method.
-            
-            NOTE: This interface is used in both the framework
-            and the core, even though that results in two different
-            types. However, sharing the source code guarantees that
-            the various implementations will be compatible and that
-            the core is able to reflect successfully over the
-            framework implementations of ITestCaseData.
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.ITestCaseData.Arguments">
-            <summary>
-            Gets the argument list to be provided to the test
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.ITestCaseData.Result">
-            <summary>
-            Gets the expected result
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.ITestCaseData.ExpectedException">
-            <summary>
-             Gets the expected exception Type
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.ITestCaseData.ExpectedExceptionName">
-            <summary>
-            Gets the FullName of the expected exception
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.ITestCaseData.TestName">
-            <summary>
-            Gets the name to be used for the test
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.ITestCaseData.Description">
-            <summary>
-            Gets the description of the test
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.ITestCaseData.Ignored">
-            <summary>
-            Gets a value indicating whether this <see cref="T:NUnit.Framework.ITestCaseData"/> is ignored.
-            </summary>
-            <value><c>true</c> if ignored; otherwise, <c>false</c>.</value>
-        </member>
-        <member name="P:NUnit.Framework.ITestCaseData.IgnoreReason">
-            <summary>
-            Gets the ignore reason.
-            </summary>
-            <value>The ignore reason.</value>
-        </member>
-        <member name="M:NUnit.Framework.TestCaseAttribute.#ctor(System.Object[])">
-            <summary>
-            Construct a TestCaseAttribute with a list of arguments.
-            This constructor is not CLS-Compliant
-            </summary>
-            <param name="arguments"></param>
-        </member>
-        <member name="M:NUnit.Framework.TestCaseAttribute.#ctor(System.Object)">
-            <summary>
-            Construct a TestCaseAttribute with a single argument
-            </summary>
-            <param name="arg"></param>
-        </member>
-        <member name="M:NUnit.Framework.TestCaseAttribute.#ctor(System.Object,System.Object)">
-            <summary>
-            Construct a TestCaseAttribute with a two arguments
-            </summary>
-            <param name="arg1"></param>
-            <param name="arg2"></param>
-        </member>
-        <member name="M:NUnit.Framework.TestCaseAttribute.#ctor(System.Object,System.Object,System.Object)">
-            <summary>
-            Construct a TestCaseAttribute with a three arguments
-            </summary>
-            <param name="arg1"></param>
-            <param name="arg2"></param>
-            <param name="arg3"></param>
-        </member>
-        <member name="P:NUnit.Framework.TestCaseAttribute.Arguments">
-            <summary>
-            Gets the list of arguments to a test case
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.TestCaseAttribute.Result">
-            <summary>
-            Gets or sets the expected result.
-            </summary>
-            <value>The result.</value>
-        </member>
-        <member name="P:NUnit.Framework.TestCaseAttribute.ExpectedException">
-            <summary>
-            Gets or sets the expected exception.
-            </summary>
-            <value>The expected exception.</value>
-        </member>
-        <member name="P:NUnit.Framework.TestCaseAttribute.ExpectedExceptionName">
-            <summary>
-            Gets or sets the name the expected exception.
-            </summary>
-            <value>The expected name of the exception.</value>
-        </member>
-        <member name="P:NUnit.Framework.TestCaseAttribute.ExpectedMessage">
-            <summary>
-            Gets or sets the expected message of the expected exception
-            </summary>
-            <value>The expected message of the exception.</value>
-        </member>
-        <member name="P:NUnit.Framework.TestCaseAttribute.MatchType">
-            <summary>
-             Gets or sets the type of match to be performed on the expected message
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.TestCaseAttribute.Description">
-            <summary>
-            Gets or sets the description.
-            </summary>
-            <value>The description.</value>
-        </member>
-        <member name="P:NUnit.Framework.TestCaseAttribute.TestName">
-            <summary>
-            Gets or sets the name of the test.
-            </summary>
-            <value>The name of the test.</value>
-        </member>
-        <member name="P:NUnit.Framework.TestCaseAttribute.Ignore">
-            <summary>
-            Gets or sets the ignored status of the test
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.TestCaseAttribute.Ignored">
-            <summary>
-            Gets or sets the ignored status of the test
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.TestCaseAttribute.IgnoreReason">
-            <summary>
-            Gets the ignore reason.
-            </summary>
-            <value>The ignore reason.</value>
-        </member>
-        <member name="T:NUnit.Framework.TestCaseSourceAttribute">
-            <summary>
-            FactoryAttribute indicates the source to be used to
-            provide test cases for a test method.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.TestCaseSourceAttribute.#ctor(System.String)">
-            <summary>
-            Construct with the name of the factory - for use with languages
-            that don't support params arrays.
-            </summary>
-            <param name="sourceName">An array of the names of the factories that will provide data</param>
-        </member>
-        <member name="M:NUnit.Framework.TestCaseSourceAttribute.#ctor(System.Type,System.String)">
-            <summary>
-            Construct with a Type and name - for use with languages
-            that don't support params arrays.
-            </summary>
-            <param name="sourceType">The Type that will provide data</param>
-            <param name="sourceName">The name of the method, property or field that will provide data</param>
-        </member>
-        <member name="P:NUnit.Framework.TestCaseSourceAttribute.SourceName">
-            <summary>
-            The name of a the method, property or fiend to be used as a source
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.TestCaseSourceAttribute.SourceType">
-            <summary>
-            A Type to be used as a source
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.TestFixtureAttribute">
-            <example>
-            [TestFixture]
-            public class ExampleClass 
-            {}
-            </example>
-        </member>
-        <member name="M:NUnit.Framework.TestFixtureAttribute.#ctor">
-            <summary>
-            Default constructor
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.TestFixtureAttribute.#ctor(System.Object[])">
-            <summary>
-            Construct with a object[] representing a set of arguments. 
-            In .NET 2.0, the arguments may later be separated into
-            type arguments and constructor arguments.
-            </summary>
-            <param name="arguments"></param>
-        </member>
-        <member name="P:NUnit.Framework.TestFixtureAttribute.Description">
-            <summary>
-            Descriptive text for this fixture
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.TestFixtureAttribute.Arguments">
-            <summary>
-            The arguments originally provided to the attribute
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.TestFixtureAttribute.Ignore">
-            <summary>
-            Gets or sets a value indicating whether this <see cref="T:NUnit.Framework.TestFixtureAttribute"/> should be ignored.
-            </summary>
-            <value><c>true</c> if ignore; otherwise, <c>false</c>.</value>
-        </member>
-        <member name="P:NUnit.Framework.TestFixtureAttribute.IgnoreReason">
-            <summary>
-            Gets or sets the ignore reason. May set Ignored as a side effect.
-            </summary>
-            <value>The ignore reason.</value>
-        </member>
-        <member name="P:NUnit.Framework.TestFixtureAttribute.TypeArgs">
-            <summary>
-            Get or set the type arguments. If not set
-            explicitly, any leading arguments that are
-            Types are taken as type arguments.
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.TestFixtureSetUpAttribute">
-            <summary>
-            Attribute used to identify a method that is 
-            called before any tests in a fixture are run.
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.TestFixtureTearDownAttribute">
-            <summary>
-            Attribute used to identify a method that is called after
-            all the tests in a fixture have run. The method is 
-            guaranteed to be called, even if an exception is thrown.
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.TheoryAttribute">
-            <summary>
-            Adding this attribute to a method within a <seealso cref="T:NUnit.Framework.TestFixtureAttribute"/> 
-            class makes the method callable from the NUnit test runner. There is a property 
-            called Description which is optional which you can provide a more detailed test
-            description. This class cannot be inherited.
-            </summary>
-            
-            <example>
-            [TestFixture]
-            public class Fixture
-            {
-              [Test]
-              public void MethodToTest()
-              {}
-              
-              [Test(Description = "more detailed description")]
-              publc void TestDescriptionMethod()
-              {}
-            }
-            </example>
-            
-        </member>
-        <member name="T:NUnit.Framework.TimeoutAttribute">
-            <summary>
-            WUsed on a method, marks the test with a timeout value in milliseconds. 
-            The test will be run in a separate thread and is cancelled if the timeout 
-            is exceeded. Used on a method or assembly, sets the default timeout 
-            for all contained test methods.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.TimeoutAttribute.#ctor(System.Int32)">
-            <summary>
-            Construct a TimeoutAttribute given a time in milliseconds
-            </summary>
-            <param name="timeout">The timeout value in milliseconds</param>
-        </member>
-        <member name="T:NUnit.Framework.RequiresSTAAttribute">
-            <summary>
-            Marks a test that must run in the STA, causing it
-            to run in a separate thread if necessary.
-            
-            On methods, you may also use STAThreadAttribute
-            to serve the same purpose.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.RequiresSTAAttribute.#ctor">
-            <summary>
-            Construct a RequiresSTAAttribute
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.RequiresMTAAttribute">
-            <summary>
-            Marks a test that must run in the MTA, causing it
-            to run in a separate thread if necessary.
-            
-            On methods, you may also use MTAThreadAttribute
-            to serve the same purpose.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.RequiresMTAAttribute.#ctor">
-            <summary>
-            Construct a RequiresMTAAttribute
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.RequiresThreadAttribute">
-            <summary>
-            Marks a test that must run on a separate thread.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.RequiresThreadAttribute.#ctor">
-            <summary>
-            Construct a RequiresThreadAttribute
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.RequiresThreadAttribute.#ctor(System.Threading.ApartmentState)">
-            <summary>
-            Construct a RequiresThreadAttribute, specifying the apartment
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.ValueSourceAttribute">
-            <summary>
-            ValueSourceAttribute indicates the source to be used to
-            provide data for one parameter of a test method.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.ValueSourceAttribute.#ctor(System.String)">
-            <summary>
-            Construct with the name of the factory - for use with languages
-            that don't support params arrays.
-            </summary>
-            <param name="sourceName">The name of the data source to be used</param>
-        </member>
-        <member name="M:NUnit.Framework.ValueSourceAttribute.#ctor(System.Type,System.String)">
-            <summary>
-            Construct with a Type and name - for use with languages
-            that don't support params arrays.
-            </summary>
-            <param name="sourceType">The Type that will provide data</param>
-            <param name="sourceName">The name of the method, property or field that will provide data</param>
-        </member>
-        <member name="P:NUnit.Framework.ValueSourceAttribute.SourceName">
-            <summary>
-            The name of a the method, property or fiend to be used as a source
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.ValueSourceAttribute.SourceType">
-            <summary>
-            A Type to be used as a source
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.AttributeExistsConstraint">
-            <summary>
-            AttributeExistsConstraint tests for the presence of a
-            specified attribute on  a Type.
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.Constraint">
-            <summary>
-            The Constraint class is the base of all built-in constraints
-            within NUnit. It provides the operator overloads used to combine 
-            constraints.
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.IResolveConstraint">
-            <summary>
-            The IConstraintExpression interface is implemented by all
-            complete and resolvable constraints and expressions.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.IResolveConstraint.Resolve">
-            <summary>
-            Return the top-level constraint for this expression
-            </summary>
-            <returns></returns>
-        </member>
-        <member name="F:NUnit.Framework.Constraints.Constraint.UNSET">
-            <summary>
-            Static UnsetObject used to detect derived constraints
-            failing to set the actual value.
-            </summary>
-        </member>
-        <member name="F:NUnit.Framework.Constraints.Constraint.actual">
-            <summary>
-            The actual value being tested against a constraint
-            </summary>
-        </member>
-        <member name="F:NUnit.Framework.Constraints.Constraint.displayName">
-            <summary>
-            The display name of this Constraint for use by ToString()
-            </summary>
-        </member>
-        <member name="F:NUnit.Framework.Constraints.Constraint.argcnt">
-            <summary>
-            Argument fields used by ToString();
-            </summary>
-        </member>
-        <member name="F:NUnit.Framework.Constraints.Constraint.builder">
-            <summary>
-            The builder holding this constraint
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.Constraint.#ctor">
-            <summary>
-            Construct a constraint with no arguments
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.Constraint.#ctor(System.Object)">
-            <summary>
-            Construct a constraint with one argument
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.Constraint.#ctor(System.Object,System.Object)">
-            <summary>
-            Construct a constraint with two arguments
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.Constraint.SetBuilder(NUnit.Framework.Constraints.ConstraintBuilder)">
-            <summary>
-            Sets the ConstraintBuilder holding this constraint
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.Constraint.WriteMessageTo(NUnit.Framework.Constraints.MessageWriter)">
-            <summary>
-            Write the failure message to the MessageWriter provided
-            as an argument. The default implementation simply passes
-            the constraint and the actual value to the writer, which
-            then displays the constraint description and the value.
-            
-            Constraints that need to provide additional details,
-            such as where the error occured can override this.
-            </summary>
-            <param name="writer">The MessageWriter on which to display the message</param>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.Constraint.Matches(System.Object)">
-            <summary>
-            Test whether the constraint is satisfied by a given value
-            </summary>
-            <param name="actual">The value to be tested</param>
-            <returns>True for success, false for failure</returns>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.Constraint.Matches(NUnit.Framework.Constraints.ActualValueDelegate)">
-            <summary>
-            Test whether the constraint is satisfied by an
-            ActualValueDelegate that returns the value to be tested.
-            The default implementation simply evaluates the delegate
-            but derived classes may override it to provide for delayed 
-            processing.
-            </summary>
-            <param name="del">An ActualValueDelegate</param>
-            <returns>True for success, false for failure</returns>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.Constraint.Matches``1(``0@)">
-            <summary>
-            Test whether the constraint is satisfied by a given reference.
-            The default implementation simply dereferences the value but
-            derived classes may override it to provide for delayed processing.
-            </summary>
-            <param name="actual">A reference to the value to be tested</param>
-            <returns>True for success, false for failure</returns>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.Constraint.WriteDescriptionTo(NUnit.Framework.Constraints.MessageWriter)">
-            <summary>
-            Write the constraint description to a MessageWriter
-            </summary>
-            <param name="writer">The writer on which the description is displayed</param>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.Constraint.WriteActualValueTo(NUnit.Framework.Constraints.MessageWriter)">
-            <summary>
-            Write the actual value for a failing constraint test to a
-            MessageWriter. The default implementation simply writes
-            the raw value of actual, leaving it to the writer to
-            perform any formatting.
-            </summary>
-            <param name="writer">The writer on which the actual value is displayed</param>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.Constraint.ToString">
-            <summary>
-            Default override of ToString returns the constraint DisplayName
-            followed by any arguments within angle brackets.
-            </summary>
-            <returns></returns>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.Constraint.GetStringRepresentation">
-            <summary>
-            Returns the string representation of this constraint
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.Constraint.op_BitwiseAnd(NUnit.Framework.Constraints.Constraint,NUnit.Framework.Constraints.Constraint)">
-            <summary>
-            This operator creates a constraint that is satisfied only if both 
-            argument constraints are satisfied.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.Constraint.op_BitwiseOr(NUnit.Framework.Constraints.Constraint,NUnit.Framework.Constraints.Constraint)">
-            <summary>
-            This operator creates a constraint that is satisfied if either 
-            of the argument constraints is satisfied.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.Constraint.op_LogicalNot(NUnit.Framework.Constraints.Constraint)">
-            <summary>
-            This operator creates a constraint that is satisfied if the 
-            argument constraint is not satisfied.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.Constraint.After(System.Int32)">
-            <summary>
-            Returns a DelayedConstraint with the specified delay time.
-            </summary>
-            <param name="delayInMilliseconds">The delay in milliseconds.</param>
-            <returns></returns>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.Constraint.After(System.Int32,System.Int32)">
-            <summary>
-            Returns a DelayedConstraint with the specified delay time
-            and polling interval.
-            </summary>
-            <param name="delayInMilliseconds">The delay in milliseconds.</param>
-            <param name="pollingInterval">The interval at which to test the constraint.</param>
-            <returns></returns>
-        </member>
-        <member name="P:NUnit.Framework.Constraints.Constraint.DisplayName">
-            <summary>
-            The display name of this Constraint for use by ToString().
-            The default value is the name of the constraint with
-            trailing "Constraint" removed. Derived classes may set
-            this to another name in their constructors.
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.Constraints.Constraint.And">
-            <summary>
-            Returns a ConstraintExpression by appending And
-            to the current constraint.
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.Constraints.Constraint.With">
-            <summary>
-            Returns a ConstraintExpression by appending And
-            to the current constraint.
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.Constraints.Constraint.Or">
-            <summary>
-            Returns a ConstraintExpression by appending Or
-            to the current constraint.
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.Constraint.UnsetObject">
-            <summary>
-            Class used to detect any derived constraints
-            that fail to set the actual value in their
-            Matches override.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.AttributeExistsConstraint.#ctor(System.Type)">
-            <summary>
-            Constructs an AttributeExistsConstraint for a specific attribute Type
-            </summary>
-            <param name="type"></param>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.AttributeExistsConstraint.Matches(System.Object)">
-            <summary>
-            Tests whether the object provides the expected attribute.
-            </summary>
-            <param name="actual">A Type, MethodInfo, or other ICustomAttributeProvider</param>
-            <returns>True if the expected attribute is present, otherwise false</returns>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.AttributeExistsConstraint.WriteDescriptionTo(NUnit.Framework.Constraints.MessageWriter)">
-            <summary>
-            Writes the description of the constraint to the specified writer
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.AttributeConstraint">
-            <summary>
-            AttributeConstraint tests that a specified attribute is present
-            on a Type or other provider and that the value of the attribute
-            satisfies some other constraint.
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.PrefixConstraint">
-            <summary>
-            Abstract base class used for prefixes
-            </summary>
-        </member>
-        <member name="F:NUnit.Framework.Constraints.PrefixConstraint.baseConstraint">
-            <summary>
-            The base constraint
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.PrefixConstraint.#ctor(NUnit.Framework.Constraints.IResolveConstraint)">
-            <summary>
-            Construct given a base constraint
-            </summary>
-            <param name="resolvable"></param>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.AttributeConstraint.#ctor(System.Type,NUnit.Framework.Constraints.Constraint)">
-            <summary>
-            Constructs an AttributeConstraint for a specified attriute
-            Type and base constraint.
-            </summary>
-            <param name="type"></param>
-            <param name="baseConstraint"></param>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.AttributeConstraint.Matches(System.Object)">
-            <summary>
-            Determines whether the Type or other provider has the 
-            expected attribute and if its value matches the
-            additional constraint specified.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.AttributeConstraint.WriteDescriptionTo(NUnit.Framework.Constraints.MessageWriter)">
-            <summary>
-            Writes a description of the attribute to the specified writer.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.AttributeConstraint.WriteActualValueTo(NUnit.Framework.Constraints.MessageWriter)">
-            <summary>
-            Writes the actual value supplied to the specified writer.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.AttributeConstraint.GetStringRepresentation">
-            <summary>
-            Returns a string representation of the constraint.
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.BasicConstraint">
-            <summary>
-            BasicConstraint is the abstract base for constraints that
-            perform a simple comparison to a constant value.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.BasicConstraint.#ctor(System.Object,System.String)">
-            <summary>
-            Initializes a new instance of the <see cref="T:BasicConstraint"/> class.
-            </summary>
-            <param name="expected">The expected.</param>
-            <param name="description">The description.</param>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.BasicConstraint.Matches(System.Object)">
-            <summary>
-            Test whether the constraint is satisfied by a given value
-            </summary>
-            <param name="actual">The value to be tested</param>
-            <returns>True for success, false for failure</returns>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.BasicConstraint.WriteDescriptionTo(NUnit.Framework.Constraints.MessageWriter)">
-            <summary>
-            Write the constraint description to a MessageWriter
-            </summary>
-            <param name="writer">The writer on which the description is displayed</param>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.NullConstraint">
-            <summary>
-            NullConstraint tests that the actual value is null
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.NullConstraint.#ctor">
-            <summary>
-            Initializes a new instance of the <see cref="T:NullConstraint"/> class.
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.TrueConstraint">
-            <summary>
-            TrueConstraint tests that the actual value is true
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.TrueConstraint.#ctor">
-            <summary>
-            Initializes a new instance of the <see cref="T:TrueConstraint"/> class.
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.FalseConstraint">
-            <summary>
-            FalseConstraint tests that the actual value is false
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.FalseConstraint.#ctor">
-            <summary>
-            Initializes a new instance of the <see cref="T:FalseConstraint"/> class.
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.NaNConstraint">
-            <summary>
-            NaNConstraint tests that the actual value is a double or float NaN
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.NaNConstraint.Matches(System.Object)">
-            <summary>
-            Test that the actual value is an NaN
-            </summary>
-            <param name="actual"></param>
-            <returns></returns>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.NaNConstraint.WriteDescriptionTo(NUnit.Framework.Constraints.MessageWriter)">
-            <summary>
-            Write the constraint description to a specified writer
-            </summary>
-            <param name="writer"></param>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.BinaryConstraint">
-            <summary>
-            BinaryConstraint is the abstract base of all constraints
-            that combine two other constraints in some fashion.
-            </summary>
-        </member>
-        <member name="F:NUnit.Framework.Constraints.BinaryConstraint.left">
-            <summary>
-            The first constraint being combined
-            </summary>
-        </member>
-        <member name="F:NUnit.Framework.Constraints.BinaryConstraint.right">
-            <summary>
-            The second constraint being combined
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.BinaryConstraint.#ctor(NUnit.Framework.Constraints.Constraint,NUnit.Framework.Constraints.Constraint)">
-            <summary>
-            Construct a BinaryConstraint from two other constraints
-            </summary>
-            <param name="left">The first constraint</param>
-            <param name="right">The second constraint</param>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.AndConstraint">
-            <summary>
-            AndConstraint succeeds only if both members succeed.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.AndConstraint.#ctor(NUnit.Framework.Constraints.Constraint,NUnit.Framework.Constraints.Constraint)">
-            <summary>
-            Create an AndConstraint from two other constraints
-            </summary>
-            <param name="left">The first constraint</param>
-            <param name="right">The second constraint</param>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.AndConstraint.Matches(System.Object)">
-            <summary>
-            Apply both member constraints to an actual value, succeeding 
-            succeeding only if both of them succeed.
-            </summary>
-            <param name="actual">The actual value</param>
-            <returns>True if the constraints both succeeded</returns>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.AndConstraint.WriteDescriptionTo(NUnit.Framework.Constraints.MessageWriter)">
-            <summary>
-            Write a description for this contraint to a MessageWriter
-            </summary>
-            <param name="writer">The MessageWriter to receive the description</param>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.AndConstraint.WriteActualValueTo(NUnit.Framework.Constraints.MessageWriter)">
-            <summary>
-            Write the actual value for a failing constraint test to a
-            MessageWriter. The default implementation simply writes
-            the raw value of actual, leaving it to the writer to
-            perform any formatting.
-            </summary>
-            <param name="writer">The writer on which the actual value is displayed</param>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.OrConstraint">
-            <summary>
-            OrConstraint succeeds if either member succeeds
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.OrConstraint.#ctor(NUnit.Framework.Constraints.Constraint,NUnit.Framework.Constraints.Constraint)">
-            <summary>
-            Create an OrConstraint from two other constraints
-            </summary>
-            <param name="left">The first constraint</param>
-            <param name="right">The second constraint</param>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.OrConstraint.Matches(System.Object)">
-            <summary>
-            Apply the member constraints to an actual value, succeeding 
-            succeeding as soon as one of them succeeds.
-            </summary>
-            <param name="actual">The actual value</param>
-            <returns>True if either constraint succeeded</returns>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.OrConstraint.WriteDescriptionTo(NUnit.Framework.Constraints.MessageWriter)">
-            <summary>
-            Write a description for this contraint to a MessageWriter
-            </summary>
-            <param name="writer">The MessageWriter to receive the description</param>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.CollectionConstraint">
-            <summary>
-            CollectionConstraint is the abstract base class for
-            constraints that operate on collections.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionConstraint.#ctor">
-            <summary>
-            Construct an empty CollectionConstraint
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionConstraint.#ctor(System.Object)">
-            <summary>
-            Construct a CollectionConstraint
-            </summary>
-            <param name="arg"></param>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionConstraint.IsEmpty(System.Collections.IEnumerable)">
-            <summary>
-            Determines whether the specified enumerable is empty.
-            </summary>
-            <param name="enumerable">The enumerable.</param>
-            <returns>
-            	<c>true</c> if the specified enumerable is empty; otherwise, <c>false</c>.
-            </returns>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionConstraint.Matches(System.Object)">
-            <summary>
-            Test whether the constraint is satisfied by a given value
-            </summary>
-            <param name="actual">The value to be tested</param>
-            <returns>True for success, false for failure</returns>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionConstraint.doMatch(System.Collections.IEnumerable)">
-            <summary>
-            Protected method to be implemented by derived classes
-            </summary>
-            <param name="collection"></param>
-            <returns></returns>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.CollectionItemsEqualConstraint">
-            <summary>
-            CollectionItemsEqualConstraint is the abstract base class for all
-            collection constraints that apply some notion of item equality
-            as a part of their operation.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionItemsEqualConstraint.#ctor">
-            <summary>
-            Construct an empty CollectionConstraint
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionItemsEqualConstraint.#ctor(System.Object)">
-            <summary>
-            Construct a CollectionConstraint
-            </summary>
-            <param name="arg"></param>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionItemsEqualConstraint.Using(System.Collections.IComparer)">
-            <summary>
-            Flag the constraint to use the supplied IComparer object.
-            </summary>
-            <param name="comparer">The IComparer object to use.</param>
-            <returns>Self.</returns>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionItemsEqualConstraint.Using``1(System.Collections.Generic.IComparer{``0})">
-            <summary>
-            Flag the constraint to use the supplied IComparer object.
-            </summary>
-            <param name="comparer">The IComparer object to use.</param>
-            <returns>Self.</returns>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionItemsEqualConstraint.Using``1(System.Comparison{``0})">
-            <summary>
-            Flag the constraint to use the supplied Comparison object.
-            </summary>
-            <param name="comparer">The IComparer object to use.</param>
-            <returns>Self.</returns>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionItemsEqualConstraint.Using(System.Collections.IEqualityComparer)">
-            <summary>
-            Flag the constraint to use the supplied IEqualityComparer object.
-            </summary>
-            <param name="comparer">The IComparer object to use.</param>
-            <returns>Self.</returns>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionItemsEqualConstraint.Using``1(System.Collections.Generic.IEqualityComparer{``0})">
-            <summary>
-            Flag the constraint to use the supplied IEqualityComparer object.
-            </summary>
-            <param name="comparer">The IComparer object to use.</param>
-            <returns>Self.</returns>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionItemsEqualConstraint.ItemsEqual(System.Object,System.Object)">
-            <summary>
-            Compares two collection members for equality
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionItemsEqualConstraint.Tally(System.Collections.IEnumerable)">
-            <summary>
-            Return a new CollectionTally for use in making tests
-            </summary>
-            <param name="c">The collection to be included in the tally</param>
-        </member>
-        <member name="P:NUnit.Framework.Constraints.CollectionItemsEqualConstraint.IgnoreCase">
-            <summary>
-            Flag the constraint to ignore case and return self.
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.EmptyCollectionConstraint">
-            <summary>
-            EmptyCollectionConstraint tests whether a collection is empty. 
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.EmptyCollectionConstraint.doMatch(System.Collections.IEnumerable)">
-            <summary>
-            Check that the collection is empty
-            </summary>
-            <param name="collection"></param>
-            <returns></returns>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.EmptyCollectionConstraint.WriteDescriptionTo(NUnit.Framework.Constraints.MessageWriter)">
-            <summary>
-            Write the constraint description to a MessageWriter
-            </summary>
-            <param name="writer"></param>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.UniqueItemsConstraint">
-            <summary>
-            UniqueItemsConstraint tests whether all the items in a 
-            collection are unique.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.UniqueItemsConstraint.doMatch(System.Collections.IEnumerable)">
-            <summary>
-            Check that all items are unique.
-            </summary>
-            <param name="actual"></param>
-            <returns></returns>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.UniqueItemsConstraint.WriteDescriptionTo(NUnit.Framework.Constraints.MessageWriter)">
-            <summary>
-            Write a description of this constraint to a MessageWriter
-            </summary>
-            <param name="writer"></param>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.CollectionContainsConstraint">
-            <summary>
-            CollectionContainsConstraint is used to test whether a collection
-            contains an expected object as a member.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionContainsConstraint.#ctor(System.Object)">
-            <summary>
-            Construct a CollectionContainsConstraint
-            </summary>
-            <param name="expected"></param>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionContainsConstraint.doMatch(System.Collections.IEnumerable)">
-            <summary>
-            Test whether the expected item is contained in the collection
-            </summary>
-            <param name="actual"></param>
-            <returns></returns>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionContainsConstraint.WriteDescriptionTo(NUnit.Framework.Constraints.MessageWriter)">
-            <summary>
-            Write a descripton of the constraint to a MessageWriter
-            </summary>
-            <param name="writer"></param>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.CollectionEquivalentConstraint">
-            <summary>
-            CollectionEquivalentCOnstraint is used to determine whether two
-            collections are equivalent.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionEquivalentConstraint.#ctor(System.Collections.IEnumerable)">
-            <summary>
-            Construct a CollectionEquivalentConstraint
-            </summary>
-            <param name="expected"></param>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionEquivalentConstraint.doMatch(System.Collections.IEnumerable)">
-            <summary>
-            Test whether two collections are equivalent
-            </summary>
-            <param name="actual"></param>
-            <returns></returns>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionEquivalentConstraint.WriteDescriptionTo(NUnit.Framework.Constraints.MessageWriter)">
-            <summary>
-            Write a description of this constraint to a MessageWriter
-            </summary>
-            <param name="writer"></param>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.CollectionSubsetConstraint">
-            <summary>
-            CollectionSubsetConstraint is used to determine whether
-            one collection is a subset of another
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionSubsetConstraint.#ctor(System.Collections.IEnumerable)">
-            <summary>
-            Construct a CollectionSubsetConstraint
-            </summary>
-            <param name="expected">The collection that the actual value is expected to be a subset of</param>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionSubsetConstraint.doMatch(System.Collections.IEnumerable)">
-            <summary>
-            Test whether the actual collection is a subset of 
-            the expected collection provided.
-            </summary>
-            <param name="actual"></param>
-            <returns></returns>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionSubsetConstraint.WriteDescriptionTo(NUnit.Framework.Constraints.MessageWriter)">
-            <summary>
-            Write a description of this constraint to a MessageWriter
-            </summary>
-            <param name="writer"></param>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.CollectionOrderedConstraint">
-            <summary>
-            CollectionOrderedConstraint is used to test whether a collection is ordered.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionOrderedConstraint.#ctor">
-            <summary>
-            Construct a CollectionOrderedConstraint
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionOrderedConstraint.Using(System.Collections.IComparer)">
-            <summary>
-            Modifies the constraint to use an IComparer and returns self.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionOrderedConstraint.Using``1(System.Collections.Generic.IComparer{``0})">
-            <summary>
-            Modifies the constraint to use an IComparer&lt;T&gt; and returns self.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionOrderedConstraint.Using``1(System.Comparison{``0})">
-            <summary>
-            Modifies the constraint to use a Comparison&lt;T&gt; and returns self.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionOrderedConstraint.By(System.String)">
-            <summary>
-            Modifies the constraint to test ordering by the value of
-            a specified property and returns self.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionOrderedConstraint.doMatch(System.Collections.IEnumerable)">
-            <summary>
-            Test whether the collection is ordered
-            </summary>
-            <param name="actual"></param>
-            <returns></returns>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionOrderedConstraint.WriteDescriptionTo(NUnit.Framework.Constraints.MessageWriter)">
-            <summary>
-            Write a description of the constraint to a MessageWriter
-            </summary>
-            <param name="writer"></param>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionOrderedConstraint.GetStringRepresentation">
-            <summary>
-            Returns the string representation of the constraint.
-            </summary>
-            <returns></returns>
-        </member>
-        <member name="P:NUnit.Framework.Constraints.CollectionOrderedConstraint.Descending">
-            <summary>
-             If used performs a reverse comparison
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.CollectionTally">
-            <summary>
-            CollectionTally counts (tallies) the number of
-            occurences of each object in one or more enumerations.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionTally.#ctor(NUnit.Framework.Constraints.NUnitEqualityComparer,System.Collections.IEnumerable)">
-            <summary>
-            Construct a CollectionTally object from a comparer and a collection
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionTally.TryRemove(System.Object)">
-            <summary>
-            Try to remove an object from the tally
-            </summary>
-            <param name="o">The object to remove</param>
-            <returns>True if successful, false if the object was not found</returns>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.CollectionTally.TryRemove(System.Collections.IEnumerable)">
-            <summary>
-            Try to remove a set of objects from the tally
-            </summary>
-            <param name="c">The objects to remove</param>
-            <returns>True if successful, false if any object was not found</returns>
-        </member>
-        <member name="P:NUnit.Framework.Constraints.CollectionTally.Count">
-            <summary>
-            The number of objects remaining in the tally
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.ComparisonAdapter">
-            <summary>
-            ComparisonAdapter class centralizes all comparisons of
-            values in NUnit, adapting to the use of any provided
-            IComparer, IComparer&lt;T&gt; or Comparison&lt;T&gt;
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.ComparisonAdapter.For(System.Collections.IComparer)">
-            <summary>
-            Returns a ComparisonAdapter that wraps an IComparer
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.ComparisonAdapter.For``1(System.Collections.Generic.IComparer{``0})">
-            <summary>
-            Returns a ComparisonAdapter that wraps an IComparer&lt;T&gt;
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.ComparisonAdapter.For``1(System.Comparison{``0})">
-            <summary>
-            Returns a ComparisonAdapter that wraps a Comparison&lt;T&gt;
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.ComparisonAdapter.Compare(System.Object,System.Object)">
-            <summary>
-            Compares two objects
-            </summary>
-        </member>
-        <member name="P:NUnit.Framework.Constraints.ComparisonAdapter.Default">
-            <summary>
-            Gets the default ComparisonAdapter, which wraps an
-            NUnitComparer object.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.ComparisonAdapter.ComparerAdapter.#ctor(System.Collections.IComparer)">
-            <summary>
-            Construct a ComparisonAdapter for an IComparer
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.ComparisonAdapter.ComparerAdapter.Compare(System.Object,System.Object)">
-            <summary>
-            Compares two objects
-            </summary>
-            <param name="expected"></param>
-            <param name="actual"></param>
-            <returns></returns>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.ComparisonAdapter.DefaultComparisonAdapter.#ctor">
-            <summary>
-            Construct a default ComparisonAdapter
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.ComparisonAdapter.ComparerAdapter`1">
-            <summary>
-            ComparisonAdapter&lt;T&gt; extends ComparisonAdapter and
-            allows use of an IComparer&lt;T&gt; or Comparison&lt;T&gt;
-            to actually perform the comparison.
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.ComparisonAdapter.ComparerAdapter`1.#ctor(System.Collections.Generic.IComparer{`0})">
-            <summary>
-            Construct a ComparisonAdapter for an IComparer&lt;T&gt;
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.ComparisonAdapter.ComparerAdapter`1.Compare(System.Object,System.Object)">
-            <summary>
-            Compare a Type T to an object
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.ComparisonAdapter.ComparisonAdapterForComparison`1.#ctor(System.Comparison{`0})">
-            <summary>
-            Construct a ComparisonAdapter for a Comparison&lt;T&gt;
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.ComparisonAdapter.ComparisonAdapterForComparison`1.Compare(System.Object,System.Object)">
-            <summary>
-            Compare a Type T to an object
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.ComparisonConstraint">
-            <summary>
-            Abstract base class for constraints that compare values to
-            determine if one is greater than, equal to or less than
-            the other.
-            </summary>
-        </member>
-        <member name="F:NUnit.Framework.Constraints.ComparisonConstraint.expected">
-            <summary>
-            The value against which a comparison is to be made
-            </summary>
-        </member>
-        <member name="F:NUnit.Framework.Constraints.ComparisonConstraint.ltOK">
-            <summary>
-            If true, less than returns success
-            </summary>
-        </member>
-        <member name="F:NUnit.Framework.Constraints.ComparisonConstraint.eqOK">
-            <summary>
-            if true, equal returns success
-            </summary>
-        </member>
-        <member name="F:NUnit.Framework.Constraints.ComparisonConstraint.gtOK">
-            <summary>
-            if true, greater than returns success
-            </summary>
-        </member>
-        <member name="F:NUnit.Framework.Constraints.ComparisonConstraint.predicate">
-            <summary>
-            The predicate used as a part of the description
-            </summary>
-        </member>
-        <member name="F:NUnit.Framework.Constraints.ComparisonConstraint.comparer">
-            <summary>
-            ComparisonAdapter to be used in making the comparison
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.ComparisonConstraint.#ctor(System.Object,System.Boolean,System.Boolean,System.Boolean,System.String)">
-            <summary>
-            Initializes a new instance of the <see cref="T:ComparisonConstraint"/> class.
-            </summary>
-            <param name="value">The value against which to make a comparison.</param>
-            <param name="ltOK">if set to <c>true</c> less succeeds.</param>
-            <param name="eqOK">if set to <c>true</c> equal succeeds.</param>
-            <param name="gtOK">if set to <c>true</c> greater succeeds.</param>
-            <param name="predicate">String used in describing the constraint.</param>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.ComparisonConstraint.Matches(System.Object)">
-            <summary>
-            Test whether the constraint is satisfied by a given value
-            </summary>
-            <param name="actual">The value to be tested</param>
-            <returns>True for success, false for failure</returns>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.ComparisonConstraint.WriteDescriptionTo(NUnit.Framework.Constraints.MessageWriter)">
-            <summary>
-            Write the constraint description to a MessageWriter
-            </summary>
-            <param name="writer">The writer on which the description is displayed</param>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.ComparisonConstraint.Using(System.Collections.IComparer)">
-            <summary>
-            Modifies the constraint to use an IComparer and returns self
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.ComparisonConstraint.Using``1(System.Collections.Generic.IComparer{``0})">
-            <summary>
-            Modifies the constraint to use an IComparer&lt;T&gt; and returns self
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.ComparisonConstraint.Using``1(System.Comparison{``0})">
-            <summary>
-            Modifies the constraint to use a Comparison&lt;T&gt; and returns self
-            </summary>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.GreaterThanConstraint">
-            <summary>
-            Tests whether a value is greater than the value supplied to its constructor
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.GreaterThanConstraint.#ctor(System.Object)">
-            <summary>
-            Initializes a new instance of the <see cref="T:GreaterThanConstraint"/> class.
-            </summary>
-            <param name="expected">The expected value.</param>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.GreaterThanOrEqualConstraint">
-            <summary>
-            Tests whether a value is greater than or equal to the value supplied to its constructor
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.GreaterThanOrEqualConstraint.#ctor(System.Object)">
-            <summary>
-            Initializes a new instance of the <see cref="T:GreaterThanOrEqualConstraint"/> class.
-            </summary>
-            <param name="expected">The expected value.</param>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.LessThanConstraint">
-            <summary>
-            Tests whether a value is less than the value supplied to its constructor
-            </summary>
-        </member>
-        <member name="M:NUnit.Framework.Constraints.LessThanConstraint.#ctor(System.Object)">
-            <summary>
-            Initializes a new instance of the <see cref="T:LessThanConstraint"/> class.
-            </summary>
-            <param name="expected">The expected value.</param>
-        </member>
-        <member name="T:NUnit.Framework.Constraints.LessThanOrEqualConstraint">
-            <summar

<TRUNCATED>
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/framework/nunit.mocks.dll
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/framework/nunit.mocks.dll b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/framework/nunit.mocks.dll
deleted file mode 100644
index 97b88e7..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/framework/nunit.mocks.dll and /dev/null differ


[36/51] [abbrv] [partial] Cleaning up and getting ready to development towards v4.8

Posted by sy...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Gallio.plugin
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Gallio.plugin b/lib/Gallio.3.2.750/tools/Gallio.plugin
deleted file mode 100644
index f507163..0000000
--- a/lib/Gallio.3.2.750/tools/Gallio.plugin
+++ /dev/null
@@ -1,658 +0,0 @@
-<?xml version="1.0" encoding="utf-8" ?>
-<plugin pluginId="Gallio"
-        recommendedInstallationPath=""
-        xmlns="http://www.gallio.org/">
-  <traits>
-    <name>Gallio</name>
-    <version>3.2.0.0</version>
-    <description>The heart of Gallio.</description>
-    <icon>plugin://Gallio/Resources/Gallio.ico</icon>
-  </traits>
-
-  <dependencies>
-    <dependency pluginId="BuiltIn" />
-  </dependencies>
-
-  <files>
-    <file path="Gallio.plugin" />
-    <file path="Gallio.dll" />
-    <file path="Gallio.pdb" />
-    <file path="Gallio.xml" />
-    <file path="Gallio.XmlSerializers.dll" />
-    <file path="Gallio.Host.exe" />
-    <file path="Gallio.Host.exe.config" />
-    <file path="Gallio.Host.x86.exe" />
-    <file path="Gallio.Host.x86.exe.config" />
-    <file path="Gallio.Host.Elevated.exe" />
-    <file path="Gallio.Host.Elevated.exe.config" />
-    <file path="Gallio.Host.Elevated.x86.exe" />
-    <file path="Gallio.Host.Elevated.x86.exe.config" />
-
-    <file path="Resources\Assembly.ico" />
-    <file path="Resources\Container.ico" />
-    <file path="Resources\Fixture.ico" />
-    <file path="Resources\Gallio.ico" />
-    <file path="Resources\Test.ico" />
-    <file path="Resources\Unsupported.ico" />
-  </files>
-
-  <assemblies>
-    <assembly fullName="Gallio, Version=3.2.0.0, Culture=neutral, PublicKeyToken=eb9cfa67ee6ab36e"
-              codeBase="Gallio.dll"
-              qualifyPartialName="true" />
-  </assemblies>
-
-  <services>
-    <service serviceId="Gallio.Common.Concurrency.ProcessCreator"
-             serviceType="Gallio.Common.Concurrency.IProcessCreator, Gallio" />
-
-    <service serviceId="Gallio.Common.Concurrency.ProcessFinder"
-             serviceType="Gallio.Common.Concurrency.IProcessFinder, Gallio" />
-
-    <service serviceId="Gallio.FileSystem"
-             serviceType="Gallio.Common.IO.IFileSystem, Gallio" />
-
-    <service serviceId="Gallio.XmlSerializer"
-             serviceType="Gallio.Common.Xml.IXmlSerializer, Gallio" />
-    
-    <service serviceId="Gallio.HostFactory"
-             serviceType="Gallio.Runtime.Hosting.IHostFactory, Gallio" />
-
-    <service serviceId="Gallio.Debugger"
-             serviceType="Gallio.Runtime.Debugging.IDebugger, Gallio" />
-
-    <service serviceId="Gallio.DebuggerManager"
-             serviceType="Gallio.Runtime.Debugging.IDebuggerManager, Gallio" />
-
-    <service serviceId="Gallio.FileTypeRecognizer"
-             serviceType="Gallio.Runtime.FileTypes.IFileTypeRecognizer, Gallio"
-             defaultComponentType="Gallio.Runtime.FileTypes.SimpleFileTypeRecognizer, Gallio" />
-
-    <service serviceId="Gallio.FileTypeManager"
-             serviceType="Gallio.Runtime.FileTypes.IFileTypeManager, Gallio" />
-
-    <service serviceId="Gallio.UtilityCommandManager"
-             serviceType="Gallio.Runtime.UtilityCommands.IUtilityCommandManager, Gallio" />
-
-    <service serviceId="Gallio.UtilityCommand"
-             serviceType="Gallio.Runtime.UtilityCommands.IUtilityCommand, Gallio" />
-
-    <service serviceId="Gallio.InstallerManager"
-             serviceType="Gallio.Runtime.Installer.IInstallerManager, Gallio" />
-
-    <service serviceId="Gallio.Installer"
-             serviceType="Gallio.Runtime.Installer.IInstaller, Gallio" />
-
-    <service serviceId="Gallio.Converter"
-             serviceType="Gallio.Runtime.Conversions.IConverter, Gallio" />
-
-    <service serviceId="Gallio.ConversionRule"
-             serviceType="Gallio.Runtime.Conversions.IConversionRule, Gallio" />
-
-    <service serviceId="Gallio.Formatter"
-             serviceType="Gallio.Runtime.Formatting.IFormatter, Gallio" />
-
-    <service serviceId="Gallio.FormattingRule"
-             serviceType="Gallio.Runtime.Formatting.IFormattingRule, Gallio" />
-
-    <service serviceId="Gallio.ElevatedCommand"
-             serviceType="Gallio.Runtime.Security.IElevatedCommand, Gallio" />
-
-    <service serviceId="Gallio.ElevationManager"
-             serviceType="Gallio.Runtime.Security.IElevationManager, Gallio" />
-
-    <service serviceId="Gallio.PreferenceManager"
-             serviceType="Gallio.Runtime.Preferences.IPreferenceManager, Gallio" />
-
-    <service serviceId="Gallio.TestFramework"
-             serviceType="Gallio.Model.ITestFramework, Gallio" />
-
-    <service serviceId="Gallio.TestFrameworkManager"
-             serviceType="Gallio.Model.ITestFrameworkManager, Gallio" />
-
-    <service serviceId="Gallio.TestKind"
-             serviceType="Gallio.Model.ITestKind, Gallio"
-             defaultComponentType="Gallio.Model.DefaultTestKind, Gallio"/>
-
-    <service serviceId="Gallio.TestKindManager"
-             serviceType="Gallio.Model.ITestKindManager, Gallio" />
-
-    <service serviceId="Gallio.TestContextTracker"
-             serviceType="Gallio.Model.Contexts.ITestContextTracker, Gallio" />
-
-    <service serviceId="Gallio.TestRunnerFactory"
-             serviceType="Gallio.Runner.ITestRunnerFactory, Gallio" />
-
-    <service serviceId="Gallio.TestIsolationProvider"
-             serviceType="Gallio.Model.Isolation.ITestIsolationProvider, Gallio" />
-
-    <service serviceId="Gallio.ReportFormatter"
-             serviceType="Gallio.Runner.Reports.IReportFormatter, Gallio" />
-
-    <service serviceId="Gallio.TestRunnerManager"
-             serviceType="Gallio.Runner.ITestRunnerManager, Gallio" />
-
-    <service serviceId="Gallio.TestEnvironment"
-             serviceType="Gallio.Model.Environments.ITestEnvironment, Gallio" />
-
-    <service serviceId="Gallio.TestEnvironmentManager"
-             serviceType="Gallio.Model.Environments.ITestEnvironmentManager, Gallio" />
-
-    <service serviceId="Gallio.ReportManager"
-             serviceType="Gallio.Runner.Reports.IReportManager, Gallio" />
-
-    <service serviceId="Gallio.TestProjectManager"
-             serviceType="Gallio.Runner.Projects.ITestProjectManager, Gallio" />
-
-    <service serviceId="Gallio.TestRunnerExtensionFactory"
-             serviceType="Gallio.Runner.Extensions.ITestRunnerExtensionFactory, Gallio" />
-
-    <service serviceId="Gallio.TestRunnerExtensionManager"
-             serviceType="Gallio.Runner.Extensions.ITestRunnerExtensionManager, Gallio" />
-
-    <service serviceId="Gallio.PatternTestController"
-             serviceType="Gallio.Framework.Pattern.PatternTestController, Gallio" />
-
-    <service serviceId="Gallio.ExtensionPoints"
-             serviceType="Gallio.Runtime.Extensibility.IExtensionPoints, Gallio" />
-
-    <service serviceId="Gallio.ComparisonSemantics"
-             serviceType="Gallio.Framework.IComparisonSemantics, Gallio" />
-  </services>
-  
-  <components>
-    <component componentId="Gallio.FallbackTestFramework"
-               serviceId="Gallio.TestFramework"
-               componentType="Gallio.Model.FallbackTestFramework, Gallio">
-      <traits>
-        <name>Fallback</name>
-        <icon>plugin://Gallio/Resources/Gallio.ico</icon>
-      </traits>
-    </component>
-
-    <component componentId="Gallio.TestFrameworkManager"
-               serviceId="Gallio.TestFrameworkManager"
-               componentType="Gallio.Model.DefaultTestFrameworkManager, Gallio">
-      <parameters>
-        <fallbackTestFrameworkHandle>${Gallio.FallbackTestFramework}</fallbackTestFrameworkHandle>
-      </parameters>
-    </component>
-
-    <component componentId="Gallio.TestRunnerManager"
-               serviceId="Gallio.TestRunnerManager"
-               componentType="Gallio.Runner.DefaultTestRunnerManager, Gallio" />
-
-    <component componentId="Gallio.TestEnvironmentManager"
-               serviceId="Gallio.TestEnvironmentManager"
-               componentType="Gallio.Model.Environments.DefaultTestEnvironmentManager, Gallio" />
-
-    <component componentId="Gallio.ConsoleTestEnvironment"
-               serviceId="Gallio.TestEnvironment"
-               componentType="Gallio.Model.Environments.ConsoleTestEnvironment, Gallio" />
-
-    <component componentId="Gallio.TraceTestEnvironment"
-               serviceId="Gallio.TestEnvironment"
-               componentType="Gallio.Model.Environments.TraceTestEnvironment, Gallio" />
-
-    <component componentId="Gallio.UnhandledExceptionTestEnvironment"
-               serviceId="Gallio.TestEnvironment"
-               componentType="Gallio.Model.Environments.UnhandledExceptionTestEnvironment, Gallio" />
-
-    <component componentId="Gallio.CustomTestEnvironment"
-               serviceId="Gallio.TestEnvironment"
-               componentType="Gallio.Model.Environments.CustomTestEnvironment, Gallio" />
-
-    <component componentId="Gallio.WindowsFormsTestEnvironment"
-               serviceId="Gallio.TestEnvironment"
-               componentType="Gallio.Model.Environments.WindowsFormsTestEnvironment, Gallio" />
-
-    <component componentId="Gallio.ReportManager"
-               serviceId="Gallio.ReportManager"
-               componentType="Gallio.Runner.Reports.DefaultReportManager, Gallio" />
-
-    <component componentId="Gallio.TestProjectManager"
-               serviceId="Gallio.TestProjectManager"
-               componentType="Gallio.Runner.Projects.DefaultTestProjectManager, Gallio" />
-
-    <component componentId="Gallio.TestContextTracker"
-               serviceId="Gallio.TestContextTracker"
-               componentType="Gallio.Model.Contexts.DefaultTestContextTracker, Gallio" />
-
-    <component componentId="Gallio.PatternTestController"
-               serviceId="Gallio.PatternTestController"
-               componentType="Gallio.Framework.Pattern.PatternTestController, Gallio" />
-
-    <component componentId="Gallio.DebuggerManager"
-               serviceId="Gallio.DebuggerManager"
-               componentType="Gallio.Runtime.Debugging.DefaultDebuggerManager, Gallio" />
-
-    <component componentId="Gallio.ElevationManager"
-               serviceId="Gallio.ElevationManager"
-               componentType="Gallio.Runtime.Security.DefaultElevationManager, Gallio" />
-
-    <component componentId="Gallio.PreferenceManager"
-               serviceId="Gallio.PreferenceManager"
-               componentType="Gallio.Runtime.Preferences.FilePreferenceManager, Gallio" />
-    
-    <component componentId="Gallio.ExtensionPoints"
-               serviceId="Gallio.ExtensionPoints"
-               componentType="Gallio.Runtime.Extensibility.DefaultExtensionPoints, Gallio" />
-	
-    <component componentId="Gallio.ComparisonSemantics"
-               serviceId="Gallio.ComparisonSemantics"
-               componentType="Gallio.Framework.DefaultComparisonSemantics, Gallio" />
-
-    <!-- Host Factories -->
-    
-    <component componentId="Gallio.LocalHostFactory"
-               serviceId="Gallio.HostFactory"
-               componentType="Gallio.Runtime.Hosting.LocalHostFactory, Gallio" />
-
-    <component componentId="Gallio.IsolatedAppDomainHostFactory"
-               serviceId="Gallio.HostFactory"
-               componentType="Gallio.Runtime.Hosting.IsolatedAppDomainHostFactory, Gallio" />
-
-    <component componentId="Gallio.IsolatedProcessHostFactory"
-               serviceId="Gallio.HostFactory"
-               componentType="Gallio.Runtime.Hosting.IsolatedProcessHostFactory, Gallio" />
-
-    <!-- Test Runner Factories -->
-
-    <component componentId="Gallio.LocalTestRunnerFactory"
-               serviceId="Gallio.TestRunnerFactory"
-               componentType="Gallio.Runner.DefaultTestRunnerFactory, Gallio">
-      <parameters>
-        <testIsolationProvider>${Gallio.LocalTestIsolationProvider}</testIsolationProvider>
-      </parameters>
-      <traits>
-        <name>Local</name>
-        <description>Runs tests locally within the same process and AppDomain as the test runner application.  Each test isolation context runs locally.  This mode offers no isolation between tests and the test runner; it does not support loading test assembly configuration files or using a different runtime version or processor architecture.</description>
-      </traits>
-    </component>
-
-    <component componentId="Gallio.IsolatedAppDomainTestRunnerFactory"
-               serviceId="Gallio.TestRunnerFactory"
-               componentType="Gallio.Runner.DefaultTestRunnerFactory, Gallio">
-      <parameters>
-        <testIsolationProvider>${Gallio.IsolatedAppDomainTestIsolationProvider}</testIsolationProvider>
-      </parameters>
-      <traits>
-        <name>IsolatedAppDomain</name>
-        <description>Runs tests within an isolated AppDomain of the same process as the test runner application.  Each test isolation context runs in its own AppDomain.  This mode provides lightweight but limited isolation between tests and the test runner; it does not support using different runtime version or processor architecture.</description>
-      </traits>
-    </component>
-
-    <component componentId="Gallio.IsolatedProcessTestRunnerFactory"
-               serviceId="Gallio.TestRunnerFactory"
-               componentType="Gallio.Runner.DefaultTestRunnerFactory, Gallio">
-      <parameters>
-        <testIsolationProvider>${Gallio.IsolatedProcessTestIsolationProvider}</testIsolationProvider>
-      </parameters>
-      <traits>
-        <name>IsolatedProcess</name>
-        <description>Runs tests within an isolated process external to the test runner.  Each test isolation context runs in its own process.  This mode protects the test runner application from most faults that may occur during test execution; it supports all features.</description>
-      </traits>
-    </component>
-    
-    <!-- Test Isolation Providers -->
-    
-    <component componentId="Gallio.LocalTestIsolationProvider"
-               serviceId="Gallio.TestIsolationProvider"
-               componentType="Gallio.Model.Isolation.HostedTestIsolationProvider, Gallio">
-      <parameters>
-        <hostFactory>${Gallio.LocalHostFactory}</hostFactory>
-      </parameters>
-    </component>
-
-    <component componentId="Gallio.IsolatedAppDomainTestIsolationProvider"
-               serviceId="Gallio.TestIsolationProvider"
-               componentType="Gallio.Model.Isolation.HostedTestIsolationProvider, Gallio">
-      <parameters>
-        <hostFactory>${Gallio.IsolatedAppDomainHostFactory}</hostFactory>
-      </parameters>
-    </component>
-
-    <component componentId="Gallio.IsolatedProcessTestIsolationProvider"
-               serviceId="Gallio.TestIsolationProvider"
-               componentType="Gallio.Model.Isolation.HostedTestIsolationProvider, Gallio">
-      <parameters>
-        <hostFactory>${Gallio.IsolatedProcessHostFactory}</hostFactory>
-      </parameters>
-    </component>
-
-    <component componentId="Gallio.TestRunnerExtensionManager"
-               serviceId="Gallio.TestRunnerExtensionManager"
-               componentType="Gallio.Runner.Extensions.DefaultTestRunnerExtensionManager, Gallio" />
-
-    <!-- Converters -->
-    <component componentId="Gallio.Converter"
-               serviceId="Gallio.Converter"
-               componentType="Gallio.Runtime.Conversions.RuleBasedConverter, Gallio" />
-
-    <component componentId="Gallio.ArrayToArrayConversionRule"
-               serviceId="Gallio.ConversionRule"
-               componentType="Gallio.Runtime.Conversions.ArrayToArrayConversionRule, Gallio" />
-
-    <component componentId="Gallio.ConvertibleToConvertibleConversionRule"
-               serviceId="Gallio.ConversionRule"
-               componentType="Gallio.Runtime.Conversions.ConvertibleToConvertibleConversionRule, Gallio" />
-
-    <component componentId="Gallio.ObjectToStringConversionRule"
-               serviceId="Gallio.ConversionRule"
-               componentType="Gallio.Runtime.Conversions.ObjectToStringConversionRule, Gallio" />
-
-    <component componentId="Gallio.StringToXmlDocumentConversionRule"
-               serviceId="Gallio.ConversionRule"
-               componentType="Gallio.Runtime.Conversions.StringToXmlDocumentConversionRule, Gallio" />
-
-    <component componentId="Gallio.XPathNavigableToXPathNavigatorConversionRule"
-               serviceId="Gallio.ConversionRule"
-               componentType="Gallio.Runtime.Conversions.XPathNavigableToXPathNavigatorConversionRule, Gallio" />
-
-    <component componentId="Gallio.XPathNavigatorToStringConversionRule"
-               serviceId="Gallio.ConversionRule"
-               componentType="Gallio.Runtime.Conversions.XPathNavigatorToStringConversionRule, Gallio" />
-
-    <component componentId="Gallio.XPathNavigatorToXmlSerializableTypeConversionRule"
-               serviceId="Gallio.ConversionRule"
-               componentType="Gallio.Runtime.Conversions.XPathNavigatorToXmlSerializableTypeConversionRule, Gallio" />
-
-    <component componentId="Gallio.StringToEnumConversionRule"
-               serviceId="Gallio.ConversionRule"
-               componentType="Gallio.Runtime.Conversions.StringToEnumConversionRule, Gallio" />
-
-    <!-- Formatters -->
-    <component componentId="Gallio.Formatter"
-               serviceId="Gallio.Formatter"
-               componentType="Gallio.Runtime.Formatting.RuleBasedFormatter, Gallio" />
-
-    <component componentId="Gallio.BooleanFormattingRule"
-               serviceId="Gallio.FormattingRule"
-               componentType="Gallio.Runtime.Formatting.BooleanFormattingRule, Gallio" />
-
-    <component componentId="Gallio.ByteFormattingRule"
-               serviceId="Gallio.FormattingRule"
-               componentType="Gallio.Runtime.Formatting.ByteFormattingRule, Gallio" />
-
-    <component componentId="Gallio.CharFormattingRule"
-               serviceId="Gallio.FormattingRule"
-               componentType="Gallio.Runtime.Formatting.CharFormattingRule, Gallio" />
-
-    <component componentId="Gallio.ConvertToStringFormattingRule"
-               serviceId="Gallio.FormattingRule"
-               componentType="Gallio.Runtime.Formatting.ConvertToStringFormattingRule, Gallio" />
-
-    <component componentId="Gallio.DateTimeFormattingRule"
-               serviceId="Gallio.FormattingRule"
-               componentType="Gallio.Runtime.Formatting.DateTimeFormattingRule, Gallio" />
-
-    <component componentId="Gallio.DBNullFormattingRule"
-               serviceId="Gallio.FormattingRule"
-               componentType="Gallio.Runtime.Formatting.DBNullFormattingRule, Gallio" />
-
-    <component componentId="Gallio.DecimalFormattingRule"
-               serviceId="Gallio.FormattingRule"
-               componentType="Gallio.Runtime.Formatting.DecimalFormattingRule, Gallio" />
-
-    <component componentId="Gallio.DictionaryEntryFormattingRule"
-               serviceId="Gallio.FormattingRule"
-               componentType="Gallio.Runtime.Formatting.DictionaryEntryFormattingRule, Gallio" />
-
-    <component componentId="Gallio.DoubleFormattingRule"
-               serviceId="Gallio.FormattingRule"
-               componentType="Gallio.Runtime.Formatting.DoubleFormattingRule, Gallio" />
-
-    <component componentId="Gallio.EnumerableFormattingRule"
-               serviceId="Gallio.FormattingRule"
-               componentType="Gallio.Runtime.Formatting.EnumerableFormattingRule, Gallio" />
-
-    <component componentId="Gallio.IntegerFormattingRule"
-               serviceId="Gallio.FormattingRule"
-               componentType="Gallio.Runtime.Formatting.IntegerFormattingRule, Gallio" />
-
-    <component componentId="Gallio.KeyValuePairFormattingRule"
-               serviceId="Gallio.FormattingRule"
-               componentType="Gallio.Runtime.Formatting.KeyValuePairFormattingRule, Gallio" />
-
-    <component componentId="Gallio.SByteFormattingRule"
-               serviceId="Gallio.FormattingRule"
-               componentType="Gallio.Runtime.Formatting.SByteFormattingRule, Gallio" />
-
-    <component componentId="Gallio.SingleFormattingRule"
-               serviceId="Gallio.FormattingRule"
-               componentType="Gallio.Runtime.Formatting.SingleFormattingRule, Gallio" />
-
-    <component componentId="Gallio.StringFormattingRule"
-               serviceId="Gallio.FormattingRule"
-               componentType="Gallio.Runtime.Formatting.StringFormattingRule, Gallio" />
-
-    <component componentId="Gallio.TypeFormattingRule"
-               serviceId="Gallio.FormattingRule"
-               componentType="Gallio.Runtime.Formatting.TypeFormattingRule, Gallio" />
-
-    <component componentId="Gallio.MemberInfoFormattingRule"
-               serviceId="Gallio.FormattingRule"
-               componentType="Gallio.Runtime.Formatting.MemberInfoFormattingRule, Gallio" />
-
-    <component componentId="Gallio.XPathNavigableFormattingRule"
-               serviceId="Gallio.FormattingRule"
-               componentType="Gallio.Runtime.Formatting.XPathNavigableFormattingRule, Gallio" />
-
-    <component componentId="Gallio.StructuralFormattingRule"
-               serviceId="Gallio.FormattingRule"
-               componentType="Gallio.Runtime.Formatting.StructuralFormattingRule, Gallio" />
-    
-    <!-- File types -->
-
-    <component componentId="Gallio.FileTypeManager"
-               serviceId="Gallio.FileTypeManager"
-               componentType="Gallio.Runtime.FileTypes.FileTypeManager, Gallio" />
-
-    <component componentId="Gallio.FileTypeRecognizers.Project"
-               serviceId="Gallio.FileTypeRecognizer">
-      <traits>
-        <id>Project</id>
-        <description>A Gallio project file.</description>
-        <fileNameRegex>.*\.gallio</fileNameRegex>
-      </traits>
-    </component>
-
-    <component componentId="Gallio.FileTypeRecognizers.Executable"
-               serviceId="Gallio.FileTypeRecognizer">
-      <traits>
-        <id>Executable</id>
-        <description>A library or program file.</description>
-        <fileNameRegex>.*\.(dll|exe)</fileNameRegex>
-      </traits>
-    </component>
-
-    <component componentId="Gallio.FileTypeRecognizers.Assembly"
-               serviceId="Gallio.FileTypeRecognizer"
-               componentType="Gallio.Runtime.FileTypes.AssemblyFileTypeRecognizer, Gallio">
-      <traits>
-        <id>Assembly</id>
-        <description>A .Net assembly.</description>
-        <superTypeId>Executable</superTypeId>
-      </traits>
-    </component>
-    
-    <!-- Common helpers -->
-
-    <component componentId="Gallio.Common.Concurrency.ProcessCreator"
-               serviceId="Gallio.Common.Concurrency.ProcessCreator"
-               componentType="Gallio.Common.Concurrency.ProcessCreator, Gallio" />
-
-    <component componentId="Gallio.Common.Concurrency.ProcessFinder"
-               serviceId="Gallio.Common.Concurrency.ProcessFinder"
-               componentType="Gallio.Common.Concurrency.ProcessFinder, Gallio" />
-
-    <component componentId="Gallio.FileSystem" 
-               serviceId="Gallio.FileSystem" 
-               componentType="Gallio.Common.IO.FileSystem, Gallio" />
-
-    <component componentId="Gallio.XmlSerializer" 
-               serviceId="Gallio.XmlSerializer" 
-               componentType="Gallio.Common.Xml.DefaultXmlSerializer, Gallio" />
-    
-    <!-- Utility commands -->
-
-    <component componentId="Gallio.UtilityCommandManager"
-               serviceId="Gallio.UtilityCommandManager"
-               componentType="Gallio.Runtime.UtilityCommands.DefaultUtilityCommandManager, Gallio" />
-
-    <component componentId="Gallio.ClearCurrentUserPluginCacheUtilityCommand"
-               serviceId="Gallio.UtilityCommand"
-               componentType="Gallio.Runtime.UtilityCommands.ClearCurrentUserPluginCacheUtilityCommand, Gallio">
-      <traits>
-        <!-- Note: This particular command name is special and is also hardcoded in the Gallio.Utility.exe program itself
-                   because we want to be able to run the command without initializing the runtime itself.
-        -->
-        <name>ClearCurrentUserPluginCache</name>
-        <description>Clears the plugin cache of the current user.</description>
-      </traits>
-    </component>
-
-    <component componentId="Gallio.FormatReportUtilityCommand"
-               serviceId="Gallio.UtilityCommand"
-               componentType="Gallio.Runtime.UtilityCommands.FormatReportUtilityCommand, Gallio">
-      <traits>
-        <name>FormatReport</name>
-        <description>Formats an existing XML test report. The command must be used with the following syntax: 
-		"FormatReport {file} /ReportType:{type} [/ReportNameFormat:{format} /ReportOutput:{dir} /ReportArchive]"
-		- {file} is the relative or absolute path of the existing XML test report.
-		- ReportType (short form: /rt) specifies the type of the output report ('txt', 'txt-common', 'txt-condensed', 'html', 'html+xhtml', 'html-condensed', 'xhtml', 'xhtml-condensed', 'ccnet-details', or 'ccnet-details-condensed')
-		- ReportNameFormat (short form: /rnf) specifies the format of the output report (optional; if not specified, the same name is kept). The tags '{0}' and '{1}' are replaced respectively by the date and the time of the test run, or by the curent date/time if not applicable.
-		- ReportOutput (short form: /ro) specifies the output directory (optional; if not specified the current directory is used).
-		- ReportArchive (short form: /ra) compresses the output report in a file archive (zip).</description>
-      </traits>
-    </component>
-	
-    <component componentId="Gallio.VerifyInstallationUtilityCommand"
-               serviceId="Gallio.UtilityCommand"
-               componentType="Gallio.Runtime.UtilityCommands.VerifyInstallationUtilityCommand, Gallio">
-      <traits>
-        <name>VerifyInstallation</name>
-        <description>Checks for runtime installation errors.</description>
-      </traits>
-    </component>
-
-    <component componentId="Gallio.SetupUtilityCommand"
-               serviceId="Gallio.UtilityCommand"
-               componentType="Gallio.Runtime.Installer.SetupUtilityCommand, Gallio">
-      <traits>
-        <name>Setup</name>
-        <description>Installs or uninstalls components.</description>
-      </traits>
-    </component>
-
-    <component componentId="Gallio.ResetInstallationIdUtilityCommand"
-               serviceId="Gallio.UtilityCommand"
-               componentType="Gallio.Runtime.UtilityCommands.ResetInstallationIdUtilityCommand, Gallio">
-      <traits>
-        <name>ResetInstallationId</name>
-        <description>Resets the installation id.  The plugin list will be refreshed the next time a Gallio application is started.</description>
-      </traits>
-    </component>
-
-    <component componentId="Gallio.ResetInstallationIdElevatedCommand"
-               serviceId="Gallio.ElevatedCommand"
-               componentType="Gallio.Runtime.UtilityCommands.ResetInstallationIdElevatedCommand, Gallio" />
-
-    <!-- Installers -->
-
-    <component componentId="Gallio.InstallerElevatedCommand"
-               serviceId="Gallio.ElevatedCommand"
-               componentType="Gallio.Runtime.Installer.InstallerElevatedCommand, Gallio" />
-
-    <component componentId="Gallio.InstallerManager"
-               serviceId="Gallio.InstallerManager"
-               componentType="Gallio.Runtime.Installer.DefaultInstallerManager, Gallio" />
-    
-    <!-- Test Kinds -->
-
-    <component componentId="Gallio.TestKindManager"
-               serviceId="Gallio.TestKindManager"
-               componentType="Gallio.Model.DefaultTestKindManager, Gallio" />
-    
-    <component componentId="Gallio.TestKinds.Root"
-               serviceId="Gallio.TestKind">
-      <traits>
-        <name>Root</name>
-        <description>The root node of the test tree.</description>
-        <icon>plugin://Gallio/Resources/Assembly.ico</icon>
-      </traits>
-    </component>
-
-    <component componentId="Gallio.TestKinds.Assembly"
-               serviceId="Gallio.TestKind">
-      <traits>
-        <name>Assembly</name>
-        <description>A test assembly.</description>
-        <icon>plugin://Gallio/Resources/Assembly.ico</icon>
-      </traits>
-    </component>
-
-    <component componentId="Gallio.TestKinds.File"
-               serviceId="Gallio.TestKind">
-      <traits>
-        <name>File</name>
-        <description>A test file.</description>
-        <icon>plugin://Gallio/Resources/Container.ico</icon>
-      </traits>
-    </component>
-
-    <component componentId="Gallio.TestKinds.Namespace"
-               serviceId="Gallio.TestKind">
-      <traits>
-        <name>Namespace</name>
-        <description>A test namespace.</description>
-        <icon>plugin://Gallio/Resources/Container.ico</icon>
-      </traits>
-    </component>
-
-    <component componentId="Gallio.TestKinds.Group"
-               serviceId="Gallio.TestKind">
-      <traits>
-        <name>Group</name>
-        <description>A test group.</description>
-        <icon>plugin://Gallio/Resources/Container.ico</icon>
-      </traits>
-    </component>
-
-    <component componentId="Gallio.TestKinds.Suite"
-               serviceId="Gallio.TestKind">
-      <traits>
-        <name>Suite</name>
-        <description>A test suite.</description>
-        <icon>plugin://Gallio/Resources/Container.ico</icon>
-      </traits>
-    </component>
-
-    <component componentId="Gallio.TestKinds.Fixture"
-               serviceId="Gallio.TestKind">
-      <traits>
-        <name>Fixture</name>
-        <description>A test fixture.</description>
-        <icon>plugin://Gallio/Resources/Fixture.ico</icon>
-      </traits>
-    </component>
-
-    <component componentId="Gallio.TestKinds.Test"
-               serviceId="Gallio.TestKind">
-      <traits>
-        <name>Test</name>
-        <description>A test case.</description>
-        <icon>plugin://Gallio/Resources/Test.ico</icon>
-      </traits>
-    </component>
-
-    <component componentId="Gallio.TestKinds.Unsupported"
-               serviceId="Gallio.TestKind">
-      <traits>
-        <name>Unsupported</name>
-        <description>An unsupported test.</description>
-        <icon>plugin://Gallio/Resources/Unsupported.ico</icon>
-      </traits>
-    </component>
-  </components>
-</plugin>


[34/51] [abbrv] [partial] Cleaning up and getting ready to development towards v4.8

Posted by sy...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Gallio35.pdb
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Gallio35.pdb b/lib/Gallio.3.2.750/tools/Gallio35.pdb
deleted file mode 100644
index 6d065f0..0000000
Binary files a/lib/Gallio.3.2.750/tools/Gallio35.pdb and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Gallio35.plugin
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Gallio35.plugin b/lib/Gallio.3.2.750/tools/Gallio35.plugin
deleted file mode 100644
index 5c38749..0000000
--- a/lib/Gallio.3.2.750/tools/Gallio35.plugin
+++ /dev/null
@@ -1,35 +0,0 @@
-<?xml version="1.0" encoding="utf-8" ?>
-<plugin pluginId="Gallio35"
-        recommendedInstallationPath=""
-        enableCondition="${minFramework:NET35}"
-        xmlns="http://www.gallio.org/">
-  <traits>
-    <name>Gallio Extensions for .Net 3.5</name>
-    <version>3.2.0.0</version>
-    <description>Provides additional Gallio features for use with .Net 3.5.</description>
-    <icon>plugin://Gallio/Resources/Gallio.ico</icon>
-  </traits>
-
-  <dependencies>
-    <dependency pluginId="Gallio" />
-  </dependencies>
-
-  <files>
-    <file path="Gallio35.plugin" />
-    <file path="Gallio35.dll" />
-    <file path="Gallio35.pdb" />
-    <file path="Gallio35.xml" />
-  </files>
-
-  <assemblies>
-    <assembly fullName="Gallio35, Version=3.2.0.0, Culture=neutral, PublicKeyToken=eb9cfa67ee6ab36e"
-              codeBase="Gallio35.dll"
-              qualifyPartialName="true" />
-  </assemblies>
-
-  <components>
-    <component componentId="Gallio35.ExpressionFormattingRule"
-               serviceId="Gallio.FormattingRule"
-               componentType="Gallio.Runtime.Formatting.ExpressionFormattingRule, Gallio35" />
-  </components>
-</plugin>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Gallio35.xml
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Gallio35.xml b/lib/Gallio.3.2.750/tools/Gallio35.xml
deleted file mode 100644
index 42cd6bb..0000000
--- a/lib/Gallio.3.2.750/tools/Gallio35.xml
+++ /dev/null
@@ -1,293 +0,0 @@
-<?xml version="1.0"?>
-<doc>
-    <assembly>
-        <name>Gallio35</name>
-    </assembly>
-    <members>
-        <member name="T:Gallio.Common.Linq.ActionExtensions">
-            <summary>
-            Extension methods for <see cref="T:Gallio.Common.Action"/> delegates.
-            </summary>
-        </member>
-        <member name="M:Gallio.Common.Linq.ActionExtensions.AsUnitFunc(System.Action)">
-            <summary>
-            Wraps an action as a function that returns a dummy <see cref="T:Gallio.Common.Unit"/> value.
-            </summary>
-            <returns>The function.</returns>
-        </member>
-        <member name="T:Gallio.Common.Linq.ExpressionExtensions">
-            <summary>
-            Extension methods for <see cref="T:System.Linq.Expressions.Expression`1"/>.
-            </summary>
-        </member>
-        <member name="M:Gallio.Common.Linq.ExpressionExtensions.Bind``2(System.Linq.Expressions.Expression{System.Func{``0,``1}},``0)">
-            <summary>
-            Binds the arguments of a function expression.
-            </summary>
-            <typeparam name="T">The parameter type.</typeparam>
-            <typeparam name="TResult">The result type.</typeparam>
-            <param name="expr">The expression.</param>
-            <param name="arg">The argument value.</param>
-            <returns>The bound function.</returns>
-        </member>
-        <member name="M:Gallio.Common.Linq.ExpressionExtensions.Bind``3(System.Linq.Expressions.Expression{System.Func{``0,``2}},``0,``1)">
-            <summary>
-            Binds the arguments of a function expression.
-            </summary>
-            <typeparam name="T1">The first parameter type.</typeparam>
-            <typeparam name="T2">The second parameter type.</typeparam>
-            <typeparam name="TResult">The result type.</typeparam>
-            <param name="expr">The expression.</param>
-            <param name="arg1">The first argument value.</param>
-            <param name="arg2">The second argument value.</param>
-            <returns>The bound function.</returns>
-        </member>
-        <member name="M:Gallio.Common.Linq.ExpressionExtensions.IsCapturedVariable(System.Linq.Expressions.Expression)">
-            <summary>
-            Returns true if the expression represents a captured variable within a closure.
-            </summary>
-            <param name="expr">The expression.</param>
-            <returns>True if the expression represents a captured variable.</returns>
-        </member>
-        <member name="M:Gallio.Common.Linq.ExpressionExtensions.IsCapturedVariable(System.Linq.Expressions.MemberExpression)">
-            <summary>
-            Returns true if the expression represents a captured variable within a closure.
-            </summary>
-            <param name="expr">The expression.</param>
-            <returns>True if the expression represents a captured variable.</returns>
-        </member>
-        <member name="M:Gallio.Common.Linq.ExpressionExtensions.IsCapturedVariableOrParameter(System.Linq.Expressions.Expression)">
-            <summary>
-            Returns true if the expression represents a captured variable or a parameter.
-            </summary>
-            <param name="expr">The expression.</param>
-            <returns>True if the expression represents a captured variable or a parameter.</returns>
-        </member>
-        <member name="T:Gallio.Common.Linq.ExpressionInstrumentor">
-            <summary>
-            Instuments an <see cref="T:System.Linq.Expressions.Expression`1"/> to intercept intermediate results
-            from each sub-expression.
-            </summary>
-        </member>
-        <member name="M:Gallio.Common.Linq.ExpressionInstrumentor.Compile``1(System.Linq.Expressions.Expression{``0})">
-            <summary>
-            Compiles an expression to introduce trace points.
-            </summary>
-            <typeparam name="T">The expression type.</typeparam>
-            <param name="expr">The expression tree.</param>
-            <returns>The compiled delegate representing expression.</returns>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="expr"/> is null.</exception>
-        </member>
-        <member name="M:Gallio.Common.Linq.ExpressionInstrumentor.Rewrite``1(System.Linq.Expressions.Expression{``0})">
-            <summary>
-            Rewrites an expression tree to introduce trace points.
-            </summary>
-            <typeparam name="T">The expression type.</typeparam>
-            <param name="expr">The expression tree.</param>
-            <returns>The compiled delegate representing expression.</returns>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="expr"/> is null.</exception>
-        </member>
-        <member name="M:Gallio.Common.Linq.ExpressionInstrumentor.Intercept``1(System.Linq.Expressions.Expression,System.Func{``0})">
-            <summary>
-            Evaluates a sub-expression and collects trace information.
-            </summary>
-            <typeparam name="T">The return type of the sub-expression.</typeparam>
-            <param name="expr">The sub-expression to evaluate.</param>
-            <param name="continuation">The continuation that evaluates the sub-expression.</param>
-            <returns>The result of the evaluation.</returns>
-        </member>
-        <member name="T:Gallio.Common.Linq.ExpressionVisitor`1">
-            <summary>
-            Performs different actions depending on the type of <see cref="T:System.Linq.Expressions.Expression"/> visited.
-            </summary>
-            <typeparam name="T">The visitor result type.</typeparam>
-        </member>
-        <member name="M:Gallio.Common.Linq.ExpressionVisitor`1.Visit(System.Linq.Expressions.Expression)">
-            <summary>
-            Visits the expression.
-            </summary>
-            <param name="expr">The expression.</param>
-            <returns>The result.</returns>
-        </member>
-        <member name="M:Gallio.Common.Linq.ExpressionVisitor`1.VisitBinary(System.Linq.Expressions.BinaryExpression)">
-            <summary>
-            Visits a binary expression.
-            </summary>
-            <param name="expr">The expression.</param>
-            <returns>The result.</returns>
-        </member>
-        <member name="M:Gallio.Common.Linq.ExpressionVisitor`1.VisitUnary(System.Linq.Expressions.UnaryExpression)">
-            <summary>
-            Visits a unary expression.
-            </summary>
-            <param name="expr">The expression.</param>
-            <returns>The result.</returns>
-        </member>
-        <member name="M:Gallio.Common.Linq.ExpressionVisitor`1.VisitMethodCall(System.Linq.Expressions.MethodCallExpression)">
-            <summary>
-            Visits a call expression.
-            </summary>
-            <param name="expr">The expression.</param>
-            <returns>The result.</returns>
-        </member>
-        <member name="M:Gallio.Common.Linq.ExpressionVisitor`1.VisitConditional(System.Linq.Expressions.ConditionalExpression)">
-            <summary>
-            Visits a conditional expression.
-            </summary>
-            <param name="expr">The expression.</param>
-            <returns>The result.</returns>
-        </member>
-        <member name="M:Gallio.Common.Linq.ExpressionVisitor`1.VisitConstant(System.Linq.Expressions.ConstantExpression)">
-            <summary>
-            Visits a constant expression.
-            </summary>
-            <param name="expr">The expression.</param>
-            <returns>The result.</returns>
-        </member>
-        <member name="M:Gallio.Common.Linq.ExpressionVisitor`1.VisitInvocation(System.Linq.Expressions.InvocationExpression)">
-            <summary>
-            Visits an invocation expression.
-            </summary>
-            <param name="expr">The expression.</param>
-            <returns>The result.</returns>
-        </member>
-        <member name="M:Gallio.Common.Linq.ExpressionVisitor`1.VisitLambda(System.Linq.Expressions.LambdaExpression)">
-            <summary>
-            Visits a lambda expression.
-            </summary>
-            <param name="expr">The expression.</param>
-            <returns>The result.</returns>
-        </member>
-        <member name="M:Gallio.Common.Linq.ExpressionVisitor`1.VisitListInit(System.Linq.Expressions.ListInitExpression)">
-            <summary>
-            Visits an list init expression.
-            </summary>
-            <param name="expr">The expression.</param>
-            <returns>The result.</returns>
-        </member>
-        <member name="M:Gallio.Common.Linq.ExpressionVisitor`1.VisitMember(System.Linq.Expressions.MemberExpression)">
-            <summary>
-            Visits a member access expression.
-            </summary>
-            <param name="expr">The expression.</param>
-            <returns>The result.</returns>
-        </member>
-        <member name="M:Gallio.Common.Linq.ExpressionVisitor`1.VisitMemberInit(System.Linq.Expressions.MemberInitExpression)">
-            <summary>
-            Visits a member init expression.
-            </summary>
-            <param name="expr">The expression.</param>
-            <returns>The result.</returns>
-        </member>
-        <member name="M:Gallio.Common.Linq.ExpressionVisitor`1.VisitNew(System.Linq.Expressions.NewExpression)">
-            <summary>
-            Visits a new expression.
-            </summary>
-            <param name="expr">The expression.</param>
-            <returns>The result.</returns>
-        </member>
-        <member name="M:Gallio.Common.Linq.ExpressionVisitor`1.VisitNewArray(System.Linq.Expressions.NewArrayExpression)">
-            <summary>
-            Visits a new array expression.
-            </summary>
-            <param name="expr">The expression.</param>
-            <returns>The result.</returns>
-        </member>
-        <member name="M:Gallio.Common.Linq.ExpressionVisitor`1.VisitParameter(System.Linq.Expressions.ParameterExpression)">
-            <summary>
-            Visits a parameter expression.
-            </summary>
-            <param name="expr">The expression.</param>
-            <returns>The result.</returns>
-        </member>
-        <member name="M:Gallio.Common.Linq.ExpressionVisitor`1.VisitTypeBinary(System.Linq.Expressions.TypeBinaryExpression)">
-            <summary>
-            Visits a type binary expression.
-            </summary>
-            <param name="expr">The expression.</param>
-            <returns>The result.</returns>
-        </member>
-        <member name="M:Gallio.Common.Linq.ExpressionVisitor`1.VisitAny(System.Linq.Expressions.Expression)">
-            <summary>
-            <para>
-            Visits an expression of any type that does not have other special behavior.
-            </para>
-            <para>
-            The default implementation throws <see cref="T:System.NotSupportedException"/>.
-            </para>
-            </summary>
-            <param name="expr">The expression.</param>
-            <returns>The result.</returns>
-        </member>
-        <member name="T:Gallio.Common.Linq.NamespaceDoc">
-            <summary>
-            The Gallio.Common.Linq namespace contains types for manipulating Linq expressions. 
-            </summary>
-        </member>
-        <member name="T:Gallio.Framework.Assertions.AssertionConditionEvaluator">
-            <summary>
-            Evaluates a conditional expression.  If the condition evaluates differently
-            than expected, returns a detailed <see cref="T:Gallio.Framework.Assertions.AssertionFailure"/> that
-            describes the formatted values of relevant sub-expressions within the condtion.
-            </summary>
-        </member>
-        <member name="M:Gallio.Framework.Assertions.AssertionConditionEvaluator.Eval(System.Linq.Expressions.Expression{System.Func{System.Boolean}},System.Boolean,System.String,System.Object[])">
-            <summary>
-            Evaluates a conditional expression.
-            </summary>
-            <param name="condition">The conditional expression.</param>
-            <param name="expectedResult">The expected result.</param>
-            <param name="messageFormat">The custom assertion message format, or null if none.</param>
-            <param name="messageArgs">The custom assertion message arguments, or null if none.</param>
-            <returns>The assertion failure if the conditional expression evaluated
-            to a different result than was expected or threw an exception, otherwise null.</returns>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="condition"/> is null.</exception>
-        </member>
-        <member name="T:Gallio.Runtime.Formatting.ExpressionFormattingRule">
-            <summary>
-            A formatting rule for <see cref="T:System.Linq.Expressions.Expression"/>.
-            </summary>
-            <remarks>
-            <para>
-            Formats expression trees using a more familiar C#-like syntax than
-            the default.  Also recognizes captured variables and displays them
-            naturally to conceal the implied field access to an anonymous class.
-            </para>
-            <para>
-            Made-up syntax for nodes that cannot be directly represented in C#.
-            <list type="bullet">
-            <item>Power operator: **, as in a ** b</item>
-            <item>Quote expression: `...`, as in `a + b`</item>
-            <item>Constants: formatted recursively using other formatters, which may yield unusual syntax</item>
-            </list>
-            </para>
-            </remarks>
-        </member>
-        <member name="M:Gallio.Runtime.Formatting.ExpressionFormattingRule.GetPriority(System.Type)">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.Runtime.Formatting.ExpressionFormattingRule.Format(System.Object,Gallio.Runtime.Formatting.IFormatter)">
-            <inheritdoc />
-        </member>
-        <member name="T:Gallio.Runtime.Formatting.FormatterExtensions">
-            <summary>
-            Extensions methods for formatting.
-            </summary>
-        </member>
-        <member name="M:Gallio.Runtime.Formatting.FormatterExtensions.Format(System.Object)">
-            <summary>
-            Formats an object using the default <see cref="T:Gallio.Runtime.Formatting.IFormatter"/>.
-            </summary>
-            <param name="obj">The object to format.</param>
-            <returns>The formatted object.</returns>
-        </member>
-        <member name="M:Gallio.Runtime.Formatting.FormatterExtensions.Format(System.Object,Gallio.Runtime.Formatting.IFormatter)">
-            <summary>
-            Formats an object using the specified <see cref="T:Gallio.Runtime.Formatting.IFormatter"/>.
-            </summary>
-            <param name="obj">The object to format.</param>
-            <param name="formatter">The formatter to use, or null for the default.</param>
-            <returns>The formatted object.</returns>
-        </member>
-    </members>
-</doc>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Gallio40.dll
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Gallio40.dll b/lib/Gallio.3.2.750/tools/Gallio40.dll
deleted file mode 100644
index cf3aea2..0000000
Binary files a/lib/Gallio.3.2.750/tools/Gallio40.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Gallio40.pdb
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Gallio40.pdb b/lib/Gallio.3.2.750/tools/Gallio40.pdb
deleted file mode 100644
index 71a0b27..0000000
Binary files a/lib/Gallio.3.2.750/tools/Gallio40.pdb and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Gallio40.plugin
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Gallio40.plugin b/lib/Gallio.3.2.750/tools/Gallio40.plugin
deleted file mode 100644
index 2c40c53..0000000
--- a/lib/Gallio.3.2.750/tools/Gallio40.plugin
+++ /dev/null
@@ -1,29 +0,0 @@
-<?xml version="1.0" encoding="utf-8" ?>
-<plugin pluginId="Gallio40"
-        recommendedInstallationPath=""
-        enableCondition="${minFramework:NET40}"
-        xmlns="http://www.gallio.org/">
-  <traits>
-    <name>Gallio Extensions for .Net 4.0</name>
-    <version>3.2.0.0</version>
-    <description>Provides additional Gallio features for use with .Net 4.0.</description>
-    <icon>plugin://Gallio/Resources/Gallio.ico</icon>
-  </traits>
-
-  <dependencies>
-    <dependency pluginId="Gallio35" />
-  </dependencies>
-
-  <files>
-    <file path="Gallio40.plugin" />
-    <file path="Gallio40.dll" />
-    <file path="Gallio40.pdb" />
-    <file path="Gallio40.xml" />
-  </files>
-
-  <assemblies>
-    <assembly fullName="Gallio40, Version=3.2.0.0, Culture=neutral, PublicKeyToken=eb9cfa67ee6ab36e"
-              codeBase="Gallio40.dll"
-              qualifyPartialName="true" />
-  </assemblies>
-</plugin>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Gallio40.xml
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Gallio40.xml b/lib/Gallio.3.2.750/tools/Gallio40.xml
deleted file mode 100644
index 4743b88..0000000
--- a/lib/Gallio.3.2.750/tools/Gallio40.xml
+++ /dev/null
@@ -1,8 +0,0 @@
-<?xml version="1.0"?>
-<doc>
-    <assembly>
-        <name>Gallio40</name>
-    </assembly>
-    <members>
-    </members>
-</doc>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/ICSharpCode.TextEditor.dll
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/ICSharpCode.TextEditor.dll b/lib/Gallio.3.2.750/tools/ICSharpCode.TextEditor.dll
deleted file mode 100644
index 47aff41..0000000
Binary files a/lib/Gallio.3.2.750/tools/ICSharpCode.TextEditor.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/MbUnit.Compatibility.dll
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/MbUnit.Compatibility.dll b/lib/Gallio.3.2.750/tools/MbUnit.Compatibility.dll
deleted file mode 100644
index 39ae2f7..0000000
Binary files a/lib/Gallio.3.2.750/tools/MbUnit.Compatibility.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/MbUnit.Compatibility.pdb
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/MbUnit.Compatibility.pdb b/lib/Gallio.3.2.750/tools/MbUnit.Compatibility.pdb
deleted file mode 100644
index beabed8..0000000
Binary files a/lib/Gallio.3.2.750/tools/MbUnit.Compatibility.pdb and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/MbUnit.Compatibility.plugin
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/MbUnit.Compatibility.plugin b/lib/Gallio.3.2.750/tools/MbUnit.Compatibility.plugin
deleted file mode 100644
index 45f277f..0000000
--- a/lib/Gallio.3.2.750/tools/MbUnit.Compatibility.plugin
+++ /dev/null
@@ -1,28 +0,0 @@
-<?xml version="1.0" encoding="utf-8" ?>
-<plugin pluginId="MbUnit.Compatibility"
-        recommendedInstallationPath=""
-        xmlns="http://www.gallio.org/">
-  <traits>
-    <name>MbUnit v3 Extensions for Backwards Compatibility</name>
-    <version>3.2.0.0</version>
-    <description>Provides extensions for MbUnit v3 to assist with test migration from MbUnit v2.</description>
-    <icon>plugin://MbUnit/Resources/MbUnit.ico</icon>
-  </traits>
-
-  <dependencies>
-    <dependency pluginId="Gallio" />
-  </dependencies>
-
-  <files>
-    <file path="MbUnit.Compatibility.plugin" />
-    <file path="MbUnit.Compatibility.dll" />
-    <file path="MbUnit.Compatibility.pdb" />
-    <file path="MbUnit.Compatibility.xml" />
-  </files>
-
-  <assemblies>
-    <assembly fullName="MbUnit.Compatibility, Version=3.2.0.0, Culture=neutral, PublicKeyToken=eb9cfa67ee6ab36e"
-              codeBase="MbUnit.Compatibility.dll"
-              qualifyPartialName="true" />
-  </assemblies>
-</plugin>
\ No newline at end of file


[14/51] [abbrv] [partial] Cleaning up and getting ready to development towards v4.8

Posted by sy...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/teardown.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/teardown.html b/lib/NUnit.org/NUnit/2.5.9/doc/teardown.html
deleted file mode 100644
index b75402c..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/teardown.html
+++ /dev/null
@@ -1,239 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - Teardown</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<script language="JavaScript" src="codeFuncs.js" ></script> <!-- Do it this way for IE -->
-
-<h3>TearDownAttribute (NUnit 2.0 / 2.5)</h3>
-
-<p>This attribute is used inside a TestFixture to provide a common set of 
-	functions that are performed after each test method is run.  
-    
-<p><b>Before NUnit 2.5</b>, a TestFixture could have only one TearDown method
-	and it was required to be an instance method. 
-	
-<p><b>Beginning with NUnit 2.5</b>, TearDown methods may be either static or
-   instance methods and you may define more than one of them in a fixture.
-   Normally, multiple TearDown methods are only defined at different levels
-   of an inheritance hierarchy, as explained below.
-
-<p>So long as any SetUp method runs without error, the TearDown method is 
-   guaranteed to run. It will not run if a SetUp method fails or throws an 
-   exception.</p>
-
-<h4>Example:</h4>
-
-<div class="code">
-
-<div class="langFilter">
-	<a href="javascript:Show('DD1')" onmouseover="Show('DD1')"><img src="img/langFilter.gif" width="14" height="14" alt="Language Filter"></a>
-	<div id="DD1" class="dropdown" style="display: none" onclick="Hide('DD1')">
-		<a href="javascript:ShowCS()">C#</a><br>
-		<a href="javascript:ShowVB()">VB</a><br>
-		<a href="javascript:ShowMC()">C++</a><br>
-		<a href="javascript:ShowJS()">J#</a><br>
-	</div>
-</div>
-
-<pre class="cs">namespace NUnit.Tests
-{
-  using System;
-  using NUnit.Framework;
-
-  [TestFixture]
-  public class SuccessTests
-  {
-    [SetUp] public void Init()
-    { /* ... */ }
-
-    [TearDown] public void Cleanup()
-    { /* ... */ }
-
-    [Test] public void Add()
-    { /* ... */ }
-  }
-}
-</pre>
-
-<pre class="vb">Imports System
-Imports Nunit.Framework
-
-Namespace Nunit.Tests
-
-  &lt;TestFixture()&gt; Public Class SuccessTests
-    &lt;SetUp()&gt; Public Sub Init()
-    ' ...
-    End Sub
-
-    &lt;TearDown()&gt; Public Sub Cleanup()
-    ' ...
-    End Sub
-
-    &lt;Test()&gt; Public Sub Add()
-    ' ...
-    End Sub
-  End Class
-End Namespace
-</pre>
-
-<pre class="mc">#using &lt;Nunit.Framework.dll&gt;
-using namespace System;
-using namespace NUnit::Framework;
-
-namespace NUnitTests
-{
-  [TestFixture]
-  public __gc class SuccessTests
-  {
-    [SetUp] void Init();
-    [TearDown] void Cleanup();
-
-    [Test] void Add();
-  };
-}
-
-#include "cppsample.h"
-
-namespace NUnitTests {
-  // ...
-}
-</pre>
-
-<pre class="js">package NUnit.Tests;
-
-import System.*;
-import NUnit.Framework.TestFixture;
-
-
-/** @attribute NUnit.Framework.TestFixture() */
-public class SuccessTests
-{
-  /** @attribute NUnit.Framework.SetUp() */
-  public void Init()
-  { /* ... */ }
-
-  /** @attribute NUnit.Framework.TearDown() */
-  public void Cleanup()
-  { /* ... */ }
-
-  /** @attribute NUnit.Framework.Test() */
-  public void Add()
-  { /* ... */ }
-}
-</pre>
-
-</div>
-
-<h3>Inheritance</h3>
-
-<p>The TearDown attribute is inherited from any base class. Therefore, if a base 
-	class has defined a TearDown method, that method will be called 
-	after each test method in the derived class. 
-	
-<p>Before NUnit 2.5, you were permitted only one TearDown method. If you wanted to 
-   have some TearDown functionality in the base class and add more in the derived 
-   class you needed to call the base class method yourself.
-	
-<p>With NUnit 2.5, you can achieve the same result by defining a TearDown method
-   in the base class and another in the derived class. NUnit will call base
-   class TearDown methods after those in the derived classes.
-   
-<p><b>Note:</b> Although it is possible to define multiple TearDown methods
-   in the same class, you should rarely do so. Unlike methods defined in
-   separate classes in the inheritance hierarchy, the order in which they
-   are executed is not guaranteed.
-
-<h4>See also...</h4>
-<ul>
-<li><a href="setup.html">SetUpAttribute</a><li><a href="fixtureSetup.html">TestFixtureSetUpAttribute</a><li><a href="fixtureTeardown.html">TestFixtureTearDownAttribute</a></ul>
-
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<ul>
-<li><a href="category.html">Category</a></li>
-<li><a href="combinatorial.html">Combinatorial</a></li>
-<li><a href="culture.html">Culture</a></li>
-<li><a href="datapoint.html">Datapoint(s)</a></li>
-<li><a href="description.html">Description</a></li>
-<li><a href="exception.html">Exception</a></li>
-<li><a href="explicit.html">Explicit</a></li>
-<li><a href="ignore.html">Ignore</a></li>
-<li><a href="maxtime.html">Maxtime</a></li>
-<li><a href="pairwise.html">Pairwise</a></li>
-<li><a href="platform.html">Platform</a></li>
-<li><a href="property.html">Property</a></li>
-<li><a href="random.html">Random</a></li>
-<li><a href="range.html">Range</a></li>
-<li><a href="repeat.html">Repeat</a></li>
-<li><a href="requiredAddin.html">RequiredAddin</a></li>
-<li><a href="requiresMTA.html">Requires&nbsp;MTA</a></li>
-<li><a href="requiresSTA.html">Requires&nbsp;STA</a></li>
-<li><a href="requiresThread.html">Requires&nbsp;Thread</a></li>
-<li><a href="sequential.html">Sequential</a></li>
-<li><a href="setCulture.html">SetCulture</a></li>
-<li><a href="setup.html">Setup</a></li>
-<li><a href="setupFixture.html">SetupFixture</a></li>
-<li><a href="suite.html">Suite</a></li>
-<li id="current"><a href="teardown.html">Teardown</a></li>
-<li><a href="test.html">Test</a></li>
-<li><a href="testCase.html">TestCase</a></li>
-<li><a href="testCaseSource.html">TestCaseSource</a></li>
-<li><a href="testFixture.html">TestFixture</a></li>
-<li><a href="fixtureSetup.html">TestFixtureSetUp</a></li>
-<li><a href="fixtureTeardown.html">TestFixtureTearDown</a></li>
-<li><a href="theory.html">Theory</a></li>
-<li><a href="timeout.html">Timeout</a></li>
-<li><a href="values.html">Values</a></li>
-<li><a href="valueSource.html">ValueSource</a></li>
-</ul>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/test.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/test.html b/lib/NUnit.org/NUnit/2.5.9/doc/test.html
deleted file mode 100644
index f27dd28..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/test.html
+++ /dev/null
@@ -1,215 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - Test</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<script language="JavaScript" src="codeFuncs.js" ></script> <!-- Do it this way for IE -->
-
-<h3>TestAttribute (NUnit 2.0 / 2.5)</h3>
-
-<p>The Test attribute is one way of marking a method inside a TestFixture class
-    as a test. For backwards compatibility with previous versions of Nunit a 
-	test method may also be found if the first 4 letters are &quot;test&quot; 
-	regardless of case. This option is available by setting a value in
-	the config file for the test.</p>
-	
-<p>Prior to NUnit 2.5, the signature for a test method was:
-	<pre>        public void MethodName()</pre></p>
-	
-<p>Beginning with NUnit 2.5, static methods may be used as tests:
-	<pre>        public static void MethodName()</pre></p>
-	
-<p>In addition, with 2.5, test methods may have arguments and return
-   values, provided that NUnit is told what values to use for the
-   arguments and how to handle the return value. For more information
-   on these capabilities, see 
-   <a href="parameterizedTests.html">Parameterized Tests</a>   as well as some of the related attributes
-   listed at the end of this page.
-   
-<p>Parameterized test methods may also be generic, provided that 
-   NUnit is able to deduce the proper argument types from the
-   types of the data arguments supplied.
-	
-<p>If the programmer marks a test method that does not have the correct signature 
-   it will be considered as not runnable and be indicated as such by the console
-   or gui runner. In the Gui, such tests are marked in red.</p> 
-
-<p>In the examples on this page, NUnit would have no way of knowing what values 
-   to supply as arguments, so methods without parameters are used.
-   
-<h4>Example:</h4>
-
-<div class="code">
-
-<div class="langFilter">
-	<a href="javascript:Show('DD1')" onmouseover="Show('DD1')"><img src="img/langFilter.gif" width="14" height="14" alt="Language Filter"></a>
-	<div id="DD1" class="dropdown" style="display: none;" onclick="Hide('DD1')">
-		<a href="javascript:ShowCS()">C#</a><br>
-		<a href="javascript:ShowVB()">VB</a><br>
-		<a href="javascript:ShowMC()">C++</a><br>
-		<a href="javascript:ShowJS()">J#</a><br>
-	</div>
-</div>
-
-<pre class="cs">namespace NUnit.Tests
-{
-  using System;
-  using NUnit.Framework;
-
-  [TestFixture]
-  public class SuccessTests
-  {
-    [Test] public void Add()
-    { /* ... */ }
-
-    public void TestSubtract()
-    { /* backwards compatibility */ }
-  }
-}
-</pre>
-
-<pre class="vb">Imports System
-Imports Nunit.Framework
-
-Namespace Nunit.Tests
-
-  &lt;TestFixture()&gt; Public Class SuccessTests
-    &lt;Test()&gt; Public Sub Add()
-    ' ...
-    End Sub
-  End Class
-End Namespace
-</pre>
-
-<pre class="mc">#using &lt;Nunit.Framework.dll&gt;
-using namespace System;
-using namespace NUnit::Framework;
-
-namespace NUnitTests
-{
-  [TestFixture]
-  public __gc class SuccessTests
-  {
-    [Test] void Add();
-  };
-}
-
-#include "cppsample.h"
-
-namespace NUnitTests {
-  // ...
-}
-</pre>
-
-<pre class="js">package NUnit.Tests;
-
-import System.*;
-import NUnit.Framework.TestFixture;
-
-
-/** @attribute NUnit.Framework.TestFixture() */
-public class SuccessTests
-{
-  /** @attribute NUnit.Framework.Test() */
-  public void Add()
-  { /* ... */ }
-}
-</pre>
-</div>
-
-<h4>See also...</h4>
-
-<ul>
-<li><a href="parameterizedTests.html">Parameterized Tests</a><li><a href="testCase.html">TestCaseAttribute</a></ul>
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<ul>
-<li><a href="category.html">Category</a></li>
-<li><a href="combinatorial.html">Combinatorial</a></li>
-<li><a href="culture.html">Culture</a></li>
-<li><a href="datapoint.html">Datapoint(s)</a></li>
-<li><a href="description.html">Description</a></li>
-<li><a href="exception.html">Exception</a></li>
-<li><a href="explicit.html">Explicit</a></li>
-<li><a href="ignore.html">Ignore</a></li>
-<li><a href="maxtime.html">Maxtime</a></li>
-<li><a href="pairwise.html">Pairwise</a></li>
-<li><a href="platform.html">Platform</a></li>
-<li><a href="property.html">Property</a></li>
-<li><a href="random.html">Random</a></li>
-<li><a href="range.html">Range</a></li>
-<li><a href="repeat.html">Repeat</a></li>
-<li><a href="requiredAddin.html">RequiredAddin</a></li>
-<li><a href="requiresMTA.html">Requires&nbsp;MTA</a></li>
-<li><a href="requiresSTA.html">Requires&nbsp;STA</a></li>
-<li><a href="requiresThread.html">Requires&nbsp;Thread</a></li>
-<li><a href="sequential.html">Sequential</a></li>
-<li><a href="setCulture.html">SetCulture</a></li>
-<li><a href="setup.html">Setup</a></li>
-<li><a href="setupFixture.html">SetupFixture</a></li>
-<li><a href="suite.html">Suite</a></li>
-<li><a href="teardown.html">Teardown</a></li>
-<li id="current"><a href="test.html">Test</a></li>
-<ul>
-<li><a href="parameterizedTests.html">Parameterized&nbsp;Tests</a></li>
-</ul>
-<li><a href="testCase.html">TestCase</a></li>
-<li><a href="testCaseSource.html">TestCaseSource</a></li>
-<li><a href="testFixture.html">TestFixture</a></li>
-<li><a href="fixtureSetup.html">TestFixtureSetUp</a></li>
-<li><a href="fixtureTeardown.html">TestFixtureTearDown</a></li>
-<li><a href="theory.html">Theory</a></li>
-<li><a href="timeout.html">Timeout</a></li>
-<li><a href="values.html">Values</a></li>
-<li><a href="valueSource.html">ValueSource</a></li>
-</ul>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/testCase.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/testCase.html b/lib/NUnit.org/NUnit/2.5.9/doc/testCase.html
deleted file mode 100644
index 29e7e58..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/testCase.html
+++ /dev/null
@@ -1,180 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - TestCase</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<script language="JavaScript" src="codeFuncs.js" ></script> <!-- Do it this way for IE -->
-
-<h3>TestCaseAttribute (NUnit 2.5)</h3>
-
-<p><b>TestCaseAttribute</b> serves the dual purpose of marking a method with
-   parameters as a test method and providing inline data to be used when
-   invoking that method. Here is an example of a test being run three
-   times, with three different sets of data:
-   
-<div class="code">
-<pre>[TestCase(12,3,4)]
-[TestCase(12,2,6)]
-[TestCase(12,4,3)]
-public void DivideTest(int n, int d, int q)
-{
-  Assert.AreEqual( q, n / d );
-}
-</pre>
-</div>
-
-<p><b>Note:</b> Because arguments to .NET attributes are limited in terms of the 
-Types that may be used, NUnit will make some attempt to convert the supplied
-values using <b>Convert.ChangeType()</b> before supplying it to the test.
-
-<p><b>TestCaseAttribute</b> may appear one or more times on a test method,
-which may also carry other attributes providing test data, such as the
-<a href="factories.html">FactoriesAttribute</a>.
-The method may optionally be marked with the 
-<a href="test.html">TestAttribute</a> as well.
-
-<p>By using the named parameter <b>Result</b> this test set may be simplified
-further:
-
-<div class="code">
-<pre>[TestCase(12,3, Result=4)]
-[TestCase(12,2, Result=6)]
-[TestCase(12,4, Result=3)]
-public int DivideTest(int n, int d)
-{
-  return( n / d );
-}
-</pre>
-</div>
-
-<p>In the above example, NUnit checks that the return
-value of the method is equal to the expected result provided on the attribut
-
-<p><b>TestCaseAttribute</b> supports a number of additional 
-named parameters, which may be used as follows:
-
-<dl>
-<dt><b>Description</b>
-<dd>Sets the description property of the test
-<dt><b>ExpectedException</b>
-<dd>Specifies a the Type of an exception that should be thrown by this invocation
-<dt><b>ExpectedExceptionName</b>
-<dd>Specifies a the FullName of an exception that should be thrown by this invocation
-<dt><b>ExpectedMessage</b>
-<dd>Specifies the message text of the expected exception
-<dt><b>MatchType</b>
-<dd>A <b>MessageMatch</b> enum value indicating how to test the expected message 
-(See <a href="exception.html">ExpectedExceptionAttribute</a>)
-<dt><b>Result</b>
-<dd>The expected result to be returned from the method, which must have
-a compatible return type.
-<dt><b>TestName</b>
-<dd>Provides a name for the test. If not specified, a name is generated based on 
-the method name and the arguments provided.
-<dt><b>Ignore</b>
-<dd>Set to true in order to ignore the individual test case.
-<dt><b>IgnoreReason</b>
-<dd>Specifies the reason for ignoring this test case. If set to a non-empty
-    string, then Ignore is assumed to be true.
-</dl>
-
-<h3>Order of Execution</h3>
-
-<p>In NUnit 2.5, individual test cases are sorted alphabetically and executed in
-   that order. With NUnit 2.5.1, the individual cases are not sorted, but are
-   executed in the order in which NUnit discovers them. This order does <b>not</b>
-   follow the lexical order of the attributes and will often vary between different
-   compilers or different versions of the CLR.
-   
-<p>As a result, when <b>TestCaseAttribute</b> appears multiple times on a method
-   or when other data-providing attributes are used in combination with 
-   <b>TestCaseAttribute</b>, the order of the test cases is undefined.
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<ul>
-<li><a href="category.html">Category</a></li>
-<li><a href="combinatorial.html">Combinatorial</a></li>
-<li><a href="culture.html">Culture</a></li>
-<li><a href="datapoint.html">Datapoint(s)</a></li>
-<li><a href="description.html">Description</a></li>
-<li><a href="exception.html">Exception</a></li>
-<li><a href="explicit.html">Explicit</a></li>
-<li><a href="ignore.html">Ignore</a></li>
-<li><a href="maxtime.html">Maxtime</a></li>
-<li><a href="pairwise.html">Pairwise</a></li>
-<li><a href="platform.html">Platform</a></li>
-<li><a href="property.html">Property</a></li>
-<li><a href="random.html">Random</a></li>
-<li><a href="range.html">Range</a></li>
-<li><a href="repeat.html">Repeat</a></li>
-<li><a href="requiredAddin.html">RequiredAddin</a></li>
-<li><a href="requiresMTA.html">Requires&nbsp;MTA</a></li>
-<li><a href="requiresSTA.html">Requires&nbsp;STA</a></li>
-<li><a href="requiresThread.html">Requires&nbsp;Thread</a></li>
-<li><a href="sequential.html">Sequential</a></li>
-<li><a href="setCulture.html">SetCulture</a></li>
-<li><a href="setup.html">Setup</a></li>
-<li><a href="setupFixture.html">SetupFixture</a></li>
-<li><a href="suite.html">Suite</a></li>
-<li><a href="teardown.html">Teardown</a></li>
-<li><a href="test.html">Test</a></li>
-<li id="current"><a href="testCase.html">TestCase</a></li>
-<li><a href="testCaseSource.html">TestCaseSource</a></li>
-<li><a href="testFixture.html">TestFixture</a></li>
-<li><a href="fixtureSetup.html">TestFixtureSetUp</a></li>
-<li><a href="fixtureTeardown.html">TestFixtureTearDown</a></li>
-<li><a href="theory.html">Theory</a></li>
-<li><a href="timeout.html">Timeout</a></li>
-<li><a href="values.html">Values</a></li>
-<li><a href="valueSource.html">ValueSource</a></li>
-</ul>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/testCaseSource.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/testCaseSource.html b/lib/NUnit.org/NUnit/2.5.9/doc/testCaseSource.html
deleted file mode 100644
index dca0f9a..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/testCaseSource.html
+++ /dev/null
@@ -1,325 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - TestCaseSource</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<script language="JavaScript" src="codeFuncs.js" ></script> <!-- Do it this way for IE -->
-
-<h3>TestCaseSourceAttribute (NUnit 2.5)</h3>
-
-<p><b>TestCaseSourceAttribute</b> is used on a parameterized test method to
-identify the property, method or field that will provide the required 
-arguments. The attribute has two public constructors.
-
-<div class="code">
-<pre>
-TestCaseSourceAttribute(Type sourceType, string sourceName);
-TestCaseSourceAttribute(string sourceName);
-</pre>
-</div>
-
-<p>If <b>sourceType</b> is specified, it represents the class that provides
-the test cases. It must have a default constructor.
-
-<p>If <b>sourceType</b> is not specified, the class containing the test
-method is used. NUnit will construct it using either the default constructor
-or - if arguments are provided - the appropriate constructor for those 
-arguments.
-
-<p>The <b>sourceName</b> argument represents the name of the source used
-to provide test cases. It has the following characteristics:
-<ul>
-<li>It may be a field, property or method.
-<li>It may be either an instance or a static member.
-<li>It must return an IEnumerable or a type that implements IEnumerable.
-<li>The individual items returned by the enumerator must be compatible
-    with the signature of the method on which the attribute appears.
-	The rules for this are described in the next section.
-</ul>
-
-<h3>Constructing Test Cases</h3>
-
-<p>In constructing tests, NUnit uses each item returned by
-the enumerator as follows:
-<ol>
-
-<li><p>If it is an object implementing <b>NUnit.Framework.ITestCaseData</b>, 
-its properties are used to provide the test case. In NUnit 2.5, this is
-done using reflection to allow compatibility with earlier versions that
-did not implement <b>ITestCaseData</b>.
-
-<p>The following public fields or properties are used:
-  <p><dl>
-  <dt><b>Arguments</b>
-  <dd>An <b>object[]</b> representing the arguments to the method
-  <dt><b>Categories</b>
-  <dd>An IList of categories to be applied to the test case.
-  <dt><b>Description</b>
-  <dd>Sets the description property of the test
-  <dt><b>ExpectedException</b>
-  <dd>Specifies a the Type of an exception that should be thrown by this invocation
-  <dt><b>ExpectedExceptionName</b>
-  <dd>Specifies a the FullName of an exception that should be thrown by this invocation
-  <dt><b>Properties</b>
-  <dd>An IDictionary of properties to be applied to the test case.
-      Note that the values provided must be compatible with PropertiesAttribute.
-	  In particular, use of custom types or enums will cause problems.
-  <dt><b>Result</b>
-  <dd>The expected result to be returned from the method, which must have
-      a compatible return type.
-  <dt><b>TestName</b>
-  <dd>Provides a name for the test. If not specified, a name is generated based on 
-      the method name and the arguments provided
-  <dt><b>Ignored</b>
-  <dd>If true, the test case is ignored.
-  <dt><b>IgnoreReason</b>
-  <dd>Specifies the reason for ignoring this test case. If set to a non-empty
-      string, then the test is ignored.
-  </dl>
-
-<p>
-<li><p>If the test has a single argument and the returned value matches the type of
-that argument it is used directly.
-
-<li><p>If it is an <b>object[]</b>, its members are used to provide
-the arguments for the method, as in this example, which returns
-arguments from a named static field.
-
-<div class="code">
-<pre>[Test, TestCaseSource("DivideCases")]
-public void DivideTest(int n, int d, int q)
-{
-    Assert.AreEqual( q, n / d );
-}
-
-static object[] DivideCases =
-{
-    new object[] { 12, 3, 4 },
-    new object[] { 12, 2, 6 },
-    new object[] { 12, 4, 3 } 
-};
-</pre></div>
-
-<li><p>If it is an array of some other type, NUnit can use it provided
-that the arguments to the method are all of that type. For example,
-the above code could be modified to make the three nested arrays 
-of type int[].
-
-<li><p>If anything else is returned, it is used directly as the sole 
-argument to the method. This allows NUnit to give an error message
-in cases where the method requires a different number arguments or
-an argument of a different type.
-This can also eliminate a bit of extra typing by the programmer, 
-as in this example:
-
-<div class="code"><pre>
-static int[] EvenNumbers = new int[] { 2, 4, 6, 8 };
-
-[Test, TestCaseSource("EvenNumbers")]
-public void TestMethod(int num)
-{
-    Assert.IsTrue( num % 2 == 0 );
-}
-</pre></div>
-
-</ol>
-
-<h3>TestCaseData Class</h3>
-
-<p>Although any object implementing <b>ITestCaseData</b> may be used to
-   provide extended test case information, NUnit provides the <b>TestCaseData</b> 
-   class for this purpose. The following    example returns <b>TestCaseData</b> 
-   instances from a data source in a separately defined class.
-
-<div class="code">
-<pre>[TestFixture]
-public class MyTests
-{
-  [Test,TestCaseSource(typeof(MyFactoryClass),"TestCases")]
-  public int DivideTest(int n, int d)
-  {
-    return n/d;
-  }
-	
-  ...
-}
-
-public class MyFactoryClass
-{
-  public static IEnumerable TestCases
-  {
-    get
-    {
-      yield return new TestCaseData( 12, 3 ).Returns( 4 );
-      yield return new TestCaseData( 12, 2 ).Returns( 6 );
-      yield return new TestCaseData( 12, 4 ).Returns( 3 );
-      yield return new TestCaseData( 0, 0 )
-        .Throws(typeof(DivideByZeroException))
-        .SetName("DivideByZero")
-        .SetDescription("An exception is expected");
-    }
-  }  
-}
-</div>
-
-<p>This example uses the fluent interface supported by <b>TestCaseData</b>
-to make the program more readable. The last yield statement above  is equivalent to
-
-<div class="code"><pre>
-      TestCaseData data = new TestCaseData(0,0);
-      data.ExpectedException = typeof(DivideByZeroException;
-      data.TestName = "DivideByZero";
-      data.Description = "An exception is expected";
-      yield return data;
-</pre>
-</div> 
-
-<p><b>TestCaseData</b> supports the following properties
-and methods, which may be appended to an instance in any order.
-
-<p>
-<dl>
-  <dt><b>.Returns</b>
-  <dd>The expected result to be returned from the method, which must have
-      a compatible return type.
-  <dt><b>.SetCategory(string)</b>
-  <dd>Applies a category to the test
-  <dt><b>.SetProperty(string, string)</b>
-  <dt><b>.SetProperty(string, int)</b>
-  <dt><b>.SetProperty(string, double)</b>
-  <dd>Applies a named property and value to the test
-  <dt><b>.SetDescription(string)</b>
-  <dd>Sets the description property of the test
-  <dt><b>.SetName(string)</b>
-  <dd>Provides a name for the test. If not specified, a name is generated based on 
-      the method name and the arguments provided
-  <dt><b>.Throws(Type)</b>
-  <dt><b>.Throws(string)</b>
-  <dd>Specifies a the Type or FullName of an exception that should be thrown by this invocation
-  <dt><b>.Ignore()</b>
-  <dd>Causes the test case to be ignored.
-  <dt><b>.Ignore(string)</b>
-  <dd>Causes the test case to be ignored with a reason specified.
-</dl>
-
-<h3>Order of Execution</h3>
-
-<p>In NUnit 2.5, individual test cases are sorted alphabetically and executed in
-   that order. With NUnit 2.5.1, the individual cases are not sorted, but are
-   executed in the order in which NUnit discovers them. This order does <b>not</b>
-   follow the lexical order of the attributes and will often vary between different
-   compilers or different versions of the CLR.
-   
-<p>As a result, when <b>TestCaseSourceAttribute</b> appears multiple times on a 
-   method or when other data-providing attributes are used in combination with 
-   <b>TestCaseSourceAttribute</b>, the order of the test cases is undefined.
-
-<p>However, when a single <b>TestCaseSourceAttribute</b> is used by itself, 
-   the order of the tests follows exactly the order in which the test cases 
-   are returned from the source.
-   
-<h3>Note on Object Construction</h3>
-
-<p>NUnit locates the test cases at the time the tests are loaded, creates
-instances of each class with non-static sources and builds a list of 
-tests to be executed. Each source object is only created once at this
-time and is destroyed after all tests are loaded. 
-
-<p>If the data source is in the test fixture itself, the object is created
-using the appropriate constructor for the fixture parameters provided on
-the <b>TestFixtureAttribute</b> or
-the default constructor if no parameters were specified. Since this object
-is destroyed before the tests are run, no communication is possible between
-these two phases - or between different runs - except through the parameters
-themselves.
-
-   
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<ul>
-<li><a href="category.html">Category</a></li>
-<li><a href="combinatorial.html">Combinatorial</a></li>
-<li><a href="culture.html">Culture</a></li>
-<li><a href="datapoint.html">Datapoint(s)</a></li>
-<li><a href="description.html">Description</a></li>
-<li><a href="exception.html">Exception</a></li>
-<li><a href="explicit.html">Explicit</a></li>
-<li><a href="ignore.html">Ignore</a></li>
-<li><a href="maxtime.html">Maxtime</a></li>
-<li><a href="pairwise.html">Pairwise</a></li>
-<li><a href="platform.html">Platform</a></li>
-<li><a href="property.html">Property</a></li>
-<li><a href="random.html">Random</a></li>
-<li><a href="range.html">Range</a></li>
-<li><a href="repeat.html">Repeat</a></li>
-<li><a href="requiredAddin.html">RequiredAddin</a></li>
-<li><a href="requiresMTA.html">Requires&nbsp;MTA</a></li>
-<li><a href="requiresSTA.html">Requires&nbsp;STA</a></li>
-<li><a href="requiresThread.html">Requires&nbsp;Thread</a></li>
-<li><a href="sequential.html">Sequential</a></li>
-<li><a href="setCulture.html">SetCulture</a></li>
-<li><a href="setup.html">Setup</a></li>
-<li><a href="setupFixture.html">SetupFixture</a></li>
-<li><a href="suite.html">Suite</a></li>
-<li><a href="teardown.html">Teardown</a></li>
-<li><a href="test.html">Test</a></li>
-<li><a href="testCase.html">TestCase</a></li>
-<li id="current"><a href="testCaseSource.html">TestCaseSource</a></li>
-<li><a href="testFixture.html">TestFixture</a></li>
-<li><a href="fixtureSetup.html">TestFixtureSetUp</a></li>
-<li><a href="fixtureTeardown.html">TestFixtureTearDown</a></li>
-<li><a href="theory.html">Theory</a></li>
-<li><a href="timeout.html">Timeout</a></li>
-<li><a href="values.html">Values</a></li>
-<li><a href="valueSource.html">ValueSource</a></li>
-</ul>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/testDecorators.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/testDecorators.html b/lib/NUnit.org/NUnit/2.5.9/doc/testDecorators.html
deleted file mode 100644
index 7194087..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/testDecorators.html
+++ /dev/null
@@ -1,112 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - TestDecorators</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h3>TestDecorators (NUnit 2.4)</h3>
-
-<h4>Purpose</h4>
-<p>TestDecorators are able to modify a test after it has been constructed.
-
-<h4>Extension Point</h4>
-<p>Addins use the host to access this extension point by name:
-
-<pre>
-	IExtensionPoint testDecorators = host.GetExtensionPoint( "TestDecorators" );</pre>
-
-<h4>Interface</h4>
-<p>The extension object passed to Install must implement the ITestDecorator interface:
-
-<pre>
-	public interface ITestDecorator
-	{
-		Test Decorate( Test test, MemberInfo member );
-	}
-</pre>
-
-<p>The Decorate method may do several things, depending on what it needs
-to accomplish:
-<ol>
-  <li>Return test unmodified
-  <li>Modify properties of the test object and return it
-  <li>Replace test with another object, either discarding the
-  original or aggregating it in the new test.
-</ol>
-
-<p>Depending on what the decorator does, it may need to run
-ahead of other decorators or after them. Decorators should
-be installed using the Install method overload that takes
-a priority. The priorities range from 1 to 9 and decorators
-with lower priority values are installed first. The following
-standard values are defined for use if desired:
-<ul>
-<li>DecoratorPriority.Default = 0
-<li>DecoratorPriority.First = 1
-<li>DecoratorPriority.Normal = 5
-<li>DecoratorPriority.Last = 9
-</ul>
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<ul>
-<li><a href="customConstraints.html">Custom&nbsp;Constraints</a></li>
-<li><a href="nunitAddins.html">NUnit&nbsp;Addins</a></li>
-<ul>
-<li><a href="suiteBuilders.html">SuiteBuilders</a></li>
-<li><a href="testcaseBuilders.html">TestcaseBuilders</a></li>
-<li id="current"><a href="testDecorators.html">TestDecorators</a></li>
-<li><a href="testcaseProviders.html">TestcaseProviders</a></li>
-<li><a href="datapointProviders.html">DatapointProviders</a></li>
-<li><a href="eventListeners.html">EventListeners</a></li>
-</ul>
-<li><a href="extensionTips.html">Tips&nbsp;for&nbsp;Extenders</a></li>
-</ul>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/testFixture.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/testFixture.html b/lib/NUnit.org/NUnit/2.5.9/doc/testFixture.html
deleted file mode 100644
index 07c1ff5..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/testFixture.html
+++ /dev/null
@@ -1,413 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - TestFixture</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<script language="JavaScript" src="codeFuncs.js" ></script> <!-- Do it this way for IE -->
-
-<h3>TestFixtureAttribute (NUnit 2.0 / 2.5)</h3>
-
-<p>This is the attribute that marks a class that contains tests and, optionally, 
-	setup or teardown methods. NUnit 2.5 introduces parameterized and generic
-	test fixtures - see below.</p>
-	
-<p>Most restrictions on a class that is used as a test fixture have now been
-   eliminated. As of NUnit 2.5.3, a test fixture class:
-	<ul>
-		<li>May be public, protected, private or internal.
-		<li>May be a static class in .NET 2.0 or later.
-		<li>May be generic, so long as any type parameters are provided or
-		    can be inferred from the actual arguments.
-		<li>May not be abstract - although the attribute may be applied to an
-		    abstract class intended to serve as a base class for test fixtures.
-		<li>If no arguments are provided with the TestFixtureAttribute, the class
-		     must have a default constructor. 
-		<li>If arguments are provided, they must match one of the constructors.
-	</ul>
-</p>
-
-<p>If any of these restrictions are violated, the class is not runnable
-   as a test and will display as an error.</p>
-
-<p>It is advisable that the constructor not have any side effects, 
-   since NUnit may construct the object multiple times in the course of a session.</li>
-
-<p>Beginning with NUnit 2.5, the <b>TestFixture</b> attribute is optional
-   for non-parameterized, non-generic fixtures. So long as the class contains
-   at least one method marked with the <b>Test</b>, <b>TestCase</b> or 
-   <b>TestCaseSource</b> attribute, it will be treated as a test fixture.
-
-<h4>Example:</h4>
-
-<div class="code">
-
-<div class="langFilter">
-	<a href="javascript:Show('DD1')" onmouseover="Show('DD1')"><img src="img/langFilter.gif" width="14" height="14" alt="Language Filter"></a>
-	<div id="DD1" class="dropdown" style="display: none;" onclick="Hide('DD1')">
-		<a href="javascript:ShowCS()">C#</a><br>
-		<a href="javascript:ShowVB()">VB</a><br>
-		<a href="javascript:ShowMC()">C++</a><br>
-		<a href="javascript:ShowJS()">J#</a><br>
-	</div>
-</div>
-
-<pre class="cs">namespace NUnit.Tests
-{
-  using System;
-  using NUnit.Framework;
-
-  [TestFixture]
-  public class SuccessTests
-  {
-    // ...
-  }
-}
-</pre>
-
-<pre class="vb">Imports System
-Imports Nunit.Framework
-
-Namespace Nunit.Tests
-
-  &lt;TestFixture()&gt; Public Class SuccessTests
-    ' ...
-  End Class
-End Namespace
-</pre>
-
-<pre class="mc">#using &lt;Nunit.Framework.dll&gt;
-using namespace System;
-using namespace NUnit::Framework;
-
-namespace NUnitTests
-{
-  [TestFixture]
-  public __gc class SuccessTests
-  {
-    // ...
-  };
-}
-
-#include "cppsample.h"
-
-namespace NUnitTests {
-  // ...
-}
-</pre>
-
-<pre class="js">package NUnit.Tests;
-
-import System.*;
-import NUnit.Framework.TestFixture;
-
-
-/** @attribute NUnit.Framework.TestFixture() */
-public class SuccessTests
-{
-  // ...
-}
-</pre>
-
-</div>
-
-<h3>Inheritance</h3>
-
-<p>The <b>TestFixtureAttribute</b> may be applied to a base class and is
-inherited by any derived classes. This includes any abstract base class,
-so the well-known Abstract Fixture pattern may be implemented if desired.
-
-<p>In order to facilitate use of generic and/or parameterized classes,
-where the derived class may require a different number of arguments (or
-type arguments) from the base class, any <b>TestFixture</b> attribute on a 
-derived class causes those on the base classes to be ignored. This allows
-use of code like the following:
-
-<div class="code">
-<pre>[TestFixture]
-public class AbstractFixtureBase
-{
-    ...
-}
-
-[TestFixture(typeof(string))]
-public class DerivedFixture&lt;T&gt; : AbstractFixtureBase
-{
-    ...
-}
-</pre>
-</div>
-
-<h3>Parameterized Test Fixtures (NUnit 2.5)</h3>
-
-<p>Beginning with NUnit 2.5, test fixtures may take constructor arguments.
-   Argument values are specified as arguments to the <b>TestFixture</b>
-   attribute. NUnit will construct a separate instance of the fixture
-   for each set of arguments.
-   
-<p>Individual fixture instances in a set of parameterized fixtures may be ignored. 
-   Set the <b>Ignore</b> named parameter of the attribute to true or set 
-   <b>IgnoreReason</b> to a non-empty string.
-   
-<h4>Example</h4>
-
-<p>The following test fixture would be instantiated by NUnit three times,
-   passing in each set of arguments to the appropriate constructor. Note
-   that there are three different constructors, matching the data types
-   provided as arguments.
-   
-<div class="code"><pre>
-[TestFixture("hello", "hello", "goodbye")]
-[TestFixture("zip", "zip")]
-[TestFixture(42, 42, 99)]
-public class ParameterizedTestFixture
-{
-    private string eq1;
-    private string eq2;
-    private string neq;
-    
-    public ParameterizedTestFixture(string eq1, string eq2, string neq)
-    {
-        this.eq1 = eq1;
-        this.eq2 = eq2;
-        this.neq = neq;
-    }
-
-    public ParameterizedTestFixture(string eq1, string eq2)
-        : this(eq1, eq2, null) { }
-
-    public ParameterizedTestFixture(int eq1, int eq2, int neq)
-    {
-        this.eq1 = eq1.ToString();
-        this.eq2 = eq2.ToString();
-        this.neq = neq.ToString();
-    }
-
-    [Test]
-    public void TestEquality()
-    {
-        Assert.AreEqual(eq1, eq2);
-        if (eq1 != null &amp;&amp; eq2 != null)
-            Assert.AreEqual(eq1.GetHashCode(), eq2.GetHashCode());
-    }
-
-    [Test]
-    public void TestInequality()
-    {
-        Assert.AreNotEqual(eq1, neq);
-        if (eq1 != null &amp;&amp; neq != null)
-            Assert.AreNotEqual(eq1.GetHashCode(), neq.GetHashCode());
-    }
-}
-</pre></div>
-
-<h3>Generic Test Fixtures (NUnit 2.5)</h3>
-
-<p>Beginning with NUnit 2.5, you may also use a generic class as a test fixture.
-   In order for NUnit to instantiate the fixture, you must either specify the 
-   types to be used as arguments to <b>TestFixtureAttribute</b> or use the
-   named parameter <b>TypeArgs=</b> to specify them. NUnit will construct a
-   separate instance of the fixture for each <b>TestFixtureAttribute</b> 
-   you provide.
-   
-<h4>Example</h4>
-
-<p>The following test fixture would be instantiated by NUnit twice,
-   once using an ArrayList and once using a List&lt;int&gt;.
-   
-<div class="code"><pre>
-[TestFixture(typeof(ArrayList))]
-[TestFixture(typeof(List&lt;int&gt;))]
-public class IList_Tests&lt;TList&gt; where TList : IList, new()
-{
-  private IList list;
-
-  [SetUp]
-  public void CreateList()
-  {
-    this.list = new TList();
-  }
-
-  [Test]
-  public void CanAddToList()
-  {
-    list.Add(1); list.Add(2); list.Add(3);
-    Assert.AreEqual(3, list.Count);
-  }
-}</pre></div>
-
-<h3>Generic Test Fixtures with Parameters (NUnit 2.5)</h3>
-
-<p>If a Generic fixture, uses constructor arguments, there are three
-   approaches to telling NUnit which arguments are type parameters 
-   and which are normal constructor parameters.
-   <ol>
-   <li>Specify both sets of parameters as arguments to the <b>TestFixtureAttribute</b>.
-       Leading <b>System.Type</b> arguments are used as type parameters, while
-	   any remaining arguments are used to construct the instance. In the
-	   following example, this leads to some obvious duplication...
-
-<div class="code"><pre>
-[TestFixture(typeof(double), typeof(int), 100.0, 42)]
-[TestFixture(typeof(int) typeof(double), 42, 100.0)]
-public class SpecifyBothSetsOfArgs&lt;T1, T2&gt;
-{
-    T1 t1;
-    T2 t2;
-
-    public SpecifyBothSetsOfArgs(T1 t1, T2 t2)
-    {
-        this.t1 = t1;
-        this.t2 = t2;
-    }
-
-    [TestCase(5, 7)]
-    public void TestMyArgTypes(T1 t1, T2 t2)
-    {
-        Assert.That(t1, Is.TypeOf&lt;T1&gt;());
-        Assert.That(t2, Is.TypeOf&lt;T2&gt;());
-    }
-}</pre></div>
-
-   <li>Specify normal parameters as arguments to <b>TestFixtureAttribute</b>
-       and use the named parameter <b>TypeArgs=</b> to specify the type
-	   arguments. Again, for this example, the type info is duplicated, but
-	   it is at least more cleanly separated from the normal arguments...
-
-<div class="code" style="width: 40em"><pre>
-[TestFixture(100.0, 42, TypeArgs=new Type[] {typeof(double), typeof(int) } )]
-[TestFixture(42, 100.0, TypeArgs=new Type[] {typeof(int), typeof(double) } )]
-public class SpecifyTypeArgsSeparately&lt;T1, T2&gt;
-{
-    T1 t1;
-    T2 t2;
-
-    public SpecifyTypeArgsSeparately(T1 t1, T2 t2)
-    {
-        this.t1 = t1;
-        this.t2 = t2;
-    }
-
-    [TestCase(5, 7)]
-    public void TestMyArgTypes(T1 t1, T2 t2)
-    {
-        Assert.That(t1, Is.TypeOf&lt;T1&gt;());
-        Assert.That(t2, Is.TypeOf&lt;T2&gt;());
-    }
-}</pre></div>
-
-   <li>In some cases, when the constructor makes use of all the type parameters 
-       NUnit may simply be able to deduce them from the arguments provided. 
-	   That's the case here and the following is the preferred way to
-	   write this example...
-   
-<div class="code"><pre>
-[TestFixture(100.0, 42)]
-[TestFixture(42, 100.0)]
-public class DeduceTypeArgsFromArgs&lt;T1, T2&gt;
-{
-    T1 t1;
-    T2 t2;
-
-    public DeduceTypeArgsFromArgs(T1 t1, T2 t2)
-    {
-        this.t1 = t1;
-        this.t2 = t2;
-    }
-
-    [TestCase(5, 7)]
-    public void TestMyArgTypes(T1 t1, T2 t2)
-    {
-        Assert.That(t1, Is.TypeOf&lt;T1&gt;());
-        Assert.That(t2, Is.TypeOf&lt;T2&gt;());
-    }
-}</pre></div>
-   </ol> 
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<ul>
-<li><a href="category.html">Category</a></li>
-<li><a href="combinatorial.html">Combinatorial</a></li>
-<li><a href="culture.html">Culture</a></li>
-<li><a href="datapoint.html">Datapoint(s)</a></li>
-<li><a href="description.html">Description</a></li>
-<li><a href="exception.html">Exception</a></li>
-<li><a href="explicit.html">Explicit</a></li>
-<li><a href="ignore.html">Ignore</a></li>
-<li><a href="maxtime.html">Maxtime</a></li>
-<li><a href="pairwise.html">Pairwise</a></li>
-<li><a href="platform.html">Platform</a></li>
-<li><a href="property.html">Property</a></li>
-<li><a href="random.html">Random</a></li>
-<li><a href="range.html">Range</a></li>
-<li><a href="repeat.html">Repeat</a></li>
-<li><a href="requiredAddin.html">RequiredAddin</a></li>
-<li><a href="requiresMTA.html">Requires&nbsp;MTA</a></li>
-<li><a href="requiresSTA.html">Requires&nbsp;STA</a></li>
-<li><a href="requiresThread.html">Requires&nbsp;Thread</a></li>
-<li><a href="sequential.html">Sequential</a></li>
-<li><a href="setCulture.html">SetCulture</a></li>
-<li><a href="setup.html">Setup</a></li>
-<li><a href="setupFixture.html">SetupFixture</a></li>
-<li><a href="suite.html">Suite</a></li>
-<li><a href="teardown.html">Teardown</a></li>
-<li><a href="test.html">Test</a></li>
-<li><a href="testCase.html">TestCase</a></li>
-<li><a href="testCaseSource.html">TestCaseSource</a></li>
-<li id="current"><a href="testFixture.html">TestFixture</a></li>
-<li><a href="fixtureSetup.html">TestFixtureSetUp</a></li>
-<li><a href="fixtureTeardown.html">TestFixtureTearDown</a></li>
-<li><a href="theory.html">Theory</a></li>
-<li><a href="timeout.html">Timeout</a></li>
-<li><a href="values.html">Values</a></li>
-<li><a href="valueSource.html">ValueSource</a></li>
-</ul>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/testProperties.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/testProperties.html b/lib/NUnit.org/NUnit/2.5.9/doc/testProperties.html
deleted file mode 100644
index 0152d91..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/testProperties.html
+++ /dev/null
@@ -1,86 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - TestProperties</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h2>Test Properties Dialog</h2>
-
-<p>The test properties dialog is displayed using either the View | Properties menu item on the main
-menu or the Properties item on the context menu. It shows information about the test and � if it
-has been run � about the results. The dialog contains a �pin� button in the upper right corner,
-which causes it to remain open as the user clicks on different tests.</p>
-
-<div class="screenshot-left">
-   <img src="img/testProperties.jpg"></div>
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<ul>
-<li><a href="nunit-console.html">Console&nbsp;Runner</a></li>
-<li><a href="nunit-gui.html">Gui&nbsp;Runner</a></li>
-<ul>
-<li><a href="guiCommandLine.html">Command-Line</a></li>
-<li><a href="mainMenu.html">Main&nbsp;Menu</a></li>
-<li><a href="contextMenu.html">Context&nbsp;Menu</a></li>
-<li><a href="settingsDialog.html">Settings&nbsp;Dialog</a></li>
-<li><a href="addinsDialog.html">Addins&nbsp;Dialog</a></li>
-<li id="current"><a href="testProperties.html">Test&nbsp;Properties</a></li>
-<li><a href="configEditor.html">Configuration&nbsp;Editor</a></li>
-<li><a href="projectEditor.html">Project&nbsp;Editor</a></li>
-</ul>
-<li><a href="pnunit.html">PNUnit&nbsp;Runner</a></li>
-<li><a href="runtimeSelection.html">Runtime&nbsp;Selection</a></li>
-<li><a href="assemblyIsolation.html">Assembly&nbsp;Isolation</a></li>
-<li><a href="configFiles.html">Configuration&nbsp;Files</a></li>
-<li><a href="multiAssembly.html">Multiple&nbsp;Assemblies</a></li>
-<li><a href="vsSupport.html">Visual&nbsp;Studio&nbsp;Support</a></li>
-</ul>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/testcaseBuilders.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/testcaseBuilders.html b/lib/NUnit.org/NUnit/2.5.9/doc/testcaseBuilders.html
deleted file mode 100644
index fabeec7..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/testcaseBuilders.html
+++ /dev/null
@@ -1,112 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - TestcaseBuilders</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h3>TestCaseBuilders (NUnit 2.4)</h3>
-
-<h4>Purpose</h4>
-<p>TestCaseBuilders create Tests based on a MethodInfo. NUnit uses several
-TestCaseBuilders internally to create various kinds of TestMethods.
-
-<h4>Extension Point</h4>
-Addins use the host to access this extension point by name:
-
-<pre>
-	IExtensionPoint testCaseBuilders = host.GetExtensionPoint( "TestCaseBuilders" );</pre>
-
-<h4>Interfaces</h4>
-<p>The extension object passed to Install must implement either the ITestCaseBuilder 
-or the ITestCaseBuilder2 interface:
-
-<pre>
-	public interface ITestCaseBuilder
-	{
-		bool CanBuildFrom( MethodInfo method );
-		Test BuildFrom( MethodInfo method );
-	}
-
-	public interface ITestCaseBuilder2 : ITestCaseBuilder
-	{
-		bool CanBuildFrom( MethodInfo method, Test suite );
-		Test BuildFrom( MethodInfo method, Test suite );
-	}
-</pre>
-
-<p>NUnit will call ITestCaseBuilder2 if it is available. Otherwise
-ITestCaseBuilder will be used.
-
-<p>The CanBuildFrom method should return true if the addin can build
-a test from the MethodInfo provided. Some TestCaseBuilder addins are only 
-intended to apply to methods within a specific type of fixture. The
-suite argument of the ITestCaseBuilder2 interface may be used to make
-this determination.
-
-<p>The BuildFrom method should return a test constructed over the MethodInfo
-provided as an argument or null if the method cannot be used.
-
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<ul>
-<li><a href="customConstraints.html">Custom&nbsp;Constraints</a></li>
-<li><a href="nunitAddins.html">NUnit&nbsp;Addins</a></li>
-<ul>
-<li><a href="suiteBuilders.html">SuiteBuilders</a></li>
-<li id="current"><a href="testcaseBuilders.html">TestcaseBuilders</a></li>
-<li><a href="testDecorators.html">TestDecorators</a></li>
-<li><a href="testcaseProviders.html">TestcaseProviders</a></li>
-<li><a href="datapointProviders.html">DatapointProviders</a></li>
-<li><a href="eventListeners.html">EventListeners</a></li>
-</ul>
-<li><a href="extensionTips.html">Tips&nbsp;for&nbsp;Extenders</a></li>
-</ul>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/testcaseProviders.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/testcaseProviders.html b/lib/NUnit.org/NUnit/2.5.9/doc/testcaseProviders.html
deleted file mode 100644
index ad29a01..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/testcaseProviders.html
+++ /dev/null
@@ -1,140 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - TestcaseProviders</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h3>TestCaseProviders (NUnit 2.5)</h3>
-
-<h4>Purpose</h4>
-<p>TestCaseProviders are used with parameterized tests to provide the
-specific test cases that will be used in calling the test.
-
-<h4>Extension Point</h4>
-<p>Addins use the host to access this extension point by name:
-
-<pre>
-	IExtensionPoint listeners = host.GetExtensionPoint( "ParameterProviders" );</pre>
-
-<h4>Interface</h4>
-<p>The extension object passed to Install must implement either the 
-   <b>ITestCaseProvider</b> or the <b>ITestCaseProvider2</b> interface:
-
-<pre>
-	public interface ITestCaseProvider
-	{
-		bool HasTestCasesFor( MethodInfo method );
-		IEnumerable GetTestCasesFor( MethodInfo method );
-	}
-	
-	public interface ITestCaseProvider2 : ITestCaseProvider
-	{
-		bool HasTestCasesFor( MethodInfo method, Test suite );
-		IEnumerable GetTestCasesFor( MethodInfo method, Test suite );
-	}
-</pre>
-
-<p>NUnit will call <b>ITestCaseProvider2</b> if it is available. Otherwise
-   <b>ITestCaseProvider</b> will be used.
-
-<p><b>HasTestCasesFor</b> should return true if the provider is able to supply test cases
-   for the specified method. If a provider only wants to be used on certain types 
-   of tests, it can examine the provided MethodInfo and the suite for which the
-   test is being constructed and return true or false based on what it finds.
-
-<p>The GetParametersFor method should return a list of individual test cases.
-   Each test case may be expressed as a ParameterSet, as an array of arguments
-   or as a custom object containing one or more of the following properties:
-   
-   <ul>
-   <li>Arguments
-   <li>RunState
-   <li>NotRunReason
-   <li>ExpectedExceptionType
-   <li>ExpectedExceptionName
-   <li>ExpectedExceptionMessage
-   <li>Result
-   <li>Description
-   <li>TestName
-   </ul>
-
-<p>The ParameterSet class provides all these properties and may be used
-to avoid the overhead of reflecting on the properties.
-
-<h4>Notes:</h4>
-
-<ol>
-<li>Most providers will delegate one of the interface implementations
-    to the other if they implement both.
-<li>TestCaseProviders that use data from the fixture class should use 
-    <b>ITestCaseProvider2</b> interface so that they are able to access any 
-	arguments supplied for constructing the fixture object.
-<li>Providers that acquire data from outside the fixture will usually
-    be able to work with <b>ITestCaseProvider</b> alone.
-<li>The <b>ITestCaseProvider2</b> interface was added in the NUnit 2.5.1 release.
-</ol>
-   
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<ul>
-<li><a href="customConstraints.html">Custom&nbsp;Constraints</a></li>
-<li><a href="nunitAddins.html">NUnit&nbsp;Addins</a></li>
-<ul>
-<li><a href="suiteBuilders.html">SuiteBuilders</a></li>
-<li><a href="testcaseBuilders.html">TestcaseBuilders</a></li>
-<li><a href="testDecorators.html">TestDecorators</a></li>
-<li id="current"><a href="testcaseProviders.html">TestcaseProviders</a></li>
-<li><a href="datapointProviders.html">DatapointProviders</a></li>
-<li><a href="eventListeners.html">EventListeners</a></li>
-</ul>
-<li><a href="extensionTips.html">Tips&nbsp;for&nbsp;Extenders</a></li>
-</ul>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/theory.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/theory.html b/lib/NUnit.org/NUnit/2.5.9/doc/theory.html
deleted file mode 100644
index e8e5d76..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/theory.html
+++ /dev/null
@@ -1,191 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - Theory</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h3>TheoryAttribute (NUnit 2.5) (Experimental)</h3>
-
-<p>A Theory is a special type of test, used to verify a general
-   statement about the system under development. Normal tests are
-   <em>example-based</em>. That is, the developer supplies one or
-   more examples of inputs and expected outputs either within the
-   code of the test or - in the case of
-   <a href="parameterizedTests.html">Parameterized Tests</a> 
-   - as arguments to the test method. A theory, on the other hand,
-   makes a general statement that all of its assertions will pass
-   for all arguments satisfying certain assumptions.
-   
-<p>Theories are implemented in NUnit
-   as methods within a <b>TestFixture</b>, which are annotated
-   with the <b>TheoryAttribute</b>. Theory methods must always have 
-   arguments and therefore appears quite similar to 
-   <a href="parameterizedTests.html">Parameterized Tests</a>   at first glance. However, a Theory incorporates additional data sources 
-   for its arguments and allows special processing for assumptions
-   about that data. The key difference, though, is that theories
-   make general statements and are more than just a set of examples.
-   
-<h4>Data for Theories</h4>
-
-<p>The primary source of data for a <b>Theory</b> is the
-   <a href="datapoint.html"><b>Datapoint</b> or <b>Datapoints</b> attribute</a>. 
-   NUnit will use any fields of the required types, which are annotated
-   with one of these attributes, to provide data for each parameter
-   of the Theory. NUnit assembles the values for individual arguments 
-   combinatorially to provide test cases for the theory.
-   
-<p>In addition to the Datapoint and Datapoints attributes, it
-   is possible to use any of the approaches for supplying data
-   that are recognized on normal parameterized tests. We suggest
-   that this capability not be overused, since it runs counter
-   to the distinction between a test based on examples and a
-   theory. However, it may be useful in order to guarantee that
-   a specific test case is included.
-   
-<h4>Assumptions</h4>
-
-<p>The theory itself is responsible for ensuring that all data supplied
-   meets its assumptions. It does this by use of the
-   <b>Assume.That(...)</b> construct, which works just like
-   <b>Assert.That(...)</b> but does not cause a failure. If
-   the assumption is not satisfied for a particular test case, that case
-   returns an Inconclusive result, rather than a Success or Failure. 
-   
-<p>The overall result of executing a Theory over a set of test cases is 
-   determined as follows:
-   
-   <ul>
-   <li>If the assumptions are violated for <b>all</b> test cases, then the
-       Theory itself is marked as a failure.
-   
-   <li>If any Assertion fails, the Theory itself fails.
-   
-   <li>If at least <b>some</b> cases pass the stated assumptions, and 
-       there are <b>no</b> assertion failures or exceptions, then the
-	   Theory passes.
-   </ul>
-   
-<h4>Example:</h4>
-
-<p>In the following example, the theory SquareRootDefinition
-   verifies that the implementation of square root satisies
-   the following definition:
-   
-<p style="margin: 2em"><i>
-"Given a non-negative number, the square root of that number
- is always non-negative and, when multiplied by itself, gives 
- the original number."</i>
-
-<div class="code" style="width: 36em">
-<pre>
-public class SqrtTests
-{
-    [Datapoints]
-    public double[] values = new double[] { 0.0, 1.0, -1.0, 42.0 };
-
-    [Theory]
-    public void SquareRootDefinition(double num)
-    {
-        Assume.That(num >= 0.0);
-
-        double sqrt = Math.Sqrt(num);
-
-        Assert.That(sqrt >= 0.0);
-        Assert.That(sqrt * sqrt, Is.EqualTo(num).Within(0.000001));
-    }
-}
-</pre>
-</div>
-   
-<h4>See also...</h4>
-
-<ul>
-<li><a href="datapoint.html">Datapoint(s)Attribute</a><li><a href="parameterizedTests.html">Parameterized Tests</a></ul>
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<ul>
-<li><a href="category.html">Category</a></li>
-<li><a href="combinatorial.html">Combinatorial</a></li>
-<li><a href="culture.html">Culture</a></li>
-<li><a href="datapoint.html">Datapoint(s)</a></li>
-<li><a href="description.html">Description</a></li>
-<li><a href="exception.html">Exception</a></li>
-<li><a href="explicit.html">Explicit</a></li>
-<li><a href="ignore.html">Ignore</a></li>
-<li><a href="maxtime.html">Maxtime</a></li>
-<li><a href="pairwise.html">Pairwise</a></li>
-<li><a href="platform.html">Platform</a></li>
-<li><a href="property.html">Property</a></li>
-<li><a href="random.html">Random</a></li>
-<li><a href="range.html">Range</a></li>
-<li><a href="repeat.html">Repeat</a></li>
-<li><a href="requiredAddin.html">RequiredAddin</a></li>
-<li><a href="requiresMTA.html">Requires&nbsp;MTA</a></li>
-<li><a href="requiresSTA.html">Requires&nbsp;STA</a></li>
-<li><a href="requiresThread.html">Requires&nbsp;Thread</a></li>
-<li><a href="sequential.html">Sequential</a></li>
-<li><a href="setCulture.html">SetCulture</a></li>
-<li><a href="setup.html">Setup</a></li>
-<li><a href="setupFixture.html">SetupFixture</a></li>
-<li><a href="suite.html">Suite</a></li>
-<li><a href="teardown.html">Teardown</a></li>
-<li><a href="test.html">Test</a></li>
-<li><a href="testCase.html">TestCase</a></li>
-<li><a href="testCaseSource.html">TestCaseSource</a></li>
-<li><a href="testFixture.html">TestFixture</a></li>
-<li><a href="fixtureSetup.html">TestFixtureSetUp</a></li>
-<li><a href="fixtureTeardown.html">TestFixtureTearDown</a></li>
-<li id="current"><a href="theory.html">Theory</a></li>
-<li><a href="timeout.html">Timeout</a></li>
-<li><a href="values.html">Values</a></li>
-<li><a href="valueSource.html">ValueSource</a></li>
-</ul>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/throwsConstraint.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/throwsConstraint.html b/lib/NUnit.org/NUnit/2.5.9/doc/throwsConstraint.html
deleted file mode 100644
index 0bbb4ba..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/throwsConstraint.html
+++ /dev/null
@@ -1,157 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - ThrowsConstraint</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h2>Throws Constraint (NUnit 2.5)</h2>
-
-<p><b>ThrowsConstraint</b> is used to test that some code, represented as a delegate,
-throws a particular exception. It may be used alone, to merely test the type
-of constraint, or with an additional constraint to be applied to the exception
-specified as an argument.
-
-p>The related <b>ThrowsNothingConstraint</b> simply asserts that the delegate
-does not throw an exception.
-
-<h4>Constructors</h4>
-<div class="code"><pre>
-ThrowsConstraint(Type expectedType)
-ThrowsConstraint&lt;T&gt;()
-ThrowsConstraint(Type expectedType, Constraint constraint)
-ThrowsConstraint&lt;T&gt;(Constraint constraint)
-ThrowsNothingConstraint()
-</pre></div>
-
-<h4>Syntax</h4>
-<div class="code"><pre>
-Throws.Exception
-Throws.TargetInvocationException
-Throws.ArgumentException
-Throws.InvalidOperationException
-Throws.TypeOf(Type expectedType)
-Throws.TypeOf&lt;T&gt;()
-Throws.InstanceOf(Type expectedType)
-Throws.InstanceOf&lt;T&gt;()
-Throws.Nothing
-Throws.InnerException
-</pre></div>
-
-<h4>Examples of Use</h4>
-<div class="code"><pre>
-// .NET 1.1
-Assert.That( new TestDelegate(SomeMethod),
-  Throws.TypeOf(typeof(ArgumentException)));
-Assert.That( new TestDelegate(SomeMethod),
-  Throws.Exception.TypeOf(typeof(ArgumentException)));
-Assert.That( new TestDelegate(SomeMethod),
-  Throws.TypeOf(typeof(ArgumentException))
-    .With.Property("Parameter").EqualTo("myParam"));
-Assert.That( new TestDelegate(SomeMethod),
-  Throws.ArgumentException );
-Assert.That( new TestDelegate(SomeMethod), 
-  Throws.TargetInvocationException
-    .With.InnerException.TypeOf(ArgumentException));
-	
-// .NET 2.0
-Assert.That( SomeMethod, 
-  Throws.TypeOf&lt;ArgumentException&gt;());
-Assert.That( SomeMethod, 
-  Throws.Exception.TypeOf&lt;ArgumentException&gt;());
-Assert.That( SomeMethod, 
-  Throws.TypeOf&lt;ArgumentException&gt;()
-    .With.Property("Parameter").EqualTo("myParam"));
-Assert.That( SomeMethod, Throws.ArgumentException );
-Assert.That( SomeMethod, 
-  Throws.TargetInvocationException
-    .With.InnerException.TypeOf&lt;ArgumentException&gt;());
-</pre></div>
-
-<h4>Notes</h4>
-<ol>
-<li><b>Throws.Exception</b> may be followed by further constraints,
-    which are applied to the exception itself as shown in the last two
-	examples above. It may also be used alone to verify that some
-	exception has been thrown, without regard to type. This is
-	not a recommended practice since you should normally know
-	what exception you are expecting.
-<li><b>Throws.TypeOf</b> and <b>Throws.InstanceOf</b> are provided
-    as a shorter syntax for this common test. They work exactly like
-	the corresponding forms following <b>Throws.Exception</b>.
-<li><b>Throws.TargetInvocationException/b>, <b>Throws.ArgumentException</b>
-    and <b>Throws.InvalidOperationException</b> provide a shortened form
-	for some common exceptions.
-<li>Used alone, <b>Throws.InnerException</b> simply tests the InnerException
-    value of the thrown exception. More commonly, it will be used in 
-	combination with a test for the type of the outer exception as shown
-	in the examples above.
-</ol>
-
-
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<ul>
-<li><a href="equalConstraint.html">Equal&nbsp;Constraint</a></li>
-<li><a href="sameasConstraint.html">SameAs&nbsp;Constraint</a></li>
-<li><a href="conditionConstraints.html">Condition&nbsp;Constraints</a></li>
-<li><a href="comparisonConstraints.html">Comparison&nbsp;Constrants</a></li>
-<li><a href="pathConstraints.html">Path&nbsp;Constraints</a></li>
-<li><a href="typeConstraints.html">Type&nbsp;Constraints</a></li>
-<li><a href="stringConstraints.html">String&nbsp;Constraints</a></li>
-<li><a href="collectionConstraints.html">Collection&nbsp;Constraints</a></li>
-<li><a href="propertyConstraint.html">Property&nbsp;Constraint</a></li>
-<li id="current"><a href="throwsConstraint.html">Throws&nbsp;Constraint</a></li>
-<li><a href="compoundConstraints.html">Compound&nbsp;Constraints</a></li>
-<li><a href="delayedConstraint.html">Delayed&nbsp;Constraint</a></li>
-<li><a href="listMapper.html">List&nbsp;Mapper</a></li>
-<li><a href="reusableConstraint.html">Reusable&nbsp;Constraint</a></li>
-</ul>
-<li><a href="attributes.html">Attributes</a></li>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/timeout.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/timeout.html b/lib/NUnit.org/NUnit/2.5.9/doc/timeout.html
deleted file mode 100644
index d9c85a1..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/timeout.html
+++ /dev/null
@@ -1,123 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - Timeout</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h3>TimeoutAttribute (NUnit 2.5)</h3>
-
-<p>The <b>TimeoutAttribute</b> is used to specify a timeout value in milliseconds
-   for a test case. If the test case runs longer than the time specified it
-   is immediately cancelled and reported as a failure, with a message 
-   indicating that the timeout was exceeded.
-   
-<p>The attribute may also be specified on a fixture or assembly, in which
-   case it indicates the default timeout for any subordinate test cases.
-   
-<h4>Example</h4>
-
-<div class="code"><pre>
-[Test, Timeout(2000)]
-public void PotentiallyLongRunningTest()
-{
-    ...
-}
-</pre></div>
-
-<h4>Notes</h4>
-<ol>
-<li>Beginning with NUnit 2.5.5, timeouts are suppressed when running under a debugger.</li>
-</ol>
-
-<h4>See Also...</h4>
-<ul>
-<li><a href="maxtime.html">MaxtimeAttribute</a></ul>
-   
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<ul>
-<li><a href="category.html">Category</a></li>
-<li><a href="combinatorial.html">Combinatorial</a></li>
-<li><a href="culture.html">Culture</a></li>
-<li><a href="datapoint.html">Datapoint(s)</a></li>
-<li><a href="description.html">Description</a></li>
-<li><a href="exception.html">Exception</a></li>
-<li><a href="explicit.html">Explicit</a></li>
-<li><a href="ignore.html">Ignore</a></li>
-<li><a href="maxtime.html">Maxtime</a></li>
-<li><a href="pairwise.html">Pairwise</a></li>
-<li><a href="platform.html">Platform</a></li>
-<li><a href="property.html">Property</a></li>
-<li><a href="random.html">Random</a></li>
-<li><a href="range.html">Range</a></li>
-<li><a href="repeat.html">Repeat</a></li>
-<li><a href="requiredAddin.html">RequiredAddin</a></li>
-<li><a href="requiresMTA.html">Requires&nbsp;MTA</a></li>
-<li><a href="requiresSTA.html">Requires&nbsp;STA</a></li>
-<li><a href="requiresThread.html">Requires&nbsp;Thread</a></li>
-<li><a href="sequential.html">Sequential</a></li>
-<li><a href="setCulture.html">SetCulture</a></li>
-<li><a href="setup.html">Setup</a></li>
-<li><a href="setupFixture.html">SetupFixture</a></li>
-<li><a href="suite.html">Suite</a></li>
-<li><a href="teardown.html">Teardown</a></li>
-<li><a href="test.html">Test</a></li>
-<li><a href="testCase.html">TestCase</a></li>
-<li><a href="testCaseSource.html">TestCaseSource</a></li>
-<li><a href="testFixture.html">TestFixture</a></li>
-<li><a href="fixtureSetup.html">TestFixtureSetUp</a></li>
-<li><a href="fixtureTeardown.html">TestFixtureTearDown</a></li>
-<li><a href="theory.html">Theory</a></li>
-<li id="current"><a href="timeout.html">Timeout</a></li>
-<li><a href="values.html">Values</a></li>
-<li><a href="valueSource.html">ValueSource</a></li>
-</ul>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/typeAsserts.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/typeAsserts.html b/lib/NUnit.org/NUnit/2.5.9/doc/typeAsserts.html
deleted file mode 100644
index ef479bb..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/typeAsserts.html
+++ /dev/null
@@ -1,129 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - TypeAsserts</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h2>Type Asserts (NUnit 2.2.3 / 2.5)</h2>
-
-<p>These methods allow us to make assertions about the type of an object.</p>
-
-<div class="code" style="width: 36em" ><pre>
-
-Assert.IsInstanceOfType( Type expected, object actual );
-Assert.IsInstanceOfType( Type expected, object actual, 
-                string message );
-Assert.IsInstanceOfType( Type expected, object actual, 
-                string message, params object[] parms );
-				
-Assert.IsNotInstanceOfType( Type expected, object actual );
-Assert.IsNotInstanceOfType( Type expected, object actual, 
-                string message );
-Assert.IsNotInstanceOfType( Type expected, object actual, 
-                string message, params object[] parms );
-			
-Assert.IsAssignableFrom( Type expected, object actual );
-Assert.IsAssignableFrom( Type expected, object actual, 
-                string message );
-Assert.IsAssignableFrom( Type expected, object actual, 
-                string message, params object[] parms );
-				
-Assert.IsNotAssignableFrom( Type expected, object actual );
-Assert.IsNotAssignableFrom( Type expected, object actual, 
-                string message );
-Assert.IsNotAssignableFrom( Type expected, object actual, 
-                string message, params object[] parms );
-				
-</pre></div>
-
-Beginning with NUnit 2.5, generic equivalents are available 
-in .NET 2.0 NUnit packages.
-
-<div class="code" style="width: 36em" ><pre>
-
-Assert.IsInstanceOf&lt;T&gt;( object actual );
-Assert.IsInstanceOf&lt;T&gt;( object actual, string message );
-Assert.IsInstanceOf&lt;T&gt;( object actual, 
-                string message, params object[] parms );
-				
-Assert.IsNotInstanceOf&lt;T&gt;( object actual );
-Assert.IsNotInstanceOf&lt;T&gt;( object actual, string message ); 
-Assert.IsNotInstanceOf&lt;T&gt;( object actual, 
-                string message, params object[] parms );
-			
-Assert.IsAssignableFrom&lt;T&gt;( object actual );
-Assert.IsAssignableFrom&lt;T&gt;( object actual, string message );
-Assert.IsAssignableFrom&lt;T&gt;( object actual, 
-                string message, params object[] parms );
-				
-Assert.IsNotAssignableFrom&lt;T&gt;( object actual );
-Assert.IsNotAssignableFrom&lt;T&gt;( object actual, string message );
-Assert.IsNotAssignableFrom&lt;T&gt;( object actual, 
-                string message, params object[] parms );
-				
-</pre></div>
-
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<ul>
-<li><a href="equalityAsserts.html">Equality&nbsp;Asserts</a></li>
-<li><a href="identityAsserts.html">Identity&nbsp;Asserts</a></li>
-<li><a href="conditionAsserts.html">Condition&nbsp;Asserts</a></li>
-<li><a href="comparisonAsserts.html">Comparison&nbsp;Asserts</a></li>
-<li id="current"><a href="typeAsserts.html">Type&nbsp;Asserts</a></li>
-<li><a href="exceptionAsserts.html">Exception&nbsp;Asserts</a></li>
-<li><a href="utilityAsserts.html">Utility&nbsp;Methods</a></li>
-<li><a href="stringAssert.html">String&nbsp;Assert</a></li>
-<li><a href="collectionAssert.html">Collection&nbsp;Assert</a></li>
-<li><a href="fileAssert.html">File&nbsp;Assert</a></li>
-<li><a href="directoryAssert.html">Directory&nbsp;Assert</a></li>
-</ul>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>


[19/51] [abbrv] [partial] Cleaning up and getting ready to development towards v4.8

Posted by sy...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/explicit.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/explicit.html b/lib/NUnit.org/NUnit/2.5.9/doc/explicit.html
deleted file mode 100644
index ea31502..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/explicit.html
+++ /dev/null
@@ -1,274 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - Explicit</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<script language="JavaScript" src="codeFuncs.js" ></script> <!-- Do it this way for IE -->
-
-<h3>ExplicitAttribute (NUnit 2.2)</h3>
-
-<p>The Explicit attribute causes a test or test fixture to be ignored unless it is 
-	explicitly selected for running. The test or fixture will be run if it is 
-	selected in the gui, if its name is specified on the console runner command 
-	line as the fixture to run or if it is included by use of a Category filter.</p>
-
-<p>An optional string argument may be used to give the reason for marking
-   the test Explicit.</p>
-
-<p>If a test or fixture with the Explicit attribute is encountered in the course of 
-	running tests, it is skipped unless it has been specifically selected by one
-	of the above means. The test does not affect the outcome of the run at all:
-	it is not considered as ignored and is not even counted in the total number
-	of tests. In the gui, the tree node for the test remains gray and the
-	status bar color is not affected.</p>
-	
-<blockquote><i><b>Note:</b> In versions of NUnit prior to 2.4, these tests were
-    shown as ignored.</i></blockquote>
-
-<h4>Test Fixture Syntax</h4>
-
-<div id="trace">
-</div>
-
-<div class="code cs">
-
-<div class="langFilter">
-	<a href="javascript:Show('DD1')" onmouseover="Show('DD1')"><img src="img/langFilter.gif" width="14" height="14" alt="Language Filter"></a>
-	<div id="DD1" class="dropdown" style="display: none;" onclick="Hide('DD1')">
-		<a href="javascript:ShowCS()">C#</a><br>
-		<a href="javascript:ShowVB()">VB</a><br>
-		<a href="javascript:ShowMC()">C++</a><br>
-		<a href="javascript:ShowJS()">J#</a><br>
-	</div>
-</div>
-
-<pre class="cs">namespace NUnit.Tests
-{
-  using System;
-  using NUnit.Framework;
-
-  [TestFixture, Explicit]
-  public class ExplicitTests
-  {
-    // ...
-  }
-}
-</pre>
-
-<pre class="vb">Imports System
-Imports Nunit.Framework
-
-Namespace Nunit.Tests
-
-  &lt;TestFixture(), Explicit()&gt;
-  Public Class ExplicitTests
-    &#39; ...
-  End Class
-End Namespace
-</pre>
-
-<pre class="mc">#using &lt;Nunit.Framework.dll&gt;
-using namespace System;
-using namespace NUnit::Framework;
-
-namespace NUnitTests
-{
-  [TestFixture]
-  [Explicit]
-  public __gc class ExplicitTests
-  {
-    // ...
-  };
-}
-
-#include &quot;cppsample.h&quot;
-
-namespace NUnitTests {
-  // ...
-}
-</pre>
-
-<pre class="js">package NUnit.Tests;
-
-import System.*;
-import NUnit.Framework.TestFixture;
-
-
-/** @attribute NUnit.Framework.TestFixture() */
-/** @attribute NUnit.Framework.Explicit() */
-public class ExplicitTests
-{
-  // ...
-}
-</pre>
-
-</div>
-
-<h4>Test Syntax</h4>
-
-<div class="code">
-
-<div class="langFilter">
-	<a href="javascript:Show('DD2')" onmouseover="Show('DD2')"><img src="img/langFilter.gif" width="14" height="14" alt="Language Filter"></a>
-	<div id="DD2" class="dropdown" style="display: none;" onclick="Hide('DD2')">
-		<a href="javascript:ShowCS()">C#</a><br>
-		<a href="javascript:ShowVB()">VB</a><br>
-		<a href="javascript:ShowMC()">C++</a><br>
-		<a href="javascript:ShowJS()">J#</a><br>
-	</div>
-</div>
-
-<pre class="cs">namespace NUnit.Tests
-{
-  using System;
-  using NUnit.Framework;
-
-  [TestFixture]
-  public class SuccessTests
-  {
-    [Test, Explicit]
-    public void ExplicitTest()
-    { /* ... */ }
-}
-</pre>
-
-<pre class="vb">Imports System
-Imports Nunit.Framework
-
-Namespace Nunit.Tests
-
-  &lt;TestFixture()&gt;
-  Public Class SuccessTests
-    &lt;Test(), Explicit()&gt; Public Sub ExplicitTest()
-      &#39; ...
-    End Sub
-  End Class
-End Namespace
-</pre>
-
-<pre class="mc">#using &lt;Nunit.Framework.dll&gt;
-using namespace System;
-using namespace NUnit::Framework;
-
-namespace NUnitTests
-{
-  [TestFixture]
-  public __gc class SuccessTests
-  {
-    [Test][Explicit] void ExplicitTest();
-  };
-}
-
-#include &quot;cppsample.h&quot;
-
-namespace NUnitTests {
-  // ...
-}
-</pre>
-
-<pre class="js">package NUnit.Tests;
-
-import System.*;
-import NUnit.Framework.TestFixture;
-
-
-/** @attribute NUnit.Framework.TestFixture() */
-public class SuccessTests
-{
-  /** @attribute NUnit.Framework.Test() */
-  /** @attribute NUnit.Framework.Explicit() */
-  public void ExplicitTest()
-  { /* ... */ }
-}
-</pre>
-
-</div>
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<ul>
-<li><a href="category.html">Category</a></li>
-<li><a href="combinatorial.html">Combinatorial</a></li>
-<li><a href="culture.html">Culture</a></li>
-<li><a href="datapoint.html">Datapoint(s)</a></li>
-<li><a href="description.html">Description</a></li>
-<li><a href="exception.html">Exception</a></li>
-<li id="current"><a href="explicit.html">Explicit</a></li>
-<li><a href="ignore.html">Ignore</a></li>
-<li><a href="maxtime.html">Maxtime</a></li>
-<li><a href="pairwise.html">Pairwise</a></li>
-<li><a href="platform.html">Platform</a></li>
-<li><a href="property.html">Property</a></li>
-<li><a href="random.html">Random</a></li>
-<li><a href="range.html">Range</a></li>
-<li><a href="repeat.html">Repeat</a></li>
-<li><a href="requiredAddin.html">RequiredAddin</a></li>
-<li><a href="requiresMTA.html">Requires&nbsp;MTA</a></li>
-<li><a href="requiresSTA.html">Requires&nbsp;STA</a></li>
-<li><a href="requiresThread.html">Requires&nbsp;Thread</a></li>
-<li><a href="sequential.html">Sequential</a></li>
-<li><a href="setCulture.html">SetCulture</a></li>
-<li><a href="setup.html">Setup</a></li>
-<li><a href="setupFixture.html">SetupFixture</a></li>
-<li><a href="suite.html">Suite</a></li>
-<li><a href="teardown.html">Teardown</a></li>
-<li><a href="test.html">Test</a></li>
-<li><a href="testCase.html">TestCase</a></li>
-<li><a href="testCaseSource.html">TestCaseSource</a></li>
-<li><a href="testFixture.html">TestFixture</a></li>
-<li><a href="fixtureSetup.html">TestFixtureSetUp</a></li>
-<li><a href="fixtureTeardown.html">TestFixtureTearDown</a></li>
-<li><a href="theory.html">Theory</a></li>
-<li><a href="timeout.html">Timeout</a></li>
-<li><a href="values.html">Values</a></li>
-<li><a href="valueSource.html">ValueSource</a></li>
-</ul>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/extensibility.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/extensibility.html b/lib/NUnit.org/NUnit/2.5.9/doc/extensibility.html
deleted file mode 100644
index 1cd80fa..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/extensibility.html
+++ /dev/null
@@ -1,78 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - Extensibility</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h2>NUnit Extensibility</h2>
-
-<p>NUnit is designed to be extended in a number of ways.</p>
-
-<p>Extensions to the NUnit framework - the part of NUnit that is referenced
-by tests - usually take the form of 
-<a href="customConstraints.html">Custom Constraints</a>, written by users to 
-encapsulate tests that pertain to their specific projects.</p>
-
-<p>Extending the features found within NUnit itself depends on the use of
-<a href="nunitAddins.html">NUnit Addins</a>. 
-Currently, The Addin mechanism only supports extensions to the NUnit core -
-the part of NUnit that builds and executes test suites. However, the API that
-is used provides for the future ability to extend the client side of NUnit, 
-including the GUI.</p>
-
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li id="current"><a href="extensibility.html">Extensibility</a></li>
-<ul>
-<li><a href="customConstraints.html">Custom&nbsp;Constraints</a></li>
-<li><a href="nunitAddins.html">NUnit&nbsp;Addins</a></li>
-<li><a href="extensionTips.html">Tips&nbsp;for&nbsp;Extenders</a></li>
-</ul>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/extensionTips.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/extensionTips.html b/lib/NUnit.org/NUnit/2.5.9/doc/extensionTips.html
deleted file mode 100644
index 7b2f876..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/extensionTips.html
+++ /dev/null
@@ -1,95 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - ExtensionTips</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h3>Tips for Writing Extensions</h3>
-
-<p>An Extenders Guide will be published in the future. At the moment, writing an
-extension is a bit of an adventure. Extension authors are advised to join the 
-nunit-developer list and post questions and comments there.
-
-<p>For the moment, the following tips may be of assistance.
-<ul>
-<li>The <b>nunit.core.interfaces</b> assembly is intended to be stable in the future
-while the <b>nunit.core</b> assembly will change from release to release. Right now,
-both assemblies are still in flux, but extensions that depend solely on the interfaces
-assembly will have a much better chance of surviving NUnit version changes. Unfortunately,
-this is rather difficult to do without duplicating a great deal of NUnit code. Most
-of the add-in samples provided with NUnit are currently version dependent.
-
-<li>If you place the definition of a custom attribute in the same assembly as your
-add-in, then user tests are dependent on the add-in assembly. If the add-in is 
-version-dependent, then the user tests will also be version-dependent. We suggest
-placing any types referenced by user tests in a separate assembly, particularly if
-your extension relies on nunit.core.
-
-<li>If using Visual Studio, set Copy Local to false for any references to nunit.core
-or nunit.core.interfaces. This is especially important if you are also building
-NUnit itself.
-
-<li>There is currently no mechanism to allow decorators to apply in a particular order.
-NUnit applies decorators in the order in which they are returned through reflection,
-which may vary among different runtimes.
-
-<li>Avoid trying to "stretch" the existing extension points to do more than they were
-intended to do. Rather, let us know what further extension points you would like to see!
-</ul>
-
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<ul>
-<li><a href="customConstraints.html">Custom&nbsp;Constraints</a></li>
-<li><a href="nunitAddins.html">NUnit&nbsp;Addins</a></li>
-<li id="current"><a href="extensionTips.html">Tips&nbsp;for&nbsp;Extenders</a></li>
-</ul>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/favicon.ico
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/favicon.ico b/lib/NUnit.org/NUnit/2.5.9/doc/favicon.ico
deleted file mode 100644
index b95fa81..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/doc/favicon.ico and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/fileAssert.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/fileAssert.html b/lib/NUnit.org/NUnit/2.5.9/doc/fileAssert.html
deleted file mode 100644
index d85ef03..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/fileAssert.html
+++ /dev/null
@@ -1,112 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - FileAssert</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h2>FileAssert (NUnit 2.4)</h2>
-<p>The FileAssert class provides methods for comparing two files,
-which may be provided as Streams, as FileInfos or as strings 
-giving the path to each file.</p>
-
-<div class="code" style="width: 36em">
-<pre>FileAssert.AreEqual( Stream expected, Stream actual );
-FileAssert.AreEqual( Stream expected, Stream actual, 
-                string message );
-FileAssert.AreEqual( Stream expected, Stream actual,
-                string message, params object[] args );
-
-FileAssert.AreEqual( FileInfo expected, FileInfo actual );
-FileAssert.AreEqual( FileInfo expected, FileInfo actual, 
-                string message );
-FileAssert.AreEqual( FileInfo expected, FileInfo actual,
-                string message, params object[] args );
-
-FileAssert.AreEqual( string expected, string actual );
-FileAssert.AreEqual( string expected, string actual, 
-                string message );
-FileAssert.AreEqual( string expected, string actual,
-                string message, params object[] args );
-
-FileAssert.AreNotEqual( Stream expected, Stream actual );
-FileAssert.AreNotEqual( Stream expected, Stream actual, 
-                string message );
-FileAssert.AreNotEqual( Stream expected, Stream actual,
-                string message, params object[] args );
-
-FileAssert.AreNotEqual( FileInfo expected, FileInfo actual );
-FileAssert.AreNotEqual( FileInfo expected, FileInfo actual, 
-                string message );
-FileAssert.AreNotEqual( FileInfo expected, FileInfo actual,
-                string message, params object[] args );
-
-FileAssert.AreNotEqual( string expected, string actual );
-FileAssert.AreNotEqual( string expected, string actual, 
-                string message );
-FileAssert.AreNotEqual( string expected, string actual,
-                string message, params object[] args );</pre>
-</div>
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<ul>
-<li><a href="equalityAsserts.html">Equality&nbsp;Asserts</a></li>
-<li><a href="identityAsserts.html">Identity&nbsp;Asserts</a></li>
-<li><a href="conditionAsserts.html">Condition&nbsp;Asserts</a></li>
-<li><a href="comparisonAsserts.html">Comparison&nbsp;Asserts</a></li>
-<li><a href="typeAsserts.html">Type&nbsp;Asserts</a></li>
-<li><a href="exceptionAsserts.html">Exception&nbsp;Asserts</a></li>
-<li><a href="utilityAsserts.html">Utility&nbsp;Methods</a></li>
-<li><a href="stringAssert.html">String&nbsp;Assert</a></li>
-<li><a href="collectionAssert.html">Collection&nbsp;Assert</a></li>
-<li id="current"><a href="fileAssert.html">File&nbsp;Assert</a></li>
-<li><a href="directoryAssert.html">Directory&nbsp;Assert</a></li>
-</ul>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/files/QuickStart.Spanish.doc
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/files/QuickStart.Spanish.doc b/lib/NUnit.org/NUnit/2.5.9/doc/files/QuickStart.Spanish.doc
deleted file mode 100644
index b60a15a..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/doc/files/QuickStart.Spanish.doc and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/files/QuickStart.doc
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/files/QuickStart.doc b/lib/NUnit.org/NUnit/2.5.9/doc/files/QuickStart.doc
deleted file mode 100644
index d92ad94..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/doc/files/QuickStart.doc and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/files/Results.xsd
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/files/Results.xsd b/lib/NUnit.org/NUnit/2.5.9/doc/files/Results.xsd
deleted file mode 100644
index 6d3d77b..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/files/Results.xsd
+++ /dev/null
@@ -1,70 +0,0 @@
-<?xml version="1.0" encoding="UTF-8" ?>
-<xs:schema xmlns:xs="http://www.w3.org/2001/XMLSchema" elementFormDefault="qualified">
-	<xs:complexType name="failureType">
-		<xs:sequence>
-			<xs:element ref="message" />
-			<xs:element ref="stack-trace" />
-		</xs:sequence>
-	</xs:complexType>
-	<xs:complexType name="reasonType">
-		<xs:sequence>
-			<xs:element ref="message" />
-		</xs:sequence>
-	</xs:complexType>
-	<xs:element name="message" type="xs:string" />
-	<xs:complexType name="resultsType">
-		<xs:choice>
-			<xs:element name="test-suite" type="test-suiteType" maxOccurs="unbounded" />
-			<xs:element name="test-case" type="test-caseType" maxOccurs="unbounded" minOccurs="0" />
-		</xs:choice>
-	</xs:complexType>
-	<xs:element name="stack-trace" type="xs:string" />
-	<xs:element name="test-results" type="resultType" />
-	<xs:complexType name="categoriesType">
-		<xs:sequence>
-			<xs:element name="category" type="categoryType" maxOccurs="unbounded" minOccurs="1"/>
-		</xs:sequence>
-	</xs:complexType>
-	<xs:complexType name="categoryType">
-		<xs:attribute name="name" type="xs:string" use="required"/>
-	</xs:complexType>
-	<xs:complexType name="resultType">
-		<xs:sequence>
-			<xs:element name="test-suite" type="test-suiteType" />
-		</xs:sequence>
-		<xs:attribute name="name" type="xs:string" use="required" />
-		<xs:attribute name="total" type="xs:decimal" use="required" />
-		<xs:attribute name="failures" type="xs:decimal" use="required" />
-		<xs:attribute name="not-run" type="xs:decimal" use="required" />
-		<xs:attribute name="date" type="xs:string" use="required" />
-		<xs:attribute name="time" type="xs:string" use="required" />
-	</xs:complexType>
-	<xs:complexType name="test-caseType">
-		<xs:sequence>
-			<xs:element name="categories" type="categoriesType" minOccurs="0" maxOccurs="1" />
-			<xs:choice>
-				<xs:element name="failure" type="failureType" minOccurs="0" />
-				<xs:element name="reason" type="reasonType" minOccurs="0" />
-			</xs:choice>
-		</xs:sequence>
-			
-		<xs:attribute name="name" type="xs:string" use="required" />
-		<xs:attribute name="description" type="xs:string" use="optional" />
-		<xs:attribute name="success" type="xs:string" use="optional" />
-		<xs:attribute name="time" type="xs:string" use="optional" />
-		<xs:attribute name="executed" type="xs:string" use="required" />
-		<xs:attribute name="asserts" type="xs:string" use="optional" />
-	</xs:complexType>
-	<xs:complexType name="test-suiteType">
-		<xs:sequence>
-			<xs:element name="categories" type="categoriesType" minOccurs="0" maxOccurs="1" />
-			<xs:element name="results" type="resultsType" />
-		</xs:sequence>
-		<xs:attribute name="name" type="xs:string" use="required" />
-		<xs:attribute name="description" type="xs:string" use="optional" />
-		<xs:attribute name="success" type="xs:string" use="required" />
-		<xs:attribute name="time" type="xs:string" use="required" />
-		<xs:attribute name="asserts" type="xs:string" use="optional" />
-	</xs:complexType>
-
-</xs:schema>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/files/Summary.xslt
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/files/Summary.xslt b/lib/NUnit.org/NUnit/2.5.9/doc/files/Summary.xslt
deleted file mode 100644
index 675ff5e..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/files/Summary.xslt
+++ /dev/null
@@ -1,47 +0,0 @@
-<?xml version="1.0" encoding="UTF-8" ?>
-<xsl:stylesheet version="1.0" xmlns:xsl="http://www.w3.org/1999/XSL/Transform">
-<xsl:output method='text'/>
-
-<xsl:template match="/">
-	<xsl:apply-templates/>
-</xsl:template>
-
-<xsl:template match="test-results">
-<xsl:text>Tests run: </xsl:text>
-<xsl:value-of select="@total"/>
-<xsl:text>, Failures: </xsl:text>
-<xsl:value-of select="@failures"/>
-<xsl:text>, Not run: </xsl:text>
-<xsl:value-of select="@not-run"/>
-<xsl:text>, Time: </xsl:text>
-<xsl:value-of select="test-suite/@time"/>
-<xsl:text> seconds
-</xsl:text>
-<xsl:text>
-</xsl:text>
-
-<xsl:if test="//test-case[failure]"><xsl:text>Failures:
-</xsl:text></xsl:if>
-<xsl:apply-templates select="//test-case[failure]"/>
-<xsl:if test="//test-case[@executed='False']"><xsl:text>Tests not run:
-</xsl:text></xsl:if>
-<xsl:apply-templates select="//test-case[@executed='False']"/>
-<xsl:text disable-output-escaping='yes'>&#xD;&#xA;</xsl:text>
-</xsl:template>
-
-<xsl:template match="test-case">
-	<xsl:value-of select="position()"/><xsl:text>) </xsl:text>
-	<xsl:value-of select="@name"/>
-	<xsl:text> : </xsl:text>
-	<xsl:value-of select="child::node()/message"/>
-<xsl:text disable-output-escaping='yes'>&#xD;&#xA;</xsl:text>
-	<xsl:if test="failure">
-		<xsl:value-of select="failure/stack-trace"/>
-<xsl:text>
-</xsl:text>
-	</xsl:if>
-</xsl:template>
-
-</xsl:stylesheet>
-
-  
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/files/TestResult.xml
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/files/TestResult.xml b/lib/NUnit.org/NUnit/2.5.9/doc/files/TestResult.xml
deleted file mode 100644
index bd8e0e6..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/files/TestResult.xml
+++ /dev/null
@@ -1,135 +0,0 @@
-<?xml version="1.0" encoding="utf-8" standalone="no"?>
-<!--This file represents the results of running a test suite-->
-<test-results name="tests\mock-assembly.dll" total="8" errors="1" failures="1" not-run="7" ignored="4" skipped="0" invalid="3" date="2008-11-22" time="20:17:48">
-  <environment nunit-version="2.5.0.8327" clr-version="2.0.50727.1433" os-version="Microsoft Windows NT 5.1.2600 Service Pack 2" platform="Win32NT" cwd="C:\Program Files\NUnit 2.5\bin\net-2.0" machine-name="FERRARI" user="Charlie" user-domain="FERRARI" />
-  <culture-info current-culture="en-US" current-uiculture="en-US" />
-  <test-suite name="tests\mock-assembly.dll" executed="True" success="False" time="0.125" asserts="0">
-    <results>
-      <test-suite name="NUnit" executed="True" success="False" time="0.109" asserts="0">
-        <results>
-          <test-suite name="Tests" executed="True" success="False" time="0.109" asserts="0">
-            <results>
-              <test-suite name="Assemblies" executed="True" success="False" time="0.109" asserts="0">
-                <results>
-                  <test-suite name="MockTestFixture" description="Fake Test Fixture" executed="True" success="False" time="0.109" asserts="0">
-                    <categories>
-                      <category name="FixtureCategory" />
-                    </categories>
-                    <results>
-                      <test-case name="NUnit.Tests.Assemblies.MockTestFixture.FailingTest" executed="True" success="False" time="0.047" asserts="0">
-                        <failure>
-                          <message><![CDATA[Intentional failure]]></message>
-                          <stack-trace><![CDATA[at NUnit.Tests.Assemblies.MockTestFixture.FailingTest()
-]]></stack-trace>
-                        </failure>
-                      </test-case>
-                      <test-case name="NUnit.Tests.Assemblies.MockTestFixture.MockTest1" description="Mock Test #1" executed="True" success="True" time="0.000" asserts="0" />
-                      <test-case name="NUnit.Tests.Assemblies.MockTestFixture.MockTest2" executed="True" success="True" time="0.000" asserts="0">
-                        <categories>
-                          <category name="MockCategory" />
-                        </categories>
-                        <properties>
-                          <property name="Severity" value="Critical" />
-                        </properties>
-                      </test-case>
-                      <test-case name="NUnit.Tests.Assemblies.MockTestFixture.MockTest3" executed="True" success="True" time="0.000" asserts="0">
-                        <categories>
-                          <category name="AnotherCategory" />
-                          <category name="MockCategory" />
-                        </categories>
-                      </test-case>
-                      <test-case name="NUnit.Tests.Assemblies.MockTestFixture.MockTest4" executed="False">
-                        <categories>
-                          <category name="Foo" />
-                        </categories>
-                        <reason>
-                          <message><![CDATA[ignoring this test method for now]]></message>
-                        </reason>
-                      </test-case>
-                      <test-case name="NUnit.Tests.Assemblies.MockTestFixture.MockTest5" executed="False">
-                        <reason>
-                          <message><![CDATA[Method is not public]]></message>
-                        </reason>
-                      </test-case>
-                      <test-case name="NUnit.Tests.Assemblies.MockTestFixture.NotRunnableTest" executed="False">
-                        <reason>
-                          <message><![CDATA[No arguments provided]]></message>
-                        </reason>
-                      </test-case>
-                      <test-case name="NUnit.Tests.Assemblies.MockTestFixture.TestWithException" executed="True" success="False" time="0.000" asserts="0">
-                        <failure>
-                          <message><![CDATA[System.ApplicationException : Intentional Exception]]></message>
-                          <stack-trace><![CDATA[at NUnit.Tests.Assemblies.MockTestFixture.MethodThrowsException()
-at NUnit.Tests.Assemblies.MockTestFixture.TestWithException()
-]]></stack-trace>
-                        </failure>
-                      </test-case>
-                      <test-case name="NUnit.Tests.Assemblies.MockTestFixture.TestWithManyProperties" executed="True" success="True" time="0.000" asserts="0">
-                        <properties>
-                          <property name="Size" value="5" />
-                          <property name="TargetMethod" value="SomeClassName" />
-                        </properties>
-                      </test-case>
-                    </results>
-                  </test-suite>
-                </results>
-              </test-suite>
-              <test-suite name="BadFixture" executed="False">
-                <reason>
-                  <message><![CDATA[No suitable constructor was found]]></message>
-                </reason>
-                <results>
-                  <test-case name="NUnit.Tests.BadFixture.SomeTest" executed="False">
-                    <reason>
-                      <message><![CDATA[No suitable constructor was found]]></message>
-                    </reason>
-                  </test-case>
-                </results>
-              </test-suite>
-              <test-suite name="IgnoredFixture" executed="False">
-                <reason>
-                  <message><![CDATA[]]></message>
-                </reason>
-                <results>
-                  <test-case name="NUnit.Tests.IgnoredFixture.Test1" executed="False">
-                    <reason>
-                      <message><![CDATA[]]></message>
-                    </reason>
-                  </test-case>
-                  <test-case name="NUnit.Tests.IgnoredFixture.Test2" executed="False">
-                    <reason>
-                      <message><![CDATA[]]></message>
-                    </reason>
-                  </test-case>
-                  <test-case name="NUnit.Tests.IgnoredFixture.Test3" executed="False">
-                    <reason>
-                      <message><![CDATA[]]></message>
-                    </reason>
-                  </test-case>
-                </results>
-              </test-suite>
-              <test-suite name="Singletons" executed="True" success="True" time="0.000" asserts="0">
-                <results>
-                  <test-suite name="OneTestCase" executed="True" success="True" time="0.000" asserts="0">
-                    <results>
-                      <test-case name="NUnit.Tests.Singletons.OneTestCase.TestCase" executed="True" success="True" time="0.000" asserts="0" />
-                    </results>
-                  </test-suite>
-                </results>
-              </test-suite>
-              <test-suite name="TestAssembly" executed="True" success="True" time="0.000" asserts="0">
-                <results>
-                  <test-suite name="MockTestFixture" executed="True" success="True" time="0.000" asserts="0">
-                    <results>
-                      <test-case name="NUnit.Tests.TestAssembly.MockTestFixture.MyTest" executed="True" success="True" time="0.000" asserts="0" />
-                    </results>
-                  </test-suite>
-                </results>
-              </test-suite>
-            </results>
-          </test-suite>
-        </results>
-      </test-suite>
-    </results>
-  </test-suite>
-</test-results>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/fixtureSetup.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/fixtureSetup.html b/lib/NUnit.org/NUnit/2.5.9/doc/fixtureSetup.html
deleted file mode 100644
index dd6fd26..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/fixtureSetup.html
+++ /dev/null
@@ -1,238 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - FixtureSetup</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<script language="JavaScript" src="codeFuncs.js" ></script> <!-- Do it this way for IE -->
-
-<h3>TestFixtureSetUpAttribute (NUnit 2.1 / 2.5)</h3>
-
-<p>This attribute is used inside a TestFixture to provide a single set of 
-	functions that are performed once prior to executing any of the tests
-	in the fixture. 
-	
-<p><b>Before NUnit 2.5</b>, a TestFixture could have only one TestFixtureSetUp method
-	and it was required to be an instance method. 
-
-<p><b>Beginning with NUnit 2.5</b>, TestFixtureSetUp methods may be either static or
-   instance methods and you may define more than one of them in a fixture.
-   Normally, multiple TestFixtureSetUp methods are only defined at different levels
-   of an inheritance hierarchy, as explained below.
-
-<p>If a TestFixtueSetUp method fails or throws an exception, none of the tests
-   in the fixure are executed and a failure or error is reported.
-
-<h4>Example:</h4>
-
-<div class="code">
-
-<div class="langFilter">
-	<a href="javascript:Show('DD1')" onmouseover="Show('DD1')"><img src="img/langFilter.gif" width="14" height="14" alt="Language Filter"></a>
-	<div id="DD1" class="dropdown" style="display: none;" onclick="Hide('DD1')">
-		<a href="javascript:ShowCS()">C#</a><br>
-		<a href="javascript:ShowVB()">VB</a><br>
-		<a href="javascript:ShowMC()">C++</a><br>
-		<a href="javascript:ShowJS()">J#</a><br>
-	</div>
-</div>
-
-<pre class="cs">namespace NUnit.Tests
-{
-  using System;
-  using NUnit.Framework;
-
-  [TestFixture]
-  public class SuccessTests
-  {
-    [TestFixtureSetUp] public void Init()
-    { /* ... */ }
-
-    [TestFixtureTearDown] public void Cleanup()
-    { /* ... */ }
-
-    [Test] public void Add()
-    { /* ... */ }
-  }
-}
-</pre>
-
-<pre class="vb">Imports System
-Imports Nunit.Framework
-
-Namespace Nunit.Tests
-
-  &lt;TestFixture()&gt; Public Class SuccessTests
-    &lt;TestFixtureSetUp()&gt; Public Sub Init()
-    ' ...
-    End Sub
-
-    &lt;TestFixtureTearDown()&gt; Public Sub Cleanup()
-    ' ...
-    End Sub
-
-    &lt;Test()&gt; Public Sub Add()
-    ' ...
-    End Sub
-  End Class
-End Namespace
-</pre>
-
-<pre class="mc">#using &lt;Nunit.Framework.dll&gt;
-using namespace System;
-using namespace NUnit::Framework;
-
-namespace NUnitTests
-{
-  [TestFixture]
-  public __gc class SuccessTests
-  {
-    [TestFixtureSetUp] void Init();
-    [TestFixtureTearDown] void Cleanup();
-
-    [Test] void Add();
-  };
-}
-
-#include "cppsample.h"
-
-namespace NUnitTests {
-  // ...
-}
-</pre>
-
-<pre class="js">package NUnit.Tests;
-
-import System.*;
-import NUnit.Framework.TestFixture;
-
-
-/** @attribute NUnit.Framework.TestFixture() */
-public class SuccessTests
-{
-  /** @attribute NUnit.Framework.TestFixtureSetUp() */
-  public void Init()
-  { /* ... */ }
-
-  /** @attribute NUnit.Framework.TestFixtureTearDown() */
-  public void Cleanup()
-  { /* ... */ }
-
-  /** @attribute NUnit.Framework.Test() */
-  public void Add()
-  { /* ... */ }
-}
-</pre>
-
-</div>
-
-<h3>Inheritance</h3>
-
-<p>The TestFixtureSetUp attribute is inherited from any base class. Therefore, if a base 
-	class has defined a SetFixtureSetUp method, that method will be called 
-	after each test method in the derived class. 
-	
-<p>Before NUnit 2.5, you were permitted only one TestFixtureSetUp method. If you wanted to 
-   have some TestFixtureSetUp functionality in the base class and add more in the derived 
-   class you needed to call the base class method yourself.
-
-<p>With NUnit 2.5, you can achieve the same result by defining a TestFixtureSetUp method
-   in the base class and another in the derived class. NUnit will call base
-   class TestFixtureSetUp methods before those in the derived classes.
-   
-<p><b>Note:</b> Although it is possible to define multiple TestFixtureSetUp methods
-   in the same class, you should rarely do so. Unlike methods defined in
-   separate classes in the inheritance hierarchy, the order in which they
-   are executed is not guaranteed.
-
-<h4>See also...</h4>
-<ul>
-<li><a href="setup.html">SetUpAttribute</a><li><a href="teardown.html">TearDownAttribute</a><li><a href="fixtureTeardown.html">TestFixtureTearDownAttribute</a></ul>
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<ul>
-<li><a href="category.html">Category</a></li>
-<li><a href="combinatorial.html">Combinatorial</a></li>
-<li><a href="culture.html">Culture</a></li>
-<li><a href="datapoint.html">Datapoint(s)</a></li>
-<li><a href="description.html">Description</a></li>
-<li><a href="exception.html">Exception</a></li>
-<li><a href="explicit.html">Explicit</a></li>
-<li><a href="ignore.html">Ignore</a></li>
-<li><a href="maxtime.html">Maxtime</a></li>
-<li><a href="pairwise.html">Pairwise</a></li>
-<li><a href="platform.html">Platform</a></li>
-<li><a href="property.html">Property</a></li>
-<li><a href="random.html">Random</a></li>
-<li><a href="range.html">Range</a></li>
-<li><a href="repeat.html">Repeat</a></li>
-<li><a href="requiredAddin.html">RequiredAddin</a></li>
-<li><a href="requiresMTA.html">Requires&nbsp;MTA</a></li>
-<li><a href="requiresSTA.html">Requires&nbsp;STA</a></li>
-<li><a href="requiresThread.html">Requires&nbsp;Thread</a></li>
-<li><a href="sequential.html">Sequential</a></li>
-<li><a href="setCulture.html">SetCulture</a></li>
-<li><a href="setup.html">Setup</a></li>
-<li><a href="setupFixture.html">SetupFixture</a></li>
-<li><a href="suite.html">Suite</a></li>
-<li><a href="teardown.html">Teardown</a></li>
-<li><a href="test.html">Test</a></li>
-<li><a href="testCase.html">TestCase</a></li>
-<li><a href="testCaseSource.html">TestCaseSource</a></li>
-<li><a href="testFixture.html">TestFixture</a></li>
-<li id="current"><a href="fixtureSetup.html">TestFixtureSetUp</a></li>
-<li><a href="fixtureTeardown.html">TestFixtureTearDown</a></li>
-<li><a href="theory.html">Theory</a></li>
-<li><a href="timeout.html">Timeout</a></li>
-<li><a href="values.html">Values</a></li>
-<li><a href="valueSource.html">ValueSource</a></li>
-</ul>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/fixtureTeardown.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/fixtureTeardown.html b/lib/NUnit.org/NUnit/2.5.9/doc/fixtureTeardown.html
deleted file mode 100644
index 9260599..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/fixtureTeardown.html
+++ /dev/null
@@ -1,238 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - FixtureTeardown</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<script language="JavaScript" src="codeFuncs.js" ></script> <!-- Do it this way for IE -->
-
-<h3>TestFixtureTearDownAttribute (NUnit 2.1 / 2.5)</h3>
-
-<p>This attribute is used inside a TestFixture to provide a single set of 
-	functions that are performed once after all tests are completed. 
-	
-<p><b>Before NUnit 2.5</b>, a TestFixture could have only one SetUp method
-	and it was required to be an instance method. 
-
-<p><b>Beginning with NUnit 2.5</b>, TestFixtureTearDown methods may be either static or
-   instance methods and you may define more than one of them in a fixture.
-   Normally, multiple TestFixtureTearDown methods are only defined at different levels
-   of an inheritance hierarchy, as explained below.
-
-<p>So long as any TestFixtureSetUp method runs without error, the TestFixtureTearDown method is 
-   guaranteed to run. It will not run if a TestFixtureSetUp method fails or throws an 
-   exception.</p>
-
-<h4>Example:</h4>
-
-<div class="code">
-
-<div class="langFilter">
-	<a href="javascript:Show('DD1')" onmouseover="Show('DD1')"><img src="img/langFilter.gif" width="14" height="14" alt="Language Filter"></a>
-	<div id="DD1" class="dropdown" style="display: none;" onclick="Hide('DD1')">
-		<a href="javascript:ShowCS()">C#</a><br>
-		<a href="javascript:ShowVB()">VB</a><br>
-		<a href="javascript:ShowMC()">C++</a><br>
-		<a href="javascript:ShowJS()">J#</a><br>
-	</div>
-</div>
-
-<pre class="cs">namespace NUnit.Tests
-{
-  using System;
-  using NUnit.Framework;
-
-  [TestFixture]
-  public class SuccessTests
-  {
-    [TestFixtureSetUp] public void Init()
-    { /* ... */ }
-
-    [TestFixtureTearDown] public void Cleanup()
-    { /* ... */ }
-
-    [Test] public void Add()
-    { /* ... */ }
-  }
-}
-</pre>
-
-<pre class="vb">Imports System
-Imports Nunit.Framework
-
-Namespace Nunit.Tests
-
-  &lt;TestFixture()&gt; Public Class SuccessTests
-    &lt;TestFixtureSetUp()&gt; Public Sub Init()
-    ' ...
-    End Sub
-
-    &lt;TestFixtureTearDown()&gt; Public Sub Cleanup()
-    ' ...
-    End Sub
-
-    &lt;Test()&gt; Public Sub Add()
-    ' ...
-    End Sub
-  End Class
-End Namespace
-</pre>
-
-<pre class="mc">#using &lt;Nunit.Framework.dll&gt;
-using namespace System;
-using namespace NUnit::Framework;
-
-namespace NUnitTests
-{
-  [TestFixture]
-  public __gc class SuccessTests
-  {
-    [TestFixtureSetUp] void Init();
-    [TestFixtureTearDown] void Cleanup();
-
-    [Test] void Add();
-  };
-}
-
-#include "cppsample.h"
-
-namespace NUnitTests {
-  // ...
-}
-</pre>
-
-<pre class="js">package NUnit.Tests;
-
-import System.*;
-import NUnit.Framework.TestFixture;
-
-
-/** @attribute NUnit.Framework.TestFixture() */
-public class SuccessTests
-{
-  /** @attribute NUnit.Framework.TestFixtureSetUp() */
-  public void Init()
-  { /* ... */ }
-
-  /** @attribute NUnit.Framework.TestFixtureTearDown() */
-  public void Cleanup()
-  { /* ... */ }
-
-  /** @attribute NUnit.Framework.Test() */
-  public void Add()
-  { /* ... */ }
-}
-</pre>
-
-</div>
-
-<h3>Inheritance</h3>
-
-<p>The TestFixtureTearDown attribute is inherited from any base class. Therefore, if a base 
-	class has defined a TestFixtureTearDown method, that method will be called 
-	after each test method in the derived class. 
-	
-<p>Before NUnit 2.5, you were permitted only one TestFixtureTearDown method. If you wanted to 
-   have some TestFixtureTearDown functionality in the base class and add more in the derived 
-   class you needed to call the base class method yourself.
-   
-<p>With NUnit 2.5, you can achieve the same result by defining a TestFixtureTearDown method
-   in the base class and another in the derived class. NUnit will call base
-   class TestFixtureTearDown methods after those in the derived classes.
-   
-<p><b>Note:</b> Although it is possible to define multiple TestFixtureTearDown methods
-   in the same class, you should rarely do so. Unlike methods defined in
-   separate classes in the inheritance hierarchy, the order in which they
-   are executed is not guaranteed.
-
-<h4>See also...</h4>
-<ul>
-<li><a href="setup.html">SetUpAttribute</a><li><a href="teardown.html">TearDownAttribute</a><li><a href="fixtureSetup.html">TestFixtureSetUpAttribute</a></ul>
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<ul>
-<li><a href="category.html">Category</a></li>
-<li><a href="combinatorial.html">Combinatorial</a></li>
-<li><a href="culture.html">Culture</a></li>
-<li><a href="datapoint.html">Datapoint(s)</a></li>
-<li><a href="description.html">Description</a></li>
-<li><a href="exception.html">Exception</a></li>
-<li><a href="explicit.html">Explicit</a></li>
-<li><a href="ignore.html">Ignore</a></li>
-<li><a href="maxtime.html">Maxtime</a></li>
-<li><a href="pairwise.html">Pairwise</a></li>
-<li><a href="platform.html">Platform</a></li>
-<li><a href="property.html">Property</a></li>
-<li><a href="random.html">Random</a></li>
-<li><a href="range.html">Range</a></li>
-<li><a href="repeat.html">Repeat</a></li>
-<li><a href="requiredAddin.html">RequiredAddin</a></li>
-<li><a href="requiresMTA.html">Requires&nbsp;MTA</a></li>
-<li><a href="requiresSTA.html">Requires&nbsp;STA</a></li>
-<li><a href="requiresThread.html">Requires&nbsp;Thread</a></li>
-<li><a href="sequential.html">Sequential</a></li>
-<li><a href="setCulture.html">SetCulture</a></li>
-<li><a href="setup.html">Setup</a></li>
-<li><a href="setupFixture.html">SetupFixture</a></li>
-<li><a href="suite.html">Suite</a></li>
-<li><a href="teardown.html">Teardown</a></li>
-<li><a href="test.html">Test</a></li>
-<li><a href="testCase.html">TestCase</a></li>
-<li><a href="testCaseSource.html">TestCaseSource</a></li>
-<li><a href="testFixture.html">TestFixture</a></li>
-<li><a href="fixtureSetup.html">TestFixtureSetUp</a></li>
-<li id="current"><a href="fixtureTeardown.html">TestFixtureTearDown</a></li>
-<li><a href="theory.html">Theory</a></li>
-<li><a href="timeout.html">Timeout</a></li>
-<li><a href="values.html">Values</a></li>
-<li><a href="valueSource.html">ValueSource</a></li>
-</ul>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/getStarted.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/getStarted.html b/lib/NUnit.org/NUnit/2.5.9/doc/getStarted.html
deleted file mode 100644
index de5cea9..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/getStarted.html
+++ /dev/null
@@ -1,80 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - GetStarted</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h2>Getting Started with NUnit</h2>
-
-<p>If you haven't already done so, go to our <a href="http://www.nunit.org/download.html">Download</a>	page, select a version of NUnit and download it. The 
-	<a href="installation.html">Installation</a> page 
-	contains instructions for installing on your system.</p>
-
-<p>To get started using NUnit, read the <a href="quickStart.html">Quick Start</a>	page. This article demonstrates the development process with NUnit in the 
-	context of a C# banking application. Check the 
-	<a href="samples.html">Samples</a> page for additional examples, 
-	including some in VB.Net, J# and managed C++.</p>
-
-<h3>Which Test Runner to use?</h3>
-
-<p>NUnit has two different ways to run your tests. The 
-	<a href="nunit-console.html">console runner</a>, nunit-console.exe, 
-	is the fastest to launch, but is not interactive. 
- 	The <a href="nunit-gui.html">gui runner</a>, 
-	nunit.exe, is a Windows Forms application that allows you to work 
-	selectively with your tests and provides graphical feedback.</p>
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li id="current"><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<ul>
-<li><a href="quickStart.html">Quick&nbsp;Start</a></li>
-<li><a href="installation.html">Installation</a></li>
-</ul>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/guiCommandLine.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/guiCommandLine.html b/lib/NUnit.org/NUnit/2.5.9/doc/guiCommandLine.html
deleted file mode 100644
index d774260..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/guiCommandLine.html
+++ /dev/null
@@ -1,193 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - GuiCommandLine</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h2>NUnit Command Line Options</h2>
-<p>The forms interface may be run with or without the name of a file containing 
-	tests on the command line. If the program is started without any file 
-	specified, it automatically loads the most recently loaded assembly.</p>
-<p><b>Note:</b> Options that take values may use an equal sign, a colon or a space 
-	to separate the option from its value.</p>
-<p><b>Note:</b> Under the Windows operating system, options may be prefixed by either
-    a forward slash or a hyphen. Under Linux, a hyphen must be used. Options that
-	take values may use an equal sign, a colon or a space to separate the option 
-	from its value.</p>
-<h4>Run without loading an Assembly</h4>
-<p>To suppress loading of the most recent assembly, use the <b>/noload</b> switch:
-	<pre class="programtext">        nunit /noload</pre>
-</p>
-<h4>Specifying an Assembly</h4>
-<p>The other option is to specify an assembly or project file name on the command 
-	line. The following will start the forms interface with the assembly 
-	nunit.tests.dll:
-	<pre class="programtext">        nunit nunit.tests.dll</pre>
-</p>
-<p>The following will start the forms interface loading the same assembly through 
-	its Visual Studio project definition:
-	<pre class="programtext">        nunit nunit.tests.csproj</pre>
-</p>
-<p>Assuming an NUnit test project has been created containing the assembly, the 
-	following will again load nunit.tests.dll:
-	<pre class="programtext">        nunit nunit.tests.nunit</pre>
-</p>
-<h4>Specifying an Assembly and a Fixture</h4>
-<p>
-	When specifying a a fixture, you must give the full name of the test fixture 
-	along with the containing assembly. For example, to load only the 
-	NUnit.Tests.AssertionTests in the nunit.tests.dll assembly use the following 
-	command:
-	<pre class="programtext">        nunit /fixture:NUnit.Tests.AssertionTests nunit.tests.dll</pre>
-</p>
-<p>The name specified after the <b>/fixture</b> option may be that of a TestFixture 
-	class, or a namespace. If a namespace is given, then all fixtures under that 
-	namespace are loaded. This option may be used with Visual Studio or NUnit 
-	projects as well.</p>
-
-<h4>Specifying Test Categories to Include or Exclude</h4>
-<p>NUnit provides CategoryAttribute for use in marking tests as belonging to 
-	one or more categories. Categories may be included or excluded in a test run 
-	using the <b>/include</b> or <b>/exclude</b> options. The following command 
-	starts the gui with only the tests in the BaseLine category selected:
-	<pre class="programtext">        nunit myassembly.dll /include:BaseLine</pre>
-</p>
-<p>The following command selects all tests <b>except</b> those in the Database 
-	category:
-	<pre class="programtext">        nunit myassembly.dll /exclude:Database</pre>
-</p>
-<p>
-Multiple categories may be specified on either option, by using commas to 
-separate them.
-<p><b>Note:</b> At this time, the /include and /exclude options may not be
-combined on the command line.</p>
-<!--   
-<h4>Specifying the Version of the CLR</h4>
-
-<p>Most applications are written to run under a specific version of the CLR.
-A few are designed to operate correctly under multiple versions. In either case,
-it is important to be able to specify the CLR version to be used for testing.</p>
-
-<p>When only one version of the CLR is used, the config files for nunit and
-nunit-console may be set up to specify that version. As a more convenient
-alternative when switching CLRs, you may use the provided <b>clr.bat</b>
-command to specify the version under which NUnit should run.</p>
-
-<p>For example, to run the gui under the RTM version of 
-the .Net 2.0 framework, use:</p>
-
-<pre class="programtext">       clr net-2.0 nunit</pre>
-
-<p>The <b>clr.bat</b> file is located in the NUnit <b>bin</b> directory. You may
-put this on your path, or copy it to a convenient location. Enter <b>clr /?</b> 
-for a list of options.</p>
-	
-<p><b>Note:</b> If you use a &lt;startup&gt; section in the config file, it takes
-precedence over this option.</p>
-
-<p><b>Note:</b> This command is specific to the Microsoft .Net 
-framework. The Mono framework provides other means to specify the version
-to be used when running a command and the NUnit Windows interface does
-not currently run under Mono.</p>
--->
-
-<h4>Load and Run All Tests</h4>
-Normally, nunit only loads an assembly and then waits for the user to click 
-on the Run button. If you wish to have the tests run immediately, use the <b>/run</b>
-option:
-<pre class="programtext">        nunit nunit.tests.dll /run</pre>
-</p>
-<h4>Load and Run Selected Tests</h4>
-To load and immediately rerun the last selected tests, use the <b>/runselected</b>
-option:
-<pre class="programtext">        nunit nunit.tests.dll /runselected</pre>
-</p>
-<p><b>Note:</b> If no selection has been saved, this option works just like <b>/run</b>.
-<h4>Specifying which Configuration to Load</h4>
-<p>When loading a Visual Studio project or an NUnit project, the first 
-	configuration found will be loaded by default. Usually this is Debug. The 
-	configuration loaded may be controlled using the <b>/config</b> switch. The 
-	following will load the Release configuration of the nunit.tests.dll:
-	<pre class="programtext">        nunit nunit.tests.csproj /config:Release</pre>
-</p>
-<p><b>Note:</b> This option has no effect when loading an assembly directly.</p>
-<h4>Specifying Multiple Assemblies</h4>
-<p>The forms interface does <b>not</b> currently provide for specifying more than 
-	one assembly on the command line. Multiple-assembly projects must be loaded by 
-	specifying the name of a Visual Studio solution file or an NUnit test project.</p>
-<h4>Clearing the ShadowCopy Cache</h4>
-<p>The <b>/cleanup</b> option erases the shadow copy cache and exits.
-<h4>Displaying Help</h4>
-<p>The <b>/help</b> or <b>/?</b> option displays a message box containing a brief 
-	help message.</p>
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<ul>
-<li><a href="nunit-console.html">Console&nbsp;Runner</a></li>
-<li><a href="nunit-gui.html">Gui&nbsp;Runner</a></li>
-<ul>
-<li id="current"><a href="guiCommandLine.html">Command-Line</a></li>
-<li><a href="mainMenu.html">Main&nbsp;Menu</a></li>
-<li><a href="contextMenu.html">Context&nbsp;Menu</a></li>
-<li><a href="settingsDialog.html">Settings&nbsp;Dialog</a></li>
-<li><a href="addinsDialog.html">Addins&nbsp;Dialog</a></li>
-<li><a href="testProperties.html">Test&nbsp;Properties</a></li>
-<li><a href="configEditor.html">Configuration&nbsp;Editor</a></li>
-<li><a href="projectEditor.html">Project&nbsp;Editor</a></li>
-</ul>
-<li><a href="pnunit.html">PNUnit&nbsp;Runner</a></li>
-<li><a href="runtimeSelection.html">Runtime&nbsp;Selection</a></li>
-<li><a href="assemblyIsolation.html">Assembly&nbsp;Isolation</a></li>
-<li><a href="configFiles.html">Configuration&nbsp;Files</a></li>
-<li><a href="multiAssembly.html">Multiple&nbsp;Assemblies</a></li>
-<li><a href="vsSupport.html">Visual&nbsp;Studio&nbsp;Support</a></li>
-</ul>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/identityAsserts.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/identityAsserts.html b/lib/NUnit.org/NUnit/2.5.9/doc/identityAsserts.html
deleted file mode 100644
index 96f0a37..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/identityAsserts.html
+++ /dev/null
@@ -1,97 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - IdentityAsserts</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h2>Identity Asserts</h2>
-
-<p><b>Assert.AreSame</b> and <b>Assert.AreNotSame</b> test whether the same objects are 
-referenced by the two arguments.</p> 
-
-<div class="code" style="width: 36em" >
-<pre>Assert.AreSame( object expected, object actual );
-Assert.AreSame( object expected, object actual, string message );
-Assert.AreSame( object expected, object actual, string message, 
-                params object[] parms );
-
-Assert.AreNotSame( object expected, object actual );
-Assert.AreNotSame( object expected, object actual, string message );
-Assert.AreNotSame( object expected, object actual, string message, 
-                params object[] parms );</pre>
-</div>
-
-<p><b>Assert.Contains</b> is used to test whether an object is contained in an array 
-or list.</p>
-
-<div class="code" width="36em">
-<pre>Assert.Contains( object anObject, IList collection );
-Assert.Contains( object anObject, IList collection, 
-                string message );
-Assert.Contains( object anObject, IList collection,
-                string message, params object[] parms );</pre>
-</div>
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<ul>
-<li><a href="equalityAsserts.html">Equality&nbsp;Asserts</a></li>
-<li id="current"><a href="identityAsserts.html">Identity&nbsp;Asserts</a></li>
-<li><a href="conditionAsserts.html">Condition&nbsp;Asserts</a></li>
-<li><a href="comparisonAsserts.html">Comparison&nbsp;Asserts</a></li>
-<li><a href="typeAsserts.html">Type&nbsp;Asserts</a></li>
-<li><a href="exceptionAsserts.html">Exception&nbsp;Asserts</a></li>
-<li><a href="utilityAsserts.html">Utility&nbsp;Methods</a></li>
-<li><a href="stringAssert.html">String&nbsp;Assert</a></li>
-<li><a href="collectionAssert.html">Collection&nbsp;Assert</a></li>
-<li><a href="fileAssert.html">File&nbsp;Assert</a></li>
-<li><a href="directoryAssert.html">Directory&nbsp;Assert</a></li>
-</ul>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/ignore.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/ignore.html b/lib/NUnit.org/NUnit/2.5.9/doc/ignore.html
deleted file mode 100644
index 060dd41..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/ignore.html
+++ /dev/null
@@ -1,267 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - Ignore</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<script language="JavaScript" src="codeFuncs.js" ></script> <!-- Do it this way for IE -->
-
-<h3>IgnoreAttribute (NUnit 2.0)</h3>
-
-<p>The ignore attribute is an attribute to not run a test or test fixture for a 
-	period of time. The person marks either a Test or a TestFixture with the Ignore 
-	Attribute. The running program sees the attribute and does not run the test or 
-	tests. The progress bar will turn yellow if a test is not run and the test will 
-	be mentioned in the reports that it was not run.</p>
-
-<p>This feature should be used to temporarily not run a test or fixture. This is a 
-	better mechanism than commenting out the test or renaming methods, since the 
-	tests will be compiled with the rest of the code and there is an indication at 
-	run time that a test is not being run. This insures that tests will not be 
-	forgotten.</p>
-
-<h4>Test Fixture Syntax</h4>
-
-<div class="code">
-
-<div class="langFilter">
-	<a href="javascript:Show('DD1')" onmouseover="Show('DD1')"><img src="img/langFilter.gif" width="14" height="14" alt="Language Filter"></a>
-	<div id="DD1" class="dropdown" style="display: none;" onclick="Hide('DD1')">
-		<a href="javascript:ShowCS()">C#</a><br>
-		<a href="javascript:ShowVB()">VB</a><br>
-		<a href="javascript:ShowMC()">C++</a><br>
-		<a href="javascript:ShowJS()">J#</a><br>
-	</div>
-</div>
-
-<pre class="cs">namespace NUnit.Tests
-{
-  using System;
-  using NUnit.Framework;
-
-  [TestFixture]
-  [Ignore(&quot;Ignore a fixture&quot;)]
-  public class SuccessTests
-  {
-    // ...
-  }
-}
-</pre>
-
-<pre class="vb">Imports System
-Imports Nunit.Framework
-
-Namespace Nunit.Tests
-
-  &lt;TestFixture(), Ignore(&quot;Ignore a fixture&quot;)&gt;
-  Public Class SuccessTests
-    &#39; ...
-  End Class
-End Namespace
-</pre>
-
-<pre class="mc">#using &lt;Nunit.Framework.dll&gt;
-using namespace System;
-using namespace NUnit::Framework;
-
-namespace NUnitTests
-{
-  [TestFixture]
-  [Ignore(&quot;Ignore a fixture&quot;)]
-  public __gc class SuccessTests
-  {
-    // ...
-  };
-}
-
-#include &quot;cppsample.h&quot;
-
-namespace NUnitTests {
-  // ...
-}
-</pre>
-
-<pre class="js">package NUnit.Tests;
-
-import System.*;
-import NUnit.Framework.TestFixture;
-
-
-/** @attribute NUnit.Framework.TestFixture() */
-/** @attribute NUnit.Framework.Ignore(&quot;Ignore a fixture&quot;) */
-public class SuccessTests
-{
-  // ...
-}
-</pre>
-	
-</div>
-
-<h4>Test Syntax</h4>
-
-<div class="code">
-
-<div class="langFilter">
-	<a href="javascript:Show('DD2')" onmouseover="Show('DD2')"><img src="img/langFilter.gif" width="14" height="14" alt="Language Filter"></a>
-	<div id="DD2" class="dropdown" style="display: none;" onclick="Hide('DD2')">
-		<a href="javascript:ShowCS()">C#</a><br>
-		<a href="javascript:ShowVB()">VB</a><br>
-		<a href="javascript:ShowMC()">C++</a><br>
-		<a href="javascript:ShowJS()">J#</a><br>
-	</div>
-</div>
-
-<pre class="cs">namespace NUnit.Tests
-{
-  using System;
-  using NUnit.Framework;
-
-  [TestFixture]
-  public class SuccessTests
-  {
-    [Test]
-    [Ignore(&quot;Ignore a test&quot;)]
-    public void IgnoredTest()
-    { /* ... */ }
-}
-</pre>
-
-<pre class="vb">Imports System
-Imports Nunit.Framework
-
-Namespace Nunit.Tests
-
-  &lt;TestFixture()&gt;
-  Public Class SuccessTests
-    &lt;Test(), Ignore(&quot;Ignore a test&quot;)&gt; Public Sub Ignored()
-      &#39; ...
-    End Sub
-  End Class
-End Namespace
-</pre>
-
-<pre class="mc">#using &lt;Nunit.Framework.dll&gt;
-using namespace System;
-using namespace NUnit::Framework;
-
-namespace NUnitTests
-{
-  [TestFixture]
-  public __gc class SuccessTests
-  {
-    [Test][Ignore(&quot;Ignore a test&quot;)] void IgnoredTest();
-  };
-}
-
-#include &quot;cppsample.h&quot;
-
-namespace NUnitTests {
-  // ...
-}
-</pre>
-
-<pre class="js">package NUnit.Tests;
-
-import System.*;
-import NUnit.Framework.TestFixture;
-
-
-/** @attribute NUnit.Framework.TestFixture() */
-public class SuccessTests
-{
-  /** @attribute NUnit.Framework.Test() */
-  /** @attribute NUnit.Framework.Ignore(&quot;ignored test&quot;) */
-  public void IgnoredTest()
-  { /* ... */ }
-}
-</pre>
-
-</div>
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<ul>
-<li><a href="category.html">Category</a></li>
-<li><a href="combinatorial.html">Combinatorial</a></li>
-<li><a href="culture.html">Culture</a></li>
-<li><a href="datapoint.html">Datapoint(s)</a></li>
-<li><a href="description.html">Description</a></li>
-<li><a href="exception.html">Exception</a></li>
-<li><a href="explicit.html">Explicit</a></li>
-<li id="current"><a href="ignore.html">Ignore</a></li>
-<li><a href="maxtime.html">Maxtime</a></li>
-<li><a href="pairwise.html">Pairwise</a></li>
-<li><a href="platform.html">Platform</a></li>
-<li><a href="property.html">Property</a></li>
-<li><a href="random.html">Random</a></li>
-<li><a href="range.html">Range</a></li>
-<li><a href="repeat.html">Repeat</a></li>
-<li><a href="requiredAddin.html">RequiredAddin</a></li>
-<li><a href="requiresMTA.html">Requires&nbsp;MTA</a></li>
-<li><a href="requiresSTA.html">Requires&nbsp;STA</a></li>
-<li><a href="requiresThread.html">Requires&nbsp;Thread</a></li>
-<li><a href="sequential.html">Sequential</a></li>
-<li><a href="setCulture.html">SetCulture</a></li>
-<li><a href="setup.html">Setup</a></li>
-<li><a href="setupFixture.html">SetupFixture</a></li>
-<li><a href="suite.html">Suite</a></li>
-<li><a href="teardown.html">Teardown</a></li>
-<li><a href="test.html">Test</a></li>
-<li><a href="testCase.html">TestCase</a></li>
-<li><a href="testCaseSource.html">TestCaseSource</a></li>
-<li><a href="testFixture.html">TestFixture</a></li>
-<li><a href="fixtureSetup.html">TestFixtureSetUp</a></li>
-<li><a href="fixtureTeardown.html">TestFixtureTearDown</a></li>
-<li><a href="theory.html">Theory</a></li>
-<li><a href="timeout.html">Timeout</a></li>
-<li><a href="values.html">Values</a></li>
-<li><a href="valueSource.html">ValueSource</a></li>
-</ul>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/img/addinsDialog.jpg
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/img/addinsDialog.jpg b/lib/NUnit.org/NUnit/2.5.9/doc/img/addinsDialog.jpg
deleted file mode 100644
index 01e2b15..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/doc/img/addinsDialog.jpg and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/img/advancedSettings.jpg
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/img/advancedSettings.jpg b/lib/NUnit.org/NUnit/2.5.9/doc/img/advancedSettings.jpg
deleted file mode 100644
index 74b83d4..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/doc/img/advancedSettings.jpg and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/img/assembliesTab.jpg
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/img/assembliesTab.jpg b/lib/NUnit.org/NUnit/2.5.9/doc/img/assembliesTab.jpg
deleted file mode 100644
index cb20495..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/doc/img/assembliesTab.jpg and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/img/assemblyReloadSettings.jpg
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/img/assemblyReloadSettings.jpg b/lib/NUnit.org/NUnit/2.5.9/doc/img/assemblyReloadSettings.jpg
deleted file mode 100644
index 42f1b0f..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/doc/img/assemblyReloadSettings.jpg and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/img/bulletOff.gif
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/img/bulletOff.gif b/lib/NUnit.org/NUnit/2.5.9/doc/img/bulletOff.gif
deleted file mode 100644
index c709ef4..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/doc/img/bulletOff.gif and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/img/bulletOn.gif
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/img/bulletOn.gif b/lib/NUnit.org/NUnit/2.5.9/doc/img/bulletOn.gif
deleted file mode 100644
index a565da5..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/doc/img/bulletOn.gif and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/img/configEditor.jpg
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/img/configEditor.jpg b/lib/NUnit.org/NUnit/2.5.9/doc/img/configEditor.jpg
deleted file mode 100644
index 81b6f3d..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/doc/img/configEditor.jpg and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/img/console-mock.jpg
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/img/console-mock.jpg b/lib/NUnit.org/NUnit/2.5.9/doc/img/console-mock.jpg
deleted file mode 100644
index 103cb5d..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/doc/img/console-mock.jpg and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/img/generalSettings.jpg
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/img/generalSettings.jpg b/lib/NUnit.org/NUnit/2.5.9/doc/img/generalSettings.jpg
deleted file mode 100644
index 8a197e7..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/doc/img/generalSettings.jpg and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/img/generalTab.jpg
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/img/generalTab.jpg b/lib/NUnit.org/NUnit/2.5.9/doc/img/generalTab.jpg
deleted file mode 100644
index 0e2273c..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/doc/img/generalTab.jpg and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/img/gui-screenshot.jpg
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/img/gui-screenshot.jpg b/lib/NUnit.org/NUnit/2.5.9/doc/img/gui-screenshot.jpg
deleted file mode 100644
index 88224ce..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/doc/img/gui-screenshot.jpg and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/img/gui-verify.jpg
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/img/gui-verify.jpg b/lib/NUnit.org/NUnit/2.5.9/doc/img/gui-verify.jpg
deleted file mode 100644
index d8cbc96..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/doc/img/gui-verify.jpg and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/img/internalTraceSettings.jpg
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/img/internalTraceSettings.jpg b/lib/NUnit.org/NUnit/2.5.9/doc/img/internalTraceSettings.jpg
deleted file mode 100644
index e47d1bb..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/doc/img/internalTraceSettings.jpg and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/img/langFilter.gif
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/img/langFilter.gif b/lib/NUnit.org/NUnit/2.5.9/doc/img/langFilter.gif
deleted file mode 100644
index 7cdf454..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/doc/img/langFilter.gif and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/img/logo.gif
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/img/logo.gif b/lib/NUnit.org/NUnit/2.5.9/doc/img/logo.gif
deleted file mode 100644
index 7540a66..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/doc/img/logo.gif and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/img/miniGui.jpg
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/img/miniGui.jpg b/lib/NUnit.org/NUnit/2.5.9/doc/img/miniGui.jpg
deleted file mode 100644
index 6c5e703..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/doc/img/miniGui.jpg and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/img/testLoadSettings.jpg
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/img/testLoadSettings.jpg b/lib/NUnit.org/NUnit/2.5.9/doc/img/testLoadSettings.jpg
deleted file mode 100644
index 146325f..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/doc/img/testLoadSettings.jpg and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/img/testOutputSettings.jpg
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/img/testOutputSettings.jpg b/lib/NUnit.org/NUnit/2.5.9/doc/img/testOutputSettings.jpg
deleted file mode 100644
index 390ee90..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/doc/img/testOutputSettings.jpg and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/img/testProperties.jpg
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/img/testProperties.jpg b/lib/NUnit.org/NUnit/2.5.9/doc/img/testProperties.jpg
deleted file mode 100644
index ad02778..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/doc/img/testProperties.jpg and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/img/testResultSettings.jpg
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/img/testResultSettings.jpg b/lib/NUnit.org/NUnit/2.5.9/doc/img/testResultSettings.jpg
deleted file mode 100644
index bd3f796..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/doc/img/testResultSettings.jpg and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/img/textOutputSettings.jpg
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/img/textOutputSettings.jpg b/lib/NUnit.org/NUnit/2.5.9/doc/img/textOutputSettings.jpg
deleted file mode 100644
index df846b9..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/doc/img/textOutputSettings.jpg and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/img/treeDisplaySettings.jpg
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/img/treeDisplaySettings.jpg b/lib/NUnit.org/NUnit/2.5.9/doc/img/treeDisplaySettings.jpg
deleted file mode 100644
index 113c662..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/doc/img/treeDisplaySettings.jpg and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/img/visualStudioSettings.jpg
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/img/visualStudioSettings.jpg b/lib/NUnit.org/NUnit/2.5.9/doc/img/visualStudioSettings.jpg
deleted file mode 100644
index 75800c5..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/doc/img/visualStudioSettings.jpg and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/index.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/index.html b/lib/NUnit.org/NUnit/2.5.9/doc/index.html
deleted file mode 100644
index 9f518bf..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/index.html
+++ /dev/null
@@ -1,77 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - DocHome</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h2>NUnit 2.5.9</h2>
-	
-<p>This documentation covers the NUnit 2.5.9 release, 
-   introducing a large set of new features to NUnit, particularly in
-   the area of parameterized or data-driven testing.
-
-<p>Where applicable, we have marked sections with the version in which a feature 
-   first appeared.</p>
-
-<p>If you are new to NUnit, we suggest you begin by reading the 
-	<a href="getStarted.html">Getting Started</a> section of this site.
-	 Those who have used earlier releases may want to begin with the 
-	<a href="upgrade.html">Upgrading</a> section.</p>
-
-<p>See the 
-   <a href="releaseNotes.html">Release Notes</a>   for more information on this release.</p>
-
-<p>All documentation is included in the release packages of NUnit. Beginning with NUnit 
-2.4.2, you may choose to <a href="http://www.nunit.org/download.html">download</a> the documentation
-separately.</p>
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li id="current"><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>


[20/51] [abbrv] [partial] Cleaning up and getting ready to development towards v4.8

Posted by sy...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/culture.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/culture.html b/lib/NUnit.org/NUnit/2.5.9/doc/culture.html
deleted file mode 100644
index 07b3f07..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/culture.html
+++ /dev/null
@@ -1,273 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - Culture</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<script language="JavaScript" src="codeFuncs.js" ></script> <!-- Do it this way for IE -->
-
-<style><!--
-div.code { width: 34em }
---></style>
-
-<h3>CultureAttribute (NUnit 2.4.2)</h3> 
-<p>The Culture attribute is used to specify cultures for which a test or fixture
-	should be run. It does not affect the culture setting, but merely uses it to 
-	determine whether to run the test. If you wish to change the culture when
-	running a test, use the SetCulture attribute instead.</p>
-	
-<p>If the specified culture requirements for a test are not met it is skipped.
-   In the gui, the tree node for the test remains gray and the status bar color is 
-   not affected.</p>
-
-<p>One use of the Culture attribute is to provide alternative tests under different
-cultures. You may specify either specific cultures, like "en-GB" or neutral
-cultures like "de".</p>
-
-<h4>Test Fixture Syntax</h4>
-
-<div class="code">
-
-<div class="langFilter">
-	<a href="javascript:Show('DD1')" onmouseover="Show('DD1')"><img src="img/langFilter.gif" width="14" height="14" alt="Language Filter"></a>
-	<div id="DD1" class="dropdown" style="display: none;" onclick="Hide('DD1')">
-		<a href="javascript:ShowCS()">C#</a><br>
-		<a href="javascript:ShowVB()">VB</a><br>
-		<a href="javascript:ShowMC()">C++</a><br>
-		<a href="javascript:ShowJS()">J#</a><br>
-	</div>
-</div>
-
-<pre class="cs">namespace NUnit.Tests
-{
-  using System;
-  using NUnit.Framework;
-
-  [TestFixture]
-  [Culture(&quot;fr-FR&quot;)]
-  public class FrenchCultureTests
-  {
-    // ...
-  }
-}
-</pre>
-
-<pre class="vb">Imports System
-Imports Nunit.Framework
-
-Namespace Nunit.Tests
-
-  &lt;TestFixture(), Culture(&quot;fr-FR&quot;)&gt;
-  Public Class FrenchCultureTests
-    &#39; ...
-  End Class
-End Namespace
-</pre>
-
-<pre class="mc">#using &lt;Nunit.Framework.dll&gt;
-using namespace System;
-using namespace NUnit::Framework;
-
-namespace NUnitTests
-{
-  [TestFixture]
-  [Culture(&quot;fr-FR&quot;)]
-  public __gc class FrenchCultureTests
-  {
-    // ...
-  };
-}
-
-#include &quot;cppsample.h&quot;
-
-namespace NUnitTests {
-  // ...
-}
-</pre>
-
-<pre class="js">package NUnit.Tests;
-
-import System.*;
-import NUnit.Framework.TestFixture;
-
-
-/** @attribute NUnit.Framework.TestFixture() */
-/** @attribute NUnit.Framework.Culture(&quot;fr-FR&quot;) */
-public class FrenchCultureTests
-{
-  // ...
-}
-</pre>
-</div>
-<h4>Test Syntax</h4>
-<div class="code">
-	
-<div class="langFilter">
-	<a href="javascript:Show('DD2')" onmouseover="Show('DD2')"><img src="img/langFilter.gif" width="14" height="14" alt="Language Filter"></a>
-	<div id="DD2" class="dropdown" style="display: none;" onclick="Hide('DD2')">
-		<a href="javascript:ShowCS()">C#</a><br>
-		<a href="javascript:ShowVB()">VB</a><br>
-		<a href="javascript:ShowMC()">C++</a><br>
-		<a href="javascript:ShowJS()">J#</a><br>
-	</div>
-</div>
-
-<pre class="cs">namespace NUnit.Tests
-{
-  using System;
-  using NUnit.Framework;
-
-  [TestFixture]
-  public class SuccessTests
-  {
-    [Test]
-    [Culture(Exclude=&quot;en,de&quot;)]
-    public void SomeTest()
-    { /* ... */ }
-}
-</pre>
-
-<pre class="vb">Imports System
-Imports Nunit.Framework
-
-Namespace Nunit.Tests
-
-  &lt;TestFixture()&gt;
-  Public Class SuccessTests
-    &lt;Test(), Culture(Exclude=&quot;en,de&quot;)&gt; Public Sub SomeTest()
-      &#39; ...
-    End Sub
-  End Class
-End Namespace
-</pre>
-
-<pre class="mc">#using &lt;Nunit.Framework.dll&gt;
-using namespace System;
-using namespace NUnit::Framework;
-
-namespace NUnitTests
-{
-  [TestFixture]
-  public __gc class SuccessTests
-  {
-    [Test][Culture(Exclude=&quot;en,de&quot;)] void SomeTest();
-  };
-}
-
-#include &quot;cppsample.h&quot;
-
-namespace NUnitTests {
-  // ...
-}
-</pre>
-
-<pre class="js">package NUnit.Tests;
-
-import System.*;
-import NUnit.Framework.TestFixture;
-
-
-/** @attribute NUnit.Framework.TestFixture() */
-public class SuccessTests
-{
-  /** @attribute NUnit.Framework.Test() */
-  /** @attribute NUnit.Framework.Culture(Exclude=en,de&quot;) */
-  public void SomeTest()
-  { /* ... */ }
-}
-</pre>
-
-</div>
-
-<h4>See also...</h4>
-<ul>
-<li><a href="setCulture.html">SetCultureAttribute</a></ul>
-
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<ul>
-<li><a href="category.html">Category</a></li>
-<li><a href="combinatorial.html">Combinatorial</a></li>
-<li id="current"><a href="culture.html">Culture</a></li>
-<li><a href="datapoint.html">Datapoint(s)</a></li>
-<li><a href="description.html">Description</a></li>
-<li><a href="exception.html">Exception</a></li>
-<li><a href="explicit.html">Explicit</a></li>
-<li><a href="ignore.html">Ignore</a></li>
-<li><a href="maxtime.html">Maxtime</a></li>
-<li><a href="pairwise.html">Pairwise</a></li>
-<li><a href="platform.html">Platform</a></li>
-<li><a href="property.html">Property</a></li>
-<li><a href="random.html">Random</a></li>
-<li><a href="range.html">Range</a></li>
-<li><a href="repeat.html">Repeat</a></li>
-<li><a href="requiredAddin.html">RequiredAddin</a></li>
-<li><a href="requiresMTA.html">Requires&nbsp;MTA</a></li>
-<li><a href="requiresSTA.html">Requires&nbsp;STA</a></li>
-<li><a href="requiresThread.html">Requires&nbsp;Thread</a></li>
-<li><a href="sequential.html">Sequential</a></li>
-<li><a href="setCulture.html">SetCulture</a></li>
-<li><a href="setup.html">Setup</a></li>
-<li><a href="setupFixture.html">SetupFixture</a></li>
-<li><a href="suite.html">Suite</a></li>
-<li><a href="teardown.html">Teardown</a></li>
-<li><a href="test.html">Test</a></li>
-<li><a href="testCase.html">TestCase</a></li>
-<li><a href="testCaseSource.html">TestCaseSource</a></li>
-<li><a href="testFixture.html">TestFixture</a></li>
-<li><a href="fixtureSetup.html">TestFixtureSetUp</a></li>
-<li><a href="fixtureTeardown.html">TestFixtureTearDown</a></li>
-<li><a href="theory.html">Theory</a></li>
-<li><a href="timeout.html">Timeout</a></li>
-<li><a href="values.html">Values</a></li>
-<li><a href="valueSource.html">ValueSource</a></li>
-</ul>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/customConstraints.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/customConstraints.html b/lib/NUnit.org/NUnit/2.5.9/doc/customConstraints.html
deleted file mode 100644
index 7c5baab..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/customConstraints.html
+++ /dev/null
@@ -1,112 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - CustomConstraints</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h2>Custom Constraints (NUnit 2.4 / 2.5)</h2>
-
-<p>You can implement your own custom constraints by creating a class that 
-inherits from the <b>Constraint</b> abstract class, which supports performing a 
-test on an actual value and generating appropriate messages. The class includes
-two abstract methods, which you must override and four virtual methods with
-default implementation that may be overridden as needed:
-   
-<div class="code" style="width: 36em">
-<pre>public abstract class Constraint
-{
- 	...
-    public abstract bool Matches( object actual );
-    public virtual bool Matches( ActualValueDelegate del );
-    public virtual bool Matches&lt;T&gt;( ref T actual );
-    public abstract void WriteDescriptionTo( MessageWriter writer );
-    public virtual void WriteMessageTo( MessageWriter writer );
-    public virtual void WriteActualValueTo( MessageWriter writer );
-	...
-}</pre>
-</div>   
-
-<p>Your derived class should save the actual argument to Matches in the protected
-field actual for later use.
-
-<p>The MessageWriter abstract class is implemented in the framework by
-TextMessageWriter. Examining the source for some of the builtin constraints
-should give you a good idea of how to use it if you have special formatting
-requirements for error messages.
-
-<h3>Custom Constraint Syntax</h3>
-
-<p>NUnit includes classes that implement a special constraint syntax,
-allowing you to write things like...
-
-<div class="code">
-<pre>Assert.That( myArray, Is.All.InRange(1,100) );</pre>
-</div>
-
-<p>Of course, the NUnit constraint syntax will not be aware of your
-custom constraint unless you modify NUnit itself. As an alternative,
-you may use the <b>Matches(Constraint)</b> syntactic element in order
-to write code like...
-
-<div class="code">
-<pre>MyConstraint myConstraint = new MyConstraint();
-Assert.That( myArray, Has.Some.Matches(myConstraint) );</pre>
-</div>
-
-
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<ul>
-<li id="current"><a href="customConstraints.html">Custom&nbsp;Constraints</a></li>
-<li><a href="nunitAddins.html">NUnit&nbsp;Addins</a></li>
-<li><a href="extensionTips.html">Tips&nbsp;for&nbsp;Extenders</a></li>
-</ul>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/datapoint.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/datapoint.html b/lib/NUnit.org/NUnit/2.5.9/doc/datapoint.html
deleted file mode 100644
index 5a5e25d..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/datapoint.html
+++ /dev/null
@@ -1,142 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - Datapoint</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h3>DatapointAttribute / DatapointsAttribute (NUnit 2.5) (Experimental)</h3>
-
-<p>The <b>Datapoint</b> and <b>Datapoints</b> attributes are used
-   to provide data for <b>Theories</b> and are ignored for ordinary
-   tests - including tests with parameters.
-   
-<h4>DataPointAttribute</h4>
-   
-<p>When a Theory is loaded, NUnit creates arguments for each
-   of its parameters by using any fields of the same type
-   as the parameter annotated with the <b>DatapointAttribute</b>.
-   Fields must be members of the class containing the Theory
-   and their Type must exactly match the argument for which
-   data is being supplied.
-   
-<h4>DataPointsAttribute</h4>
-   
-<p>In addition to specifying individual datapoints, collections of
-   datapoints may be provided by use of the <b>DatapointsAttribute</b>
-   - note the spelling. This attribute may be placed on methods or
-   properties in addition to fields. The returned value must be
-   either an array of the required type or (beginning with NUnit
-   2.5.5) an <b>IEnumerable&lt;T&gt;</b> returning an enumeration
-   of the required type. The data Type must exactly match the argument 
-   for which data is being supplied.
-   
-<h4>Automatically Supplied Datapoints</h4>
-
-<p>It is normally not necessary to specify datapoints for 
-   <b>boolean</b> or <b>enum</b> arguments. Beginning with
-   version 2.5.4, NUnit automatically supplies values of <b>true</b> 
-   and <b>false</b> for <b>boolean</b> arguments and will supply all 
-   defined values of any enumeration.
-   
-<p>If for some reason you don't wish to use all possible values, you
-   can override this behavior by supplying your own datapoints. If you
-   supply any datapoints for an argument, automatic datapoint generation 
-   is suppressed.
-   
-<h4>Example</h4>
-
-<p>For an example of use, see <a href="theory.html">TheoryAttribute</a>.
-   
-<h4>See also...</h4>
-
-<ul>
-<li><a href="theory.html">TheoryAttribute</a><li><a href="parameterizedTests.html">Parameterized Tests</a></ul>
-   
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<ul>
-<li><a href="category.html">Category</a></li>
-<li><a href="combinatorial.html">Combinatorial</a></li>
-<li><a href="culture.html">Culture</a></li>
-<li id="current"><a href="datapoint.html">Datapoint(s)</a></li>
-<li><a href="description.html">Description</a></li>
-<li><a href="exception.html">Exception</a></li>
-<li><a href="explicit.html">Explicit</a></li>
-<li><a href="ignore.html">Ignore</a></li>
-<li><a href="maxtime.html">Maxtime</a></li>
-<li><a href="pairwise.html">Pairwise</a></li>
-<li><a href="platform.html">Platform</a></li>
-<li><a href="property.html">Property</a></li>
-<li><a href="random.html">Random</a></li>
-<li><a href="range.html">Range</a></li>
-<li><a href="repeat.html">Repeat</a></li>
-<li><a href="requiredAddin.html">RequiredAddin</a></li>
-<li><a href="requiresMTA.html">Requires&nbsp;MTA</a></li>
-<li><a href="requiresSTA.html">Requires&nbsp;STA</a></li>
-<li><a href="requiresThread.html">Requires&nbsp;Thread</a></li>
-<li><a href="sequential.html">Sequential</a></li>
-<li><a href="setCulture.html">SetCulture</a></li>
-<li><a href="setup.html">Setup</a></li>
-<li><a href="setupFixture.html">SetupFixture</a></li>
-<li><a href="suite.html">Suite</a></li>
-<li><a href="teardown.html">Teardown</a></li>
-<li><a href="test.html">Test</a></li>
-<li><a href="testCase.html">TestCase</a></li>
-<li><a href="testCaseSource.html">TestCaseSource</a></li>
-<li><a href="testFixture.html">TestFixture</a></li>
-<li><a href="fixtureSetup.html">TestFixtureSetUp</a></li>
-<li><a href="fixtureTeardown.html">TestFixtureTearDown</a></li>
-<li><a href="theory.html">Theory</a></li>
-<li><a href="timeout.html">Timeout</a></li>
-<li><a href="values.html">Values</a></li>
-<li><a href="valueSource.html">ValueSource</a></li>
-</ul>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/datapointProviders.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/datapointProviders.html b/lib/NUnit.org/NUnit/2.5.9/doc/datapointProviders.html
deleted file mode 100644
index 3d8d069..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/datapointProviders.html
+++ /dev/null
@@ -1,124 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - DatapointProviders</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h3>DataPointProviders (NUnit 2.5)</h3>
-
-<h4>Purpose</h4>
-<p>DataPointProviders are used to supply data for an individual parameter
-of a parameterized test method.
-
-<h4>Extension Point</h4>
-<p>Addins use the host to access this extension point by name:
-
-<pre>
-	IExtensionPoint listeners = host.GetExtensionPoint( "DataPointProviders" );</pre>
-
-<h4>Interface</h4>
-<p>The extension object passed to Install must implement either the
-   <b>IDataPointProvider</b> or the <b>IDataPointProvider2</b> interface:
-
-<pre>
-	public interface IDataPointProvider
-	{
-		bool HasDataFor( ParameterInfo parameter );
-		IEnumerable GetDataFor( ParameterInfo parameter );
-	}
-	
-	public interface IDataPointProvider2 : IDatapointProvider
-	{
-		bool HasDataFor( ParameterInfo parameter, Test parentSuite );
-		IEnumerable GetDataFor( ParameterInfo parameter, Test parentSuite );
-	}
-</pre>
-
-<p>NUnit will call <b>IDataPointProvider2</b> if it is available. Otherwise
-   <b>IDataPointProvider</b> will be used.
-
-<p>The <b>HasDataFor</b> method should return true if the provider is able to
-   supply data for the specified parameter. If a provider only wants to be used 
-   on certain types of tests, it can examine the supplied ParameterInfo and
-   its associated MethodInfo and Type and/or the parent test suite.
-
-<p>The <b>GetDataFor</b> method should return a list of individual values to
-   use for the supplied parameter in running the test.
-   
-<h4>Notes:</h4>
-
-<ol>
-<li>Most providers will delegate one of the interface implementations
-    to the other if they implement both.
-<li>DataPointProviders that use data from the fixture class should use 
-    <b>IDataPointProvider2</b> interface so that they are able to access any 
-	arguments supplied for constructing the fixture object.
-<li>Providers that acquire data from outside the fixture will usually
-    be able to work with <b>IDataPointProvider</b> alone.
-<li>The <b>IDataPointProvider2</b> interface was added in the NUnit 2.5.1 release.
-</ol>
-   
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<ul>
-<li><a href="customConstraints.html">Custom&nbsp;Constraints</a></li>
-<li><a href="nunitAddins.html">NUnit&nbsp;Addins</a></li>
-<ul>
-<li><a href="suiteBuilders.html">SuiteBuilders</a></li>
-<li><a href="testcaseBuilders.html">TestcaseBuilders</a></li>
-<li><a href="testDecorators.html">TestDecorators</a></li>
-<li><a href="testcaseProviders.html">TestcaseProviders</a></li>
-<li id="current"><a href="datapointProviders.html">DatapointProviders</a></li>
-<li><a href="eventListeners.html">EventListeners</a></li>
-</ul>
-<li><a href="extensionTips.html">Tips&nbsp;for&nbsp;Extenders</a></li>
-</ul>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/delayedConstraint.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/delayedConstraint.html b/lib/NUnit.org/NUnit/2.5.9/doc/delayedConstraint.html
deleted file mode 100644
index 7a1887e..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/delayedConstraint.html
+++ /dev/null
@@ -1,94 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - DelayedConstraint</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h2>Delayed Constraint (NUnit 2.5)</h2>
-
-<p><b>DelayedConstraint</b> delays the application of another constraint until a certain
-   amount of time has passed. In it's simplest form, it replaces use of a Sleep 
-   in the code but it also supports polling, which may allow use of a longer 
-   maximum time while still keeping the tests as fast as possible. 
-   
-<p>The <b>After</b> modifier is permitted on any constraint, and the delay applies to 
-   the entire expression up to the point where <b>After</b> appears. 
-
-<p>Use of a <b>DelayedConstraint</b> with a value argument makes no sense, since 
-   the value will be extracted at the point of call. It's intended use is with 
-   delegates and references. If a delegate is used with polling, it may be called 
-   multiple times so only methods without side effects should be used in this way. 
-
-<table class="constraints">
-<tr><th>Syntax Helper</th><th>Constructor</th><th>Operation</th></tr>
-<tr><td>After(int)</td><td>DelayedConstraint(Constraint, int)</td></td><td>tests that a constraint is satisfied after a delay.</tr>
-<tr><td>After(int, int)</td><td>DelayedConstraint(Constraint, int, int)</td></td><td>tests that a constraint is satisfied after a delay using polling.</tr>
-</table>
-
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<ul>
-<li><a href="equalConstraint.html">Equal&nbsp;Constraint</a></li>
-<li><a href="sameasConstraint.html">SameAs&nbsp;Constraint</a></li>
-<li><a href="conditionConstraints.html">Condition&nbsp;Constraints</a></li>
-<li><a href="comparisonConstraints.html">Comparison&nbsp;Constrants</a></li>
-<li><a href="pathConstraints.html">Path&nbsp;Constraints</a></li>
-<li><a href="typeConstraints.html">Type&nbsp;Constraints</a></li>
-<li><a href="stringConstraints.html">String&nbsp;Constraints</a></li>
-<li><a href="collectionConstraints.html">Collection&nbsp;Constraints</a></li>
-<li><a href="propertyConstraint.html">Property&nbsp;Constraint</a></li>
-<li><a href="throwsConstraint.html">Throws&nbsp;Constraint</a></li>
-<li><a href="compoundConstraints.html">Compound&nbsp;Constraints</a></li>
-<li id="current"><a href="delayedConstraint.html">Delayed&nbsp;Constraint</a></li>
-<li><a href="listMapper.html">List&nbsp;Mapper</a></li>
-<li><a href="reusableConstraint.html">Reusable&nbsp;Constraint</a></li>
-</ul>
-<li><a href="attributes.html">Attributes</a></li>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/description.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/description.html b/lib/NUnit.org/NUnit/2.5.9/doc/description.html
deleted file mode 100644
index 8b4e9b0..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/description.html
+++ /dev/null
@@ -1,196 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - Description</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<script language="JavaScript" src="codeFuncs.js" ></script> <!-- Do it this way for IE -->
-
-<h3>Description (NUnit 2.4)</h3>
-
-<p>The Description attribute is used to apply descriptive text to a Test,
-TestFixture or Assembly. The text appears in the XML output file and is 
-shown in the Test Properties dialog.</p>
-
-<h4>Example:</h4>
-
-<div class="code">
-
-<div class="langFilter">
-	<a href="javascript:Show('DD1')" onmouseover="Show('DD1')"><img src="img/langFilter.gif" width="14" height="14" alt="Language Filter"></a>
-	<div id="DD1" class="dropdown" style="display: none;" onclick="Hide('DD1')">
-		<a href="javascript:ShowCS()">C#</a><br>
-		<a href="javascript:ShowVB()">VB</a><br>
-		<a href="javascript:ShowMC()">C++</a><br>
-		<a href="javascript:ShowJS()">J#</a><br>
-	</div>
-</div>
-
-<pre class="cs">[assembly: Description("Assembly description here")]
-
-namespace NUnit.Tests
-{
-  using System;
-  using NUnit.Framework;
-
-  [TestFixture, Description("Fixture description here")]
-  public class SomeTests
-  {
-    [Test, Description("Test description here")] 
-    public void OneTest()
-    { /* ... */ }
-  }
-}
-</pre>
-<pre class="vb">&lt;assembly: Description("Assembly description here")&gt;
-
-Imports System
-Imports Nunit.Framework
-
-Namespace Nunit.Tests
-
-  &lt;TestFixture(), Description("Fixture description here")&gt;_
-  Public Class SomeTests
-    &lt;Test(), Description("Test description here")&gt;_
-    Public Sub OneTest()
-    ' ...
-    End Sub
-  End Class
-End Namespace
-</pre>
-<pre class="mc">[assembly:Description("Assembly description here")]
-
-#using &lt;Nunit.Framework.dll&gt;
-using namespace System;
-using namespace NUnit::Framework;
-
-namespace NUnitTests
-{
-  [TestFixture, Description("Fixture description here")]
-  public __gc class SomeTests
-  {
-    [Test, Description("Test description here")]
-    void OneTest();
-  };
-}
-
-#include "cppsample.h"
-
-namespace NUnitTests {
-  // ...
-}
-</pre>
-
-<pre class="js">/** @assembly NUnit.Framework.Description("Assembly description here") */
-
-package NUnit.Tests;
-
-import System.*;
-import NUnit.Framework.TestFixture;
-
-
-/** @attribute NUnit.Framework.TestFixture() */
-/** @attribute NUnit.Framework.Description("Fixture description here") */
-public class SomeTests
-{
-  /** @attribute NUnit.Framework.Test() */
-  /** @attribute NUnit.Framework.Description("Test description here") */
-  public void OneTest()
-  { /* ... */ }
-}
-</pre>
-</div>
-
-<p><b>Note:</b> The Test and TestFixture attributes continue to support an 
-optional Description property. The Description attribute should be used for 
-new applciations. If both are used, the Description attribute takes precedence.</p>
-	
-
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<ul>
-<li><a href="category.html">Category</a></li>
-<li><a href="combinatorial.html">Combinatorial</a></li>
-<li><a href="culture.html">Culture</a></li>
-<li><a href="datapoint.html">Datapoint(s)</a></li>
-<li id="current"><a href="description.html">Description</a></li>
-<li><a href="exception.html">Exception</a></li>
-<li><a href="explicit.html">Explicit</a></li>
-<li><a href="ignore.html">Ignore</a></li>
-<li><a href="maxtime.html">Maxtime</a></li>
-<li><a href="pairwise.html">Pairwise</a></li>
-<li><a href="platform.html">Platform</a></li>
-<li><a href="property.html">Property</a></li>
-<li><a href="random.html">Random</a></li>
-<li><a href="range.html">Range</a></li>
-<li><a href="repeat.html">Repeat</a></li>
-<li><a href="requiredAddin.html">RequiredAddin</a></li>
-<li><a href="requiresMTA.html">Requires&nbsp;MTA</a></li>
-<li><a href="requiresSTA.html">Requires&nbsp;STA</a></li>
-<li><a href="requiresThread.html">Requires&nbsp;Thread</a></li>
-<li><a href="sequential.html">Sequential</a></li>
-<li><a href="setCulture.html">SetCulture</a></li>
-<li><a href="setup.html">Setup</a></li>
-<li><a href="setupFixture.html">SetupFixture</a></li>
-<li><a href="suite.html">Suite</a></li>
-<li><a href="teardown.html">Teardown</a></li>
-<li><a href="test.html">Test</a></li>
-<li><a href="testCase.html">TestCase</a></li>
-<li><a href="testCaseSource.html">TestCaseSource</a></li>
-<li><a href="testFixture.html">TestFixture</a></li>
-<li><a href="fixtureSetup.html">TestFixtureSetUp</a></li>
-<li><a href="fixtureTeardown.html">TestFixtureTearDown</a></li>
-<li><a href="theory.html">Theory</a></li>
-<li><a href="timeout.html">Timeout</a></li>
-<li><a href="values.html">Values</a></li>
-<li><a href="valueSource.html">ValueSource</a></li>
-</ul>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/directoryAssert.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/directoryAssert.html b/lib/NUnit.org/NUnit/2.5.9/doc/directoryAssert.html
deleted file mode 100644
index 8fa5551..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/directoryAssert.html
+++ /dev/null
@@ -1,168 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - DirectoryAssert</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h2>DirectoryAssert (NUnit 2.5)</h2>
-<p>The DirectoryAssert class provides methods for making asserts about
-file system directories, which may be provided as DirectoryInfos or as strings 
-giving the path to each directory.</p>
-
-<p> <b>DirectoryAssert.AreEqual()</b> and <b>DirectoryAssert.AreNotEqual()</b>
-compare two directories for equality. Directories are considered equal if
-they have the same FullName, Attributes, CreationTime and LastAccessTime.
-
-<p><b>Note:</b> Two different directories containing the same files are not
-considered to be equal.
-
-<div class="code" style="width: 40em"><pre>
-
-DirectoryAssert.AreEqual( DirectoryInfo expected, DirectoryInfo actual );
-DirectoryAssert.AreEqual( DirectoryInfo expected, DirectoryInfo actual, 
-                string message );
-DirectoryAssert.AreEqual( DirectoryInfo expected, DirectoryInfo actual,
-                string message, params object[] args );
-
-DirectoryAssert.AreEqual( string expected, string actual );
-DirectoryAssert.AreEqual( string expected, string actual, 
-                string message );
-DirectoryAssert.AreEqual( string expected, string actual,
-                string message, params object[] args );
-
-DirectoryAssert.AreNotEqual( DirectoryInfo expected, DirectoryInfo actual );
-DirectoryAssert.AreNotEqual( DirectoryInfo expected, DirectoryInfo actual, 
-                string message );
-DirectoryAssert.AreNotEqual( DirectoryInfo expected, DirectoryInfo actual,
-                string message, params object[] args );
-
-DirectoryAssert.AreNotEqual( string expected, string actual );
-DirectoryAssert.AreNotEqual( string expected, string actual, 
-                string message );
-DirectoryAssert.AreNotEqual( string expected, string actual,
-                string message, params object[] args );
-
-</pre></div>
-
-<p><b>DirectoryAssert.IsEmpty()</b> and <b>DirectoryAssert.IsNotEmpty()</b>
-test whether the specified directory is empty.
-
-<div class="code" style="width: 40em"><pre>
-
-DirectoryAssert.IsEmpty( DirectoryInfo directory );
-DirectoryAssert.IsEmpty( DirectoryInfo directory, string message );
-DirectoryAssert.IsEmpty( DirectoryInfo directory,
-                string message, params object[] args );
-
-DirectoryAssert.IsEmpty( string directory );
-DirectoryAssert.IsEmpty( string directory, string message );
-DirectoryAssert.IsEmpty( string directory,
-                string message, params object[] args );
-
-DirectoryAssert.IsNotEmpty( DirectoryInfo directory );
-DirectoryAssert.IsNotEmpty( DirectoryInfo directory, string message );
-DirectoryAssert.IsNotEmpty( DirectoryInfo directory,
-                string message, params object[] args );
-
-DirectoryAssert.IsNotEmpty( string directory );
-DirectoryAssert.IsNotEmpty( string directory, string message );
-DirectoryAssert.IsNotEmpty( string directory,
-                string message, params object[] args );
-
-</pre></div>
-
-<p><b>DirectoryAssert.IsWithin()</b> and <b>DirectoryAssert.IsNotWithin()</b>
-test whether the second directory is a direct or indirect subdirectory
-of the first directory.
-
-<div class="code" style="width: 40em"><pre>
-
-DirectoryAssert.IsWithin( DirectoryInfo expected, DirectoryInfo actual );
-DirectoryAssert.IsWithin( DirectoryInfo expected, DirectoryInfo actual,
-                string message );
-DirectoryAssert.IsWithin( DirectoryInfo expected, DirectoryInfo actual,
-                string message, params object[] args );
-
-DirectoryAssert.IsWithin( string expected, string actual );
-DirectoryAssert.IsWithin( string expected, string actual,
-                string message );
-DirectoryAssert.IsWithin( string expected, string actual,
-                string message, params object[] args );
-
-DirectoryAssert.IsNotWithin( DirectoryInfo expected, DirectoryInfo actual );
-DirectoryAssert.IsNotWithin( DirectoryInfo expected, DirectoryInfo actual,
-                string message );
-DirectoryAssert.IsNotWithin( DirectoryInfo expected, DirectoryInfo actual,
-                string message, params object[] args );
-
-DirectoryAssert.IsNotWithin( string expected, string actual );
-DirectoryAssert.IsNotWithin( string expected, string actual,
-                string message );
-DirectoryAssert.IsNotWithin( string expected, string actual,
-                string message, params object[] args );
-
-</pre></div>
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<ul>
-<li><a href="equalityAsserts.html">Equality&nbsp;Asserts</a></li>
-<li><a href="identityAsserts.html">Identity&nbsp;Asserts</a></li>
-<li><a href="conditionAsserts.html">Condition&nbsp;Asserts</a></li>
-<li><a href="comparisonAsserts.html">Comparison&nbsp;Asserts</a></li>
-<li><a href="typeAsserts.html">Type&nbsp;Asserts</a></li>
-<li><a href="exceptionAsserts.html">Exception&nbsp;Asserts</a></li>
-<li><a href="utilityAsserts.html">Utility&nbsp;Methods</a></li>
-<li><a href="stringAssert.html">String&nbsp;Assert</a></li>
-<li><a href="collectionAssert.html">Collection&nbsp;Assert</a></li>
-<li><a href="fileAssert.html">File&nbsp;Assert</a></li>
-<li id="current"><a href="directoryAssert.html">Directory&nbsp;Assert</a></li>
-</ul>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/equalConstraint.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/equalConstraint.html b/lib/NUnit.org/NUnit/2.5.9/doc/equalConstraint.html
deleted file mode 100644
index 7be1359..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/equalConstraint.html
+++ /dev/null
@@ -1,275 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - EqualConstraint</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h2>Equal Constraint (NUnit 2.4 / 2.5)</h2>
-
-<p>An EqualConstraint is used to test whether an actual value
-   is equal to the expected value supplied in its constructor,
-   optionally within a specified tolerance.
-
-<h4>Constructor</h4>
-<div class="code"><pre>
-EqualConstraint(object expected )
-</pre></div>
-
-<h4>Syntax</h4>
-<div class="code"><pre>
-Is.EqualTo( object expected )
-</pre></div>
-
-<h4>Modifiers</h4>
-<div class="code"><pre>
-...IgnoreCase
-...AsCollection
-...NoClip
-...Within(object tolerance)
-      .Ulps
-      .Percent
-      .Days
-      .Hours
-      .Minutes
-      .Seconds
-      .Milliseconds
-      .Ticks
-...Using(IEqualityComparer comparer)
-...Using(IEqualityComparer&lt;T&gt; comparer)
-...Using(IComparer comparer)
-...Using<T>(IComparer&lt;T&gt; comparer)
-...Using<T>(Comparison&lt;T&gt; comparer)
-</pre></div>
-
-<h4>Comparing Numerics</h4>
-<p>Numerics are compared based on their values. Different types
-   may be compared successfully if their values are equal.
-   
-<p>Using the <b>Within</b> modifier, numerics may be tested
-for equality within a fixed or percent tolerance.
-
-<div class="code"><pre>
-Assert.That(2 + 2, Is.EqualTo(4.0));
-Assert.That(2 + 2 == 4);
-Assert.That(2 + 2, Is.Not.EqualTo(5));
-Assert.That(2 + 2 != 5);
-Assert.That( 5.0, Is.EqualTo( 5 );
-Assert.That( 5.5, Is.EqualTo( 5 ).Within(0.075);
-Assert.That( 5.5, Is.EqualTo( 5 ).Within(1.5).Percent;
-</pre></div>
-
-<h4>Comparing Floating Point Values</h4>
-<p>Values of type float and double are normally compared using a tolerance
-specified by the <b>Within</b> modifier. The special values PositiveInfinity, 
-NegativeInfinity and NaN compare
-as equal to themselves.
-
-<p>With version 2.5, floating-point values may be compared using a tolerance
-in "Units in the Last Place" or ULPs. For certain types of numerical work,
-this is safer than a fixed tolerance because it automatically compensates
-for the added inaccuracy of larger numbers.
-
-<div class="code" style="width: 42em"><pre>
-Assert.That( 2.1 + 1.2, Is.EqualTo( 3.3 ).Within( .0005 );
-Assert.That( double.PositiveInfinity, Is.EqualTo( double.PositiveInfinity ) );
-Assert.That( double.NegativeInfinity, Is.EqualTo( double.NegativeInfinity ) );
-Assert.That( double.NaN, Is.EqualTo( double.NaN ) );
-Assert.That( 20000000000000004.0, Is.EqualTo(20000000000000000.0).Within(1).Ulps);
-</pre></div>
-
-<h4>Comparing Strings</h4>
-
-<p>String comparisons normally respect case. The <b>IgnoreCase</b> modifier 
-   causes the comparison to be case-insensitive. It may also be used when 
-   comparing arrays or collections of strings.
-
-<div class="code"><pre>
-Assert.That( "Hello!", Is.Not.EqualTo( "HELLO!" ) );
-Assert.That( "Hello!", Is.EqualTo( "HELLO!" ).IgnoreCase );
-
-string[] expected = new string[] { "Hello", World" };
-string[] actual = new string[] { "HELLO", "world" };
-Assert.That( actual, Is.EqualTo( expected ).IgnoreCase;
-</pre></div>
-
-<h4>Comparing DateTimes and TimeSpans</h4>
-
-<p><b>DateTimes</b> and <b>TimeSpans</b> may be compared either with or without
-   a tolerance. A tolerance is specified using <b>Within</b> with either a 
-   <b>TimeSpan</b> as an argument or with a numeric value followed by a one of 
-   the time conversion modifiers: <b>Days</b>, <b>Hours</b>, <b>Minutes</b>,
-   <b>Seconds</b>, <b>Milliseconds</b> or <b>Ticks</b>.
-
-<div class="code"><pre>
-DateTime now = DateTime.Now;
-DateTime later = now + TimeSpan.FromHours(1.0);
-
-Assert.That( now, Is.EqualTo(now) );
-Assert.That( later. Is.EqualTo(now).Within(TimeSpan.FromHours(3.0);
-Assert.That( later, Is.EqualTo(now).Within(3).Hours;
-</pre></div>
-
-<h4>Comparing Arrays and Collections</h4>
-
-<p>Since version 2.2, NUnit has been able to compare two single-dimensioned arrays.
-    Beginning with version 2.4, multi-dimensioned arrays, nested arrays (arrays of arrays)
-	and collections may be compared. With version 2.5, any IEnumerable is supported.
-	Two arrays, collections or IEnumerables are considered equal if they have the
-	the same dimensions and if each of the corresponding elements is equal.</p>
-	
-<p>If you want to treat two arrays of different shapes as simple collections 
-   for purposes of comparison, use the <b>AsCollection</b> modifier, which causes 
-   the comparison to be made element by element, without regard for the rank or 
-   dimensions of the array. Note that jagged arrays (arrays of arrays) do not
-   have a single underlying collection. The modifier would be applied
-   to each array separately, which has no effect in most cases. 
-
-<div class="code"><pre>
-int[] i3 = new int[] { 1, 2, 3 };
-double[] d3 = new double[] { 1.0, 2.0, 3.0 };
-int[] iunequal = new int[] { 1, 3, 2 };
-Assert.That(i3, Is.EqualTo(d3));
-Assert.That(i3, Is.Not.EqualTo(iunequal));
-
-int array2x2 = new int[,] { { 1, 2 } { 3, 4 } };
-int array4 = new int[] { 1, 2, 3, 4 };		
-Assert.That( array2x2, Is.Not.EqualTo( array4 ) );
-Assert.That( array2x2, Is.EqualTo( array4 ).AsCollection );
-</pre></div>
-
-<h4>Comparing Dictionaries</h4>
-
-<p>Dictionaries implement <b>ICollection</b>, and NUnit has treated
-them as collections since version 2.4. However, this did not
-give useful results, since the dictionary entries had to be
-in the same order for the comparison to succeed and the 
-underlying implementation had to be the same.
-
-<p>Beginning with NUnit 2.5.6, NUnit has specific code for
-comparing dictionaries. Two dictionaries are considered equal if
-
-<ol>
-<li>The list of keys is the same - without regard to ordering.
-<li>The values associated with each key are equal.
-</ol>
-
-<p>You can use this capability to compare any two objects implementing
-<b>IDictionary</b>. Generic and non-generic dictionaries (Hashtables) 
-may be successfully compared.
-
-<h4>User-Specified Comparers</h4>
-
-<p>If the default NUnit or .NET behavior for testing equality doesn't
-meet your needs, you can supply a comparer of your own through the
-<b>Using</b> modifier. When used with <b>EqualConstraint</b>, you
-may supply an <b>IEqualityComparer</b>, <b>IEqualityComparer&lt;T&gt;</b>,
-<b>IComparer</b>, <b>IComparer&lt;T&gt</b>; or <b>Comparison&lt;T&gt;</b> 
-as the argument to <b>Using</b>.
-
-<div class="code"><pre>
-Assert.That( myObj1, Is.EqualTo( myObj2 ).Using( myComparer ) );
-</pre></div>
-
-<h4>Notes</h4>
-<ol>
-<li><p>When checking the equality of user-defined classes, NUnit makes use 
-    of the <b>Equals</b> override on the expected object. If you neglect to 
-	override <b>Equals</b>, you can expect failures non-identical objects. 
-	In particular, overriding <b>operator==</b> without overriding <b>Equals</b>
-	has no effect.
-<li><p>The <b>Within</b> modifier was originally designed for use with floating point
-    values only. Beginning with NUnit 2.4, comparisons of <b>DateTime</b> values 
-	may use a <b>TimeSpan</b> as a tolerance. Beginning with NUnit 2.4.2, 
-	non-float numeric comparisons may also specify a tolerance.
-<li><p>Beginning with NUnit 2.4.4, float and double comparisons for which no 
-	tolerance is specified use a default, use the value of
-	<b>GlobalSettings.DefaultFloatingPointTolerance</b>. If this is not
-	set, a tolerance of 0.0d is used.
-<li><p>Prior to NUnit 2.2.3, comparison of two NaN values would always fail,
-    as specified by IEEE floating point standards. The new behavior, was
-	introduced after some discussion becuase it seems more useful in tests. 
-	To avoid confusion, consider using <b>Is.NaN</b> where appropriate.
-<li><p>When an equality test between two strings fails, the relevant portion of
-	of both strings is displayed in the error message, clipping the strings to
-	fit the length of the line as needed. Beginning with 2.4.4, this behavior
-	may be modified by use of the <b>NoClip</b> modifier on the constraint. In
-	addition, the maximum line length may be modified for all tests by setting
-	the value of <b>TextMessageWriter.MaximumLineLength</b> in the appropriate
-	level of setup.
-<li><p>When used with arrays, collections or dictionaries, EqualConstraint 
-    operates recursively. Any modifiers are saved and used as they apply to 
-	individual items.
-<li><p>A user-specified comparer will not be called by <b>EqualConstraint</b>
-    if either or both arguments are null. If both are null, the Constraint
-	succeeds. If only one is null, it fails.
-<li><p>NUnit has special semantics for comparing <b>Streams</b> and
-<b>DirectoryInfos</b>. For a <b>Stream</b>, the contents are compared.
-For a <b>DirectoryInfo</b>, the first-level directory contents are compared.
-</ol>
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<ul>
-<li id="current"><a href="equalConstraint.html">Equal&nbsp;Constraint</a></li>
-<li><a href="sameasConstraint.html">SameAs&nbsp;Constraint</a></li>
-<li><a href="conditionConstraints.html">Condition&nbsp;Constraints</a></li>
-<li><a href="comparisonConstraints.html">Comparison&nbsp;Constrants</a></li>
-<li><a href="pathConstraints.html">Path&nbsp;Constraints</a></li>
-<li><a href="typeConstraints.html">Type&nbsp;Constraints</a></li>
-<li><a href="stringConstraints.html">String&nbsp;Constraints</a></li>
-<li><a href="collectionConstraints.html">Collection&nbsp;Constraints</a></li>
-<li><a href="propertyConstraint.html">Property&nbsp;Constraint</a></li>
-<li><a href="throwsConstraint.html">Throws&nbsp;Constraint</a></li>
-<li><a href="compoundConstraints.html">Compound&nbsp;Constraints</a></li>
-<li><a href="delayedConstraint.html">Delayed&nbsp;Constraint</a></li>
-<li><a href="listMapper.html">List&nbsp;Mapper</a></li>
-<li><a href="reusableConstraint.html">Reusable&nbsp;Constraint</a></li>
-</ul>
-<li><a href="attributes.html">Attributes</a></li>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/equalityAsserts.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/equalityAsserts.html b/lib/NUnit.org/NUnit/2.5.9/doc/equalityAsserts.html
deleted file mode 100644
index 89d5e3d..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/equalityAsserts.html
+++ /dev/null
@@ -1,185 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - EqualityAsserts</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h2>Equality Asserts</h2>
-
-<p>These methods test whether the two arguments are equal. Overloaded
-methods are provided for common value types so that languages that don't
-automatically box values can use them directly.</p>
-
-<div class="code" style="width: 36em" >
-	<pre>Assert.AreEqual( int expected, int actual );
-Assert.AreEqual( int expected, int actual, string message );
-Assert.AreEqual( int expected, int actual, string message, 
-                 params object[] parms );
-				 
-Assert.AreEqual( uint expected, uint actual );
-Assert.AreEqual( uint expected, uint actual, string message );
-Assert.AreEqual( uint expected, uint actual, string message, 
-                 params object[] parms );
-
-Assert.AreEqual( decimal expected, decimal actual );
-Assert.AreEqual( decimal expected, decimal actual, string message );
-Assert.AreEqual( decimal expected, decimal actual, string message, 
-                 params object[] parms );
-
-Assert.AreEqual( float expected, float actual, float tolerance );
-Assert.AreEqual( float expected, float actual, float tolerance,
-                 string message );
-Assert.AreEqual( float expected, float actual, float tolerance,
-                 string message, params object[] parms );
-
-Assert.AreEqual( double expected, double actual, double tolerance );
-Assert.AreEqual( double expected, double actual, double tolerance,
-                 string message );
-Assert.AreEqual( double expected, double actual, double tolerance,
-                 string message, params object[] parms );
-
-Assert.AreEqual( object expected, object actual );
-Assert.AreEqual( object expected, object actual, string message );
-Assert.AreEqual( object expected, object actual, string message, 
-                 params object[] parms );
-
-Assert.AreNotEqual( int expected, int actual );
-Assert.AreNotEqual( int expected, int actual, string message );
-Assert.AreNotEqual( int expected, int actual, string message,
-                 params object[] parms );
-
-Assert.AreNotEqual( long expected, long actual );
-Assert.AreNotEqual( long expected, long actual, string message );
-Assert.AreNotEqual( long expected, long actual, string message,
-                 params object[] parms );
-
-Assert.AreNotEqual( uint expected, uint actual );
-Assert.AreNotEqual( uint expected, uint actual, string message );
-Assert.AreNotEqual( uint expected, uint actual, string message,
-                 params object[] parms );
-
-Assert.AreNotEqual( ulong expected, ulong actual );
-Assert.AreNotEqual( ulong expected, ulong actual, string message );
-Assert.AreNotEqual( ulong expected, ulong actual, string message,
-                 params object[] parms );
-
-Assert.AreNotEqual( decimal expected, decimal actual );
-Assert.AreNotEqual( decimal expected, decimal actual, string message );
-Assert.AreNotEqual( decimal expected, decimal actual, string message,
-                 params object[] parms );
-
-Assert.AreNotEqual( float expected, float actual );
-Assert.AreNotEqual( float expected, float actual, string message );
-Assert.AreNotEqual( float expected, float actual, string message,
-                 params object[] parms );
-
-Assert.AreNotEqual( double expected, double actual );
-Assert.AreNotEqual( double expected, double actual, string message );
-Assert.AreNotEqual( double expected, double actual, string message,
-                 params object[] parms );
-
-Assert.AreNotEqual( object expected, object actual );
-Assert.AreNotEqual( object expected, object actual, string message );
-Assert.AreNotEqual( object expected, object actual, string message,
-                 params object[] parms );</pre>
-</div>
-
-<h4>Comparing Numerics of Different Types</h4>
-
-<p>The method overloads that compare two objects make special provision so that numeric 
-	values of different types compare as expected. This assert succeeds:
-	<pre>        Assert.AreEqual( 5, 5.0 );</pre>
-</p>
-
-<h4>Comparing Floating Point Values</h4>
-
-<p>Values of type float and double are normally compared using an additional
-argument that indicates a tolerance within which they will be considered 
-as equal. Beginning with NUnit 2.4.4, the value of
-<b>GlobalSettings.DefaultFloatingPointTolerance</b> is used if a third argument
-is not provided. In earlier versions, or if the default has not been set,
-values are tested for exact equality.
-
-<p>Special values are handled so that the following Asserts succeed:</p>
-
-<pre>        Assert.AreEqual( double.PositiveInfinity, double.PositiveInfinity );
-        Assert.AreEqual( double.NegativeInfinity, double.NegativeInfinity );
-        Assert.AreEqual( double.NaN, double.NaN );</pre>
-
-<blockquote><i><b>Note:</b> The last example above represents a change with NUnit 2.2.3.
-      In earlier releases, the test would fail. We have made this change
-      because the new behavior seems to be more useful in tests. To avoid confusion,
-      we suggest using the new Assert.IsNaN method where appropriate.</i></blockquote>
-
-<h4>Comparing Arrays and Collections</h4>
-
-<p>Since version 2.2, NUnit has been able to compare two single-dimensioned arrays.
-    Beginning with version 2.4, multi-dimensioned arrays, nested arrays (arrays of arrays)
-	and collections may be compared. Two arrays or collections will be treated as equal 
-	by Assert.AreEqual if they have the same dimensions and if each of the corresponding 
-	elements is equal.</p>
-	
-</div>
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<ul>
-<li id="current"><a href="equalityAsserts.html">Equality&nbsp;Asserts</a></li>
-<li><a href="identityAsserts.html">Identity&nbsp;Asserts</a></li>
-<li><a href="conditionAsserts.html">Condition&nbsp;Asserts</a></li>
-<li><a href="comparisonAsserts.html">Comparison&nbsp;Asserts</a></li>
-<li><a href="typeAsserts.html">Type&nbsp;Asserts</a></li>
-<li><a href="exceptionAsserts.html">Exception&nbsp;Asserts</a></li>
-<li><a href="utilityAsserts.html">Utility&nbsp;Methods</a></li>
-<li><a href="stringAssert.html">String&nbsp;Assert</a></li>
-<li><a href="collectionAssert.html">Collection&nbsp;Assert</a></li>
-<li><a href="fileAssert.html">File&nbsp;Assert</a></li>
-<li><a href="directoryAssert.html">Directory&nbsp;Assert</a></li>
-</ul>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/eventListeners.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/eventListeners.html b/lib/NUnit.org/NUnit/2.5.9/doc/eventListeners.html
deleted file mode 100644
index 33ca5bb..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/eventListeners.html
+++ /dev/null
@@ -1,105 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - EventListeners</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h3>EventListeners (NUnit 2.4.4)</h3>
-
-<h4>Purpose</h4>
-<p>EventListeners are able to respond to events that occur in the course
-of a test run, usually by recording information of some kind. Note that
-EventListeners called asynchronously with respect to test execution and
-are not able to affect the actual execution of the test.
-
-<h4>Extension Point</h4>
-<p>Addins use the host to access this extension point by name:
-
-<pre>
-	IExtensionPoint listeners = host.GetExtensionPoint( "EventListeners" );</pre>
-
-<h4>Interface</h4>
-<p>The extension object passed to Install must implement the EventListener interface:
-
-<pre>
-	public interface EventListener
-	{
-		void RunStarted( string name, int testCount );
-		void RunFinished( TestResult result );
-		void RunFinished( Exception exception );
-		void TestStarted(TestName testName);
-		void TestFinished(TestResult result);
-		void SuiteStarted(TestName testName);
-		void SuiteFinished(TestResult result);
-		void UnhandledException( Exception exception );
-		void TestOutput(TestOutput testOutput);
-	}
-</pre>
-
-<p>You must provide all the methods, but the body may be empty for any
-that you have no need of.
-
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<ul>
-<li><a href="customConstraints.html">Custom&nbsp;Constraints</a></li>
-<li><a href="nunitAddins.html">NUnit&nbsp;Addins</a></li>
-<ul>
-<li><a href="suiteBuilders.html">SuiteBuilders</a></li>
-<li><a href="testcaseBuilders.html">TestcaseBuilders</a></li>
-<li><a href="testDecorators.html">TestDecorators</a></li>
-<li><a href="testcaseProviders.html">TestcaseProviders</a></li>
-<li><a href="datapointProviders.html">DatapointProviders</a></li>
-<li id="current"><a href="eventListeners.html">EventListeners</a></li>
-</ul>
-<li><a href="extensionTips.html">Tips&nbsp;for&nbsp;Extenders</a></li>
-</ul>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/exception.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/exception.html b/lib/NUnit.org/NUnit/2.5.9/doc/exception.html
deleted file mode 100644
index e7d865f..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/exception.html
+++ /dev/null
@@ -1,316 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - Exception</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<script language="JavaScript" src="codeFuncs.js" ></script> <!-- Do it this way for IE -->
-
-<h3>ExpectedExceptionAttribute (NUnit 2.0 plus Updates)</h3>
-
-<p>This is the way to specify that the execution of a test will throw an 
-	exception. This attribute has a number of positional and
-	named parameters, which we will discuss in separate sections
-	according to the purpose they serve.</p>
-	
-<h4>Specifying the Expected Exception Type</h4>
-
-<p>The original attribute, introduced with NUnit 2.0 took a single
-argument giving the exact type of the expected exception. For example...</p>
-
-
-<div class="code"><pre>[ExpectedException( typeof( ArgumentException ) )]
-public void TestMethod()
-{
-...</pre></div>
-
-<p>Beginning with NUnit 2.2.4, it became possible to specify the type
-of exception as a string, avoiding the need for a reference to the
-defining assembly...</p>
-
-<div class="code"><pre>[ExpectedException( "System.ArgumentException" ) )]
-public void TestMethod()
-{
-...</pre></div>
-
-<p>The above two examples function identically: the test only succeeds if a
-System.Argument exception is thrown.</p>
-
-<h4>Specifying the Expected Message</h4>
-
-<p>NUnit 2.1 introduced a constructor with a second argument, specifying the
-exact text of the message property of the exception. After NUnit 2.2.4, the
-same extension was made to the constructor taking a string argument. With
-NUnit 2.4, these arguments are marked obsolete, and a named parameter
-is provided instead...</p>
-
-<div class="code" style="width: 44em"><pre>// Obsolete form:
-[ExpectedException( typeof( ArgumentException ), "expected message" )]
-[ExpectedException( "System.ArgumentException", "expected message" )]
-
-// Prefered form:
-[ExpectedException( typeof( ArgumentException ), ExpectedMessage="expected message" )]
-[ExpectedException( "System.ArgumentException", ExpectedMessage="expected message" )]</pre></div>
-
-<p>With NUnit 2.4, it is possible to specify additional tests on the
-exception message, beyond a simple exact match. This is done using the 
-MatchType named parameter, whose argument is an enumeration, defined as
-follows:</p>
-   
-<div class="code">
-<pre>public enum MessageMatch
-{
-    /// Expect an exact match
-    Exact,	
-    /// Expect a message containing the parameter string
-    Contains,
-    /// Match the regular expression provided as a parameter
-    Regex,
-    /// Expect a message starting with the parameter string
-    StartsWith
-}</pre></div>
-
-<p>The following example is for a test that passes only if an ArgumentException
-with a message containing "unspecified" is received.</p>
-
-<div class="code" style="width: 57em">
-<pre>[ExpectedException( typeof( ArgumentException), ExpectedMessage="unspecified", MatchType=MessageMatch.Contains )]
-public void TestMethod()
-{
-...</pre></div>
-
-<p>If MatchType is not specified, an exact match is used as before.</p>
-
-<h4>Specifying a Custom Error Message</h4>
-
-<p>With NUnit 2.4, it is possible to specify a custom message to be
-displayed if the ExpectedException attribute is not satisfied. This
-is done through the UserMessage named parameter...</p>
-
-<div class="code" style="width: 41em">
-<pre>[ExpectedException( typeof( ArgumentException ), UserMessage="Custom message" )]
-public void TestMethod()
-{
-...</pre>
-</div>
-
-<h4>Handling the Exception in Code</h4>
-
-<p>If the processing required for an exception is too complex to express
-in the attribute declaration, the normal practice is to process it in the
-test code using a try/catch block. As an alternative, NUnit 2.4 allows
-designating a method that will be called to process the exception. This
-is particularly useful when multiple exceptions need to be processed
-in the same way.</p>
-
-<p>An common exception handler may be designated by implementing the
-<b>IExpectExceptionInterface</b>, which is defined as follows...</p>
-
-<div class="code">
-<pre>public interface IExpectException
-{
-    void HandleException( System.Exception ex );
-}</pre>
-</div>
-
-<p>The exception handler is only called for methods marked with
-the <b>ExpectedException</b> attribute. If all checks - including
-the type of the exception - are to be performed in code, the
-attribute may be specified without any arguments in order to
-indicate that an exception is expected.</p>
-
-<p>An handler may be designated for a particular method
-using the <b>Handler</b> named parameter.</p>
-
-<div class="code"><pre>[ExpectedException( Handler="HandlerMethod" )]
-public void TestMethod()
-{
-...
-}
-
-public void HandlerMethod( System.Exception ex )
-{
-...
-}</pre></div>
-
-<p>This technique may be
-used without implementing <b>IExpectException</b> or in
-combination with it. In the latter case, the designated handler
-applies to any method that specifies it, while the normal
-exception handler applies to any other methods that specify
-an <b>ExpectedException</b>.</p>
-
-<p>However it is specified, the handler method should examine the exception and 
-<b>Assert</b> on whatever properties are relevant. Any resulting failure message 
-will then be consistent in format with other assertions performed in the tests.</p>
-
-
-<h4>Example:</h4>
-
-<div class="code">
-
-<div class="langFilter">
-	<a href="javascript:Show('DD1')" onmouseover="Show('DD1')"><img src="img/langFilter.gif" width="14" height="14" alt="Language Filter"></a>
-	<div id="DD1" class="dropdown" style="display: none" onclick="Hide('DD1')">
-		<a href="javascript:ShowCS()">C#</a><br>
-		<a href="javascript:ShowVB()">VB</a><br>
-		<a href="javascript:ShowMC()">C++</a><br>
-	</div>
-</div>
-
-<pre class="cs">namespace NUnit.Tests
-{
-  using System;
-  using NUnit.Framework;
-
-  [TestFixture]
-  public class SuccessTests
-  {
-    [Test]
-    [ExpectedException(typeof(InvalidOperationException))]
-    public void ExpectAnExceptionByType()
-    { /* ... */ }
-
-    [Test]
-    [ExpectedException("System.InvalidOperationException")]
-    public void ExpectAnExceptionByName()
-    { /* ... */ }
-  }
-}
-</pre>
-
-<pre class="vb">Imports System
-Imports Nunit.Framework
-
-Namespace Nunit.Tests
-
-  &lt;TestFixture()&gt; Public Class SuccessTests
-    &lt;Test(), ExpectedException(GetType(Exception))&gt;
-      Public Sub ExpectAnExceptionByType()
-    &#39; ...
-    End Sub
-
-  &lt;TestFixture()&gt; Public Class SuccessTests
-    &lt;Test(), ExpectedException("System.Exception")&gt;
-      Public Sub ExpectAnExceptionByName()
-    &#39; ...
-    End Sub
-  End Class
-End Namespace
-</pre>
-
-<pre class="mc">#using &lt;Nunit.Framework.dll&gt;
-using namespace System;
-using namespace NUnit::Framework;
-
-namespace NUnitTests
-{
-  [TestFixture]
-  public __gc class SuccessTests
-  {
-    [Test]
-    [ExpectedException(__typeof(InvalidOperationException))]
-    void ExpectAnExceptionByType();
-
-    [Test]
-    [ExpectedException(S"SystemInvalidOperationException")]
-    void ExpectAnExceptionByName();
-  };
-}
-
-#include &quot;cppsample.h&quot;
-
-namespace NUnitTests {
-  // ...
-}
-</pre>
-
-</div>
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<ul>
-<li><a href="category.html">Category</a></li>
-<li><a href="combinatorial.html">Combinatorial</a></li>
-<li><a href="culture.html">Culture</a></li>
-<li><a href="datapoint.html">Datapoint(s)</a></li>
-<li><a href="description.html">Description</a></li>
-<li id="current"><a href="exception.html">Exception</a></li>
-<li><a href="explicit.html">Explicit</a></li>
-<li><a href="ignore.html">Ignore</a></li>
-<li><a href="maxtime.html">Maxtime</a></li>
-<li><a href="pairwise.html">Pairwise</a></li>
-<li><a href="platform.html">Platform</a></li>
-<li><a href="property.html">Property</a></li>
-<li><a href="random.html">Random</a></li>
-<li><a href="range.html">Range</a></li>
-<li><a href="repeat.html">Repeat</a></li>
-<li><a href="requiredAddin.html">RequiredAddin</a></li>
-<li><a href="requiresMTA.html">Requires&nbsp;MTA</a></li>
-<li><a href="requiresSTA.html">Requires&nbsp;STA</a></li>
-<li><a href="requiresThread.html">Requires&nbsp;Thread</a></li>
-<li><a href="sequential.html">Sequential</a></li>
-<li><a href="setCulture.html">SetCulture</a></li>
-<li><a href="setup.html">Setup</a></li>
-<li><a href="setupFixture.html">SetupFixture</a></li>
-<li><a href="suite.html">Suite</a></li>
-<li><a href="teardown.html">Teardown</a></li>
-<li><a href="test.html">Test</a></li>
-<li><a href="testCase.html">TestCase</a></li>
-<li><a href="testCaseSource.html">TestCaseSource</a></li>
-<li><a href="testFixture.html">TestFixture</a></li>
-<li><a href="fixtureSetup.html">TestFixtureSetUp</a></li>
-<li><a href="fixtureTeardown.html">TestFixtureTearDown</a></li>
-<li><a href="theory.html">Theory</a></li>
-<li><a href="timeout.html">Timeout</a></li>
-<li><a href="values.html">Values</a></li>
-<li><a href="valueSource.html">ValueSource</a></li>
-</ul>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/exceptionAsserts.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/exceptionAsserts.html b/lib/NUnit.org/NUnit/2.5.9/doc/exceptionAsserts.html
deleted file mode 100644
index b6da660..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/exceptionAsserts.html
+++ /dev/null
@@ -1,234 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - ExceptionAsserts</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h2>Exception Asserts (NUnit 2.5)</h2>
-
-<p>The <b>Assert.Throws</b> method is pretty much in a class by itself. Rather than
-   comparing values, it attempts to invoke a code snippet, represented as
-   a delegate, in order to verify that it throws a particular exception.
-   
-<p>It's also in a class by itself in that it returns an Exception, rather
-    than void, if the Assert is successful. See the example below for
-	a few ways to use this.
-   
-<p><b>Assert.Throws</b> may be used with a constraint argument, which is applied
-   to the actual exception thrown, or with the Type of exception expected.
-   The Type format is available in both both a non-generic and (in the .NET 2.0 version)
-   generic form.
-   
-<p><b>Assert.DoesNotThrow</b> simply verifies that the delegate does not throw
-   an exception.
-   
-<p><b>Assert.Catch</b> is similar to <b>Assert.Throws</b> but will pass for an exception
-   that is derived from the one specified.
-   
-<div class="code" style="width: 40em"><pre>
-Exception Assert.Throws( Type expectedExceptionType, TestDelegate code );
-Exception Assert.Throws( Type expectedExceptionType, TestDelegate code, 
-		string message );
-Exception Assert.Throws( Type expectedExceptionType, TestDelegate code, 
-		string message, params object[] parms);
-
-Exception Assert.Throws( IResolveConstraint constraint, TestDelegate code );
-Exception Assert.Throws( IResolveConstraint constraint, TestDelegate code, 
-		string message );
-Exception Assert.Throws( IResolveConstraint constraint, TestDelegate code, 
-		string message, params object[] parms);
-
-T Assert.Throws&lt;T&gt;( TestDelegate code );
-T Assert.Throws&lt;T&gt;( TestDelegate code, string message );
-T Assert.Throws&lt;T&gt;( TestDelegate code, string message, 
-		params object[] parms);
-		
-void Assert.DoesNotThrow( TestDelegate code );
-void Assert.DoesNotThrow( TestDelegate code, string message );
-void Assert.DoesNotThrow( TestDelegate code, string message, 
-        params object[] parms);
-
-Exception Assert.Catch( TestDelegate code );
-Exception Assert.Catch( TestDelegate code, string message );
-Exception Assert.Catch( TestDelegate code, string message, 
-        params object[] parms);
-
-Exception Assert.Catch( Type expectedExceptionType, TestDelegate code );
-Exception Assert.Catch( Type expectedExceptionType, TestDelegate code, 
-		string message );
-Exception Assert.Catch( Type expectedExceptionType, TestDelegate code, 
-		string message, params object[] parms);
-
-T Assert.Catch&lt;T&gt;( TestDelegate code );
-T Assert.Catch&lt;T&gt;( TestDelegate code, string message );
-T Assert.Catch&lt;T&gt;( TestDelegate code, string message, 
-		params object[] parms);
-</pre></div>
-
-<p>In the above code <b>TestDelegate</b> is a delegate of the form
-<b>void TestDelegate()</b>, which is used to execute the code
-in question. Under .NET 2.0, this may be an anonymous delegate.
-If compiling under C# 3.0, it may be a lambda expression.
-
-<p>The following example shows different ways of writing the
-same test.
-
-<div class="code"><pre>
-[TestFixture]
-public class AssertThrowsTests
-{
-  [Test]
-  public void Tests()
-  {
-    // .NET 1.x
-    Assert.Throws( typeof(ArgumentException),
-      new TestDelegate(MethodThatThrows) );
-	  
-    // .NET 2.0
-    Assert.Throws&lt;ArgumentException&gt;( MethodThatThrows() );
-
-    Assert.Throws&lt;ArgumentException&gt;(
-	  delegate { throw new ArgumentException(); } );
-
-    // Using C# 3.0	  
-    Assert.Throws&lt;ArgumentException&gt;(
-      () => throw new ArgumentException(); } );
-  }
-  
-  void MethodThatThrows()
-  {
-    throw new ArgumentException();
-  }
-
-</pre></div>
-
-<p>This example shows use of the return value to perform
-additional verification of the exception.
-
-<div class="code"><pre>
-[TestFixture]
-public class UsingReturnValue
-{
-  [Test]
-  public void TestException()
-  {
-    MyException ex = Assert.Throws&lt;MyException&gt;(
-      delegate { throw new MyException( "message", 42 ); } );
-    Assert.That( ex.Message, Is.EqualTo( "message" ) );
-    Assert.That( ex.MyParam, Is.EqualTo( 42 ) ); 
-  }
-</pre></div>
-
-<p>This example does the same thing
-using the overload that includes a constraint.
-
-<div class="code"><pre>
-[TestFixture]
-public class UsingConstraint
-{
-  [Test]
-  public void TestException()
-  {
-    Assert.Throws( Is.Typeof&lt;MyException&gt;()
-                 .And.Message.EqualTo( "message" )
-                 .And.Property( "MyParam" ).EqualTo( 42 ),
-      delegate { throw new MyException( "message", 42 ); } );
-  }
-</pre></div>
-
-<p>Use the form that matches your style of coding.
-
-<h3>Exact Versus Derived Types</h3>
-
-<p>When used with a Type argument, <b>Assert.Throws</b> requires
-that exact type to be thrown. If you want to test for any
-derived Type, use one of the forms that allows specifying
-a constraint. Alternatively, you may use <b>Assert.Catch</b>,
-which differs from <b>Assert.Throws</b> in allowing derived
-types. See the following code for examples:
-
-<div class="code">
-<pre>
-// Require an ApplicationException - derived types fail!
-Assert.Throws( typeof(ApplicationException), code );
-Assert.Throws&lt;ApplicationException&gt;()( code );
-
-// Allow both ApplicationException and any derived type
-Assert.Throws( Is.InstanceOf( typeof(ApplicationException), code );
-Assert.Throws( Is.InstanceOf&lt;ApplicationException&gt;(), code );
-
-// Allow both ApplicationException and any derived type
-Assert.Catch&lt;ApplicationException&gt;( code );
-
-// Allow any kind of exception
-Assert.Catch( code );
-</pre>
-</div>
-
-<h4>See also...</h4>
-<ul>
-<li><a href="throwsConstraint.html">ThrowsConstraint</a></ul>
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<ul>
-<li><a href="equalityAsserts.html">Equality&nbsp;Asserts</a></li>
-<li><a href="identityAsserts.html">Identity&nbsp;Asserts</a></li>
-<li><a href="conditionAsserts.html">Condition&nbsp;Asserts</a></li>
-<li><a href="comparisonAsserts.html">Comparison&nbsp;Asserts</a></li>
-<li><a href="typeAsserts.html">Type&nbsp;Asserts</a></li>
-<li id="current"><a href="exceptionAsserts.html">Exception&nbsp;Asserts</a></li>
-<li><a href="utilityAsserts.html">Utility&nbsp;Methods</a></li>
-<li><a href="stringAssert.html">String&nbsp;Assert</a></li>
-<li><a href="collectionAssert.html">Collection&nbsp;Assert</a></li>
-<li><a href="fileAssert.html">File&nbsp;Assert</a></li>
-<li><a href="directoryAssert.html">Directory&nbsp;Assert</a></li>
-</ul>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>


[26/51] [abbrv] [partial] Cleaning up and getting ready to development towards v4.8

Posted by sy...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/WeifenLuo.WinFormsUI.Docking.dll
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/WeifenLuo.WinFormsUI.Docking.dll b/lib/Gallio.3.2.750/tools/WeifenLuo.WinFormsUI.Docking.dll
deleted file mode 100644
index dd42cc6..0000000
Binary files a/lib/Gallio.3.2.750/tools/WeifenLuo.WinFormsUI.Docking.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/ICSharpCode/SharpZipLib/0.85/ICSharpCode.SharpZipLib.dll
----------------------------------------------------------------------
diff --git a/lib/ICSharpCode/SharpZipLib/0.85/ICSharpCode.SharpZipLib.dll b/lib/ICSharpCode/SharpZipLib/0.85/ICSharpCode.SharpZipLib.dll
deleted file mode 100644
index e829ebf..0000000
Binary files a/lib/ICSharpCode/SharpZipLib/0.85/ICSharpCode.SharpZipLib.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Lucene.Net.snk
----------------------------------------------------------------------
diff --git a/lib/Lucene.Net.snk b/lib/Lucene.Net.snk
deleted file mode 100644
index f7f9ee5..0000000
Binary files a/lib/Lucene.Net.snk and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/Logo.ico
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/Logo.ico b/lib/NUnit.org/NUnit/2.5.9/Logo.ico
deleted file mode 100644
index 13c4ff9..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/Logo.ico and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/NUnitFitTests.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/NUnitFitTests.html b/lib/NUnit.org/NUnit/2.5.9/NUnitFitTests.html
deleted file mode 100644
index ca5cd4f..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/NUnitFitTests.html
+++ /dev/null
@@ -1,277 +0,0 @@
-<!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0 Transitional//EN">
-<html>
-	<body>
-		<h1>NUnit Acceptance Tests</h1>
-		<p>
-		Developers love self-referential programs! Hence, NUnit has always run all it's 
-		own tests, even those that are not really unit tests.
-		<p>Now, beginning with NUnit 2.4, NUnit has top-level tests using Ward Cunningham's 
-			FIT framework. At this time, the tests are pretty rudimentary, but it's a start 
-			and it's a framework for doing more.
-			<h2>Running the Tests</h2>
-		<p>Open a console or shell window and navigate to the NUnit bin directory, which 
-			contains this file. To run the test under Microsoft .Net, enter the command
-			<pre>    runFile NUnitFitTests.html TestResults.html .</pre>
-			To run it under Mono, enter
-			<pre>    mono runFile.exe NUnitFitTests.html TestResults.html .</pre>
-			Note the space and dot at the end of each command. The results of your test 
-			will be in TestResults.html in the same directory.
-			<h2>Platform and CLR Version</h2>
-			<table BORDER cellSpacing="0" cellPadding="5">
-				<tr>
-					<td colspan="2">NUnit.Fixtures.PlatformInfo</td>
-				</tr>
-			</table>
-			<h2>Verify Unit Tests</h2>
-		<p>
-		Load and run the NUnit unit tests, verifying that the results are as expected. 
-		When these tests are run on different platforms, different numbers of tests may 
-		be skipped, so the values for Skipped and Run tests are informational only.
-		<p>
-		The number of tests in each assembly should be constant across all platforms - 
-		any discrepancy usually means that one of the test source files was not 
-		compiled on the platform. There should be no failures and no tests ignored.
-		<p><b>Note:</b>
-		At the moment, the nunit.extensions.tests assembly is failing because the 
-		fixture doesn't initialize addins in the test domain.
-		<p>
-			<table BORDER cellSpacing="0" cellPadding="5">
-				<tr>
-					<td colspan="6">NUnit.Fixtures.AssemblyRunner</td>
-				</tr>
-				<tr>
-					<td>Assembly</td>
-					<td>Tests()</td>
-					<td>Run()</td>
-					<td>Skipped()</td>
-					<td>Ignored()</td>
-					<td>Failures()</td>
-				</tr>
-				<tr>
-					<td>nunit.framework.tests.dll</td>
-					<td>397</td>
-					<td>&nbsp;</td>
-					<td>&nbsp;</td>
-					<td>0</td>
-					<td>0</td>
-				</tr>
-				<tr>
-					<td>nunit.core.tests.dll</td>
-					<td>355</td>
-					<td>&nbsp;</td>
-					<td>&nbsp;</td>
-					<td>0</td>
-					<td>0</td>
-				</tr>
-				<tr>
-					<td>nunit.util.tests.dll</td>
-					<td>238</td>
-					<td>&nbsp;</td>
-					<td>&nbsp;</td>
-					<td>0</td>
-					<td>0</td>
-				</tr>
-				<tr>
-					<td>nunit.mocks.tests.dll</td>
-					<td>43</td>
-					<td>&nbsp;</td>
-					<td>&nbsp;</td>
-					<td>0</td>
-					<td>0</td>
-				</tr>
-				<tr>
-					<td>nunit.extensions.tests.dll</td>
-					<td>5</td>
-					<td>&nbsp;</td>
-					<td>&nbsp;</td>
-					<td>0</td>
-					<td>0</td>
-				</tr>
-				<tr>
-					<td>nunit-console.tests.dll</td>
-					<td>40</td>
-					<td>&nbsp;</td>
-					<td>&nbsp;</td>
-					<td>0</td>
-					<td>0</td>
-				</tr>
-				<tr>
-					<td>nunit.uikit.tests.dll</td>
-					<td>34</td>
-					<td>&nbsp;</td>
-					<td>&nbsp;</td>
-					<td>0</td>
-					<td>0</td>
-				</tr>
-				<tr>
-					<td>nunit-gui.tests.dll</td>
-					<td>15</td>
-					<td>&nbsp;</td>
-					<td>&nbsp;</td>
-					<td>0</td>
-					<td>0</td>
-				</tr>
-				<tr>
-					<td>nunit.fixtures.tests.dll</td>
-					<td>6</td>
-					<td>&nbsp;</td>
-					<td>&nbsp;</td>
-					<td>0</td>
-					<td>0</td>
-				</tr>
-			</table>
-			<h2>Code Snippet Tests</h2>
-		<p>
-		These tests create a test assembly from a snippet of code and then load and run 
-		the tests that it contains, verifying that the structure of the loaded tests is 
-		as expected and that the number of tests run, skipped, ignored or failed is 
-		correct.
-		<p>
-			<table BORDER cellSpacing="0" cellPadding="5">
-				<tr>
-					<td colspan="6">NUnit.Fixtures.SnippetRunner</td>
-				</tr>
-				<tr>
-					<td>Code</td>
-					<td>Tree()</td>
-					<td>Run()</td>
-					<td>Skipped()</td>
-					<td>Ignored()</td>
-					<td>Failures()</td>
-				</tr>
-				<tr>
-					<td><pre>public class TestClass
-{
-}</pre>
-					</td>
-					<td>EMPTY</td>
-					<td>0</td>
-					<td>0</td>
-					<td>0</td>
-					<td>0</td>
-				</tr>
-				<tr>
-					<td><pre>using NUnit.Framework;
-
-[TestFixture]
-public class TestClass
-{
-}</pre>
-					</td>
-					<td>TestClass</td>
-					<td>0</td>
-					<td>0</td>
-					<td>0</td>
-					<td>0</td>
-				</tr>
-				<tr>
-					<td><pre>using NUnit.Framework;
-
-[TestFixture]
-public class TestClass
-{
-    [Test]
-    public void T1() { }
-    [Test]
-    public void T2() { }
-    [Test]
-    public void T3() { }
-}</pre>
-					</td>
-					<td><pre>TestClass
-&gt;T1
-&gt;T2
-&gt;T3</pre>
-					</td>
-					<td>3</td>
-					<td>0</td>
-					<td>0</td>
-					<td>0</td>
-				</tr>
-				<tr>
-					<td><pre>using NUnit.Framework;
-
-[TestFixture]
-public class TestClass1
-{
-    [Test]
-    public void T1() { }
-}
-
-[TestFixture]
-public class TestClass2
-{
-    [Test]
-    public void T2() { }
-    [Test]
-    public void T3() { }
-}</pre>
-					</td>
-					<td><pre>TestClass1
-&gt;T1
-TestClass2
-&gt;T2
-&gt;T3</pre>
-					</td>
-					<td>3</td>
-					<td>0</td>
-					<td>0</td>
-					<td>0</td>
-				</tr>
-				<tr>
-					<td><pre>using NUnit.Framework;
-
-[TestFixture]
-public class TestClass
-{
-    [Test]
-    public void T1() { }
-    [Test, Ignore]
-    public void T2() { }
-    [Test]
-    public void T3() { }
-}</pre>
-					</td>
-					<td><pre>TestClass
-&gt;T1
-&gt;T2
-&gt;T3</pre>
-					</td>
-					<td>2</td>
-					<td>0</td>
-					<td>1</td>
-					<td>0</td>
-				</tr>
-				<tr>
-					<td><pre>using NUnit.Framework;
-
-[TestFixture]
-public class TestClass
-{
-    [Test]
-    public void T1() { }
-    [Test, Explicit]
-    public void T2() { }
-    [Test]
-    public void T3() { }
-}</pre>
-					</td>
-					<td><pre>TestClass
-&gt;T1
-&gt;T2
-&gt;T3</pre>
-					</td>
-					<td>2</td>
-					<td>1</td>
-					<td>0</td>
-					<td>0</td>
-				</tr>
-			</table>
-			<h2>Summary Information</h2>
-			<table BORDER cellSpacing="0" cellPadding="5">
-				<tr>
-					<td colspan="2">fit.Summary</td>
-				</tr>
-			</table>
-	</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/NUnitFitTests.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/NUnitFitTests.html b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/NUnitFitTests.html
deleted file mode 100644
index ca5cd4f..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/NUnitFitTests.html
+++ /dev/null
@@ -1,277 +0,0 @@
-<!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0 Transitional//EN">
-<html>
-	<body>
-		<h1>NUnit Acceptance Tests</h1>
-		<p>
-		Developers love self-referential programs! Hence, NUnit has always run all it's 
-		own tests, even those that are not really unit tests.
-		<p>Now, beginning with NUnit 2.4, NUnit has top-level tests using Ward Cunningham's 
-			FIT framework. At this time, the tests are pretty rudimentary, but it's a start 
-			and it's a framework for doing more.
-			<h2>Running the Tests</h2>
-		<p>Open a console or shell window and navigate to the NUnit bin directory, which 
-			contains this file. To run the test under Microsoft .Net, enter the command
-			<pre>    runFile NUnitFitTests.html TestResults.html .</pre>
-			To run it under Mono, enter
-			<pre>    mono runFile.exe NUnitFitTests.html TestResults.html .</pre>
-			Note the space and dot at the end of each command. The results of your test 
-			will be in TestResults.html in the same directory.
-			<h2>Platform and CLR Version</h2>
-			<table BORDER cellSpacing="0" cellPadding="5">
-				<tr>
-					<td colspan="2">NUnit.Fixtures.PlatformInfo</td>
-				</tr>
-			</table>
-			<h2>Verify Unit Tests</h2>
-		<p>
-		Load and run the NUnit unit tests, verifying that the results are as expected. 
-		When these tests are run on different platforms, different numbers of tests may 
-		be skipped, so the values for Skipped and Run tests are informational only.
-		<p>
-		The number of tests in each assembly should be constant across all platforms - 
-		any discrepancy usually means that one of the test source files was not 
-		compiled on the platform. There should be no failures and no tests ignored.
-		<p><b>Note:</b>
-		At the moment, the nunit.extensions.tests assembly is failing because the 
-		fixture doesn't initialize addins in the test domain.
-		<p>
-			<table BORDER cellSpacing="0" cellPadding="5">
-				<tr>
-					<td colspan="6">NUnit.Fixtures.AssemblyRunner</td>
-				</tr>
-				<tr>
-					<td>Assembly</td>
-					<td>Tests()</td>
-					<td>Run()</td>
-					<td>Skipped()</td>
-					<td>Ignored()</td>
-					<td>Failures()</td>
-				</tr>
-				<tr>
-					<td>nunit.framework.tests.dll</td>
-					<td>397</td>
-					<td>&nbsp;</td>
-					<td>&nbsp;</td>
-					<td>0</td>
-					<td>0</td>
-				</tr>
-				<tr>
-					<td>nunit.core.tests.dll</td>
-					<td>355</td>
-					<td>&nbsp;</td>
-					<td>&nbsp;</td>
-					<td>0</td>
-					<td>0</td>
-				</tr>
-				<tr>
-					<td>nunit.util.tests.dll</td>
-					<td>238</td>
-					<td>&nbsp;</td>
-					<td>&nbsp;</td>
-					<td>0</td>
-					<td>0</td>
-				</tr>
-				<tr>
-					<td>nunit.mocks.tests.dll</td>
-					<td>43</td>
-					<td>&nbsp;</td>
-					<td>&nbsp;</td>
-					<td>0</td>
-					<td>0</td>
-				</tr>
-				<tr>
-					<td>nunit.extensions.tests.dll</td>
-					<td>5</td>
-					<td>&nbsp;</td>
-					<td>&nbsp;</td>
-					<td>0</td>
-					<td>0</td>
-				</tr>
-				<tr>
-					<td>nunit-console.tests.dll</td>
-					<td>40</td>
-					<td>&nbsp;</td>
-					<td>&nbsp;</td>
-					<td>0</td>
-					<td>0</td>
-				</tr>
-				<tr>
-					<td>nunit.uikit.tests.dll</td>
-					<td>34</td>
-					<td>&nbsp;</td>
-					<td>&nbsp;</td>
-					<td>0</td>
-					<td>0</td>
-				</tr>
-				<tr>
-					<td>nunit-gui.tests.dll</td>
-					<td>15</td>
-					<td>&nbsp;</td>
-					<td>&nbsp;</td>
-					<td>0</td>
-					<td>0</td>
-				</tr>
-				<tr>
-					<td>nunit.fixtures.tests.dll</td>
-					<td>6</td>
-					<td>&nbsp;</td>
-					<td>&nbsp;</td>
-					<td>0</td>
-					<td>0</td>
-				</tr>
-			</table>
-			<h2>Code Snippet Tests</h2>
-		<p>
-		These tests create a test assembly from a snippet of code and then load and run 
-		the tests that it contains, verifying that the structure of the loaded tests is 
-		as expected and that the number of tests run, skipped, ignored or failed is 
-		correct.
-		<p>
-			<table BORDER cellSpacing="0" cellPadding="5">
-				<tr>
-					<td colspan="6">NUnit.Fixtures.SnippetRunner</td>
-				</tr>
-				<tr>
-					<td>Code</td>
-					<td>Tree()</td>
-					<td>Run()</td>
-					<td>Skipped()</td>
-					<td>Ignored()</td>
-					<td>Failures()</td>
-				</tr>
-				<tr>
-					<td><pre>public class TestClass
-{
-}</pre>
-					</td>
-					<td>EMPTY</td>
-					<td>0</td>
-					<td>0</td>
-					<td>0</td>
-					<td>0</td>
-				</tr>
-				<tr>
-					<td><pre>using NUnit.Framework;
-
-[TestFixture]
-public class TestClass
-{
-}</pre>
-					</td>
-					<td>TestClass</td>
-					<td>0</td>
-					<td>0</td>
-					<td>0</td>
-					<td>0</td>
-				</tr>
-				<tr>
-					<td><pre>using NUnit.Framework;
-
-[TestFixture]
-public class TestClass
-{
-    [Test]
-    public void T1() { }
-    [Test]
-    public void T2() { }
-    [Test]
-    public void T3() { }
-}</pre>
-					</td>
-					<td><pre>TestClass
-&gt;T1
-&gt;T2
-&gt;T3</pre>
-					</td>
-					<td>3</td>
-					<td>0</td>
-					<td>0</td>
-					<td>0</td>
-				</tr>
-				<tr>
-					<td><pre>using NUnit.Framework;
-
-[TestFixture]
-public class TestClass1
-{
-    [Test]
-    public void T1() { }
-}
-
-[TestFixture]
-public class TestClass2
-{
-    [Test]
-    public void T2() { }
-    [Test]
-    public void T3() { }
-}</pre>
-					</td>
-					<td><pre>TestClass1
-&gt;T1
-TestClass2
-&gt;T2
-&gt;T3</pre>
-					</td>
-					<td>3</td>
-					<td>0</td>
-					<td>0</td>
-					<td>0</td>
-				</tr>
-				<tr>
-					<td><pre>using NUnit.Framework;
-
-[TestFixture]
-public class TestClass
-{
-    [Test]
-    public void T1() { }
-    [Test, Ignore]
-    public void T2() { }
-    [Test]
-    public void T3() { }
-}</pre>
-					</td>
-					<td><pre>TestClass
-&gt;T1
-&gt;T2
-&gt;T3</pre>
-					</td>
-					<td>2</td>
-					<td>0</td>
-					<td>1</td>
-					<td>0</td>
-				</tr>
-				<tr>
-					<td><pre>using NUnit.Framework;
-
-[TestFixture]
-public class TestClass
-{
-    [Test]
-    public void T1() { }
-    [Test, Explicit]
-    public void T2() { }
-    [Test]
-    public void T3() { }
-}</pre>
-					</td>
-					<td><pre>TestClass
-&gt;T1
-&gt;T2
-&gt;T3</pre>
-					</td>
-					<td>2</td>
-					<td>1</td>
-					<td>0</td>
-					<td>0</td>
-				</tr>
-			</table>
-			<h2>Summary Information</h2>
-			<table BORDER cellSpacing="0" cellPadding="5">
-				<tr>
-					<td colspan="2">fit.Summary</td>
-				</tr>
-			</table>
-	</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/NUnitTests.config
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/NUnitTests.config b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/NUnitTests.config
deleted file mode 100644
index fb15771..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/NUnitTests.config
+++ /dev/null
@@ -1,85 +0,0 @@
-<?xml version="1.0" encoding="utf-8" ?>
-<configuration>
-<!--
-	 This is the configuration file for the NUnitTests.nunit test project. You may
-	 need to create a similar configuration file for your own test project. 
- -->	 
-
-<!--
-	 The <NUnit> section is only needed if you want to use a non-default value
-	 for any of the settings. It is commented out below. If you are going to use
-   it, you must deifne the NUnit section group and the sections you need.
- 
-   The syntax shown here works for most runtimes. If NUnit fails at startup, you
-   can try specifying the name of the assembly containing the NameValueSectionHandler:
-   
-      <section name="TestCaseBuilder" type="System.Configuration.NameValueSectionHandler, System" />
-      
-   If that fails, try the fully qualified name of the assembly:
-   
-      <section name="TestCaseBuilder" type="System.Configuration.NameValueSectionHandler, System, 
-             Version=2.0.50727.832, Culture=neutral, PublicKeyToken=b77a5c561934e089" />
-             
-   Unfortunately, this last approach makes your config file non-portable across runtimes.
-   -->
-
-<!--
-  <configSections>
-		<sectionGroup name="NUnit">
-			<section name="TestCaseBuilder" type="System.Configuration.NameValueSectionHandler"/>
-			<section name="TestRunner" type="System.Configuration.NameValueSectionHandler"/>
-		</sectionGroup>
-	</configSections>
- -->
-
-  <appSettings>
-		<!--   User application and configured property settings go here.-->
-		<!--   Example: <add key="settingName" value="settingValue"/> -->
-		<add key="test.setting" value="54321" />
-	</appSettings>
-
-<!-- Sample NUnit section group showing all default values -->
-<!--
-	<NUnit>
-		<TestCaseBuilder>
-			<add key="OldStyleTestCases" value="false" />
-		</TestCaseBuilder>
-		<TestRunner>
-			<add key="ApartmentState" value="MTA" />
-			<add key="ThreadPriority" value="Normal" />
-      <add key="DefaultLogThreshold" value="Info" />
-		</TestRunner>
-	</NUnit>
--->
-  
-   <!--
-    The following <runtime> section allows running nunit tests under 
-    .NET 1.0 by redirecting assemblies. The appliesTo attribute
-    causes the section to be ignored except under .NET 1.0.
-   --> 
-	<runtime>
-		<assemblyBinding xmlns="urn:schemas-microsoft-com:asm.v1"
-				appliesTo="v1.0.3705">
-			<dependentAssembly>
-				<assemblyIdentity name="System" publicKeyToken="b77a5c561934e089" culture="" />
-				<bindingRedirect oldVersion="1.0.5000.0" newVersion="1.0.3300.0" />
-			</dependentAssembly>
-			<dependentAssembly>
-				<assemblyIdentity name="System.Data" publicKeyToken="b77a5c561934e089" culture="" />
-				<bindingRedirect oldVersion="1.0.5000.0" newVersion="1.0.3300.0" />
-			</dependentAssembly>
-			<dependentAssembly>
-				<assemblyIdentity name="System.Drawing" publicKeyToken="b03f5f7f11d50a3a" culture="" />
-				<bindingRedirect oldVersion="1.0.5000.0" newVersion="1.0.3300.0" />
-			</dependentAssembly>
-			<dependentAssembly>
-				<assemblyIdentity name="System.Windows.Forms" publicKeyToken="b77a5c561934e089" culture="" />
-				<bindingRedirect oldVersion="1.0.5000.0" newVersion="1.0.3300.0" />
-			</dependentAssembly>
-			<dependentAssembly>
-				<assemblyIdentity name="System.Xml" publicKeyToken="b77a5c561934e089" culture="" />
-				<bindingRedirect oldVersion="1.0.5000.0" newVersion="1.0.3300.0" />
-			</dependentAssembly>
-		</assemblyBinding>
-	</runtime>
-</configuration> 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/NUnitTests.nunit
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/NUnitTests.nunit b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/NUnitTests.nunit
deleted file mode 100644
index 55e6ea2..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/NUnitTests.nunit
+++ /dev/null
@@ -1,11 +0,0 @@
-<NUnitProject>
-  <Settings appbase="."/>
-  <Config name="Default" binpath="lib;tests;framework">
-    <assembly path="tests/nunit.framework.tests.dll" />
-    <assembly path="tests/nunit.core.tests.dll" />
-    <assembly path="tests/nunit.util.tests.dll" />
-    <assembly path="tests/nunit.mocks.tests.dll" />
-    <assembly path="tests/nunit-console.tests.dll" />
-    <assembly path="tests/nunit.fixtures.tests.dll" />
-  </Config>
-</NUnitProject>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/agent.conf
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/agent.conf b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/agent.conf
deleted file mode 100644
index ddbcd8e..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/agent.conf
+++ /dev/null
@@ -1,4 +0,0 @@
-<AgentConfig>
-  <Port>8080</Port>
-  <PathToAssemblies>.</PathToAssemblies>
-</AgentConfig>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/agent.log.conf
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/agent.log.conf b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/agent.log.conf
deleted file mode 100644
index 4bd90ca..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/agent.log.conf
+++ /dev/null
@@ -1,18 +0,0 @@
-<log4net>
-	<!-- A1 is set to be a ConsoleAppender -->
-	<appender name="A1" type="log4net.Appender.ConsoleAppender">
-
-		<!-- A1 uses PatternLayout -->
-		<layout type="log4net.Layout.PatternLayout">
-			<!-- Print the date in ISO 8601 format -->
-			<conversionPattern value="%-5level %logger - %message%newline" />
-		</layout>
-	</appender>
-	
-	<!-- Set root logger level to DEBUG and its only appender to A1 -->
-	<root>
-		<level value="DEBUG" />
-		<appender-ref ref="A1" />
-	</root>
-
-</log4net>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/framework/nunit.framework.dll
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/framework/nunit.framework.dll b/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/framework/nunit.framework.dll
deleted file mode 100644
index 105213c..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-1.1/framework/nunit.framework.dll and /dev/null differ


[31/51] [abbrv] [partial] Cleaning up and getting ready to development towards v4.8

Posted by sy...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/MbUnit.xml
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/MbUnit.xml b/lib/Gallio.3.2.750/tools/MbUnit.xml
deleted file mode 100644
index 095f2ac..0000000
--- a/lib/Gallio.3.2.750/tools/MbUnit.xml
+++ /dev/null
@@ -1,12247 +0,0 @@
-<?xml version="1.0"?>
-<doc>
-    <assembly>
-        <name>MbUnit</name>
-    </assembly>
-    <members>
-        <member name="T:MbUnit.Framework.ContractVerifiers.Core.NotEnoughHashesException">
-            <summary>
-            This exception type is used to signal that a <see cref="T:MbUnit.Framework.ContractVerifiers.Core.HashStore"/> was
-            not initialized with a sufficient number of hash code values.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.ContractVerifiers.Core.NotEnoughHashesException.#ctor(System.Int32,System.Int32)">
-            <summary>
-            Creates an exception specifying the expected minimum and the
-            actual number of hash code values.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.ContractVerifiers.Core.NotEnoughHashesException.#ctor(System.Runtime.Serialization.SerializationInfo,System.Runtime.Serialization.StreamingContext)">
-            <summary>
-            Creates a exception from serialization info.
-            </summary>
-            <param name="info">The serialization info.</param>
-            <param name="context">The streaming context.</param>
-        </member>
-        <member name="T:MbUnit.Framework.Assert">
-            <summary>
-            Defines a set of assertions that enable a test to verify the expected
-            behavior of the subject under test.
-            </summary>
-            <remarks>
-            <para>
-            Each assertion is generally provided in at least 4 flavors distinguished by overloads:
-            <list type="bullet">
-            <item>A simple form that takes only the assertion parameters.</item>
-            <item>A simple form that accepts a custom message format string and arguments in addition to the assertion parameters.</item>
-            <item>A rich form that takes the assertion parameters and a custom comparer object.</item>
-            <item>A rich form that accepts a custom message format string and arguments in addition to the assertion parameters and a custom comparer object.</item>
-            </list>
-            </para>
-            <para>
-            The value upon which the assertion is being evaluated is usually called the "actual value".
-            Other parameters for the assertion are given names such as the "expected value", "unexpected value",
-            or other terms as appropriate.  In some cases where the role of a parameter is ambiguous,
-            we may use designations such as "left" and "right" to distinguish the parameters.
-            </para>
-            <para>
-            The Assert class does not provide direct support for old-style collection types such as <see cref="T:System.Collections.ICollection"/>
-            and <see cref="T:System.Collections.IEnumerable"/>.  If you are using .Net 3.5 for your test projects, you may find the
-            "Cast" function helpful.
-            <example>
-            <code>
-            ICollection myOldCollection = subjectUnderTest.DoSomething();
-            Assert.AreElementsEqual(new[] { "a", "b", "c" }, myOldCollection.Cast&lt;string&gt;());
-            </code>
-            </example>
-            </para>
-            <para>
-            Framework authors may choose to extend this class with additional assertions by creating
-            a subclass.  Alternately, new assertions can be defined in other classes.
-            </para>
-            <para>
-            When formatting values for inclusion in assertion failures, it is recommended to use the
-            formatter provided by the <see cref="P:Gallio.Framework.Assertions.AssertionFailureBuilder.Formatter"/> property instead
-            of directly calling <see cref="M:System.Object.ToString"/>.  This enables custom formatting rules to
-            decide how best to present values of particular types and yields a more consistent user experience.
-            In particular the <see cref="M:Gallio.Framework.Assertions.AssertionFailureBuilder.AddRawLabeledValue(System.String,System.Object)"/> method and
-            its siblings automatically format values in this manner.
-            </para>
-            </remarks>
-        </member>
-        <member name="M:MbUnit.Framework.Assert.HasAttribute(System.Type,System.Reflection.MemberInfo)">
-            <summary>
-            Verifies that the targeted object is decorated once with the specified <see cref="T:System.Attribute"/>.
-            </summary>
-            <remarks>
-            <para>
-            The assertion returns the instance of the actual attribute found.
-            </para>
-            <para>
-            The assertion fails if the target object is decorated with multiple instances of the searched attribute. If several
-            instances are expected, use <see cref="M:MbUnit.Framework.Assert.HasAttribute(System.Type,System.Reflection.MemberInfo)"/> instead.
-            </para>
-            </remarks>
-            <param name="expectedAttributeType">The type of the searched <see cref="T:System.Attribute"/>.</param>
-            <param name="target">The targeted object to evaluate.</param>
-            <returns>The instance of the actual attribute found.</returns>
-            <exception cref="T:Gallio.Framework.Assertions.AssertionException">Thrown if the verification failed unless the current <see cref="P:Gallio.Framework.Assertions.AssertionContext.AssertionFailureBehavior"/> indicates otherwise.</exception>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="expectedAttributeType"/> or <paramref name="target"/> is null.</exception>
-        </member>
-        <member name="M:MbUnit.Framework.Assert.HasAttribute(System.Type,System.Reflection.MemberInfo,System.String,System.Object[])">
-            <summary>
-            Verifies that the targeted object is decorated once with the specified <see cref="T:System.Attribute"/>.
-            </summary>
-            <remarks>
-            <para>
-            The assertion returns the instance of the actual attribute found.
-            </para>
-            <para>
-            The assertion fails if the target object is decorated with multiple instances of the searched attribute. If several
-            instances are expected, use <see cref="M:MbUnit.Framework.Assert.HasAttribute(System.Type,System.Reflection.MemberInfo,System.String,System.Object[])"/> instead.
-            </para>
-            </remarks>
-            <param name="expectedAttributeType">The type of the searched <see cref="T:System.Attribute"/>.</param>
-            <param name="target">The targeted object to evaluate.</param>
-            <param name="messageFormat">The custom assertion message format, or null if none.</param>
-            <param name="messageArgs">The custom assertion message arguments, or null if none.</param>
-            <returns>The instance of the actual attribute found.</returns>
-            <exception cref="T:Gallio.Framework.Assertions.AssertionException">Thrown if the verification failed unless the current <see cref="P:Gallio.Framework.Assertions.AssertionContext.AssertionFailureBehavior"/> indicates otherwise.</exception>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="expectedAttributeType"/> or <paramref name="target"/> is null.</exception>
-        </member>
-        <member name="M:MbUnit.Framework.Assert.HasAttribute``1(System.Reflection.MemberInfo)">
-            <summary>
-            Verifies that the targeted type is decorated once with the specified <see cref="T:System.Attribute"/>.
-            </summary>
-            <remarks>
-            <para>
-            The assertion returns the instance of the actual attribute found.
-            </para>
-            <para>
-            The assertion fails if the target object is decorated with multiple instances of the searched attribute. If several
-            instances are expected, use <see cref="M:MbUnit.Framework.Assert.HasAttribute``1(System.Reflection.MemberInfo)"/> instead.
-            </para>
-            </remarks>
-            <typeparam name="TAttribute">The type of the searched <see cref="T:System.Attribute"/>.</typeparam>
-            <param name="target">The target type to evaluate.</param>
-            <returns>The instance of the actual attribute found.</returns>
-            <exception cref="T:Gallio.Framework.Assertions.AssertionException">Thrown if the verification failed unless the current <see cref="P:Gallio.Framework.Assertions.AssertionContext.AssertionFailureBehavior"/> indicates otherwise.</exception>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="target"/> is null.</exception>
-        </member>
-        <member name="M:MbUnit.Framework.Assert.HasAttribute``1(System.Reflection.MemberInfo,System.String,System.Object[])">
-            <summary>
-            Verifies that the targeted type is decorated once with the specified <see cref="T:System.Attribute"/>.
-            </summary>
-            <remarks>
-            <para>
-            The assertion returns the instance of the actual attribute found.
-            </para>
-            <para>
-            The assertion fails if the target object is decorated with multiple instances of the searched attribute. If several
-            instances are expected, use <see cref="M:MbUnit.Framework.Assert.HasAttribute``1(System.Reflection.MemberInfo,System.String,System.Object[])"/> instead.
-            </para>
-            </remarks>
-            <typeparam name="TAttribute">The type of the searched <see cref="T:System.Attribute"/>.</typeparam>
-            <param name="target">The target type to evaluate.</param>
-            <param name="messageFormat">The custom assertion message format, or null if none.</param>
-            <param name="messageArgs">The custom assertion message arguments, or null if none.</param>
-            <returns>The instance of the actual attribute found.</returns>
-            <exception cref="T:Gallio.Framework.Assertions.AssertionException">Thrown if the verification failed unless the current <see cref="P:Gallio.Framework.Assertions.AssertionContext.AssertionFailureBehavior"/> indicates otherwise.</exception>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="target"/> is null.</exception>
-        </member>
-        <member name="M:MbUnit.Framework.Assert.HasAttribute(System.Type,MbUnit.Framework.Mirror.MemberSet)">
-            <summary>
-            Verifies that the targeted object is decorated once with the specified <see cref="T:System.Attribute"/>.
-            </summary>
-            <remarks>
-            <para>
-            The assertion returns the instance of the actual attribute found.
-            </para>
-            <para>
-            The assertion fails if the target object is decorated with multiple instances of the searched attribute. If several
-            instances are expected, use <see cref="M:MbUnit.Framework.Assert.HasAttribute(System.Type,System.Reflection.MemberInfo)"/> instead.
-            </para>
-            </remarks>
-            <param name="expectedAttributeType">The type of the searched <see cref="T:System.Attribute"/>.</param>
-            <param name="target">The targeted object to evaluate.</param>
-            <returns>The instance of the actual attribute found.</returns>
-            <exception cref="T:Gallio.Framework.Assertions.AssertionException">Thrown if the verification failed unless the current <see cref="P:Gallio.Framework.Assertions.AssertionContext.AssertionFailureBehavior"/> indicates otherwise.</exception>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="expectedAttributeType"/> or <paramref name="target"/> is null.</exception>
-        </member>
-        <member name="M:MbUnit.Framework.Assert.HasAttribute(System.Type,MbUnit.Framework.Mirror.MemberSet,System.String,System.Object[])">
-            <summary>
-            Verifies that the targeted object is decorated once with the specified <see cref="T:System.Attribute"/>.
-            </summary>
-            <remarks>
-            <para>
-            The assertion returns the instance of the actual attribute found.
-            </para>
-            <para>
-            The assertion fails if the target object is decorated with multiple instances of the searched attribute. If several
-            instances are expected, use <see cref="M:MbUnit.Framework.Assert.HasAttribute(System.Type,System.Reflection.MemberInfo,System.String,System.Object[])"/> instead.
-            </para>
-            </remarks>
-            <param name="expectedAttributeType">The type of the searched <see cref="T:System.Attribute"/>.</param>
-            <param name="target">The targeted object to evaluate.</param>
-            <param name="messageFormat">The custom assertion message format, or null if none.</param>
-            <param name="messageArgs">The custom assertion message arguments, or null if none.</param>
-            <returns>The instance of the actual attribute found.</returns>
-            <exception cref="T:Gallio.Framework.Assertions.AssertionException">Thrown if the verification failed unless the current <see cref="P:Gallio.Framework.Assertions.AssertionContext.AssertionFailureBehavior"/> indicates otherwise.</exception>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="expectedAttributeType"/> or <paramref name="target"/> is null.</exception>
-        </member>
-        <member name="M:MbUnit.Framework.Assert.HasAttribute``1(MbUnit.Framework.Mirror.MemberSet)">
-            <summary>
-            Verifies that the targeted type is decorated once with the specified <see cref="T:System.Attribute"/>.
-            </summary>
-            <remarks>
-            <para>
-            The assertion returns the instance of the actual attribute found.
-            </para>
-            <para>
-            The assertion fails if the target object is decorated with multiple instances of the searched attribute. If several
-            instances are expected, use <see cref="M:MbUnit.Framework.Assert.HasAttribute``1(System.Reflection.MemberInfo)"/> instead.
-            </para>
-            </remarks>
-            <typeparam name="TAttribute">The type of the searched <see cref="T:System.Attribute"/>.</typeparam>
-            <param name="target">The target type to evaluate.</param>
-            <returns>The instance of the actual attribute found.</returns>
-            <exception cref="T:Gallio.Framework.Assertions.AssertionException">Thrown if the verification failed unless the current <see cref="P:Gallio.Framework.Assertions.AssertionContext.AssertionFailureBehavior"/> indicates otherwise.</exception>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="target"/> is null.</exception>
-        </member>
-        <member name="M:MbUnit.Framework.Assert.HasAttribute``1(MbUnit.Framework.Mirror.MemberSet,System.String,System.Object[])">
-            <summary>
-            Verifies that the targeted type is decorated once with the specified <see cref="T:System.Attribute"/>.
-            </summary>
-            <remarks>
-            <para>
-            The assertion returns the instance of the actual attribute found.
-            </para>
-            <para>
-            The assertion fails if the target object is decorated with multiple instances of the searched attribute. If several
-            instances are expected, use <see cref="M:MbUnit.Framework.Assert.HasAttribute``1(System.Reflection.MemberInfo,System.String,System.Object[])"/> instead.
-            </para>
-            </remarks>
-            <typeparam name="TAttribute">The type of the searched <see cref="T:System.Attribute"/>.</typeparam>
-            <param name="target">The target type to evaluate.</param>
-            <param name="messageFormat">The custom assertion message format, or null if none.</param>
-            <param name="messageArgs">The custom assertion message arguments, or null if none.</param>
-            <returns>The instance of the actual attribute found.</returns>
-            <exception cref="T:Gallio.Framework.Assertions.AssertionException">Thrown if the verification failed unless the current <see cref="P:Gallio.Framework.Assertions.AssertionContext.AssertionFailureBehavior"/> indicates otherwise.</exception>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="target"/> is null.</exception>
-        </member>
-        <member name="M:MbUnit.Framework.Assert.HasAttributes(System.Type,System.Reflection.MemberInfo)">
-            <summary>
-            Verifies that the targeted object is decorated with one or several instances of the specified <see cref="T:System.Attribute"/>.
-            </summary>
-            <param name="expectedAttributeType">The type of the searched <see cref="T:System.Attribute"/>.</param>
-            <param name="target">The targeted object to evaluate.</param>
-            <returns>An array of attribute instances.</returns>
-            <exception cref="T:Gallio.Framework.Assertions.AssertionException">Thrown if the verification failed unless the current <see cref="P:Gallio.Framework.Assertions.AssertionContext.AssertionFailureBehavior"/> indicates otherwise.</exception>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="expectedAttributeType"/> or <paramref name="target"/> is null.</exception>
-        </member>
-        <member name="M:MbUnit.Framework.Assert.HasAttributes(System.Type,System.Reflection.MemberInfo,System.String,System.Object[])">
-            <summary>
-            Verifies that the targeted object is decorated with one or several instances of the specified <see cref="T:System.Attribute"/>.
-            </summary>
-            <param name="expectedAttributeType">The type of the searched <see cref="T:System.Attribute"/>.</param>
-            <param name="target">The targeted object to evaluate.</param>
-            <param name="messageFormat">The custom assertion message format, or null if none.</param>
-            <param name="messageArgs">The custom assertion message arguments, or null if none.</param>
-            <returns>An array of attribute instances.</returns>
-            <exception cref="T:Gallio.Framework.Assertions.AssertionException">Thrown if the verification failed unless the current <see cref="P:Gallio.Framework.Assertions.AssertionContext.AssertionFailureBehavior"/> indicates otherwise.</exception>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="expectedAttributeType"/> or <paramref name="target"/> is null.</exception>
-        </member>
-        <member name="M:MbUnit.Framework.Assert.HasAttributes``1(System.Reflection.MemberInfo)">
-            <summary>
-            Verifies that the targeted object is decorated with one or several instances of the specified <see cref="T:System.Attribute"/>.
-            </summary>
-            <typeparam name="TAttribute">The type of the searched <see cref="T:System.Attribute"/>.</typeparam>
-            <param name="target">The target type to evaluate.</param>
-            <returns>An array of attribute instances.</returns>
-            <exception cref="T:Gallio.Framework.Assertions.AssertionException">Thrown if the verification failed unless the current <see cref="P:Gallio.Framework.Assertions.AssertionContext.AssertionFailureBehavior"/> indicates otherwise.</exception>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="target"/> is null.</exception>
-        </member>
-        <member name="M:MbUnit.Framework.Assert.HasAttributes``1(System.Reflection.MemberInfo,System.String,System.Object[])">
-            <summary>
-            Verifies that the targeted object is decorated with one or several instances of the specified <see cref="T:System.Attribute"/>.
-            </summary>
-            <typeparam name="TAttribute">The type of the searched <see cref="T:System.Attribute"/>.</typeparam>
-            <param name="target">The target type to evaluate.</param>
-            <param name="messageFormat">The custom assertion message format, or null if none.</param>
-            <param name="messageArgs">The custom assertion message arguments, or null if none.</param>
-            <returns>An array of attribute instances.</returns>
-            <exception cref="T:Gallio.Framework.Assertions.AssertionException">Thrown if the verification failed unless the current <see cref="P:Gallio.Framework.Assertions.AssertionContext.AssertionFailureBehavior"/> indicates otherwise.</exception>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="target"/> is null.</exception>
-        </member>
-        <member name="M:MbUnit.Framework.Assert.HasAttributes(System.Type,MbUnit.Framework.Mirror.MemberSet)">
-            <summary>
-            Verifies that the targeted object is decorated with one or several instances of the specified <see cref="T:System.Attribute"/>.
-            </summary>
-            <param name="expectedAttributeType">The type of the searched <see cref="T:System.Attribute"/>.</param>
-            <param name="target">The targeted object to evaluate.</param>
-            <returns>An array of attribute instances.</returns>
-            <exception cref="T:Gallio.Framework.Assertions.AssertionException">Thrown if the verification failed unless the current <see cref="P:Gallio.Framework.Assertions.AssertionContext.AssertionFailureBehavior"/> indicates otherwise.</exception>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="expectedAttributeType"/> or <paramref name="target"/> is null.</exception>
-        </member>
-        <member name="M:MbUnit.Framework.Assert.HasAttributes(System.Type,MbUnit.Framework.Mirror.MemberSet,System.String,System.Object[])">
-            <summary>
-            Verifies that the targeted object is decorated with one or several instances of the specified <see cref="T:System.Attribute"/>.
-            </summary>
-            <param name="expectedAttributeType">The type of the searched <see cref="T:System.Attribute"/>.</param>
-            <param name="target">The targeted object to evaluate.</param>
-            <param name="messageFormat">The custom assertion message format, or null if none.</param>
-            <param name="messageArgs">The custom assertion message arguments, or null if none.</param>
-            <returns>An array of attribute instances.</returns>
-            <exception cref="T:Gallio.Framework.Assertions.AssertionException">Thrown if the verification failed unless the current <see cref="P:Gallio.Framework.Assertions.AssertionContext.AssertionFailureBehavior"/> indicates otherwise.</exception>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="expectedAttributeType"/> or <paramref name="target"/> is null.</exception>
-        </member>
-        <member name="M:MbUnit.Framework.Assert.HasAttributes``1(MbUnit.Framework.Mirror.MemberSet)">
-            <summary>
-            Verifies that the targeted object is decorated with one or several instances of the specified <see cref="T:System.Attribute"/>.
-            </summary>
-            <typeparam name="TAttribute">The type of the searched <see cref="T:System.Attribute"/>.</typeparam>
-            <param name="target">The target type to evaluate.</param>
-            <returns>An array of attribute instances.</returns>
-            <exception cref="T:Gallio.Framework.Assertions.AssertionException">Thrown if the verification failed unless the current <see cref="P:Gallio.Framework.Assertions.AssertionContext.AssertionFailureBehavior"/> indicates otherwise.</exception>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="target"/> is null.</exception>
-        </member>
-        <member name="M:MbUnit.Framework.Assert.HasAttributes``1(MbUnit.Framework.Mirror.MemberSet,System.String,System.Object[])">
-            <summary>
-            Verifies that the targeted object is decorated with one or several instances of the specified <see cref="T:System.Attribute"/>.
-            </summary>
-            <typeparam name="TAttribute">The type of the searched <see cref="T:System.Attribute"/>.</typeparam>
-            <param name="target">The target type to evaluate.</param>
-            <param name="messageFormat">The custom assertion message format, or null if none.</param>
-            <param name="messageArgs">The custom assertion message arguments, or null if none.</param>
-            <returns>An array of attribute instances.</returns>
-            <exception cref="T:Gallio.Framework.Assertions.AssertionException">Thrown if the verification failed unless the current <see cref="P:Gallio.Framework.Assertions.AssertionContext.AssertionFailureBehavior"/> indicates otherwise.</exception>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="target"/> is null.</exception>
-        </member>
-        <member name="M:MbUnit.Framework.Assert.HasAttributes(System.Type,System.Reflection.MemberInfo,System.Int32)">
-            <summary>
-            Verifies that the targeted object is decorated with the exact number of instances of the specified <see cref="T:System.Attribute"/>.
-            </summary>
-            <param name="expectedAttributeType">The type of the searched <see cref="T:System.Attribute"/>.</param>
-            <param name="target">The targeted object to evaluate.</param>
-            <param name="expectedCount">The expected number of attribute instances to be found.</param>
-            <returns>An array of attribute instances.</returns>
-            <exception cref="T:Gallio.Framework.Assertions.AssertionException">Thrown if the verification failed unless the current <see cref="P:Gallio.Framework.Assertions.AssertionContext.AssertionFailureBehavior"/> indicates otherwise.</exception>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="expectedAttributeType"/> or <paramref name="target"/> is null.</exception>
-            <exception cref="T:System.ArgumentOutOfRangeException">Thrown if <paramref name="expectedCount"/> is less than or equal to zero.</exception>
-        </member>
-        <member name="M:MbUnit.Framework.Assert.HasAttributes(System.Type,System.Reflection.MemberInfo,System.Int32,System.String,System.Object[])">
-            <summary>
-            Verifies that the targeted object is decorated with the exact number of instances of the specified <see cref="T:System.Attribute"/>.
-            </summary>
-            <param name="expectedAttributeType">The type of the searched <see cref="T:System.Attribute"/>.</param>
-            <param name="target">The targeted object to evaluate.</param>
-            <param name="expectedCount">The expected number of attribute instances to be found.</param>
-            <param name="messageFormat">The custom assertion message format, or null if none.</param>
-            <param name="messageArgs">The custom assertion message arguments, or null if none.</param>
-            <returns>An array of attribute instances.</returns>
-            <exception cref="T:Gallio.Framework.Assertions.AssertionException">Thrown if the verification failed unless the current <see cref="P:Gallio.Framework.Assertions.AssertionContext.AssertionFailureBehavior"/> indicates otherwise.</exception>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="expectedAttributeType"/> or <paramref name="target"/> is null.</exception>
-            <exception cref="T:System.ArgumentOutOfRangeException">Thrown if <paramref name="expectedCount"/> is less than or equal to zero.</exception>
-        </member>
-        <member name="M:MbUnit.Framework.Assert.HasAttributes``1(System.Reflection.MemberInfo,System.Int32)">
-            <summary>
-            Verifies that the targeted object is decorated with the exact number of instances of the specified <see cref="T:System.Attribute"/>.
-            </summary>
-            <typeparam name="TAttribute">The type of the searched <see cref="T:System.Attribute"/>.</typeparam>
-            <param name="target">The target type to evaluate.</param>
-            <param name="expectedCount">The expected number of attribute instances to be found.</param>
-            <returns>An array of attribute instances.</returns>
-            <exception cref="T:Gallio.Framework.Assertions.AssertionException">Thrown if the verification failed unless the current <see cref="P:Gallio.Framework.Assertions.AssertionContext.AssertionFailureBehavior"/> indicates otherwise.</exception>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="target"/> is null.</exception>
-            <exception cref="T:System.ArgumentOutOfRangeException">Thrown if <paramref name="expectedCount"/> is less than or equal to zero.</exception>
-        </member>
-        <member name="M:MbUnit.Framework.Assert.HasAttributes``1(System.Reflection.MemberInfo,System.Int32,System.String,System.Object[])">
-            <summary>
-            Verifies that the targeted object is decorated with the exact number of instances of the specified <see cref="T:System.Attribute"/>.
-            </summary>
-            <typeparam name="TAttribute">The type of the searched <see cref="T:System.Attribute"/>.</typeparam>
-            <param name="target">The target type to evaluate.</param>
-            <param name="expectedCount">The expected number of attribute instances to be found.</param>
-            <param name="messageFormat">The custom assertion message format, or null if none.</param>
-            <param name="messageArgs">The custom assertion message arguments, or null if none.</param>
-            <returns>An array of attribute instances.</returns>
-            <exception cref="T:Gallio.Framework.Assertions.AssertionException">Thrown if the verification failed unless the current <see cref="P:Gallio.Framework.Assertions.AssertionContext.AssertionFailureBehavior"/> indicates otherwise.</exception>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="target"/> is null.</exception>
-            <exception cref="T:System.ArgumentOutOfRangeException">Thrown if <paramref name="expectedCount"/> is less than or equal to zero.</exception>
-        </member>
-        <member name="M:MbUnit.Framework.Assert.HasAttributes(System.Type,MbUnit.Framework.Mirror.MemberSet,System.Int32)">
-            <summary>
-            Verifies that the targeted object is decorated with the exact number of instances of the specified <see cref="T:System.Attribute"/>.
-            </summary>
-            <param name="expectedAttributeType">The type of the searched <see cref="T:System.Attribute"/>.</param>
-            <param name="target">The targeted object to evaluate.</param>
-            <param name="expectedCount">The expected number of attribute instances to be found.</param>
-            <returns>An array of attribute instances.</returns>
-            <exception cref="T:Gallio.Framework.Assertions.AssertionException">Thrown if the verification failed unless the current <see cref="P:Gallio.Framework.Assertions.AssertionContext.AssertionFailureBehavior"/> indicates otherwise.</exception>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="expectedAttributeType"/> or <paramref name="target"/> is null.</exception>
-            <exception cref="T:System.ArgumentOutOfRangeException">Thrown if <paramref name="expectedCount"/> is less than or equal to zero.</exception>
-        </member>
-        <member name="M:MbUnit.Framework.Assert.HasAttributes(System.Type,MbUnit.Framework.Mirror.MemberSet,System.Int32,System.String,System.Object[])">
-            <summary>
-            Verifies that the targeted object is decorated with the exact number of instances of the specified <see cref="T:System.Attribute"/>.
-            </summary>
-            <param name="expectedAttributeType">The type of the searched <see cref="T:System.Attribute"/>.</param>
-            <param name="target">The targeted object to evaluate.</param>
-            <param name="expectedCount">The expected number of attribute instances to be found.</param>
-            <param name="messageFormat">The custom assertion message format, or null if none.</param>
-            <param name="messageArgs">The custom assertion message arguments, or null if none.</param>
-            <returns>An array of attribute instances.</returns>
-            <exception cref="T:Gallio.Framework.Assertions.AssertionException">Thrown if the verification failed unless the current <see cref="P:Gallio.Framework.Assertions.AssertionContext.AssertionFailureBehavior"/> indicates otherwise.</exception>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="expectedAttributeType"/> or <paramref name="target"/> is null.</exception>
-            <exception cref="T:System.ArgumentOutOfRangeException">Thrown if <paramref name="expectedCount"/> is less than or equal to zero.</exception>
-        </member>
-        <member name="M:MbUnit.Framework.Assert.HasAttributes``1(MbUnit.Framework.Mirror.MemberSet,System.Int32)">
-            <summary>
-            Verifies that the targeted object is decorated with the exact number of instances of the specified <see cref="T:System.Attribute"/>.
-            </summary>
-            <typeparam name="TAttribute">The type of the searched <see cref="T:System.Attribute"/>.</typeparam>
-            <param name="target">The target type to evaluate.</param>
-            <param name="expectedCount">The expected number of attribute instances to be found.</param>
-            <returns>An array of attribute instances.</returns>
-            <exception cref="T:Gallio.Framework.Assertions.AssertionException">Thrown if the verification failed unless the current <see cref="P:Gallio.Framework.Assertions.AssertionContext.AssertionFailureBehavior"/> indicates otherwise.</exception>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="target"/> is null.</exception>
-            <exception cref="T:System.ArgumentOutOfRangeException">Thrown if <paramref name="expectedCount"/> is less than or equal to zero.</exception>
-        </member>
-        <member name="M:MbUnit.Framework.Assert.HasAttributes``1(MbUnit.Framework.Mirror.MemberSet,System.Int32,System.String,System.Object[])">
-            <summary>
-            Verifies that the targeted object is decorated with the exact number of instances of the specified <see cref="T:System.Attribute"/>.
-            </summary>
-            <typeparam name="TAttribute">The type of the searched <see cref="T:System.Attribute"/>.</typeparam>
-            <param name="target">The target type to evaluate.</param>
-            <param name="expectedCount">The expected number of attribute instances to be found.</param>
-            <param name="messageFormat">The custom assertion message format, or null if none.</param>
-            <param name="messageArgs">The custom assertion message arguments, or null if none.</param>
-            <returns>An array of attribute instances.</returns>
-            <exception cref="T:Gallio.Framework.Assertions.AssertionException">Thrown if the verification failed unless the current <see cref="P:Gallio.Framework.Assertions.AssertionContext.AssertionFailureBehavior"/> indicates otherwise.</exception>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="target"/> is null.</exception>
-            <exception cref="T:System.ArgumentOutOfRangeException">Thrown if <paramref name="expectedCount"/> is less than or equal to zero.</exception>
-        </member>
-        <member name="M:MbUnit.Framework.Assert.Count(System.Int32,System.Collections.IEnumerable)">
-            <summary>
-            Verifies that the specified sequence, collection, or array contains the expected number of elements.
-            </summary>
-            <remarks>
-            <para>
-            The assertion counts the elements according to the underlying type of the sequence.
-            <list type="bullet">
-            <item>Uses <see cref="P:System.Array.Length"/> if the sequence is an array.</item>
-            <item>Uses <see cref="P:System.Collections.ICollection.Count"/> or <see cref="P:System.Collections.Generic.ICollection`1.Count"/> if the sequence is a collection such as <see cref="T:System.Collections.Generic.List`1"/> or <see cref="T:System.Collections.Generic.Dictionary`2"/>. It enumerates and counts the elements as well.</item>
-            <item>Enumerates and counts the elements if the sequence is a simple <see cref="T:System.Collections.IEnumerable"/>.</item>
-            </list>
-            </para>
-            </remarks>
-            <param name="expectedCount">The expected number of elements.</param>
-            <param name="values">The enumeration of elements to count.</param>
-            <exception cref="T:Gallio.Framework.Assertions.AssertionException">Thrown if the verification failed unless the current <see cref="P:Gallio.Framework.Assertions.AssertionContext.AssertionFailureBehavior"/> indicates otherwise.</exception>
-            <exception cref="T:System.ArgumentOutOfRangeException">Thrown if <paramref name="expectedCount"/> is negative.</exception>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="values"/> is null.</exception>
-        </member>
-        <member name="M:MbUnit.Framework.Assert.Count(System.Int32,System.Collections.IEnumerable,System.String,System.Object[])">
-            <summary>
-            Verifies that the specified sequence, collection, or array contains the expected number of elements.
-            </summary>
-            <remarks>
-            <para>
-            The assertion counts the elements according to the underlying type of the sequence.
-            <list type="bullet">
-            <item>Uses <see cref="P:System.Array.Length"/> if the sequence is an array.</item>
-            <item>Uses <see cref="P:System.Collections.ICollection.Count"/> or <see cref="P:System.Collections.Generic.ICollection`1.Count"/> if the sequence is a collection such as <see cref="T:System.Collections.Generic.List`1"/> or <see cref="T:System.Collections.Generic.Dictionary`2"/>. It enumerates and counts the elements as well.</item>
-            <item>Enumerates and counts the elements if the sequence is a simple <see cref="T:System.Collections.IEnumerable"/>.</item>
-            </list>
-            </para>
-            </remarks>
-            <param name="expectedCount">The expected number of elements.</param>
-            <param name="values">The enumeration of elements to count.</param>
-            <param name="messageFormat">The custom assertion message format, or null if none.</param>
-            <param name="messageArgs">The custom assertion message arguments, or null if none.</param>
-            <exception cref="T:Gallio.Framework.Assertions.AssertionException">Thrown if the verification failed unless the current <see cref="P:Gallio.Framework.Assertions.AssertionContext.AssertionFailureBehavior"/> indicates otherwise.</exception>
-            <exception cref="T:System.ArgumentOutOfRangeException">Thrown if <paramref name="expectedCount"/> is negative.</exception>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="values"/> is null.</exception>
-        </member>
-        <member name="M:MbUnit.Framework.Assert.#ctor">
-            <summary>
-            Prevents instantiation.
-            Subclasses should likewise define their constructor to be protected.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.Assert.Equals(System.Object,System.Object)">
-            <summary>
-            Always throws an <see cref="T:System.InvalidOperationException"/>.
-            Use <see cref="M:MbUnit.Framework.Assert.AreEqual``1(``0,``0)"/> instead.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.Assert.ReferenceEquals(System.Object,System.Object)">
-            <summary>
-            Always throws an <see cref="T:System.InvalidOperationException"/>.
-            Use <see cref="M:MbUnit.Framework.Assert.AreSame``1(``0,``0)"/> instead.
-            </summary>
-        </member>
-        <member name="M:MbUnit.Framework.Assert.Fail">
-            <summary>
-            Signals an unconditional assertion failure.
-            </summary>
-            <remarks>
-            <para>
-            Use <see cref="M:Gallio.Framework.Assertions.AssertionHelper.Verify(Gallio.Common.Func{Gallio.Framework.Assertions.AssertionFailure})"/> and <see cref="M:Gallio.Framework.Assertions.AssertionHelper.Fail(Gallio.Framework.Assertions.AssertionFailure)"/>
-            instead when implementing custom assertions.
-            </para>
-            </remarks>
-            <exception cref="T:Gallio.Framework.Assertions.AssertionException">Thrown unless the current <see cref="P:Gallio.Framework.Assertions.AssertionContext.AssertionFailureBehavior"/> indicates otherwise.</exception>
-        </member>
-        <member name="M:MbUnit.Framework.Assert.Fail(System.String,System.Object[])">
-            <summary>
-            Signals an unconditional assertion failure with a particular message.
-            </summary>
-            <remarks>
-            <para>
-            Use <see cref="M:Gallio.Framework.Assertions.AssertionHelper.Verify(Gallio.Common.Func{Gallio.Framework.Assertions.AssertionFailure})"/> and <see cref="M:Gallio.Framework.Assertions.AssertionHelper.Fail(Gallio.Framework.Assertions.AssertionFailure)"/>
-            instead when implementing custom assertions.
-            </para>
-            </remarks>
-            <param name="messageFormat">The format of the assertion failure message.</param>
-            <param name="messageArgs">The arguments for the assertion failure message format string.</param>
-            <exception cref="T:Gallio.Framework.Assertions.AssertionException">Thrown unless the current <see cref="P:Gallio.Framework.Assertions.AssertionContext.AssertionFailureBehavior"/> indicates otherwise.</exception>
-        </member>
-        <member name="M:MbUnit.Framework.Assert.Inconclusive">
-            <summary>
-            Terminates the test and reports an inconclusive test outcome.
-            </summary>
-            <remarks>
-            <para>
-            The test is terminated with an inconclusive test outcome by throwing a
-            <see cref="T:Gallio.Framework.TestInconclusiveException"/>.  If other code in the test case catches
-            this exception and does not rethrow it then the test might not terminate correctly.
-            </para>
-            </remarks>
-            <exception cref="T:Gallio.Framework.TestInconclusiveException">Thrown always.</exception>
-        </member>
-        <member name="M:MbUnit.Framework.Assert.Inconclusive(System.String,System.Object[])">
-            <summary>
-            Terminates the test and reports an inconclusive test outcome.
-            </summary>
-            <remarks>
-            <para>
-            The test is terminated with an inconclusive test outcome by throwing a
-            <see cref="T:Gallio.Framework.TestInconclusiveException"/>.  If other code in the test case catches
-            this exception and does not rethrow it then the test might not terminate correctly.
-            </para>
-            </remarks>
-            <param name="messageFormat">The custom message format string, or null if none.</param>
-            <param name="messageArgs">The custom message arguments, or null if none.</param>
-            <exception cref="T:Gallio.Framework.TestInconclusiveException">Thrown always.</exception>
-        </member>
-        <member name="M:MbUnit.Framework.Assert.Terminate(Gallio.Model.TestOutcome)">
-            <summary>
-            Terminates the test and reports a specific test outcome.
-            </summary>
-            <remarks>
-            <para>
-            The test is terminated with by throwing a <see cref="T:Gallio.Framework.TestTerminatedException"/>
-            with the specified outcome.  If other code in the test case catches
-            this exception and does not rethrow it then the test might not terminate correctly.
-            </para>
-            </remarks>
-            <param name="outcome">The desired test outcome.</param>
-            <exception cref="T:Gallio.Framework.TestTerminatedException">Thrown always.</exception>
-        </member>
-        <member name="M:MbUnit.Framework.Assert.Terminate(Gallio.Model.TestOutcome,System.String,System.Object[])">
-            <summary>
-            Terminates the test and reports a specific test outcome.
-            </summary>
-            <remarks>
-            <para>
-            The test is terminated with by throwing a <see cref="T:Gallio.Framework.TestTerminatedException"/>
-            with the specified outcome.  If other code in the test case catches
-            this exception and does not rethrow it then the test might not terminate correctly.
-            </para>
-            </remarks>
-            <param name="outcome">The desired test outcome.</param>
-            <param name="messageFormat">The custom message format string, or null if none.</param>
-            <param name="messageArgs">The custom message arguments, or null if none.</param>
-            <exception cref="T:Gallio.Framework.TestTerminatedException">Thrown always.</exception>
-        </member>
-        <member name="M:MbUnit.Framework.Assert.TerminateSilently(Gallio.Model.TestOutcome)">
-            <summary>
-            Terminates the test silently and reports a specific test outcome.
-            </summary>
-            <remarks>
-            <para>
-            Unlike <see cref="M:MbUnit.Framework.Assert.Terminate(Gallio.Model.TestOutcome)"/> this method does not report the
-            stack trace.  It also does not include a termination reason unless one is explicitly
-            specified by the caller.
-            </para>
-            <para>
-            The test is terminated with by throwing a <see cref="T:Gallio.Framework.SilentTestException"/>
-            with the specified outcome.  If other code in the test case catches
-            this exception and does not rethrow it then the test might not terminate correctly.
-            </para>
-            </remarks>
-            <param name="outcome">The desired test outcome.</param>
-            <exception cref="T:Gallio.Framework.SilentTestException">Thrown always.</exception>
-        </member>
-        <member name="M:MbUnit.Framework.Assert.TerminateSilently(Gallio.Model.TestOutcome,System.String,System.Object[])">
-            <summary>
-            Terminates the test silently and reports a specific test outcome.
-            </summary>
-            <remarks>
-            <para>
-            Unlike <see cref="M:MbUnit.Framework.Assert.Terminate(Gallio.Model.TestOutcome,System.String,System.Object[])"/> this method does not report the
-            stack trace.  It also does not include a termination reason unless one is explicitly
-            specified by the caller.
-            </para>
-            <para>
-            The test is terminated with by throwing a <see cref="T:Gallio.Framework.TestTerminatedException"/>
-            with the specified outcome.  If other code in the test case catches
-            this exception and does not rethrow it then the test might not terminate correctly.
-            </para>
-            </remarks>
-            <param name="outcome">The desired test outcome.</param>
-            <param name="messageFormat">The custom message format string, or null if none.</param>
-            <param name="messageArgs">The custom message arguments, or null if none.</param>
-            <exception cref="T:Gallio.Framework.SilentTestException">Thrown always.</exception>
-        </member>
-        <member name="M:MbUnit.Framework.Assert.Multiple(Gallio.Common.Action)">
-            <summary>
-            Evaluates a block of code that contains multiple related assertions.
-            </summary>
-            <remarks>
-            <para>
-            While the action delegate runs, the behavior of assertions is change such that
-            failures are captured but do not cause a <see cref="T:Gallio.Framework.Assertions.AssertionFailureException"/>
-            to be throw.  When the delegate returns, the previous assertion failure behavior
-            is restored and any captured assertion failures are reported.  The net effect
-            of this change is that the test can continue to run even after an assertion failure
-            occurs which can help to provide more information about the problem.
-            </para>
-            <para>
-            A multiple assertion block is useful for verifying the state of a single
-            component with many parts that require several assertions to check.
-            This feature can accelerate debugging because more diagnostic information
-            become available at once.
-            </para>
-            </remarks>
-            <param name="action">The action to invoke.</param>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="action"/> is null.</exception>
-        </member>
-        <member name="M:MbUnit.Framework.Assert.Multiple(Gallio.Common.Action,System.String,System.Object[])">
-            <summary>
-            Evaluates a block of code that contains multiple related assertions.
-            </summary>
-            <remarks>
-            <para>
-            While the action delegate runs, the behavior of assertions is change such that
-            failures are captured but do not cause a <see cref="T:Gallio.Framework.Assertions.AssertionFailureException"/>
-            to be throw.  When the delegate returns, the previous assertion failure behavior
-            is restored and any captured assertion failures are reported.  The net effect
-            of this change is that the test can continue to run even after an assertion failure
-            occurs which can help to provide more information about the problem.
-            </para>
-            <para>
-            A multiple assertion block is useful for verifying the state of a single
-            component with many parts that require several assertions to check.
-            This feature can accelerate debugging because more diagnostic information
-            become available at once.
-            </para>
-            </remarks>
-            <param name="action">The action to invoke.</param>
-            <param name="messageFormat">The custom assertion message format, or null if none.</param>
-            <param name="messageArgs">The custom assertion message arguments, or null if none.</param>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="action"/> is null.</exception>
-        </member>
-        <member name="M:MbUnit.Framework.Assert.Contains(System.String,System.String)">
-            <summary>
-            Verifies that a string contains some expected value.
-            </summary>
-            <remarks>
-            <para>
-            This assertion will fail if the string is null.
-            </para>
-            </remarks>
-            <param name="actualValue">The actual value.</param>
-            <param name="expectedSubstring">The expected substring.</param>
-            <exception cref="T:Gallio.Framework.Assertions.AssertionException">Thrown if the verification failed unless the current <see cref="P:Gallio.Framework.Assertions.AssertionContext.AssertionFailureBehavior"/> indicates otherwise.</exception>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="expectedSubstring"/> is null.</exception>
-        </member>
-        <member name="M:MbUnit.Framework.Assert.Contains(System.String,System.String,System.String,System.Object[])">
-            <summary>
-            Verifies that a string contains some expected value.
-            </summary>
-            <remarks>
-            <para>
-            This assertion will fail if the string is null.
-            </para>
-            </remarks>
-            <param name="actualValue">The actual value.</param>
-            <param name="expectedSubstring">The expected substring.</param>
-            <param name="messageFormat">The custom assertion message format, or null if none.</param>
-            <param name="messageArgs">The custom assertion message arguments, or null if none.</param>
-            <exception cref="T:Gallio.Framework.Assertions.AssertionException">Thrown if the verification failed unless the current <see cref="P:Gallio.Framework.Assertions.AssertionContext.AssertionFailureBehavior"/> indicates otherwise.</exception>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="expectedSubstring"/> is null.</exception>
-        </member>
-        <member name="M:MbUnit.Framework.Assert.Contains(System.String,System.String,System.StringComparison)">
-            <summary>
-            Verifies that a string contains some expected value.
-            </summary>
-            <remarks>
-            <para>
-            This assertion will fail if the string is null.
-            </para>
-            </remarks>
-            <param name="actualValue">The actual value.</param>
-            <param name="expectedSubstring">The expected substring.</param>
-            <param name="comparisonType">One of the <see cref="T:System.StringComparison"/> values that determines how the expected substring is compared to the actual value.</param>
-            <exception cref="T:Gallio.Framework.Assertions.AssertionException">Thrown if the verification failed unless the current <see cref="P:Gallio.Framework.Assertions.AssertionContext.AssertionFailureBehavior"/> indicates otherwise.</exception>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="expectedSubstring"/> is null.</exception>
-            <exception cref="T:System.ArgumentException">Thrown if <paramref name="comparisonType"> has invalid value.</paramref></exception>
-        </member>
-        <member name="M:MbUnit.Framework.Assert.Contains(System.String,System.String,System.StringComparison,System.String,System.Object[])">
-            <summary>
-            Verifies that a string contains some expected value.
-            </summary>
-            <remarks>
-            <para>
-            This assertion will fail if the string is null.
-            </para>
-            </remarks>
-            <param name="actualValue">The actual value.</param>
-            <param name="expectedSubstring">The expected substring.</param>
-            <param name="comparisonType">One of the <see cref="T:System.StringComparison"/> values that determines how the expected substring is compared to the actual value.</param>
-            <param name="messageFormat">The custom assertion message format, or null if none.</param>
-            <param name="messageArgs">The custom assertion message arguments, or null if none.</param>
-            <exception cref="T:Gallio.Framework.Assertions.AssertionException">Thrown if the verification failed unless the current <see cref="P:Gallio.Framework.Assertions.AssertionContext.AssertionFailureBehavior"/> indicates otherwise.</exception>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="expectedSubstring"/> is null.</exception>
-            <exception cref="T:System.ArgumentException">Thrown if <paramref name="comparisonType"> has invalid value.</paramref></exception>
-        </member>
-        <member name="M:MbUnit.Framework.Assert.DoesNotContain(System.String,System.String)">
-            <summary>
-            Verifies that a string does not contain some unexpected substring.
-            </summary>
-            <remarks>
-            <para>
-            This assertion will fail if the string is null.
-            </para>
-            </remarks>
-            <param name="actualValue">The actual value.</param>
-            <param name="unexpectedSubstring">The unexpected substring.</param>
-            <exception cref="T:Gallio.Framework.Assertions.AssertionException">Thrown if the verification failed unless the current <see cref="P:Gallio.Framework.Assertions.AssertionContext.AssertionFailureBehavior"/> indicates otherwise.</exception>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="unexpectedSubstring"/> is null.</exception>
-        </member>
-        <member name="M:MbUnit.Framework.Assert.DoesNotContain(System.String,System.String,System.String,System.Object[])">
-            <summary>
-            Verifies that a string does not contain some unexpected substring.
-            </summary>
-            <remarks>
-            <para>
-            This assertion will fail if the string is null.
-            </para>
-            </remarks>
-            <param name="actualValue">The actual value.</param>
-            <param name="unexpectedSubstring">The unexpected substring.</param>
-            <param name="messageFormat">The custom assertion message format, or null if none.</param>
-            <param name="messageArgs">The custom assertion message arguments, or null if none.</param>
-            <exception cref="T:Gallio.Framework.Assertions.AssertionException">Thrown if the verification failed unless the current <see cref="P:Gallio.Framework.Assertions.AssertionContext.AssertionFailureBehavior"/> indicates otherwise.</exception>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="unexpectedSubstring"/> is null.</exception>
-        </member>
-        <member name="M:MbUnit.Framework.Assert.DoesNotContain(System.String,System.String,System.StringComparison)">
-            <summary>
-            Verifies that a string does not contain some unexpected substring.
-            </summary>
-            <remarks>
-            <para>
-            This assertion will fail if the string is null.
-            </para>
-            </remarks>
-            <param name="actualValue">The actual value.</param>
-            <param name="unexpectedSubstring">The unexpected substring.</param>
-            <param name="comparisonType">One of the <see cref="T:System.StringComparison"/> values that determines how unexpected text is compared to the actual value.</param>
-            <exception cref="T:Gallio.Framework.Assertions.AssertionException">Thrown if the verification failed unless the current <see cref="P:Gallio.Framework.Assertions.AssertionContext.AssertionFailureBehavior"/> indicates otherwise.</exception>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="unexpectedSubstring"/> is null.</exception>
-            <exception cref="T:System.ArgumentException">Thrown if <paramref name="comparisonType"> has invalid value.</paramref></exception>
-        </member>
-        <member name="M:MbUnit.Framework.Assert.DoesNotContain(System.String,System.String,System.StringComparison,System.String,System.Object[])">
-            <summary>
-            Verifies that a string does not contain some unexpected substring.
-            </summary>
-            <remarks>
-            <para>
-            This assertion will fail if the string is null.
-            </para>
-            </remarks>
-            <param name="actualValue">The actual value.</param>
-            <param name="unexpectedSubstring">The unexpected substring.</param>
-            <param name="comparisonType">One of the <see cref="T:System.StringComparison"/> values that determines how unexpected text is compared to the actual value.</param>
-            <param name="messageFormat">The custom assertion message format, or null if none.</param>
-            <param name="messageArgs">The custom assertion message arguments, or null if none.</param>
-            <exception cref="T:Gallio.Framework.Assertions.AssertionException">Thrown if the verification failed unless the current <see cref="P:Gallio.Framework.Assertions.AssertionContext.AssertionFailureBehavior"/> indicates otherwise.</exception>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="unexpectedSubstring"/> is null.</exception>
-            <exception cref="T:System.ArgumentException">Thrown if <paramref name="comparisonType"> has invalid value.</paramref></exception>
-        </member>
-        <member name="M:MbUnit.Framework.Assert.AreEqual(System.String,System.String,System.StringComparison)">
-            <summary>
-            Asserts that two strings are equal according to a particular string comparison mode.
-            </summary>
-            <param name="expectedValue">The expected value.</param>
-            <param name="actualValue">The actual value.</param>
-            <param name="comparisonType">The string comparison type.</param>
-            <exception cref="T:Gallio.Framework.Assertions.AssertionException">Thrown if the verification failed unless the current <see cref="P:Gallio.Framework.Assertions.AssertionContext.AssertionFailureBehavior"/> indicates otherwise.</exception>
-        </member>
-        <member name="M:MbUnit.Framework.Assert.AreEqual(System.String,System.String,System.StringComparison,System.String,System.Object[])">
-            <summary>
-            Asserts that two strings are equal according to a particular string comparison mode.
-            </summary>
-            <param name="expectedValue">The expected value.</param>
-            <param name="actualValue">The actual value.</param>
-            <param name="comparisonType">The string comparison type.</param>
-            <param name="messageFormat">The custom assertion message format, or null if none.</param>
-            <param name="messageArgs">The custom assertion message arguments, or null if none.</param>
-            <exception cref="T:Gallio.Framework.Assertions.AssertionException">Thrown if the verification failed unless the current <see cref="P:Gallio.Framework.Assertions.AssertionContext.AssertionFailureBehavior"/> indicates otherwise.</exception>
-        </member>
-        <member name="M:MbUnit.Framework.Assert.AreNotEqual(System.String,System.String,System.StringComparison)">
-            <summary>
-            Asserts that two strings are not equal according to a particular string comparison mode.
-            </summary>
-            <param name="unexpectedValue">The unexpected value.</param>
-            <param name="actualValue">The actual value.</param>
-            <param name="comparisonType">The string comparison type.</param>
-            <exception cref="T:Gallio.Framework.Assertions.AssertionException">Thrown if the verification failed unless the current <see cref="P:Gallio.Framework.Assertions.AssertionContext.AssertionFailureBehavior"/> indicates otherwise.</exception>
-        </member>
-        <member name="M:MbUnit.Framework.Assert.AreNotEqual(System.String,System.String,System.StringComparison,System.String,System.Object[])">
-            <summary>
-            Asserts that two strings are not equal according to a particular string comparison mode.
-            </summary>
-            <param name="unexpectedValue">The unexpected value.</param>
-            <param name="actualValue">The actual value.</param>
-            <param name="comparisonType">The string comparison type.</param>
-            <param name="messageFormat">The custom assertion message format, or null if none.</param>
-            <param name="messageArgs">The custom assertion message arguments, or null if none.</param>
-            <exception cref="T:Gallio.Framework.Assertions.AssertionException">Thrown if the verification failed unless the current <see cref="P:Gallio.Framework.Assertions.AssertionContext.AssertionFailureBehavior"/> indicates otherwise.</exception>
-        </member>
-        <member name="M:MbUnit.Framework.Assert.FullMatch(System.String,System.String)">
-            <summary>
-            Verifies that a string matches regular expression pattern exactly.
-            </summary>
-            <remarks>
-            <para>
-            This assertion will fail if the string is null.
-            </para>
-            </remarks>
-            <seealso cref="M:System.Text.RegularExpressions.Regex.Match(System.String,System.String,System.Text.RegularExpressions.RegexOptions)"/>
-            <param name="actualValue">The actual value.</param>
-            <param name="regexPattern">The regular expression pattern.</param>
-            <exception cref="T:Gallio.Framework.Assertions.AssertionException">Thrown if the verification failed unless the current <see cref="P:Gallio.Framework.Assertions.AssertionContext.AssertionFailureBehavior"/> indicates otherwise.</exception>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="regexPattern"/> is null.</exception>
-        </member>
-        <member name="M:MbUnit.Framework.Assert.FullMatch(System.String,System.String,System.String,System.Object[])">
-            <summary>
-            Verifies that a string matches regular expression pattern exactly.
-            </summary>
-            <remarks>
-            <para>
-            This assertion will fail if the string is null.
-            </para>
-            </remarks>
-            <seealso cref="M:System.Text.RegularExpressions.Regex.Match(System.String,System.String,System.Text.RegularExpressions.RegexOptions)"/>
-            <param name="actualValue">The actual value.</param>
-            <param name="regexPattern">The regular expression pattern.</param>
-            <param name="messageFormat">The custom assertion message format, or null if none.</param>
-            <param name="messageArgs">The custom assertion message arguments, or null if none.</param>
-            <exception cref="T:Gallio.Framework.Assertions.AssertionException">Thrown if the verification failed unless the current <see cref="P:Gallio.Framework.Assertions.AssertionContext.AssertionFailureBehavior"/> indicates otherwise.</exception>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="regexPattern"/> is null.</exception>
-        </member>
-        <member name="M:MbUnit.Framework.Assert.FullMatch(System.String,System.String,System.Text.RegularExpressions.RegexOptions)">
-            <summary>
-            Verifies that a string matches regular expression pattern exactly.
-            </summary>
-            <remarks>
-            <para>
-            This assertion will fail if the string is null.
-            </para>
-            </remarks>
-            <seealso cref="M:System.Text.RegularExpressions.Regex.Match(System.String,System.String,System.Text.RegularExpressions.RegexOptions)"/>
-            <param name="actualValue">The actual value.</param>
-            <param name="regexPattern">The regular expression pattern.</param>
-            <param name="regexOptions">The regular expression options.</param>
-            <exception cref="T:Gallio.Framework.Assertions.AssertionException">Thrown if the verification failed unless the current <see cref="P:Gallio.Framework.Assertions.AssertionContext.AssertionFailureBehavior"/> indicates otherwise.</exception>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="regexPattern"/> is null.</exception>
-        </member>
-        <member name="M:MbUnit.Framework.Assert.FullMatch(System.String,System.String,System.Text.RegularExpressions.RegexOptions,System.String,System.Object[])">
-            <summary>
-            Verifies that a string matches regular expression pattern exactly.
-            </summary>
-            <remarks>
-            <para>
-            This assertion will fail if the string is null.
-            </para>
-            </remarks>
-            <seealso cref="M:System.Text.RegularExpressions.Regex.Match(System.String,System.String,System.Text.RegularExpressions.RegexOptions)"/>
-            <param name="actualValue">The actual value.</param>
-            <param name="regexPattern">The regular expression pattern.</param>
-            <param name="regexOptions">The regular expression options.</param>
-            <param name="messageFormat">The custom assertion message format, or null if none.</param>
-            <param name="messageArgs">The custom assertion message arguments, or null if none.</param>
-            <exception cref="T:Gallio.Framework.Assertions.AssertionException">Thrown if the verification failed unless the current <see cref="P:Gallio.Framework.Assertions.AssertionContext.AssertionFailureBehavior"/> indicates otherwise.</exception>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="regexPattern"/> is null.</exception>
-        </member>
-        <member name="M:MbUnit.Framework.Assert.FullMatch(System.String,System.Text.RegularExpressions.Regex)">
-            <summary>
-            Verifies that a string matches regular expression pattern exactly.
-            </summary>
-            <remarks>
-            <para>
-            This assertion will fail if the string is null.
-            </para>
-            </remarks>
-            <seealso cref="M:System.Text.RegularExpressions.Regex.Match(System.String)"/>
-            <param name="actualValue">The actual value.</param>
-            <param name="regex">The regular expression.</param>
-            <exception cref="T:Gallio.Framework.Assertions.AssertionException">Thrown if the verification failed unless the current <see cref="P:Gallio.Framework.Assertions.AssertionContext.AssertionFailureBehavior"/> indicates otherwise.</exception>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="regex"/> is null.</exception>
-        </member>
-        <member name="M:MbUnit.Framework.Assert.FullMatch(System.String,System.Text.RegularExpressions.Regex,System.String,System.Object[])">
-            <summary>
-            Verifies that a string matches regular expression pattern exactly.
-            </summary>
-            <remarks>
-            <para>
-            This assertion will fail if the string is null.
-            </para>
-            </remarks>
-            <seealso cref="M:System.Text.RegularExpressions.Regex.Match(System.String)"/>
-            <param name="actualValue">The actual value.</param>
-            <param name="regex">The regular expression.</param>
-            <param name="messageFormat">The custom assertion message format, or null if none.</param>
-            <param name="messageArgs">The custom assertion message arguments, or null if none.</param>
-            <exception cref="T:Gallio.Framework.Assertions.AssertionException">Thrown if the verification failed unless the current <see cref="P:Gallio.Framework.Assertions.AssertionContext.AssertionFailureBehavior"/> indicates otherwise.</exception>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="regex"/> is null.</exception>
-        </member>
-        <member name="M:MbUnit.Framework.Assert.Like(System.String,System.String)">
-            <summary>
-            Verifies that a string contains a full or partial match of a regular expression pattern.
-            </summary>
-            <remarks>
-            <para>
-            This assertion will fail if the string is null.
-            </para>
-            </remarks>
-            <seealso cref="M:System.Text.RegularExpressions.Regex.IsMatch(System.String,System.String,System.Text.RegularExpressions.RegexOptions)"/>
-            <param name="actualValue">The actual value.</param>
-            <param name="regexPattern">The regular expression pattern.</param>
-            <exception cref="T:Gallio.Framework.Assertions.AssertionException">Thrown if the verification failed unless the current <see cref="P:Gallio.Framework.Assertions.AssertionContext.AssertionFailureBehavior"/> indicates otherwise.</exception>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="regexPattern"/> is null.</exception>
-        </member>
-        <member name="M:MbUnit.Framework.Assert.Like(System.String,System.String,System.String,System.Object[])">
-            <summary>
-            Verifies that a string contains a full or partial match of a regular expression pattern.
-            </summary>
-            <remarks>
-            <para>
-            This assertion will fail if the string is null.
-            </para>
-            </remarks>
-            <seealso cref="M:System.Text.RegularExpressions.Regex.IsMatch(System.String,System.String,System.Text.RegularExpressions.RegexOptions)"/>
-            <param name="actualValue">The actual value.</param>
-            <param name="regexPattern">The regular expression pattern.</param>
-            <param name="messageFormat">The custom assertion message format, or null if none.</param>
-            <param name="messageArgs">The custom assertion message arguments, or null if none.</param>
-            <exception cref="T:Gallio.Framework.Assertions.AssertionException">Thrown if the verification failed unless the current <see cref="P:Gallio.Framework.Assertions.AssertionContext.AssertionFailureBehavior"/> indicates otherwise.</exception>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="regexPattern"/> is null.</exception>
-        </member>
-        <member name="M:MbUnit.Framework.Assert.Like(System.String,System.String,System.Text.RegularExpressions.RegexOptions)">
-            <summary>
-            Verifies that a string contains a full or partial match of a regular expression pattern.
-            </summary>
-            <remarks>
-            <para>
-            This assertion will fail if the string is null.
-            </para>
-            </remarks>
-            <seealso cref="M:System.Text.RegularExpressions.Regex.IsMatch(System.String,System.String,System.Text.RegularExpressions.RegexOptions)"/>
-            <param name="actualValue">The actual value.</param>
-            <param name="regexPattern">The regular expression pattern.</param>
-            <param name="regexOptions">The regular expression options.</param>
-            <exception cref="T:Gallio.Framework.Assertions.AssertionException">Thrown if the verification failed unless the current <see cref="P:Gallio.Framework.Assertions.AssertionContext.AssertionFailureBehavior"/> indicates otherwise.</exception>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="regexPattern"/> is null.</exception>
-        </member>
-        <member name="M:MbUnit.Framework.Assert.Like(System.String,System.String,System.Text.RegularExpressions.RegexOptions,System.String,System.Object[])">
-            <summary>
-            Verifies that a string contains a full or partial match of a regular expression pattern.
-            </summary>
-            <remarks>
-            <para>
-            This assertion will fail if the string is null.
-            </para>
-            </remarks>
-            <seealso cref="M:System.Text.RegularExpressions.Regex.IsMatch(System.String,System.String,System.Text.RegularExpressions.RegexOptions)"/>
-            <param name="actualValue">The actual value.</param>
-            <param name="regexPattern">The regular expression pattern.</param>
-            <param name="regexOptions">The regular expression options.</param>
-            <param name="messageFormat">The custom assertion message format, or null if none.</param>
-            <param name="messageArgs">The custom assertion message arguments, or null if none.</param>
-            <exception cref="T:Gallio.Framework.Assertions.AssertionException">Thrown if the verification failed unless the current <see cref="P:Gallio.Framework.Assertions.AssertionContext.AssertionFailureBehavior"/> indicates otherwise.</exception>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="regexPattern"/> is null.</exception>
-        </member>
-        <member name="M:MbUnit.Framework.Assert.Like(System.String,System.Text.RegularExpressions.Regex)">
-            <summary>
-            Verifies that a string contains a full or partial match of a regular expression pattern.
-            </summary>
-            <remarks>
-            <para>
-            This assertion will fail if the string is null.
-            </para>
-            </remarks>
-            <seealso cref="M:System.Text.RegularExpressions.Regex.IsMatch(System.String)"/>
-            <param name="actualValue">The actual value.</param>
-            <param name="regex">The regular expression.</param>
-            <exception cref="T:Gallio.Framework.Assertions.AssertionException">Thrown if the verification failed unless the current <see cref="P:Gallio.Framework.Assertions.AssertionContext.AssertionFailureBehavior"/> indicates otherwise.</exception>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="regex"/> is null.</exception>
-        </member>
-        <member name="M:MbUnit.Framework.Assert.Like(System.String,System.Text.RegularExpressions.Regex,System.String,System.Object[])">
-            <summary>
-            Verifies that a string contains a full or partial match of a regular expression pattern.
-            </summary>
-            <remarks>
-            <para>
-            This assertion will fail if the string is null.
-            </para>
-            </remarks>
-            <seealso cref="M:System.Text.RegularExpressions.Regex.IsMatch(System.String)"/>
-            <param name="actualValue">The actual value.</param>
-            <param name="regex">The regular expression.</param>
-            <param name="messageFormat">The custom assertion message format, or null if none.</param>
-            <param name="messageArgs">The custom assertion message arguments, or null if none.</param>
-            <exception cref="T:Gallio.Framework.Assertions.AssertionException">Thrown if the verification failed unless the current <see cref="P:Gallio.Framework.Assertions.AssertionContext.AssertionFailureBehavior"/> indicates otherwise.</exception>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="regex"/> is null.</exception>
-        </member>
-        <member name="M:MbUnit.Framework.Assert.NotLike(System.String,System.String)">
-            <summary>
-            Verifies that a string does not contain a full or partial match of a regular expression pattern.
-            </summary>
-            <remarks>
-            <para>
-            This assertion will fail if the string is null.
-            </para>
-            </remarks>
-            <seealso cref="M:System.Text.RegularExpressions.Regex.IsMatch(System.String,System.String,System.Text.RegularExpressions.RegexOptions)"/>
-            <param name="actualValue">The actual value.</param>
-            <param name="regexPattern">The regular expression pattern.</param>
-            <exception cref="T:Gallio.Framework.Assertions.AssertionException">Thrown if the verification failed unless the current <see cref="P:Gallio.Framework.Assertions.AssertionContext.AssertionFailureBehavior"/> indicates otherwise.</exception>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="regexPattern"/> is null.</exception>
-        </member>
-        <member name="M:MbUnit.Framework.Assert.NotLike(System.String,System.String,System.String,System.Object[])">
-            <summary>
-            Verifies that a string does not contain a full or partial match of a regular expression pattern.
-            </summary>
-            <remarks>
-            <para>
-            This assertion will fail if the string is null.
-            </para>
-            </remarks>
-            <seealso cref="M:System.Text.RegularExpressions.Regex.IsMatch(System.String,System.String,System.Text.RegularExpressions.RegexOptions)"/>
-            <param name="actualValue">The actual value.</param>
-            <param name="regexPattern">The regular expression pattern.</param>
-            <param name="messageFormat">The custom assertion message format, or null if none.</param>
-            <param name="messageArgs">The custom assertion message arguments, or null if none.</param>
-            <exception cref="T:Gallio.Framework.Assertions.AssertionException">Thrown if the verification failed unless the current <see cref="P:Gallio.Framework.Assertions.AssertionContext.AssertionFailureBehavior"/> indicates otherwise.</exception>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="regexPattern"/> is null.</exception>
-        </member>
-        <member name="M:MbUnit.Framework.Assert.NotLike(System.String,System.String,System.Text.RegularExpressions.RegexOptions)">
-            <summary>
-            Verifies that a string does not contain a full or partial match of a regular expression pattern.
-            </summary>
-            <remarks>
-            <para>
-            This assertion will fail if the string is null.
-            </para>
-            </remarks>
-            <seealso cref="M:System.Text.RegularExpressions.Regex.IsMatch(System.String,System.String,System.Text.RegularExpressions.RegexOptions)"/>
-            <param name="actualValue">The actual value.</param>
-            <param name="regexPattern">The regular expression pattern.</param>
-            <param name="regexOptions">The regular expression options.</param>
-            <exception cref="T:Gallio.Framework.Assertions.AssertionException">Thrown if the verification failed unless the current <see cref="P:Gallio.Framework.Assertions.AssertionContext.AssertionFailureBehavior"/> indicates otherwise.</exception>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="regexPattern"/> is null.</exception>
-        </member>
-        <member name="M:MbUnit.Framework.Assert.NotLike(System.String,System.String,System.Text.RegularExpressions.RegexOptions,System.String,System.Object[])">
-            <summary>
-            Verifies that a string does not contain a full or partial match of a regular expression pattern.
-            </summary>
-            <remarks>
-            <para>
-            This assertion will fail if the string is null.
-            </para>
-            </remarks>
-            <seealso cref="M:System.Text.RegularExpressions.Regex.IsMatch(System.String,System.String,System.Text.RegularExpressions.RegexOptions)"/>
-            <param name="actualValue">The actual value.</param>
-            <param name="regexPattern">The regular expression pattern.</param>
-            <param name="regexOptions">The regular expression options.</param>
-            <param name="messageFormat">The custom assertion message format, or null if none.</param>
-            <param name="messageArgs">The custom assertion message arguments, or null if none.</param>
-            <exception cref="T:Gallio.Framework.Assertions.AssertionException">Thrown if the verification failed unless the current <see cref="P:Gallio.Framework.Assertions.AssertionContext.AssertionFailureBehavior"/> indicates otherwise.</exception>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="regexPattern"/> is null.</exception>
-        </member>
-        <member name="M:MbUnit.Framework.Assert.NotLike(System.String,System.Text.RegularExpressions.Regex)">
-            <summary>
-            Verifies that a string does not contain a full or partial match of a regular expression pattern.
-            </summary>
-            <remarks>
-            <para>
-            This assertion will fail if the string is null.
-            </para>
-            </remarks>
-            <seealso cref="M:System.Text.RegularExpressions.Regex.IsMatch(System.String)"/>
-            <param name="actualValue">The actual value.</param>
-            <param name="regex">The regular expression.</param>
-            <exception cref="T:Gallio.Framework.Assertions.AssertionException">Thrown if the verification failed unless the current <see cref="P:Gallio.Framework.Assertions.AssertionContext.AssertionFailureBehavior"/> indicates otherwise.</exception>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="regex"/> is null.</exception>
-        </member>
-        <member name="M:MbUnit.Framework.Assert.NotLike(System.String,System.Text.RegularExpressions.Regex,System.String,System.Object[])">
-            <summary>
-            Verifies that a string does not contain a full or partial match of a regular expression pattern.
-            </summary>
-            <remarks>
-            <para>
-            This assertion will fail if the string is null.
-            </para>
-            </remarks>
-            <seealso cref="M:System.Text.RegularExpressions.Regex.IsMatch(System.String)"/>
-            <param name="actualValue">The actual value.</param>
-            <param name="regex">The regular expression.</param>
-            <param name="messageFormat">The custom assertion message format, or null if none.</param>
-            <param name="messageArgs">The custom assertion message arguments, or null if none.</param>
-            <exception cref="T:Gallio.Framework.Assertions.AssertionException">Thrown if the verification failed unless the current <see cref="P:Gallio.Framework.Assertions.AssertionContext.AssertionFailureBehavior"/> indicates otherwise.</exception>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="regex"/> is null.</exception>
-        </member>
-        <member name="M:MbUnit.Framework.Assert.StartsWith(System.String,System.String)">
-            <summary>
-            Verifies that a string starts with the specified text.
-            </summary>
-            <remarks>
-            <para>
-            This assertion will fail if the string is null.
-            </para>
-            </remarks>
-            <seealso cref="M:System.String.StartsWith(System.String)"/>
-            <param name="actualValue">The actual value.</param>
-            <param name="expectedText">The expected pattern.</param>
-            <exception cref="T:Gallio.Framework.Assertions.AssertionException">Thrown if the verification failed unless the current <see cref="P:Gallio.Framework.Assertions.AssertionContext.AssertionFailureBehavior"/> indicates otherwise.</exception>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="expectedText"/> is null.</exception>
-        </member>
-        <member name="M:MbUnit.Framework.Assert.StartsWith(System.String,System.String,System.String,System.Object[])">
-            <summary>
-            Verifies that a string starts with the specified text.
-            </summary>
-            <remarks>
-            <para>
-            This assertion will fail if the string is null.
-            </para>
-            </remarks>
-            <seealso cref="M:System.String.StartsWith(System.String)"/>
-            <param name="actualValue">The actual value.</param>
-            <param name="expectedText">The

<TRUNCATED>
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/MbUnit35.dll
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/MbUnit35.dll b/lib/Gallio.3.2.750/tools/MbUnit35.dll
deleted file mode 100644
index dfbaec1..0000000
Binary files a/lib/Gallio.3.2.750/tools/MbUnit35.dll and /dev/null differ


[22/51] [abbrv] [partial] Cleaning up and getting ready to development towards v4.8

Posted by sy...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/framework/pnunit.framework.dll
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/framework/pnunit.framework.dll b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/framework/pnunit.framework.dll
deleted file mode 100644
index ca9b5cb..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/framework/pnunit.framework.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/launcher.log.conf
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/launcher.log.conf b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/launcher.log.conf
deleted file mode 100644
index 4bd90ca..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/launcher.log.conf
+++ /dev/null
@@ -1,18 +0,0 @@
-<log4net>
-	<!-- A1 is set to be a ConsoleAppender -->
-	<appender name="A1" type="log4net.Appender.ConsoleAppender">
-
-		<!-- A1 uses PatternLayout -->
-		<layout type="log4net.Layout.PatternLayout">
-			<!-- Print the date in ISO 8601 format -->
-			<conversionPattern value="%-5level %logger - %message%newline" />
-		</layout>
-	</appender>
-	
-	<!-- Set root logger level to DEBUG and its only appender to A1 -->
-	<root>
-		<level value="DEBUG" />
-		<appender-ref ref="A1" />
-	</root>
-
-</log4net>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/lib/Failure.png
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/lib/Failure.png b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/lib/Failure.png
deleted file mode 100644
index 2e400b2..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/lib/Failure.png and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/lib/Ignored.png
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/lib/Ignored.png b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/lib/Ignored.png
deleted file mode 100644
index 478efbf..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/lib/Ignored.png and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/lib/Inconclusive.png
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/lib/Inconclusive.png b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/lib/Inconclusive.png
deleted file mode 100644
index 4807b7c..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/lib/Inconclusive.png and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/lib/Skipped.png
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/lib/Skipped.png b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/lib/Skipped.png
deleted file mode 100644
index 7c9fc64..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/lib/Skipped.png and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/lib/Success.png
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/lib/Success.png b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/lib/Success.png
deleted file mode 100644
index 2a30150..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/lib/Success.png and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/lib/fit.dll
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/lib/fit.dll b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/lib/fit.dll
deleted file mode 100644
index 40bbef0..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/lib/fit.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/lib/log4net.dll
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/lib/log4net.dll b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/lib/log4net.dll
deleted file mode 100644
index 20a2e1c..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/lib/log4net.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/lib/nunit-console-runner.dll
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/lib/nunit-console-runner.dll b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/lib/nunit-console-runner.dll
deleted file mode 100644
index a18299e..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/lib/nunit-console-runner.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/lib/nunit-gui-runner.dll
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/lib/nunit-gui-runner.dll b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/lib/nunit-gui-runner.dll
deleted file mode 100644
index ec364fa..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/lib/nunit-gui-runner.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/lib/nunit.core.dll
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/lib/nunit.core.dll b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/lib/nunit.core.dll
deleted file mode 100644
index 5e9fcc0..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/lib/nunit.core.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/lib/nunit.core.interfaces.dll
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/lib/nunit.core.interfaces.dll b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/lib/nunit.core.interfaces.dll
deleted file mode 100644
index 3152dd2..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/lib/nunit.core.interfaces.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/lib/nunit.fixtures.dll
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/lib/nunit.fixtures.dll b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/lib/nunit.fixtures.dll
deleted file mode 100644
index 0b19937..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/lib/nunit.fixtures.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/lib/nunit.uiexception.dll
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/lib/nunit.uiexception.dll b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/lib/nunit.uiexception.dll
deleted file mode 100644
index 66b4b95..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/lib/nunit.uiexception.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/lib/nunit.uikit.dll
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/lib/nunit.uikit.dll b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/lib/nunit.uikit.dll
deleted file mode 100644
index adc5ead..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/lib/nunit.uikit.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/lib/nunit.util.dll
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/lib/nunit.util.dll b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/lib/nunit.util.dll
deleted file mode 100644
index b31beef..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/lib/nunit.util.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/nunit-agent-x86.exe
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/nunit-agent-x86.exe b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/nunit-agent-x86.exe
deleted file mode 100644
index 00b331c..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/nunit-agent-x86.exe and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/nunit-agent-x86.exe.config
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/nunit-agent-x86.exe.config b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/nunit-agent-x86.exe.config
deleted file mode 100644
index d840f37..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/nunit-agent-x86.exe.config
+++ /dev/null
@@ -1,69 +0,0 @@
-<?xml version="1.0" encoding="utf-8"?>
-<configuration>
-  
-  <runtime>
-    <!-- We need this so test exceptions don't crash NUnit -->
-    <legacyUnhandledExceptionPolicy enabled="1" />
-
-    <!-- Look for addins in the addins directory for now -->
-    <assemblyBinding xmlns="urn:schemas-microsoft-com:asm.v1">
-      <probing privatePath="lib;addins"/>
-   </assemblyBinding>
-
-    <!--
-    The following <assemblyBinding> section allows running nunit under 
-    .NET 1.0 by redirecting assemblies. The appliesTo attribute
-    causes the section to be ignored except under .NET 1.0
-    on a machine with only the .NET version 1.0 runtime installed.
-    If application and its tests were built for .NET 1.1 you will
-    also need to redirect system assemblies in the test config file,
-    which controls loading of the tests.
-   -->
-    <assemblyBinding xmlns="urn:schemas-microsoft-com:asm.v1"
-			appliesTo="v1.0.3705">
-
-      <dependentAssembly> 
-        <assemblyIdentity name="System" 
-                          publicKeyToken="b77a5c561934e089" 
-                          culture="neutral"/>
-        <bindingRedirect  oldVersion="1.0.5000.0" 
-                          newVersion="1.0.3300.0"/>
-      </dependentAssembly>
-
-      <dependentAssembly> 
-        <assemblyIdentity name="System.Data" 
-                          publicKeyToken="b77a5c561934e089" 
-                          culture="neutral"/>
-        <bindingRedirect  oldVersion="1.0.5000.0" 
-                          newVersion="1.0.3300.0"/>
-      </dependentAssembly>
-
-      <dependentAssembly> 
-        <assemblyIdentity name="System.Drawing" 
-                          publicKeyToken="b03f5f7f11d50a3a" 
-                          culture="neutral"/>
-        <bindingRedirect  oldVersion="1.0.5000.0" 
-                          newVersion="1.0.3300.0"/>
-      </dependentAssembly>
-
-      <dependentAssembly> 
-        <assemblyIdentity name="System.Windows.Forms" 
-                          publicKeyToken="b77a5c561934e089" 
-                          culture="neutral"/>
-        <bindingRedirect  oldVersion="1.0.5000.0" 
-                          newVersion="1.0.3300.0"/>
-      </dependentAssembly>
-
-      <dependentAssembly> 
-        <assemblyIdentity name="System.Xml" 
-                          publicKeyToken="b77a5c561934e089" 
-                          culture="neutral"/>
-        <bindingRedirect  oldVersion="1.0.5000.0" 
-                          newVersion="1.0.3300.0"/>
-      </dependentAssembly>
-
-    </assemblyBinding>
-  
-  </runtime>
-  
-</configuration>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/nunit-agent.exe
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/nunit-agent.exe b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/nunit-agent.exe
deleted file mode 100644
index 8729148..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/nunit-agent.exe and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/nunit-agent.exe.config
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/nunit-agent.exe.config b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/nunit-agent.exe.config
deleted file mode 100644
index d840f37..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/nunit-agent.exe.config
+++ /dev/null
@@ -1,69 +0,0 @@
-<?xml version="1.0" encoding="utf-8"?>
-<configuration>
-  
-  <runtime>
-    <!-- We need this so test exceptions don't crash NUnit -->
-    <legacyUnhandledExceptionPolicy enabled="1" />
-
-    <!-- Look for addins in the addins directory for now -->
-    <assemblyBinding xmlns="urn:schemas-microsoft-com:asm.v1">
-      <probing privatePath="lib;addins"/>
-   </assemblyBinding>
-
-    <!--
-    The following <assemblyBinding> section allows running nunit under 
-    .NET 1.0 by redirecting assemblies. The appliesTo attribute
-    causes the section to be ignored except under .NET 1.0
-    on a machine with only the .NET version 1.0 runtime installed.
-    If application and its tests were built for .NET 1.1 you will
-    also need to redirect system assemblies in the test config file,
-    which controls loading of the tests.
-   -->
-    <assemblyBinding xmlns="urn:schemas-microsoft-com:asm.v1"
-			appliesTo="v1.0.3705">
-
-      <dependentAssembly> 
-        <assemblyIdentity name="System" 
-                          publicKeyToken="b77a5c561934e089" 
-                          culture="neutral"/>
-        <bindingRedirect  oldVersion="1.0.5000.0" 
-                          newVersion="1.0.3300.0"/>
-      </dependentAssembly>
-
-      <dependentAssembly> 
-        <assemblyIdentity name="System.Data" 
-                          publicKeyToken="b77a5c561934e089" 
-                          culture="neutral"/>
-        <bindingRedirect  oldVersion="1.0.5000.0" 
-                          newVersion="1.0.3300.0"/>
-      </dependentAssembly>
-
-      <dependentAssembly> 
-        <assemblyIdentity name="System.Drawing" 
-                          publicKeyToken="b03f5f7f11d50a3a" 
-                          culture="neutral"/>
-        <bindingRedirect  oldVersion="1.0.5000.0" 
-                          newVersion="1.0.3300.0"/>
-      </dependentAssembly>
-
-      <dependentAssembly> 
-        <assemblyIdentity name="System.Windows.Forms" 
-                          publicKeyToken="b77a5c561934e089" 
-                          culture="neutral"/>
-        <bindingRedirect  oldVersion="1.0.5000.0" 
-                          newVersion="1.0.3300.0"/>
-      </dependentAssembly>
-
-      <dependentAssembly> 
-        <assemblyIdentity name="System.Xml" 
-                          publicKeyToken="b77a5c561934e089" 
-                          culture="neutral"/>
-        <bindingRedirect  oldVersion="1.0.5000.0" 
-                          newVersion="1.0.3300.0"/>
-      </dependentAssembly>
-
-    </assemblyBinding>
-  
-  </runtime>
-  
-</configuration>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/nunit-console-x86.exe
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/nunit-console-x86.exe b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/nunit-console-x86.exe
deleted file mode 100644
index 48f726f..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/nunit-console-x86.exe and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/nunit-console-x86.exe.config
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/nunit-console-x86.exe.config b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/nunit-console-x86.exe.config
deleted file mode 100644
index fa0a262..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/nunit-console-x86.exe.config
+++ /dev/null
@@ -1,69 +0,0 @@
-<?xml version="1.0" encoding="utf-8"?>
-<configuration>
-
-  <runtime>
-    <!-- We need this so test exceptions don't crash NUnit -->
-    <legacyUnhandledExceptionPolicy enabled="1" />
-
-    <!-- Look for addins in the addins directory for now -->
-    <assemblyBinding xmlns="urn:schemas-microsoft-com:asm.v1">
-      <probing privatePath="lib;addins"/>
-   </assemblyBinding>
-
-   <!--
-    The following <assemblyBinding> section allows running nunit under 
-    .NET 1.0 by redirecting assemblies. The appliesTo attribute
-    causes the section to be ignored except under .NET 1.0
-    on a machine with only the .NET version 1.0 runtime installed.
-    If application and its tests were built for .NET 1.1 you will
-    also need to redirect system assemblies in the test config file,
-    which controls loading of the tests.
-   -->
-   <assemblyBinding xmlns="urn:schemas-microsoft-com:asm.v1"
-			appliesTo="v1.0.3705">
-
-      <dependentAssembly> 
-        <assemblyIdentity name="System" 
-                          publicKeyToken="b77a5c561934e089" 
-                          culture="neutral"/>
-        <bindingRedirect  oldVersion="1.0.5000.0" 
-                          newVersion="1.0.3300.0"/>
-      </dependentAssembly>
-
-      <dependentAssembly> 
-        <assemblyIdentity name="System.Data" 
-                          publicKeyToken="b77a5c561934e089" 
-                          culture="neutral"/>
-        <bindingRedirect  oldVersion="1.0.5000.0" 
-                          newVersion="1.0.3300.0"/>
-      </dependentAssembly>
-
-      <dependentAssembly> 
-        <assemblyIdentity name="System.Drawing" 
-                          publicKeyToken="b03f5f7f11d50a3a" 
-                          culture="neutral"/>
-        <bindingRedirect  oldVersion="1.0.5000.0" 
-                          newVersion="1.0.3300.0"/>
-      </dependentAssembly>
-
-      <dependentAssembly> 
-        <assemblyIdentity name="System.Windows.Forms" 
-                          publicKeyToken="b77a5c561934e089" 
-                          culture="neutral"/>
-        <bindingRedirect  oldVersion="1.0.5000.0" 
-                          newVersion="1.0.3300.0"/>
-      </dependentAssembly>
-
-      <dependentAssembly> 
-        <assemblyIdentity name="System.Xml" 
-                          publicKeyToken="b77a5c561934e089" 
-                          culture="neutral"/>
-        <bindingRedirect  oldVersion="1.0.5000.0" 
-                          newVersion="1.0.3300.0"/>
-      </dependentAssembly>
-
-    </assemblyBinding>
-
-  </runtime>
-  
-</configuration>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/nunit-console.exe
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/nunit-console.exe b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/nunit-console.exe
deleted file mode 100644
index 74f3dff..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/nunit-console.exe and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/nunit-console.exe.config
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/nunit-console.exe.config b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/nunit-console.exe.config
deleted file mode 100644
index fa0a262..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/nunit-console.exe.config
+++ /dev/null
@@ -1,69 +0,0 @@
-<?xml version="1.0" encoding="utf-8"?>
-<configuration>
-
-  <runtime>
-    <!-- We need this so test exceptions don't crash NUnit -->
-    <legacyUnhandledExceptionPolicy enabled="1" />
-
-    <!-- Look for addins in the addins directory for now -->
-    <assemblyBinding xmlns="urn:schemas-microsoft-com:asm.v1">
-      <probing privatePath="lib;addins"/>
-   </assemblyBinding>
-
-   <!--
-    The following <assemblyBinding> section allows running nunit under 
-    .NET 1.0 by redirecting assemblies. The appliesTo attribute
-    causes the section to be ignored except under .NET 1.0
-    on a machine with only the .NET version 1.0 runtime installed.
-    If application and its tests were built for .NET 1.1 you will
-    also need to redirect system assemblies in the test config file,
-    which controls loading of the tests.
-   -->
-   <assemblyBinding xmlns="urn:schemas-microsoft-com:asm.v1"
-			appliesTo="v1.0.3705">
-
-      <dependentAssembly> 
-        <assemblyIdentity name="System" 
-                          publicKeyToken="b77a5c561934e089" 
-                          culture="neutral"/>
-        <bindingRedirect  oldVersion="1.0.5000.0" 
-                          newVersion="1.0.3300.0"/>
-      </dependentAssembly>
-
-      <dependentAssembly> 
-        <assemblyIdentity name="System.Data" 
-                          publicKeyToken="b77a5c561934e089" 
-                          culture="neutral"/>
-        <bindingRedirect  oldVersion="1.0.5000.0" 
-                          newVersion="1.0.3300.0"/>
-      </dependentAssembly>
-
-      <dependentAssembly> 
-        <assemblyIdentity name="System.Drawing" 
-                          publicKeyToken="b03f5f7f11d50a3a" 
-                          culture="neutral"/>
-        <bindingRedirect  oldVersion="1.0.5000.0" 
-                          newVersion="1.0.3300.0"/>
-      </dependentAssembly>
-
-      <dependentAssembly> 
-        <assemblyIdentity name="System.Windows.Forms" 
-                          publicKeyToken="b77a5c561934e089" 
-                          culture="neutral"/>
-        <bindingRedirect  oldVersion="1.0.5000.0" 
-                          newVersion="1.0.3300.0"/>
-      </dependentAssembly>
-
-      <dependentAssembly> 
-        <assemblyIdentity name="System.Xml" 
-                          publicKeyToken="b77a5c561934e089" 
-                          culture="neutral"/>
-        <bindingRedirect  oldVersion="1.0.5000.0" 
-                          newVersion="1.0.3300.0"/>
-      </dependentAssembly>
-
-    </assemblyBinding>
-
-  </runtime>
-  
-</configuration>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/nunit-x86.exe
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/nunit-x86.exe b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/nunit-x86.exe
deleted file mode 100644
index f791368..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/nunit-x86.exe and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/nunit-x86.exe.config
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/nunit-x86.exe.config b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/nunit-x86.exe.config
deleted file mode 100644
index 1641a50..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/nunit-x86.exe.config
+++ /dev/null
@@ -1,83 +0,0 @@
-<?xml version="1.0" encoding="utf-8"?>
-<configuration>
-  <!--
-     Application settings for NUnit-gui.exe. Do NOT put settings
-	 for use by your tests here.
-	-->
-  <appSettings>
-    <!--
-     Uncomment to specify the url to be used for help. If not used, the
-     default value is something like
-		file://localhost/C:/Program Files/NUnit 2.2/doc/index.html
-	 This setting is provided in case your default browser doesn't
-	 support this format.
-	-->
-    <!-- <add key="helpUrl" value="http://www.nunit.org" /> -->
-  </appSettings>
-
-  <runtime>
-    <!-- We need this so test exceptions don't crash NUnit -->
-    <legacyUnhandledExceptionPolicy enabled="1" />
-
-    <!-- Look for addins in the addins directory for now -->
-    <assemblyBinding xmlns="urn:schemas-microsoft-com:asm.v1">
-      <probing privatePath="lib;addins" />
-    </assemblyBinding>
-
-    <!--
-    The following <assemblyBinding> section allows running nunit under 
-    .NET 1.0 by redirecting assemblies. The appliesTo attribute
-    causes the section to be ignored except under .NET 1.0
-    on a machine with only the .NET version 1.0 runtime installed.
-    If application and its tests were built for .NET 1.1 you will
-    also need to redirect system assemblies in the test config file,
-    which controls loading of the tests.
-   -->
-    <assemblyBinding xmlns="urn:schemas-microsoft-com:asm.v1"
-       appliesTo="v1.0.3705">
-
-      <dependentAssembly>
-        <assemblyIdentity name="System"
-                          publicKeyToken="b77a5c561934e089"
-                          culture="neutral"/>
-        <bindingRedirect  oldVersion="1.0.5000.0"
-                          newVersion="1.0.3300.0"/>
-      </dependentAssembly>
-
-      <dependentAssembly>
-        <assemblyIdentity name="System.Data"
-                          publicKeyToken="b77a5c561934e089"
-                          culture="neutral"/>
-        <bindingRedirect  oldVersion="1.0.5000.0"
-                          newVersion="1.0.3300.0"/>
-      </dependentAssembly>
-
-      <dependentAssembly>
-        <assemblyIdentity name="System.Drawing"
-                          publicKeyToken="b03f5f7f11d50a3a"
-                          culture="neutral"/>
-        <bindingRedirect  oldVersion="1.0.5000.0"
-                          newVersion="1.0.3300.0"/>
-      </dependentAssembly>
-
-      <dependentAssembly>
-        <assemblyIdentity name="System.Windows.Forms"
-                          publicKeyToken="b77a5c561934e089"
-                          culture="neutral"/>
-        <bindingRedirect  oldVersion="1.0.5000.0"
-                          newVersion="1.0.3300.0"/>
-      </dependentAssembly>
-
-      <dependentAssembly>
-        <assemblyIdentity name="System.Xml"
-                          publicKeyToken="b77a5c561934e089"
-                          culture="neutral"/>
-        <bindingRedirect  oldVersion="1.0.5000.0"
-                          newVersion="1.0.3300.0"/>
-      </dependentAssembly>
-
-    </assemblyBinding>
-
-  </runtime>
-
-</configuration>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/nunit.exe
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/nunit.exe b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/nunit.exe
deleted file mode 100644
index 7718d8d..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/nunit.exe and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/nunit.exe.config
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/nunit.exe.config b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/nunit.exe.config
deleted file mode 100644
index 1641a50..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/nunit.exe.config
+++ /dev/null
@@ -1,83 +0,0 @@
-<?xml version="1.0" encoding="utf-8"?>
-<configuration>
-  <!--
-     Application settings for NUnit-gui.exe. Do NOT put settings
-	 for use by your tests here.
-	-->
-  <appSettings>
-    <!--
-     Uncomment to specify the url to be used for help. If not used, the
-     default value is something like
-		file://localhost/C:/Program Files/NUnit 2.2/doc/index.html
-	 This setting is provided in case your default browser doesn't
-	 support this format.
-	-->
-    <!-- <add key="helpUrl" value="http://www.nunit.org" /> -->
-  </appSettings>
-
-  <runtime>
-    <!-- We need this so test exceptions don't crash NUnit -->
-    <legacyUnhandledExceptionPolicy enabled="1" />
-
-    <!-- Look for addins in the addins directory for now -->
-    <assemblyBinding xmlns="urn:schemas-microsoft-com:asm.v1">
-      <probing privatePath="lib;addins" />
-    </assemblyBinding>
-
-    <!--
-    The following <assemblyBinding> section allows running nunit under 
-    .NET 1.0 by redirecting assemblies. The appliesTo attribute
-    causes the section to be ignored except under .NET 1.0
-    on a machine with only the .NET version 1.0 runtime installed.
-    If application and its tests were built for .NET 1.1 you will
-    also need to redirect system assemblies in the test config file,
-    which controls loading of the tests.
-   -->
-    <assemblyBinding xmlns="urn:schemas-microsoft-com:asm.v1"
-       appliesTo="v1.0.3705">
-
-      <dependentAssembly>
-        <assemblyIdentity name="System"
-                          publicKeyToken="b77a5c561934e089"
-                          culture="neutral"/>
-        <bindingRedirect  oldVersion="1.0.5000.0"
-                          newVersion="1.0.3300.0"/>
-      </dependentAssembly>
-
-      <dependentAssembly>
-        <assemblyIdentity name="System.Data"
-                          publicKeyToken="b77a5c561934e089"
-                          culture="neutral"/>
-        <bindingRedirect  oldVersion="1.0.5000.0"
-                          newVersion="1.0.3300.0"/>
-      </dependentAssembly>
-
-      <dependentAssembly>
-        <assemblyIdentity name="System.Drawing"
-                          publicKeyToken="b03f5f7f11d50a3a"
-                          culture="neutral"/>
-        <bindingRedirect  oldVersion="1.0.5000.0"
-                          newVersion="1.0.3300.0"/>
-      </dependentAssembly>
-
-      <dependentAssembly>
-        <assemblyIdentity name="System.Windows.Forms"
-                          publicKeyToken="b77a5c561934e089"
-                          culture="neutral"/>
-        <bindingRedirect  oldVersion="1.0.5000.0"
-                          newVersion="1.0.3300.0"/>
-      </dependentAssembly>
-
-      <dependentAssembly>
-        <assemblyIdentity name="System.Xml"
-                          publicKeyToken="b77a5c561934e089"
-                          culture="neutral"/>
-        <bindingRedirect  oldVersion="1.0.5000.0"
-                          newVersion="1.0.3300.0"/>
-      </dependentAssembly>
-
-    </assemblyBinding>
-
-  </runtime>
-
-</configuration>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/nunit.framework.dll
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/nunit.framework.dll b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/nunit.framework.dll
deleted file mode 100644
index 875e098..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/nunit.framework.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/pnunit-agent.exe
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/pnunit-agent.exe b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/pnunit-agent.exe
deleted file mode 100644
index 31a03d8..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/pnunit-agent.exe and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/pnunit-agent.exe.config
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/pnunit-agent.exe.config b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/pnunit-agent.exe.config
deleted file mode 100644
index 0bf29b3..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/pnunit-agent.exe.config
+++ /dev/null
@@ -1,77 +0,0 @@
-<?xml version="1.0" encoding="Windows-1252"?>
-<configuration>
-
-  <!-- Set the level for tracing NUnit itself -->
-  <!-- 0=Off 1=Error 2=Warning 3=Info 4=Debug -->
-  <system.diagnostics>
-	  <switches>
-      <add name="NTrace" value="0" />
-	  </switches>
-  </system.diagnostics>
-  
-  <runtime>
-    <!-- We need this so test exceptions don't crash NUnit -->
-    <legacyUnhandledExceptionPolicy enabled="1" />
-
-    <!-- Look for addins in the addins directory for now -->
-    <assemblyBinding xmlns="urn:schemas-microsoft-com:asm.v1">
-      <probing privatePath="framework;lib;addins"/>
-   </assemblyBinding>
-
-    <!--
-    The following <assemblyBinding> section allows running nunit under 
-    .NET 1.0 by redirecting assemblies. The appliesTo attribute
-    causes the section to be ignored except under .NET 1.0
-    on a machine with only the .NET version 1.0 runtime installed.
-    If application and its tests were built for .NET 1.1 you will
-    also need to redirect system assemblies in the test config file,
-    which controls loading of the tests.
-   -->
-    <assemblyBinding xmlns="urn:schemas-microsoft-com:asm.v1"
-			appliesTo="v1.0.3705">
-
-      <dependentAssembly> 
-        <assemblyIdentity name="System" 
-                          publicKeyToken="b77a5c561934e089" 
-                          culture="neutral"/>
-        <bindingRedirect  oldVersion="1.0.5000.0" 
-                          newVersion="1.0.3300.0"/>
-      </dependentAssembly>
-
-      <dependentAssembly> 
-        <assemblyIdentity name="System.Data" 
-                          publicKeyToken="b77a5c561934e089" 
-                          culture="neutral"/>
-        <bindingRedirect  oldVersion="1.0.5000.0" 
-                          newVersion="1.0.3300.0"/>
-      </dependentAssembly>
-
-      <dependentAssembly> 
-        <assemblyIdentity name="System.Drawing" 
-                          publicKeyToken="b03f5f7f11d50a3a" 
-                          culture="neutral"/>
-        <bindingRedirect  oldVersion="1.0.5000.0" 
-                          newVersion="1.0.3300.0"/>
-      </dependentAssembly>
-
-      <dependentAssembly> 
-        <assemblyIdentity name="System.Windows.Forms" 
-                          publicKeyToken="b77a5c561934e089" 
-                          culture="neutral"/>
-        <bindingRedirect  oldVersion="1.0.5000.0" 
-                          newVersion="1.0.3300.0"/>
-      </dependentAssembly>
-
-      <dependentAssembly> 
-        <assemblyIdentity name="System.Xml" 
-                          publicKeyToken="b77a5c561934e089" 
-                          culture="neutral"/>
-        <bindingRedirect  oldVersion="1.0.5000.0" 
-                          newVersion="1.0.3300.0"/>
-      </dependentAssembly>
-
-    </assemblyBinding>
-  
-  </runtime>
-  
-</configuration>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/pnunit-launcher.exe
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/pnunit-launcher.exe b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/pnunit-launcher.exe
deleted file mode 100644
index e4c4f09..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/pnunit-launcher.exe and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/pnunit-launcher.exe.config
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/pnunit-launcher.exe.config b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/pnunit-launcher.exe.config
deleted file mode 100644
index 0bf29b3..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/pnunit-launcher.exe.config
+++ /dev/null
@@ -1,77 +0,0 @@
-<?xml version="1.0" encoding="Windows-1252"?>
-<configuration>
-
-  <!-- Set the level for tracing NUnit itself -->
-  <!-- 0=Off 1=Error 2=Warning 3=Info 4=Debug -->
-  <system.diagnostics>
-	  <switches>
-      <add name="NTrace" value="0" />
-	  </switches>
-  </system.diagnostics>
-  
-  <runtime>
-    <!-- We need this so test exceptions don't crash NUnit -->
-    <legacyUnhandledExceptionPolicy enabled="1" />
-
-    <!-- Look for addins in the addins directory for now -->
-    <assemblyBinding xmlns="urn:schemas-microsoft-com:asm.v1">
-      <probing privatePath="framework;lib;addins"/>
-   </assemblyBinding>
-
-    <!--
-    The following <assemblyBinding> section allows running nunit under 
-    .NET 1.0 by redirecting assemblies. The appliesTo attribute
-    causes the section to be ignored except under .NET 1.0
-    on a machine with only the .NET version 1.0 runtime installed.
-    If application and its tests were built for .NET 1.1 you will
-    also need to redirect system assemblies in the test config file,
-    which controls loading of the tests.
-   -->
-    <assemblyBinding xmlns="urn:schemas-microsoft-com:asm.v1"
-			appliesTo="v1.0.3705">
-
-      <dependentAssembly> 
-        <assemblyIdentity name="System" 
-                          publicKeyToken="b77a5c561934e089" 
-                          culture="neutral"/>
-        <bindingRedirect  oldVersion="1.0.5000.0" 
-                          newVersion="1.0.3300.0"/>
-      </dependentAssembly>
-
-      <dependentAssembly> 
-        <assemblyIdentity name="System.Data" 
-                          publicKeyToken="b77a5c561934e089" 
-                          culture="neutral"/>
-        <bindingRedirect  oldVersion="1.0.5000.0" 
-                          newVersion="1.0.3300.0"/>
-      </dependentAssembly>
-
-      <dependentAssembly> 
-        <assemblyIdentity name="System.Drawing" 
-                          publicKeyToken="b03f5f7f11d50a3a" 
-                          culture="neutral"/>
-        <bindingRedirect  oldVersion="1.0.5000.0" 
-                          newVersion="1.0.3300.0"/>
-      </dependentAssembly>
-
-      <dependentAssembly> 
-        <assemblyIdentity name="System.Windows.Forms" 
-                          publicKeyToken="b77a5c561934e089" 
-                          culture="neutral"/>
-        <bindingRedirect  oldVersion="1.0.5000.0" 
-                          newVersion="1.0.3300.0"/>
-      </dependentAssembly>
-
-      <dependentAssembly> 
-        <assemblyIdentity name="System.Xml" 
-                          publicKeyToken="b77a5c561934e089" 
-                          culture="neutral"/>
-        <bindingRedirect  oldVersion="1.0.5000.0" 
-                          newVersion="1.0.3300.0"/>
-      </dependentAssembly>
-
-    </assemblyBinding>
-  
-  </runtime>
-  
-</configuration>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/pnunit.framework.dll
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/pnunit.framework.dll b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/pnunit.framework.dll
deleted file mode 100644
index ca9b5cb..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/pnunit.framework.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/pnunit.tests.dll
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/pnunit.tests.dll b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/pnunit.tests.dll
deleted file mode 100644
index e3985d6..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/pnunit.tests.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/runFile.exe
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/runFile.exe b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/runFile.exe
deleted file mode 100644
index a794458..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/runFile.exe and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/runFile.exe.config
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/runFile.exe.config b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/runFile.exe.config
deleted file mode 100644
index f58f099..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/runFile.exe.config
+++ /dev/null
@@ -1,43 +0,0 @@
-<?xml version="1.0" encoding="utf-8" ?>
-<configuration>
-  <startup>
-	  <supportedRuntime version="v2.0.50727" />
-	  <supportedRuntime version="v2.0.50215" />
-	  <supportedRuntime version="v2.0.40607" />
-	  <supportedRuntime version="v1.1.4322" />
-	  <supportedRuntime version="v1.0.3705" />
-	
-	  <requiredRuntime version="v1.0.3705" />
-  </startup>
-
-<!--
-     The following <runtime> section allows running nunit tests under 
-     .NET 1.0 by redirecting assemblies. The appliesTo attribute
-     causes the section to be ignored except under .NET 1.0.
-	-->
-	<runtime>
-		<assemblyBinding xmlns="urn:schemas-microsoft-com:asm.v1"
-				appliesTo="v1.0.3705">
-			<dependentAssembly>
-				<assemblyIdentity name="System" publicKeyToken="b77a5c561934e089" culture="" />
-				<bindingRedirect oldVersion="1.0.5000.0" newVersion="1.0.3300.0" />
-			</dependentAssembly>
-			<dependentAssembly>
-				<assemblyIdentity name="System.Data" publicKeyToken="b77a5c561934e089" culture="" />
-				<bindingRedirect oldVersion="1.0.5000.0" newVersion="1.0.3300.0" />
-			</dependentAssembly>
-			<dependentAssembly>
-				<assemblyIdentity name="System.Drawing" publicKeyToken="b03f5f7f11d50a3a" culture="" />
-				<bindingRedirect oldVersion="1.0.5000.0" newVersion="1.0.3300.0" />
-			</dependentAssembly>
-			<dependentAssembly>
-				<assemblyIdentity name="System.Windows.Forms" publicKeyToken="b77a5c561934e089" culture="" />
-				<bindingRedirect oldVersion="1.0.5000.0" newVersion="1.0.3300.0" />
-			</dependentAssembly>
-			<dependentAssembly>
-				<assemblyIdentity name="System.Xml" publicKeyToken="b77a5c561934e089" culture="" />
-				<bindingRedirect oldVersion="1.0.5000.0" newVersion="1.0.3300.0" />
-			</dependentAssembly>
-		</assemblyBinding>
-	</runtime>
-</configuration>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/runpnunit.bat
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/runpnunit.bat b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/runpnunit.bat
deleted file mode 100644
index a05cbb7..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/runpnunit.bat
+++ /dev/null
@@ -1,2 +0,0 @@
-start pnunit-agent agent.conf
-pnunit-launcher test.conf
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/test.conf
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/test.conf b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/test.conf
deleted file mode 100644
index 14cd113..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/test.conf
+++ /dev/null
@@ -1,24 +0,0 @@
-<TestGroup>
-    <ParallelTests>
-
-        <ParallelTest>
-            <Name>Testing</Name>
-            <Tests>
-                <TestConf>
-                    <Name>Testing</Name>
-                    <Assembly>pnunit.tests.dll</Assembly>
-                    <TestToRun>TestLibraries.Testing.EqualTo19</TestToRun>
-                    <Machine>localhost:8080</Machine>
-                    <TestParams>
-                        <string>..\server</string> <!-- server dir -->
-			<string></string> <!-- database server -->
-			<string></string><!-- conn string -->
-                    </TestParams>                                                                                
-                </TestConf>
-
-            </Tests>
-        </ParallelTest>
-
-
-    </ParallelTests>
-</TestGroup>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/tests/loadtest-assembly.dll
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/tests/loadtest-assembly.dll b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/tests/loadtest-assembly.dll
deleted file mode 100644
index 157cc43..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/tests/loadtest-assembly.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/tests/mock-assembly.dll
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/tests/mock-assembly.dll b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/tests/mock-assembly.dll
deleted file mode 100644
index 4a76850..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/tests/mock-assembly.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/tests/nonamespace-assembly.dll
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/tests/nonamespace-assembly.dll b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/tests/nonamespace-assembly.dll
deleted file mode 100644
index b12afd4..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/tests/nonamespace-assembly.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/tests/nunit-console.tests.dll
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/tests/nunit-console.tests.dll b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/tests/nunit-console.tests.dll
deleted file mode 100644
index 72d86ac..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/tests/nunit-console.tests.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/tests/nunit-gui.tests.dll
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/tests/nunit-gui.tests.dll b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/tests/nunit-gui.tests.dll
deleted file mode 100644
index 5be8253..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/tests/nunit-gui.tests.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/tests/nunit.core.tests.dll
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/tests/nunit.core.tests.dll b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/tests/nunit.core.tests.dll
deleted file mode 100644
index 897b061..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/tests/nunit.core.tests.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/tests/nunit.fixtures.tests.dll
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/tests/nunit.fixtures.tests.dll b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/tests/nunit.fixtures.tests.dll
deleted file mode 100644
index 22ba068..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/tests/nunit.fixtures.tests.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/tests/nunit.framework.dll
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/tests/nunit.framework.dll b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/tests/nunit.framework.dll
deleted file mode 100644
index 875e098..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/tests/nunit.framework.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/tests/nunit.framework.tests.dll
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/tests/nunit.framework.tests.dll b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/tests/nunit.framework.tests.dll
deleted file mode 100644
index 28dc3ab..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/tests/nunit.framework.tests.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/tests/nunit.mocks.tests.dll
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/tests/nunit.mocks.tests.dll b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/tests/nunit.mocks.tests.dll
deleted file mode 100644
index 09a0b17..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/tests/nunit.mocks.tests.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/tests/nunit.uiexception.tests.dll
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/tests/nunit.uiexception.tests.dll b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/tests/nunit.uiexception.tests.dll
deleted file mode 100644
index 43863c0..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/tests/nunit.uiexception.tests.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/tests/nunit.uikit.tests.dll
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/tests/nunit.uikit.tests.dll b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/tests/nunit.uikit.tests.dll
deleted file mode 100644
index 0abc2a7..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/tests/nunit.uikit.tests.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/tests/nunit.util.tests.dll
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/tests/nunit.util.tests.dll b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/tests/nunit.util.tests.dll
deleted file mode 100644
index 6e9e90a..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/tests/nunit.util.tests.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/tests/test-assembly.dll
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/tests/test-assembly.dll b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/tests/test-assembly.dll
deleted file mode 100644
index 4304241..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/tests/test-assembly.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/tests/test-utilities.dll
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/tests/test-utilities.dll b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/tests/test-utilities.dll
deleted file mode 100644
index 553750b..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/tests/test-utilities.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/tests/timing-tests.dll
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/tests/timing-tests.dll b/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/tests/timing-tests.dll
deleted file mode 100644
index fc2711b..0000000
Binary files a/lib/NUnit.org/NUnit/2.5.9/bin/net-2.0/tests/timing-tests.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/addinsDialog.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/addinsDialog.html b/lib/NUnit.org/NUnit/2.5.9/doc/addinsDialog.html
deleted file mode 100644
index 1f76d0a..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/addinsDialog.html
+++ /dev/null
@@ -1,109 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - AddinsDialog</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h2>Addins Dialog</h2>
-
-<p>The Addins Dialog is displayed using the Tools | Addins menu item on the main
-menu. It lists all addins that have been found and loaded by NUnit.</p>
-
-<div class="screenshot-right">
-   <img src="img/addinsDialog.jpg"></div>
-
-<h3>Addin</h3>
-
-<p>This column lists the name of the addin, as defined by its author.
-
-<h3>Status</h3>
-
-<p>This column shows the status of each addin. Possible values are
-<ul>
-<li>Unknown
-<li>Enabled
-<li>Disabled
-<li>Loaded
-<li>Error
-</ul>
-
-<h3>Description</h3>
-
-<p>If the author of an addin has provided a description, it is
-shown here when the addin is selected.
-
-<h3>Message</h3>
-
-<p>If the addin failed to load, its status will be shown as Error
-and any error message displayed here when that addin is selected.
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<ul>
-<li><a href="nunit-console.html">Console&nbsp;Runner</a></li>
-<li><a href="nunit-gui.html">Gui&nbsp;Runner</a></li>
-<ul>
-<li><a href="guiCommandLine.html">Command-Line</a></li>
-<li><a href="mainMenu.html">Main&nbsp;Menu</a></li>
-<li><a href="contextMenu.html">Context&nbsp;Menu</a></li>
-<li><a href="settingsDialog.html">Settings&nbsp;Dialog</a></li>
-<li id="current"><a href="addinsDialog.html">Addins&nbsp;Dialog</a></li>
-<li><a href="testProperties.html">Test&nbsp;Properties</a></li>
-<li><a href="configEditor.html">Configuration&nbsp;Editor</a></li>
-<li><a href="projectEditor.html">Project&nbsp;Editor</a></li>
-</ul>
-<li><a href="pnunit.html">PNUnit&nbsp;Runner</a></li>
-<li><a href="runtimeSelection.html">Runtime&nbsp;Selection</a></li>
-<li><a href="assemblyIsolation.html">Assembly&nbsp;Isolation</a></li>
-<li><a href="configFiles.html">Configuration&nbsp;Files</a></li>
-<li><a href="multiAssembly.html">Multiple&nbsp;Assemblies</a></li>
-<li><a href="vsSupport.html">Visual&nbsp;Studio&nbsp;Support</a></li>
-</ul>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/assemblyIsolation.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/assemblyIsolation.html b/lib/NUnit.org/NUnit/2.5.9/doc/assemblyIsolation.html
deleted file mode 100644
index 284432b..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/assemblyIsolation.html
+++ /dev/null
@@ -1,112 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - AssemblyIsolation</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h3>Assembly Isolation</h3>
-
-<p>NUnit isolates test assemblies from its own code and from one another
-   by use of separate AppDomains and/or Processes.
-   
-<p>By default, NUnit loads a test assembly into a separate <b>AppDomain</b>, 
-   while its own code runs in the primary <b>AppDomain</b>.
-   
-<p>When multiple assemblies are run at the same time, NUnit loads them differently 
-   depending on how they were specified. For assemblies that are part of an
-   NUnit project, then a single <b>AppDomain</b> is used. If the assemblies 
-   were specified on the console runner command line, then a separate 
-   <b>AppDomain</b> is used for each of them.
-   
-<p>If greater separation is desired, test assemblies may be loaded into
-   a separate <b>Process</b> or into multiple processes. This is done
-   automatically by NUnit in the case where the tests are to be run under
-   a different runtime from the one that NUnit is currently using. Tests
-   running in a separate process are executed under the control of the
-   <a href="nunit-agent.html">nunit-agent</a> program.
-   
-<h3>Controlling Isolation</h3>
-
-<p>Beyond the NUnit default behavior, the user may control the level of isolation
-   through the command line or through NUnit's general settings. Process and AppDomain
-   isolation may also be specified as part of the settings of an NUnit project.
-   
-<h4>Command Line</h4>
-
-<p>Assembly Isolation may be specified on the console runner commandline using
-   the <b>/process</b> and <b>/domain</b> options. See 
-   <a href="consoleCommandLine.html">NUnit-Console Command Line Options</a>   for more information.
-   
-<h4>General Settings</h4>
-
-<p>The built-in NUnit defaults may be overridden using the <b>Assembly Isolation</b>
-   panel of the NUnit <b>Settings Dialog</b>. Settings made here are saved and become
-   the new default values for all executions of NUnit until changed. For more info,
-   see the <a href="settingsDialog.html">Settings Dialog</a> page.
-
-<h4>Project Settings</h4>
-
-<p>Isolation settings may be specified for an individual NUnit project using the
-   <a href="projectEditor.html">Project Editor</a>.
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<ul>
-<li><a href="nunit-console.html">Console&nbsp;Runner</a></li>
-<li><a href="nunit-gui.html">Gui&nbsp;Runner</a></li>
-<li><a href="pnunit.html">PNUnit&nbsp;Runner</a></li>
-<li><a href="nunit-agent.html">NUnit&nbsp;Agent</a></li>
-<li><a href="runtimeSelection.html">Runtime&nbsp;Selection</a></li>
-<li id="current"><a href="assemblyIsolation.html">Assembly&nbsp;Isolation</a></li>
-<li><a href="configFiles.html">Configuration&nbsp;Files</a></li>
-<li><a href="multiAssembly.html">Multiple&nbsp;Assemblies</a></li>
-<li><a href="vsSupport.html">Visual&nbsp;Studio&nbsp;Support</a></li>
-</ul>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/assertions.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/assertions.html b/lib/NUnit.org/NUnit/2.5.9/doc/assertions.html
deleted file mode 100644
index 210c52c..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/assertions.html
+++ /dev/null
@@ -1,105 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - Assertions</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h2>Assertions</h2>
-
-<p>Assertions are central to unit testing in any of the xUnit frameworks, and NUnit 
-	is no exception. NUnit provides a rich set of assertions as static methods of 
-	the Assert class.</p>
-
-<p>If an assertion fails, the method call does not return and an error is reported. 
-	If a test contains multiple assertions, any that follow the one that failed 
-	will not be executed. For this reason, it's usually best to try for one 
-	assertion per test.</p>
-
-<p>Each method may be called without a message, with a simple text message or with 
-	a message and arguments. In the last case the message is formatted using the 
-	provided text and arguments.</p>
-	
-<h3>Two Models</h3>
-
-<p>Before NUnit 2.4, a separate method of the Assert class was used for each
-   different assertion. We call this the "Classic Model." It
-   continues to be supported in NUnit, since many people prefer it.</p>
-
-<p>Beginning with NUnit 2.4, a new "Constraint-based" model was 
-   introduced. This approach uses a single method of the Assert class
-   for all assertions, passing a <a href="constraintModel.html">Constraint</a>   object that specifies the test to be performed.
-
-<p>This constraint-based model is now used internally by NUnit
-   for all assertions. The methods of the classic approach have been 
-   re-implemented on top of this new model.
-   
-   <!--
-<h4>See Also...</h4>
-<ul>
-<li>
-</ul>
--->
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li id="current"><a href="assertions.html">Assertions</a></li>
-<ul>
-<li><a href="equalityAsserts.html">Equality&nbsp;Asserts</a></li>
-<li><a href="identityAsserts.html">Identity&nbsp;Asserts</a></li>
-<li><a href="conditionAsserts.html">Condition&nbsp;Asserts</a></li>
-<li><a href="comparisonAsserts.html">Comparison&nbsp;Asserts</a></li>
-<li><a href="typeAsserts.html">Type&nbsp;Asserts</a></li>
-<li><a href="exceptionAsserts.html">Exception&nbsp;Asserts</a></li>
-<li><a href="utilityAsserts.html">Utility&nbsp;Methods</a></li>
-<li><a href="stringAssert.html">String&nbsp;Assert</a></li>
-<li><a href="collectionAssert.html">Collection&nbsp;Assert</a></li>
-<li><a href="fileAssert.html">File&nbsp;Assert</a></li>
-<li><a href="directoryAssert.html">Directory&nbsp;Assert</a></li>
-</ul>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/attributes.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/attributes.html b/lib/NUnit.org/NUnit/2.5.9/doc/attributes.html
deleted file mode 100644
index fdb2d5c..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/attributes.html
+++ /dev/null
@@ -1,107 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - Attributes</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h2>Attributes</h2>
-<p>Version 1 of NUnit used the classic approach to identifying tests based on 
-	inheritance and naming conventions. From version 2.0 on, NUnit has used custom 
-	attributes for this purpose.</p>
-<p>Because NUnit test fixtures do not inherit from a framework class, the developer 
-	is free to use inheritance in other ways. And because there is no arbitrary 
-	convention for naming tests, the choice of names can be entirely oriented 
-	toward communicating the purpose of the test.</p>
-<p>All NUnit attributes are contained in the NUnit.Framework namespace. Each source 
-	file that contains tests must include a using statement for that namespace and 
-	the project must reference the framework assembly, nunit.framework.dll.</p>
-<p>Beginning with NUnit 2.4.6, NUnit's attributes are no longer sealed and any
-    attributes that derive from them will be recognized by NUnit.
- 
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li id="current"><a href="attributes.html">Attributes</a></li>
-<ul>
-<li><a href="category.html">Category</a></li>
-<li><a href="combinatorial.html">Combinatorial</a></li>
-<li><a href="culture.html">Culture</a></li>
-<li><a href="datapoint.html">Datapoint(s)</a></li>
-<li><a href="description.html">Description</a></li>
-<li><a href="exception.html">Exception</a></li>
-<li><a href="explicit.html">Explicit</a></li>
-<li><a href="ignore.html">Ignore</a></li>
-<li><a href="maxtime.html">Maxtime</a></li>
-<li><a href="pairwise.html">Pairwise</a></li>
-<li><a href="platform.html">Platform</a></li>
-<li><a href="property.html">Property</a></li>
-<li><a href="random.html">Random</a></li>
-<li><a href="range.html">Range</a></li>
-<li><a href="repeat.html">Repeat</a></li>
-<li><a href="requiredAddin.html">RequiredAddin</a></li>
-<li><a href="requiresMTA.html">Requires&nbsp;MTA</a></li>
-<li><a href="requiresSTA.html">Requires&nbsp;STA</a></li>
-<li><a href="requiresThread.html">Requires&nbsp;Thread</a></li>
-<li><a href="sequential.html">Sequential</a></li>
-<li><a href="setCulture.html">SetCulture</a></li>
-<li><a href="setup.html">Setup</a></li>
-<li><a href="setupFixture.html">SetupFixture</a></li>
-<li><a href="suite.html">Suite</a></li>
-<li><a href="teardown.html">Teardown</a></li>
-<li><a href="test.html">Test</a></li>
-<li><a href="testCase.html">TestCase</a></li>
-<li><a href="testCaseSource.html">TestCaseSource</a></li>
-<li><a href="testFixture.html">TestFixture</a></li>
-<li><a href="fixtureSetup.html">TestFixtureSetUp</a></li>
-<li><a href="fixtureTeardown.html">TestFixtureTearDown</a></li>
-<li><a href="theory.html">Theory</a></li>
-<li><a href="timeout.html">Timeout</a></li>
-<li><a href="values.html">Values</a></li>
-<li><a href="valueSource.html">ValueSource</a></li>
-</ul>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/category.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/category.html b/lib/NUnit.org/NUnit/2.5.9/doc/category.html
deleted file mode 100644
index 84956e2..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/category.html
+++ /dev/null
@@ -1,283 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - Category</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<script language="JavaScript" src="codeFuncs.js" ></script> <!-- Do it this way for IE -->
-
-<h3>CategoryAttribute (NUnit 2.2)</h3>
-<p>The Category attribute provides an alternative to suites for dealing with groups 
-	of tests. Either individual test cases or fixtures may be identified as 
-	belonging to a particular category. Both the gui and console test runners allow 
-	specifying a list of categories to be included in or excluded from the run. 
-	When categories are used, only the tests in the selected categories will be 
-	run. Those tests in categories that are not selected are not reported at all.</p>
-<p>This feature is accessible by use of the /include and /exclude arguments to the 
-	console runner and through a separate "Categories" tab in the gui. The gui 
-	provides a visual indication of which categories are selected at any time.</p>
-
-<h4>Test Fixture Syntax</h4>
-
-<div class="code">
-
-<div class="langFilter">
-	<a href="javascript:Show('DD1')" onmouseover="Show('DD1')"><img src="img/langFilter.gif" width="14" height="14" alt="Language Filter"></a>
-	<div id="DD1" class="dropdown" style="display: none;" onclick="Hide('DD1')">
-		<a href="javascript:ShowCS()">C#</a><br>
-		<a href="javascript:ShowVB()">VB</a><br>
-		<a href="javascript:ShowMC()">C++</a><br>
-		<a href="javascript:ShowJS()">J#</a><br>
-	</div>
-</div>
-
-<pre class="cs">namespace NUnit.Tests
-{
-  using System;
-  using NUnit.Framework;
-
-  [TestFixture]
-  [Category(&quot;LongRunning&quot;)]
-  public class LongRunningTests
-  {
-    // ...
-  }
-}
-</pre>
-
-<pre class="vb">Imports System
-Imports Nunit.Framework
-
-Namespace Nunit.Tests
-
-  &lt;TestFixture(), Category(&quot;LongRunning&quot;)&gt;
-  Public Class LongRunningTests
-    &#39; ...
-  End Class
-End Namespace
-</pre>
-
-<pre class="mc">#using &lt;Nunit.Framework.dll&gt;
-using namespace System;
-using namespace NUnit::Framework;
-
-namespace NUnitTests
-{
-  [TestFixture]
-  [Category(&quot;LongRunning&quot;)]
-  public __gc class LongRunningTests
-  {
-    // ...
-  };
-}
-
-#include &quot;cppsample.h&quot;
-
-namespace NUnitTests {
-  // ...
-}
-</pre>
-
-<pre class="js">package NUnit.Tests;
-
-import System.*;
-import NUnit.Framework.TestFixture;
-
-
-/** @attribute NUnit.Framework.TestFixture() */
-/** @attribute NUnit.Framework.Category(&quot;LongRunning&quot;) */
-public class LongRunningTests
-{
-  // ...
-}
-</pre>
-</div>
-<h4>Test Syntax</h4>
-<div class="code">
-	
-<div class="langFilter">
-	<a href="javascript:Show('DD2')" onmouseover="Show('DD2')"><img src="img/langFilter.gif" width="14" height="14" alt="Language Filter"></a>
-	<div id="DD2" class="dropdown" style="display: none;" onclick="Hide('DD2')">
-		<a href="javascript:ShowCS()">C#</a><br>
-		<a href="javascript:ShowVB()">VB</a><br>
-		<a href="javascript:ShowMC()">C++</a><br>
-		<a href="javascript:ShowJS()">J#</a><br>
-	</div>
-</div>
-
-<pre class="cs">namespace NUnit.Tests
-{
-  using System;
-  using NUnit.Framework;
-
-  [TestFixture]
-  public class SuccessTests
-  {
-    [Test]
-    [Category(&quot;Long&quot;)]
-    public void VeryLongTest()
-    { /* ... */ }
-}
-</pre>
-
-<pre class="vb">Imports System
-Imports Nunit.Framework
-
-Namespace Nunit.Tests
-
-  &lt;TestFixture()&gt;
-  Public Class SuccessTests
-    &lt;Test(), Category(&quot;Long&quot;)&gt; Public Sub VeryLongTest()
-      &#39; ...
-    End Sub
-  End Class
-End Namespace
-</pre>
-
-<pre class="mc">#using &lt;Nunit.Framework.dll&gt;
-using namespace System;
-using namespace NUnit::Framework;
-
-namespace NUnitTests
-{
-  [TestFixture]
-  public __gc class SuccessTests
-  {
-    [Test][Category(&quot;Long&quot;)] void VeryLongTest();
-  };
-}
-
-#include &quot;cppsample.h&quot;
-
-namespace NUnitTests {
-  // ...
-}
-</pre>
-
-<pre class="js">package NUnit.Tests;
-
-import System.*;
-import NUnit.Framework.TestFixture;
-
-
-/** @attribute NUnit.Framework.TestFixture() */
-public class SuccessTests
-{
-  /** @attribute NUnit.Framework.Test() */
-  /** @attribute NUnit.Framework.Category(&quot;Long&quot;) */
-  public void VeryLongTest()
-  { /* ... */ }
-}
-</pre>
-
-</div>
-
-<h3>Custom Category Attributes</h3>
-
-<p>Beginning with <b>NUnit 2.4</b>, it is possible to define custom
-attributes that derive from <b>CategoryAttribute</b> and have them
-recognized by NUnit. The default protected constructor of CategoryAttribute 
-sets the category name to the name of your class.
-
-<p>Here's an example that creates a category of Critical tests. It works
-just like any other category, but has a simpler syntax. A test reporting
-system might make use of the attribute to provide special reports.
-
-<div class=code><pre>
-[AttributeUsage(AttributeTargets.Method, AllowMultiple=false)]
-public class CriticalAttribute : CategoryAttribute { }
-
-...
-
-[Test, Critical]
-public void MyTest()
-{ /*...*/ }
-</pre></div>
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<ul>
-<li id="current"><a href="category.html">Category</a></li>
-<li><a href="combinatorial.html">Combinatorial</a></li>
-<li><a href="culture.html">Culture</a></li>
-<li><a href="datapoint.html">Datapoint(s)</a></li>
-<li><a href="description.html">Description</a></li>
-<li><a href="exception.html">Exception</a></li>
-<li><a href="explicit.html">Explicit</a></li>
-<li><a href="ignore.html">Ignore</a></li>
-<li><a href="maxtime.html">Maxtime</a></li>
-<li><a href="pairwise.html">Pairwise</a></li>
-<li><a href="platform.html">Platform</a></li>
-<li><a href="property.html">Property</a></li>
-<li><a href="random.html">Random</a></li>
-<li><a href="range.html">Range</a></li>
-<li><a href="repeat.html">Repeat</a></li>
-<li><a href="requiredAddin.html">RequiredAddin</a></li>
-<li><a href="requiresMTA.html">Requires&nbsp;MTA</a></li>
-<li><a href="requiresSTA.html">Requires&nbsp;STA</a></li>
-<li><a href="requiresThread.html">Requires&nbsp;Thread</a></li>
-<li><a href="sequential.html">Sequential</a></li>
-<li><a href="setCulture.html">SetCulture</a></li>
-<li><a href="setup.html">Setup</a></li>
-<li><a href="setupFixture.html">SetupFixture</a></li>
-<li><a href="suite.html">Suite</a></li>
-<li><a href="teardown.html">Teardown</a></li>
-<li><a href="test.html">Test</a></li>
-<li><a href="testCase.html">TestCase</a></li>
-<li><a href="testCaseSource.html">TestCaseSource</a></li>
-<li><a href="testFixture.html">TestFixture</a></li>
-<li><a href="fixtureSetup.html">TestFixtureSetUp</a></li>
-<li><a href="fixtureTeardown.html">TestFixtureTearDown</a></li>
-<li><a href="theory.html">Theory</a></li>
-<li><a href="timeout.html">Timeout</a></li>
-<li><a href="values.html">Values</a></li>
-<li><a href="valueSource.html">ValueSource</a></li>
-</ul>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/codeFuncs.js
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/codeFuncs.js b/lib/NUnit.org/NUnit/2.5.9/doc/codeFuncs.js
deleted file mode 100644
index 7b7c3e4..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/codeFuncs.js
+++ /dev/null
@@ -1,77 +0,0 @@
-window.onload = init;
-
-var langElements = new Array();
-
-function init() {
-	var els = document.getElementsByTagName( 'pre' );
-	var elsLen = els.length;
-	var pattern = new RegExp('(^|\\s)(cs|vb|mc|js)(\\s|$)');
-	for (i = 0, j = 0; i < elsLen; i++) {
-		if ( pattern.test(els[i].className) ) {
-		   //els[i].style.background = "#fcc";
-		   langElements[j] = els[i];
-		   j++;
-		}
-	}
-	
-	var lang = getCookie( "lang" );
-	if ( lang == null ) lang = "cs";
-	showLang(lang);
-}
-
-function getCookie(name) {
- 	var cname = name + "=";
-	var dc = document.cookie;
-	if ( dc.length > 0 ) {
-	   begin = dc.indexOf(cname);
-	   if ( begin != -1 ) {
-	   	  begin += cname.length;
-		  end = dc.indexOf(";",begin);
-		  if (end == -1) end = dc.length;
-		  return unescape(dc.substring(begin, end) );
-	   }
-	}
-}
-
-function setCookie(name,value,expires) {
-	document.cookie = name + "=" + escape(value) + "; path=/" +
-	((expires == null) ? "" : "; expires=" + expires.toGMTString());
-}
-
-function showLang(lang) {
-	var pattern = new RegExp('(^|\\s)'+lang+'(\\s|$)');
-	var elsLen = langElements.length;
-	for (i = 0; i < elsLen; i++ )
-	{
-	 	var el = langElements[i];
-		if ( pattern.test( el.className ) )
-		   el.style.display = "";
-		else
-		   el.style.display = "none";
-	}
-	setCookie("lang",lang);
-}
-
-function Show( id ) {
-	document.getElementById(id).style.display = "";
-}
-
-function Hide( id ) {
-	document.getElementById(id).style.display = "none";
-}
-
-function ShowCS() {
-	showLang('cs');
-}
-
-function ShowVB() {
-	showLang('vb');
-}
-
-function ShowMC() {
-	showLang('mc');
-}
-
-function ShowJS() {
-	showLang('js');
-}

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/NUnit.org/NUnit/2.5.9/doc/collectionAssert.html
----------------------------------------------------------------------
diff --git a/lib/NUnit.org/NUnit/2.5.9/doc/collectionAssert.html b/lib/NUnit.org/NUnit/2.5.9/doc/collectionAssert.html
deleted file mode 100644
index 0a2c6d8..0000000
--- a/lib/NUnit.org/NUnit/2.5.9/doc/collectionAssert.html
+++ /dev/null
@@ -1,176 +0,0 @@
-<!-- saved from url=(0014)about:internet --><!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.0//EN">
-<html>
-<!-- Standard Head Part -->
-<head>
-<title>NUnit - CollectionAssert</title>
-<meta http-equiv="Content-Type" content="text/html; charset=windows-1252">
-<meta http-equiv="Content-Language" content="en-US">
-<link rel="stylesheet" type="text/css" href="nunit.css">
-<link rel="shortcut icon" href="favicon.ico">
-</head>
-<!-- End Standard Head Part -->
-
-<body>
-
-<!-- Standard Header for NUnit.org -->
-<div id="header">
-  <a id="logo" href="http://www.nunit.org"><img src="img/logo.gif" alt="NUnit.org" title="NUnit.org"></a>
-  <div id="nav">
-    <a href="http://www.nunit.org">NUnit</a>
-    <a class="active" href="index.html">Documentation</a>
-  </div>
-</div>
-<!-- End of Header -->
-
-<div id="content">
-
-<h2>CollectionAssert (NUnit 2.4 / 2.5)</h2>
-<p>The CollectionAssert class provides a number of methods that are useful 
-when examining collections and their contents or for comparing two collections.</p>
-
-<p>The <b>AreEqual</b> overloads succeed if the corresponding elements of the two 
-collections are equal. <b>AreEquivalent</b> tests whether the collection contents
-are equal, but without regard to order. In both cases, elements are compared using 
-NUnit's default equality comparison.</p>
-
-<p>Beginning with NUnit 2.4.6, these methods may be used on any object that
-implements IEnumerable. Prior to 2.4.6, only true collections were supported.
-
-<div class="code" style="width: 38em">
-<pre>CollectionAssert.AllItemsAreInstancesOfType( IEnumerable collection,
-          Type expectedType );
-CollectionAssert.AllItemsAreInstancesOfType( IEnumerable collection,
-          Type expectedType, string message );
-CollectionAssert.AllItemsAreInstancesOfType( IEnumerable collection,
-          Type expectedType, string message, params object[] args );
-
-CollectionAssert.AllItemsAreNotNull( IEnumerable collection );
-CollectionAssert.AllItemsAreNotNull( IEnumerable collection,
-          string message );
-CollectionAssert.AllItemsAreNotNull( IEnumerable collection,
-          string message, params object[] args );
-
-CollectionAssert.AllItemsAreUnique( IEnumerable collection );
-CollectionAssert.AllItemsAreUnique( IEnumerable collection,
-          string message );
-CollectionAssert.AllItemsAreUnique( IEnumerable collection,
-          string message, params object[] args );
-
-CollectionAssert.AreEqual( IEnumerable expected, IEnumerable actual );
-CollectionAssert.AreEqual( IEnumerable expected, IEnumerable actual,
-          string message );
-CollectionAssert.AreEqual( IEnumerable expected, IEnumerable actual
-          string message, params object[] args );
-
-CollectionAssert.AreEquivalent( IEnumerable expected, IEnumerable actual);
-CollectionAssert.AreEquivalent( IEnumerable expected, IEnumerable actual,
-          string message );
-CollectionAssert.AreEquivalent( IEnumerable expected, IEnumerable actual
-          string message, params object[] args );
-
-CollectionAssert.AreNotEqual( IEnumerable expected, IEnumerable actual );
-CollectionAssert.AreNotEqual( IEnumerable expected, IEnumerable actual,
-          string message );
-CollectionAssert.AreNotEqual( IEnumerableon expected, IEnumerable actual
-          string message, params object[] args );
-
-CollectionAssert.AreNotEquivalent( IEnumerable expected,
-          IEnumerable actual );
-CollectionAssert.AreNotEquivalent( IEnumerable expected,
-          IEnumerable actual, string message );
-CollectionAssert.AreNotEquivalent( IEnumerable expected,
-          IEnumerable actual, string message, params object[] args );
-
-CollectionAssert.Contains( IEnumerable expected, object actual );
-CollectionAssert.Contains( IEnumerable expected, object actual,
-          string message );
-CollectionAssert.Contains( IEnumerable expected, object actual
-          string message, params object[] args );
-
-CollectionAssert.DoesNotContain( IEnumerable expected, object actual );
-CollectionAssert.DoesNotContain( IEnumerable expected, object actual,
-          string message );
-CollectionAssert.DoesNotContain( IEnumerable expected, object actual
-          string message, params object[] args );
-
-CollectionAssert.IsSubsetOf( IEnumerable subset, IEnumerable superset );
-CollectionAssert.IsSubsetOf( IEnumerable subset, IEnumerable superset,
-          string message );
-CollectionAssert.IsSubsetOf( IEnumerable subset, IEnumerable superset,
-          string message, params object[] args );
-
-CollectionAssert.IsNotSubsetOf( IEnumerable subset, IEnumerable superset);
-CollectionAssert.IsNotSubsetOf( IEnumerable subset, IEnumerable superset,
-          string message );
-CollectionAssert.IsNotSubsetOf( IEnumerable subset, IEnumerable superset,
-          string message, params object[] args );
-
-CollectionAssert.IsEmpty( IEnumerable collection );
-CollectionAssert.IsEmpty( IEnumerable collection, string message );
-CollectionAssert.IsEmpty( IEnumerable collection, string message,
-          params object[] args );
-
-CollectionAssert.IsNotEmpty( IEnumerable collection );
-CollectionAssert.IsNotEmpty( IEnumerable collection, string message );
-CollectionAssert.IsNotEmpty( IEnumerable collection, string message,
-          params object[] args );
-</pre></div>
-		 
-<p>The following methods are available beginning with NUnit 2.5
-
-<div class="code" style="width: 38em"><pre>
-CollectionAssert.IsOrdered( IEnumerable collection );
-CollectionAssert.IsOrdered( IEnumerable collection, string message );
-CollectionAssert.IsOrdered( IEnumerable collection, string message,
-          params object[] args );
-		  
-CollectionAssert.IsOrdered( IEnumerable collection, IComparer comparer );
-CollectionAssert.IsOrdered( IEnumerable collection, IComparer comparer,
-          string message );
-CollectionAssert.IsOrdered( IEnumerable collection, IComparer comparer,
-          string message, params object[] args );
-</pre></div>
-
-</div>
-
-<!-- Submenu -->
-<div id="subnav">
-<ul>
-<li><a href="index.html">NUnit 2.5.9</a></li>
-<ul>
-<li><a href="getStarted.html">Getting&nbsp;Started</a></li>
-<li><a href="assertions.html">Assertions</a></li>
-<ul>
-<li><a href="equalityAsserts.html">Equality&nbsp;Asserts</a></li>
-<li><a href="identityAsserts.html">Identity&nbsp;Asserts</a></li>
-<li><a href="conditionAsserts.html">Condition&nbsp;Asserts</a></li>
-<li><a href="comparisonAsserts.html">Comparison&nbsp;Asserts</a></li>
-<li><a href="typeAsserts.html">Type&nbsp;Asserts</a></li>
-<li><a href="exceptionAsserts.html">Exception&nbsp;Asserts</a></li>
-<li><a href="utilityAsserts.html">Utility&nbsp;Methods</a></li>
-<li><a href="stringAssert.html">String&nbsp;Assert</a></li>
-<li id="current"><a href="collectionAssert.html">Collection&nbsp;Assert</a></li>
-<li><a href="fileAssert.html">File&nbsp;Assert</a></li>
-<li><a href="directoryAssert.html">Directory&nbsp;Assert</a></li>
-</ul>
-<li><a href="constraintModel.html">Constraints</a></li>
-<li><a href="attributes.html">Attributes</a></li>
-<li><a href="runningTests.html">Running&nbsp;Tests</a></li>
-<li><a href="extensibility.html">Extensibility</a></li>
-<li><a href="releaseNotes.html">Release&nbsp;Notes</a></li>
-<li><a href="samples.html">Samples</a></li>
-<li><a href="license.html">License</a></li>
-</ul>
-</ul>
-</div>
-<!-- End of Submenu -->
-
-
-<!-- Standard Footer for NUnit.org -->
-<div id="footer">
-  Copyright &copy; 2010 Charlie Poole. All Rights Reserved.
-</div>
-<!-- End of Footer -->
-
-</body>
-</html>


[38/51] [abbrv] [partial] Cleaning up and getting ready to development towards v4.8

Posted by sy...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Gallio.PowerShellCommands.xml
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Gallio.PowerShellCommands.xml b/lib/Gallio.3.2.750/tools/Gallio.PowerShellCommands.xml
deleted file mode 100644
index 6a898a9..0000000
--- a/lib/Gallio.3.2.750/tools/Gallio.PowerShellCommands.xml
+++ /dev/null
@@ -1,660 +0,0 @@
-<?xml version="1.0"?>
-<doc>
-    <assembly>
-        <name>Gallio.PowerShellCommands</name>
-    </assembly>
-    <members>
-        <member name="T:Gallio.PowerShellCommands.BaseCommand">
-            <exclude />
-            <summary>
-            Abstract base class for PowerShell commands.
-            Provides some useful runtime support.
-            </summary>
-        </member>
-        <member name="M:Gallio.PowerShellCommands.BaseCommand.PostMessage(Gallio.Common.Action)">
-            <summary>
-            Posts an action to perform later within the message loop.
-            </summary>
-            <param name="action">The action to perform.</param>
-            <seealso cref="M:Gallio.PowerShellCommands.BaseCommand.RunWithMessagePump(Gallio.Common.Action)"/>
-        </member>
-        <member name="M:Gallio.PowerShellCommands.BaseCommand.RunWithMessagePump(Gallio.Common.Action)">
-            <summary>
-            Starts a message pump running on the current thread and performs the
-            specified action in another thread.  The action can asynchronously communicate back to the
-            cmdlet using <see cref="M:Gallio.PowerShellCommands.BaseCommand.PostMessage(Gallio.Common.Action)"/> on the current thread.
-            </summary>
-            <param name="action">The action to perform.</param>
-        </member>
-        <member name="M:Gallio.PowerShellCommands.BaseCommand.StopProcessing">
-            <summary>
-            Aborts the processing of the command.
-            </summary>
-        </member>
-        <member name="E:Gallio.PowerShellCommands.BaseCommand.StopRequested">
-            <summary>
-            The event dispatches when the command is asynchronously being stopped
-            via <see cref="M:Gallio.PowerShellCommands.BaseCommand.StopProcessing"/>.
-            </summary>
-        </member>
-        <member name="P:Gallio.PowerShellCommands.BaseCommand.Logger">
-            <summary>
-            Gets the logger for the cmdlet.
-            </summary>
-        </member>
-        <member name="P:Gallio.PowerShellCommands.BaseCommand.NoProgress">
-            <summary>
-            Sets whether progress information is shown during the execution. If this option is specified,
-            the execution is silent and no progress information is displayed.
-            </summary>
-            <remarks>
-            <list type="bullet">
-            <item>This parameter takes the value true if present and false if not. No
-            value has to be specified.</item>
-            </list>
-            </remarks>
-            <example>
-            <code>
-            # Shows progress information
-            Run-Gallio SomeAssembly.dll
-            # Hides progress information
-            Run-Gallio SomeAssembly.dll -np
-            </code>
-            </example>
-        </member>
-        <member name="P:Gallio.PowerShellCommands.BaseCommand.ProgressMonitorProvider">
-            <summary>
-            Gets the progress monitor provider for the cmdlet.
-            </summary>
-        </member>
-        <member name="T:Gallio.PowerShellCommands.CommandProgressMonitorPresenter">
-            <exclude />
-        </member>
-        <member name="T:Gallio.PowerShellCommands.CommandProgressMonitorProvider">
-            <exclude />
-        </member>
-        <member name="T:Gallio.PowerShellCommands.NamespaceDoc">
-            <summary>
-            The Gallio.PowerShellCommands namespace contains Powershell cmdlets for Gallio.
-            </summary>
-        </member>
-        <member name="T:Gallio.PowerShellCommands.RunGallioCommand">
-            <summary>
-            A PowerShell Cmdlet for running Gallio.
-            </summary>
-            <remarks>
-            Only the <see cref="P:Gallio.PowerShellCommands.RunGallioCommand.Files"/> parameter is required.
-            </remarks>
-            <example>
-            <para>There are severals ways to run this cmdlet:</para>
-            <code><![CDATA[
-            # Makes the Gallio commands available
-            Add-PSSnapIn Gallio
-            
-            # Runs a few assemblies and scripts.
-            Run-Gallio "[Path-to-assembly1]\TestAssembly1.dll","[Path-to-assembly2]\TestAssembly2.dll","[Path-to-test-script1]/TestScript1_spec.rb","[Path-to-test-script2]/TestScript2.xml" -f Category:UnitTests -rd C:\build\reports -rf html -ra zip
-            ]]></code>
-            </example>
-        </member>
-        <member name="M:Gallio.PowerShellCommands.RunGallioCommand.#ctor">
-            <summary>
-            Default constructor.
-            </summary>
-        </member>
-        <member name="M:Gallio.PowerShellCommands.RunGallioCommand.EndProcessing">
-            <exclude />
-        </member>
-        <member name="M:Gallio.PowerShellCommands.RunGallioCommand.RunLauncher(Gallio.Runner.TestLauncher)">
-            <exclude />
-            <summary>
-            Provided so that the unit tests can override test execution behavior.
-            </summary>
-        </member>
-        <member name="P:Gallio.PowerShellCommands.RunGallioCommand.Files">
-             <summary>
-             The list of relative or absolute paths of test files, projects and assemblies to execute.
-             Wildcards may be used.  This is required.
-             </summary>
-             <example>
-             <para>There are severals ways to pass the test files to the cmdlet:</para>
-             <code><![CDATA[
-             # Runs TestAssembly1.dll
-             Run-Gallio "[Path-to-assembly1]\TestAssembly1.dll"
-             
-             # Runs TestAssembly1.dll and TestAssembly2.dll
-             Run-Gallio "[Path-to-assembly1]\TestAssembly1.dll","[Path-to-assembly2]\TestAssembly2.dll"
-             
-             # Runs TestAssembly1.dll and TestAssembly2.dll
-             $assemblies = "[Path-to-assembly1]\TestAssembly1.dll","[Path-to-assembly2]\TestAssembly2.dll"
-             Run-Gallio $assemblies
-             
-             # Runs TestAssembly1.dll, TestAssembly2.dll, TestScript1_spec.rb, and TestScript2.xml
-             $assembly1 = "[Path-to-assembly1]\TestAssembly1.dll"
-             $assembly2 = "[Path-to-assembly2]\TestAssembly2.dll"
-             $script1 = "[Path-to-test-script1]\TestScript1_spec.rb"
-             $script2 = "[Path-to-test-script2]/TestScript2.xml"
-             $files = $assembly1,$assembly2,$script1,$script2
-             Run-Gallio $files
-             
-             # If you don't specify the test files, PowerShell will prompt you for the names:
-             PS C:\Documents and Settings\jhi> Run-Gallio
-            
-             cmdlet Run-Gallio at command pipeline position
-             Supply values for the following parameters:
-             Files[0]:
-             ]]></code>
-             </example>
-        </member>
-        <member name="P:Gallio.PowerShellCommands.RunGallioCommand.HintDirectories">
-            <summary>
-            The list of directories used for loading referenced assemblies and other dependent resources.
-            </summary>
-            <example>
-            <para>The following example shows how to specify the hint directories:</para>
-            <code><![CDATA[
-            Run-Gallio SomeAssembly.dll -hd C:\SomeFolder
-            ]]></code>
-            <para>See the <see cref="P:Gallio.PowerShellCommands.RunGallioCommand.Files"/> property for more ways of passing list of parameters to the cmdlet.</para>
-            </example>
-        </member>
-        <member name="P:Gallio.PowerShellCommands.RunGallioCommand.PluginDirectories">
-            <summary>
-            Additional Gallio plugin directories to search recursively.
-            </summary>
-            <example>
-            <para>The following example shows how to specify the plugin directories:</para>
-            <code><![CDATA[
-            Run-Gallio SomeAssembly.dll -pd C:\SomeFolder
-            ]]></code>
-            <para>See the <see cref="P:Gallio.PowerShellCommands.RunGallioCommand.Files"/> property for more ways of passing list of parameters to
-            the cmdlet.</para>
-            </example>
-        </member>
-        <member name="P:Gallio.PowerShellCommands.RunGallioCommand.ApplicationBaseDirectory">
-            <summary>
-            Gets or sets the relative or absolute path of the application base directory,
-            or null to use a default value selected by the consumer.
-            </summary>
-            <remarks>
-            <para>
-            If relative, the path is based on the current working directory,
-            so a value of "" causes the current working directory to be used.
-            </para>
-            <para>
-            The default is null.
-            </para>
-            </remarks>
-        </member>
-        <member name="P:Gallio.PowerShellCommands.RunGallioCommand.WorkingDirectory">
-            <summary>
-            Gets or sets the relative or absolute path of the working directory
-            or null to use a default value selected by the consumer.
-            </summary>
-            <remarks>
-            <para>
-            If relative, the path is based on the current working directory,
-            so a value of "" causes the current working directory to be used.
-            </para>
-            <para>
-            The default is null.
-            </para>
-            </remarks>
-        </member>
-        <member name="P:Gallio.PowerShellCommands.RunGallioCommand.ShadowCopy">
-            <summary>
-            Enables shadow copying when set to true.
-            </summary>
-            <remarks>
-            <para>
-            Shadow copying allows the original assemblies to be modified while the tests are running.
-            However, shadow copying may occasionally cause some tests to fail if they depend on their original location.
-            </para>
-            <para>
-            The default is false.
-            </para>
-            </remarks>
-        </member>
-        <member name="P:Gallio.PowerShellCommands.RunGallioCommand.DebugTests">
-            <summary>
-            Attaches the debugger to the test process when set to true.
-            </summary>
-            <remarks>
-            <para>
-            The default is false.
-            </para>
-            </remarks>
-        </member>
-        <member name="P:Gallio.PowerShellCommands.RunGallioCommand.RuntimeVersion">
-            <summary>
-            Gets or sets the version of the .Net runtime to use for running tests.
-            </summary>
-            <remarks>
-            <para>
-            For the CLR, this must be the name of one of the framework directories in <c>%SystemRoot%\Microsoft.Net\Framework.</c>  eg. 'v2.0.50727'.
-            </para>
-            <para>
-            The default is null which uses the most recent installed and supported framework.
-            </para>
-            </remarks>
-        </member>
-        <member name="P:Gallio.PowerShellCommands.RunGallioCommand.ReportTypes">
-            <summary>
-            A list of the types of reports to generate, separated by semicolons. 
-            </summary>
-            <remarks>
-            <list type="bullet">
-            <item>The types supported "out of the box" are: Html, Html-Inline, Text, XHtml,
-            XHtml-Inline, Xml, and Xml-Inline, but more types could be available as plugins.</item>
-            <item>The report types are not case sensitives.</item>
-            </list>
-            </remarks>
-            <example>
-            <para>In the following example reports will be generated in both HTML and XML format:</para>
-            <code><![CDATA[
-            Run-Gallio SomeAssembly.dll -rt "html","text"
-            ]]></code>
-            <para>See the <see cref="P:Gallio.PowerShellCommands.RunGallioCommand.Files"/> property for more ways of passing list of parameters to
-            the cmdlet.</para>
-            </example>
-        </member>
-        <member name="P:Gallio.PowerShellCommands.RunGallioCommand.ReportNameFormat">
-            <summary>
-            Sets the format string to use to generate the reports filenames.
-            </summary>
-            <remarks>
-            <para>
-            Any occurence of {0} will be replaced by the date, and any occurrence of {1} by the time.
-            </para>
-            <para>
-            The default format string is <c>test-report-{0}-{1}</c>.
-            </para>
-            </remarks>
-        </member>
-        <member name="P:Gallio.PowerShellCommands.RunGallioCommand.ReportDirectory">
-            <summary>
-            Sets the name of the directory where the reports will be put.
-            </summary>
-            <remarks>
-            <para>
-            The directory will be created if it doesn't exist. Existing files will be overwritten.
-            The default report directory is "Reports".
-            </para>
-            </remarks>
-        </member>
-        <member name="P:Gallio.PowerShellCommands.RunGallioCommand.ReportArchive">
-            <summary>
-            Specifies to enclose the resulting reports into a compressed archive file (zip).
-            </summary>
-        </member>
-        <member name="P:Gallio.PowerShellCommands.RunGallioCommand.Filter">
-            <summary>
-            <para>
-      Sets the filter set to apply, which consists of a sequence of one or more inclusion
-      or exclusion filter rules prefixed using 'include' (optional) or 'exclude'.
-    </para>
-            </summary>
-            <remarks>
-            <para>
-      A filter rule consists of zero or more filter expressions
-      that may be combined using 'and', 'or', and 'not' and grouped with
-      parentheses.  A filter expression consists of a filter key followed by one or
-      more comma-delimited matching values in the form 'key: value, "quoted value",
-      /regular expression/'.
-    </para><para>
-      The filter grammar is defined as follows:
-    </para><para>
-      <code><![CDATA[
-     INCLUDE          ::= "include"              # Not case-sensitive
-     EXCLUDE          ::= "exclude"              # Not case-sensitive
-	
-     OR               ::= "or"                   # Not case-sensitive
-     AND              ::= "and"                  # Not case-sensitive
-     NOT              ::= "not"                  # Not case-sensitive
-
-     <unquotedWord>   ::= [^:,*()/\"']+
-    
-     <quotedWord>     ::= '"' .* '"'             # String delimited by double quotation marks
-                      | "'" .* "'"               # String delimited by single quotation marks
-               
-     <word>           ::= <unquotedWord>
-                      | <quotedWord>
-                      
-     <regexWord>      ::= "/" .* "/"             # Regular expression
-                      | "/" .* "/i"              # Case-insensitive regular expression
-                      
-     <key>            ::= <word>
-    
-     <value>          ::= <word>                 # Value specified by exact string
-                      | <regexWord>              # Value specified by regular expression
-    
-     <matchSequence>  ::= <value> (',' <value>)* # One or more comma-separated values
-    
-     <filterExpr>     ::= "*"                    # "Any"
-                      | <key> ":" matchSeq>
-                      | <filterExpr> OR filterExpr>   # Combine filter expressions with OR
-                      | <filterExpr> AND filterExpr>  # Combine filter expressions with AND
-                      | NOT <filterExpr>         # Negate filter expression
-                      | "(" <filterExpr> ")"     # Grouping filter expression
-		      
-     <filterRule>     ::= <filterExpr>           # Inclusion rule (default case)
-                      | INCLUDE <filterExpr>     # Inclusion rule
-                      | EXCLUDE <filterExpr>     # Exclusion rule
-
-     <filterSet>      ::= <filterRule>           # Filter set consists of at least one filter rule.
-                      | <filterRule> <filterSet> # But may be a sequence of rules.
-     ]]></code>
-    </para><list type="bullet">
-      <item>By default this property takes the value "*", which means the "Any" filter will be applied.</item>
-      <item>
-        The operator precedence is, from highest to lowest: NOT, AND, and OR. All these operators are
-        left-associative.
-      </item>
-      <item>
-        The commas used to separate the values are interpreted as OR operators, so "Type:Fixture1,Fixture2"
-        is equivalent to "Type:Fixture1 or Type:Fixture2".
-      </item>
-      <item>
-        White-space is ignored outside quoted strings, so "Type:Fixture1|Type:Fixture2" is equivalent
-        to "Type : Fixture1 | Type : Fixture2".
-      </item>
-      <item>
-        Commas, colons, slashes, backslashes and quotation marks can be escaped with a backslash. For
-        example, \' will be interpreted as '. Using a single backslash in front of any other character
-        is invalid.
-      </item>
-      <item>
-        Currently the following filter keys are recognized:
-        <list type="bullet">
-          <item>Id: Filter by id.</item>
-          <item>Name: Filter by name.</item>
-          <item>Assembly: Filter by assembly name.</item>
-          <item>Namespace: Filter by namespace name.</item>
-          <item>Type: Filter by type name, including inherited types.</item>
-          <item>ExactType: Filter by type name, excluding inherited types.</item>
-          <item>Member: Filter by member name.</item>
-          <item>
-            *: All other names are assumed to correspond to metadata keys. See <see cref="T:Gallio.Model.MetadataKeys"/> for standard metadata keys.  Common keys are: AuthorName, Category, Description, Importance, TestsOn.  <seealso cref="T:Gallio.Model.MetadataKeys"/>
-          </item>
-        </list>
-      </item>      
-    </list>
-            </remarks>
-            <example>
-            <para>
-      Assuming the following fixtures have been defined:
-    </para><code><![CDATA[
-      [TestFixture]
-      [Category("UnitTest")]
-      [Author("AlbertEinstein")]
-      public class Fixture1
-      {
-        [Test]
-        public void Test1()
-        {
-        }
-        [Test]
-        public void Test2()
-        {
-        }
-      }
-
-      [TestFixture]
-      [Category("IntegrationTest")]
-      public class Fixture2
-      {
-        [Test]
-        public void Test1()
-        {
-        }
-        [Test]
-        public void Test2()
-        {
-        }
-      }
-    ]]></code><para>The following filters could be applied:</para><list type="bullet">
-      <item>
-        <term>Type: Fixture1</term>
-        <description>All the tests within Fixture1 will be run.</description>
-      </item>
-
-      <item>
-        <term>Member: Test1</term>
-        <description>Only Fixture1.Test1 and Fixture2.Test1 will be run.</description>
-      </item>
-
-      <item>
-        <term>Type: Fixture1, Fixture2</term>
-        <description>All the tests within Fixture1 or Fixture2 will be run.</description>
-      </item>
-
-      <item>
-        <term>Type:Fixture1 or Type:Fixture2</term>
-        <description>All the tests within Fixture1 or Fixture2 will be run.</description>
-      </item>
-
-      <item>
-        <term>Type:Fixture1, Fixture2 and Member:Test2</term>
-        <description>Only Fixture1.Test2 and Fixture2.Test2 will be run.</description>
-      </item>
-
-      <item>
-        <term>Type:/Fixture*/ and Member:Test2</term>
-        <description>Only Fixture1.Test2 and Fixture2.Test2 will be run.</description>
-      </item>
-
-      <item>
-        <term>AuthorName:AlbertEinstein</term>
-        <description>All the tests within Fixture1 will be run because its author attribute is set to "AlbertEinstein".</description>
-      </item>
-
-      <item>
-        <term>Category: IntegrationTest</term>
-        <description>All the tests within Fixture2 will be run because its category attribute is set to "IntegrationTest".</description>
-      </item>
-
-      <item>
-        <term>("Type": 'Fixture1' and "Member":/Test*/) or (Type : Fixture2 and Member: /Test*/)</term>
-        <description>All the tests will be run. This example also shows that you can enclose key and
-        values with quotation marks, and group expressions with parentheses.</description>
-      </item>
-
-      <item>
-        <term>exclude AuthorName: AlbertEinstein</term>
-        <description>All the tests within Fixture2 will be run because its author attribute is not set to "AlbertEinstein".</description>
-      </item>
-      
-      <item>
-        <term>exclude Type: Fixture2 include Member: Test2</term>
-        <description>Only Fixture1.Test2 will be run because Fixture2 was excluded from consideration before the inclusion rule was applied.</description>
-      </item>
-    </list>
-            </example>
-        </member>
-        <member name="P:Gallio.PowerShellCommands.RunGallioCommand.ShowReports">
-            <summary>
-            Sets whether to open the generated reports once execution has finished.
-            </summary>
-            <remarks>
-            <list type="bullet">
-            <item>This parameter takes the value true if present and false if not. No
-            value has to be specified.</item>
-            <item>
-            The reports are opened in a window using the default system application
-            registered to the report file type.
-            </item>
-            </list>
-            </remarks>
-            <example>
-            <code><![CDATA[
-            # Doesn't show the reports once execution has finished
-            Run-Gallio SomeAssembly.dll
-            
-            # Shows the reports once execution has finished
-            Run-Gallio SomeAssembly.dll -sr
-            ]]></code>
-            </example>
-        </member>
-        <member name="P:Gallio.PowerShellCommands.RunGallioCommand.RunnerType">
-            <summary>
-            Sets the type of test runner to use.
-            </summary>
-            <remarks>
-            <list type="bullet">
-            <item>The types supported "out of the box" are: <c>Local</c>, <c>IsolatedAppDomain</c>
-            and <c>IsolatedProcess</c> (default), but more types could be available as plugins.</item>
-            <item>The runner types are not case sensitive.</item>
-            </list>
-            </remarks>
-        </member>
-        <member name="P:Gallio.PowerShellCommands.RunGallioCommand.RunnerExtensions">
-            <summary>
-            Specifies the type, assembly, and parameters of custom test runner
-            extensions to use during the test run.
-            </summary>
-            <remarks>
-            <para>
-            The value must be in the form <c>'[Namespace.]Type,Assembly[;Parameters]'</c> .
-            </para>
-            </remarks>
-            <example>
-            The following example runs tests using a custom logger extension:
-            <code><![CDATA[
-            Run-Gallio SomeAssembly.dll -runner-extension 'FancyLogger,MyExtensions.dll;ColorOutput,FancyIndenting'
-            ]]></code>
-            </example>
-        </member>
-        <member name="P:Gallio.PowerShellCommands.RunGallioCommand.RunnerProperties">
-            <summary>
-            Specifies option property key/value pairs for the test runner.
-            </summary>
-            <example>
-            The following example specifies some extra NCover arguments.
-            <code><![CDATA[
-            Run-Gallio SomeAssembly.dll -runner-property "NCoverArguments='//eas Gallio'"
-            ]]></code>
-            </example>
-        </member>
-        <member name="P:Gallio.PowerShellCommands.RunGallioCommand.ReportFormatterProperties">
-            <summary>
-            Specifies option property key/value pairs for the report formatter.
-            </summary>
-            <example>
-            The following example changes the default attachment content disposition for the reports.
-            <code><![CDATA[
-            Run-Gallio SomeAssembly.dll -report-formatter-property "AttachmentContentDisposition=Absent"
-            ]]></code>
-            </example>
-        </member>
-        <member name="P:Gallio.PowerShellCommands.RunGallioCommand.DoNotRun">
-            <summary>
-            Sets whether to load the tests but not run them.  
-            </summary>
-            <remarks>
-            <para>
-            This option may be used to produce a report that contains test metadata for consumption by other tools.
-            </para>
-            </remarks>
-        </member>
-        <member name="P:Gallio.PowerShellCommands.RunGallioCommand.IgnoreAnnotations">
-            <summary>
-            Sets whether to ignore annotations when determining the result code.
-            </summary>
-            <remarks>
-            <para>
-            If false (default), then error annotations, usually indicative of broken tests, will cause
-            a failure result to be generated.
-            </para>
-            </remarks>
-        </member>
-        <member name="P:Gallio.PowerShellCommands.RunGallioCommand.NoEchoResults">
-            <summary>
-            Sets whether to echo results to the screen as tests finish.  
-            </summary>
-            <remarks>
-            <para>
-            If this option is specified only the final summary statistics are displayed.  Otherwise test results are echoed to the
-            console in varying detail depending on the current verbosity level.
-            </para>
-            </remarks>
-        </member>
-        <member name="P:Gallio.PowerShellCommands.RunGallioCommand.RunTimeLimit">
-            <summary>
-            Sets the maximum amount of time (in seconds) the tests can run 
-            before they are canceled. The default is an infinite time to run. 
-            </summary>
-        </member>
-        <member name="T:Gallio.PowerShellCommands.GallioSnapIn">
-            <exclude />
-            <summary>
-            A PowerShell SnapIn that registers the Gallio Cmdlets.
-            </summary>
-        </member>
-        <member name="P:Gallio.PowerShellCommands.GallioSnapIn.Description">
-            <summary>
-            Gets the description of the snap-in.
-            </summary>
-        </member>
-        <member name="P:Gallio.PowerShellCommands.GallioSnapIn.Name">
-            <summary>
-            Gets the name of the snap-in.
-            </summary>
-        </member>
-        <member name="P:Gallio.PowerShellCommands.GallioSnapIn.Vendor">
-            <summary>
-            Gets the vendor of the snap-in.
-            </summary>
-        </member>
-        <member name="T:Gallio.PowerShellCommands.CommandLogger">
-            <exclude/>
-            <summary>
-            Logs messages using a <see cref="T:Gallio.PowerShellCommands.BaseCommand"/>'s logging functions.
-            </summary>
-        </member>
-        <member name="M:Gallio.PowerShellCommands.CommandLogger.#ctor(Gallio.PowerShellCommands.BaseCommand)">
-            <summary>
-            Initializes a new instance of the <see cref="T:Gallio.PowerShellCommands.CommandLogger"/> class.
-            </summary>
-            <param name="cmdlet">The <see cref="T:System.Management.Automation.Cmdlet"/> instance to channel
-            log messages to.</param>
-        </member>
-        <member name="M:Gallio.PowerShellCommands.CommandLogger.LogImpl(Gallio.Runtime.Logging.LogSeverity,System.String,Gallio.Common.Diagnostics.ExceptionData)">
-            <summary>
-            Logs a message.
-            </summary>
-            <param name="severity">The log message severity.</param>
-            <param name="message">The message to log.</param>
-            <param name="exceptionData">The exception to log (it can be null).</param>
-        </member>
-        <member name="T:Gallio.PowerShellCommands.Properties.Resources">
-            <summary>
-              A strongly-typed resource class, for looking up localized strings, etc.
-            </summary>
-        </member>
-        <member name="P:Gallio.PowerShellCommands.Properties.Resources.ResourceManager">
-            <summary>
-              Returns the cached ResourceManager instance used by this class.
-            </summary>
-        </member>
-        <member name="P:Gallio.PowerShellCommands.Properties.Resources.Culture">
-            <summary>
-              Overrides the current thread's CurrentUICulture property for all
-              resource lookups using this strongly typed resource class.
-            </summary>
-        </member>
-        <member name="P:Gallio.PowerShellCommands.Properties.Resources.CmdletNameAndVersion">
-            <summary>
-              Looks up a localized string similar to Gallio PowerShell Cmdlet - Version {0}.{1} build {2}.
-            </summary>
-        </member>
-        <member name="P:Gallio.PowerShellCommands.Properties.Resources.DefaultReportNameFormat">
-            <summary>
-              Looks up a localized string similar to test-report-{0}-{1}.
-            </summary>
-        </member>
-        <member name="P:Gallio.PowerShellCommands.Properties.Resources.UnexpectedErrorDuringExecution">
-            <summary>
-              Looks up a localized string similar to An unexpected error occurred during execution of the Gallio task..
-            </summary>
-        </member>
-    </members>
-</doc>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Gallio.Reports.dll
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Gallio.Reports.dll b/lib/Gallio.3.2.750/tools/Gallio.Reports.dll
deleted file mode 100644
index ebc028b..0000000
Binary files a/lib/Gallio.3.2.750/tools/Gallio.Reports.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Gallio.Reports.plugin
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Gallio.Reports.plugin b/lib/Gallio.3.2.750/tools/Gallio.Reports.plugin
deleted file mode 100644
index 309483e..0000000
--- a/lib/Gallio.3.2.750/tools/Gallio.Reports.plugin
+++ /dev/null
@@ -1,241 +0,0 @@
-<?xml version="1.0" encoding="utf-8" ?>
-<plugin pluginId="Gallio.Reports"
-        recommendedInstallationPath=""
-        xmlns="http://www.gallio.org/">
-  <traits>
-    <name>Gallio Reports Library</name>
-    <version>3.2.0.0</version>
-    <description>Provides several common report formats including Xml, Html, XHtml, MHtml and Text.</description>
-    <icon>plugin://Gallio/Resources/Gallio.ico</icon>
-  </traits>
-
-  <dependencies>
-    <dependency pluginId="Gallio" />
-  </dependencies>
-
-  <files>
-    <file path="Gallio.Reports.plugin" />
-    <file path="Gallio.Reports.dll" />
-    <file path="Gallio.Reports.xml" />
-    <file path="Resources\css\Gallio-Report.css" />
-    <file path="Resources\img\Failed.gif" />
-    <file path="Resources\img\FullStop.gif" />
-    <file path="Resources\img\GallioTestReportHeader.png" />
-    <file path="Resources\img\header-background.gif" />
-    <file path="Resources\img\Ignored.gif" />
-    <file path="Resources\img\Minus.gif" />
-    <file path="Resources\img\Passed.gif" />
-    <file path="Resources\img\Plus.gif" />
-    <file path="Resources\img\UnknownTestKind.png" />
-    <file path="Resources\js\Gallio-Report.js" />
-    <file path="Resources\js\expressInstall.swf" />
-    <file path="Resources\js\player.swf" />
-    <file path="Resources\js\swfobject.js" />
-    <file path="Resources\xsl\Gallio-Report.ccnet-details-condensed.xsl" />
-    <file path="Resources\xsl\Gallio-Report.ccnet-details.xsl" />
-    <file path="Resources\xsl\Gallio-Report.common.xsl" />
-    <file path="Resources\xsl\Gallio-Report.html-condensed.xsl" />
-    <file path="Resources\xsl\Gallio-Report.html.xsl" />
-    <file path="Resources\xsl\Gallio-Report.html+xhtml.xsl" />
-    <file path="Resources\xsl\Gallio-Report.txt.xsl" />
-    <file path="Resources\xsl\Gallio-Report.txt-common.xsl" />
-    <file path="Resources\xsl\Gallio-Report.txt-condensed.xsl" />
-    <file path="Resources\xsl\Gallio-Report.xhtml-condensed.xsl" />
-    <file path="Resources\xsl\Gallio-Report.xhtml.xsl" />
-  </files>
-
-  <assemblies>
-    <assembly fullName="Gallio.Reports, Version=3.2.0.0, Culture=neutral, PublicKeyToken=eb9cfa67ee6ab36e"
-              codeBase="Gallio.Reports.dll"
-              qualifyPartialName="true" />
-  </assemblies>
-
-  <components>
-    <component componentId="ReportFormatter.Xml"
-               serviceId="Gallio.ReportFormatter"
-               componentType="Gallio.Reports.XmlReportFormatter, Gallio.Reports">
-      <parameters>
-        <defaultAttachmentContentDisposition>Link</defaultAttachmentContentDisposition>
-      </parameters>
-      <traits>
-        <name>Xml</name>
-        <description>
-          Generates XML reports with linked attachment files.
-
-          Supported report formatter properties:
-          - AttachmentContentDisposition: Specifies how attachments should be stored.  "Absent", "Link" or "Inline".  Default is "Link".
-        </description>
-      </traits>
-    </component>
-
-    <component componentId="ReportFormatter.Xml-Inline"
-               serviceId="Gallio.ReportFormatter"
-               componentType="Gallio.Reports.XmlReportFormatter, Gallio.Reports">
-      <parameters>
-        <defaultAttachmentContentDisposition>Inline</defaultAttachmentContentDisposition>
-      </parameters>
-      <traits>
-        <name>Xml-Inline</name>
-        <description>Generates XML reports with inline encoded attachments.</description>
-      </traits>
-    </component>
-
-    <component componentId="ReportFormatter.Text"
-               serviceId="Gallio.ReportFormatter"
-               componentType="Gallio.Reports.XsltReportFormatter, Gallio.Reports">
-      <parameters>
-        <extension>txt</extension>
-        <contentType>text/plain</contentType>
-        <defaultAttachmentContentDisposition>Absent</defaultAttachmentContentDisposition>
-        <resourceDirectory>plugin://Gallio.Reports/Resources/</resourceDirectory>
-        <xsltPath>xsl/Gallio-Report.txt.xsl</xsltPath>
-        <resourcePaths></resourcePaths>
-      </parameters>
-      <traits>
-        <name>Text</name>
-        <description>Generates plain text reports.</description>
-      </traits>
-    </component>
-
-    <component componentId="ReportFormatter.Text-Condensed"
-           serviceId="Gallio.ReportFormatter"
-           componentType="Gallio.Reports.XsltReportFormatter, Gallio.Reports">
-      <parameters>
-        <extension>txt</extension>
-        <contentType>text/plain</contentType>
-        <defaultAttachmentContentDisposition>Absent</defaultAttachmentContentDisposition>
-        <resourceDirectory>plugin://Gallio.Reports/Resources/</resourceDirectory>
-        <xsltPath>xsl/Gallio-Report.txt-condensed.xsl</xsltPath>
-        <resourcePaths></resourcePaths>
-      </parameters>
-      <traits>
-        <name>Text-Condensed</name>
-        <description>Generates plain text reports without passing tests.</description>
-      </traits>
-    </component>
-    
-    <component componentId="ReportFormatter.Html"
-               serviceId="Gallio.ReportFormatter"
-               componentType="Gallio.Reports.XsltReportFormatter, Gallio.Reports">
-      <parameters>
-        <extension>html</extension>
-        <contentType>text/html</contentType>
-        <defaultAttachmentContentDisposition>Link</defaultAttachmentContentDisposition>
-        <resourceDirectory>plugin://Gallio.Reports/Resources/</resourceDirectory>
-        <xsltPath>xsl/Gallio-Report.html.xsl</xsltPath>
-        <resourcePaths>css;js;img</resourcePaths>
-      </parameters>
-      <traits>
-        <name>Html</name>
-        <description>
-          Generates HTML reports.
-
-          Supported report formatter properties:
-          - AttachmentContentDisposition: Specifies how attachments should be stored.  "Absent", "Link" or "Inline".  Default is "Link".
-        </description>
-      </traits>
-    </component>
-
-    <component componentId="ReportFormatter.Html-Condensed"
-               serviceId="Gallio.ReportFormatter"
-               componentType="Gallio.Reports.XsltReportFormatter, Gallio.Reports">
-      <parameters>
-        <extension>html</extension>
-        <contentType>text/html</contentType>
-        <defaultAttachmentContentDisposition>Link</defaultAttachmentContentDisposition>
-        <resourceDirectory>plugin://Gallio.Reports/Resources/</resourceDirectory>
-        <xsltPath>xsl/Gallio-Report.html-condensed.xsl</xsltPath>
-        <resourcePaths>css;js;img</resourcePaths>
-      </parameters>
-      <traits>
-        <name>Html-Condensed</name>
-        <description>
-          Generates HTML reports that omit passing tests.
-
-          Supported report formatter properties:
-          - AttachmentContentDisposition: Specifies how attachments should be stored.  "Absent", "Link" or "Inline".  Default is "Link".
-        </description>
-      </traits>
-    </component>
-
-    <component componentId="ReportFormatter.XHtml"
-               serviceId="Gallio.ReportFormatter"
-               componentType="Gallio.Reports.XsltReportFormatter, Gallio.Reports">
-      <parameters>
-        <extension>xhtml</extension>
-        <contentType>text/xhtml+xml</contentType>
-        <defaultAttachmentContentDisposition>Link</defaultAttachmentContentDisposition>
-        <resourceDirectory>plugin://Gallio.Reports/Resources/</resourceDirectory>
-        <xsltPath>xsl/Gallio-Report.xhtml.xsl</xsltPath>
-        <resourcePaths>css;js;img</resourcePaths>
-      </parameters>
-      <traits>
-        <name>XHtml</name>
-        <description>
-          Generates XHTML reports.
-
-          Supported report formatter properties:
-          - AttachmentContentDisposition: Specifies how attachments should be stored.  "Absent", "Link" or "Inline".  Default is "Link".
-        </description>
-      </traits>
-    </component>
-
-    <component componentId="ReportFormatter.XHtml-Condensed"
-               serviceId="Gallio.ReportFormatter"
-               componentType="Gallio.Reports.XsltReportFormatter, Gallio.Reports">
-      <parameters>
-        <extension>xhtml</extension>
-        <contentType>text/xhtml+xml</contentType>
-        <defaultAttachmentContentDisposition>Link</defaultAttachmentContentDisposition>
-        <resourceDirectory>plugin://Gallio.Reports/Resources/</resourceDirectory>
-        <xsltPath>xsl/Gallio-Report.xhtml-condensed.xsl</xsltPath>
-        <resourcePaths>css;js;img</resourcePaths>
-      </parameters>
-      <traits>
-        <name>XHtml-Condensed</name>
-        <description>
-          Generates XHTML reports that omit passing tests.
-
-          Supported report formatter properties:
-          - AttachmentContentDisposition: Specifies how attachments should be stored.  "Absent", "Link" or "Inline".  Default is "Link".
-        </description>
-      </traits>
-    </component>
-
-    <component componentId="ReportFormatter.MHtml"
-               serviceId="Gallio.ReportFormatter"
-               componentType="Gallio.Reports.MHtmlReportFormatter, Gallio.Reports">
-      <parameters>
-        <htmlReportFormatter>${ReportFormatter.Html}</htmlReportFormatter>
-      </parameters>
-      <traits>
-        <name>MHtml</name>
-        <description>Generates MHTML reports.</description>
-      </traits>
-    </component>
-
-    <component componentId="ReportFormatter.MHtml-Condensed"
-               serviceId="Gallio.ReportFormatter"
-               componentType="Gallio.Reports.MHtmlReportFormatter, Gallio.Reports">
-      <parameters>
-        <htmlReportFormatter>${ReportFormatter.Html-Condensed}</htmlReportFormatter>
-      </parameters>
-      <traits>
-        <name>MHtml-Condensed</name>
-        <description>Generates MHTML reports that omit passing tests.</description>
-      </traits>
-    </component>
-
-    <component componentId="Gallio.Reports.Installer"
-               serviceId="Gallio.Installer"
-               componentType="Gallio.Reports.ReportResourcesInstaller, Gallio.Reports">
-      <parameters>
-        <testKindImageDir>plugin://Gallio.Reports/Resources/img/testkinds/</testKindImageDir>
-        <generatedCssFile>plugin://Gallio.Reports/Resources/css/Gallio-Report.Generated.css</generatedCssFile>
-      </parameters>
-      <traits>
-        <requiresElevation>true</requiresElevation>
-      </traits>
-    </component>
-  </components>
-</plugin>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Gallio.Reports.xml
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Gallio.Reports.xml b/lib/Gallio.3.2.750/tools/Gallio.Reports.xml
deleted file mode 100644
index 5280155..0000000
--- a/lib/Gallio.3.2.750/tools/Gallio.Reports.xml
+++ /dev/null
@@ -1,229 +0,0 @@
-<?xml version="1.0"?>
-<doc>
-    <assembly>
-        <name>Gallio.Reports</name>
-    </assembly>
-    <members>
-        <member name="T:Gallio.Reports.BaseReportFormatter">
-            <summary>
-            Abstract base class for report formatters.
-            </summary>
-        </member>
-        <member name="F:Gallio.Reports.BaseReportFormatter.AttachmentContentDispositionOption">
-            <summary>
-            Gets the name of the option that how attachments are saved.
-            </summary>
-        </member>
-        <member name="M:Gallio.Reports.BaseReportFormatter.#ctor">
-            <summary>
-            Creates a report formatter.
-            </summary>
-        </member>
-        <member name="M:Gallio.Reports.BaseReportFormatter.GetAttachmentContentDisposition(Gallio.Runner.Reports.ReportFormatterOptions)">
-            <summary>
-            Gets the attachment content disposition.
-            </summary>
-            <param name="options">The formatter options.</param>
-            <returns>The attachment content disposition.</returns>
-        </member>
-        <member name="M:Gallio.Reports.BaseReportFormatter.Format(Gallio.Runner.Reports.IReportWriter,Gallio.Runner.Reports.ReportFormatterOptions,Gallio.Runtime.ProgressMonitoring.IProgressMonitor)">
-            <inheritdoc />
-        </member>
-        <member name="P:Gallio.Reports.BaseReportFormatter.DefaultAttachmentContentDisposition">
-            <summary>
-            Gets or sets the default attachment content disposition.
-            Defaults to <see cref="F:Gallio.Common.Markup.AttachmentContentDisposition.Absent"/>.
-            </summary>
-        </member>
-        <member name="T:Gallio.Reports.MHtmlReportFormatter">
-            <summary>
-            <para>
-            Formats MIME HTML archive reports similar to the web archives generated by Internet Explorer.
-            The report can then be sent to recipients as a single file.
-            </para>
-            <para>
-            Unfortunately the format is non-standard and cannot be read by most other browsers.
-            </para>
-            </summary>
-        </member>
-        <member name="M:Gallio.Reports.MHtmlReportFormatter.#ctor(Gallio.Runner.Reports.IReportFormatter)">
-            <summary>
-            Creates a report formatter.
-            </summary>
-            <param name="htmlReportFormatter">The HTML report formatter.</param>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="htmlReportFormatter"/> is null.</exception>
-        </member>
-        <member name="M:Gallio.Reports.MHtmlReportFormatter.Format(Gallio.Runner.Reports.IReportWriter,Gallio.Runner.Reports.ReportFormatterOptions,Gallio.Runtime.ProgressMonitoring.IProgressMonitor)">
-            <inheritdoc />
-        </member>
-        <member name="T:Gallio.Reports.MultipartMimeReportContainer">
-            <summary>
-            A report container that saves a report as a multipart mime archive in a single file
-            within another container.
-            </summary>
-            <remarks>
-            This is currently specialized for saving HTML reports.
-            It does not support loading reports.
-            </remarks>
-        </member>
-        <member name="M:Gallio.Reports.MultipartMimeReportContainer.#ctor(Gallio.Runner.Reports.IReportContainer)">
-            <summary>
-            Creates the multipart mime report container.
-            </summary>
-            <param name="inner">The container to which the archived report should be saved.</param>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="inner"/> is null.</exception>
-        </member>
-        <member name="M:Gallio.Reports.MultipartMimeReportContainer.OpenArchive(System.String)">
-            <summary>
-            Opens the archive within the inner container.
-            </summary>
-            <param name="archivePath">The path of the archive to create.</param>
-            <exception cref="T:System.ArgumentNullException">Thrown if <paramref name="archivePath"/> is null.</exception>
-            <exception cref="T:System.InvalidOperationException">Thrown if the archive has already been opened.</exception>
-        </member>
-        <member name="M:Gallio.Reports.MultipartMimeReportContainer.CloseArchive">
-            <summary>
-            Finishes writing out the MIME archive and closes it.
-            Does nothing if the archive is not open.
-            </summary>
-        </member>
-        <member name="P:Gallio.Reports.MultipartMimeReportContainer.ReportName">
-            <inheritdoc />
-        </member>
-        <member name="T:Gallio.Reports.NamespaceDoc">
-            <summary>
-            The Gallio.Reports namespace provides report formatters for common Gallio test report types.
-            </summary>
-        </member>
-        <member name="T:Gallio.Reports.Properties.Resources">
-            <summary>
-              A strongly-typed resource class, for looking up localized strings, etc.
-            </summary>
-        </member>
-        <member name="P:Gallio.Reports.Properties.Resources.ResourceManager">
-            <summary>
-              Returns the cached ResourceManager instance used by this class.
-            </summary>
-        </member>
-        <member name="P:Gallio.Reports.Properties.Resources.Culture">
-            <summary>
-              Overrides the current thread's CurrentUICulture property for all
-              resource lookups using this strongly typed resource class.
-            </summary>
-        </member>
-        <member name="T:Gallio.Reports.ReportResourcesInstaller">
-            <summary>
-            Installs derived resources for reports such as test framework icons.
-            </summary>
-        </member>
-        <member name="M:Gallio.Reports.ReportResourcesInstaller.#ctor(Gallio.Model.ITestKindManager,System.IO.DirectoryInfo,System.IO.FileInfo)">
-            <summary>
-            Initializes the installer.
-            </summary>
-            <param name="testKindManager">The test kind manager, not null.</param>
-            <param name="testKindImageDir">The test kind image directory, not null.</param>
-            <param name="generatedCssFile">The generated CSS file, not null.</param>
-        </member>
-        <member name="M:Gallio.Reports.ReportResourcesInstaller.Install(Gallio.Runtime.ProgressMonitoring.IProgressMonitor)">
-            <inheritdoc />
-        </member>
-        <member name="T:Gallio.Reports.XmlReportFormatter">
-            <summary>
-            Formats reports as Xml.
-            </summary>
-            <remarks>
-            <para>
-            Recognizes the following options:
-            <list type="bullet">
-            <listheader>
-            <term>Option</term>
-            <description>Description</description>
-            </listheader>
-            <item>
-            <term>AttachmentContentDisposition</term>
-            <description>Overrides the default attachment content disposition for the format.
-            The content disposition may be "Absent" to exclude attachments, "Link" to
-            include attachments by reference to external files, or "Inline" to include attachments as
-            inline content within the formatted document.  Different formats use different
-            default content dispositions.</description>
-            </item>
-            </list>
-            </para>
-            </remarks>
-        </member>
-        <member name="M:Gallio.Reports.XmlReportFormatter.#ctor">
-            <summary>
-            Creates an Xml report formatter.
-            </summary>
-        </member>
-        <member name="M:Gallio.Reports.XmlReportFormatter.Format(Gallio.Runner.Reports.IReportWriter,Gallio.Runner.Reports.ReportFormatterOptions,Gallio.Runtime.ProgressMonitoring.IProgressMonitor)">
-            <inheritdoc />
-        </member>
-        <member name="T:Gallio.Reports.XsltReportFormatter">
-            <summary>
-            <para>
-            Generic XSLT report formatter.
-            </para>
-            <para>
-            Recognizes the following options:
-            <list type="bullet">
-            <listheader>
-            <term>Option</term>
-            <description>Description</description>
-            </listheader>
-            <item>
-            <term>AttachmentContentDisposition</term>
-            <description>Overrides the default attachment content disposition for the format.
-            The content disposition may be "Absent" to exclude attachments, "Link" to
-            include attachments by reference to external files, or "Inline" to include attachments as
-            inline content within the formatted document.  Different formats use different
-            default content dispositions.</description>
-            </item>
-            </list>
-            </para>
-            </summary>
-        </member>
-        <member name="M:Gallio.Reports.XsltReportFormatter.#ctor(System.String,System.String,System.IO.DirectoryInfo,System.String,System.String[])">
-            <summary>
-            Creates an XSLT report formatter.
-            </summary>
-            <param name="extension">The preferred extension without a '.'</param>
-            <param name="contentType">The content type of the main report document.</param>
-            <param name="resourceDirectory">The resource directory.</param>
-            <param name="xsltPath">The path of the XSLT relative to the resource directory.</param>
-            <param name="resourcePaths">The paths of the resources (such as images or CSS) to copy
-            to the report directory relative to the resource directory.</param>
-            <exception cref="T:System.ArgumentNullException">Thrown if any arguments are null.</exception>
-        </member>
-        <member name="M:Gallio.Reports.XsltReportFormatter.Format(Gallio.Runner.Reports.IReportWriter,Gallio.Runner.Reports.ReportFormatterOptions,Gallio.Runtime.ProgressMonitoring.IProgressMonitor)">
-            <inheritdoc />
-        </member>
-        <member name="M:Gallio.Reports.XsltReportFormatter.ApplyTransform(Gallio.Runner.Reports.IReportWriter,Gallio.Common.Markup.AttachmentContentDisposition,Gallio.Runner.Reports.ReportFormatterOptions)">
-            <summary>
-            Applies the transform to produce a report.
-            </summary>
-        </member>
-        <member name="M:Gallio.Reports.XsltReportFormatter.CopyResources(Gallio.Runner.Reports.IReportWriter)">
-            <summary>
-            Copies additional resources to the content path within the report.
-            </summary>
-        </member>
-        <member name="M:Gallio.Reports.XsltReportFormatter.PopulateArguments(System.Xml.Xsl.XsltArgumentList,Gallio.Runner.Reports.ReportFormatterOptions,System.String)">
-            <summary>
-            Populates the arguments for the XSL template processing.
-            </summary>
-        </member>
-        <member name="M:Gallio.Reports.XsltReportFormatter.LoadTransform(System.String)">
-            <summary>
-            Loads the XSL transform.
-            </summary>
-            <param name="resolvedXsltPath">The full path of the XSLT.</param>
-            <returns>The transform.</returns>
-        </member>
-        <member name="P:Gallio.Reports.XsltReportFormatter.Transform">
-            <summary>
-            Gets the XSL transform.
-            </summary>
-        </member>
-    </members>
-</doc>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Gallio.UI.dll
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Gallio.UI.dll b/lib/Gallio.3.2.750/tools/Gallio.UI.dll
deleted file mode 100644
index 4f186ae..0000000
Binary files a/lib/Gallio.3.2.750/tools/Gallio.UI.dll and /dev/null differ

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/lib/Gallio.3.2.750/tools/Gallio.UI.plugin
----------------------------------------------------------------------
diff --git a/lib/Gallio.3.2.750/tools/Gallio.UI.plugin b/lib/Gallio.3.2.750/tools/Gallio.UI.plugin
deleted file mode 100644
index e266855..0000000
--- a/lib/Gallio.3.2.750/tools/Gallio.UI.plugin
+++ /dev/null
@@ -1,127 +0,0 @@
-<?xml version="1.0" encoding="utf-8" ?>
-<plugin pluginId="Gallio.UI"
-        recommendedInstallationPath=""
-        xmlns="http://www.gallio.org/">
-  <traits>
-    <name>Gallio UI Library</name>
-    <version>3.2.0.0</version>
-    <description>Gallio UI components.</description>
-    <icon>plugin://Gallio/Resources/Gallio.ico</icon>
-  </traits>
-
-  <dependencies>
-    <dependency pluginId="Gallio" />
-  </dependencies>
-
-  <files>
-    <file path="Gallio.UI.plugin" />
-    <file path="Gallio.UI.dll" />
-    <file path="Gallio.UI.xml" />
-    
-    <file path="Aga.Controls.dll" />
-    <file path="WeifenLuo.WinFormsUI.Docking.dll" />
-    
-    <file path="Gallio.Common.Splash.dll" />
-    <file path="Gallio.Common.Splash.xml" />
-  </files>
-
-  <assemblies>
-    <assembly fullName="Gallio.UI, Version=3.2.0.0, Culture=neutral, PublicKeyToken=eb9cfa67ee6ab36e"
-              codeBase="Gallio.UI.dll"
-              qualifyPartialName="true" />
-  </assemblies>
-
-  <services>
-    <service serviceId="Gallio.UI.ControlPanelPresenter"
-             serviceType="Gallio.UI.ControlPanel.IControlPanelPresenter, Gallio.UI" />
-
-    <service serviceId="Gallio.UI.ControlPanelTabProvider"
-             serviceType="Gallio.UI.ControlPanel.IControlPanelTabProvider, Gallio.UI" />
-
-    <service serviceId="Gallio.UI.PreferencePaneProvider"
-             serviceType="Gallio.UI.ControlPanel.Preferences.IPreferencePaneProvider, Gallio.UI"
-             defaultComponentType="Gallio.UI.ControlPanel.Preferences.PlaceholderPreferencePaneProvider, Gallio.UI"/>
-
-    <service serviceId="Gallio.UI.EventAggregator"
-         serviceType="Gallio.UI.Events.IEventAggregator, Gallio.UI" />
-
-    <service serviceId="Gallio.UI.TaskManager" 
-             serviceType="Gallio.UI.ProgressMonitoring.ITaskManager, Gallio.UI" />
-
-    <service serviceId="Gallio.UI.TaskQueue"
-         serviceType="Gallio.UI.ProgressMonitoring.ITaskQueue, Gallio.UI" />
-
-    <service serviceId="Gallio.UI.TaskRunner"
-         serviceType="Gallio.UI.ProgressMonitoring.ITaskRunner, Gallio.UI" />
-
-    <service serviceId="Gallio.UI.UnhandledExceptionPolicy"
-         serviceType="Gallio.UI.Common.Policies.IUnhandledExceptionPolicy, Gallio.UI" />
-  </services>
-
-  <components>
-    <component componentId="Gallio.UI.ControlPanelPresenter"
-               serviceId="Gallio.UI.ControlPanelPresenter"
-               componentType="Gallio.UI.ControlPanel.ControlPanelPresenter, Gallio.UI" />
-
-    <component componentId="Gallio.UI.PreferenceControlPanelTabProvider"
-               serviceId="Gallio.UI.ControlPanelTabProvider"
-               componentType="Gallio.UI.ControlPanel.Preferences.PreferenceControlPanelTabProvider, Gallio.UI">
-      <traits>
-        <name>Preferences</name>
-        <order>0</order>
-      </traits>
-    </component>
-
-    <component componentId="Gallio.UI.PluginControlPanelTabProvider"
-               serviceId="Gallio.UI.ControlPanelTabProvider"
-               componentType="Gallio.UI.ControlPanel.Plugins.PluginControlPanelTabProvider, Gallio.UI">
-      <traits>
-        <name>Plugins</name>
-        <order>100</order>
-      </traits>
-    </component>
-
-    <component componentId="Gallio.UI.PlaceholderPreferencePaneProvider"
-               serviceId="Gallio.UI.PreferencePaneProvider">
-      <traits>
-        <path>Gallio</path>
-        <order>-100</order>
-        <icon>plugin://Gallio/Resources/Gallio.ico</icon>
-      </traits>
-    </component>
-
-    <component componentId="Gallio.UI.RuntimePreferencePaneProvider"
-               serviceId="Gallio.UI.PreferencePaneProvider"
-               componentType="Gallio.UI.ControlPanel.Preferences.RuntimePreferencePaneProvider, Gallio.UI">
-      <traits>
-        <path>Gallio/Runtime</path>
-        <icon>plugin://Gallio/Resources/Gallio.ico</icon>
-        <scope>Machine</scope>
-      </traits>
-    </component>
-
-    <component componentId="Gallio.UI.RuntimePreferencePaneCommitterElevatedCommand"
-               serviceId="Gallio.ElevatedCommand"
-               componentType="Gallio.UI.ControlPanel.Preferences.RuntimePreferencePaneCommitterElevatedCommand, Gallio.UI" />
-
-    <component componentId="Gallio.UI.EventAggregator"
-           serviceId="Gallio.UI.EventAggregator"
-           componentType="Gallio.UI.Events.EventAggregator, Gallio.UI" />
-    
-    <component componentId="Gallio.UI.TaskManager" 
-               serviceId="Gallio.UI.TaskManager" 
-               componentType="Gallio.UI.ProgressMonitoring.TaskManager, Gallio.UI" />
-
-    <component componentId="Gallio.UI.TaskQueue"
-           serviceId="Gallio.UI.TaskQueue"
-           componentType="Gallio.UI.ProgressMonitoring.TaskQueue, Gallio.UI" />
-
-    <component componentId="Gallio.UI.TaskRunner"
-           serviceId="Gallio.UI.TaskRunner"
-           componentType="Gallio.UI.ProgressMonitoring.TaskRunner, Gallio.UI" />
-    
-    <component componentId="Gallio.UI.UnhandledExceptionPolicy" 
-               serviceId="Gallio.UI.UnhandledExceptionPolicy" 
-               componentType="Gallio.UI.Common.Policies.UnhandledExceptionPolicy, Gallio.UI" />
-  </components>
-</plugin>
\ No newline at end of file


[45/51] [abbrv] [partial] Cleaning up and getting ready to development towards v4.8

Posted by sy...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/vs2010/test/Contrib.All.Test.sln
----------------------------------------------------------------------
diff --git a/build/vs2010/test/Contrib.All.Test.sln b/build/vs2010/test/Contrib.All.Test.sln
deleted file mode 100644
index f9ce4a2..0000000
--- a/build/vs2010/test/Contrib.All.Test.sln
+++ /dev/null
@@ -1,306 +0,0 @@
-
-Microsoft Visual Studio Solution File, Format Version 11.00
-# Visual C# Express 2010
-#
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-#
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net", "..\..\..\src\core\Lucene.Net.csproj", "{5D4AD9BE-1FFB-41AB-9943-25737971BF57}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Core", "..\..\..\src\contrib\Core\Contrib.Core.csproj", "{FEF899EB-610C-4D3C-A556-A01F56F4AFE0}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Analyzers", "..\..\..\src\contrib\Analyzers\Contrib.Analyzers.csproj", "{4286E961-9143-4821-B46D-3D39D3736386}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.FastVectorHighlighter", "..\..\..\src\contrib\FastVectorHighlighter\Contrib.FastVectorHighlighter.csproj", "{9D2E3153-076F-49C5-B83D-FB2573536B5F}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Highlighter", "..\..\..\src\contrib\Highlighter\Contrib.Highlighter.csproj", "{901D5415-383C-4AA6-A256-879558841BEA}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Queries", "..\..\..\src\contrib\Queries\Contrib.Queries.csproj", "{481CF6E3-52AF-4621-9DEB-022122079AF6}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Snowball", "..\..\..\src\contrib\Snowball\Contrib.Snowball.csproj", "{8F9D7A92-F122-413E-9D8D-027E4ECD327C}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Spatial", "..\..\..\src\contrib\Spatial\Contrib.Spatial.csproj", "{35C347F4-24B2-4BE5-8117-A0E3001551CE}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.SpellChecker", "..\..\..\src\contrib\SpellChecker\Contrib.SpellChecker.csproj", "{FF45EE91-9CA3-443D-8231-75E9FA1AF40E}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Analyzers.Test", "..\..\..\test\contrib\Analyzers\Contrib.Analyzers.Test.csproj", "{67D27628-F1D5-4499-9818-B669731925C8}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net.Test", "..\..\..\test\core\Lucene.Net.Test.csproj", "{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Core.Test", "..\..\..\test\contrib\Core\Contrib.Core.Test.csproj", "{A065904B-1EBA-48DA-8D3D-D92A85BA41FC}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.FastVectorHighlighter.Test", "..\..\..\test\contrib\FastVectorHighlighter\Contrib.FastVectorHighlighter.Test.csproj", "{33ED01FD-A87C-4208-BA49-2586EFE32974}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Highlighter.Test", "..\..\..\test\contrib\Highlighter\Contrib.Highlighter.Test.csproj", "{31E10ECB-1385-4C06-970B-2C030FBD4893}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Queries.Test", "..\..\..\test\contrib\Queries\Contrib.Queries.Test.csproj", "{8685A826-9B7A-42C8-88F3-EEE6B41D6D81}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Snowball.Test", "..\..\..\test\contrib\Snowball\Contrib.Snowball.Test.csproj", "{992216FA-372D-4412-8D7C-E252AE042F48}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Spatial.Tests", "..\..\..\test\contrib\Spatial\Contrib.Spatial.Tests.csproj", "{19FC2A6B-4DE9-403F-8CEF-10850F57B96E}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.SpellChecker.Test", "..\..\..\test\contrib\SpellChecker\Contrib.SpellChecker.Test.csproj", "{4DCB81AA-ECC1-4B3D-A0C9-28E54F5B125C}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Demo.Common", "..\..\..\src\demo\Demo.Common\Demo.Common.csproj", "{F04CA2F4-E182-46A8-B914-F46AF5319E83}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Regex.Test", "..\..\..\test\contrib\Regex\Contrib.Regex.Test.csproj", "{F1875552-0E59-46AA-976E-6183733FD2AB}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Regex", "..\..\..\src\contrib\Regex\Contrib.Regex.csproj", "{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "SimpleFacetedSearch", "..\..\..\src\contrib\SimpleFacetedSearch\SimpleFacetedSearch.csproj", "{66772190-FB3F-48F5-8E05-0B302BACEA73}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "SimpleFacetedSearch.Test", "..\..\..\test\contrib\SimpleFacetedSearch\SimpleFacetedSearch.Test.csproj", "{D8CC9461-64E0-416E-BA6E-1DF6FA66CBF5}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Memory", "..\..\..\src\contrib\Memory\Contrib.Memory.csproj", "{112B9A7C-29CC-4539-8F5A-45669C07CD4D}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Memory.Test", "..\..\..\test\contrib\Memory\Contrib.Memory.Test.csproj", "{66C13054-FF41-4C1D-BD0D-8DA009D1DFFD}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Spatial.NTS", "..\..\..\src\contrib\Spatial\Contrib.Spatial.NTS.csproj", "{02D030D0-C7B5-4561-8BDD-41408B2E2F41}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Spatial.NTS.Tests", "..\..\..\test\contrib\Spatial\Contrib.Spatial.NTS.Tests.csproj", "{DEC65744-D581-4007-87B2-BB0726EE0395}"
-EndProject
-Global
-	GlobalSection(SolutionConfigurationPlatforms) = preSolution
-		Debug|Any CPU = Debug|Any CPU
-		Debug35|Any CPU = Debug35|Any CPU
-		Release|Any CPU = Release|Any CPU
-		Release35|Any CPU = Release35|Any CPU
-	EndGlobalSection
-	GlobalSection(ProjectConfigurationPlatforms) = postSolution
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.Build.0 = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{FEF899EB-610C-4D3C-A556-A01F56F4AFE0}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{FEF899EB-610C-4D3C-A556-A01F56F4AFE0}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{FEF899EB-610C-4D3C-A556-A01F56F4AFE0}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{FEF899EB-610C-4D3C-A556-A01F56F4AFE0}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{FEF899EB-610C-4D3C-A556-A01F56F4AFE0}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{FEF899EB-610C-4D3C-A556-A01F56F4AFE0}.Release|Any CPU.Build.0 = Release|Any CPU
-		{FEF899EB-610C-4D3C-A556-A01F56F4AFE0}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{FEF899EB-610C-4D3C-A556-A01F56F4AFE0}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{4286E961-9143-4821-B46D-3D39D3736386}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{4286E961-9143-4821-B46D-3D39D3736386}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{4286E961-9143-4821-B46D-3D39D3736386}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{4286E961-9143-4821-B46D-3D39D3736386}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{4286E961-9143-4821-B46D-3D39D3736386}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{4286E961-9143-4821-B46D-3D39D3736386}.Release|Any CPU.Build.0 = Release|Any CPU
-		{4286E961-9143-4821-B46D-3D39D3736386}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{4286E961-9143-4821-B46D-3D39D3736386}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{9D2E3153-076F-49C5-B83D-FB2573536B5F}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{9D2E3153-076F-49C5-B83D-FB2573536B5F}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{9D2E3153-076F-49C5-B83D-FB2573536B5F}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{9D2E3153-076F-49C5-B83D-FB2573536B5F}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{9D2E3153-076F-49C5-B83D-FB2573536B5F}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{9D2E3153-076F-49C5-B83D-FB2573536B5F}.Release|Any CPU.Build.0 = Release|Any CPU
-		{9D2E3153-076F-49C5-B83D-FB2573536B5F}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{9D2E3153-076F-49C5-B83D-FB2573536B5F}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{901D5415-383C-4AA6-A256-879558841BEA}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{901D5415-383C-4AA6-A256-879558841BEA}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{901D5415-383C-4AA6-A256-879558841BEA}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{901D5415-383C-4AA6-A256-879558841BEA}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{901D5415-383C-4AA6-A256-879558841BEA}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{901D5415-383C-4AA6-A256-879558841BEA}.Release|Any CPU.Build.0 = Release|Any CPU
-		{901D5415-383C-4AA6-A256-879558841BEA}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{901D5415-383C-4AA6-A256-879558841BEA}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{481CF6E3-52AF-4621-9DEB-022122079AF6}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{481CF6E3-52AF-4621-9DEB-022122079AF6}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{481CF6E3-52AF-4621-9DEB-022122079AF6}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{481CF6E3-52AF-4621-9DEB-022122079AF6}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{481CF6E3-52AF-4621-9DEB-022122079AF6}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{481CF6E3-52AF-4621-9DEB-022122079AF6}.Release|Any CPU.Build.0 = Release|Any CPU
-		{481CF6E3-52AF-4621-9DEB-022122079AF6}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{481CF6E3-52AF-4621-9DEB-022122079AF6}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{8F9D7A92-F122-413E-9D8D-027E4ECD327C}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{8F9D7A92-F122-413E-9D8D-027E4ECD327C}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{8F9D7A92-F122-413E-9D8D-027E4ECD327C}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{8F9D7A92-F122-413E-9D8D-027E4ECD327C}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{8F9D7A92-F122-413E-9D8D-027E4ECD327C}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{8F9D7A92-F122-413E-9D8D-027E4ECD327C}.Release|Any CPU.Build.0 = Release|Any CPU
-		{8F9D7A92-F122-413E-9D8D-027E4ECD327C}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{8F9D7A92-F122-413E-9D8D-027E4ECD327C}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{35C347F4-24B2-4BE5-8117-A0E3001551CE}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{35C347F4-24B2-4BE5-8117-A0E3001551CE}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{35C347F4-24B2-4BE5-8117-A0E3001551CE}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{35C347F4-24B2-4BE5-8117-A0E3001551CE}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{35C347F4-24B2-4BE5-8117-A0E3001551CE}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{35C347F4-24B2-4BE5-8117-A0E3001551CE}.Release|Any CPU.Build.0 = Release|Any CPU
-		{35C347F4-24B2-4BE5-8117-A0E3001551CE}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{35C347F4-24B2-4BE5-8117-A0E3001551CE}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{FF45EE91-9CA3-443D-8231-75E9FA1AF40E}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{FF45EE91-9CA3-443D-8231-75E9FA1AF40E}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{FF45EE91-9CA3-443D-8231-75E9FA1AF40E}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{FF45EE91-9CA3-443D-8231-75E9FA1AF40E}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{FF45EE91-9CA3-443D-8231-75E9FA1AF40E}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{FF45EE91-9CA3-443D-8231-75E9FA1AF40E}.Release|Any CPU.Build.0 = Release|Any CPU
-		{FF45EE91-9CA3-443D-8231-75E9FA1AF40E}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{FF45EE91-9CA3-443D-8231-75E9FA1AF40E}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{67D27628-F1D5-4499-9818-B669731925C8}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{67D27628-F1D5-4499-9818-B669731925C8}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{67D27628-F1D5-4499-9818-B669731925C8}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{67D27628-F1D5-4499-9818-B669731925C8}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{67D27628-F1D5-4499-9818-B669731925C8}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{67D27628-F1D5-4499-9818-B669731925C8}.Release|Any CPU.Build.0 = Release|Any CPU
-		{67D27628-F1D5-4499-9818-B669731925C8}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{67D27628-F1D5-4499-9818-B669731925C8}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Release|Any CPU.Build.0 = Release|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{A065904B-1EBA-48DA-8D3D-D92A85BA41FC}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{A065904B-1EBA-48DA-8D3D-D92A85BA41FC}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{A065904B-1EBA-48DA-8D3D-D92A85BA41FC}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{A065904B-1EBA-48DA-8D3D-D92A85BA41FC}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{A065904B-1EBA-48DA-8D3D-D92A85BA41FC}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{A065904B-1EBA-48DA-8D3D-D92A85BA41FC}.Release|Any CPU.Build.0 = Release|Any CPU
-		{A065904B-1EBA-48DA-8D3D-D92A85BA41FC}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{A065904B-1EBA-48DA-8D3D-D92A85BA41FC}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{33ED01FD-A87C-4208-BA49-2586EFE32974}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{33ED01FD-A87C-4208-BA49-2586EFE32974}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{33ED01FD-A87C-4208-BA49-2586EFE32974}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{33ED01FD-A87C-4208-BA49-2586EFE32974}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{33ED01FD-A87C-4208-BA49-2586EFE32974}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{33ED01FD-A87C-4208-BA49-2586EFE32974}.Release|Any CPU.Build.0 = Release|Any CPU
-		{33ED01FD-A87C-4208-BA49-2586EFE32974}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{33ED01FD-A87C-4208-BA49-2586EFE32974}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{31E10ECB-1385-4C06-970B-2C030FBD4893}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{31E10ECB-1385-4C06-970B-2C030FBD4893}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{31E10ECB-1385-4C06-970B-2C030FBD4893}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{31E10ECB-1385-4C06-970B-2C030FBD4893}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{31E10ECB-1385-4C06-970B-2C030FBD4893}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{31E10ECB-1385-4C06-970B-2C030FBD4893}.Release|Any CPU.Build.0 = Release|Any CPU
-		{31E10ECB-1385-4C06-970B-2C030FBD4893}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{31E10ECB-1385-4C06-970B-2C030FBD4893}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{8685A826-9B7A-42C8-88F3-EEE6B41D6D81}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{8685A826-9B7A-42C8-88F3-EEE6B41D6D81}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{8685A826-9B7A-42C8-88F3-EEE6B41D6D81}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{8685A826-9B7A-42C8-88F3-EEE6B41D6D81}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{8685A826-9B7A-42C8-88F3-EEE6B41D6D81}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{8685A826-9B7A-42C8-88F3-EEE6B41D6D81}.Release|Any CPU.Build.0 = Release|Any CPU
-		{8685A826-9B7A-42C8-88F3-EEE6B41D6D81}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{8685A826-9B7A-42C8-88F3-EEE6B41D6D81}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{992216FA-372D-4412-8D7C-E252AE042F48}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{992216FA-372D-4412-8D7C-E252AE042F48}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{992216FA-372D-4412-8D7C-E252AE042F48}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{992216FA-372D-4412-8D7C-E252AE042F48}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{992216FA-372D-4412-8D7C-E252AE042F48}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{992216FA-372D-4412-8D7C-E252AE042F48}.Release|Any CPU.Build.0 = Release|Any CPU
-		{992216FA-372D-4412-8D7C-E252AE042F48}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{992216FA-372D-4412-8D7C-E252AE042F48}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{19FC2A6B-4DE9-403F-8CEF-10850F57B96E}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{19FC2A6B-4DE9-403F-8CEF-10850F57B96E}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{19FC2A6B-4DE9-403F-8CEF-10850F57B96E}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{19FC2A6B-4DE9-403F-8CEF-10850F57B96E}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{19FC2A6B-4DE9-403F-8CEF-10850F57B96E}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{19FC2A6B-4DE9-403F-8CEF-10850F57B96E}.Release|Any CPU.Build.0 = Release|Any CPU
-		{19FC2A6B-4DE9-403F-8CEF-10850F57B96E}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{19FC2A6B-4DE9-403F-8CEF-10850F57B96E}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{4DCB81AA-ECC1-4B3D-A0C9-28E54F5B125C}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{4DCB81AA-ECC1-4B3D-A0C9-28E54F5B125C}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{4DCB81AA-ECC1-4B3D-A0C9-28E54F5B125C}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{4DCB81AA-ECC1-4B3D-A0C9-28E54F5B125C}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{4DCB81AA-ECC1-4B3D-A0C9-28E54F5B125C}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{4DCB81AA-ECC1-4B3D-A0C9-28E54F5B125C}.Release|Any CPU.Build.0 = Release|Any CPU
-		{4DCB81AA-ECC1-4B3D-A0C9-28E54F5B125C}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{4DCB81AA-ECC1-4B3D-A0C9-28E54F5B125C}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Release|Any CPU.Build.0 = Release|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{F1875552-0E59-46AA-976E-6183733FD2AB}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{F1875552-0E59-46AA-976E-6183733FD2AB}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{F1875552-0E59-46AA-976E-6183733FD2AB}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{F1875552-0E59-46AA-976E-6183733FD2AB}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{F1875552-0E59-46AA-976E-6183733FD2AB}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{F1875552-0E59-46AA-976E-6183733FD2AB}.Release|Any CPU.Build.0 = Release|Any CPU
-		{F1875552-0E59-46AA-976E-6183733FD2AB}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{F1875552-0E59-46AA-976E-6183733FD2AB}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Release|Any CPU.Build.0 = Release|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Release|Any CPU.Build.0 = Release|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{D8CC9461-64E0-416E-BA6E-1DF6FA66CBF5}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{D8CC9461-64E0-416E-BA6E-1DF6FA66CBF5}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{D8CC9461-64E0-416E-BA6E-1DF6FA66CBF5}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{D8CC9461-64E0-416E-BA6E-1DF6FA66CBF5}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{D8CC9461-64E0-416E-BA6E-1DF6FA66CBF5}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{D8CC9461-64E0-416E-BA6E-1DF6FA66CBF5}.Release|Any CPU.Build.0 = Release|Any CPU
-		{D8CC9461-64E0-416E-BA6E-1DF6FA66CBF5}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{D8CC9461-64E0-416E-BA6E-1DF6FA66CBF5}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Release|Any CPU.Build.0 = Release|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{66C13054-FF41-4C1D-BD0D-8DA009D1DFFD}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{66C13054-FF41-4C1D-BD0D-8DA009D1DFFD}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{66C13054-FF41-4C1D-BD0D-8DA009D1DFFD}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{66C13054-FF41-4C1D-BD0D-8DA009D1DFFD}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{66C13054-FF41-4C1D-BD0D-8DA009D1DFFD}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{66C13054-FF41-4C1D-BD0D-8DA009D1DFFD}.Release|Any CPU.Build.0 = Release|Any CPU
-		{66C13054-FF41-4C1D-BD0D-8DA009D1DFFD}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{66C13054-FF41-4C1D-BD0D-8DA009D1DFFD}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{02D030D0-C7B5-4561-8BDD-41408B2E2F41}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{02D030D0-C7B5-4561-8BDD-41408B2E2F41}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{02D030D0-C7B5-4561-8BDD-41408B2E2F41}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{02D030D0-C7B5-4561-8BDD-41408B2E2F41}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{02D030D0-C7B5-4561-8BDD-41408B2E2F41}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{02D030D0-C7B5-4561-8BDD-41408B2E2F41}.Release|Any CPU.Build.0 = Release|Any CPU
-		{02D030D0-C7B5-4561-8BDD-41408B2E2F41}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{02D030D0-C7B5-4561-8BDD-41408B2E2F41}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{DEC65744-D581-4007-87B2-BB0726EE0395}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{DEC65744-D581-4007-87B2-BB0726EE0395}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{DEC65744-D581-4007-87B2-BB0726EE0395}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{DEC65744-D581-4007-87B2-BB0726EE0395}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{DEC65744-D581-4007-87B2-BB0726EE0395}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{DEC65744-D581-4007-87B2-BB0726EE0395}.Release|Any CPU.Build.0 = Release|Any CPU
-		{DEC65744-D581-4007-87B2-BB0726EE0395}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{DEC65744-D581-4007-87B2-BB0726EE0395}.Release35|Any CPU.Build.0 = Release35|Any CPU
-	EndGlobalSection
-	GlobalSection(SolutionProperties) = preSolution
-		HideSolutionNode = FALSE
-	EndGlobalSection
-EndGlobal

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/vs2010/test/Contrib.Analyzers.Test.sln
----------------------------------------------------------------------
diff --git a/build/vs2010/test/Contrib.Analyzers.Test.sln b/build/vs2010/test/Contrib.Analyzers.Test.sln
deleted file mode 100644
index 6a9100a..0000000
--- a/build/vs2010/test/Contrib.Analyzers.Test.sln
+++ /dev/null
@@ -1,86 +0,0 @@
-
-Microsoft Visual Studio Solution File, Format Version 11.00
-# Visual C# Express 2010
-#
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-#
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net", "..\..\..\src\core\Lucene.Net.csproj", "{5D4AD9BE-1FFB-41AB-9943-25737971BF57}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Analyzers", "..\..\..\src\contrib\Analyzers\Contrib.Analyzers.csproj", "{4286E961-9143-4821-B46D-3D39D3736386}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Analyzers.Test", "..\..\..\test\contrib\Analyzers\Contrib.Analyzers.Test.csproj", "{67D27628-F1D5-4499-9818-B669731925C8}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net.Test", "..\..\..\test\core\Lucene.Net.Test.csproj", "{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Demo.Common", "..\..\..\src\demo\Demo.Common\Demo.Common.csproj", "{F04CA2F4-E182-46A8-B914-F46AF5319E83}"
-EndProject
-Global
-	GlobalSection(SolutionConfigurationPlatforms) = preSolution
-		Debug35|Any CPU = Debug35|Any CPU
-		Debug|Any CPU = Debug|Any CPU
-		Release35|Any CPU = Release35|Any CPU
-		Release|Any CPU = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(ProjectConfigurationPlatforms) = postSolution
-		{4286E961-9143-4821-B46D-3D39D3736386}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{4286E961-9143-4821-B46D-3D39D3736386}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{4286E961-9143-4821-B46D-3D39D3736386}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{4286E961-9143-4821-B46D-3D39D3736386}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{4286E961-9143-4821-B46D-3D39D3736386}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{4286E961-9143-4821-B46D-3D39D3736386}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{4286E961-9143-4821-B46D-3D39D3736386}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{4286E961-9143-4821-B46D-3D39D3736386}.Release|Any CPU.Build.0 = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.Build.0 = Release|Any CPU
-		{67D27628-F1D5-4499-9818-B669731925C8}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{67D27628-F1D5-4499-9818-B669731925C8}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{67D27628-F1D5-4499-9818-B669731925C8}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{67D27628-F1D5-4499-9818-B669731925C8}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{67D27628-F1D5-4499-9818-B669731925C8}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{67D27628-F1D5-4499-9818-B669731925C8}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{67D27628-F1D5-4499-9818-B669731925C8}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{67D27628-F1D5-4499-9818-B669731925C8}.Release|Any CPU.Build.0 = Release|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Release|Any CPU.Build.0 = Release|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Release|Any CPU.Build.0 = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(SolutionProperties) = preSolution
-		HideSolutionNode = FALSE
-	EndGlobalSection
-EndGlobal

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/vs2010/test/Contrib.Core.Test.sln
----------------------------------------------------------------------
diff --git a/build/vs2010/test/Contrib.Core.Test.sln b/build/vs2010/test/Contrib.Core.Test.sln
deleted file mode 100644
index 97e682e..0000000
--- a/build/vs2010/test/Contrib.Core.Test.sln
+++ /dev/null
@@ -1,66 +0,0 @@
-
-Microsoft Visual Studio Solution File, Format Version 11.00
-# Visual C# Express 2010
-#
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-#
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net", "..\..\..\src\core\Lucene.Net.csproj", "{5D4AD9BE-1FFB-41AB-9943-25737971BF57}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Core", "..\..\..\src\contrib\Core\Contrib.Core.csproj", "{FEF899EB-610C-4D3C-A556-A01F56F4AFE0}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Core.Test", "..\..\..\test\contrib\Core\Contrib.Core.Test.csproj", "{A065904B-1EBA-48DA-8D3D-D92A85BA41FC}"
-EndProject
-Global
-	GlobalSection(SolutionConfigurationPlatforms) = preSolution
-		Debug35|Any CPU = Debug35|Any CPU
-		Debug|Any CPU = Debug|Any CPU
-		Release35|Any CPU = Release35|Any CPU
-		Release|Any CPU = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(ProjectConfigurationPlatforms) = postSolution
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.Build.0 = Release|Any CPU
-		{A065904B-1EBA-48DA-8D3D-D92A85BA41FC}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{A065904B-1EBA-48DA-8D3D-D92A85BA41FC}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{A065904B-1EBA-48DA-8D3D-D92A85BA41FC}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{A065904B-1EBA-48DA-8D3D-D92A85BA41FC}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{A065904B-1EBA-48DA-8D3D-D92A85BA41FC}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{A065904B-1EBA-48DA-8D3D-D92A85BA41FC}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{A065904B-1EBA-48DA-8D3D-D92A85BA41FC}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{A065904B-1EBA-48DA-8D3D-D92A85BA41FC}.Release|Any CPU.Build.0 = Release|Any CPU
-		{FEF899EB-610C-4D3C-A556-A01F56F4AFE0}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{FEF899EB-610C-4D3C-A556-A01F56F4AFE0}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{FEF899EB-610C-4D3C-A556-A01F56F4AFE0}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{FEF899EB-610C-4D3C-A556-A01F56F4AFE0}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{FEF899EB-610C-4D3C-A556-A01F56F4AFE0}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{FEF899EB-610C-4D3C-A556-A01F56F4AFE0}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{FEF899EB-610C-4D3C-A556-A01F56F4AFE0}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{FEF899EB-610C-4D3C-A556-A01F56F4AFE0}.Release|Any CPU.Build.0 = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(SolutionProperties) = preSolution
-		HideSolutionNode = FALSE
-	EndGlobalSection
-EndGlobal

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/vs2010/test/Contrib.FastVectorHighlighter.Test.sln
----------------------------------------------------------------------
diff --git a/build/vs2010/test/Contrib.FastVectorHighlighter.Test.sln b/build/vs2010/test/Contrib.FastVectorHighlighter.Test.sln
deleted file mode 100644
index 672811a..0000000
--- a/build/vs2010/test/Contrib.FastVectorHighlighter.Test.sln
+++ /dev/null
@@ -1,66 +0,0 @@
-
-Microsoft Visual Studio Solution File, Format Version 11.00
-# Visual C# Express 2010
-#
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-#
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net", "..\..\..\src\core\Lucene.Net.csproj", "{5D4AD9BE-1FFB-41AB-9943-25737971BF57}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.FastVectorHighlighter", "..\..\..\src\contrib\FastVectorHighlighter\Contrib.FastVectorHighlighter.csproj", "{9D2E3153-076F-49C5-B83D-FB2573536B5F}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.FastVectorHighlighter.Test", "..\..\..\test\contrib\FastVectorHighlighter\Contrib.FastVectorHighlighter.Test.csproj", "{33ED01FD-A87C-4208-BA49-2586EFE32974}"
-EndProject
-Global
-	GlobalSection(SolutionConfigurationPlatforms) = preSolution
-		Debug35|Any CPU = Debug35|Any CPU
-		Debug|Any CPU = Debug|Any CPU
-		Release35|Any CPU = Release35|Any CPU
-		Release|Any CPU = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(ProjectConfigurationPlatforms) = postSolution
-		{33ED01FD-A87C-4208-BA49-2586EFE32974}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{33ED01FD-A87C-4208-BA49-2586EFE32974}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{33ED01FD-A87C-4208-BA49-2586EFE32974}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{33ED01FD-A87C-4208-BA49-2586EFE32974}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{33ED01FD-A87C-4208-BA49-2586EFE32974}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{33ED01FD-A87C-4208-BA49-2586EFE32974}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{33ED01FD-A87C-4208-BA49-2586EFE32974}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{33ED01FD-A87C-4208-BA49-2586EFE32974}.Release|Any CPU.Build.0 = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.Build.0 = Release|Any CPU
-		{9D2E3153-076F-49C5-B83D-FB2573536B5F}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{9D2E3153-076F-49C5-B83D-FB2573536B5F}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{9D2E3153-076F-49C5-B83D-FB2573536B5F}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{9D2E3153-076F-49C5-B83D-FB2573536B5F}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{9D2E3153-076F-49C5-B83D-FB2573536B5F}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{9D2E3153-076F-49C5-B83D-FB2573536B5F}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{9D2E3153-076F-49C5-B83D-FB2573536B5F}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{9D2E3153-076F-49C5-B83D-FB2573536B5F}.Release|Any CPU.Build.0 = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(SolutionProperties) = preSolution
-		HideSolutionNode = FALSE
-	EndGlobalSection
-EndGlobal

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/vs2010/test/Contrib.Highlighter.Test.sln
----------------------------------------------------------------------
diff --git a/build/vs2010/test/Contrib.Highlighter.Test.sln b/build/vs2010/test/Contrib.Highlighter.Test.sln
deleted file mode 100644
index 9d600af..0000000
--- a/build/vs2010/test/Contrib.Highlighter.Test.sln
+++ /dev/null
@@ -1,106 +0,0 @@
-
-Microsoft Visual Studio Solution File, Format Version 11.00
-# Visual C# Express 2010
-#
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-#
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net", "..\..\..\src\core\Lucene.Net.csproj", "{5D4AD9BE-1FFB-41AB-9943-25737971BF57}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Highlighter", "..\..\..\src\contrib\Highlighter\Contrib.Highlighter.csproj", "{901D5415-383C-4AA6-A256-879558841BEA}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Highlighter.Test", "..\..\..\test\contrib\Highlighter\Contrib.Highlighter.Test.csproj", "{31E10ECB-1385-4C06-970B-2C030FBD4893}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Memory", "..\..\..\src\contrib\Memory\Contrib.Memory.csproj", "{112B9A7C-29CC-4539-8F5A-45669C07CD4D}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Regex", "..\..\..\src\contrib\Regex\Contrib.Regex.csproj", "{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net.Test", "..\..\..\test\core\Lucene.Net.Test.csproj", "{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Demo.Common", "..\..\..\src\demo\Demo.Common\Demo.Common.csproj", "{F04CA2F4-E182-46A8-B914-F46AF5319E83}"
-EndProject
-Global
-	GlobalSection(SolutionConfigurationPlatforms) = preSolution
-		Debug35|Any CPU = Debug35|Any CPU
-		Debug|Any CPU = Debug|Any CPU
-		Release35|Any CPU = Release35|Any CPU
-		Release|Any CPU = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(ProjectConfigurationPlatforms) = postSolution
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Release|Any CPU.Build.0 = Release|Any CPU
-		{31E10ECB-1385-4C06-970B-2C030FBD4893}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{31E10ECB-1385-4C06-970B-2C030FBD4893}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{31E10ECB-1385-4C06-970B-2C030FBD4893}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{31E10ECB-1385-4C06-970B-2C030FBD4893}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{31E10ECB-1385-4C06-970B-2C030FBD4893}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{31E10ECB-1385-4C06-970B-2C030FBD4893}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{31E10ECB-1385-4C06-970B-2C030FBD4893}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{31E10ECB-1385-4C06-970B-2C030FBD4893}.Release|Any CPU.Build.0 = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.Build.0 = Release|Any CPU
-		{901D5415-383C-4AA6-A256-879558841BEA}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{901D5415-383C-4AA6-A256-879558841BEA}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{901D5415-383C-4AA6-A256-879558841BEA}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{901D5415-383C-4AA6-A256-879558841BEA}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{901D5415-383C-4AA6-A256-879558841BEA}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{901D5415-383C-4AA6-A256-879558841BEA}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{901D5415-383C-4AA6-A256-879558841BEA}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{901D5415-383C-4AA6-A256-879558841BEA}.Release|Any CPU.Build.0 = Release|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Release|Any CPU.Build.0 = Release|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Release|Any CPU.Build.0 = Release|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Release|Any CPU.Build.0 = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(SolutionProperties) = preSolution
-		HideSolutionNode = FALSE
-	EndGlobalSection
-EndGlobal

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/vs2010/test/Contrib.Memory.Test.sln
----------------------------------------------------------------------
diff --git a/build/vs2010/test/Contrib.Memory.Test.sln b/build/vs2010/test/Contrib.Memory.Test.sln
deleted file mode 100644
index f41127e..0000000
--- a/build/vs2010/test/Contrib.Memory.Test.sln
+++ /dev/null
@@ -1,86 +0,0 @@
-
-Microsoft Visual Studio Solution File, Format Version 11.00
-# Visual C# Express 2010
-#
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-#
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net", "..\..\..\src\core\Lucene.Net.csproj", "{5D4AD9BE-1FFB-41AB-9943-25737971BF57}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Memory", "..\..\..\src\contrib\Memory\Contrib.Memory.csproj", "{112B9A7C-29CC-4539-8F5A-45669C07CD4D}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Memory.Test", "..\..\..\test\contrib\Memory\Contrib.Memory.Test.csproj", "{66C13054-FF41-4C1D-BD0D-8DA009D1DFFD}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net.Test", "..\..\..\test\core\Lucene.Net.Test.csproj", "{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Demo.Common", "..\..\..\src\demo\Demo.Common\Demo.Common.csproj", "{F04CA2F4-E182-46A8-B914-F46AF5319E83}"
-EndProject
-Global
-	GlobalSection(SolutionConfigurationPlatforms) = preSolution
-		Debug35|Any CPU = Debug35|Any CPU
-		Debug|Any CPU = Debug|Any CPU
-		Release35|Any CPU = Release35|Any CPU
-		Release|Any CPU = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(ProjectConfigurationPlatforms) = postSolution
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{112B9A7C-29CC-4539-8F5A-45669C07CD4D}.Release|Any CPU.Build.0 = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.Build.0 = Release|Any CPU
-		{66C13054-FF41-4C1D-BD0D-8DA009D1DFFD}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{66C13054-FF41-4C1D-BD0D-8DA009D1DFFD}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{66C13054-FF41-4C1D-BD0D-8DA009D1DFFD}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{66C13054-FF41-4C1D-BD0D-8DA009D1DFFD}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{66C13054-FF41-4C1D-BD0D-8DA009D1DFFD}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{66C13054-FF41-4C1D-BD0D-8DA009D1DFFD}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{66C13054-FF41-4C1D-BD0D-8DA009D1DFFD}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{66C13054-FF41-4C1D-BD0D-8DA009D1DFFD}.Release|Any CPU.Build.0 = Release|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Release|Any CPU.Build.0 = Release|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Release|Any CPU.Build.0 = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(SolutionProperties) = preSolution
-		HideSolutionNode = FALSE
-	EndGlobalSection
-EndGlobal

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/vs2010/test/Contrib.Queries.Test.sln
----------------------------------------------------------------------
diff --git a/build/vs2010/test/Contrib.Queries.Test.sln b/build/vs2010/test/Contrib.Queries.Test.sln
deleted file mode 100644
index 19f835b..0000000
--- a/build/vs2010/test/Contrib.Queries.Test.sln
+++ /dev/null
@@ -1,86 +0,0 @@
-
-Microsoft Visual Studio Solution File, Format Version 11.00
-# Visual C# Express 2010
-#
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-#
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net", "..\..\..\src\core\Lucene.Net.csproj", "{5D4AD9BE-1FFB-41AB-9943-25737971BF57}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Queries", "..\..\..\src\contrib\Queries\Contrib.Queries.csproj", "{481CF6E3-52AF-4621-9DEB-022122079AF6}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net.Test", "..\..\..\test\core\Lucene.Net.Test.csproj", "{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Queries.Test", "..\..\..\test\contrib\Queries\Contrib.Queries.Test.csproj", "{8685A826-9B7A-42C8-88F3-EEE6B41D6D81}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Demo.Common", "..\..\..\src\demo\Demo.Common\Demo.Common.csproj", "{F04CA2F4-E182-46A8-B914-F46AF5319E83}"
-EndProject
-Global
-	GlobalSection(SolutionConfigurationPlatforms) = preSolution
-		Debug35|Any CPU = Debug35|Any CPU
-		Debug|Any CPU = Debug|Any CPU
-		Release35|Any CPU = Release35|Any CPU
-		Release|Any CPU = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(ProjectConfigurationPlatforms) = postSolution
-		{481CF6E3-52AF-4621-9DEB-022122079AF6}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{481CF6E3-52AF-4621-9DEB-022122079AF6}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{481CF6E3-52AF-4621-9DEB-022122079AF6}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{481CF6E3-52AF-4621-9DEB-022122079AF6}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{481CF6E3-52AF-4621-9DEB-022122079AF6}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{481CF6E3-52AF-4621-9DEB-022122079AF6}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{481CF6E3-52AF-4621-9DEB-022122079AF6}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{481CF6E3-52AF-4621-9DEB-022122079AF6}.Release|Any CPU.Build.0 = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.Build.0 = Release|Any CPU
-		{8685A826-9B7A-42C8-88F3-EEE6B41D6D81}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{8685A826-9B7A-42C8-88F3-EEE6B41D6D81}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{8685A826-9B7A-42C8-88F3-EEE6B41D6D81}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{8685A826-9B7A-42C8-88F3-EEE6B41D6D81}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{8685A826-9B7A-42C8-88F3-EEE6B41D6D81}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{8685A826-9B7A-42C8-88F3-EEE6B41D6D81}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{8685A826-9B7A-42C8-88F3-EEE6B41D6D81}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{8685A826-9B7A-42C8-88F3-EEE6B41D6D81}.Release|Any CPU.Build.0 = Release|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Release|Any CPU.Build.0 = Release|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Release|Any CPU.Build.0 = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(SolutionProperties) = preSolution
-		HideSolutionNode = FALSE
-	EndGlobalSection
-EndGlobal

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/vs2010/test/Contrib.Regex.Test.sln
----------------------------------------------------------------------
diff --git a/build/vs2010/test/Contrib.Regex.Test.sln b/build/vs2010/test/Contrib.Regex.Test.sln
deleted file mode 100644
index 6ec91f2..0000000
--- a/build/vs2010/test/Contrib.Regex.Test.sln
+++ /dev/null
@@ -1,86 +0,0 @@
-
-Microsoft Visual Studio Solution File, Format Version 11.00
-# Visual C# Express 2010
-#
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-#
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net", "..\..\..\src\core\Lucene.Net.csproj", "{5D4AD9BE-1FFB-41AB-9943-25737971BF57}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net.Test", "..\..\..\test\core\Lucene.Net.Test.csproj", "{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Demo.Common", "..\..\..\src\demo\Demo.Common\Demo.Common.csproj", "{F04CA2F4-E182-46A8-B914-F46AF5319E83}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Regex", "..\..\..\src\contrib\Regex\Contrib.Regex.csproj", "{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Regex.Test", "..\..\..\test\contrib\Regex\Contrib.Regex.Test.csproj", "{F1875552-0E59-46AA-976E-6183733FD2AB}"
-EndProject
-Global
-	GlobalSection(SolutionConfigurationPlatforms) = preSolution
-		Debug35|Any CPU = Debug35|Any CPU
-		Debug|Any CPU = Debug|Any CPU
-		Release35|Any CPU = Release35|Any CPU
-		Release|Any CPU = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(ProjectConfigurationPlatforms) = postSolution
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.Build.0 = Release|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{A26BD3B7-DF90-43B4-99E2-6A617CDE1579}.Release|Any CPU.Build.0 = Release|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Release|Any CPU.Build.0 = Release|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Release|Any CPU.Build.0 = Release|Any CPU
-		{F1875552-0E59-46AA-976E-6183733FD2AB}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{F1875552-0E59-46AA-976E-6183733FD2AB}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{F1875552-0E59-46AA-976E-6183733FD2AB}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{F1875552-0E59-46AA-976E-6183733FD2AB}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{F1875552-0E59-46AA-976E-6183733FD2AB}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{F1875552-0E59-46AA-976E-6183733FD2AB}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{F1875552-0E59-46AA-976E-6183733FD2AB}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{F1875552-0E59-46AA-976E-6183733FD2AB}.Release|Any CPU.Build.0 = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(SolutionProperties) = preSolution
-		HideSolutionNode = FALSE
-	EndGlobalSection
-EndGlobal

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/vs2010/test/Contrib.SimpleFacetedSearch.Test.sln
----------------------------------------------------------------------
diff --git a/build/vs2010/test/Contrib.SimpleFacetedSearch.Test.sln b/build/vs2010/test/Contrib.SimpleFacetedSearch.Test.sln
deleted file mode 100644
index 9cceee7..0000000
--- a/build/vs2010/test/Contrib.SimpleFacetedSearch.Test.sln
+++ /dev/null
@@ -1,110 +0,0 @@
-
-Microsoft Visual Studio Solution File, Format Version 11.00
-# Visual C# Express 2010
-#
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-#
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "SimpleFacetedSearch.Test", "..\..\..\test\contrib\SimpleFacetedSearch\SimpleFacetedSearch.Test.csproj", "{D8CC9461-64E0-416E-BA6E-1DF6FA66CBF5}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "SimpleFacetedSearch", "..\..\..\src\contrib\SimpleFacetedSearch\SimpleFacetedSearch.csproj", "{66772190-FB3F-48F5-8E05-0B302BACEA73}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net", "..\..\..\src\core\Lucene.Net.csproj", "{5D4AD9BE-1FFB-41AB-9943-25737971BF57}"
-EndProject
-Global
-	GlobalSection(SolutionConfigurationPlatforms) = preSolution
-		Debug35|Any CPU = Debug35|Any CPU
-		Debug35|Mixed Platforms = Debug35|Mixed Platforms
-		Debug35|x86 = Debug35|x86
-		Debug|Any CPU = Debug|Any CPU
-		Debug|Mixed Platforms = Debug|Mixed Platforms
-		Debug|x86 = Debug|x86
-		Release35|Any CPU = Release35|Any CPU
-		Release35|Mixed Platforms = Release35|Mixed Platforms
-		Release35|x86 = Release35|x86
-		Release|Any CPU = Release|Any CPU
-		Release|Mixed Platforms = Release|Mixed Platforms
-		Release|x86 = Release|x86
-	EndGlobalSection
-	GlobalSection(ProjectConfigurationPlatforms) = postSolution
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Mixed Platforms.ActiveCfg = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Mixed Platforms.Build.0 = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|x86.ActiveCfg = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Mixed Platforms.ActiveCfg = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Mixed Platforms.Build.0 = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|x86.ActiveCfg = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.ActiveCfg = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.Build.0 = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Mixed Platforms.ActiveCfg = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Mixed Platforms.Build.0 = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|x86.ActiveCfg = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.Build.0 = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Mixed Platforms.ActiveCfg = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Mixed Platforms.Build.0 = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|x86.ActiveCfg = Release|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Debug35|Mixed Platforms.ActiveCfg = Debug35|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Debug35|Mixed Platforms.Build.0 = Debug35|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Debug35|x86.ActiveCfg = Debug35|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Debug|Mixed Platforms.ActiveCfg = Debug|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Debug|Mixed Platforms.Build.0 = Debug|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Debug|x86.ActiveCfg = Debug|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Release35|Any CPU.ActiveCfg = Release|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Release35|Any CPU.Build.0 = Release|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Release35|Mixed Platforms.ActiveCfg = Release35|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Release35|Mixed Platforms.Build.0 = Release35|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Release35|x86.ActiveCfg = Release|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Release|Any CPU.Build.0 = Release|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Release|Mixed Platforms.ActiveCfg = Release|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Release|Mixed Platforms.Build.0 = Release|Any CPU
-		{66772190-FB3F-48F5-8E05-0B302BACEA73}.Release|x86.ActiveCfg = Release|Any CPU
-		{D8CC9461-64E0-416E-BA6E-1DF6FA66CBF5}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{D8CC9461-64E0-416E-BA6E-1DF6FA66CBF5}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{D8CC9461-64E0-416E-BA6E-1DF6FA66CBF5}.Debug35|Mixed Platforms.ActiveCfg = Debug35|Any CPU
-		{D8CC9461-64E0-416E-BA6E-1DF6FA66CBF5}.Debug35|Mixed Platforms.Build.0 = Debug35|Any CPU
-		{D8CC9461-64E0-416E-BA6E-1DF6FA66CBF5}.Debug35|x86.ActiveCfg = Debug35|Any CPU
-		{D8CC9461-64E0-416E-BA6E-1DF6FA66CBF5}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{D8CC9461-64E0-416E-BA6E-1DF6FA66CBF5}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{D8CC9461-64E0-416E-BA6E-1DF6FA66CBF5}.Debug|Mixed Platforms.ActiveCfg = Debug|Any CPU
-		{D8CC9461-64E0-416E-BA6E-1DF6FA66CBF5}.Debug|Mixed Platforms.Build.0 = Debug|Any CPU
-		{D8CC9461-64E0-416E-BA6E-1DF6FA66CBF5}.Debug|x86.ActiveCfg = Debug|Any CPU
-		{D8CC9461-64E0-416E-BA6E-1DF6FA66CBF5}.Release35|Any CPU.ActiveCfg = Release|Any CPU
-		{D8CC9461-64E0-416E-BA6E-1DF6FA66CBF5}.Release35|Any CPU.Build.0 = Release|Any CPU
-		{D8CC9461-64E0-416E-BA6E-1DF6FA66CBF5}.Release35|Mixed Platforms.ActiveCfg = Release35|Any CPU
-		{D8CC9461-64E0-416E-BA6E-1DF6FA66CBF5}.Release35|Mixed Platforms.Build.0 = Release35|Any CPU
-		{D8CC9461-64E0-416E-BA6E-1DF6FA66CBF5}.Release35|x86.ActiveCfg = Release|Any CPU
-		{D8CC9461-64E0-416E-BA6E-1DF6FA66CBF5}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{D8CC9461-64E0-416E-BA6E-1DF6FA66CBF5}.Release|Any CPU.Build.0 = Release|Any CPU
-		{D8CC9461-64E0-416E-BA6E-1DF6FA66CBF5}.Release|Mixed Platforms.ActiveCfg = Release|Any CPU
-		{D8CC9461-64E0-416E-BA6E-1DF6FA66CBF5}.Release|Mixed Platforms.Build.0 = Release|Any CPU
-		{D8CC9461-64E0-416E-BA6E-1DF6FA66CBF5}.Release|x86.ActiveCfg = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(SolutionProperties) = preSolution
-		HideSolutionNode = FALSE
-	EndGlobalSection
-EndGlobal

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/vs2010/test/Contrib.Snowball.Test.sln
----------------------------------------------------------------------
diff --git a/build/vs2010/test/Contrib.Snowball.Test.sln b/build/vs2010/test/Contrib.Snowball.Test.sln
deleted file mode 100644
index 38c588e..0000000
--- a/build/vs2010/test/Contrib.Snowball.Test.sln
+++ /dev/null
@@ -1,85 +0,0 @@
-Microsoft Visual Studio Solution File, Format Version 11.00
-# Visual C# Express 2010
-#
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-#
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net", "..\..\..\src\core\Lucene.Net.csproj", "{5D4AD9BE-1FFB-41AB-9943-25737971BF57}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Snowball", "..\..\..\src\contrib\Snowball\Contrib.Snowball.csproj", "{8F9D7A92-F122-413E-9D8D-027E4ECD327C}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Snowball.Test", "..\..\..\test\contrib\Snowball\Contrib.Snowball.Test.csproj", "{992216FA-372D-4412-8D7C-E252AE042F48}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net.Test", "..\..\..\test\core\Lucene.Net.Test.csproj", "{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Demo.Common", "..\..\..\src\demo\Demo.Common\Demo.Common.csproj", "{F04CA2F4-E182-46A8-B914-F46AF5319E83}"
-EndProject
-Global
-	GlobalSection(SolutionConfigurationPlatforms) = preSolution
-		Debug35|Any CPU = Debug35|Any CPU
-		Debug|Any CPU = Debug|Any CPU
-		Release35|Any CPU = Release35|Any CPU
-		Release|Any CPU = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(ProjectConfigurationPlatforms) = postSolution
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.Build.0 = Release|Any CPU
-		{8F9D7A92-F122-413E-9D8D-027E4ECD327C}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{8F9D7A92-F122-413E-9D8D-027E4ECD327C}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{8F9D7A92-F122-413E-9D8D-027E4ECD327C}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{8F9D7A92-F122-413E-9D8D-027E4ECD327C}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{8F9D7A92-F122-413E-9D8D-027E4ECD327C}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{8F9D7A92-F122-413E-9D8D-027E4ECD327C}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{8F9D7A92-F122-413E-9D8D-027E4ECD327C}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{8F9D7A92-F122-413E-9D8D-027E4ECD327C}.Release|Any CPU.Build.0 = Release|Any CPU
-		{992216FA-372D-4412-8D7C-E252AE042F48}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{992216FA-372D-4412-8D7C-E252AE042F48}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{992216FA-372D-4412-8D7C-E252AE042F48}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{992216FA-372D-4412-8D7C-E252AE042F48}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{992216FA-372D-4412-8D7C-E252AE042F48}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{992216FA-372D-4412-8D7C-E252AE042F48}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{992216FA-372D-4412-8D7C-E252AE042F48}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{992216FA-372D-4412-8D7C-E252AE042F48}.Release|Any CPU.Build.0 = Release|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{AAF68BCF-F781-45FC-98B3-2B9CEE411E01}.Release|Any CPU.Build.0 = Release|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{F04CA2F4-E182-46A8-B914-F46AF5319E83}.Release|Any CPU.Build.0 = Release|Any CPU
-	EndGlobalSection
-	GlobalSection(SolutionProperties) = preSolution
-		HideSolutionNode = FALSE
-	EndGlobalSection
-EndGlobal

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/build/vs2010/test/Contrib.Spatial.Test.sln
----------------------------------------------------------------------
diff --git a/build/vs2010/test/Contrib.Spatial.Test.sln b/build/vs2010/test/Contrib.Spatial.Test.sln
deleted file mode 100644
index 5d641cd..0000000
--- a/build/vs2010/test/Contrib.Spatial.Test.sln
+++ /dev/null
@@ -1,86 +0,0 @@
-
-Microsoft Visual Studio Solution File, Format Version 11.00
-# Visual C# Express 2010
-#
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-#
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net", "..\..\..\src\core\Lucene.Net.csproj", "{5D4AD9BE-1FFB-41AB-9943-25737971BF57}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Spatial", "..\..\..\src\contrib\Spatial\Contrib.Spatial.csproj", "{35C347F4-24B2-4BE5-8117-A0E3001551CE}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Spatial.Tests", "..\..\..\test\contrib\Spatial\Contrib.Spatial.Tests.csproj", "{19FC2A6B-4DE9-403F-8CEF-10850F57B96E}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Spatial.NTS", "..\..\..\src\contrib\Spatial\Contrib.Spatial.NTS.csproj", "{02D030D0-C7B5-4561-8BDD-41408B2E2F41}"
-EndProject
-Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Contrib.Spatial.NTS.Tests", "..\..\..\test\contrib\Spatial\Contrib.Spatial.NTS.Tests.csproj", "{DEC65744-D581-4007-87B2-BB0726EE0395}"
-EndProject
-Global
-	GlobalSection(SolutionConfigurationPlatforms) = preSolution
-		Debug|Any CPU = Debug|Any CPU
-		Debug35|Any CPU = Debug35|Any CPU
-		Release|Any CPU = Release|Any CPU
-		Release35|Any CPU = Release35|Any CPU
-	EndGlobalSection
-	GlobalSection(ProjectConfigurationPlatforms) = postSolution
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.Build.0 = Release|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{35C347F4-24B2-4BE5-8117-A0E3001551CE}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{35C347F4-24B2-4BE5-8117-A0E3001551CE}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{35C347F4-24B2-4BE5-8117-A0E3001551CE}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{35C347F4-24B2-4BE5-8117-A0E3001551CE}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{35C347F4-24B2-4BE5-8117-A0E3001551CE}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{35C347F4-24B2-4BE5-8117-A0E3001551CE}.Release|Any CPU.Build.0 = Release|Any CPU
-		{35C347F4-24B2-4BE5-8117-A0E3001551CE}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{35C347F4-24B2-4BE5-8117-A0E3001551CE}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{19FC2A6B-4DE9-403F-8CEF-10850F57B96E}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{19FC2A6B-4DE9-403F-8CEF-10850F57B96E}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{19FC2A6B-4DE9-403F-8CEF-10850F57B96E}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{19FC2A6B-4DE9-403F-8CEF-10850F57B96E}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{19FC2A6B-4DE9-403F-8CEF-10850F57B96E}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{19FC2A6B-4DE9-403F-8CEF-10850F57B96E}.Release|Any CPU.Build.0 = Release|Any CPU
-		{19FC2A6B-4DE9-403F-8CEF-10850F57B96E}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{19FC2A6B-4DE9-403F-8CEF-10850F57B96E}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{02D030D0-C7B5-4561-8BDD-41408B2E2F41}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{02D030D0-C7B5-4561-8BDD-41408B2E2F41}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{02D030D0-C7B5-4561-8BDD-41408B2E2F41}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{02D030D0-C7B5-4561-8BDD-41408B2E2F41}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{02D030D0-C7B5-4561-8BDD-41408B2E2F41}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{02D030D0-C7B5-4561-8BDD-41408B2E2F41}.Release|Any CPU.Build.0 = Release|Any CPU
-		{02D030D0-C7B5-4561-8BDD-41408B2E2F41}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{02D030D0-C7B5-4561-8BDD-41408B2E2F41}.Release35|Any CPU.Build.0 = Release35|Any CPU
-		{DEC65744-D581-4007-87B2-BB0726EE0395}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
-		{DEC65744-D581-4007-87B2-BB0726EE0395}.Debug|Any CPU.Build.0 = Debug|Any CPU
-		{DEC65744-D581-4007-87B2-BB0726EE0395}.Debug35|Any CPU.ActiveCfg = Debug35|Any CPU
-		{DEC65744-D581-4007-87B2-BB0726EE0395}.Debug35|Any CPU.Build.0 = Debug35|Any CPU
-		{DEC65744-D581-4007-87B2-BB0726EE0395}.Release|Any CPU.ActiveCfg = Release|Any CPU
-		{DEC65744-D581-4007-87B2-BB0726EE0395}.Release|Any CPU.Build.0 = Release|Any CPU
-		{DEC65744-D581-4007-87B2-BB0726EE0395}.Release35|Any CPU.ActiveCfg = Release35|Any CPU
-		{DEC65744-D581-4007-87B2-BB0726EE0395}.Release35|Any CPU.Build.0 = Release35|Any CPU
-	EndGlobalSection
-	GlobalSection(SolutionProperties) = preSolution
-		HideSolutionNode = FALSE
-	EndGlobalSection
-EndGlobal


[07/51] [abbrv] [partial] Cleaning up and getting ready to development towards v4.8

Posted by sy...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/src/Lucene.Net.Codecs/Intblock/VariableIntBlockIndexInput.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Codecs/Intblock/VariableIntBlockIndexInput.cs b/src/Lucene.Net.Codecs/Intblock/VariableIntBlockIndexInput.cs
new file mode 100644
index 0000000..85c711a
--- /dev/null
+++ b/src/Lucene.Net.Codecs/Intblock/VariableIntBlockIndexInput.cs
@@ -0,0 +1,198 @@
+package org.apache.lucene.codecs.intblock;
+
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+/** Naive int block API that writes vInts.  This is
+ *  expected to give poor performance; it's really only for
+ *  testing the pluggability.  One should typically use pfor instead. */
+
+import java.io.IOException;
+
+import org.apache.lucene.codecs.sep.IntIndexInput;
+import org.apache.lucene.store.DataInput;
+import org.apache.lucene.store.IndexInput;
+
+// TODO: much of this can be shared code w/ the fixed case
+
+/** Abstract base class that reads variable-size blocks of ints
+ *  from an IndexInput.  While this is a simple approach, a
+ *  more performant approach would directly create an impl
+ *  of IntIndexInput inside Directory.  Wrapping a generic
+ *  IndexInput will likely cost performance.
+ *
+ * @lucene.experimental
+ */
+public abstract class VariableIntBlockIndexInput extends IntIndexInput {
+
+  protected final IndexInput in;
+  protected final int maxBlockSize;
+
+  protected VariableIntBlockIndexInput(final IndexInput in)  {
+    this.in = in;
+    maxBlockSize = in.readInt();
+  }
+
+  @Override
+  public IntIndexInput.Reader reader()  {
+    final int[] buffer = new int[maxBlockSize];
+    final IndexInput clone = in.clone();
+    // TODO: can this be simplified?
+    return new Reader(clone, buffer, this.getBlockReader(clone, buffer));
+  }
+
+  @Override
+  public void close()  {
+    in.close();
+  }
+
+  @Override
+  public IntIndexInput.Index index() {
+    return new Index();
+  }
+
+  protected abstract BlockReader getBlockReader(IndexInput in, int[] buffer) ;
+
+  /**
+   * Interface for variable-size block decoders.
+   * <p>
+   * Implementations should decode into the buffer in {@link #readBlock}.
+   */
+  public interface BlockReader {
+    public int readBlock() ;
+    public void seek(long pos) ;
+  }
+
+  private static class Reader extends IntIndexInput.Reader {
+    private final IndexInput in;
+
+    public final int[] pending;
+    int upto;
+
+    private bool seekPending;
+    private long pendingFP;
+    private int pendingUpto;
+    private long lastBlockFP;
+    private int blockSize;
+    private final BlockReader blockReader;
+
+    public Reader(final IndexInput in, final int[] pending, final BlockReader blockReader) {
+      this.in = in;
+      this.pending = pending;
+      this.blockReader = blockReader;
+    }
+
+    void seek(final long fp, final int upto) {
+      // TODO: should we do this in real-time, not lazy?
+      pendingFP = fp;
+      pendingUpto = upto;
+      Debug.Assert( pendingUpto >= 0: "pendingUpto=" + pendingUpto;
+      seekPending = true;
+    }
+
+    private final void maybeSeek()  {
+      if (seekPending) {
+        if (pendingFP != lastBlockFP) {
+          // need new block
+          in.seek(pendingFP);
+          blockReader.seek(pendingFP);
+          lastBlockFP = pendingFP;
+          blockSize = blockReader.readBlock();
+        }
+        upto = pendingUpto;
+
+        // TODO: if we were more clever when writing the
+        // index, such that a seek point wouldn't be written
+        // until the int encoder "committed", we could avoid
+        // this (likely minor) inefficiency:
+
+        // This is necessary for int encoders that are
+        // non-causal, ie must see future int values to
+        // encode the current ones.
+        while(upto >= blockSize) {
+          upto -= blockSize;
+          lastBlockFP = in.getFilePointer();
+          blockSize = blockReader.readBlock();
+        }
+        seekPending = false;
+      }
+    }
+
+    @Override
+    public int next()  {
+      this.maybeSeek();
+      if (upto == blockSize) {
+        lastBlockFP = in.getFilePointer();
+        blockSize = blockReader.readBlock();
+        upto = 0;
+      }
+
+      return pending[upto++];
+    }
+  }
+
+  private class Index extends IntIndexInput.Index {
+    private long fp;
+    private int upto;
+
+    @Override
+    public void read(final DataInput indexIn, final bool absolute)  {
+      if (absolute) {
+        upto = indexIn.readVInt();
+        fp = indexIn.readVLong();
+      } else {
+        final int uptoDelta = indexIn.readVInt();
+        if ((uptoDelta & 1) == 1) {
+          // same block
+          upto += uptoDelta >>> 1;
+        } else {
+          // new block
+          upto = uptoDelta >>> 1;
+          fp += indexIn.readVLong();
+        }
+      }
+      // TODO: we can't do this Debug.Assert( because non-causal
+      // int encoders can have upto over the buffer size
+      //Debug.Assert( upto < maxBlockSize: "upto=" + upto + " max=" + maxBlockSize;
+    }
+
+    @Override
+    public String toString() {
+      return "VarIntBlock.Index fp=" + fp + " upto=" + upto + " maxBlock=" + maxBlockSize;
+    }
+
+    @Override
+    public void seek(final IntIndexInput.Reader other)  {
+      ((Reader) other).seek(fp, upto);
+    }
+
+    @Override
+    public void copyFrom(final IntIndexInput.Index other) {
+      final Index idx = (Index) other;
+      fp = idx.fp;
+      upto = idx.upto;
+    }
+
+    @Override
+    public Index clone() {
+      Index other = new Index();
+      other.fp = fp;
+      other.upto = upto;
+      return other;
+    }
+  }
+}

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/src/Lucene.Net.Codecs/Intblock/VariableIntBlockIndexOutput.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Codecs/Intblock/VariableIntBlockIndexOutput.cs b/src/Lucene.Net.Codecs/Intblock/VariableIntBlockIndexOutput.cs
new file mode 100644
index 0000000..574b7f4
--- /dev/null
+++ b/src/Lucene.Net.Codecs/Intblock/VariableIntBlockIndexOutput.cs
@@ -0,0 +1,136 @@
+package org.apache.lucene.codecs.intblock;
+
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+/** Naive int block API that writes vInts.  This is
+ *  expected to give poor performance; it's really only for
+ *  testing the pluggability.  One should typically use pfor instead. */
+
+import java.io.IOException;
+
+import org.apache.lucene.codecs.sep.IntIndexOutput;
+import org.apache.lucene.store.DataOutput;
+import org.apache.lucene.store.IndexOutput;
+
+// TODO: much of this can be shared code w/ the fixed case
+
+/** Abstract base class that writes variable-size blocks of ints
+ *  to an IndexOutput.  While this is a simple approach, a
+ *  more performant approach would directly create an impl
+ *  of IntIndexOutput inside Directory.  Wrapping a generic
+ *  IndexInput will likely cost performance.
+ *
+ * @lucene.experimental
+ */
+public abstract class VariableIntBlockIndexOutput extends IntIndexOutput {
+
+  protected final IndexOutput out;
+
+  private int upto;
+  private bool hitExcDuringWrite;
+
+  // TODO what Var-Var codecs exist in practice... and what are there blocksizes like?
+  // if its less than 128 we should set that as max and use byte?
+
+  /** NOTE: maxBlockSize must be the maximum block size 
+   *  plus the max non-causal lookahead of your codec.  EG Simple9
+   *  requires lookahead=1 because on seeing the Nth value
+   *  it knows it must now encode the N-1 values before it. */
+  protected VariableIntBlockIndexOutput(IndexOutput out, int maxBlockSize)  {
+    this.out = out;
+    out.writeInt(maxBlockSize);
+  }
+
+  /** Called one value at a time.  Return the number of
+   *  buffered input values that have been written to out. */
+  protected abstract int add(int value) ;
+
+  @Override
+  public IntIndexOutput.Index index() {
+    return new Index();
+  }
+
+  private class Index extends IntIndexOutput.Index {
+    long fp;
+    int upto;
+    long lastFP;
+    int lastUpto;
+
+    @Override
+    public void mark()  {
+      fp = out.getFilePointer();
+      upto = VariableIntBlockIndexOutput.this.upto;
+    }
+
+    @Override
+    public void copyFrom(IntIndexOutput.Index other, bool copyLast)  {
+      Index idx = (Index) other;
+      fp = idx.fp;
+      upto = idx.upto;
+      if (copyLast) {
+        lastFP = fp;
+        lastUpto = upto;
+      }
+    }
+
+    @Override
+    public void write(DataOutput indexOut, bool absolute)  {
+      Debug.Assert( upto >= 0;
+      if (absolute) {
+        indexOut.writeVInt(upto);
+        indexOut.writeVLong(fp);
+      } else if (fp == lastFP) {
+        // same block
+        Debug.Assert( upto >= lastUpto;
+        int uptoDelta = upto - lastUpto;
+        indexOut.writeVInt(uptoDelta << 1 | 1);
+      } else {      
+        // new block
+        indexOut.writeVInt(upto << 1);
+        indexOut.writeVLong(fp - lastFP);
+      }
+      lastUpto = upto;
+      lastFP = fp;
+    }
+  }
+
+  @Override
+  public void write(int v)  {
+    hitExcDuringWrite = true;
+    upto -= add(v)-1;
+    hitExcDuringWrite = false;
+    Debug.Assert( upto >= 0;
+  }
+
+  @Override
+  public void close()  {
+    try {
+      if (!hitExcDuringWrite) {
+        // stuff 0s in until the "real" data is flushed:
+        int stuffed = 0;
+        while(upto > stuffed) {
+          upto -= add(0)-1;
+          Debug.Assert( upto >= 0;
+          stuffed += 1;
+        }
+      }
+    } finally {
+      out.close();
+    }
+  }
+}

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/src/Lucene.Net.Codecs/Lucene.Net.Codecs.csproj
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Codecs/Lucene.Net.Codecs.csproj b/src/Lucene.Net.Codecs/Lucene.Net.Codecs.csproj
new file mode 100644
index 0000000..3f014ce
--- /dev/null
+++ b/src/Lucene.Net.Codecs/Lucene.Net.Codecs.csproj
@@ -0,0 +1,138 @@
+<?xml version="1.0" encoding="utf-8"?>
+<Project ToolsVersion="12.0" DefaultTargets="Build" xmlns="http://schemas.microsoft.com/developer/msbuild/2003">
+  <Import Project="$(MSBuildExtensionsPath)\$(MSBuildToolsVersion)\Microsoft.Common.props" Condition="Exists('$(MSBuildExtensionsPath)\$(MSBuildToolsVersion)\Microsoft.Common.props')" />
+  <PropertyGroup>
+    <Configuration Condition=" '$(Configuration)' == '' ">Debug</Configuration>
+    <Platform Condition=" '$(Platform)' == '' ">AnyCPU</Platform>
+    <ProjectGuid>{3F79B6D4-4359-4F83-B64F-07F4F6262425}</ProjectGuid>
+    <OutputType>Library</OutputType>
+    <AppDesignerFolder>Properties</AppDesignerFolder>
+    <RootNamespace>Lucene.Net.Codecs</RootNamespace>
+    <AssemblyName>Lucene.Net.Codecs</AssemblyName>
+    <TargetFrameworkVersion>v4.5</TargetFrameworkVersion>
+    <FileAlignment>512</FileAlignment>
+    <TargetFrameworkProfile />
+  </PropertyGroup>
+  <PropertyGroup Condition=" '$(Configuration)|$(Platform)' == 'Debug|AnyCPU' ">
+    <DebugSymbols>true</DebugSymbols>
+    <DebugType>full</DebugType>
+    <Optimize>false</Optimize>
+    <OutputPath>bin\Debug\</OutputPath>
+    <DefineConstants>DEBUG;TRACE</DefineConstants>
+    <ErrorReport>prompt</ErrorReport>
+    <WarningLevel>4</WarningLevel>
+  </PropertyGroup>
+  <PropertyGroup Condition=" '$(Configuration)|$(Platform)' == 'Release|AnyCPU' ">
+    <DebugType>pdbonly</DebugType>
+    <Optimize>true</Optimize>
+    <OutputPath>bin\Release\</OutputPath>
+    <DefineConstants>TRACE</DefineConstants>
+    <ErrorReport>prompt</ErrorReport>
+    <WarningLevel>4</WarningLevel>
+  </PropertyGroup>
+  <ItemGroup>
+    <Reference Include="System" />
+    <Reference Include="System.Core" />
+    <Reference Include="System.Xml.Linq" />
+    <Reference Include="System.Data.DataSetExtensions" />
+    <Reference Include="Microsoft.CSharp" />
+    <Reference Include="System.Data" />
+    <Reference Include="System.Xml" />
+  </ItemGroup>
+  <ItemGroup>
+    <Compile Include="Appending\AppendingCodec.cs" />
+    <Compile Include="Appending\AppendingPostingsFormat.cs" />
+    <Compile Include="Appending\AppendingTermsReader.cs" />
+    <Compile Include="BlockTerms\BlockTermsFieldAndTerm.cs" />
+    <Compile Include="BlockTerms\BlockTermsReader.cs" />
+    <Compile Include="BlockTerms\BlockTermsWriter.cs" />
+    <Compile Include="BlockTerms\FixedGapTermsIndexReader.cs" />
+    <Compile Include="BlockTerms\FixedGapTermsIndexWriter.cs" />
+    <Compile Include="BlockTerms\TermsIndexReaderBase.cs" />
+    <Compile Include="BlockTerms\TermsIndexWriterBase.cs" />
+    <Compile Include="BlockTerms\VariableGapTermsIndexReader.cs" />
+    <Compile Include="BlockTerms\VariableGapTermsIndexWriter.cs" />
+    <Compile Include="Bloom\BloomFilterFactory.cs" />
+    <Compile Include="Bloom\BloomFilteringPostingsFormat.cs" />
+    <Compile Include="Bloom\DefaultBloomFilterFactory.cs" />
+    <Compile Include="Bloom\FuzzySet.cs" />
+    <Compile Include="Bloom\HashFunction.cs" />
+    <Compile Include="Bloom\MurmurHash2.cs" />
+    <Compile Include="DiskDV\DiskDocValuesFormat.cs" />
+    <Compile Include="DiskDV\DiskDocValuesProducer.cs" />
+    <Compile Include="DiskDV\DiskNormsFormat.cs" />
+    <Compile Include="Intblock\FixedIntBlockIndexInput.cs" />
+    <Compile Include="Intblock\FixedIntBlockIndexOutput.cs" />
+    <Compile Include="Intblock\IBlockReader.cs" />
+    <Compile Include="Intblock\Index.cs" />
+    <Compile Include="Intblock\Reader.cs" />
+    <Compile Include="Intblock\VariableIntBlockIndexInput.cs" />
+    <Compile Include="Intblock\VariableIntBlockIndexOutput.cs" />
+    <Compile Include="Memory\DirectDocValuesConsumer.cs" />
+    <Compile Include="Memory\DirectDocValuesFormat.cs" />
+    <Compile Include="Memory\DirectDocValuesProducer.cs" />
+    <Compile Include="Memory\DirectPostingsFormat.cs" />
+    <Compile Include="Memory\FSTOrdPostingsFormat.cs" />
+    <Compile Include="Memory\FSTOrdPulsing41PostingsFormat.cs" />
+    <Compile Include="Memory\FSTOrdTermsReader.cs" />
+    <Compile Include="Memory\FSTOrdTermsWriter.cs" />
+    <Compile Include="Memory\FSTPostingsFormat.cs" />
+    <Compile Include="Memory\FSTPulsing41PostingsFormat.cs" />
+    <Compile Include="Memory\FSTTermOutputs.cs" />
+    <Compile Include="Memory\FSTTermsReader.cs" />
+    <Compile Include="Memory\FSTTermsWriter.cs" />
+    <Compile Include="Memory\MemoryDocValuesConsumer.cs" />
+    <Compile Include="Memory\MemoryDocValuesFormat.cs" />
+    <Compile Include="Memory\MemoryDocValuesProducer.cs" />
+    <Compile Include="Memory\MemoryPostingsFormat.cs" />
+    <Compile Include="Properties\AssemblyInfo.cs" />
+    <Compile Include="Pulsing\Pulsing41PostingsFormat.cs" />
+    <Compile Include="Pulsing\PulsingPostingsFormat.cs" />
+    <Compile Include="Pulsing\PulsingPostingsReader.cs" />
+    <Compile Include="Pulsing\PulsingPostingsWriter.cs" />
+    <Compile Include="Sep\IntIndexInput.cs" />
+    <Compile Include="Sep\IntIndexOutput.cs" />
+    <Compile Include="Sep\IntStreamFactory.cs" />
+    <Compile Include="Sep\SepPostingsReader.cs" />
+    <Compile Include="Sep\SepPostingsWriter.cs" />
+    <Compile Include="Sep\SepSkipListReader.cs" />
+    <Compile Include="Sep\SepSkipListWriter.cs" />
+    <Compile Include="SimpleText\SimpleTextCodec.cs" />
+    <Compile Include="SimpleText\SimpleTextDocValuesFormat.cs" />
+    <Compile Include="SimpleText\SimpleTextDocValuesReader.cs" />
+    <Compile Include="SimpleText\SimpleTextDocValuesWriter.cs" />
+    <Compile Include="SimpleText\SimpleTextFieldInfosFormat.cs" />
+    <Compile Include="SimpleText\SimpleTextFieldInfosReader.cs" />
+    <Compile Include="SimpleText\SimpleTextFieldInfosWriter.cs" />
+    <Compile Include="SimpleText\SimpleTextFieldsReader.cs" />
+    <Compile Include="SimpleText\SimpleTextFieldsWriter.cs" />
+    <Compile Include="SimpleText\SimpleTextLiveDocsFormat.cs" />
+    <Compile Include="SimpleText\SimpleTextNormsFormat.cs" />
+    <Compile Include="SimpleText\SimpleTextPostingsFormat.cs" />
+    <Compile Include="SimpleText\SimpleTextSegmentInfoFormat.cs" />
+    <Compile Include="SimpleText\SimpleTextSegmentInfoReader.cs" />
+    <Compile Include="SimpleText\SimpleTextSegmentInfoWriter.cs" />
+    <Compile Include="SimpleText\SimpleTextStoredFieldsFormat.cs" />
+    <Compile Include="SimpleText\SimpleTextStoredFieldsReader.cs" />
+    <Compile Include="SimpleText\SimpleTextStoredFieldsWriter.cs" />
+    <Compile Include="SimpleText\SimpleTextTermVectorsFormat.cs" />
+    <Compile Include="SimpleText\SimpleTextTermVectorsReader.cs" />
+    <Compile Include="SimpleText\SimpleTextTermVectorsWriter.cs" />
+    <Compile Include="SimpleText\SimpleTextUtil.cs" />
+  </ItemGroup>
+  <ItemGroup />
+  <ItemGroup>
+    <ProjectReference Include="..\core\Lucene.Net.csproj">
+      <Project>{5d4ad9be-1ffb-41ab-9943-25737971bf57}</Project>
+      <Name>Lucene.Net</Name>
+    </ProjectReference>
+  </ItemGroup>
+  <Import Project="$(MSBuildToolsPath)\Microsoft.CSharp.targets" />
+  <!-- To modify your build process, add your task inside one of the targets below and uncomment it. 
+       Other similar extension points exist, see Microsoft.Common.targets.
+  <Target Name="BeforeBuild">
+  </Target>
+  <Target Name="AfterBuild">
+  </Target>
+  -->
+</Project>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/src/Lucene.Net.Codecs/Lucene.Net.Codecs.sln
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Codecs/Lucene.Net.Codecs.sln b/src/Lucene.Net.Codecs/Lucene.Net.Codecs.sln
new file mode 100644
index 0000000..3cf5780
--- /dev/null
+++ b/src/Lucene.Net.Codecs/Lucene.Net.Codecs.sln
@@ -0,0 +1,26 @@
+
+Microsoft Visual Studio Solution File, Format Version 12.00
+# Visual Studio 2013
+VisualStudioVersion = 12.0.30110.0
+MinimumVisualStudioVersion = 10.0.40219.1
+Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net.Codecs", "Lucene.Net.Codecs.csproj", "{3F79B6D4-4359-4F83-B64F-07F4F6262425}"
+EndProject
+Project("{FAE04EC0-301F-11D3-BF4B-00C04F79EFBC}") = "Lucene.Net", "..\Lucene.Net.Core\Lucene.Net.csproj", "{5D4AD9BE-1FFB-41AB-9943-25737971BF57}"
+EndProject
+Global
+	GlobalSection(SolutionConfigurationPlatforms) = preSolution
+		Debug|Any CPU = Debug|Any CPU
+		Release|Any CPU = Release|Any CPU
+	EndGlobalSection
+	GlobalSection(ProjectConfigurationPlatforms) = postSolution
+		{3F79B6D4-4359-4F83-B64F-07F4F6262425}.Debug|Any CPU.ActiveCfg = Debug|Any CPU
+		{3F79B6D4-4359-4F83-B64F-07F4F6262425}.Debug|Any CPU.Build.0 = Debug|Any CPU
+		{3F79B6D4-4359-4F83-B64F-07F4F6262425}.Release|Any CPU.ActiveCfg = Release|Any CPU
+		{3F79B6D4-4359-4F83-B64F-07F4F6262425}.Release|Any CPU.Build.0 = Release|Any CPU
+		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Debug|Any CPU.ActiveCfg = Debug|x86
+		{5D4AD9BE-1FFB-41AB-9943-25737971BF57}.Release|Any CPU.ActiveCfg = Release|x86
+	EndGlobalSection
+	GlobalSection(SolutionProperties) = preSolution
+		HideSolutionNode = FALSE
+	EndGlobalSection
+EndGlobal

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/src/Lucene.Net.Codecs/Memory/DirectDocValuesConsumer.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Codecs/Memory/DirectDocValuesConsumer.cs b/src/Lucene.Net.Codecs/Memory/DirectDocValuesConsumer.cs
new file mode 100644
index 0000000..2e7e013
--- /dev/null
+++ b/src/Lucene.Net.Codecs/Memory/DirectDocValuesConsumer.cs
@@ -0,0 +1,304 @@
+package org.apache.lucene.codecs.memory;
+
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+import java.io.IOException;
+import java.util.Iterator;
+
+import org.apache.lucene.codecs.CodecUtil;
+import org.apache.lucene.codecs.DocValuesConsumer;
+import org.apache.lucene.index.FieldInfo;
+import org.apache.lucene.index.IndexFileNames;
+import org.apache.lucene.index.SegmentWriteState;
+import org.apache.lucene.store.IndexOutput;
+import org.apache.lucene.util.BytesRef;
+import org.apache.lucene.util.IOUtils;
+
+import static org.apache.lucene.codecs.memory.DirectDocValuesProducer.VERSION_CURRENT;
+import static org.apache.lucene.codecs.memory.DirectDocValuesProducer.BYTES;
+import static org.apache.lucene.codecs.memory.DirectDocValuesProducer.SORTED;
+import static org.apache.lucene.codecs.memory.DirectDocValuesProducer.SORTED_SET;
+import static org.apache.lucene.codecs.memory.DirectDocValuesProducer.NUMBER;
+
+/**
+ * Writer for {@link DirectDocValuesFormat}
+ */
+
+class DirectDocValuesConsumer extends DocValuesConsumer {
+  IndexOutput data, meta;
+  final int maxDoc;
+
+  DirectDocValuesConsumer(SegmentWriteState state, String dataCodec, String dataExtension, String metaCodec, String metaExtension)  {
+    maxDoc = state.segmentInfo.getDocCount();
+    bool success = false;
+    try {
+      String dataName = IndexFileNames.segmentFileName(state.segmentInfo.name, state.segmentSuffix, dataExtension);
+      data = state.directory.createOutput(dataName, state.context);
+      CodecUtil.writeHeader(data, dataCodec, VERSION_CURRENT);
+      String metaName = IndexFileNames.segmentFileName(state.segmentInfo.name, state.segmentSuffix, metaExtension);
+      meta = state.directory.createOutput(metaName, state.context);
+      CodecUtil.writeHeader(meta, metaCodec, VERSION_CURRENT);
+      success = true;
+    } finally {
+      if (!success) {
+        IOUtils.closeWhileHandlingException(this);
+      }
+    }
+  }
+
+  @Override
+  public void addNumericField(FieldInfo field, Iterable<Number> values)  {
+    meta.writeVInt(field.number);
+    meta.writeByte(NUMBER);
+    addNumericFieldValues(field, values);
+  }
+
+  private void addNumericFieldValues(FieldInfo field, Iterable<Number> values)  {
+    meta.writeLong(data.getFilePointer());
+    long minValue = Long.MAX_VALUE;
+    long maxValue = Long.MIN_VALUE;
+    bool missing = false;
+
+    long count = 0;
+    for (Number nv : values) {
+      if (nv != null) {
+        long v = nv.longValue();
+        minValue = Math.min(minValue, v);
+        maxValue = Math.max(maxValue, v);
+      } else {
+        missing = true;
+      }
+      count++;
+      if (count >= DirectDocValuesFormat.MAX_SORTED_SET_ORDS) {
+        throw new IllegalArgumentException("DocValuesField \"" + field.name + "\" is too large, must be <= " + DirectDocValuesFormat.MAX_SORTED_SET_ORDS + " values/total ords");
+      }
+    }
+    meta.writeInt((int) count);
+    
+    if (missing) {
+      long start = data.getFilePointer();
+      writeMissingBitset(values);
+      meta.writeLong(start);
+      meta.writeLong(data.getFilePointer() - start);
+    } else {
+      meta.writeLong(-1L);
+    }
+
+    byte byteWidth;
+    if (minValue >= Byte.MIN_VALUE && maxValue <= Byte.MAX_VALUE) {
+      byteWidth = 1;
+    } else if (minValue >= Short.MIN_VALUE && maxValue <= Short.MAX_VALUE) {
+      byteWidth = 2;
+    } else if (minValue >= Integer.MIN_VALUE && maxValue <= Integer.MAX_VALUE) {
+      byteWidth = 4;
+    } else {
+      byteWidth = 8;
+    }
+    meta.writeByte(byteWidth);
+
+    for (Number nv : values) {
+      long v;
+      if (nv != null) {
+        v = nv.longValue();
+      } else {
+        v = 0;
+      }
+
+      switch(byteWidth) {
+      case 1:
+        data.writeByte((byte) v);
+        break;
+      case 2:
+        data.writeShort((short) v);
+        break;
+      case 4:
+        data.writeInt((int) v);
+        break;
+      case 8:
+        data.writeLong(v);
+        break;
+      }
+    }
+  }
+  
+  @Override
+  public void close()  {
+    bool success = false;
+    try {
+      if (meta != null) {
+        meta.writeVInt(-1); // write EOF marker
+        CodecUtil.writeFooter(meta); // write checksum
+      }
+      if (data != null) {
+        CodecUtil.writeFooter(data);
+      }
+      success = true;
+    } finally {
+      if (success) {
+        IOUtils.close(data, meta);
+      } else {
+        IOUtils.closeWhileHandlingException(data, meta);
+      }
+      data = meta = null;
+    }
+  }
+
+  @Override
+  public void addBinaryField(FieldInfo field, final Iterable<BytesRef> values)  {
+    meta.writeVInt(field.number);
+    meta.writeByte(BYTES);
+    addBinaryFieldValues(field, values);
+  }
+
+  private void addBinaryFieldValues(FieldInfo field, final Iterable<BytesRef> values)  {
+    // write the byte[] data
+    final long startFP = data.getFilePointer();
+    bool missing = false;
+    long totalBytes = 0;
+    int count = 0;
+    for(BytesRef v : values) {
+      if (v != null) {
+        data.writeBytes(v.bytes, v.offset, v.length);
+        totalBytes += v.length;
+        if (totalBytes > DirectDocValuesFormat.MAX_TOTAL_BYTES_LENGTH) {
+          throw new IllegalArgumentException("DocValuesField \"" + field.name + "\" is too large, cannot have more than DirectDocValuesFormat.MAX_TOTAL_BYTES_LENGTH (" + DirectDocValuesFormat.MAX_TOTAL_BYTES_LENGTH + ") bytes");
+        }
+      } else {
+        missing = true;
+      }
+      count++;
+    }
+
+    meta.writeLong(startFP);
+    meta.writeInt((int) totalBytes);
+    meta.writeInt(count);
+    if (missing) {
+      long start = data.getFilePointer();
+      writeMissingBitset(values);
+      meta.writeLong(start);
+      meta.writeLong(data.getFilePointer() - start);
+    } else {
+      meta.writeLong(-1L);
+    }
+    
+    int addr = 0;
+    for (BytesRef v : values) {
+      data.writeInt(addr);
+      if (v != null) {
+        addr += v.length;
+      }
+    }
+    data.writeInt(addr);
+  }
+  
+  // TODO: in some cases representing missing with minValue-1 wouldn't take up additional space and so on,
+  // but this is very simple, and algorithms only check this for values of 0 anyway (doesnt slow down normal decode)
+  void writeMissingBitset(Iterable<?> values)  {
+    long bits = 0;
+    int count = 0;
+    for (Object v : values) {
+      if (count == 64) {
+        data.writeLong(bits);
+        count = 0;
+        bits = 0;
+      }
+      if (v != null) {
+        bits |= 1L << (count & 0x3f);
+      }
+      count++;
+    }
+    if (count > 0) {
+      data.writeLong(bits);
+    }
+  }
+
+  @Override
+  public void addSortedField(FieldInfo field, Iterable<BytesRef> values, Iterable<Number> docToOrd)  {
+    meta.writeVInt(field.number);
+    meta.writeByte(SORTED);
+
+    // write the ordinals as numerics
+    addNumericFieldValues(field, docToOrd);
+    
+    // write the values as binary
+    addBinaryFieldValues(field, values);
+  }
+
+  // note: this might not be the most efficient... but its fairly simple
+  @Override
+  public void addSortedSetField(FieldInfo field, Iterable<BytesRef> values, final Iterable<Number> docToOrdCount, final Iterable<Number> ords)  {
+    meta.writeVInt(field.number);
+    meta.writeByte(SORTED_SET);
+
+    // First write docToOrdCounts, except we "aggregate" the
+    // counts so they turn into addresses, and add a final
+    // value = the total aggregate:
+    addNumericFieldValues(field, new Iterable<Number>() {
+
+        // Just aggregates the count values so they become
+        // "addresses", and adds one more value in the end
+        // (the final sum):
+
+        @Override
+        public Iterator<Number> iterator() {
+          final Iterator<Number> iter = docToOrdCount.iterator();
+
+          return new Iterator<Number>() {
+
+            long sum;
+            bool ended;
+
+            @Override
+            public bool hasNext() {
+              return iter.hasNext() || !ended;
+            }
+
+            @Override
+            public Number next() {
+              long toReturn = sum;
+
+              if (iter.hasNext()) {
+                Number n = iter.next();
+                if (n != null) {
+                  sum += n.longValue();
+                }
+              } else if (!ended) {
+                ended = true;
+              } else {
+                Debug.Assert( false;
+              }
+
+              return toReturn;
+            }
+
+            @Override
+            public void remove() {
+              throw new UnsupportedOperationException();
+            }
+          };
+        }
+      });
+
+    // Write ordinals for all docs, appended into one big
+    // numerics:
+    addNumericFieldValues(field, ords);
+      
+    // write the values as binary
+    addBinaryFieldValues(field, values);
+  }
+}

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/src/Lucene.Net.Codecs/Memory/DirectDocValuesFormat.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Codecs/Memory/DirectDocValuesFormat.cs b/src/Lucene.Net.Codecs/Memory/DirectDocValuesFormat.cs
new file mode 100644
index 0000000..1f89e43
--- /dev/null
+++ b/src/Lucene.Net.Codecs/Memory/DirectDocValuesFormat.cs
@@ -0,0 +1,83 @@
+package org.apache.lucene.codecs.memory;
+
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+import java.io.IOException;
+
+import org.apache.lucene.codecs.DocValuesConsumer;
+import org.apache.lucene.codecs.DocValuesFormat;
+import org.apache.lucene.codecs.DocValuesProducer;
+import org.apache.lucene.document.SortedSetDocValuesField; // javadocs
+import org.apache.lucene.index.SegmentReadState;
+import org.apache.lucene.index.SegmentWriteState;
+import org.apache.lucene.util.ArrayUtil;
+
+/** In-memory docvalues format that does no (or very little)
+ *  compression.  Indexed values are stored on disk, but
+ *  then at search time all values are loaded into memory as
+ *  simple java arrays.  For numeric values, it uses
+ *  byte[], short[], int[], long[] as necessary to fit the
+ *  range of the values.  For binary values, there is an int
+ *  (4 bytes) overhead per value.
+ *
+ *  <p>Limitations:
+ *  <ul>
+ *    <li>For binary and sorted fields the total space
+ *        required for all binary values cannot exceed about
+ *        2.1 GB (see #MAX_TOTAL_BYTES_LENGTH).</li>
+ *
+ *    <li>For sorted set fields, the sum of the size of each
+ *        document's set of values cannot exceed about 2.1 B
+ *        values (see #MAX_SORTED_SET_ORDS).  For example,
+ *        if every document has 10 values (10 instances of
+ *        {@link SortedSetDocValuesField}) added, then no
+ *        more than ~210 M documents can be added to one
+ *        segment. </li>
+ *  </ul> */
+
+public class DirectDocValuesFormat extends DocValuesFormat {
+
+  /** The sum of all byte lengths for binary field, or for
+   *  the unique values in sorted or sorted set fields, cannot
+   *  exceed this. */
+  public final static int MAX_TOTAL_BYTES_LENGTH = ArrayUtil.MAX_ARRAY_LENGTH;
+
+  /** The sum of the number of values across all documents
+   *  in a sorted set field cannot exceed this. */
+  public final static int MAX_SORTED_SET_ORDS = ArrayUtil.MAX_ARRAY_LENGTH;
+
+  /** Sole constructor. */
+  public DirectDocValuesFormat() {
+    super("Direct");
+  }
+  
+  @Override
+  public DocValuesConsumer fieldsConsumer(SegmentWriteState state)  {
+    return new DirectDocValuesConsumer(state, DATA_CODEC, DATA_EXTENSION, METADATA_CODEC, METADATA_EXTENSION);
+  }
+  
+  @Override
+  public DocValuesProducer fieldsProducer(SegmentReadState state)  {
+    return new DirectDocValuesProducer(state, DATA_CODEC, DATA_EXTENSION, METADATA_CODEC, METADATA_EXTENSION);
+  }
+  
+  static final String DATA_CODEC = "DirectDocValuesData";
+  static final String DATA_EXTENSION = "dvdd";
+  static final String METADATA_CODEC = "DirectDocValuesMetadata";
+  static final String METADATA_EXTENSION = "dvdm";
+}

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1da1cb5b/src/Lucene.Net.Codecs/Memory/DirectDocValuesProducer.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Codecs/Memory/DirectDocValuesProducer.cs b/src/Lucene.Net.Codecs/Memory/DirectDocValuesProducer.cs
new file mode 100644
index 0000000..a95f384
--- /dev/null
+++ b/src/Lucene.Net.Codecs/Memory/DirectDocValuesProducer.cs
@@ -0,0 +1,511 @@
+package org.apache.lucene.codecs.memory;
+
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+import java.io.IOException;
+import java.util.HashMap;
+import java.util.Map;
+import java.util.concurrent.atomic.AtomicLong;
+
+import org.apache.lucene.codecs.CodecUtil;
+import org.apache.lucene.codecs.DocValuesProducer;
+import org.apache.lucene.index.BinaryDocValues;
+import org.apache.lucene.index.CorruptIndexException;
+import org.apache.lucene.index.DocValues;
+import org.apache.lucene.index.FieldInfo;
+import org.apache.lucene.index.IndexFileNames;
+import org.apache.lucene.index.NumericDocValues;
+import org.apache.lucene.index.RandomAccessOrds;
+import org.apache.lucene.index.SegmentReadState;
+import org.apache.lucene.index.SortedDocValues;
+import org.apache.lucene.index.SortedSetDocValues;
+import org.apache.lucene.store.ChecksumIndexInput;
+import org.apache.lucene.store.IndexInput;
+import org.apache.lucene.util.Bits;
+import org.apache.lucene.util.BytesRef;
+import org.apache.lucene.util.FixedBitSet;
+import org.apache.lucene.util.IOUtils;
+import org.apache.lucene.util.RamUsageEstimator;
+
+/**
+ * Reader for {@link DirectDocValuesFormat}
+ */
+
+class DirectDocValuesProducer extends DocValuesProducer {
+  // metadata maps (just file pointers and minimal stuff)
+  private final Map<Integer,NumericEntry> numerics = new HashMap<>();
+  private final Map<Integer,BinaryEntry> binaries = new HashMap<>();
+  private final Map<Integer,SortedEntry> sorteds = new HashMap<>();
+  private final Map<Integer,SortedSetEntry> sortedSets = new HashMap<>();
+  private final IndexInput data;
+  
+  // ram instances we have already loaded
+  private final Map<Integer,NumericDocValues> numericInstances = 
+      new HashMap<>();
+  private final Map<Integer,BinaryDocValues> binaryInstances =
+      new HashMap<>();
+  private final Map<Integer,SortedDocValues> sortedInstances =
+      new HashMap<>();
+  private final Map<Integer,SortedSetRawValues> sortedSetInstances =
+      new HashMap<>();
+  private final Map<Integer,Bits> docsWithFieldInstances = new HashMap<>();
+  
+  private final int maxDoc;
+  private final AtomicLong ramBytesUsed;
+  private final int version;
+  
+  static final byte NUMBER = 0;
+  static final byte BYTES = 1;
+  static final byte SORTED = 2;
+  static final byte SORTED_SET = 3;
+
+  static final int VERSION_START = 0;
+  static final int VERSION_CHECKSUM = 1;
+  static final int VERSION_CURRENT = VERSION_CHECKSUM;
+    
+  DirectDocValuesProducer(SegmentReadState state, String dataCodec, String dataExtension, String metaCodec, String metaExtension)  {
+    maxDoc = state.segmentInfo.getDocCount();
+    String metaName = IndexFileNames.segmentFileName(state.segmentInfo.name, state.segmentSuffix, metaExtension);
+    // read in the entries from the metadata file.
+    ChecksumIndexInput in = state.directory.openChecksumInput(metaName, state.context);
+    ramBytesUsed = new AtomicLong(RamUsageEstimator.shallowSizeOfInstance(getClass()));
+    bool success = false;
+    try {
+      version = CodecUtil.checkHeader(in, metaCodec, 
+                                      VERSION_START,
+                                      VERSION_CURRENT);
+      readFields(in);
+
+      if (version >= VERSION_CHECKSUM) {
+        CodecUtil.checkFooter(in);
+      } else {
+        CodecUtil.checkEOF(in);
+      }
+      success = true;
+    } finally {
+      if (success) {
+        IOUtils.close(in);
+      } else {
+        IOUtils.closeWhileHandlingException(in);
+      }
+    }
+
+    success = false;
+    try {
+      String dataName = IndexFileNames.segmentFileName(state.segmentInfo.name, state.segmentSuffix, dataExtension);
+      data = state.directory.openInput(dataName, state.context);
+      final int version2 = CodecUtil.checkHeader(data, dataCodec, 
+                                                 VERSION_START,
+                                                 VERSION_CURRENT);
+      if (version != version2) {
+        throw new CorruptIndexException("Format versions mismatch");
+      }
+
+      success = true;
+    } finally {
+      if (!success) {
+        IOUtils.closeWhileHandlingException(this.data);
+      }
+    }
+  }
+
+  private NumericEntry readNumericEntry(IndexInput meta)  {
+    NumericEntry entry = new NumericEntry();
+    entry.offset = meta.readLong();
+    entry.count = meta.readInt();
+    entry.missingOffset = meta.readLong();
+    if (entry.missingOffset != -1) {
+      entry.missingBytes = meta.readLong();
+    } else {
+      entry.missingBytes = 0;
+    }
+    entry.byteWidth = meta.readByte();
+
+    return entry;
+  }
+
+  private BinaryEntry readBinaryEntry(IndexInput meta)  {
+    BinaryEntry entry = new BinaryEntry();
+    entry.offset = meta.readLong();
+    entry.numBytes = meta.readInt();
+    entry.count = meta.readInt();
+    entry.missingOffset = meta.readLong();
+    if (entry.missingOffset != -1) {
+      entry.missingBytes = meta.readLong();
+    } else {
+      entry.missingBytes = 0;
+    }
+
+    return entry;
+  }
+
+  private SortedEntry readSortedEntry(IndexInput meta)  {
+    SortedEntry entry = new SortedEntry();
+    entry.docToOrd = readNumericEntry(meta);
+    entry.values = readBinaryEntry(meta);
+    return entry;
+  }
+
+  private SortedSetEntry readSortedSetEntry(IndexInput meta)  {
+    SortedSetEntry entry = new SortedSetEntry();
+    entry.docToOrdAddress = readNumericEntry(meta);
+    entry.ords = readNumericEntry(meta);
+    entry.values = readBinaryEntry(meta);
+    return entry;
+  }
+
+  private void readFields(IndexInput meta)  {
+    int fieldNumber = meta.readVInt();
+    while (fieldNumber != -1) {
+      int fieldType = meta.readByte();
+      if (fieldType == NUMBER) {
+        numerics.put(fieldNumber, readNumericEntry(meta));
+      } else if (fieldType == BYTES) {
+        binaries.put(fieldNumber, readBinaryEntry(meta));
+      } else if (fieldType == SORTED) {
+        sorteds.put(fieldNumber, readSortedEntry(meta));
+      } else if (fieldType == SORTED_SET) {
+        sortedSets.put(fieldNumber, readSortedSetEntry(meta));
+      } else {
+        throw new CorruptIndexException("invalid entry type: " + fieldType + ", input=" + meta);
+      }
+      fieldNumber = meta.readVInt();
+    }
+  }
+
+  @Override
+  public long ramBytesUsed() {
+    return ramBytesUsed.get();
+  }
+  
+  @Override
+  public void checkIntegrity()  {
+    if (version >= VERSION_CHECKSUM) {
+      CodecUtil.checksumEntireFile(data);
+    }
+  }
+
+  @Override
+  public synchronized NumericDocValues getNumeric(FieldInfo field)  {
+    NumericDocValues instance = numericInstances.get(field.number);
+    if (instance == null) {
+      // Lazy load
+      instance = loadNumeric(numerics.get(field.number));
+      numericInstances.put(field.number, instance);
+    }
+    return instance;
+  }
+  
+  private NumericDocValues loadNumeric(NumericEntry entry)  {
+    data.seek(entry.offset + entry.missingBytes);
+    switch (entry.byteWidth) {
+    case 1:
+      {
+        final byte[] values = new byte[entry.count];
+        data.readBytes(values, 0, entry.count);
+        ramBytesUsed.addAndGet(RamUsageEstimator.sizeOf(values));
+        return new NumericDocValues() {
+          @Override
+          public long get(int idx) {
+            return values[idx];
+          }
+        };
+      }
+
+    case 2:
+      {
+        final short[] values = new short[entry.count];
+        for(int i=0;i<entry.count;i++) {
+          values[i] = data.readShort();
+        }
+        ramBytesUsed.addAndGet(RamUsageEstimator.sizeOf(values));
+        return new NumericDocValues() {
+          @Override
+          public long get(int idx) {
+            return values[idx];
+          }
+        };
+      }
+
+    case 4:
+      {
+        final int[] values = new int[entry.count];
+        for(int i=0;i<entry.count;i++) {
+          values[i] = data.readInt();
+        }
+        ramBytesUsed.addAndGet(RamUsageEstimator.sizeOf(values));
+        return new NumericDocValues() {
+          @Override
+          public long get(int idx) {
+            return values[idx];
+          }
+        };
+      }
+
+    case 8:
+      {
+        final long[] values = new long[entry.count];
+        for(int i=0;i<entry.count;i++) {
+          values[i] = data.readLong();
+        }
+        ramBytesUsed.addAndGet(RamUsageEstimator.sizeOf(values));
+        return new NumericDocValues() {
+          @Override
+          public long get(int idx) {
+            return values[idx];
+          }
+        };
+      }
+    
+    default:
+      throw new Debug.Assert(ionError();
+    }
+  }
+
+  @Override
+  public synchronized BinaryDocValues getBinary(FieldInfo field)  {
+    BinaryDocValues instance = binaryInstances.get(field.number);
+    if (instance == null) {
+      // Lazy load
+      instance = loadBinary(binaries.get(field.number));
+      binaryInstances.put(field.number, instance);
+    }
+    return instance;
+  }
+  
+  private BinaryDocValues loadBinary(BinaryEntry entry)  {
+    data.seek(entry.offset);
+    final byte[] bytes = new byte[entry.numBytes];
+    data.readBytes(bytes, 0, entry.numBytes);
+    data.seek(entry.offset + entry.numBytes + entry.missingBytes);
+
+    final int[] address = new int[entry.count+1];
+    for(int i=0;i<entry.count;i++) {
+      address[i] = data.readInt();
+    }
+    address[entry.count] = data.readInt();
+
+    ramBytesUsed.addAndGet(RamUsageEstimator.sizeOf(bytes) + RamUsageEstimator.sizeOf(address));
+
+    return new BinaryDocValues() {
+      @Override
+      public void get(int docID, BytesRef result) {
+        result.bytes = bytes;
+        result.offset = address[docID];
+        result.length = address[docID+1] - result.offset;
+      };
+    };
+  }
+  
+  @Override
+  public synchronized SortedDocValues getSorted(FieldInfo field)  {
+    SortedDocValues instance = sortedInstances.get(field.number);
+    if (instance == null) {
+      // Lazy load
+      instance = loadSorted(field);
+      sortedInstances.put(field.number, instance);
+    }
+    return instance;
+  }
+
+  private SortedDocValues loadSorted(FieldInfo field)  {
+    final SortedEntry entry = sorteds.get(field.number);
+    final NumericDocValues docToOrd = loadNumeric(entry.docToOrd);
+    final BinaryDocValues values = loadBinary(entry.values);
+
+    return new SortedDocValues() {
+
+      @Override
+      public int getOrd(int docID) {
+        return (int) docToOrd.get(docID);
+      }
+
+      @Override
+      public void lookupOrd(int ord, BytesRef result) {
+        values.get(ord, result);
+      }
+
+      @Override
+      public int getValueCount() {
+        return entry.values.count;
+      }
+
+      // Leave lookupTerm to super's binary search
+
+      // Leave termsEnum to super
+    };
+  }
+
+  @Override
+  public synchronized SortedSetDocValues getSortedSet(FieldInfo field)  {
+    SortedSetRawValues instance = sortedSetInstances.get(field.number);
+    final SortedSetEntry entry = sortedSets.get(field.number);
+    if (instance == null) {
+      // Lazy load
+      instance = loadSortedSet(entry);
+      sortedSetInstances.put(field.number, instance);
+    }
+
+    final NumericDocValues docToOrdAddress = instance.docToOrdAddress;
+    final NumericDocValues ords = instance.ords;
+    final BinaryDocValues values = instance.values;
+
+    // Must make a new instance since the iterator has state:
+    return new RandomAccessOrds() {
+      int ordStart;
+      int ordUpto;
+      int ordLimit;
+
+      @Override
+      public long nextOrd() {
+        if (ordUpto == ordLimit) {
+          return NO_MORE_ORDS;
+        } else {
+          return ords.get(ordUpto++);
+        }
+      }
+      
+      @Override
+      public void setDocument(int docID) {
+        ordStart = ordUpto = (int) docToOrdAddress.get(docID);
+        ordLimit = (int) docToOrdAddress.get(docID+1);
+      }
+
+      @Override
+      public void lookupOrd(long ord, BytesRef result) {
+        values.get((int) ord, result);
+      }
+
+      @Override
+      public long getValueCount() {
+        return entry.values.count;
+      }
+
+      @Override
+      public long ordAt(int index) {
+        return ords.get(ordStart + index);
+      }
+
+      @Override
+      public int cardinality() {
+        return ordLimit - ordStart;
+      }
+
+      // Leave lookupTerm to super's binary search
+
+      // Leave termsEnum to super
+    };
+  }
+  
+  private SortedSetRawValues loadSortedSet(SortedSetEntry entry)  {
+    SortedSetRawValues instance = new SortedSetRawValues();
+    instance.docToOrdAddress = loadNumeric(entry.docToOrdAddress);
+    instance.ords = loadNumeric(entry.ords);
+    instance.values = loadBinary(entry.values);
+    return instance;
+  }
+
+  private Bits getMissingBits(int fieldNumber, final long offset, final long length)  {
+    if (offset == -1) {
+      return new Bits.MatchAllBits(maxDoc);
+    } else {
+      Bits instance;
+      synchronized(this) {
+        instance = docsWithFieldInstances.get(fieldNumber);
+        if (instance == null) {
+          IndexInput data = this.data.clone();
+          data.seek(offset);
+          Debug.Assert( length % 8 == 0;
+          long bits[] = new long[(int) length >> 3];
+          for (int i = 0; i < bits.length; i++) {
+            bits[i] = data.readLong();
+          }
+          instance = new FixedBitSet(bits, maxDoc);
+          docsWithFieldInstances.put(fieldNumber, instance);
+        }
+      }
+      return instance;
+    }
+  }
+  
+  @Override
+  public Bits getDocsWithField(FieldInfo field)  {
+    switch(field.getDocValuesType()) {
+      case SORTED_SET:
+        return DocValues.docsWithValue(getSortedSet(field), maxDoc);
+      case SORTED:
+        return DocValues.docsWithValue(getSorted(field), maxDoc);
+      case BINARY:
+        BinaryEntry be = binaries.get(field.number);
+        return getMissingBits(field.number, be.missingOffset, be.missingBytes);
+      case NUMERIC:
+        NumericEntry ne = numerics.get(field.number);
+        return getMissingBits(field.number, ne.missingOffset, ne.missingBytes);
+      default: 
+        throw new Debug.Assert(ionError();
+    }
+  }
+
+  @Override
+  public void close()  {
+    data.close();
+  }
+  
+  static class SortedSetRawValues {
+    NumericDocValues docToOrdAddress;
+    NumericDocValues ords;
+    BinaryDocValues values;
+  }
+
+  static class NumericEntry {
+    long offset;
+    int count;
+    long missingOffset;
+    long missingBytes;
+    byte byteWidth;
+    int packedIntsVersion;
+  }
+
+  static class BinaryEntry {
+    long offset;
+    long missingOffset;
+    long missingBytes;
+    int count;
+    int numBytes;
+    int minLength;
+    int maxLength;
+    int packedIntsVersion;
+    int blockSize;
+  }
+  
+  static class SortedEntry {
+    NumericEntry docToOrd;
+    BinaryEntry values;
+  }
+
+  static class SortedSetEntry {
+    NumericEntry docToOrdAddress;
+    NumericEntry ords;
+    BinaryEntry values;
+  }
+  
+  static class FSTEntry {
+    long offset;
+    long numOrds;
+  }
+}