You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@lucenenet.apache.org by ni...@apache.org on 2017/02/08 14:31:40 UTC

[01/53] [abbrv] lucenenet git commit: Lucene.Net.Core: Renamed all type-derived properties and methods from Short, Int, Long, and Float to match CLR types Int16, Int32, Int64, and Single, respectively. [Forced Update!]

Repository: lucenenet
Updated Branches:
  refs/heads/api-work 25e9d01dd -> cfdda330c (forced update)


http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Tests/core/Util/Fst/TestFSTs.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Util/Fst/TestFSTs.cs b/src/Lucene.Net.Tests/core/Util/Fst/TestFSTs.cs
index 061437c..83b3f07 100644
--- a/src/Lucene.Net.Tests/core/Util/Fst/TestFSTs.cs
+++ b/src/Lucene.Net.Tests/core/Util/Fst/TestFSTs.cs
@@ -256,7 +256,7 @@ namespace Lucene.Net.Util.Fst
                     output.Length = s.Length;
                     for (int idx2 = 0; idx2 < output.Length; idx2++)
                     {
-                        output.Ints[idx2] = s[idx2];
+                        output.Int32s[idx2] = s[idx2];
                     }
                     pairs.Add(new FSTTester<IntsRef>.InputOutput<IntsRef>(terms[idx], output));
                 }
@@ -413,7 +413,7 @@ namespace Lucene.Net.Util.Fst
                     {
                         output = termsEnum.DocFreq;
                     }
-                    builder.Add(Util.ToIntsRef(term, scratchIntsRef), (long)output);
+                    builder.Add(Util.ToInt32sRef(term, scratchIntsRef), (long)output);
                     ord++;
                     if (VERBOSE && ord % 100000 == 0 && LuceneTestCase.TEST_NIGHTLY)
                     {
@@ -888,7 +888,7 @@ namespace Lucene.Net.Util.Fst
         {
             Outputs<object> outputs = NoOutputs.Singleton;
             Builder<object> b = new Builder<object>(FST.INPUT_TYPE.BYTE1, outputs);
-            b.Add(Util.ToIntsRef(new BytesRef("foobar"), new IntsRef()), outputs.NoOutput);
+            b.Add(Util.ToInt32sRef(new BytesRef("foobar"), new IntsRef()), outputs.NoOutput);
             BytesRefFSTEnum<object> fstEnum = new BytesRefFSTEnum<object>(b.Finish());
             Assert.IsNull(fstEnum.SeekFloor(new BytesRef("foo")));
             Assert.IsNull(fstEnum.SeekCeil(new BytesRef("foobaz")));
@@ -904,7 +904,7 @@ namespace Lucene.Net.Util.Fst
             IntsRef ints = new IntsRef();
             for (int i = 0; i < 10; i++)
             {
-                b.Add(Util.ToIntsRef(new BytesRef(str), ints), outputs.NoOutput);
+                b.Add(Util.ToInt32sRef(new BytesRef(str), ints), outputs.NoOutput);
             }
             FST<object> fst = b.Finish();
 
@@ -979,9 +979,9 @@ namespace Lucene.Net.Util.Fst
             BytesRef b = new BytesRef("b");
             BytesRef c = new BytesRef("c");
 
-            builder.Add(Util.ToIntsRef(a, new IntsRef()), 17L);
-            builder.Add(Util.ToIntsRef(b, new IntsRef()), 42L);
-            builder.Add(Util.ToIntsRef(c, new IntsRef()), 13824324872317238L);
+            builder.Add(Util.ToInt32sRef(a, new IntsRef()), 17L);
+            builder.Add(Util.ToInt32sRef(b, new IntsRef()), 42L);
+            builder.Add(Util.ToInt32sRef(c, new IntsRef()), 13824324872317238L);
 
             FST<long?> fst = builder.Finish();
 
@@ -1006,10 +1006,10 @@ namespace Lucene.Net.Util.Fst
             Assert.AreEqual(b, seekResult.Input);
             Assert.AreEqual(42, seekResult.Output);
 
-            Assert.AreEqual(Util.ToIntsRef(new BytesRef("c"), new IntsRef()), Util.GetByOutput(fst, 13824324872317238L));
+            Assert.AreEqual(Util.ToInt32sRef(new BytesRef("c"), new IntsRef()), Util.GetByOutput(fst, 13824324872317238L));
             Assert.IsNull(Util.GetByOutput(fst, 47));
-            Assert.AreEqual(Util.ToIntsRef(new BytesRef("b"), new IntsRef()), Util.GetByOutput(fst, 42));
-            Assert.AreEqual(Util.ToIntsRef(new BytesRef("a"), new IntsRef()), Util.GetByOutput(fst, 17));
+            Assert.AreEqual(Util.ToInt32sRef(new BytesRef("b"), new IntsRef()), Util.GetByOutput(fst, 42));
+            Assert.AreEqual(Util.ToInt32sRef(new BytesRef("a"), new IntsRef()), Util.GetByOutput(fst, 17));
         }
 
         [Test]
@@ -1287,7 +1287,7 @@ namespace Lucene.Net.Util.Fst
                         break;
                     }
                     term.CopyChars(w);
-                    b.Add(Util.ToIntsRef(term, scratchIntsRef), nothing);
+                    b.Add(Util.ToInt32sRef(term, scratchIntsRef), nothing);
                 }
 
                 return b.Finish();
@@ -1358,8 +1358,8 @@ namespace Lucene.Net.Util.Fst
             PositiveIntOutputs outputs = PositiveIntOutputs.Singleton;
             bool willRewrite = Random().NextBoolean();
             Builder<long?> builder = new Builder<long?>(FST.INPUT_TYPE.BYTE1, 0, 0, true, true, int.MaxValue, outputs, null, willRewrite, PackedInts.DEFAULT, true, 15);
-            builder.Add(Util.ToIntsRef(new BytesRef("stat"), new IntsRef()), outputs.NoOutput);
-            builder.Add(Util.ToIntsRef(new BytesRef("station"), new IntsRef()), outputs.NoOutput);
+            builder.Add(Util.ToInt32sRef(new BytesRef("stat"), new IntsRef()), outputs.NoOutput);
+            builder.Add(Util.ToInt32sRef(new BytesRef("station"), new IntsRef()), outputs.NoOutput);
             FST<long?> fst = builder.Finish();
             StringWriter w = new StringWriter();
             //Writer w = new OutputStreamWriter(new FileOutputStream("/x/tmp/out.dot"));
@@ -1471,9 +1471,9 @@ namespace Lucene.Net.Util.Fst
             Builder<long?> builder = new Builder<long?>(FST.INPUT_TYPE.BYTE1, outputs);
 
             IntsRef scratch = new IntsRef();
-            builder.Add(Util.ToIntsRef(new BytesRef("aab"), scratch), 22L);
-            builder.Add(Util.ToIntsRef(new BytesRef("aac"), scratch), 7L);
-            builder.Add(Util.ToIntsRef(new BytesRef("ax"), scratch), 17L);
+            builder.Add(Util.ToInt32sRef(new BytesRef("aab"), scratch), 22L);
+            builder.Add(Util.ToInt32sRef(new BytesRef("aac"), scratch), 7L);
+            builder.Add(Util.ToInt32sRef(new BytesRef("ax"), scratch), 17L);
             FST<long?> fst = builder.Finish();
             //Writer w = new OutputStreamWriter(new FileOutputStream("out.dot"));
             //Util.toDot(fst, w, false, false);
@@ -1482,13 +1482,13 @@ namespace Lucene.Net.Util.Fst
             Util.TopResults<long?> res = Util.ShortestPaths(fst, fst.GetFirstArc(new FST.Arc<long?>()), outputs.NoOutput, minLongComparer, 3, true);
             Assert.IsTrue(res.IsComplete);
             Assert.AreEqual(3, res.TopN.Count);
-            Assert.AreEqual(Util.ToIntsRef(new BytesRef("aac"), scratch), res.TopN[0].Input);
+            Assert.AreEqual(Util.ToInt32sRef(new BytesRef("aac"), scratch), res.TopN[0].Input);
             Assert.AreEqual(7L, res.TopN[0].Output);
 
-            Assert.AreEqual(Util.ToIntsRef(new BytesRef("ax"), scratch), res.TopN[1].Input);
+            Assert.AreEqual(Util.ToInt32sRef(new BytesRef("ax"), scratch), res.TopN[1].Input);
             Assert.AreEqual(17L, res.TopN[1].Output);
 
-            Assert.AreEqual(Util.ToIntsRef(new BytesRef("aab"), scratch), res.TopN[2].Input);
+            Assert.AreEqual(Util.ToInt32sRef(new BytesRef("aab"), scratch), res.TopN[2].Input);
             Assert.AreEqual(22L, res.TopN[2].Output);
         }
 
@@ -1499,12 +1499,12 @@ namespace Lucene.Net.Util.Fst
             Builder<long?> builder = new Builder<long?>(FST.INPUT_TYPE.BYTE1, outputs);
 
             IntsRef scratch = new IntsRef();
-            builder.Add(Util.ToIntsRef(new BytesRef("aab"), scratch), 22L);
-            builder.Add(Util.ToIntsRef(new BytesRef("aac"), scratch), 7L);
-            builder.Add(Util.ToIntsRef(new BytesRef("adcd"), scratch), 17L);
-            builder.Add(Util.ToIntsRef(new BytesRef("adcde"), scratch), 17L);
+            builder.Add(Util.ToInt32sRef(new BytesRef("aab"), scratch), 22L);
+            builder.Add(Util.ToInt32sRef(new BytesRef("aac"), scratch), 7L);
+            builder.Add(Util.ToInt32sRef(new BytesRef("adcd"), scratch), 17L);
+            builder.Add(Util.ToInt32sRef(new BytesRef("adcde"), scratch), 17L);
 
-            builder.Add(Util.ToIntsRef(new BytesRef("ax"), scratch), 17L);
+            builder.Add(Util.ToInt32sRef(new BytesRef("ax"), scratch), 17L);
             FST<long?> fst = builder.Finish();
             AtomicInteger rejectCount = new AtomicInteger();
             Util.TopNSearcher<long?> searcher = new TopNSearcherAnonymousInnerClassHelper(this, fst, minLongComparer, rejectCount);
@@ -1515,7 +1515,7 @@ namespace Lucene.Net.Util.Fst
             Assert.IsTrue(res.IsComplete); // rejected(4) + topN(2) <= maxQueueSize(6)
 
             Assert.AreEqual(1, res.TopN.Count);
-            Assert.AreEqual(Util.ToIntsRef(new BytesRef("aac"), scratch), res.TopN[0].Input);
+            Assert.AreEqual(Util.ToInt32sRef(new BytesRef("aac"), scratch), res.TopN[0].Input);
             Assert.AreEqual(7L, res.TopN[0].Output);
             rejectCount.Set(0);
             searcher = new TopNSearcherAnonymousInnerClassHelper2(this, fst, minLongComparer, rejectCount);
@@ -1600,9 +1600,9 @@ namespace Lucene.Net.Util.Fst
             Builder<Pair> builder = new Builder<Pair>(FST.INPUT_TYPE.BYTE1, outputs);
 
             IntsRef scratch = new IntsRef();
-            builder.Add(Util.ToIntsRef(new BytesRef("aab"), scratch), outputs.NewPair(22L, 57L));
-            builder.Add(Util.ToIntsRef(new BytesRef("aac"), scratch), outputs.NewPair(7L, 36L));
-            builder.Add(Util.ToIntsRef(new BytesRef("ax"), scratch), outputs.NewPair(17L, 85L));
+            builder.Add(Util.ToInt32sRef(new BytesRef("aab"), scratch), outputs.NewPair(22L, 57L));
+            builder.Add(Util.ToInt32sRef(new BytesRef("aac"), scratch), outputs.NewPair(7L, 36L));
+            builder.Add(Util.ToInt32sRef(new BytesRef("ax"), scratch), outputs.NewPair(17L, 85L));
             FST<Pair> fst = builder.Finish();
             //Writer w = new OutputStreamWriter(new FileOutputStream("out.dot"));
             //Util.toDot(fst, w, false, false);
@@ -1612,15 +1612,15 @@ namespace Lucene.Net.Util.Fst
             Assert.IsTrue(res.IsComplete);
             Assert.AreEqual(3, res.TopN.Count);
 
-            Assert.AreEqual(Util.ToIntsRef(new BytesRef("aac"), scratch), res.TopN[0].Input);
+            Assert.AreEqual(Util.ToInt32sRef(new BytesRef("aac"), scratch), res.TopN[0].Input);
             Assert.AreEqual(7L, res.TopN[0].Output.Output1); // weight
             Assert.AreEqual(36L, res.TopN[0].Output.Output2); // output
 
-            Assert.AreEqual(Util.ToIntsRef(new BytesRef("ax"), scratch), res.TopN[1].Input);
+            Assert.AreEqual(Util.ToInt32sRef(new BytesRef("ax"), scratch), res.TopN[1].Input);
             Assert.AreEqual(17L, res.TopN[1].Output.Output1); // weight
             Assert.AreEqual(85L, res.TopN[1].Output.Output2); // output
 
-            Assert.AreEqual(Util.ToIntsRef(new BytesRef("aab"), scratch), res.TopN[2].Input);
+            Assert.AreEqual(Util.ToInt32sRef(new BytesRef("aab"), scratch), res.TopN[2].Input);
             Assert.AreEqual(22L, res.TopN[2].Output.Output1); // weight
             Assert.AreEqual(57L, res.TopN[2].Output.Output2); // output
         }
@@ -1661,7 +1661,7 @@ namespace Lucene.Net.Util.Fst
             foreach (KeyValuePair<string, long> e in slowCompletor)
             {
                 //System.out.println("add: " + e);
-                builder.Add(Util.ToIntsRef(new BytesRef(e.Key), scratch), e.Value);
+                builder.Add(Util.ToInt32sRef(new BytesRef(e.Key), scratch), e.Value);
             }
 
             FST<long?> fst = builder.Finish();
@@ -1703,7 +1703,7 @@ namespace Lucene.Net.Util.Fst
                     if (e.Key.StartsWith(prefix))
                     {
                         //System.out.println("  consider " + e.getKey());
-                        matches.Add(new Util.Result<long?>(Util.ToIntsRef(new BytesRef(e.Key.Substring(prefix.Length)), new IntsRef()), e.Value - prefixOutput));
+                        matches.Add(new Util.Result<long?>(Util.ToInt32sRef(new BytesRef(e.Key.Substring(prefix.Length)), new IntsRef()), e.Value - prefixOutput));
                     }
                 }
 
@@ -1804,7 +1804,7 @@ namespace Lucene.Net.Util.Fst
                 //System.out.println("add: " + e);
                 long weight = e.Value.a;
                 long output = e.Value.b;
-                builder.Add(Util.ToIntsRef(new BytesRef(e.Key), scratch), outputs.NewPair(weight, output));
+                builder.Add(Util.ToInt32sRef(new BytesRef(e.Key), scratch), outputs.NewPair(weight, output));
             }
 
             FST<Pair> fst = builder.Finish();
@@ -1845,7 +1845,7 @@ namespace Lucene.Net.Util.Fst
                     if (e.Key.StartsWith(prefix))
                     {
                         //System.out.println("  consider " + e.getKey());
-                        matches.Add(new Util.Result<Pair>(Util.ToIntsRef(new BytesRef(e.Key.Substring(prefix.Length)), new IntsRef()),
+                        matches.Add(new Util.Result<Pair>(Util.ToInt32sRef(new BytesRef(e.Key.Substring(prefix.Length)), new IntsRef()),
                             outputs.NewPair(e.Value.a - prefixOutput.Output1, e.Value.b - prefixOutput.Output2)));
                     }
                 }
@@ -1881,7 +1881,7 @@ namespace Lucene.Net.Util.Fst
             BytesRef output = new BytesRef(bytes);
             for (int arc = 0; arc < 6; arc++)
             {
-                input.Ints[0] = arc;
+                input.Int32s[0] = arc;
                 output.Bytes[0] = (byte)arc;
                 builder.Add(input, BytesRef.DeepCopyOf(output));
             }
@@ -1889,7 +1889,7 @@ namespace Lucene.Net.Util.Fst
             FST<BytesRef> fst = builder.Finish();
             for (int arc = 0; arc < 6; arc++)
             {
-                input.Ints[0] = arc;
+                input.Int32s[0] = arc;
                 BytesRef result = Util.Get(fst, input);
                 Assert.IsNotNull(result);
                 Assert.AreEqual(300, result.Length);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Tests/core/Util/Packed/TestPackedInts.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Util/Packed/TestPackedInts.cs b/src/Lucene.Net.Tests/core/Util/Packed/TestPackedInts.cs
index 8527887..35de442 100644
--- a/src/Lucene.Net.Tests/core/Util/Packed/TestPackedInts.cs
+++ b/src/Lucene.Net.Tests/core/Util/Packed/TestPackedInts.cs
@@ -135,9 +135,9 @@ namespace Lucene.Net.Util.Packed
                         IndexInput @in = d.OpenInput("out.bin", NewIOContext(Random()));
                         // header = codec header | bitsPerValue | valueCount | format
                         CodecUtil.CheckHeader(@in, PackedInts.CODEC_NAME, PackedInts.VERSION_START, PackedInts.VERSION_CURRENT); // codec header
-                        Assert.AreEqual(w.BitsPerValue, @in.ReadVInt());
-                        Assert.AreEqual(valueCount, @in.ReadVInt());
-                        Assert.AreEqual(w.Format.Id, @in.ReadVInt());
+                        Assert.AreEqual(w.BitsPerValue, @in.ReadVInt32());
+                        Assert.AreEqual(valueCount, @in.ReadVInt32());
+                        Assert.AreEqual(w.Format.Id, @in.ReadVInt32());
                         Assert.AreEqual(startFp, @in.FilePointer);
                         @in.Dispose();
                     }
@@ -179,7 +179,7 @@ namespace Lucene.Net.Util.Packed
                             LongsRef next = r.Next(count);
                             for (int k = 0; k < next.Length; ++k)
                             {
-                                Assert.AreEqual(values[i + k], next.Longs[next.Offset + k], "index=" + i + " valueCount=" + valueCount + " nbits=" + nbits + " for " + r.GetType().Name);
+                                Assert.AreEqual(values[i + k], next.Int64s[next.Offset + k], "index=" + i + " valueCount=" + valueCount + " nbits=" + nbits + " for " + r.GetType().Name);
                             }
                             i += next.Length;
                         }
@@ -213,7 +213,7 @@ namespace Lucene.Net.Util.Packed
             IndexOutput @out = dir.CreateOutput("tests.bin", NewIOContext(Random()));
             for (int i = 0; i < valueCount; ++i)
             {
-                @out.WriteLong(0);
+                @out.WriteInt64(0);
             }
             @out.Dispose();
             IndexInput @in = dir.OpenInput("tests.bin", NewIOContext(Random()));
@@ -1004,12 +1004,12 @@ namespace Lucene.Net.Util.Packed
 
                     PackedInts.IEncoder encoder = PackedInts.GetEncoder(format, PackedInts.VERSION_CURRENT, bpv);
                     PackedInts.IDecoder decoder = PackedInts.GetDecoder(format, PackedInts.VERSION_CURRENT, bpv);
-                    int longBlockCount = encoder.LongBlockCount;
-                    int longValueCount = encoder.LongValueCount;
+                    int longBlockCount = encoder.Int64BlockCount;
+                    int longValueCount = encoder.Int64ValueCount;
                     int byteBlockCount = encoder.ByteBlockCount;
                     int byteValueCount = encoder.ByteValueCount;
-                    Assert.AreEqual(longBlockCount, decoder.LongBlockCount);
-                    Assert.AreEqual(longValueCount, decoder.LongValueCount);
+                    Assert.AreEqual(longBlockCount, decoder.Int64BlockCount);
+                    Assert.AreEqual(longValueCount, decoder.Int64ValueCount);
                     Assert.AreEqual(byteBlockCount, decoder.ByteBlockCount);
                     Assert.AreEqual(byteValueCount, decoder.ByteValueCount);
 
@@ -1068,7 +1068,7 @@ namespace Lucene.Net.Util.Packed
 
                     // 4. byte[] decoding
                     byte[] byteBlocks = new byte[8 * blocks.Length];
-                    ByteBuffer.Wrap(byteBlocks).AsLongBuffer().Put(blocks);
+                    ByteBuffer.Wrap(byteBlocks).AsInt64Buffer().Put(blocks);
                     long[] values2 = new long[valuesOffset + longIterations * longValueCount];
                     decoder.Decode(byteBlocks, blocksOffset * 8, values2, valuesOffset, byteIterations);
                     foreach (long value in values2)
@@ -1087,7 +1087,7 @@ namespace Lucene.Net.Util.Packed
                     // 5. byte[] encoding
                     byte[] blocks3_ = new byte[8 * (blocksOffset2 + blocksLen)];
                     encoder.Encode(values, valuesOffset, blocks3_, 8 * blocksOffset2, byteIterations);
-                    assertEquals(msg, LongBuffer.Wrap(blocks2), ByteBuffer.Wrap(blocks3_).AsLongBuffer());
+                    assertEquals(msg, LongBuffer.Wrap(blocks2), ByteBuffer.Wrap(blocks3_).AsInt64Buffer());
                     // test encoding from int[]
                     if (bpv <= 32)
                     {
@@ -1274,7 +1274,7 @@ namespace Lucene.Net.Util.Packed
             long totalBits = 0;
             for (int i = 0; i < longs.Length; ++i)
             {
-                pout.WriteLong(longs[i], bitsPerValues[i]);
+                pout.WriteInt64(longs[i], bitsPerValues[i]);
                 totalBits += bitsPerValues[i];
                 if (skip[i])
                 {
@@ -1289,7 +1289,7 @@ namespace Lucene.Net.Util.Packed
             PackedDataInput pin = new PackedDataInput(@in);
             for (int i = 0; i < longs.Length; ++i)
             {
-                Assert.AreEqual(longs[i], pin.ReadLong(bitsPerValues[i]), "" + i);
+                Assert.AreEqual(longs[i], pin.ReadInt64(bitsPerValues[i]), "" + i);
                 if (skip[i])
                 {
                     pin.SkipToNextByte();
@@ -1365,7 +1365,7 @@ namespace Lucene.Net.Util.Packed
                         LongsRef nextValues = it.Next(TestUtil.NextInt(Random(), 1, 1024));
                         for (int j = 0; j < nextValues.Length; ++j)
                         {
-                            Assert.AreEqual(values[i + j], nextValues.Longs[nextValues.Offset + j], "" + (i + j));
+                            Assert.AreEqual(values[i + j], nextValues.Int64s[nextValues.Offset + j], "" + (i + j));
                         }
                         i += nextValues.Length;
                     }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Tests/core/Util/TestArrayUtil.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Util/TestArrayUtil.cs b/src/Lucene.Net.Tests/core/Util/TestArrayUtil.cs
index 58c2c21..4502869 100644
--- a/src/Lucene.Net.Tests/core/Util/TestArrayUtil.cs
+++ b/src/Lucene.Net.Tests/core/Util/TestArrayUtil.cs
@@ -78,7 +78,7 @@ namespace Lucene.Net.Util
             int test;
             try
             {
-                test = ArrayUtil.ParseInt("".ToCharArray());
+                test = ArrayUtil.ParseInt32("".ToCharArray());
                 Assert.IsTrue(false);
             }
 #pragma warning disable 168
@@ -89,7 +89,7 @@ namespace Lucene.Net.Util
             }
             try
             {
-                test = ArrayUtil.ParseInt("foo".ToCharArray());
+                test = ArrayUtil.ParseInt32("foo".ToCharArray());
                 Assert.IsTrue(false);
             }
 #pragma warning disable 168
@@ -100,7 +100,7 @@ namespace Lucene.Net.Util
             }
             try
             {
-                test = ArrayUtil.ParseInt(Convert.ToString(long.MaxValue).ToCharArray());
+                test = ArrayUtil.ParseInt32(Convert.ToString(long.MaxValue).ToCharArray());
                 Assert.IsTrue(false);
             }
 #pragma warning disable 168
@@ -111,7 +111,7 @@ namespace Lucene.Net.Util
             }
             try
             {
-                test = ArrayUtil.ParseInt("0.34".ToCharArray());
+                test = ArrayUtil.ParseInt32("0.34".ToCharArray());
                 Assert.IsTrue(false);
             }
 #pragma warning disable 168
@@ -123,15 +123,15 @@ namespace Lucene.Net.Util
 
             try
             {
-                test = ArrayUtil.ParseInt("1".ToCharArray());
+                test = ArrayUtil.ParseInt32("1".ToCharArray());
                 Assert.IsTrue(test == 1, test + " does not equal: " + 1);
-                test = ArrayUtil.ParseInt("-10000".ToCharArray());
+                test = ArrayUtil.ParseInt32("-10000".ToCharArray());
                 Assert.IsTrue(test == -10000, test + " does not equal: " + -10000);
-                test = ArrayUtil.ParseInt("1923".ToCharArray());
+                test = ArrayUtil.ParseInt32("1923".ToCharArray());
                 Assert.IsTrue(test == 1923, test + " does not equal: " + 1923);
-                test = ArrayUtil.ParseInt("-1".ToCharArray());
+                test = ArrayUtil.ParseInt32("-1".ToCharArray());
                 Assert.IsTrue(test == -1, test + " does not equal: " + -1);
-                test = ArrayUtil.ParseInt("foo 1923 bar".ToCharArray(), 4, 4);
+                test = ArrayUtil.ParseInt32("foo 1923 bar".ToCharArray(), 4, 4);
                 Assert.IsTrue(test == 1923, test + " does not equal: " + 1923);
             }
             catch (FormatException e)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Tests/core/Util/TestBroadWord.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Util/TestBroadWord.cs b/src/Lucene.Net.Tests/core/Util/TestBroadWord.cs
index b505972..eb6b219 100644
--- a/src/Lucene.Net.Tests/core/Util/TestBroadWord.cs
+++ b/src/Lucene.Net.Tests/core/Util/TestBroadWord.cs
@@ -138,7 +138,7 @@ namespace Lucene.Net.Util
                 {
                     long ii = i * BroadWord.L8_L;
                     long jj = j * BroadWord.L8_L;
-                    Assert.AreEqual(ToStringUtils.LongHex((i < j) ? unchecked(0x80L * BroadWord.L8_L) : 0x0L), ToStringUtils.LongHex(BroadWord.SmallerUpTo7_8(ii, jj)), ToStringUtils.LongHex(ii) + " < " + ToStringUtils.LongHex(jj));
+                    Assert.AreEqual(ToStringUtils.Int64Hex((i < j) ? unchecked(0x80L * BroadWord.L8_L) : 0x0L), ToStringUtils.Int64Hex(BroadWord.SmallerUpTo7_8(ii, jj)), ToStringUtils.Int64Hex(ii) + " < " + ToStringUtils.Int64Hex(jj));
                 }
             }
         }
@@ -153,7 +153,7 @@ namespace Lucene.Net.Util
                 {
                     long ii = i * BroadWord.L8_L;
                     long jj = j * BroadWord.L8_L;
-                    Assert.AreEqual(ToStringUtils.LongHex((i < j) ? unchecked(0x80L * BroadWord.L8_L) : 0x0L), ToStringUtils.LongHex(BroadWord.Smalleru_8(ii, jj)), ToStringUtils.LongHex(ii) + " < " + ToStringUtils.LongHex(jj));
+                    Assert.AreEqual(ToStringUtils.Int64Hex((i < j) ? unchecked(0x80L * BroadWord.L8_L) : 0x0L), ToStringUtils.Int64Hex(BroadWord.Smalleru_8(ii, jj)), ToStringUtils.Int64Hex(ii) + " < " + ToStringUtils.Int64Hex(jj));
                 }
             }
         }
@@ -165,7 +165,7 @@ namespace Lucene.Net.Util
             for (long i = 0x0L; i <= 0xFFL; i++)
             {
                 long ii = i * BroadWord.L8_L;
-                Assert.AreEqual(ToStringUtils.LongHex((i != 0L) ? unchecked(0x80L * BroadWord.L8_L) : 0x0L), ToStringUtils.LongHex(BroadWord.NotEquals0_8(ii)), ToStringUtils.LongHex(ii) + " <> 0");
+                Assert.AreEqual(ToStringUtils.Int64Hex((i != 0L) ? unchecked(0x80L * BroadWord.L8_L) : 0x0L), ToStringUtils.Int64Hex(BroadWord.NotEquals0_8(ii)), ToStringUtils.Int64Hex(ii) + " <> 0");
             }
         }
     }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Tests/core/Util/TestFieldCacheSanityChecker.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Util/TestFieldCacheSanityChecker.cs b/src/Lucene.Net.Tests/core/Util/TestFieldCacheSanityChecker.cs
index ab2a4e2..8773d2b 100644
--- a/src/Lucene.Net.Tests/core/Util/TestFieldCacheSanityChecker.cs
+++ b/src/Lucene.Net.Tests/core/Util/TestFieldCacheSanityChecker.cs
@@ -125,8 +125,8 @@ namespace Lucene.Net.Util
             cache.GetDoubles(ReaderAclone, "theDouble", FieldCache.DEFAULT_DOUBLE_PARSER, false);
             cache.GetDoubles(ReaderB, "theDouble", FieldCache.DEFAULT_DOUBLE_PARSER, false);
 
-            cache.GetInts(ReaderX, "theInt", false);
-            cache.GetInts(ReaderX, "theInt", FieldCache.DEFAULT_INT_PARSER, false);
+            cache.GetInt32s(ReaderX, "theInt", false);
+            cache.GetInt32s(ReaderX, "theInt", FieldCache.DEFAULT_INT_PARSER, false);
 
             // // //
 
@@ -147,7 +147,7 @@ namespace Lucene.Net.Util
             IFieldCache cache = FieldCache.DEFAULT;
             cache.PurgeAllCaches();
 
-            cache.GetInts(ReaderX, "theInt", FieldCache.DEFAULT_INT_PARSER, false);
+            cache.GetInt32s(ReaderX, "theInt", FieldCache.DEFAULT_INT_PARSER, false);
             cache.GetTerms(ReaderX, "theInt", false);
 #pragma warning disable 612, 618
             cache.GetBytes(ReaderX, "theByte", false);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Tests/core/Util/TestIntsRef.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Util/TestIntsRef.cs b/src/Lucene.Net.Tests/core/Util/TestIntsRef.cs
index 2ecf8eb..7b50d74 100644
--- a/src/Lucene.Net.Tests/core/Util/TestIntsRef.cs
+++ b/src/Lucene.Net.Tests/core/Util/TestIntsRef.cs
@@ -26,7 +26,7 @@ namespace Lucene.Net.Util
         public virtual void TestEmpty()
         {
             IntsRef i = new IntsRef();
-            Assert.AreEqual(IntsRef.EMPTY_INTS, i.Ints);
+            Assert.AreEqual(IntsRef.EMPTY_INTS, i.Int32s);
             Assert.AreEqual(0, i.Offset);
             Assert.AreEqual(0, i.Length);
         }
@@ -36,7 +36,7 @@ namespace Lucene.Net.Util
         {
             int[] ints = new int[] { 1, 2, 3, 4 };
             IntsRef i = new IntsRef(ints, 0, 4);
-            Assert.AreEqual(ints, i.Ints);
+            Assert.AreEqual(ints, i.Int32s);
             Assert.AreEqual(0, i.Offset);
             Assert.AreEqual(4, i.Length);
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Tests/core/Util/TestNumericUtils.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Util/TestNumericUtils.cs b/src/Lucene.Net.Tests/core/Util/TestNumericUtils.cs
index 45614c2..ab14b15 100644
--- a/src/Lucene.Net.Tests/core/Util/TestNumericUtils.cs
+++ b/src/Lucene.Net.Tests/core/Util/TestNumericUtils.cs
@@ -34,7 +34,7 @@ namespace Lucene.Net.Util
             BytesRef last = null, act = new BytesRef(NumericUtils.BUF_SIZE_LONG);
             for (long l = -100000L; l < 100000L; l++)
             {
-                NumericUtils.LongToPrefixCodedBytes(l, 0, act);
+                NumericUtils.Int64ToPrefixCodedBytes(l, 0, act);
                 if (last != null)
                 {
                     // test if smaller
@@ -42,7 +42,7 @@ namespace Lucene.Net.Util
                     Assert.IsTrue(last.Utf8ToString().CompareToOrdinal(act.Utf8ToString()) < 0, "actual bigger than last (as String)");
                 }
                 // test is back and forward conversion works
-                Assert.AreEqual(l, NumericUtils.PrefixCodedToLong(act), "forward and back conversion should generate same long");
+                Assert.AreEqual(l, NumericUtils.PrefixCodedToInt64(act), "forward and back conversion should generate same long");
                 // next step
                 last = act;
                 act = new BytesRef(NumericUtils.BUF_SIZE_LONG);
@@ -56,7 +56,7 @@ namespace Lucene.Net.Util
             BytesRef last = null, act = new BytesRef(NumericUtils.BUF_SIZE_INT);
             for (int i = -100000; i < 100000; i++)
             {
-                NumericUtils.IntToPrefixCodedBytes(i, 0, act);
+                NumericUtils.Int32ToPrefixCodedBytes(i, 0, act);
                 if (last != null)
                 {
                     // test if smaller
@@ -64,7 +64,7 @@ namespace Lucene.Net.Util
                     Assert.IsTrue(last.Utf8ToString().CompareToOrdinal(act.Utf8ToString()) < 0, "actual bigger than last (as String)");
                 }
                 // test is back and forward conversion works
-                Assert.AreEqual(i, NumericUtils.PrefixCodedToInt(act), "forward and back conversion should generate same int");
+                Assert.AreEqual(i, NumericUtils.PrefixCodedToInt32(act), "forward and back conversion should generate same int");
                 // next step
                 last = act;
                 act = new BytesRef(NumericUtils.BUF_SIZE_INT);
@@ -80,15 +80,15 @@ namespace Lucene.Net.Util
             for (int i = 0; i < vals.Length; i++)
             {
                 prefixVals[i] = new BytesRef(NumericUtils.BUF_SIZE_LONG);
-                NumericUtils.LongToPrefixCodedBytes(vals[i], 0, prefixVals[i]);
+                NumericUtils.Int64ToPrefixCodedBytes(vals[i], 0, prefixVals[i]);
 
                 // check forward and back conversion
-                Assert.AreEqual(vals[i], NumericUtils.PrefixCodedToLong(prefixVals[i]), "forward and back conversion should generate same long");
+                Assert.AreEqual(vals[i], NumericUtils.PrefixCodedToInt64(prefixVals[i]), "forward and back conversion should generate same long");
 
                 // test if decoding values as int fails correctly
                 try
                 {
-                    NumericUtils.PrefixCodedToInt(prefixVals[i]);
+                    NumericUtils.PrefixCodedToInt32(prefixVals[i]);
                     Assert.Fail("decoding a prefix coded long value as int should fail");
                 }
 #pragma warning disable 168
@@ -111,8 +111,8 @@ namespace Lucene.Net.Util
             {
                 for (int j = 0; j < 64; j++)
                 {
-                    NumericUtils.LongToPrefixCodedBytes(vals[i], j, @ref);
-                    long prefixVal = NumericUtils.PrefixCodedToLong(@ref);
+                    NumericUtils.Int64ToPrefixCodedBytes(vals[i], j, @ref);
+                    long prefixVal = NumericUtils.PrefixCodedToInt64(@ref);
                     long mask = (1L << j) - 1L;
                     Assert.AreEqual(vals[i] & mask, vals[i] - prefixVal, "difference between prefix val and original value for " + vals[i] + " with shift=" + j);
                 }
@@ -128,15 +128,15 @@ namespace Lucene.Net.Util
             for (int i = 0; i < vals.Length; i++)
             {
                 prefixVals[i] = new BytesRef(NumericUtils.BUF_SIZE_INT);
-                NumericUtils.IntToPrefixCodedBytes(vals[i], 0, prefixVals[i]);
+                NumericUtils.Int32ToPrefixCodedBytes(vals[i], 0, prefixVals[i]);
 
                 // check forward and back conversion
-                Assert.AreEqual(vals[i], NumericUtils.PrefixCodedToInt(prefixVals[i]), "forward and back conversion should generate same int");
+                Assert.AreEqual(vals[i], NumericUtils.PrefixCodedToInt32(prefixVals[i]), "forward and back conversion should generate same int");
 
                 // test if decoding values as long fails correctly
                 try
                 {
-                    NumericUtils.PrefixCodedToLong(prefixVals[i]);
+                    NumericUtils.PrefixCodedToInt64(prefixVals[i]);
                     Assert.Fail("decoding a prefix coded int value as long should fail");
                 }
 #pragma warning disable 168
@@ -159,8 +159,8 @@ namespace Lucene.Net.Util
             {
                 for (int j = 0; j < 32; j++)
                 {
-                    NumericUtils.IntToPrefixCodedBytes(vals[i], j, @ref);
-                    int prefixVal = NumericUtils.PrefixCodedToInt(@ref);
+                    NumericUtils.Int32ToPrefixCodedBytes(vals[i], j, @ref);
+                    int prefixVal = NumericUtils.PrefixCodedToInt32(@ref);
                     int mask = (1 << j) - 1;
                     Assert.AreEqual(vals[i] & mask, vals[i] - prefixVal, "difference between prefix val and original value for " + vals[i] + " with shift=" + j);
                 }
@@ -176,8 +176,8 @@ namespace Lucene.Net.Util
             // check forward and back conversion
             for (int i = 0; i < vals.Length; i++)
             {
-                longVals[i] = NumericUtils.DoubleToSortableLong(vals[i]);
-                Assert.IsTrue(vals[i].CompareTo(NumericUtils.SortableLongToDouble(longVals[i])) == 0, "forward and back conversion should generate same double");
+                longVals[i] = NumericUtils.DoubleToSortableInt64(vals[i]);
+                Assert.IsTrue(vals[i].CompareTo(NumericUtils.SortableInt64ToDouble(longVals[i])) == 0, "forward and back conversion should generate same double");
             }
 
             // check sort order (prefixVals should be ascending)
@@ -192,11 +192,11 @@ namespace Lucene.Net.Util
         [Test]
         public virtual void TestSortableDoubleNaN()
         {
-            long plusInf = NumericUtils.DoubleToSortableLong(double.PositiveInfinity);
+            long plusInf = NumericUtils.DoubleToSortableInt64(double.PositiveInfinity);
             foreach (double nan in DOUBLE_NANs)
             {
                 Assert.IsTrue(double.IsNaN(nan));
-                long sortable = NumericUtils.DoubleToSortableLong(nan);
+                long sortable = NumericUtils.DoubleToSortableInt64(nan);
                 Assert.IsTrue((ulong)sortable > (ulong)plusInf, "Double not sorted correctly: " + nan + ", long repr: " + sortable + ", positive inf.: " + plusInf);
             }
         }
@@ -210,8 +210,8 @@ namespace Lucene.Net.Util
             // check forward and back conversion
             for (int i = 0; i < vals.Length; i++)
             {
-                intVals[i] = NumericUtils.FloatToSortableInt(vals[i]);
-                Assert.IsTrue(vals[i].CompareTo(NumericUtils.SortableIntToFloat(intVals[i])) == 0, "forward and back conversion should generate same double");
+                intVals[i] = NumericUtils.SingleToSortableInt32(vals[i]);
+                Assert.IsTrue(vals[i].CompareTo(NumericUtils.SortableInt32ToSingle(intVals[i])) == 0, "forward and back conversion should generate same double");
             }
 
             // check sort order (prefixVals should be ascending)
@@ -221,16 +221,16 @@ namespace Lucene.Net.Util
             }
         }
 
-        public static readonly float[] FLOAT_NANs = new float[] { float.NaN, Number.IntBitsToFloat(0x7f800001), Number.IntBitsToFloat(0x7fffffff), Number.IntBitsToFloat(unchecked((int)0xff800001)), Number.IntBitsToFloat(unchecked((int)0xffffffff)) };
+        public static readonly float[] FLOAT_NANs = new float[] { float.NaN, Number.Int32BitsToSingle(0x7f800001), Number.Int32BitsToSingle(0x7fffffff), Number.Int32BitsToSingle(unchecked((int)0xff800001)), Number.Int32BitsToSingle(unchecked((int)0xffffffff)) };
 
         [Test]
         public virtual void TestSortableFloatNaN()
         {
-            int plusInf = NumericUtils.FloatToSortableInt(float.PositiveInfinity);
+            int plusInf = NumericUtils.SingleToSortableInt32(float.PositiveInfinity);
             foreach (float nan in FLOAT_NANs)
             {
                 Assert.IsTrue(float.IsNaN(nan));
-                uint sortable = (uint)NumericUtils.FloatToSortableInt(nan);
+                uint sortable = (uint)NumericUtils.SingleToSortableInt32(nan);
                 Assert.IsTrue(sortable > plusInf, "Float not sorted correctly: " + nan + ", int repr: " + sortable + ", positive inf.: " + plusInf);
             }
         }
@@ -246,7 +246,7 @@ namespace Lucene.Net.Util
             IEnumerator<long> neededBounds = (expectedBounds == null) ? null : expectedBounds.GetEnumerator();
             IEnumerator<int> neededShifts = (expectedShifts == null) ? null : expectedShifts.GetEnumerator();
 
-            NumericUtils.SplitLongRange(new LongRangeBuilderAnonymousInnerClassHelper(this, lower, upper, useBitSet, bits, neededBounds, neededShifts), precisionStep, lower, upper);
+            NumericUtils.SplitInt64Range(new LongRangeBuilderAnonymousInnerClassHelper(this, lower, upper, useBitSet, bits, neededBounds, neededShifts), precisionStep, lower, upper);
 
             if (useBitSet)
             {
@@ -446,7 +446,7 @@ namespace Lucene.Net.Util
             IEnumerator<int> neededBounds = (expectedBounds == null) ? null : expectedBounds.GetEnumerator();
             IEnumerator<int> neededShifts = (expectedShifts == null) ? null : expectedShifts.GetEnumerator();
 
-            NumericUtils.SplitIntRange(new IntRangeBuilderAnonymousInnerClassHelper(this, lower, upper, useBitSet, bits, neededBounds, neededShifts), precisionStep, lower, upper);
+            NumericUtils.SplitInt32Range(new IntRangeBuilderAnonymousInnerClassHelper(this, lower, upper, useBitSet, bits, neededBounds, neededShifts), precisionStep, lower, upper);
 
             if (useBitSet)
             {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Tests/core/Util/TestRecyclingIntBlockAllocator.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Util/TestRecyclingIntBlockAllocator.cs b/src/Lucene.Net.Tests/core/Util/TestRecyclingIntBlockAllocator.cs
index 15c83d6..b218493 100644
--- a/src/Lucene.Net.Tests/core/Util/TestRecyclingIntBlockAllocator.cs
+++ b/src/Lucene.Net.Tests/core/Util/TestRecyclingIntBlockAllocator.cs
@@ -44,7 +44,7 @@ namespace Lucene.Net.Util
         {
             RecyclingIntBlockAllocator allocator = NewAllocator();
             HashSet<int[]> set = new HashSet<int[]>();
-            int[] block = allocator.GetIntBlock();
+            int[] block = allocator.GetInt32Block();
             set.Add(block);
             Assert.IsNotNull(block);
             int size = block.Length;
@@ -52,7 +52,7 @@ namespace Lucene.Net.Util
             int num = AtLeast(97);
             for (int i = 0; i < num; i++)
             {
-                block = allocator.GetIntBlock();
+                block = allocator.GetInt32Block();
                 Assert.IsNotNull(block);
                 Assert.AreEqual(size, block.Length);
                 Assert.IsTrue(set.Add(block), "block is returned twice");
@@ -67,7 +67,7 @@ namespace Lucene.Net.Util
             RecyclingIntBlockAllocator allocator = NewAllocator();
             HashSet<int[]> allocated = new HashSet<int[]>();
 
-            int[] block = allocator.GetIntBlock();
+            int[] block = allocator.GetInt32Block();
             allocated.Add(block);
             Assert.IsNotNull(block);
             int size = block.Length;
@@ -78,7 +78,7 @@ namespace Lucene.Net.Util
                 int num = 1 + Random().Next(39);
                 for (int j = 0; j < num; j++)
                 {
-                    block = allocator.GetIntBlock();
+                    block = allocator.GetInt32Block();
                     Assert.IsNotNull(block);
                     Assert.AreEqual(size, block.Length);
                     Assert.IsTrue(allocated.Add(block), "block is returned twice");
@@ -92,7 +92,7 @@ namespace Lucene.Net.Util
                 {
                     selected.Add(array[j]);
                 }
-                allocator.RecycleIntBlocks(array, begin, end);
+                allocator.RecycleInt32Blocks(array, begin, end);
                 for (int j = begin; j < end; j++)
                 {
                     Assert.IsNull(array[j]);
@@ -109,7 +109,7 @@ namespace Lucene.Net.Util
             RecyclingIntBlockAllocator allocator = NewAllocator();
             HashSet<int[]> allocated = new HashSet<int[]>();
             int freeButAllocated = 0;
-            int[] block = allocator.GetIntBlock();
+            int[] block = allocator.GetInt32Block();
             allocated.Add(block);
             Assert.IsNotNull(block);
             int size = block.Length;
@@ -120,7 +120,7 @@ namespace Lucene.Net.Util
                 int num = 1 + Random().Next(39);
                 for (int j = 0; j < num; j++)
                 {
-                    block = allocator.GetIntBlock();
+                    block = allocator.GetInt32Block();
                     freeButAllocated = Math.Max(0, freeButAllocated - 1);
                     Assert.IsNotNull(block);
                     Assert.AreEqual(size, block.Length);
@@ -136,7 +136,7 @@ namespace Lucene.Net.Util
                     int[] b = array[j];
                     Assert.IsTrue(allocated.Remove(b));
                 }
-                allocator.RecycleIntBlocks(array, begin, end);
+                allocator.RecycleInt32Blocks(array, begin, end);
                 for (int j = begin; j < end; j++)
                 {
                     Assert.IsNull(array[j]);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Tests/core/Util/TestSmallFloat.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Util/TestSmallFloat.cs b/src/Lucene.Net.Tests/core/Util/TestSmallFloat.cs
index ce38493..a933ccd 100644
--- a/src/Lucene.Net.Tests/core/Util/TestSmallFloat.cs
+++ b/src/Lucene.Net.Tests/core/Util/TestSmallFloat.cs
@@ -32,7 +32,7 @@ namespace Lucene.Net.Util
             int mantissa = b & 7;
             int exponent = (b >> 3) & 31;
             int bits = ((exponent + (63 - 15)) << 24) | (mantissa << 21);
-            return Number.IntBitsToFloat(bits);
+            return Number.Int32BitsToSingle(bits);
         }
 
         // original lucene floatToByte (since lucene 1.3)
@@ -48,7 +48,7 @@ namespace Lucene.Net.Util
                 return 0;
             }
 
-            int bits = Number.FloatToIntBits(f); // parse float into parts
+            int bits = Number.SingleToInt32Bits(f); // parse float into parts
             int mantissa = (bits & 0xffffff) >> 21;
             int exponent = (((bits >> 24) & 0x7f) - 63) + 15;
 
@@ -81,7 +81,7 @@ namespace Lucene.Net.Util
                 return 0;
             }
 
-            int bits = Number.FloatToIntBits(f); // parse float into parts
+            int bits = Number.SingleToInt32Bits(f); // parse float into parts
             int mantissa = (bits & 0xffffff) >> 21;
             int exponent = (((bits >> 24) & 0x7f) - 63) + 15;
 
@@ -106,13 +106,13 @@ namespace Lucene.Net.Util
             for (int i = 0; i < 256; i++)
             {
                 float f1 = Orig_byteToFloat((sbyte)i);
-                float f2 = SmallFloat.ByteToFloat((sbyte)i, 3, 15);
-                float f3 = SmallFloat.Byte315ToFloat((sbyte)i);
+                float f2 = SmallFloat.ByteToSingle((sbyte)i, 3, 15);
+                float f3 = SmallFloat.Byte315ToSingle((sbyte)i);
                 Assert.AreEqual(f1, f2, 0.0);
                 Assert.AreEqual(f2, f3, 0.0);
 
-                float f4 = SmallFloat.ByteToFloat((sbyte)i, 5, 2);
-                float f5 = SmallFloat.Byte52ToFloat((sbyte)i);
+                float f4 = SmallFloat.ByteToSingle((sbyte)i, 5, 2);
+                float f5 = SmallFloat.Byte52ToSingle((sbyte)i);
                 Assert.AreEqual(f4, f5, 0.0);
             }
         }
@@ -122,37 +122,37 @@ namespace Lucene.Net.Util
         {
             Assert.AreEqual(0, Orig_floatToByte_v13(5.8123817E-10f)); // verify the old bug (see LUCENE-2937)
             Assert.AreEqual(1, Orig_floatToByte(5.8123817E-10f)); // verify it's fixed in this test code
-            Assert.AreEqual(1, SmallFloat.FloatToByte315(5.8123817E-10f)); // verify it's fixed
+            Assert.AreEqual(1, SmallFloat.SingleToByte315(5.8123817E-10f)); // verify it's fixed
 
             // test some constants
-            Assert.AreEqual(0, SmallFloat.FloatToByte315(0));
+            Assert.AreEqual(0, SmallFloat.SingleToByte315(0));
             //Java's Float.MIN_VALUE equals C#'s float.Epsilon
-            Assert.AreEqual(1, SmallFloat.FloatToByte315(float.Epsilon)); // underflow rounds up to smallest positive
-            Assert.AreEqual(255, SmallFloat.FloatToByte315(float.MaxValue) & 0xff); // overflow rounds down to largest positive
-            Assert.AreEqual(255, SmallFloat.FloatToByte315(float.PositiveInfinity) & 0xff);
+            Assert.AreEqual(1, SmallFloat.SingleToByte315(float.Epsilon)); // underflow rounds up to smallest positive
+            Assert.AreEqual(255, SmallFloat.SingleToByte315(float.MaxValue) & 0xff); // overflow rounds down to largest positive
+            Assert.AreEqual(255, SmallFloat.SingleToByte315(float.PositiveInfinity) & 0xff);
 
             // all negatives map to 0
-            Assert.AreEqual(0, SmallFloat.FloatToByte315(-float.Epsilon));
-            Assert.AreEqual(0, SmallFloat.FloatToByte315(-float.MaxValue));
-            Assert.AreEqual(0, SmallFloat.FloatToByte315(float.NegativeInfinity));
+            Assert.AreEqual(0, SmallFloat.SingleToByte315(-float.Epsilon));
+            Assert.AreEqual(0, SmallFloat.SingleToByte315(-float.MaxValue));
+            Assert.AreEqual(0, SmallFloat.SingleToByte315(float.NegativeInfinity));
 
             // up iterations for more exhaustive test after changing something
             int num = AtLeast(100000);
             for (int i = 0; i < num; i++)
             {
-                float f = Number.IntBitsToFloat(Random().Next());
+                float f = Number.Int32BitsToSingle(Random().Next());
                 if (float.IsNaN(f)) // skip NaN
                 {
                     continue;
                 }
                 sbyte b1 = Orig_floatToByte(f);
-                sbyte b2 = SmallFloat.FloatToByte(f, 3, 15);
-                sbyte b3 = SmallFloat.FloatToByte315(f);
+                sbyte b2 = SmallFloat.SingleToByte(f, 3, 15);
+                sbyte b3 = SmallFloat.SingleToByte315(f);
                 Assert.AreEqual(b1, b2);
                 Assert.AreEqual(b2, b3);
 
-                sbyte b4 = SmallFloat.FloatToByte(f, 5, 2);
-                sbyte b5 = SmallFloat.FloatToByte52(f);
+                sbyte b4 = SmallFloat.SingleToByte(f, 5, 2);
+                sbyte b5 = SmallFloat.SingleToByte52(f);
                 Assert.AreEqual(b4, b5);
             }
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Tests/core/Util/TestUnicodeUtil.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Util/TestUnicodeUtil.cs b/src/Lucene.Net.Tests/core/Util/TestUnicodeUtil.cs
index ef7314e..d4d40a7 100644
--- a/src/Lucene.Net.Tests/core/Util/TestUnicodeUtil.cs
+++ b/src/Lucene.Net.Tests/core/Util/TestUnicodeUtil.cs
@@ -176,7 +176,7 @@ namespace Lucene.Net.Util
                     codePoints[intUpto++] = cp;
                     charUpto += Character.CharCount(cp);
                 }
-                if (!ArrayUtil.Equals(codePoints, 0, utf32.Ints, utf32.Offset, intUpto))
+                if (!ArrayUtil.Equals(codePoints, 0, utf32.Int32s, utf32.Offset, intUpto))
                 {
                     Console.WriteLine("FAILED");
                     for (int j = 0; j < s.Length; j++)
@@ -187,7 +187,7 @@ namespace Lucene.Net.Util
                     Assert.AreEqual(intUpto, utf32.Length);
                     for (int j = 0; j < intUpto; j++)
                     {
-                        Console.WriteLine("  " + utf32.Ints[j].ToString("x") + " vs " + codePoints[j].ToString("x"));
+                        Console.WriteLine("  " + utf32.Int32s[j].ToString("x") + " vs " + codePoints[j].ToString("x"));
                     }
                     Assert.Fail("mismatch");
                 }


[19/53] [abbrv] lucenenet git commit: Lucene.Net.QueryParser: Renamed all type-derived properties and methods from Short, Int, Long, and Float to match CLR types Int16, Int32, Int64, and Single, respectively.

Posted by ni...@apache.org.
Lucene.Net.QueryParser: Renamed all type-derived properties and methods from Short, Int, Long, and Float to match CLR types Int16, Int32, Int64, and Single, respectively.


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

Branch: refs/heads/api-work
Commit: 67f5e6ca2b6ff44a4ac976d91df4d42961ac7122
Parents: ec70857
Author: Shad Storhaug <sh...@shadstorhaug.com>
Authored: Wed Feb 8 00:32:31 2017 +0700
Committer: Shad Storhaug <sh...@shadstorhaug.com>
Committed: Wed Feb 8 21:08:21 2017 +0700

----------------------------------------------------------------------
 src/Lucene.Net.QueryParser/Classic/QueryParserBase.cs          | 6 ++++--
 .../Flexible/Standard/Parser/EscapeQuerySyntaxImpl.cs          | 6 ++++--
 2 files changed, 8 insertions(+), 4 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/lucenenet/blob/67f5e6ca/src/Lucene.Net.QueryParser/Classic/QueryParserBase.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.QueryParser/Classic/QueryParserBase.cs b/src/Lucene.Net.QueryParser/Classic/QueryParserBase.cs
index 0f0521d..2702716 100644
--- a/src/Lucene.Net.QueryParser/Classic/QueryParserBase.cs
+++ b/src/Lucene.Net.QueryParser/Classic/QueryParserBase.cs
@@ -927,7 +927,7 @@ namespace Lucene.Net.QueryParsers.Classic
                 char curChar = input[i];
                 if (codePointMultiplier > 0)
                 {
-                    codePoint += HexToInt(curChar) * codePointMultiplier;
+                    codePoint += HexToInt32(curChar) * codePointMultiplier;
                     codePointMultiplier = Number.URShift(codePointMultiplier, 4);
                     if (codePointMultiplier == 0)
                     {
@@ -979,8 +979,10 @@ namespace Lucene.Net.QueryParsers.Classic
 
         /// <summary>
         /// Returns the numeric value of the hexadecimal character
+        /// <para/>
+        /// NOTE: This was hexToInt() in Lucene
         /// </summary>
-        private static int HexToInt(char c)
+        private static int HexToInt32(char c)
         {
             if ('0' <= c && c <= '9')
             {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/67f5e6ca/src/Lucene.Net.QueryParser/Flexible/Standard/Parser/EscapeQuerySyntaxImpl.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.QueryParser/Flexible/Standard/Parser/EscapeQuerySyntaxImpl.cs b/src/Lucene.Net.QueryParser/Flexible/Standard/Parser/EscapeQuerySyntaxImpl.cs
index 722941f..9d6b660 100644
--- a/src/Lucene.Net.QueryParser/Flexible/Standard/Parser/EscapeQuerySyntaxImpl.cs
+++ b/src/Lucene.Net.QueryParser/Flexible/Standard/Parser/EscapeQuerySyntaxImpl.cs
@@ -274,7 +274,7 @@ namespace Lucene.Net.QueryParsers.Flexible.Standard.Parser
                 char curChar = input[i];
                 if (codePointMultiplier > 0)
                 {
-                    codePoint += HexToInt(curChar) * codePointMultiplier;
+                    codePoint += HexToInt32(curChar) * codePointMultiplier;
                     codePointMultiplier = (int)((uint)codePointMultiplier >> 4);
                     if (codePointMultiplier == 0)
                     {
@@ -329,8 +329,10 @@ namespace Lucene.Net.QueryParsers.Flexible.Standard.Parser
 
         /// <summary>
         /// Returns the numeric value of the hexadecimal character
+        /// <para/>
+        /// NOTE: This was hexToInt() in Lucene
         /// </summary>
-        private static int HexToInt(char c)
+        private static int HexToInt32(char c)
         {
             if ('0' <= c && c <= '9')
             {


[11/53] [abbrv] lucenenet git commit: Lucene.Net.Core: Renamed all type-derived properties and methods from Short, Int, Long, and Float to match CLR types Int16, Int32, Int64, and Single, respectively.

Posted by ni...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Codecs/BlockTreeTermsReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/BlockTreeTermsReader.cs b/src/Lucene.Net.Core/Codecs/BlockTreeTermsReader.cs
index be4641d..a9ecb01 100644
--- a/src/Lucene.Net.Core/Codecs/BlockTreeTermsReader.cs
+++ b/src/Lucene.Net.Core/Codecs/BlockTreeTermsReader.cs
@@ -154,7 +154,7 @@ namespace Lucene.Net.Codecs
                     SeekDir(indexIn, indexDirOffset);
                 }
 
-                int numFields = @in.ReadVInt();
+                int numFields = @in.ReadVInt32();
                 if (numFields < 0)
                 {
                     throw new CorruptIndexException("invalid numFields: " + numFields + " (resource=" + @in + ")");
@@ -162,19 +162,19 @@ namespace Lucene.Net.Codecs
 
                 for (int i = 0; i < numFields; i++)
                 {
-                    int field = @in.ReadVInt();
-                    long numTerms = @in.ReadVLong();
+                    int field = @in.ReadVInt32();
+                    long numTerms = @in.ReadVInt64();
                     Debug.Assert(numTerms >= 0);
-                    int numBytes = @in.ReadVInt();
+                    int numBytes = @in.ReadVInt32();
                     BytesRef rootCode = new BytesRef(new byte[numBytes]);
                     @in.ReadBytes(rootCode.Bytes, 0, numBytes);
                     rootCode.Length = numBytes;
                     FieldInfo fieldInfo = fieldInfos.FieldInfo(field);
                     Debug.Assert(fieldInfo != null, "field=" + field);
-                    long sumTotalTermFreq = fieldInfo.IndexOptions == IndexOptions.DOCS_ONLY ? -1 : @in.ReadVLong();
-                    long sumDocFreq = @in.ReadVLong();
-                    int docCount = @in.ReadVInt();
-                    int longsSize = version >= BlockTreeTermsWriter.VERSION_META_ARRAY ? @in.ReadVInt() : 0;
+                    long sumTotalTermFreq = fieldInfo.IndexOptions == IndexOptions.DOCS_ONLY ? -1 : @in.ReadVInt64();
+                    long sumDocFreq = @in.ReadVInt64();
+                    int docCount = @in.ReadVInt32();
+                    int longsSize = version >= BlockTreeTermsWriter.VERSION_META_ARRAY ? @in.ReadVInt32() : 0;
                     if (docCount < 0 || docCount > info.DocCount) // #docs with field must be <= #docs
                     {
                         throw new CorruptIndexException("invalid docCount: " + docCount + " maxDoc: " + info.DocCount + " (resource=" + @in + ")");
@@ -187,7 +187,7 @@ namespace Lucene.Net.Codecs
                     {
                         throw new CorruptIndexException("invalid sumTotalTermFreq: " + sumTotalTermFreq + " sumDocFreq: " + sumDocFreq + " (resource=" + @in + ")");
                     }
-                    long indexStartFP = indexDivisor != -1 ? indexIn.ReadVLong() : 0;
+                    long indexStartFP = indexDivisor != -1 ? indexIn.ReadVInt64() : 0;
 
                     if (fields.ContainsKey(fieldInfo.Name))
                     {
@@ -222,7 +222,7 @@ namespace Lucene.Net.Codecs
             int version = CodecUtil.CheckHeader(input, BlockTreeTermsWriter.TERMS_CODEC_NAME, BlockTreeTermsWriter.VERSION_START, BlockTreeTermsWriter.VERSION_CURRENT);
             if (version < BlockTreeTermsWriter.VERSION_APPEND_ONLY)
             {
-                dirOffset = input.ReadLong();
+                dirOffset = input.ReadInt64();
             }
             return version;
         }
@@ -234,7 +234,7 @@ namespace Lucene.Net.Codecs
             int version = CodecUtil.CheckHeader(input, BlockTreeTermsWriter.TERMS_INDEX_CODEC_NAME, BlockTreeTermsWriter.VERSION_START, BlockTreeTermsWriter.VERSION_CURRENT);
             if (version < BlockTreeTermsWriter.VERSION_APPEND_ONLY)
             {
-                indexDirOffset = input.ReadLong();
+                indexDirOffset = input.ReadInt64();
             }
             return version;
         }
@@ -246,12 +246,12 @@ namespace Lucene.Net.Codecs
             if (version >= BlockTreeTermsWriter.VERSION_CHECKSUM)
             {
                 input.Seek(input.Length - CodecUtil.FooterLength() - 8);
-                dirOffset = input.ReadLong();
+                dirOffset = input.ReadInt64();
             }
             else if (version >= BlockTreeTermsWriter.VERSION_APPEND_ONLY)
             {
                 input.Seek(input.Length - 8);
-                dirOffset = input.ReadLong();
+                dirOffset = input.ReadInt64();
             }
             input.Seek(dirOffset);
         }
@@ -568,7 +568,7 @@ namespace Lucene.Net.Codecs
                 //   System.out.println("BTTR: seg=" + segment + " field=" + fieldInfo.name + " rootBlockCode=" + rootCode + " divisor=" + indexDivisor);
                 // }
 
-                rootBlockFP = (int)((uint)(new ByteArrayDataInput((byte[])(Array)rootCode.Bytes, rootCode.Offset, rootCode.Length)).ReadVLong() >> BlockTreeTermsWriter.OUTPUT_FLAGS_NUM_BITS);
+                rootBlockFP = (int)((uint)(new ByteArrayDataInput((byte[])(Array)rootCode.Bytes, rootCode.Offset, rootCode.Length)).ReadVInt64() >> BlockTreeTermsWriter.OUTPUT_FLAGS_NUM_BITS);
 
                 if (indexIn != null)
                 {
@@ -752,9 +752,12 @@ namespace Lucene.Net.Codecs
                     internal readonly BlockTermState termState;
 
                     // metadata buffer, holding monotonic values
+                    /// <summary>
+                    /// NOTE: This was longs (field) in Lucene
+                    /// </summary>
                     [WritableArray]
                     [SuppressMessage("Microsoft.Performance", "CA1819", Justification = "Lucene's design requires some writable array properties")]
-                    public long[] Longs
+                    public long[] Int64s
                     {
                         get { return longs; }
                         set { longs = value; }
@@ -795,7 +798,7 @@ namespace Lucene.Net.Codecs
 
                         do
                         {
-                            fp = fpOrig + ((int)((uint)floorDataReader.ReadVLong() >> 1));
+                            fp = fpOrig + ((int)((uint)floorDataReader.ReadVInt64() >> 1));
                             numFollowFloorBlocks--;
                             // if (DEBUG) System.out.println("    skip floor block2!  nextFloorLabel=" + (char) nextFloorLabel + " vs target=" + (char) transitions[transitionIndex].getMin() + " newFP=" + fp + " numFollowFloorBlocks=" + numFollowFloorBlocks);
                             if (numFollowFloorBlocks != 0)
@@ -842,10 +845,10 @@ namespace Lucene.Net.Codecs
                             floorDataReader.Reset(floorData, 0, frameIndexData.Length);
                             // Skip first long -- has redundant fp, hasTerms
                             // flag, isFloor flag
-                            long code = floorDataReader.ReadVLong();
+                            long code = floorDataReader.ReadVInt64();
                             if ((code & BlockTreeTermsWriter.OUTPUT_FLAG_IS_FLOOR) != 0)
                             {
-                                numFollowFloorBlocks = floorDataReader.ReadVInt();
+                                numFollowFloorBlocks = floorDataReader.ReadVInt32();
                                 nextFloorLabel = floorDataReader.ReadByte() & 0xff;
                                 // if (DEBUG) System.out.println("    numFollowFloorBlocks=" + numFollowFloorBlocks + " nextFloorLabel=" + nextFloorLabel);
 
@@ -856,7 +859,7 @@ namespace Lucene.Net.Codecs
                                     // Maybe skip floor blocks:
                                     while (numFollowFloorBlocks != 0 && nextFloorLabel <= transitions[0].Min)
                                     {
-                                        fp = fpOrig + ((int)((uint)floorDataReader.ReadVLong() >> 1));
+                                        fp = fpOrig + ((int)((uint)floorDataReader.ReadVInt64() >> 1));
                                         numFollowFloorBlocks--;
                                         // if (DEBUG) System.out.println("    skip floor block!  nextFloorLabel=" + (char) nextFloorLabel + " vs target=" + (char) transitions[0].getMin() + " newFP=" + fp + " numFollowFloorBlocks=" + numFollowFloorBlocks);
                                         if (numFollowFloorBlocks != 0)
@@ -873,13 +876,13 @@ namespace Lucene.Net.Codecs
                         }
 
                         outerInstance.@in.Seek(fp);
-                        int code_ = outerInstance.@in.ReadVInt();
+                        int code_ = outerInstance.@in.ReadVInt32();
                         entCount = (int)((uint)code_ >> 1);
                         Debug.Assert(entCount > 0);
                         isLastInFloor = (code_ & 1) != 0;
 
                         // term suffixes:
-                        code_ = outerInstance.@in.ReadVInt();
+                        code_ = outerInstance.@in.ReadVInt32();
                         isLeafBlock = (code_ & 1) != 0;
                         int numBytes = (int)((uint)code_ >> 1);
                         // if (DEBUG) System.out.println("      entCount=" + entCount + " lastInFloor?=" + isLastInFloor + " leafBlock?=" + isLeafBlock + " numSuffixBytes=" + numBytes);
@@ -891,7 +894,7 @@ namespace Lucene.Net.Codecs
                         suffixesReader.Reset(suffixBytes, 0, numBytes);
 
                         // stats
-                        numBytes = outerInstance.@in.ReadVInt();
+                        numBytes = outerInstance.@in.ReadVInt32();
                         if (statBytes.Length < numBytes)
                         {
                             statBytes = new byte[ArrayUtil.Oversize(numBytes, 1)];
@@ -904,7 +907,7 @@ namespace Lucene.Net.Codecs
                         nextEnt = 0;
 
                         // metadata
-                        numBytes = outerInstance.@in.ReadVInt();
+                        numBytes = outerInstance.@in.ReadVInt32();
                         if (bytes == null)
                         {
                             bytes = new byte[ArrayUtil.Oversize(numBytes, 1)];
@@ -938,7 +941,7 @@ namespace Lucene.Net.Codecs
                         //if (DEBUG) System.out.println("  frame.next ord=" + ord + " nextEnt=" + nextEnt + " entCount=" + entCount);
                         Debug.Assert(nextEnt != -1 && nextEnt < entCount, "nextEnt=" + nextEnt + " entCount=" + entCount + " fp=" + fp);
                         nextEnt++;
-                        suffix = suffixesReader.ReadVInt();
+                        suffix = suffixesReader.ReadVInt32();
                         startBytePos = suffixesReader.Position;
                         suffixesReader.SkipBytes(suffix);
                         return false;
@@ -949,7 +952,7 @@ namespace Lucene.Net.Codecs
                         //if (DEBUG) System.out.println("  frame.next ord=" + ord + " nextEnt=" + nextEnt + " entCount=" + entCount);
                         Debug.Assert(nextEnt != -1 && nextEnt < entCount, "nextEnt=" + nextEnt + " entCount=" + entCount + " fp=" + fp);
                         nextEnt++;
-                        int code = suffixesReader.ReadVInt();
+                        int code = suffixesReader.ReadVInt32();
                         suffix = (int)((uint)code >> 1);
                         startBytePos = suffixesReader.Position;
                         suffixesReader.SkipBytes(suffix);
@@ -962,7 +965,7 @@ namespace Lucene.Net.Codecs
                         else
                         {
                             // A sub-block; make sub-FP absolute:
-                            lastSubFP = fp - suffixesReader.ReadVLong();
+                            lastSubFP = fp - suffixesReader.ReadVInt64();
                             return true;
                         }
                     }
@@ -995,17 +998,17 @@ namespace Lucene.Net.Codecs
                             // just skipN here:
 
                             // stats
-                            termState.DocFreq = statsReader.ReadVInt();
+                            termState.DocFreq = statsReader.ReadVInt32();
                             //if (DEBUG) System.out.println("    dF=" + state.docFreq);
                             if (outerInstance.outerInstance.fieldInfo.IndexOptions != IndexOptions.DOCS_ONLY)
                             {
-                                termState.TotalTermFreq = termState.DocFreq + statsReader.ReadVLong();
+                                termState.TotalTermFreq = termState.DocFreq + statsReader.ReadVInt64();
                                 //if (DEBUG) System.out.println("    totTF=" + state.totalTermFreq);
                             }
                             // metadata
                             for (int i = 0; i < outerInstance.outerInstance.longsSize; i++)
                             {
-                                longs[i] = bytesReader.ReadVLong();
+                                longs[i] = bytesReader.ReadVInt64();
                             }
                             outerInstance.outerInstance.outerInstance.postingsReader.DecodeTerm(longs, bytesReader, outerInstance.outerInstance.fieldInfo, termState, absolute);
 
@@ -1760,7 +1763,7 @@ namespace Lucene.Net.Codecs
                 internal Frame PushFrame(FST.Arc<BytesRef> arc, BytesRef frameData, int length)
                 {
                     scratchReader.Reset((byte[])(Array)frameData.Bytes, frameData.Offset, frameData.Length);
-                    long code = scratchReader.ReadVLong();
+                    long code = scratchReader.ReadVInt64();
                     long fpSeek = (long)((ulong)code >> BlockTreeTermsWriter.OUTPUT_FLAGS_NUM_BITS);
                     Frame f = GetFrame(1 + currentFrame.ord);
                     f.hasTerms = (code & BlockTreeTermsWriter.OUTPUT_FLAG_HAS_TERMS) != 0;
@@ -2732,9 +2735,12 @@ namespace Lucene.Net.Codecs
                     internal readonly BlockTermState state;
 
                     // metadata buffer, holding monotonic values
+                    /// <summary>
+                    /// NOTE: This was longs (field) in Lucene
+                    /// </summary>
                     [WritableArray]
                     [SuppressMessage("Microsoft.Performance", "CA1819", Justification = "Lucene's design requires some writable array properties")]
-                    public long[] Longs
+                    public long[] Int64s
                     {
                         get { return longs; }
                         set { longs = value; }
@@ -2771,7 +2777,7 @@ namespace Lucene.Net.Codecs
                         }
                         System.Buffer.BlockCopy(source.Bytes, source.Offset + @in.Position, floorData, 0, numBytes);
                         floorDataReader.Reset(floorData, 0, numBytes);
-                        numFollowFloorBlocks = floorDataReader.ReadVInt();
+                        numFollowFloorBlocks = floorDataReader.ReadVInt32();
                         nextFloorLabel = floorDataReader.ReadByte() & 0xff;
                         //if (DEBUG) {
                         //System.out.println("    setFloorData fpOrig=" + fpOrig + " bytes=" + new BytesRef(source.bytes, source.offset + in.getPosition(), numBytes) + " numFollowFloorBlocks=" + numFollowFloorBlocks + " nextFloorLabel=" + toHex(nextFloorLabel));
@@ -2822,7 +2828,7 @@ namespace Lucene.Net.Codecs
                         //System.out.println("blc=" + blockLoadCount);
 
                         outerInstance.@in.Seek(fp);
-                        int code = outerInstance.@in.ReadVInt();
+                        int code = outerInstance.@in.ReadVInt32();
                         entCount = (int)((uint)code >> 1);
                         Debug.Assert(entCount > 0);
                         isLastInFloor = (code & 1) != 0;
@@ -2834,7 +2840,7 @@ namespace Lucene.Net.Codecs
                         // we could have simple array of offsets
 
                         // term suffixes:
-                        code = outerInstance.@in.ReadVInt();
+                        code = outerInstance.@in.ReadVInt32();
                         isLeafBlock = (code & 1) != 0;
                         int numBytes = (int)((uint)code >> 1);
                         if (suffixBytes.Length < numBytes)
@@ -2853,7 +2859,7 @@ namespace Lucene.Net.Codecs
                           }*/
 
                         // stats
-                        numBytes = outerInstance.@in.ReadVInt();
+                        numBytes = outerInstance.@in.ReadVInt32();
                         if (statBytes.Length < numBytes)
                         {
                             statBytes = new byte[ArrayUtil.Oversize(numBytes, 1)];
@@ -2869,7 +2875,7 @@ namespace Lucene.Net.Codecs
                         // TODO: we could skip this if !hasTerms; but
                         // that's rare so won't help much
                         // metadata
-                        numBytes = outerInstance.@in.ReadVInt();
+                        numBytes = outerInstance.@in.ReadVInt32();
                         if (bytes == null)
                         {
                             bytes = new byte[ArrayUtil.Oversize(numBytes, 1)];
@@ -2899,7 +2905,7 @@ namespace Lucene.Net.Codecs
                         if (isFloor)
                         {
                             floorDataReader.Rewind();
-                            numFollowFloorBlocks = floorDataReader.ReadVInt();
+                            numFollowFloorBlocks = floorDataReader.ReadVInt32();
                             nextFloorLabel = floorDataReader.ReadByte() & 0xff;
                         }
 
@@ -2949,7 +2955,7 @@ namespace Lucene.Net.Codecs
                         //if (DEBUG) System.out.println("  frame.next ord=" + ord + " nextEnt=" + nextEnt + " entCount=" + entCount);
                         Debug.Assert(nextEnt != -1 && nextEnt < entCount, "nextEnt=" + nextEnt + " entCount=" + entCount + " fp=" + fp);
                         nextEnt++;
-                        suffix = suffixesReader.ReadVInt();
+                        suffix = suffixesReader.ReadVInt32();
                         startBytePos = suffixesReader.Position;
                         outerInstance.term.Length = prefix + suffix;
                         if (outerInstance.term.Bytes.Length < outerInstance.term.Length)
@@ -2967,7 +2973,7 @@ namespace Lucene.Net.Codecs
                         //if (DEBUG) System.out.println("  frame.next ord=" + ord + " nextEnt=" + nextEnt + " entCount=" + entCount);
                         Debug.Assert(nextEnt != -1 && nextEnt < entCount, "nextEnt=" + nextEnt + " entCount=" + entCount + " fp=" + fp);
                         nextEnt++;
-                        int code = suffixesReader.ReadVInt();
+                        int code = suffixesReader.ReadVInt32();
                         suffix = (int)((uint)code >> 1);
                         startBytePos = suffixesReader.Position;
                         outerInstance.term.Length = prefix + suffix;
@@ -2988,7 +2994,7 @@ namespace Lucene.Net.Codecs
                         {
                             // A sub-block; make sub-FP absolute:
                             outerInstance.termExists = false;
-                            subCode = suffixesReader.ReadVLong();
+                            subCode = suffixesReader.ReadVInt64();
                             lastSubFP = fp - subCode;
                             //if (DEBUG) {
                             //System.out.println("    lastSubFP=" + lastSubFP);
@@ -3029,7 +3035,7 @@ namespace Lucene.Net.Codecs
                         long newFP = fpOrig;
                         while (true)
                         {
-                            long code = floorDataReader.ReadVLong();
+                            long code = floorDataReader.ReadVInt64();
                             newFP = fpOrig + ((long)((ulong)code >> 1));
                             hasTerms = (code & 1) != 0;
                             // if (DEBUG) {
@@ -3099,17 +3105,17 @@ namespace Lucene.Net.Codecs
                             // just skipN here:
 
                             // stats
-                            state.DocFreq = statsReader.ReadVInt();
+                            state.DocFreq = statsReader.ReadVInt32();
                             //if (DEBUG) System.out.println("    dF=" + state.docFreq);
                             if (outerInstance.outerInstance.fieldInfo.IndexOptions != IndexOptions.DOCS_ONLY)
                             {
-                                state.TotalTermFreq = state.DocFreq + statsReader.ReadVLong();
+                                state.TotalTermFreq = state.DocFreq + statsReader.ReadVInt64();
                                 //if (DEBUG) System.out.println("    totTF=" + state.totalTermFreq);
                             }
                             // metadata
                             for (int i = 0; i < outerInstance.outerInstance.longsSize; i++)
                             {
-                                longs[i] = bytesReader.ReadVLong();
+                                longs[i] = bytesReader.ReadVInt64();
                             }
                             outerInstance.outerInstance.outerInstance.postingsReader.DecodeTerm(longs, bytesReader, outerInstance.outerInstance.fieldInfo, state, absolute);
 
@@ -3153,12 +3159,12 @@ namespace Lucene.Net.Codecs
                         {
                             Debug.Assert(nextEnt < entCount);
                             nextEnt++;
-                            int code = suffixesReader.ReadVInt();
+                            int code = suffixesReader.ReadVInt32();
                             suffixesReader.SkipBytes(isLeafBlock ? code : (int)((uint)code >> 1));
                             //if (DEBUG) System.out.println("    " + nextEnt + " (of " + entCount + ") ent isSubBlock=" + ((code&1)==1));
                             if ((code & 1) != 0)
                             {
-                                long subCode = suffixesReader.ReadVLong();
+                                long subCode = suffixesReader.ReadVInt64();
                                 //if (DEBUG) System.out.println("      subCode=" + subCode);
                                 if (targetSubCode == subCode)
                                 {
@@ -3212,7 +3218,7 @@ namespace Lucene.Net.Codecs
                         {
                             nextEnt++;
 
-                            suffix = suffixesReader.ReadVInt();
+                            suffix = suffixesReader.ReadVInt32();
 
                             // if (DEBUG) {
                             //   BytesRef suffixBytesRef = new BytesRef();
@@ -3356,7 +3362,7 @@ namespace Lucene.Net.Codecs
                         {
                             nextEnt++;
 
-                            int code = suffixesReader.ReadVInt();
+                            int code = suffixesReader.ReadVInt32();
                             suffix = (int)((uint)code >> 1);
                             // if (DEBUG) {
                             //   BytesRef suffixBytesRef = new BytesRef();
@@ -3377,7 +3383,7 @@ namespace Lucene.Net.Codecs
                             }
                             else
                             {
-                                subCode = suffixesReader.ReadVLong();
+                                subCode = suffixesReader.ReadVInt64();
                                 lastSubFP = fp - subCode;
                             }
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Codecs/BlockTreeTermsWriter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/BlockTreeTermsWriter.cs b/src/Lucene.Net.Core/Codecs/BlockTreeTermsWriter.cs
index 05c55b2..4541d1d 100644
--- a/src/Lucene.Net.Core/Codecs/BlockTreeTermsWriter.cs
+++ b/src/Lucene.Net.Core/Codecs/BlockTreeTermsWriter.cs
@@ -246,7 +246,11 @@ namespace Lucene.Net.Codecs
             public long SumTotalTermFreq { get; private set; }
             public long SumDocFreq { get; private set; }
             public int DocCount { get; private set; }
-            internal int LongsSize { get; private set; }
+
+            /// <summary>
+            /// NOTE: This was longsSize (field) in Lucene
+            /// </summary>
+            internal int Int64sSize { get; private set; }
 
             public FieldMetaData(FieldInfo fieldInfo, BytesRef rootCode, long numTerms, long indexStartFP, long sumTotalTermFreq, long sumDocFreq, int docCount, int longsSize)
             {
@@ -259,7 +263,7 @@ namespace Lucene.Net.Codecs
                 this.SumTotalTermFreq = sumTotalTermFreq;
                 this.SumDocFreq = sumDocFreq;
                 this.DocCount = docCount;
-                this.LongsSize = longsSize;
+                this.Int64sSize = longsSize;
             }
         }
 
@@ -345,14 +349,14 @@ namespace Lucene.Net.Codecs
         /// Writes the terms file trailer. </summary>
         protected internal virtual void WriteTrailer(IndexOutput @out, long dirStart)
         {
-            @out.WriteLong(dirStart);
+            @out.WriteInt64(dirStart);
         }
 
         /// <summary>
         /// Writes the index file trailer. </summary>
         protected internal virtual void WriteIndexTrailer(IndexOutput indexOut, long dirStart)
         {
-            indexOut.WriteLong(dirStart);
+            indexOut.WriteInt64(dirStart);
         }
 
         public override TermsConsumer AddField(FieldInfo field)
@@ -436,10 +440,10 @@ namespace Lucene.Net.Codecs
                 // TODO: try writing the leading vLong in MSB order
                 // (opposite of what Lucene does today), for better
                 // outputs sharing in the FST
-                scratchBytes.WriteVLong(EncodeOutput(Fp, HasTerms, IsFloor));
+                scratchBytes.WriteVInt64(EncodeOutput(Fp, HasTerms, IsFloor));
                 if (IsFloor)
                 {
-                    scratchBytes.WriteVInt(floorBlocks.Count);
+                    scratchBytes.WriteVInt32(floorBlocks.Count);
                     foreach (PendingBlock sub in floorBlocks)
                     {
                         Debug.Assert(sub.FloorLeadByte != -1);
@@ -448,7 +452,7 @@ namespace Lucene.Net.Codecs
                         //}
                         scratchBytes.WriteByte((byte)(sbyte)sub.FloorLeadByte);
                         Debug.Assert(sub.Fp > Fp);
-                        scratchBytes.WriteVLong((sub.Fp - Fp) << 1 | (sub.HasTerms ? 1 : 0));
+                        scratchBytes.WriteVInt64((sub.Fp - Fp) << 1 | (sub.HasTerms ? 1 : 0));
                     }
                 }
 
@@ -457,7 +461,7 @@ namespace Lucene.Net.Codecs
                 var bytes = new byte[(int)scratchBytes.FilePointer];
                 Debug.Assert(bytes.Length > 0);
                 scratchBytes.WriteTo(bytes, 0);
-                indexBuilder.Add(Util.ToIntsRef(Prefix, scratchIntsRef), new BytesRef(bytes, 0, bytes.Length));
+                indexBuilder.Add(Util.ToInt32sRef(Prefix, scratchIntsRef), new BytesRef(bytes, 0, bytes.Length));
                 scratchBytes.Reset();
 
                 // Copy over index for all sub-blocks
@@ -508,7 +512,7 @@ namespace Lucene.Net.Codecs
                     //if (DEBUG) {
                     //  System.out.println("      add sub=" + indexEnt.input + " " + indexEnt.input + " output=" + indexEnt.output);
                     //}
-                    builder.Add(Util.ToIntsRef(indexEnt.Input, scratchIntsRef), indexEnt.Output);
+                    builder.Add(Util.ToInt32sRef(indexEnt.Input, scratchIntsRef), indexEnt.Output);
                 }
             }
         }
@@ -647,7 +651,7 @@ namespace Lucene.Net.Codecs
                     //}
                     //System.out.println("\nwbs count=" + count);
 
-                    int savLabel = prevTerm.Ints[prevTerm.Offset + prefixLength];
+                    int savLabel = prevTerm.Int32s[prevTerm.Offset + prefixLength];
 
                     // Count up how many items fall under
                     // each unique label after the prefix.
@@ -791,7 +795,7 @@ namespace Lucene.Net.Codecs
                             {
                                 curPrefixLength = 1 + prefixLength;
                                 // floor term:
-                                prevTerm.Ints[prevTerm.Offset + prefixLength] = startLabel;
+                                prevTerm.Int32s[prevTerm.Offset + prefixLength] = startLabel;
                             }
                             //System.out.println("  " + subCount + " subs");
                             PendingBlock floorBlock = WriteBlock(prevTerm, prefixLength, curPrefixLength, curStart, pendingCount, subTermCountSums[1 + sub], true, startLabel, curStart == pendingCount);
@@ -824,7 +828,7 @@ namespace Lucene.Net.Codecs
                                 // here
                                 Debug.Assert(startLabel != -1);
                                 Debug.Assert(firstBlock != null);
-                                prevTerm.Ints[prevTerm.Offset + prefixLength] = startLabel;
+                                prevTerm.Int32s[prevTerm.Offset + prefixLength] = startLabel;
                                 //System.out.println("  final " + (numSubs-sub-1) + " subs");
                                 /*
                                 for(sub++;sub < numSubs;sub++) {
@@ -841,7 +845,7 @@ namespace Lucene.Net.Codecs
                         }
                     }
 
-                    prevTerm.Ints[prevTerm.Offset + prefixLength] = savLabel;
+                    prevTerm.Int32s[prevTerm.Offset + prefixLength] = savLabel;
 
                     Debug.Assert(firstBlock != null);
                     firstBlock.CompileIndex(floorBlocks, outerInstance.scratchBytes);
@@ -885,12 +889,12 @@ namespace Lucene.Net.Codecs
                 BytesRef prefix = new BytesRef(indexPrefixLength);
                 for (int m = 0; m < indexPrefixLength; m++)
                 {
-                    prefix.Bytes[m] = (byte)prevTerm.Ints[m];
+                    prefix.Bytes[m] = (byte)prevTerm.Int32s[m];
                 }
                 prefix.Length = indexPrefixLength;
 
                 // Write block header:
-                outerInstance.@out.WriteVInt((length << 1) | (isLastInFloor ? 1 : 0));
+                outerInstance.@out.WriteVInt32((length << 1) | (isLastInFloor ? 1 : 0));
 
                 // 1st pass: pack term suffix bytes into byte[] blob
                 // TODO: cutover to bulk int codec... simple64?
@@ -946,15 +950,15 @@ namespace Lucene.Net.Codecs
                         //   System.out.println("    write term suffix=" + suffixBytes);
                         // }
                         // For leaf block we write suffix straight
-                        suffixWriter.WriteVInt(suffix);
+                        suffixWriter.WriteVInt32(suffix);
                         suffixWriter.WriteBytes(term.Term.Bytes, prefixLength, suffix);
 
                         // Write term stats, to separate byte[] blob:
-                        statsWriter.WriteVInt(state.DocFreq);
+                        statsWriter.WriteVInt32(state.DocFreq);
                         if (fieldInfo.IndexOptions != IndexOptions.DOCS_ONLY)
                         {
                             Debug.Assert(state.TotalTermFreq >= state.DocFreq, state.TotalTermFreq + " vs " + state.DocFreq);
-                            statsWriter.WriteVLong(state.TotalTermFreq - state.DocFreq);
+                            statsWriter.WriteVInt64(state.TotalTermFreq - state.DocFreq);
                         }
 
                         // Write term meta data
@@ -962,7 +966,7 @@ namespace Lucene.Net.Codecs
                         for (int pos = 0; pos < longsSize; pos++)
                         {
                             Debug.Assert(longs[pos] >= 0);
-                            metaWriter.WriteVLong(longs[pos]);
+                            metaWriter.WriteVInt64(longs[pos]);
                         }
                         bytesWriter.WriteTo(metaWriter);
                         bytesWriter.Reset();
@@ -989,15 +993,15 @@ namespace Lucene.Net.Codecs
                             // }
                             // For non-leaf block we borrow 1 bit to record
                             // if entry is term or sub-block
-                            suffixWriter.WriteVInt(suffix << 1);
+                            suffixWriter.WriteVInt32(suffix << 1);
                             suffixWriter.WriteBytes(term.Term.Bytes, prefixLength, suffix);
 
                             // Write term stats, to separate byte[] blob:
-                            statsWriter.WriteVInt(state.DocFreq);
+                            statsWriter.WriteVInt32(state.DocFreq);
                             if (fieldInfo.IndexOptions != IndexOptions.DOCS_ONLY)
                             {
                                 Debug.Assert(state.TotalTermFreq >= state.DocFreq);
-                                statsWriter.WriteVLong(state.TotalTermFreq - state.DocFreq);
+                                statsWriter.WriteVInt64(state.TotalTermFreq - state.DocFreq);
                             }
 
                             // TODO: now that terms dict "sees" these longs,
@@ -1013,7 +1017,7 @@ namespace Lucene.Net.Codecs
                             for (int pos = 0; pos < longsSize; pos++)
                             {
                                 Debug.Assert(longs[pos] >= 0);
-                                metaWriter.WriteVLong(longs[pos]);
+                                metaWriter.WriteVInt64(longs[pos]);
                             }
                             bytesWriter.WriteTo(metaWriter);
                             bytesWriter.Reset();
@@ -1030,7 +1034,7 @@ namespace Lucene.Net.Codecs
 
                             // For non-leaf block we borrow 1 bit to record
                             // if entry is term or sub-block
-                            suffixWriter.WriteVInt((suffix << 1) | 1);
+                            suffixWriter.WriteVInt32((suffix << 1) | 1);
                             suffixWriter.WriteBytes(block.Prefix.Bytes, prefixLength, suffix);
                             Debug.Assert(block.Fp < startFP);
 
@@ -1041,7 +1045,7 @@ namespace Lucene.Net.Codecs
                             //   System.out.println("    write sub-block suffix=" + toString(suffixBytes) + " subFP=" + block.fp + " subCode=" + (startFP-block.fp) + " floor=" + block.isFloor);
                             // }
 
-                            suffixWriter.WriteVLong(startFP - block.Fp);
+                            suffixWriter.WriteVInt64(startFP - block.Fp);
                             subIndices.Add(block.Index);
                         }
                     }
@@ -1054,17 +1058,17 @@ namespace Lucene.Net.Codecs
                 // search on lookup
 
                 // Write suffixes byte[] blob to terms dict output:
-                outerInstance.@out.WriteVInt((int)(suffixWriter.FilePointer << 1) | (isLeafBlock ? 1 : 0));
+                outerInstance.@out.WriteVInt32((int)(suffixWriter.FilePointer << 1) | (isLeafBlock ? 1 : 0));
                 suffixWriter.WriteTo(outerInstance.@out);
                 suffixWriter.Reset();
 
                 // Write term stats byte[] blob
-                outerInstance.@out.WriteVInt((int)statsWriter.FilePointer);
+                outerInstance.@out.WriteVInt32((int)statsWriter.FilePointer);
                 statsWriter.WriteTo(outerInstance.@out);
                 statsWriter.Reset();
 
                 // Write term meta data byte[] blob
-                outerInstance.@out.WriteVInt((int)metaWriter.FilePointer);
+                outerInstance.@out.WriteVInt32((int)metaWriter.FilePointer);
                 metaWriter.WriteTo(outerInstance.@out);
                 metaWriter.Reset();
 
@@ -1134,7 +1138,7 @@ namespace Lucene.Net.Codecs
                 Debug.Assert(stats.DocFreq > 0);
                 //if (DEBUG) System.out.println("BTTW.finishTerm term=" + fieldInfo.name + ":" + toString(text) + " seg=" + segment + " df=" + stats.docFreq);
 
-                blockBuilder.Add(Util.ToIntsRef(text, scratchIntsRef), noOutputs.NoOutput);
+                blockBuilder.Add(Util.ToInt32sRef(text, scratchIntsRef), noOutputs.NoOutput);
                 BlockTermState state = outerInstance.postingsWriter.NewTermState();
                 state.DocFreq = stats.DocFreq;
                 state.TotalTermFreq = stats.TotalTermFreq;
@@ -1199,23 +1203,23 @@ namespace Lucene.Net.Codecs
                 long dirStart = @out.FilePointer;
                 long indexDirStart = indexOut.FilePointer;
 
-                @out.WriteVInt(fields.Count);
+                @out.WriteVInt32(fields.Count);
 
                 foreach (FieldMetaData field in fields)
                 {
                     //System.out.println("  field " + field.fieldInfo.name + " " + field.numTerms + " terms");
-                    @out.WriteVInt(field.FieldInfo.Number);
-                    @out.WriteVLong(field.NumTerms);
-                    @out.WriteVInt(field.RootCode.Length);
+                    @out.WriteVInt32(field.FieldInfo.Number);
+                    @out.WriteVInt64(field.NumTerms);
+                    @out.WriteVInt32(field.RootCode.Length);
                     @out.WriteBytes(field.RootCode.Bytes, field.RootCode.Offset, field.RootCode.Length);
                     if (field.FieldInfo.IndexOptions != IndexOptions.DOCS_ONLY)
                     {
-                        @out.WriteVLong(field.SumTotalTermFreq);
+                        @out.WriteVInt64(field.SumTotalTermFreq);
                     }
-                    @out.WriteVLong(field.SumDocFreq);
-                    @out.WriteVInt(field.DocCount);
-                    @out.WriteVInt(field.LongsSize);
-                    indexOut.WriteVLong(field.IndexStartFP);
+                    @out.WriteVInt64(field.SumDocFreq);
+                    @out.WriteVInt32(field.DocCount);
+                    @out.WriteVInt32(field.Int64sSize);
+                    indexOut.WriteVInt64(field.IndexStartFP);
                 }
                 WriteTrailer(@out, dirStart);
                 CodecUtil.WriteFooter(@out);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Codecs/CodecUtil.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/CodecUtil.cs b/src/Lucene.Net.Core/Codecs/CodecUtil.cs
index a578397..8c565e8 100644
--- a/src/Lucene.Net.Core/Codecs/CodecUtil.cs
+++ b/src/Lucene.Net.Core/Codecs/CodecUtil.cs
@@ -79,9 +79,9 @@ namespace Lucene.Net.Codecs
             {
                 throw new System.ArgumentException("codec must be simple ASCII, less than 128 characters in length [got " + codec + "]");
             }
-            @out.WriteInt(CODEC_MAGIC);
+            @out.WriteInt32(CODEC_MAGIC);
             @out.WriteString(codec);
-            @out.WriteInt(version);
+            @out.WriteInt32(version);
         }
 
         /// <summary>
@@ -124,7 +124,7 @@ namespace Lucene.Net.Codecs
         public static int CheckHeader(DataInput @in, string codec, int minVersion, int maxVersion)
         {
             // Safety to guard against reading a bogus string:
-            int actualHeader = @in.ReadInt();
+            int actualHeader = @in.ReadInt32();
             if (actualHeader != CODEC_MAGIC)
             {
                 throw new System.IO.IOException("codec header mismatch: actual header=" + actualHeader + " vs expected header=" + CODEC_MAGIC + " (resource: " + @in + ")");
@@ -146,7 +146,7 @@ namespace Lucene.Net.Codecs
                 throw new System.IO.IOException("codec mismatch: actual codec=" + actualCodec + " vs expected codec=" + codec + " (resource: " + @in + ")");
             }
 
-            int actualVersion = @in.ReadInt();
+            int actualVersion = @in.ReadInt32();
             if (actualVersion < minVersion)
             {
                 throw new System.IO.IOException("Version: " + actualVersion + " is not supported. Minimum Version number is " + minVersion + ".");
@@ -181,9 +181,9 @@ namespace Lucene.Net.Codecs
         /// <exception cref="IOException"> If there is an I/O error writing to the underlying medium. </exception>
         public static void WriteFooter(IndexOutput @out)
         {
-            @out.WriteInt(FOOTER_MAGIC);
-            @out.WriteInt(0);
-            @out.WriteLong(@out.Checksum);
+            @out.WriteInt32(FOOTER_MAGIC);
+            @out.WriteInt32(0);
+            @out.WriteInt64(@out.Checksum);
         }
 
         /// <summary>
@@ -206,7 +206,7 @@ namespace Lucene.Net.Codecs
         {
             ValidateFooter(@in);
             long actualChecksum = @in.Checksum;
-            long expectedChecksum = @in.ReadLong();
+            long expectedChecksum = @in.ReadInt64();
             if (expectedChecksum != actualChecksum)
             {
                 throw new System.IO.IOException("checksum failed (hardware problem?) : expected=" + expectedChecksum.ToString("x") + " actual=" + actualChecksum.ToString("x") + " (resource=" + @in + ")");
@@ -226,18 +226,18 @@ namespace Lucene.Net.Codecs
         {
             @in.Seek(@in.Length - FooterLength());
             ValidateFooter(@in);
-            return @in.ReadLong();
+            return @in.ReadInt64();
         }
 
         private static void ValidateFooter(IndexInput @in)
         {
-            int magic = @in.ReadInt();
+            int magic = @in.ReadInt32();
             if (magic != FOOTER_MAGIC)
             {
                 throw new System.IO.IOException("codec footer mismatch: actual footer=" + magic + " vs expected footer=" + FOOTER_MAGIC + " (resource: " + @in + ")");
             }
 
-            int algorithmID = @in.ReadInt();
+            int algorithmID = @in.ReadInt32();
             if (algorithmID != 0)
             {
                 throw new System.IO.IOException("codec footer mismatch: unknown algorithmID: " + algorithmID);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Codecs/Compressing/CompressingStoredFieldsIndexReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/Compressing/CompressingStoredFieldsIndexReader.cs b/src/Lucene.Net.Core/Codecs/Compressing/CompressingStoredFieldsIndexReader.cs
index 606267e..7a07078 100644
--- a/src/Lucene.Net.Core/Codecs/Compressing/CompressingStoredFieldsIndexReader.cs
+++ b/src/Lucene.Net.Core/Codecs/Compressing/CompressingStoredFieldsIndexReader.cs
@@ -57,13 +57,13 @@ namespace Lucene.Net.Codecs.Compressing
             PackedInts.Reader[] docBasesDeltas = new PackedInts.Reader[16];
             PackedInts.Reader[] startPointersDeltas = new PackedInts.Reader[16];
 
-            int packedIntsVersion = fieldsIndexIn.ReadVInt();
+            int packedIntsVersion = fieldsIndexIn.ReadVInt32();
 
             int blockCount = 0;
 
             for (; ; )
             {
-                int numChunks = fieldsIndexIn.ReadVInt();
+                int numChunks = fieldsIndexIn.ReadVInt32();
                 if (numChunks == 0)
                 {
                     break;
@@ -80,9 +80,9 @@ namespace Lucene.Net.Codecs.Compressing
                 }
 
                 // doc bases
-                docBases[blockCount] = fieldsIndexIn.ReadVInt();
-                avgChunkDocs[blockCount] = fieldsIndexIn.ReadVInt();
-                int bitsPerDocBase = fieldsIndexIn.ReadVInt();
+                docBases[blockCount] = fieldsIndexIn.ReadVInt32();
+                avgChunkDocs[blockCount] = fieldsIndexIn.ReadVInt32();
+                int bitsPerDocBase = fieldsIndexIn.ReadVInt32();
                 if (bitsPerDocBase > 32)
                 {
                     throw new CorruptIndexException("Corrupted bitsPerDocBase (resource=" + fieldsIndexIn + ")");
@@ -90,9 +90,9 @@ namespace Lucene.Net.Codecs.Compressing
                 docBasesDeltas[blockCount] = PackedInts.GetReaderNoHeader(fieldsIndexIn, PackedInts.Format.PACKED, packedIntsVersion, numChunks, bitsPerDocBase);
 
                 // start pointers
-                startPointers[blockCount] = fieldsIndexIn.ReadVLong();
-                avgChunkSizes[blockCount] = fieldsIndexIn.ReadVLong();
-                int bitsPerStartPointer = fieldsIndexIn.ReadVInt();
+                startPointers[blockCount] = fieldsIndexIn.ReadVInt64();
+                avgChunkSizes[blockCount] = fieldsIndexIn.ReadVInt64();
+                int bitsPerStartPointer = fieldsIndexIn.ReadVInt32();
                 if (bitsPerStartPointer > 64)
                 {
                     throw new CorruptIndexException("Corrupted bitsPerStartPointer (resource=" + fieldsIndexIn + ")");

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Codecs/Compressing/CompressingStoredFieldsIndexWriter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/Compressing/CompressingStoredFieldsIndexWriter.cs b/src/Lucene.Net.Core/Codecs/Compressing/CompressingStoredFieldsIndexWriter.cs
index 101cc79..6d7ce28 100644
--- a/src/Lucene.Net.Core/Codecs/Compressing/CompressingStoredFieldsIndexWriter.cs
+++ b/src/Lucene.Net.Core/Codecs/Compressing/CompressingStoredFieldsIndexWriter.cs
@@ -90,7 +90,7 @@ namespace Lucene.Net.Codecs.Compressing
             totalDocs = 0;
             docBaseDeltas = new int[BLOCK_SIZE];
             startPointerDeltas = new long[BLOCK_SIZE];
-            fieldsIndexOut.WriteVInt(PackedInts.VERSION_CURRENT);
+            fieldsIndexOut.WriteVInt32(PackedInts.VERSION_CURRENT);
         }
 
         private void Reset()
@@ -103,7 +103,7 @@ namespace Lucene.Net.Codecs.Compressing
         private void WriteBlock()
         {
             Debug.Assert(blockChunks > 0);
-            fieldsIndexOut.WriteVInt(blockChunks);
+            fieldsIndexOut.WriteVInt32(blockChunks);
 
             // The trick here is that we only store the difference from the average start
             // pointer or doc base, this helps save bits per value.
@@ -122,8 +122,8 @@ namespace Lucene.Net.Codecs.Compressing
             {
                 avgChunkDocs = (int)Math.Round((float)(blockDocs - docBaseDeltas[blockChunks - 1]) / (blockChunks - 1));
             }
-            fieldsIndexOut.WriteVInt(totalDocs - blockDocs); // docBase
-            fieldsIndexOut.WriteVInt(avgChunkDocs);
+            fieldsIndexOut.WriteVInt32(totalDocs - blockDocs); // docBase
+            fieldsIndexOut.WriteVInt32(avgChunkDocs);
             int docBase = 0;
             long maxDelta = 0;
             for (int i = 0; i < blockChunks; ++i)
@@ -134,7 +134,7 @@ namespace Lucene.Net.Codecs.Compressing
             }
 
             int bitsPerDocBase = PackedInts.BitsRequired(maxDelta);
-            fieldsIndexOut.WriteVInt(bitsPerDocBase);
+            fieldsIndexOut.WriteVInt32(bitsPerDocBase);
             PackedInts.Writer writer = PackedInts.GetWriterNoHeader(fieldsIndexOut, PackedInts.Format.PACKED, blockChunks, bitsPerDocBase, 1);
             docBase = 0;
             for (int i = 0; i < blockChunks; ++i)
@@ -147,7 +147,7 @@ namespace Lucene.Net.Codecs.Compressing
             writer.Finish();
 
             // start pointers
-            fieldsIndexOut.WriteVLong(firstStartPointer);
+            fieldsIndexOut.WriteVInt64(firstStartPointer);
             long avgChunkSize;
             if (blockChunks == 1)
             {
@@ -157,7 +157,7 @@ namespace Lucene.Net.Codecs.Compressing
             {
                 avgChunkSize = (maxStartPointer - firstStartPointer) / (blockChunks - 1);
             }
-            fieldsIndexOut.WriteVLong(avgChunkSize);
+            fieldsIndexOut.WriteVInt64(avgChunkSize);
             long startPointer = 0;
             maxDelta = 0;
             for (int i = 0; i < blockChunks; ++i)
@@ -168,7 +168,7 @@ namespace Lucene.Net.Codecs.Compressing
             }
 
             int bitsPerStartPointer = PackedInts.BitsRequired(maxDelta);
-            fieldsIndexOut.WriteVInt(bitsPerStartPointer);
+            fieldsIndexOut.WriteVInt32(bitsPerStartPointer);
             writer = PackedInts.GetWriterNoHeader(fieldsIndexOut, PackedInts.Format.PACKED, blockChunks, bitsPerStartPointer, 1);
             startPointer = 0;
             for (int i = 0; i < blockChunks; ++i)
@@ -214,8 +214,8 @@ namespace Lucene.Net.Codecs.Compressing
             {
                 WriteBlock();
             }
-            fieldsIndexOut.WriteVInt(0); // end marker
-            fieldsIndexOut.WriteVLong(maxPointer);
+            fieldsIndexOut.WriteVInt32(0); // end marker
+            fieldsIndexOut.WriteVInt64(maxPointer);
             CodecUtil.WriteFooter(fieldsIndexOut);
         }
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Codecs/Compressing/CompressingStoredFieldsReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/Compressing/CompressingStoredFieldsReader.cs b/src/Lucene.Net.Core/Codecs/Compressing/CompressingStoredFieldsReader.cs
index 83dc1d8..7d82d35 100644
--- a/src/Lucene.Net.Core/Codecs/Compressing/CompressingStoredFieldsReader.cs
+++ b/src/Lucene.Net.Core/Codecs/Compressing/CompressingStoredFieldsReader.cs
@@ -105,7 +105,7 @@ namespace Lucene.Net.Codecs.Compressing
 
                 if (version >= CompressingStoredFieldsWriter.VERSION_CHECKSUM)
                 {
-                    maxPointer = indexStream.ReadVLong();
+                    maxPointer = indexStream.ReadVInt64();
                     CodecUtil.CheckFooter(indexStream);
                 }
                 else
@@ -141,13 +141,13 @@ namespace Lucene.Net.Codecs.Compressing
 
                 if (version >= CompressingStoredFieldsWriter.VERSION_BIG_CHUNKS)
                 {
-                    chunkSize = fieldsStream.ReadVInt();
+                    chunkSize = fieldsStream.ReadVInt32();
                 }
                 else
                 {
                     chunkSize = -1;
                 }
-                packedIntsVersion = fieldsStream.ReadVInt();
+                packedIntsVersion = fieldsStream.ReadVInt32();
                 decompressor = compressionMode.NewDecompressor();
                 this.bytes = new BytesRef();
 
@@ -188,14 +188,14 @@ namespace Lucene.Net.Codecs.Compressing
             switch (bits & CompressingStoredFieldsWriter.TYPE_MASK)
             {
                 case CompressingStoredFieldsWriter.BYTE_ARR:
-                    int length = @in.ReadVInt();
+                    int length = @in.ReadVInt32();
                     var data = new byte[length];
                     @in.ReadBytes(data, 0, length);
                     visitor.BinaryField(info, data);
                     break;
 
                 case CompressingStoredFieldsWriter.STRING:
-                    length = @in.ReadVInt();
+                    length = @in.ReadVInt32();
                     data = new byte[length];
                     @in.ReadBytes(data, 0, length);
 #pragma warning disable 612, 618
@@ -204,19 +204,19 @@ namespace Lucene.Net.Codecs.Compressing
                     break;
 
                 case CompressingStoredFieldsWriter.NUMERIC_INT:
-                    visitor.Int32Field(info, @in.ReadInt());
+                    visitor.Int32Field(info, @in.ReadInt32());
                     break;
 
                 case CompressingStoredFieldsWriter.NUMERIC_FLOAT:
-                    visitor.SingleField(info, Number.IntBitsToFloat(@in.ReadInt()));
+                    visitor.SingleField(info, Number.Int32BitsToSingle(@in.ReadInt32()));
                     break;
 
                 case CompressingStoredFieldsWriter.NUMERIC_LONG:
-                    visitor.Int64Field(info, @in.ReadLong());
+                    visitor.Int64Field(info, @in.ReadInt64());
                     break;
 
                 case CompressingStoredFieldsWriter.NUMERIC_DOUBLE:
-                    visitor.DoubleField(info, BitConverter.Int64BitsToDouble(@in.ReadLong()));
+                    visitor.DoubleField(info, BitConverter.Int64BitsToDouble(@in.ReadInt64()));
                     break;
 
                 default:
@@ -230,18 +230,18 @@ namespace Lucene.Net.Codecs.Compressing
             {
                 case CompressingStoredFieldsWriter.BYTE_ARR:
                 case CompressingStoredFieldsWriter.STRING:
-                    int length = @in.ReadVInt();
+                    int length = @in.ReadVInt32();
                     @in.SkipBytes(length);
                     break;
 
                 case CompressingStoredFieldsWriter.NUMERIC_INT:
                 case CompressingStoredFieldsWriter.NUMERIC_FLOAT:
-                    @in.ReadInt();
+                    @in.ReadInt32();
                     break;
 
                 case CompressingStoredFieldsWriter.NUMERIC_LONG:
                 case CompressingStoredFieldsWriter.NUMERIC_DOUBLE:
-                    @in.ReadLong();
+                    @in.ReadInt64();
                     break;
 
                 default:
@@ -253,8 +253,8 @@ namespace Lucene.Net.Codecs.Compressing
         {
             fieldsStream.Seek(indexReader.GetStartPointer(docID));
 
-            int docBase = fieldsStream.ReadVInt();
-            int chunkDocs = fieldsStream.ReadVInt();
+            int docBase = fieldsStream.ReadVInt32();
+            int chunkDocs = fieldsStream.ReadVInt32();
             if (docID < docBase || docID >= docBase + chunkDocs || docBase + chunkDocs > numDocs)
             {
                 throw new CorruptIndexException("Corrupted: docID=" + docID + ", docBase=" + docBase + ", chunkDocs=" + chunkDocs + ", numDocs=" + numDocs + " (resource=" + fieldsStream + ")");
@@ -263,17 +263,17 @@ namespace Lucene.Net.Codecs.Compressing
             int numStoredFields, offset, length, totalLength;
             if (chunkDocs == 1)
             {
-                numStoredFields = fieldsStream.ReadVInt();
+                numStoredFields = fieldsStream.ReadVInt32();
                 offset = 0;
-                length = fieldsStream.ReadVInt();
+                length = fieldsStream.ReadVInt32();
                 totalLength = length;
             }
             else
             {
-                int bitsPerStoredFields = fieldsStream.ReadVInt();
+                int bitsPerStoredFields = fieldsStream.ReadVInt32();
                 if (bitsPerStoredFields == 0)
                 {
-                    numStoredFields = fieldsStream.ReadVInt();
+                    numStoredFields = fieldsStream.ReadVInt32();
                 }
                 else if (bitsPerStoredFields > 31)
                 {
@@ -287,10 +287,10 @@ namespace Lucene.Net.Codecs.Compressing
                     fieldsStream.Seek(filePointer + PackedInts.Format.PACKED.ByteCount(packedIntsVersion, chunkDocs, bitsPerStoredFields));
                 }
 
-                int bitsPerLength = fieldsStream.ReadVInt();
+                int bitsPerLength = fieldsStream.ReadVInt32();
                 if (bitsPerLength == 0)
                 {
-                    length = fieldsStream.ReadVInt();
+                    length = fieldsStream.ReadVInt32();
                     offset = (docID - docBase) * length;
                     totalLength = chunkDocs * length;
                 }
@@ -346,7 +346,7 @@ namespace Lucene.Net.Codecs.Compressing
 
             for (int fieldIDX = 0; fieldIDX < numStoredFields; fieldIDX++)
             {
-                long infoAndBits = documentInput.ReadVLong();
+                long infoAndBits = documentInput.ReadVInt64();
                 int fieldNumber = (int)((long)((ulong)infoAndBits >> CompressingStoredFieldsWriter.TYPE_BITS));
                 FieldInfo fieldInfo = fieldInfos.FieldInfo(fieldNumber);
 
@@ -507,8 +507,8 @@ namespace Lucene.Net.Codecs.Compressing
                 Debug.Assert(doc >= this.docBase + this.chunkDocs, doc + " " + this.docBase + " " + this.chunkDocs);
                 fieldsStream.Seek(outerInstance.indexReader.GetStartPointer(doc));
 
-                int docBase = fieldsStream.ReadVInt();
-                int chunkDocs = fieldsStream.ReadVInt();
+                int docBase = fieldsStream.ReadVInt32();
+                int chunkDocs = fieldsStream.ReadVInt32();
                 if (docBase < this.docBase + this.chunkDocs || docBase + chunkDocs > outerInstance.numDocs)
                 {
                     throw new CorruptIndexException("Corrupted: current docBase=" + this.docBase + ", current numDocs=" + this.chunkDocs + ", new docBase=" + docBase + ", new numDocs=" + chunkDocs + " (resource=" + fieldsStream + ")");
@@ -525,15 +525,15 @@ namespace Lucene.Net.Codecs.Compressing
 
                 if (chunkDocs == 1)
                 {
-                    numStoredFields[0] = fieldsStream.ReadVInt();
-                    lengths[0] = fieldsStream.ReadVInt();
+                    numStoredFields[0] = fieldsStream.ReadVInt32();
+                    lengths[0] = fieldsStream.ReadVInt32();
                 }
                 else
                 {
-                    int bitsPerStoredFields = fieldsStream.ReadVInt();
+                    int bitsPerStoredFields = fieldsStream.ReadVInt32();
                     if (bitsPerStoredFields == 0)
                     {
-                        Arrays.Fill(numStoredFields, 0, chunkDocs, fieldsStream.ReadVInt());
+                        Arrays.Fill(numStoredFields, 0, chunkDocs, fieldsStream.ReadVInt32());
                     }
                     else if (bitsPerStoredFields > 31)
                     {
@@ -548,10 +548,10 @@ namespace Lucene.Net.Codecs.Compressing
                         }
                     }
 
-                    int bitsPerLength = fieldsStream.ReadVInt();
+                    int bitsPerLength = fieldsStream.ReadVInt32();
                     if (bitsPerLength == 0)
                     {
-                        Arrays.Fill(lengths, 0, chunkDocs, fieldsStream.ReadVInt());
+                        Arrays.Fill(lengths, 0, chunkDocs, fieldsStream.ReadVInt32());
                     }
                     else if (bitsPerLength > 31)
                     {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Codecs/Compressing/CompressingStoredFieldsWriter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/Compressing/CompressingStoredFieldsWriter.cs b/src/Lucene.Net.Core/Codecs/Compressing/CompressingStoredFieldsWriter.cs
index 28f94ad..b1f722e 100644
--- a/src/Lucene.Net.Core/Codecs/Compressing/CompressingStoredFieldsWriter.cs
+++ b/src/Lucene.Net.Core/Codecs/Compressing/CompressingStoredFieldsWriter.cs
@@ -102,8 +102,8 @@ namespace Lucene.Net.Codecs.Compressing
                 indexWriter = new CompressingStoredFieldsIndexWriter(indexStream);
                 indexStream = null;
 
-                fieldsStream.WriteVInt(chunkSize);
-                fieldsStream.WriteVInt(PackedInts.VERSION_CURRENT);
+                fieldsStream.WriteVInt32(chunkSize);
+                fieldsStream.WriteVInt32(PackedInts.VERSION_CURRENT);
 
                 success = true;
             }
@@ -154,12 +154,15 @@ namespace Lucene.Net.Codecs.Compressing
             }
         }
 
-        private static void SaveInts(int[] values, int length, DataOutput @out) // LUCENENET TODO: Rename SaveInt32s ?
+        /// <summary>
+        /// NOTE: This was saveInts() in Lucene
+        /// </summary>
+        private static void SaveInt32s(int[] values, int length, DataOutput @out)
         {
             Debug.Assert(length > 0);
             if (length == 1)
             {
-                @out.WriteVInt(values[0]);
+                @out.WriteVInt32(values[0]);
             }
             else
             {
@@ -174,8 +177,8 @@ namespace Lucene.Net.Codecs.Compressing
                 }
                 if (allEqual)
                 {
-                    @out.WriteVInt(0);
-                    @out.WriteVInt(values[0]);
+                    @out.WriteVInt32(0);
+                    @out.WriteVInt32(values[0]);
                 }
                 else
                 {
@@ -185,7 +188,7 @@ namespace Lucene.Net.Codecs.Compressing
                         max |= (uint)values[i];
                     }
                     int bitsRequired = PackedInts.BitsRequired(max);
-                    @out.WriteVInt(bitsRequired);
+                    @out.WriteVInt32(bitsRequired);
                     PackedInts.Writer w = PackedInts.GetWriterNoHeader(@out, PackedInts.Format.PACKED, length, bitsRequired, 1);
                     for (int i = 0; i < length; ++i)
                     {
@@ -199,14 +202,14 @@ namespace Lucene.Net.Codecs.Compressing
         private void WriteHeader(int docBase, int numBufferedDocs, int[] numStoredFields, int[] lengths)
         {
             // save docBase and numBufferedDocs
-            fieldsStream.WriteVInt(docBase);
-            fieldsStream.WriteVInt(numBufferedDocs);
+            fieldsStream.WriteVInt32(docBase);
+            fieldsStream.WriteVInt32(numBufferedDocs);
 
             // save numStoredFields
-            SaveInts(numStoredFields, numBufferedDocs, fieldsStream);
+            SaveInt32s(numStoredFields, numBufferedDocs, fieldsStream);
 
             // save lengths
-            SaveInts(lengths, numBufferedDocs, fieldsStream);
+            SaveInt32s(lengths, numBufferedDocs, fieldsStream);
         }
 
         private bool TriggerFlush()
@@ -333,11 +336,11 @@ namespace Lucene.Net.Codecs.Compressing
             }
 
             long infoAndBits = (((long)info.Number) << TYPE_BITS) | bits;
-            bufferedDocs.WriteVLong(infoAndBits);
+            bufferedDocs.WriteVInt64(infoAndBits);
 
             if (bytes != null)
             {
-                bufferedDocs.WriteVInt(bytes.Length);
+                bufferedDocs.WriteVInt32(bytes.Length);
                 bufferedDocs.WriteBytes(bytes.Bytes, bytes.Offset, bytes.Length);
             }
             else if (@string != null)
@@ -381,19 +384,19 @@ namespace Lucene.Net.Codecs.Compressing
                 {
                     if (number is sbyte || number is short || number is int)
                     {
-                        bufferedDocs.WriteInt((int)number);
+                        bufferedDocs.WriteInt32((int)number);
                     }
                     else if (number is long)
                     {
-                        bufferedDocs.WriteLong((long)number);
+                        bufferedDocs.WriteInt64((long)number);
                     }
                     else if (number is float)
                     {
-                        bufferedDocs.WriteInt(Number.FloatToIntBits((float)number));
+                        bufferedDocs.WriteInt32(Number.SingleToInt32Bits((float)number));
                     }
                     else if (number is double)
                     {
-                        bufferedDocs.WriteLong(BitConverter.DoubleToInt64Bits((double)number));
+                        bufferedDocs.WriteInt64(BitConverter.DoubleToInt64Bits((double)number));
                     }
                     else
                     {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Codecs/Compressing/CompressingTermVectorsReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/Compressing/CompressingTermVectorsReader.cs b/src/Lucene.Net.Core/Codecs/Compressing/CompressingTermVectorsReader.cs
index 1abbb55..af107da 100644
--- a/src/Lucene.Net.Core/Codecs/Compressing/CompressingTermVectorsReader.cs
+++ b/src/Lucene.Net.Core/Codecs/Compressing/CompressingTermVectorsReader.cs
@@ -83,7 +83,7 @@ namespace Lucene.Net.Codecs.Compressing
 
                 if (version >= CompressingTermVectorsWriter.VERSION_CHECKSUM)
                 {
-                    indexStream.ReadVLong(); // the end of the data file
+                    indexStream.ReadVInt64(); // the end of the data file
                     CodecUtil.CheckFooter(indexStream);
                 }
                 else
@@ -106,8 +106,8 @@ namespace Lucene.Net.Codecs.Compressing
                 }
                 Debug.Assert(CodecUtil.HeaderLength(codecNameDat) == vectorsStream.FilePointer);
 
-                packedIntsVersion = vectorsStream.ReadVInt();
-                chunkSize = vectorsStream.ReadVInt();
+                packedIntsVersion = vectorsStream.ReadVInt32();
+                chunkSize = vectorsStream.ReadVInt32();
                 decompressor = compressionMode.NewDecompressor();
                 this.reader = new BlockPackedReaderIterator(vectorsStream, packedIntsVersion, CompressingTermVectorsWriter.BLOCK_SIZE, 0);
 
@@ -138,7 +138,10 @@ namespace Lucene.Net.Codecs.Compressing
             }
         }
 
-        internal int PackedIntsVersion
+        /// <summary>
+        /// NOTE: This was getPackedIntsVersion() in Lucene
+        /// </summary>
+        internal int PackedInt32sVersion
         {
             get
             {
@@ -206,8 +209,8 @@ namespace Lucene.Net.Codecs.Compressing
             // decode
             // - docBase: first doc ID of the chunk
             // - chunkDocs: number of docs of the chunk
-            int docBase = vectorsStream.ReadVInt();
-            int chunkDocs = vectorsStream.ReadVInt();
+            int docBase = vectorsStream.ReadVInt32();
+            int chunkDocs = vectorsStream.ReadVInt32();
             if (doc < docBase || doc >= docBase + chunkDocs || docBase + chunkDocs > numDocs)
             {
                 throw new CorruptIndexException("docBase=" + docBase + ",chunkDocs=" + chunkDocs + ",doc=" + doc + " (resource=" + vectorsStream + ")");
@@ -219,7 +222,7 @@ namespace Lucene.Net.Codecs.Compressing
             if (chunkDocs == 1)
             {
                 skip = 0;
-                numFields = totalFields = vectorsStream.ReadVInt();
+                numFields = totalFields = vectorsStream.ReadVInt32();
             }
             else
             {
@@ -254,7 +257,7 @@ namespace Lucene.Net.Codecs.Compressing
                 int totalDistinctFields = (int)((uint)token >> 5);
                 if (totalDistinctFields == 0x07)
                 {
-                    totalDistinctFields += vectorsStream.ReadVInt();
+                    totalDistinctFields += vectorsStream.ReadVInt32();
                 }
                 ++totalDistinctFields;
                 PackedInts.IReaderIterator it = PackedInts.GetReaderIteratorNoHeader(vectorsStream, PackedInts.Format.PACKED, packedIntsVersion, totalDistinctFields, bitsPerFieldNum, 1);
@@ -271,7 +274,7 @@ namespace Lucene.Net.Codecs.Compressing
             {
                 int bitsPerOff = PackedInts.BitsRequired(fieldNums.Length - 1);
                 PackedInts.Reader allFieldNumOffs = PackedInts.GetReaderNoHeader(vectorsStream, PackedInts.Format.PACKED, packedIntsVersion, totalFields, bitsPerOff);
-                switch (vectorsStream.ReadVInt())
+                switch (vectorsStream.ReadVInt32())
                 {
                     case 0:
                         PackedInts.Reader fieldFlags = PackedInts.GetReaderNoHeader(vectorsStream, PackedInts.Format.PACKED, packedIntsVersion, fieldNums.Length, CompressingTermVectorsWriter.FLAGS_BITS);
@@ -303,7 +306,7 @@ namespace Lucene.Net.Codecs.Compressing
             PackedInts.Reader numTerms;
             int totalTerms;
             {
-                int bitsRequired = vectorsStream.ReadVInt();
+                int bitsRequired = vectorsStream.ReadVInt32();
                 numTerms = PackedInts.GetReaderNoHeader(vectorsStream, PackedInts.Format.PACKED, packedIntsVersion, totalFields, bitsRequired);
                 int sum = 0;
                 for (int i = 0; i < totalFields; ++i)
@@ -338,7 +341,7 @@ namespace Lucene.Net.Codecs.Compressing
                         LongsRef next = reader.Next(termCount - j);
                         for (int k = 0; k < next.Length; ++k)
                         {
-                            fieldPrefixLengths[j++] = (int)next.Longs[next.Offset + k];
+                            fieldPrefixLengths[j++] = (int)next.Int64s[next.Offset + k];
                         }
                     }
                 }
@@ -364,7 +367,7 @@ namespace Lucene.Net.Codecs.Compressing
                         LongsRef next = reader.Next(termCount - j);
                         for (int k = 0; k < next.Length; ++k)
                         {
-                            fieldSuffixLengths[j++] = (int)next.Longs[next.Offset + k];
+                            fieldSuffixLengths[j++] = (int)next.Int64s[next.Offset + k];
                         }
                     }
                     fieldLengths[i] = Sum(suffixLengths[i]);
@@ -389,7 +392,7 @@ namespace Lucene.Net.Codecs.Compressing
                     LongsRef next = reader.Next(totalTerms - i);
                     for (int k = 0; k < next.Length; ++k)
                     {
-                        termFreqs[i++] = 1 + (int)next.Longs[next.Offset + k];
+                        termFreqs[i++] = 1 + (int)next.Int64s[next.Offset + k];
                     }
                 }
             }
@@ -436,7 +439,7 @@ namespace Lucene.Net.Codecs.Compressing
                 float[] charsPerTerm = new float[fieldNums.Length];
                 for (int i = 0; i < charsPerTerm.Length; ++i)
                 {
-                    charsPerTerm[i] = Number.IntBitsToFloat(vectorsStream.ReadInt());
+                    charsPerTerm[i] = Number.Int32BitsToSingle(vectorsStream.ReadInt32());
                 }
                 startOffsets = ReadPositions(skip, numFields, flags, numTerms, termFreqs, CompressingTermVectorsWriter.OFFSETS, totalOffsets, positionIndex);
                 lengths = ReadPositions(skip, numFields, flags, numTerms, termFreqs, CompressingTermVectorsWriter.OFFSETS, totalOffsets, positionIndex);
@@ -676,7 +679,7 @@ namespace Lucene.Net.Codecs.Compressing
                         LongsRef nextPositions = reader.Next(totalFreq - j);
                         for (int k = 0; k < nextPositions.Length; ++k)
                         {
-                            fieldPositions[j++] = (int)nextPositions.Longs[nextPositions.Offset + k];
+                            fieldPositions[j++] = (int)nextPositions.Int64s[nextPositions.Offset + k];
                         }
                     }
                 }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Codecs/Compressing/CompressingTermVectorsWriter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/Compressing/CompressingTermVectorsWriter.cs b/src/Lucene.Net.Core/Codecs/Compressing/CompressingTermVectorsWriter.cs
index 2f5055a..275ca91 100644
--- a/src/Lucene.Net.Core/Codecs/Compressing/CompressingTermVectorsWriter.cs
+++ b/src/Lucene.Net.Core/Codecs/Compressing/CompressingTermVectorsWriter.cs
@@ -268,8 +268,8 @@ namespace Lucene.Net.Codecs.Compressing
                 indexWriter = new CompressingStoredFieldsIndexWriter(indexStream);
                 indexStream = null;
 
-                vectorsStream.WriteVInt(PackedInts.VERSION_CURRENT);
-                vectorsStream.WriteVInt(chunkSize);
+                vectorsStream.WriteVInt32(PackedInts.VERSION_CURRENT);
+                vectorsStream.WriteVInt32(chunkSize);
                 writer = new BlockPackedWriter(vectorsStream, BLOCK_SIZE);
 
                 positionsBuf = new int[1024];
@@ -380,8 +380,8 @@ namespace Lucene.Net.Codecs.Compressing
             indexWriter.WriteIndex(chunkDocs, vectorsStream.FilePointer);
 
             int docBase = numDocs - chunkDocs;
-            vectorsStream.WriteVInt(docBase);
-            vectorsStream.WriteVInt(chunkDocs);
+            vectorsStream.WriteVInt32(docBase);
+            vectorsStream.WriteVInt32(chunkDocs);
 
             // total number of fields of the chunk
             int totalFields = FlushNumFields(chunkDocs);
@@ -423,7 +423,7 @@ namespace Lucene.Net.Codecs.Compressing
             if (chunkDocs == 1)
             {
                 int numFields = pendingDocs.First.Value.numFields;
-                vectorsStream.WriteVInt(numFields);
+                vectorsStream.WriteVInt32(numFields);
                 return numFields;
             }
             else
@@ -460,7 +460,7 @@ namespace Lucene.Net.Codecs.Compressing
             vectorsStream.WriteByte((byte)(sbyte)token);
             if (numDistinctFields - 1 >= 0x07)
             {
-                vectorsStream.WriteVInt(numDistinctFields - 1 - 0x07);
+                vectorsStream.WriteVInt32(numDistinctFields - 1 - 0x07);
             }
             PackedInts.Writer writer = PackedInts.GetWriterNoHeader(vectorsStream, PackedInts.Format.PACKED, fieldNums.Count, bitsRequired, 1);
             foreach (int fieldNum in fieldNums)
@@ -524,7 +524,7 @@ namespace Lucene.Net.Codecs.Compressing
             if (nonChangingFlags)
             {
                 // write one flag per field num
-                vectorsStream.WriteVInt(0);
+                vectorsStream.WriteVInt32(0);
                 PackedInts.Writer writer = PackedInts.GetWriterNoHeader(vectorsStream, PackedInts.Format.PACKED, fieldFlags.Length, FLAGS_BITS, 1);
                 foreach (int flags in fieldFlags)
                 {
@@ -537,7 +537,7 @@ namespace Lucene.Net.Codecs.Compressing
             else
             {
                 // write one flag for every field instance
-                vectorsStream.WriteVInt(1);
+                vectorsStream.WriteVInt32(1);
                 PackedInts.Writer writer = PackedInts.GetWriterNoHeader(vectorsStream, PackedInts.Format.PACKED, totalFields, FLAGS_BITS, 1);
                 foreach (DocData dd in pendingDocs)
                 {
@@ -562,7 +562,7 @@ namespace Lucene.Net.Codecs.Compressing
                 }
             }
             int bitsRequired = PackedInts.BitsRequired(maxNumTerms);
-            vectorsStream.WriteVInt(bitsRequired);
+            vectorsStream.WriteVInt32(bitsRequired);
             PackedInts.Writer writer = PackedInts.GetWriterNoHeader(vectorsStream, PackedInts.Format.PACKED, totalFields, bitsRequired, 1);
             foreach (DocData dd in pendingDocs)
             {
@@ -695,7 +695,7 @@ namespace Lucene.Net.Codecs.Compressing
             // start offsets
             for (int i = 0; i < fieldNums.Length; ++i)
             {
-                vectorsStream.WriteInt(Number.FloatToIntBits(charsPerTerm[i]));
+                vectorsStream.WriteInt32(Number.SingleToInt32Bits(charsPerTerm[i]));
             }
 
             writer.Reset(vectorsStream);
@@ -813,11 +813,11 @@ namespace Lucene.Net.Codecs.Compressing
                     }
                     for (int i = 0; i < numProx; ++i)
                     {
-                        int code = positions.ReadVInt();
+                        int code = positions.ReadVInt32();
                         if ((code & 1) != 0)
                         {
                             // this position has a payload
-                            int payloadLength = positions.ReadVInt();
+                            int payloadLength = positions.ReadVInt32();
                             payloadLengthsBuf[payStart + i] = payloadLength;
                             payloadBytes.CopyBytes(positions, payloadLength);
                         }
@@ -833,7 +833,7 @@ namespace Lucene.Net.Codecs.Compressing
                 {
                     for (int i = 0; i < numProx; ++i)
                     {
-                        position += ((int)((uint)positions.ReadVInt() >> 1));
+                        position += ((int)((uint)positions.ReadVInt32() >> 1));
                         positionsBuf[posStart + i] = position;
                     }
                 }
@@ -851,8 +851,8 @@ namespace Lucene.Net.Codecs.Compressing
                 int lastOffset = 0, startOffset, endOffset;
                 for (int i = 0; i < numProx; ++i)
                 {
-                    startOffset = lastOffset + offsets.ReadVInt();
-                    endOffset = startOffset + offsets.ReadVInt();
+                    startOffset = lastOffset + offsets.ReadVInt32();
+                    endOffset = startOffset + offsets.ReadVInt32();
                     lastOffset = endOffset;
                     startOffsetsBuf[offStart + i] = startOffset;
                     lengthsBuf[offStart + i] = endOffset - startOffset;
@@ -884,7 +884,7 @@ namespace Lucene.Net.Codecs.Compressing
                 int maxDoc = reader.MaxDoc;
                 IBits liveDocs = reader.LiveDocs;
 
-                if (matchingVectorsReader == null || matchingVectorsReader.Version != VERSION_CURRENT || matchingVectorsReader.CompressionMode != compressionMode || matchingVectorsReader.ChunkSize != chunkSize || matchingVectorsReader.PackedIntsVersion != PackedInts.VERSION_CURRENT)
+                if (matchingVectorsReader == null || matchingVectorsReader.Version != VERSION_CURRENT || matchingVectorsReader.CompressionMode != compressionMode || matchingVectorsReader.ChunkSize != chunkSize || matchingVectorsReader.PackedInt32sVersion != PackedInts.VERSION_CURRENT)
                 {
                     // naive merge...
                     for (int i = NextLiveDoc(0, liveDocs, maxDoc); i < maxDoc; i = NextLiveDoc(i + 1, liveDocs, maxDoc))
@@ -913,16 +913,16 @@ namespace Lucene.Net.Codecs.Compressing
                         }
                         if ((pendingDocs.Count == 0) && (i == 0 || index.GetStartPointer(i - 1) < startPointer)) // start of a chunk
                         {
-                            int docBase = vectorsStream.ReadVInt();
-                            int chunkDocs = vectorsStream.ReadVInt();
+                            int docBase = vectorsStream.ReadVInt32();
+                            int chunkDocs = vectorsStream.ReadVInt32();
                             Debug.Assert(docBase + chunkDocs <= matchingSegmentReader.MaxDoc);
                             if (docBase + chunkDocs < matchingSegmentReader.MaxDoc && NextDeletedDoc(docBase, liveDocs, docBase + chunkDocs) == docBase + chunkDocs)
                             {
                                 long chunkEnd = index.GetStartPointer(docBase + chunkDocs);
                                 long chunkLength = chunkEnd - vectorsStream.FilePointer;
                                 indexWriter.WriteIndex(chunkDocs, this.vectorsStream.FilePointer);
-                                this.vectorsStream.WriteVInt(docCount);
-                                this.vectorsStream.WriteVInt(chunkDocs);
+                                this.vectorsStream.WriteVInt32(docCount);
+                                this.vectorsStream.WriteVInt32(chunkDocs);
                                 this.vectorsStream.CopyBytes(vectorsStream, chunkLength);
                                 docCount += chunkDocs;
                                 this.numDocs += chunkDocs;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Codecs/Compressing/CompressionMode.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/Compressing/CompressionMode.cs b/src/Lucene.Net.Core/Codecs/Compressing/CompressionMode.cs
index 55de4db..ce0857c 100644
--- a/src/Lucene.Net.Core/Codecs/Compressing/CompressionMode.cs
+++ b/src/Lucene.Net.Core/Codecs/Compressing/CompressionMode.cs
@@ -217,7 +217,7 @@ namespace Lucene.Net.Codecs.Compressing
                     return;
                 }
 
-                byte[] compressedBytes = new byte[input.ReadVInt()];
+                byte[] compressedBytes = new byte[input.ReadVInt32()];
                 input.ReadBytes(compressedBytes, 0, compressedBytes.Length);
                 byte[] decompressedBytes = null;
 
@@ -272,12 +272,12 @@ namespace Lucene.Net.Codecs.Compressing
                 if (resultArray.Length == 0)
                 {
                     Debug.Assert(len == 0, len.ToString());
-                    output.WriteVInt(0);
+                    output.WriteVInt32(0);
                     return;
                 }
                 else
                 {
-                    output.WriteVInt(resultArray.Length);
+                    output.WriteVInt32(resultArray.Length);
                     output.WriteBytes(resultArray, resultArray.Length);
                 }
             }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Codecs/Compressing/LZ4.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/Compressing/LZ4.cs b/src/Lucene.Net.Core/Codecs/Compressing/LZ4.cs
index 94921d8..b4316bb 100644
--- a/src/Lucene.Net.Core/Codecs/Compressing/LZ4.cs
+++ b/src/Lucene.Net.Core/Codecs/Compressing/LZ4.cs
@@ -55,15 +55,21 @@ namespace Lucene.Net.Codecs.Compressing
             return Hash(i, HASH_LOG_HC);
         }
 
-        private static int ReadInt(byte[] buf, int i)
+        /// <summary>
+        /// NOTE: This was readInt() in Lucene
+        /// </summary>
+        private static int ReadInt32(byte[] buf, int i)
         {
             return ((((sbyte)buf[i]) & 0xFF) << 24) | ((((sbyte)buf[i + 1]) & 0xFF) << 16) | ((((sbyte)buf[i + 2]) & 0xFF) << 8) |
                 (((sbyte)buf[i + 3]) & 0xFF);
         }
 
-        private static bool ReadIntEquals(byte[] buf, int i, int j)
+        /// <summary>
+        /// NOTE: This was readIntEquals() in Lucene
+        /// </summary>
+        private static bool ReadInt32Equals(byte[] buf, int i, int j)
         {
-            return ReadInt(buf, i) == ReadInt(buf, j);
+            return ReadInt32(buf, i) == ReadInt32(buf, j);
         }
 
         private static int CommonBytes(byte[] b, int o1, int o2, int limit)
@@ -264,12 +270,12 @@ namespace Lucene.Net.Codecs.Compressing
                         {
                             goto mainBreak;
                         }
-                        int v = ReadInt(bytes, off);
+                        int v = ReadInt32(bytes, off);
                         int h = Hash(v, hashLog);
                         @ref = @base + (int)hashTable.Get(h);
                         Debug.Assert(PackedInts.BitsRequired(off - @base) <= hashTable.BitsPerValue);
                         hashTable.Set(h, off - @base);
-                        if (off - @ref < MAX_DISTANCE && ReadInt(bytes, @ref) == v)
+                        if (off - @ref < MAX_DISTANCE && ReadInt32(bytes, @ref) == v)
                         {
                             break;
                         }
@@ -342,7 +348,7 @@ namespace Lucene.Net.Codecs.Compressing
 
             private int HashPointer(byte[] bytes, int off)
             {
-                int v = ReadInt(bytes, off);
+                int v = ReadInt32(bytes, off);
                 int h = HashHC(v);
                 return hashTable[h];
             }
@@ -354,7 +360,7 @@ namespace Lucene.Net.Codecs.Compressing
 
             private void AddHash(byte[] bytes, int off)
             {
-                int v = ReadInt(bytes, off);
+                int v = ReadInt32(bytes, off);
                 int h = HashHC(v);
                 int delta = off - hashTable[h];
                 Debug.Assert(delta > 0, delta.ToString());
@@ -387,7 +393,7 @@ namespace Lucene.Net.Codecs.Compressing
 
                 if (@ref >= off - 4 && @ref <= off && @ref >= @base) // potential repetition
                 {
-                    if (ReadIntEquals(buf, @ref, off)) // confirmed
+                    if (ReadInt32Equals(buf, @ref, off)) // confirmed
                     {
                         delta = off - @ref;
                         repl = match.len = MIN_MATCH + CommonBytes(buf, @ref + MIN_MATCH, off + MIN_MATCH, matchLimit);
@@ -402,7 +408,7 @@ namespace Lucene.Net.Codecs.Compressing
                     {
                         break;
                     }
-                    if (buf[@ref + match.len] == buf[off + match.len] && ReadIntEquals(buf, @ref, off))
+                    if (buf[@ref + match.len] == buf[off + match.len] && ReadInt32Equals(buf, @ref, off))
                     {
                         int matchLen = MIN_MATCH + CommonBytes(buf, @ref + MIN_MATCH, off + MIN_MATCH, matchLimit);
                         if (matchLen > match.len)
@@ -426,7 +432,7 @@ namespace Lucene.Net.Codecs.Compressing
                     do
                     {
                         chainTable[ptr & MASK] = (short)delta;
-                        hashTable[HashHC(ReadInt(buf, ptr))] = ptr;
+                        hashTable[HashHC(ReadInt32(buf, ptr))] = ptr;
                         ++ptr;
                     } while (ptr < end);
                     nextToUpdate = end;
@@ -449,7 +455,7 @@ namespace Lucene.Net.Codecs.Compressing
                     {
                         break;
                     }
-                    if (buf[@ref - delta + match.len] == buf[startLimit + match.len] && ReadIntEquals(buf, @ref, off))
+                    if (buf[@ref - delta + match.len] == buf[startLimit + match.len] && ReadInt32Equals(buf, @ref, off))
                     {
                         int matchLenForward = MIN_MATCH + CommonBytes(buf, @ref + MIN_MATCH, off + MIN_MATCH, matchLimit);
                         int matchLenBackward = CommonBytesBackward(buf, @ref, off, @base, startLimit);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Codecs/Lucene3x/Lucene3xFieldInfosReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/Lucene3x/Lucene3xFieldInfosReader.cs b/src/Lucene.Net.Core/Codecs/Lucene3x/Lucene3xFieldInfosReader.cs
index 7d3da96..1b06a5c 100644
--- a/src/Lucene.Net.Core/Codecs/Lucene3x/Lucene3xFieldInfosReader.cs
+++ b/src/Lucene.Net.Core/Codecs/Lucene3x/Lucene3xFieldInfosReader.cs
@@ -66,7 +66,7 @@ namespace Lucene.Net.Codecs.Lucene3x
             bool success = false;
             try
             {
-                int format = input.ReadVInt();
+                int format = input.ReadVInt32();
 
                 if (format > FORMAT_MINIMUM)
                 {
@@ -77,7 +77,7 @@ namespace Lucene.Net.Codecs.Lucene3x
                     throw new IndexFormatTooNewException(input, format, FORMAT_MINIMUM, FORMAT_CURRENT);
                 }
 
-                int size = input.ReadVInt(); //read in the size
+                int size = input.ReadVInt32(); //read in the size
                 FieldInfo[] infos = new FieldInfo[size];
 
                 for (int i = 0; i < size; i++)


[27/53] [abbrv] lucenenet git commit: Lucene.Net.Core: Renamed all type-derived classes and interfaces from Short, Int, Long, and Float to match CLR types Int16, Int32, Int64, and Single, respectively.

Posted by ni...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Search/FieldCacheImpl.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Search/FieldCacheImpl.cs b/src/Lucene.Net.Core/Search/FieldCacheImpl.cs
index e1e7c21..8891e73 100644
--- a/src/Lucene.Net.Core/Search/FieldCacheImpl.cs
+++ b/src/Lucene.Net.Core/Search/FieldCacheImpl.cs
@@ -36,9 +36,9 @@ namespace Lucene.Net.Search
     using FixedBitSet = Lucene.Net.Util.FixedBitSet;
     using GrowableWriter = Lucene.Net.Util.Packed.GrowableWriter;
     using IndexReader = Lucene.Net.Index.IndexReader;
-    using MonotonicAppendingLongBuffer = Lucene.Net.Util.Packed.MonotonicAppendingLongBuffer;
+    using MonotonicAppendingInt64Buffer = Lucene.Net.Util.Packed.MonotonicAppendingInt64Buffer;
     using NumericDocValues = Lucene.Net.Index.NumericDocValues;
-    using PackedInts = Lucene.Net.Util.Packed.PackedInts;
+    using PackedInt32s = Lucene.Net.Util.Packed.PackedInt32s;
     using PagedBytes = Lucene.Net.Util.PagedBytes;
     using SegmentReader = Lucene.Net.Index.SegmentReader;
     using SortedDocValues = Lucene.Net.Index.SortedDocValues;
@@ -71,10 +71,10 @@ namespace Lucene.Net.Search
             {
                 caches = new Dictionary<Type, Cache>(9);
                 caches[typeof(sbyte)] = new ByteCache(this);
-                caches[typeof(short)] = new ShortCache(this);
-                caches[typeof(int)] = new IntCache(this);
-                caches[typeof(float)] = new FloatCache(this);
-                caches[typeof(long)] = new LongCache(this);
+                caches[typeof(short)] = new Int16Cache(this);
+                caches[typeof(int)] = new Int32Cache(this);
+                caches[typeof(float)] = new SingleCache(this);
+                caches[typeof(long)] = new Int64Cache(this);
                 caches[typeof(double)] = new DoubleCache(this);
                 caches[typeof(BinaryDocValues)] = new BinaryDocValuesCache(this);
                 caches[typeof(SortedDocValues)] = new SortedDocValuesCache(this);
@@ -608,7 +608,7 @@ namespace Lucene.Net.Search
         /// <summary>
         /// NOTE: this was getShorts() in Lucene
         /// </summary>
-        public virtual FieldCache.Shorts GetInt16s(AtomicReader reader, string field, bool setDocsWithField)
+        public virtual FieldCache.Int16s GetInt16s(AtomicReader reader, string field, bool setDocsWithField)
         {
             return GetInt16s(reader, field, null, setDocsWithField);
         }
@@ -617,21 +617,21 @@ namespace Lucene.Net.Search
         /// <summary>
         /// NOTE: this was getShorts() in Lucene
         /// </summary>
-        public virtual FieldCache.Shorts GetInt16s(AtomicReader reader, string field, FieldCache.IShortParser parser, bool setDocsWithField)
+        public virtual FieldCache.Int16s GetInt16s(AtomicReader reader, string field, FieldCache.IInt16Parser parser, bool setDocsWithField)
         {
             NumericDocValues valuesIn = reader.GetNumericDocValues(field);
             if (valuesIn != null)
             {
                 // Not cached here by FieldCacheImpl (cached instead
                 // per-thread by SegmentReader):
-                return new FieldCache_ShortsAnonymousInnerClassHelper(this, valuesIn);
+                return new FieldCache_Int16sAnonymousInnerClassHelper(this, valuesIn);
             }
             else
             {
                 FieldInfo info = reader.FieldInfos.FieldInfo(field);
                 if (info == null)
                 {
-                    return FieldCache.Shorts.EMPTY;
+                    return FieldCache.Int16s.EMPTY;
                 }
                 else if (info.HasDocValues)
                 {
@@ -639,19 +639,19 @@ namespace Lucene.Net.Search
                 }
                 else if (!info.IsIndexed)
                 {
-                    return FieldCache.Shorts.EMPTY;
+                    return FieldCache.Int16s.EMPTY;
                 }
-                return (FieldCache.Shorts)caches[typeof(short)].Get(reader, new CacheKey(field, parser), setDocsWithField);
+                return (FieldCache.Int16s)caches[typeof(short)].Get(reader, new CacheKey(field, parser), setDocsWithField);
             }
         }
 
-        private class FieldCache_ShortsAnonymousInnerClassHelper : FieldCache.Shorts
+        private class FieldCache_Int16sAnonymousInnerClassHelper : FieldCache.Int16s
         {
             private readonly FieldCacheImpl outerInstance;
 
             private NumericDocValues valuesIn;
 
-            public FieldCache_ShortsAnonymousInnerClassHelper(FieldCacheImpl outerInstance, NumericDocValues valuesIn)
+            public FieldCache_Int16sAnonymousInnerClassHelper(FieldCacheImpl outerInstance, NumericDocValues valuesIn)
             {
                 this.outerInstance = outerInstance;
                 this.valuesIn = valuesIn;
@@ -663,11 +663,14 @@ namespace Lucene.Net.Search
             }
         }
 
-        internal class ShortsFromArray : FieldCache.Shorts
+        /// <summary>
+        /// NOTE: This was ShortsFromArray in Lucene
+        /// </summary>
+        internal class Int16sFromArray : FieldCache.Int16s
         {
             private readonly short[] values;
 
-            public ShortsFromArray(short[] values)
+            public Int16sFromArray(short[] values)
             {
                 this.values = values;
             }
@@ -678,9 +681,12 @@ namespace Lucene.Net.Search
             }
         }
 
-        internal sealed class ShortCache : Cache
+        /// <summary>
+        /// NOTE: This was ShortCache in Lucene
+        /// </summary>
+        internal sealed class Int16Cache : Cache
         {
-            internal ShortCache(FieldCacheImpl wrapper)
+            internal Int16Cache(FieldCacheImpl wrapper)
                 : base(wrapper)
             {
             }
@@ -689,7 +695,7 @@ namespace Lucene.Net.Search
             {
                 int maxDoc = reader.MaxDoc;
                 short[] values;
-                FieldCache.IShortParser parser = (FieldCache.IShortParser)key.custom;
+                FieldCache.IInt16Parser parser = (FieldCache.IInt16Parser)key.custom;
                 if (parser == null)
                 {
                     // Confusing: must delegate to wrapper (vs simply
@@ -707,17 +713,17 @@ namespace Lucene.Net.Search
                 {
                     wrapper.SetDocsWithField(reader, key.field, u.docsWithField);
                 }
-                return new ShortsFromArray(values);
+                return new Int16sFromArray(values);
             }
 
             private class UninvertAnonymousInnerClassHelper : Uninvert
             {
-                private readonly ShortCache outerInstance;
+                private readonly Int16Cache outerInstance;
 
                 private short[] values;
-                private FieldCache.IShortParser parser;
+                private FieldCache.IInt16Parser parser;
 
-                public UninvertAnonymousInnerClassHelper(ShortCache outerInstance, short[] values, FieldCache.IShortParser parser)
+                public UninvertAnonymousInnerClassHelper(Int16Cache outerInstance, short[] values, FieldCache.IInt16Parser parser)
                 {
                     this.outerInstance = outerInstance;
                     this.values = values;
@@ -747,7 +753,7 @@ namespace Lucene.Net.Search
         /// <summary>
         /// NOTE: this was getInts() in Lucene
         /// </summary>
-        public virtual FieldCache.Ints GetInt32s(AtomicReader reader, string field, bool setDocsWithField)
+        public virtual FieldCache.Int32s GetInt32s(AtomicReader reader, string field, bool setDocsWithField)
         {
             return GetInt32s(reader, field, null, setDocsWithField);
         }
@@ -755,21 +761,21 @@ namespace Lucene.Net.Search
         /// <summary>
         /// NOTE: this was getInts() in Lucene
         /// </summary>
-        public virtual FieldCache.Ints GetInt32s(AtomicReader reader, string field, FieldCache.IIntParser parser, bool setDocsWithField)
+        public virtual FieldCache.Int32s GetInt32s(AtomicReader reader, string field, FieldCache.IInt32Parser parser, bool setDocsWithField)
         {
             NumericDocValues valuesIn = reader.GetNumericDocValues(field);
             if (valuesIn != null)
             {
                 // Not cached here by FieldCacheImpl (cached instead
                 // per-thread by SegmentReader):
-                return new FieldCache_IntsAnonymousInnerClassHelper(this, valuesIn);
+                return new FieldCache_Int32sAnonymousInnerClassHelper(this, valuesIn);
             }
             else
             {
                 FieldInfo info = reader.FieldInfos.FieldInfo(field);
                 if (info == null)
                 {
-                    return FieldCache.Ints.EMPTY;
+                    return FieldCache.Int32s.EMPTY;
                 }
                 else if (info.HasDocValues)
                 {
@@ -777,19 +783,19 @@ namespace Lucene.Net.Search
                 }
                 else if (!info.IsIndexed)
                 {
-                    return FieldCache.Ints.EMPTY;
+                    return FieldCache.Int32s.EMPTY;
                 }
-                return (FieldCache.Ints)caches[typeof(int)].Get(reader, new CacheKey(field, parser), setDocsWithField);
+                return (FieldCache.Int32s)caches[typeof(int)].Get(reader, new CacheKey(field, parser), setDocsWithField);
             }
         }
 
-        private class FieldCache_IntsAnonymousInnerClassHelper : FieldCache.Ints
+        private class FieldCache_Int32sAnonymousInnerClassHelper : FieldCache.Int32s
         {
             private readonly FieldCacheImpl outerInstance;
 
             private NumericDocValues valuesIn;
 
-            public FieldCache_IntsAnonymousInnerClassHelper(FieldCacheImpl outerInstance, NumericDocValues valuesIn)
+            public FieldCache_Int32sAnonymousInnerClassHelper(FieldCacheImpl outerInstance, NumericDocValues valuesIn)
             {
                 this.outerInstance = outerInstance;
                 this.valuesIn = valuesIn;
@@ -801,12 +807,15 @@ namespace Lucene.Net.Search
             }
         }
 
-        internal class IntsFromArray : FieldCache.Ints
+        /// <summary>
+        /// NOTE: This was IntsFromArray in Lucene
+        /// </summary>
+        internal class Int32sFromArray : FieldCache.Int32s
         {
-            private readonly PackedInts.Reader values;
+            private readonly PackedInt32s.Reader values;
             private readonly int minValue;
 
-            public IntsFromArray(PackedInts.Reader values, int minValue)
+            public Int32sFromArray(PackedInt32s.Reader values, int minValue)
             {
                 Debug.Assert(values.BitsPerValue <= 32);
                 this.values = values;
@@ -847,16 +856,19 @@ namespace Lucene.Net.Search
             public long MinValue { get; set; } // LUCENENET NOTE: for some reason, this was not marked readonly
         }
 
-        internal sealed class IntCache : Cache
+        /// <summary>
+        /// NOTE: This was IntCache in Lucene
+        /// </summary>
+        internal sealed class Int32Cache : Cache
         {
-            internal IntCache(FieldCacheImpl wrapper)
+            internal Int32Cache(FieldCacheImpl wrapper)
                 : base(wrapper)
             {
             }
 
             protected override object CreateValue(AtomicReader reader, CacheKey key, bool setDocsWithField)
             {
-                FieldCache.IIntParser parser = (FieldCache.IIntParser)key.custom;
+                FieldCache.IInt32Parser parser = (FieldCache.IInt32Parser)key.custom;
                 if (parser == null)
                 {
                     // Confusing: must delegate to wrapper (vs simply
@@ -887,20 +899,20 @@ namespace Lucene.Net.Search
                 GrowableWriterAndMinValue values = valuesRef.Get();
                 if (values == null)
                 {
-                    return new IntsFromArray(new PackedInts.NullReader(reader.MaxDoc), 0);
+                    return new Int32sFromArray(new PackedInt32s.NullReader(reader.MaxDoc), 0);
                 }
-                return new IntsFromArray(values.Writer.Mutable, (int)values.MinValue);
+                return new Int32sFromArray(values.Writer.Mutable, (int)values.MinValue);
             }
 
             private class UninvertAnonymousInnerClassHelper : Uninvert
             {
-                private readonly IntCache outerInstance;
+                private readonly Int32Cache outerInstance;
 
                 private AtomicReader reader;
-                private FieldCache.IIntParser parser;
+                private FieldCache.IInt32Parser parser;
                 private FieldCacheImpl.HoldsOneThing<GrowableWriterAndMinValue> valuesRef;
 
-                public UninvertAnonymousInnerClassHelper(IntCache outerInstance, AtomicReader reader, FieldCache.IIntParser parser, FieldCacheImpl.HoldsOneThing<GrowableWriterAndMinValue> valuesRef)
+                public UninvertAnonymousInnerClassHelper(Int32Cache outerInstance, AtomicReader reader, FieldCache.IInt32Parser parser, FieldCacheImpl.HoldsOneThing<GrowableWriterAndMinValue> valuesRef)
                 {
                     this.outerInstance = outerInstance;
                     this.reader = reader;
@@ -926,14 +938,14 @@ namespace Lucene.Net.Search
                         if (currentValue < 0)
                         {
                             minValue = currentValue;
-                            startBitsPerValue = PackedInts.BitsRequired((-minValue) & 0xFFFFFFFFL);
+                            startBitsPerValue = PackedInt32s.BitsRequired((-minValue) & 0xFFFFFFFFL);
                         }
                         else
                         {
                             minValue = 0;
-                            startBitsPerValue = PackedInts.BitsRequired(currentValue);
+                            startBitsPerValue = PackedInt32s.BitsRequired(currentValue);
                         }
-                        values = new GrowableWriter(startBitsPerValue, reader.MaxDoc, PackedInts.FAST);
+                        values = new GrowableWriter(startBitsPerValue, reader.MaxDoc, PackedInt32s.FAST);
                         if (minValue != 0)
                         {
                             values.Fill(0, values.Count, (-minValue) & 0xFFFFFFFFL); // default value must be 0
@@ -1043,7 +1055,7 @@ namespace Lucene.Net.Search
         /// <summary>
         /// NOTE: this was getFloats() in Lucene
         /// </summary>
-        public virtual FieldCache.Floats GetSingles(AtomicReader reader, string field, bool setDocsWithField)
+        public virtual FieldCache.Singles GetSingles(AtomicReader reader, string field, bool setDocsWithField)
         {
             return GetSingles(reader, field, null, setDocsWithField);
         }
@@ -1051,21 +1063,21 @@ namespace Lucene.Net.Search
         /// <summary>
         /// NOTE: this was getFloats() in Lucene
         /// </summary>
-        public virtual FieldCache.Floats GetSingles(AtomicReader reader, string field, FieldCache.IFloatParser parser, bool setDocsWithField)
+        public virtual FieldCache.Singles GetSingles(AtomicReader reader, string field, FieldCache.ISingleParser parser, bool setDocsWithField)
         {
             NumericDocValues valuesIn = reader.GetNumericDocValues(field);
             if (valuesIn != null)
             {
                 // Not cached here by FieldCacheImpl (cached instead
                 // per-thread by SegmentReader):
-                return new FieldCache_FloatsAnonymousInnerClassHelper(this, valuesIn);
+                return new FieldCache_SinglesAnonymousInnerClassHelper(this, valuesIn);
             }
             else
             {
                 FieldInfo info = reader.FieldInfos.FieldInfo(field);
                 if (info == null)
                 {
-                    return FieldCache.Floats.EMPTY;
+                    return FieldCache.Singles.EMPTY;
                 }
                 else if (info.HasDocValues)
                 {
@@ -1073,19 +1085,19 @@ namespace Lucene.Net.Search
                 }
                 else if (!info.IsIndexed)
                 {
-                    return FieldCache.Floats.EMPTY;
+                    return FieldCache.Singles.EMPTY;
                 }
-                return (FieldCache.Floats)caches[typeof(float)].Get(reader, new CacheKey(field, parser), setDocsWithField);
+                return (FieldCache.Singles)caches[typeof(float)].Get(reader, new CacheKey(field, parser), setDocsWithField);
             }
         }
 
-        private class FieldCache_FloatsAnonymousInnerClassHelper : FieldCache.Floats
+        private class FieldCache_SinglesAnonymousInnerClassHelper : FieldCache.Singles
         {
             private readonly FieldCacheImpl outerInstance;
 
             private NumericDocValues valuesIn;
 
-            public FieldCache_FloatsAnonymousInnerClassHelper(FieldCacheImpl outerInstance, NumericDocValues valuesIn)
+            public FieldCache_SinglesAnonymousInnerClassHelper(FieldCacheImpl outerInstance, NumericDocValues valuesIn)
             {
                 this.outerInstance = outerInstance;
                 this.valuesIn = valuesIn;
@@ -1097,11 +1109,14 @@ namespace Lucene.Net.Search
             }
         }
 
-        internal class FloatsFromArray : FieldCache.Floats
+        /// <summary>
+        /// NOTE: This was FloatsFromArray in Lucene
+        /// </summary>
+        internal class SinglesFromArray : FieldCache.Singles
         {
             private readonly float[] values;
 
-            public FloatsFromArray(float[] values)
+            public SinglesFromArray(float[] values)
             {
                 this.values = values;
             }
@@ -1112,16 +1127,19 @@ namespace Lucene.Net.Search
             }
         }
 
-        internal sealed class FloatCache : Cache
+        /// <summary>
+        /// NOTE: This was FloatCache in Lucene
+        /// </summary>
+        internal sealed class SingleCache : Cache
         {
-            internal FloatCache(FieldCacheImpl wrapper)
+            internal SingleCache(FieldCacheImpl wrapper)
                 : base(wrapper)
             {
             }
 
             protected override object CreateValue(AtomicReader reader, CacheKey key, bool setDocsWithField)
             {
-                FieldCache.IFloatParser parser = (FieldCache.IFloatParser)key.custom;
+                FieldCache.ISingleParser parser = (FieldCache.ISingleParser)key.custom;
                 if (parser == null)
                 {
                     // Confusing: must delegate to wrapper (vs simply
@@ -1155,18 +1173,18 @@ namespace Lucene.Net.Search
                 {
                     values = new float[reader.MaxDoc];
                 }
-                return new FloatsFromArray(values);
+                return new SinglesFromArray(values);
             }
 
             private class UninvertAnonymousInnerClassHelper : Uninvert
             {
-                private readonly FloatCache outerInstance;
+                private readonly SingleCache outerInstance;
 
                 private AtomicReader reader;
-                private FieldCache.IFloatParser parser;
+                private FieldCache.ISingleParser parser;
                 private FieldCacheImpl.HoldsOneThing<float[]> valuesRef;
 
-                public UninvertAnonymousInnerClassHelper(FloatCache outerInstance, AtomicReader reader, FieldCache.IFloatParser parser, FieldCacheImpl.HoldsOneThing<float[]> valuesRef)
+                public UninvertAnonymousInnerClassHelper(SingleCache outerInstance, AtomicReader reader, FieldCache.ISingleParser parser, FieldCacheImpl.HoldsOneThing<float[]> valuesRef)
                 {
                     this.outerInstance = outerInstance;
                     this.reader = reader;
@@ -1206,7 +1224,7 @@ namespace Lucene.Net.Search
         /// <summary>
         /// NOTE: this was getLongs() in Lucene
         /// </summary>
-        public virtual FieldCache.Longs GetInt64s(AtomicReader reader, string field, bool setDocsWithField)
+        public virtual FieldCache.Int64s GetInt64s(AtomicReader reader, string field, bool setDocsWithField)
         {
             return GetInt64s(reader, field, null, setDocsWithField);
         }
@@ -1214,21 +1232,21 @@ namespace Lucene.Net.Search
         /// <summary>
         /// NOTE: this was getLongs() in Lucene
         /// </summary>
-        public virtual FieldCache.Longs GetInt64s(AtomicReader reader, string field, FieldCache.ILongParser parser, bool setDocsWithField)
+        public virtual FieldCache.Int64s GetInt64s(AtomicReader reader, string field, FieldCache.IInt64Parser parser, bool setDocsWithField)
         {
             NumericDocValues valuesIn = reader.GetNumericDocValues(field);
             if (valuesIn != null)
             {
                 // Not cached here by FieldCacheImpl (cached instead
                 // per-thread by SegmentReader):
-                return new FieldCache_LongsAnonymousInnerClassHelper(this, valuesIn);
+                return new FieldCache_Int64sAnonymousInnerClassHelper(this, valuesIn);
             }
             else
             {
                 FieldInfo info = reader.FieldInfos.FieldInfo(field);
                 if (info == null)
                 {
-                    return FieldCache.Longs.EMPTY;
+                    return FieldCache.Int64s.EMPTY;
                 }
                 else if (info.HasDocValues)
                 {
@@ -1236,19 +1254,19 @@ namespace Lucene.Net.Search
                 }
                 else if (!info.IsIndexed)
                 {
-                    return FieldCache.Longs.EMPTY;
+                    return FieldCache.Int64s.EMPTY;
                 }
-                return (FieldCache.Longs)caches[typeof(long)].Get(reader, new CacheKey(field, parser), setDocsWithField);
+                return (FieldCache.Int64s)caches[typeof(long)].Get(reader, new CacheKey(field, parser), setDocsWithField);
             }
         }
 
-        private class FieldCache_LongsAnonymousInnerClassHelper : FieldCache.Longs
+        private class FieldCache_Int64sAnonymousInnerClassHelper : FieldCache.Int64s
         {
             private readonly FieldCacheImpl outerInstance;
 
             private NumericDocValues valuesIn;
 
-            public FieldCache_LongsAnonymousInnerClassHelper(FieldCacheImpl outerInstance, NumericDocValues valuesIn)
+            public FieldCache_Int64sAnonymousInnerClassHelper(FieldCacheImpl outerInstance, NumericDocValues valuesIn)
             {
                 this.outerInstance = outerInstance;
                 this.valuesIn = valuesIn;
@@ -1260,12 +1278,15 @@ namespace Lucene.Net.Search
             }
         }
 
-        internal class LongsFromArray : FieldCache.Longs
+        /// <summary>
+        /// NOTE: This was LongsFromArray in Lucene
+        /// </summary>
+        internal class Int64sFromArray : FieldCache.Int64s
         {
-            private readonly PackedInts.Reader values;
+            private readonly PackedInt32s.Reader values;
             private readonly long minValue;
 
-            public LongsFromArray(PackedInts.Reader values, long minValue)
+            public Int64sFromArray(PackedInt32s.Reader values, long minValue)
             {
                 this.values = values;
                 this.minValue = minValue;
@@ -1277,16 +1298,19 @@ namespace Lucene.Net.Search
             }
         }
 
-        internal sealed class LongCache : Cache
+        /// <summary>
+        /// NOTE: This was LongCache in Lucene
+        /// </summary>
+        internal sealed class Int64Cache : Cache
         {
-            internal LongCache(FieldCacheImpl wrapper)
+            internal Int64Cache(FieldCacheImpl wrapper)
                 : base(wrapper)
             {
             }
 
             protected override object CreateValue(AtomicReader reader, CacheKey key, bool setDocsWithField)
             {
-                FieldCache.ILongParser parser = (FieldCache.ILongParser)key.custom;
+                FieldCache.IInt64Parser parser = (FieldCache.IInt64Parser)key.custom;
                 if (parser == null)
                 {
                     // Confusing: must delegate to wrapper (vs simply
@@ -1317,20 +1341,20 @@ namespace Lucene.Net.Search
                 GrowableWriterAndMinValue values = valuesRef.Get();
                 if (values == null)
                 {
-                    return new LongsFromArray(new PackedInts.NullReader(reader.MaxDoc), 0L);
+                    return new Int64sFromArray(new PackedInt32s.NullReader(reader.MaxDoc), 0L);
                 }
-                return new LongsFromArray(values.Writer.Mutable, values.MinValue);
+                return new Int64sFromArray(values.Writer.Mutable, values.MinValue);
             }
 
             private class UninvertAnonymousInnerClassHelper : Uninvert
             {
-                private readonly LongCache outerInstance;
+                private readonly Int64Cache outerInstance;
 
                 private AtomicReader reader;
-                private FieldCache.ILongParser parser;
+                private FieldCache.IInt64Parser parser;
                 private FieldCacheImpl.HoldsOneThing<GrowableWriterAndMinValue> valuesRef;
 
-                public UninvertAnonymousInnerClassHelper(LongCache outerInstance, AtomicReader reader, FieldCache.ILongParser parser, FieldCacheImpl.HoldsOneThing<GrowableWriterAndMinValue> valuesRef)
+                public UninvertAnonymousInnerClassHelper(Int64Cache outerInstance, AtomicReader reader, FieldCache.IInt64Parser parser, FieldCacheImpl.HoldsOneThing<GrowableWriterAndMinValue> valuesRef)
                 {
                     this.outerInstance = outerInstance;
                     this.reader = reader;
@@ -1356,14 +1380,14 @@ namespace Lucene.Net.Search
                         if (currentValue < 0)
                         {
                             minValue = currentValue;
-                            startBitsPerValue = minValue == long.MinValue ? 64 : PackedInts.BitsRequired(-minValue);
+                            startBitsPerValue = minValue == long.MinValue ? 64 : PackedInt32s.BitsRequired(-minValue);
                         }
                         else
                         {
                             minValue = 0;
-                            startBitsPerValue = PackedInts.BitsRequired(currentValue);
+                            startBitsPerValue = PackedInt32s.BitsRequired(currentValue);
                         }
-                        values = new GrowableWriter(startBitsPerValue, reader.MaxDoc, PackedInts.FAST);
+                        values = new GrowableWriter(startBitsPerValue, reader.MaxDoc, PackedInt32s.FAST);
                         if (minValue != 0)
                         {
                             values.Fill(0, values.Count, -minValue); // default value must be 0
@@ -1543,11 +1567,11 @@ namespace Lucene.Net.Search
         public class SortedDocValuesImpl : SortedDocValues
         {
             private readonly PagedBytes.Reader bytes;
-            private readonly MonotonicAppendingLongBuffer termOrdToBytesOffset;
-            private readonly PackedInts.Reader docToTermOrd;
+            private readonly MonotonicAppendingInt64Buffer termOrdToBytesOffset;
+            private readonly PackedInt32s.Reader docToTermOrd;
             private readonly int numOrd;
 
-            public SortedDocValuesImpl(PagedBytes.Reader bytes, MonotonicAppendingLongBuffer termOrdToBytesOffset, PackedInts.Reader docToTermOrd, int numOrd)
+            public SortedDocValuesImpl(PagedBytes.Reader bytes, MonotonicAppendingInt64Buffer termOrdToBytesOffset, PackedInt32s.Reader docToTermOrd, int numOrd)
             {
                 this.bytes = bytes;
                 this.docToTermOrd = docToTermOrd;
@@ -1583,7 +1607,7 @@ namespace Lucene.Net.Search
 
         public virtual SortedDocValues GetTermsIndex(AtomicReader reader, string field)
         {
-            return GetTermsIndex(reader, field, PackedInts.FAST);
+            return GetTermsIndex(reader, field, PackedInt32s.FAST);
         }
 
         public virtual SortedDocValues GetTermsIndex(AtomicReader reader, string field, float acceptableOverheadRatio)
@@ -1662,7 +1686,7 @@ namespace Lucene.Net.Search
                             numUniqueTerms = termCountHardLimit;
                         }
 
-                        startTermsBPV = PackedInts.BitsRequired(numUniqueTerms);
+                        startTermsBPV = PackedInt32s.BitsRequired(numUniqueTerms);
                     }
                     else
                     {
@@ -1674,7 +1698,7 @@ namespace Lucene.Net.Search
                     startTermsBPV = 1;
                 }
 
-                MonotonicAppendingLongBuffer termOrdToBytesOffset = new MonotonicAppendingLongBuffer();
+                MonotonicAppendingInt64Buffer termOrdToBytesOffset = new MonotonicAppendingInt64Buffer();
                 GrowableWriter docToTermOrd = new GrowableWriter(startTermsBPV, maxDoc, acceptableOverheadRatio);
 
                 int termOrd = 0;
@@ -1723,9 +1747,9 @@ namespace Lucene.Net.Search
         private class BinaryDocValuesImpl : BinaryDocValues
         {
             private readonly PagedBytes.Reader bytes;
-            private readonly PackedInts.Reader docToOffset;
+            private readonly PackedInt32s.Reader docToOffset;
 
-            public BinaryDocValuesImpl(PagedBytes.Reader bytes, PackedInts.Reader docToOffset)
+            public BinaryDocValuesImpl(PagedBytes.Reader bytes, PackedInt32s.Reader docToOffset)
             {
                 this.bytes = bytes;
                 this.docToOffset = docToOffset;
@@ -1751,7 +1775,7 @@ namespace Lucene.Net.Search
         // should share it...
         public virtual BinaryDocValues GetTerms(AtomicReader reader, string field, bool setDocsWithField)
         {
-            return GetTerms(reader, field, setDocsWithField, PackedInts.FAST);
+            return GetTerms(reader, field, setDocsWithField, PackedInt32s.FAST);
         }
 
         public virtual BinaryDocValues GetTerms(AtomicReader reader, string field, bool setDocsWithField, float acceptableOverheadRatio)
@@ -1823,7 +1847,7 @@ namespace Lucene.Net.Search
                         {
                             numUniqueTerms = termCountHardLimit;
                         }
-                        startBPV = PackedInts.BitsRequired(numUniqueTerms * 4);
+                        startBPV = PackedInt32s.BitsRequired(numUniqueTerms * 4);
                     }
                     else
                     {
@@ -1874,7 +1898,7 @@ namespace Lucene.Net.Search
                     }
                 }
 
-                PackedInts.Reader offsetReader = docToOffset.Mutable;
+                PackedInt32s.Reader offsetReader = docToOffset.Mutable;
                 if (setDocsWithField)
                 {
                     wrapper.SetDocsWithField(reader, key.field, new BitsAnonymousInnerClassHelper(this, maxDoc, offsetReader));
@@ -1888,9 +1912,9 @@ namespace Lucene.Net.Search
                 private readonly BinaryDocValuesCache outerInstance;
 
                 private int maxDoc;
-                private PackedInts.Reader offsetReader;
+                private PackedInt32s.Reader offsetReader;
 
-                public BitsAnonymousInnerClassHelper(BinaryDocValuesCache outerInstance, int maxDoc, PackedInts.Reader offsetReader)
+                public BitsAnonymousInnerClassHelper(BinaryDocValuesCache outerInstance, int maxDoc, PackedInt32s.Reader offsetReader)
                 {
                     this.outerInstance = outerInstance;
                     this.maxDoc = maxDoc;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Search/FieldCacheRangeFilter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Search/FieldCacheRangeFilter.cs b/src/Lucene.Net.Core/Search/FieldCacheRangeFilter.cs
index b48805e..f7c4185 100644
--- a/src/Lucene.Net.Core/Search/FieldCacheRangeFilter.cs
+++ b/src/Lucene.Net.Core/Search/FieldCacheRangeFilter.cs
@@ -312,15 +312,15 @@ namespace Lucene.Net.Search
 #if FEATURE_SERIALIZABLE
         [Serializable]
 #endif
-        private class AnonymousShortFieldCacheRangeFilter : FieldCacheRangeFilter<short?>
+        private class AnonymousInt16FieldCacheRangeFilter : FieldCacheRangeFilter<short?>
         {
             private class AnonymousClassFieldCacheDocIdSet : FieldCacheDocIdSet
             {
-                private FieldCache.Shorts values;
+                private FieldCache.Int16s values;
                 private short inclusiveLowerPoint;
                 private short inclusiveUpperPoint;
 
-                internal AnonymousClassFieldCacheDocIdSet(FieldCache.Shorts values, short inclusiveLowerPoint, short inclusiveUpperPoint, int maxDoc, IBits acceptDocs)
+                internal AnonymousClassFieldCacheDocIdSet(FieldCache.Int16s values, short inclusiveLowerPoint, short inclusiveUpperPoint, int maxDoc, IBits acceptDocs)
                     : base(maxDoc, acceptDocs)
                 {
                     this.values = values;
@@ -335,7 +335,7 @@ namespace Lucene.Net.Search
                 }
             }
 
-            internal AnonymousShortFieldCacheRangeFilter(string field, FieldCache.IParser parser, short? lowerVal, short? upperVal, bool includeLower, bool includeUpper)
+            internal AnonymousInt16FieldCacheRangeFilter(string field, FieldCache.IParser parser, short? lowerVal, short? upperVal, bool includeLower, bool includeUpper)
                 : base(field, parser, lowerVal, upperVal, includeLower, includeUpper)
             {
             }
@@ -371,7 +371,7 @@ namespace Lucene.Net.Search
                     return null;
 
 #pragma warning disable 612, 618
-                FieldCache.Shorts values = FieldCache.DEFAULT.GetInt16s(context.AtomicReader, field, (FieldCache.IShortParser)parser, false);
+                FieldCache.Int16s values = FieldCache.DEFAULT.GetInt16s(context.AtomicReader, field, (FieldCache.IInt16Parser)parser, false);
 #pragma warning restore 612, 618
 
                 // we only request the usage of termDocs, if the range contains 0
@@ -382,15 +382,15 @@ namespace Lucene.Net.Search
 #if FEATURE_SERIALIZABLE
         [Serializable]
 #endif
-        private class AnonymousIntFieldCacheRangeFilter : FieldCacheRangeFilter<int?>
+        private class AnonymousInt32FieldCacheRangeFilter : FieldCacheRangeFilter<int?>
         {
             private class AnonymousClassFieldCacheDocIdSet : FieldCacheDocIdSet
             {
-                private FieldCache.Ints values;
+                private FieldCache.Int32s values;
                 private int inclusiveLowerPoint;
                 private int inclusiveUpperPoint;
 
-                internal AnonymousClassFieldCacheDocIdSet(FieldCache.Ints values, int inclusiveLowerPoint, int inclusiveUpperPoint, int maxDoc, IBits acceptDocs)
+                internal AnonymousClassFieldCacheDocIdSet(FieldCache.Int32s values, int inclusiveLowerPoint, int inclusiveUpperPoint, int maxDoc, IBits acceptDocs)
                     : base(maxDoc, acceptDocs)
                 {
                     this.values = values;
@@ -405,7 +405,7 @@ namespace Lucene.Net.Search
                 }
             }
 
-            internal AnonymousIntFieldCacheRangeFilter(string field, FieldCache.IParser parser, int? lowerVal, int? upperVal, bool includeLower, bool includeUpper)
+            internal AnonymousInt32FieldCacheRangeFilter(string field, FieldCache.IParser parser, int? lowerVal, int? upperVal, bool includeLower, bool includeUpper)
                 : base(field, parser, lowerVal, upperVal, includeLower, includeUpper)
             {
             }
@@ -440,7 +440,7 @@ namespace Lucene.Net.Search
                 if (inclusiveLowerPoint > inclusiveUpperPoint)
                     return null;
 
-                FieldCache.Ints values = FieldCache.DEFAULT.GetInt32s(context.AtomicReader, field, (FieldCache.IIntParser)parser, false);
+                FieldCache.Int32s values = FieldCache.DEFAULT.GetInt32s(context.AtomicReader, field, (FieldCache.IInt32Parser)parser, false);
                 // we only request the usage of termDocs, if the range contains 0
                 return new AnonymousClassFieldCacheDocIdSet(values, inclusiveLowerPoint, inclusiveUpperPoint, context.Reader.MaxDoc, acceptDocs);
             }
@@ -449,15 +449,15 @@ namespace Lucene.Net.Search
 #if FEATURE_SERIALIZABLE
         [Serializable]
 #endif
-        private class AnonymousLongFieldCacheRangeFilter : FieldCacheRangeFilter<long?>
+        private class AnonymousInt64FieldCacheRangeFilter : FieldCacheRangeFilter<long?>
         {
             private class AnonymousClassFieldCacheDocIdSet : FieldCacheDocIdSet
             {
-                private FieldCache.Longs values;
+                private FieldCache.Int64s values;
                 private long inclusiveLowerPoint;
                 private long inclusiveUpperPoint;
 
-                internal AnonymousClassFieldCacheDocIdSet(FieldCache.Longs values, long inclusiveLowerPoint, long inclusiveUpperPoint, int maxDoc, IBits acceptDocs)
+                internal AnonymousClassFieldCacheDocIdSet(FieldCache.Int64s values, long inclusiveLowerPoint, long inclusiveUpperPoint, int maxDoc, IBits acceptDocs)
                     : base(maxDoc, acceptDocs)
                 {
                     this.values = values;
@@ -472,7 +472,7 @@ namespace Lucene.Net.Search
                 }
             }
 
-            internal AnonymousLongFieldCacheRangeFilter(string field, FieldCache.IParser parser, long? lowerVal, long? upperVal, bool includeLower, bool includeUpper)
+            internal AnonymousInt64FieldCacheRangeFilter(string field, FieldCache.IParser parser, long? lowerVal, long? upperVal, bool includeLower, bool includeUpper)
                 : base(field, parser, lowerVal, upperVal, includeLower, includeUpper)
             {
             }
@@ -507,7 +507,7 @@ namespace Lucene.Net.Search
                 if (inclusiveLowerPoint > inclusiveUpperPoint)
                     return null;
 
-                FieldCache.Longs values = FieldCache.DEFAULT.GetInt64s(context.AtomicReader, field, (FieldCache.ILongParser)parser, false);
+                FieldCache.Int64s values = FieldCache.DEFAULT.GetInt64s(context.AtomicReader, field, (FieldCache.IInt64Parser)parser, false);
                 // we only request the usage of termDocs, if the range contains 0
                 return new AnonymousClassFieldCacheDocIdSet(values, inclusiveLowerPoint, inclusiveUpperPoint, context.Reader.MaxDoc, acceptDocs);
             }
@@ -516,15 +516,15 @@ namespace Lucene.Net.Search
 #if FEATURE_SERIALIZABLE
         [Serializable]
 #endif
-        private class AnonymousFloatFieldCacheRangeFilter : FieldCacheRangeFilter<float?>
+        private class AnonymousSingleFieldCacheRangeFilter : FieldCacheRangeFilter<float?>
         {
             private class AnonymousClassFieldCacheDocIdSet : FieldCacheDocIdSet
             {
-                private FieldCache.Floats values;
+                private FieldCache.Singles values;
                 private float inclusiveLowerPoint;
                 private float inclusiveUpperPoint;
 
-                internal AnonymousClassFieldCacheDocIdSet(FieldCache.Floats values, float inclusiveLowerPoint, float inclusiveUpperPoint, int maxDoc, IBits acceptDocs)
+                internal AnonymousClassFieldCacheDocIdSet(FieldCache.Singles values, float inclusiveLowerPoint, float inclusiveUpperPoint, int maxDoc, IBits acceptDocs)
                     : base(maxDoc, acceptDocs)
                 {
                     this.values = values;
@@ -539,7 +539,7 @@ namespace Lucene.Net.Search
                 }
             }
 
-            internal AnonymousFloatFieldCacheRangeFilter(string field, FieldCache.IParser parser, float? lowerVal, float? upperVal, bool includeLower, bool includeUpper)
+            internal AnonymousSingleFieldCacheRangeFilter(string field, FieldCache.IParser parser, float? lowerVal, float? upperVal, bool includeLower, bool includeUpper)
                 : base(field, parser, lowerVal, upperVal, includeLower, includeUpper)
             {
             }
@@ -578,7 +578,7 @@ namespace Lucene.Net.Search
                 if (inclusiveLowerPoint > inclusiveUpperPoint)
                     return null;
 
-                FieldCache.Floats values = FieldCache.DEFAULT.GetSingles(context.AtomicReader, field, (FieldCache.IFloatParser)parser, false);
+                FieldCache.Singles values = FieldCache.DEFAULT.GetSingles(context.AtomicReader, field, (FieldCache.ISingleParser)parser, false);
 
                 // we only request the usage of termDocs, if the range contains 0
                 return new AnonymousClassFieldCacheDocIdSet(values, inclusiveLowerPoint, inclusiveUpperPoint, context.Reader.MaxDoc, acceptDocs);
@@ -723,9 +723,9 @@ namespace Lucene.Net.Search
         /// NOTE: this was newShortRange() in Lucene
         /// </summary>
         [Obsolete]
-        public static FieldCacheRangeFilter<short?> NewInt16Range(string field, FieldCache.IShortParser parser, short? lowerVal, short? upperVal, bool includeLower, bool includeUpper)
+        public static FieldCacheRangeFilter<short?> NewInt16Range(string field, FieldCache.IInt16Parser parser, short? lowerVal, short? upperVal, bool includeLower, bool includeUpper)
         {
-            return new AnonymousShortFieldCacheRangeFilter(field, parser, lowerVal, upperVal, includeLower, includeUpper);
+            return new AnonymousInt16FieldCacheRangeFilter(field, parser, lowerVal, upperVal, includeLower, includeUpper);
         }
 
         /// <summary>
@@ -747,9 +747,9 @@ namespace Lucene.Net.Search
         /// <para/>
         /// NOTE: this was newIntRange() in Lucene
         /// </summary>
-        public static FieldCacheRangeFilter<int?> NewInt32Range(string field, FieldCache.IIntParser parser, int? lowerVal, int? upperVal, bool includeLower, bool includeUpper)
+        public static FieldCacheRangeFilter<int?> NewInt32Range(string field, FieldCache.IInt32Parser parser, int? lowerVal, int? upperVal, bool includeLower, bool includeUpper)
         {
-            return new AnonymousIntFieldCacheRangeFilter(field, parser, lowerVal, upperVal, includeLower, includeUpper);
+            return new AnonymousInt32FieldCacheRangeFilter(field, parser, lowerVal, upperVal, includeLower, includeUpper);
         }
 
         /// <summary>
@@ -770,9 +770,9 @@ namespace Lucene.Net.Search
         /// <para/>
         /// NOTE: this was newLongRange() in Lucene
         /// </summary>
-        public static FieldCacheRangeFilter<long?> NewInt64Range(string field, FieldCache.ILongParser parser, long? lowerVal, long? upperVal, bool includeLower, bool includeUpper)
+        public static FieldCacheRangeFilter<long?> NewInt64Range(string field, FieldCache.IInt64Parser parser, long? lowerVal, long? upperVal, bool includeLower, bool includeUpper)
         {
-            return new AnonymousLongFieldCacheRangeFilter(field, parser, lowerVal, upperVal, includeLower, includeUpper);
+            return new AnonymousInt64FieldCacheRangeFilter(field, parser, lowerVal, upperVal, includeLower, includeUpper);
         }
 
         /// <summary>
@@ -794,9 +794,9 @@ namespace Lucene.Net.Search
         /// <para/>
         /// NOTE: this was newFloatRange() in Lucene
         /// </summary>
-        public static FieldCacheRangeFilter<float?> NewSingleRange(string field, FieldCache.IFloatParser parser, float? lowerVal, float? upperVal, bool includeLower, bool includeUpper)
+        public static FieldCacheRangeFilter<float?> NewSingleRange(string field, FieldCache.ISingleParser parser, float? lowerVal, float? upperVal, bool includeLower, bool includeUpper)
         {
-            return new AnonymousFloatFieldCacheRangeFilter(field, parser, lowerVal, upperVal, includeLower, includeUpper);
+            return new AnonymousSingleFieldCacheRangeFilter(field, parser, lowerVal, upperVal, includeLower, includeUpper);
         }
 
         /// <summary>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Search/FieldCacheRewriteMethod.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Search/FieldCacheRewriteMethod.cs b/src/Lucene.Net.Core/Search/FieldCacheRewriteMethod.cs
index 973bf8b..f669871 100644
--- a/src/Lucene.Net.Core/Search/FieldCacheRewriteMethod.cs
+++ b/src/Lucene.Net.Core/Search/FieldCacheRewriteMethod.cs
@@ -24,7 +24,7 @@ namespace Lucene.Net.Search
     using IBits = Lucene.Net.Util.IBits;
     using BytesRef = Lucene.Net.Util.BytesRef;
     using IndexReader = Lucene.Net.Index.IndexReader;
-    using LongBitSet = Lucene.Net.Util.LongBitSet;
+    using Int64BitSet = Lucene.Net.Util.Int64BitSet;
     using SortedDocValues = Lucene.Net.Index.SortedDocValues;
     using Terms = Lucene.Net.Index.Terms;
     using TermsEnum = Lucene.Net.Index.TermsEnum;
@@ -102,7 +102,7 @@ namespace Lucene.Net.Search
             {
                 SortedDocValues fcsi = FieldCache.DEFAULT.GetTermsIndex((context.AtomicReader), m_query.m_field);
                 // Cannot use FixedBitSet because we require long index (ord):
-                LongBitSet termSet = new LongBitSet(fcsi.ValueCount);
+                Int64BitSet termSet = new Int64BitSet(fcsi.ValueCount);
                 TermsEnum termsEnum = m_query.GetTermsEnum(new TermsAnonymousInnerClassHelper(this, fcsi));
 
                 Debug.Assert(termsEnum != null);
@@ -206,9 +206,9 @@ namespace Lucene.Net.Search
                 private readonly MultiTermQueryFieldCacheWrapperFilter outerInstance;
 
                 private SortedDocValues fcsi;
-                private LongBitSet termSet;
+                private Int64BitSet termSet;
 
-                public FieldCacheDocIdSetAnonymousInnerClassHelper(MultiTermQueryFieldCacheWrapperFilter outerInstance, int maxDoc, IBits acceptDocs, SortedDocValues fcsi, LongBitSet termSet)
+                public FieldCacheDocIdSetAnonymousInnerClassHelper(MultiTermQueryFieldCacheWrapperFilter outerInstance, int maxDoc, IBits acceptDocs, SortedDocValues fcsi, Int64BitSet termSet)
                     : base(maxDoc, acceptDocs)
                 {
                     this.outerInstance = outerInstance;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Search/FieldComparator.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Search/FieldComparator.cs b/src/Lucene.Net.Core/Search/FieldComparator.cs
index e4b0026..e4600ef 100644
--- a/src/Lucene.Net.Core/Search/FieldComparator.cs
+++ b/src/Lucene.Net.Core/Search/FieldComparator.cs
@@ -529,21 +529,22 @@ namespace Lucene.Net.Search
         /// <summary>
         /// Parses field's values as float (using {@link
         ///  FieldCache#getFloats} and sorts by ascending value
+        /// <para/>
+        /// NOTE: This was FloatComparator in Lucene
         /// </summary>
-         // LUCENENET TODO: Rename SingleComparer ?
-        public sealed class FloatComparer : NumericComparer<float>
+        public sealed class SingleComparer : NumericComparer<float>
         {
             private readonly float[] values;
-            private readonly FieldCache.IFloatParser parser;
-            private FieldCache.Floats currentReaderValues;
+            private readonly FieldCache.ISingleParser parser;
+            private FieldCache.Singles currentReaderValues;
             private float bottom;
             private float topValue;
 
-            internal FloatComparer(int numHits, string field, FieldCache.IParser parser, float? missingValue)
+            internal SingleComparer(int numHits, string field, FieldCache.IParser parser, float? missingValue)
                 : base(field, missingValue)
             {
                 values = new float[numHits];
-                this.parser = (FieldCache.IFloatParser)parser;
+                this.parser = (FieldCache.ISingleParser)parser;
             }
 
             public override int Compare(int slot1, int slot2)
@@ -616,23 +617,24 @@ namespace Lucene.Net.Search
 
         /// <summary>
         /// Parses field's values as short (using {@link
-        ///  FieldCache#getShorts} and sorts by ascending value
+        /// FieldCache#getShorts} and sorts by ascending value
+        /// <para/>
+        /// NOTE: This was ShortComparator in Lucene
         /// </summary>
-         // LUCENENET TODO: Rename Int16Comparer ?
         [Obsolete]
-        public sealed class ShortComparer : NumericComparer<short>
+        public sealed class Int16Comparer : NumericComparer<short>
         {
             private readonly short[] values;
-            private readonly FieldCache.IShortParser parser;
-            private FieldCache.Shorts currentReaderValues;
+            private readonly FieldCache.IInt16Parser parser;
+            private FieldCache.Int16s currentReaderValues;
             private short bottom;
             private short topValue;
 
-            internal ShortComparer(int numHits, string field, FieldCache.IParser parser, short? missingValue)
+            internal Int16Comparer(int numHits, string field, FieldCache.IParser parser, short? missingValue)
                 : base(field, missingValue)
             {
                 values = new short[numHits];
-                this.parser = (FieldCache.IShortParser)parser;
+                this.parser = (FieldCache.IInt16Parser)parser;
             }
 
             public override int Compare(int slot1, int slot2)
@@ -706,22 +708,23 @@ namespace Lucene.Net.Search
 
         /// <summary>
         /// Parses field's values as int (using {@link
-        ///  FieldCache#getInts} and sorts by ascending value
+        /// FieldCache#getInts} and sorts by ascending value
+        /// <para/>
+        /// NOTE: This was IntComparator in Lucene
         /// </summary>
-         // LUCENENET TODO: Rename Int32Comparer ?
-        public sealed class IntComparer : NumericComparer<int>
+        public sealed class Int32Comparer : NumericComparer<int>
         {
             private readonly int[] values;
-            private readonly FieldCache.IIntParser parser;
-            private FieldCache.Ints currentReaderValues;
+            private readonly FieldCache.IInt32Parser parser;
+            private FieldCache.Int32s currentReaderValues;
             private int bottom; // Value of bottom of queue
             private int topValue;
 
-            internal IntComparer(int numHits, string field, FieldCache.IParser parser, int? missingValue)
+            internal Int32Comparer(int numHits, string field, FieldCache.IParser parser, int? missingValue)
                 : base(field, missingValue)
             {
                 values = new int[numHits];
-                this.parser = (FieldCache.IIntParser)parser;
+                this.parser = (FieldCache.IInt32Parser)parser;
             }
 
             public override int Compare(int slot1, int slot2)
@@ -792,22 +795,23 @@ namespace Lucene.Net.Search
 
         /// <summary>
         /// Parses field's values as long (using {@link
-        ///  FieldCache#getLongs} and sorts by ascending value
+        /// FieldCache#getLongs} and sorts by ascending value
+        /// <para/>
+        /// NOTE: This was LongComparator in Lucene
         /// </summary>
-         // LUCENENET TODO: Rename Int64Comparer ?
-        public sealed class LongComparer : NumericComparer<long>
+        public sealed class Int64Comparer : NumericComparer<long>
         {
             private readonly long[] values;
-            private readonly FieldCache.ILongParser parser;
-            private FieldCache.Longs currentReaderValues;
+            private readonly FieldCache.IInt64Parser parser;
+            private FieldCache.Int64s currentReaderValues;
             private long bottom;
             private long topValue;
 
-            internal LongComparer(int numHits, string field, FieldCache.IParser parser, long? missingValue)
+            internal Int64Comparer(int numHits, string field, FieldCache.IParser parser, long? missingValue)
                 : base(field, missingValue)
             {
                 values = new long[numHits];
-                this.parser = (FieldCache.ILongParser)parser;
+                this.parser = (FieldCache.IInt64Parser)parser;
             }
 
             public override int Compare(int slot1, int slot2)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Search/MultiPhraseQuery.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Search/MultiPhraseQuery.cs b/src/Lucene.Net.Core/Search/MultiPhraseQuery.cs
index 7fff3c8..16d15a2 100644
--- a/src/Lucene.Net.Core/Search/MultiPhraseQuery.cs
+++ b/src/Lucene.Net.Core/Search/MultiPhraseQuery.cs
@@ -519,9 +519,12 @@ namespace Lucene.Net.Search
             }
         }
 
-        private sealed class IntQueue
+        /// <summary>
+        /// NOTE: This was IntQueue in Lucene
+        /// </summary>
+        private sealed class Int32Queue
         {
-            public IntQueue()
+            public Int32Queue()
             {
                 InitializeInstanceFields();
             }
@@ -579,7 +582,7 @@ namespace Lucene.Net.Search
         private int _doc;
         private int _freq;
         private readonly DocsQueue _queue;
-        private readonly IntQueue _posList;
+        private readonly Int32Queue _posList;
         private readonly long _cost;
 
         public UnionDocsAndPositionsEnum(IBits liveDocs, AtomicReaderContext context, Term[] terms, IDictionary<Term, TermContext> termContexts, TermsEnum termsEnum)
@@ -606,7 +609,7 @@ namespace Lucene.Net.Search
             }
 
             _queue = new DocsQueue(docsEnums);
-            _posList = new IntQueue();
+            _posList = new Int32Queue();
         }
 
         public override sealed int NextDoc()

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Search/NumericRangeQuery.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Search/NumericRangeQuery.cs b/src/Lucene.Net.Core/Search/NumericRangeQuery.cs
index 003078f..08a86c4 100644
--- a/src/Lucene.Net.Core/Search/NumericRangeQuery.cs
+++ b/src/Lucene.Net.Core/Search/NumericRangeQuery.cs
@@ -34,8 +34,8 @@ namespace Lucene.Net.Search
     /// <summary>
     /// <p>A <seealso cref="Query"/> that matches numeric values within a
     /// specified range.  To use this, you must first index the
-    /// numeric values using <seealso cref="IntField"/>, {@link
-    /// FloatField}, <seealso cref="LongField"/> or <seealso cref="DoubleField"/> (expert: {@link
+    /// numeric values using <seealso cref="Int32Field"/>, {@link
+    /// FloatField}, <seealso cref="Int64Field"/> or <seealso cref="DoubleField"/> (expert: {@link
     /// NumericTokenStream}).  If your terms are instead textual,
     /// you should use <seealso cref="TermRangeQuery"/>.  {@link
     /// NumericRangeFilter} is the filter equivalent of this
@@ -144,8 +144,8 @@ namespace Lucene.Net.Search
     ///  <li>Steps <b>&gt;=64</b> for <em>long/double</em> and <b>&gt;=32</b> for <em>int/float</em> produces one token
     ///  per value in the index and querying is as slow as a conventional <seealso cref="TermRangeQuery"/>. But it can be used
     ///  to produce fields, that are solely used for sorting (in this case simply use <seealso cref="Integer#MAX_VALUE"/> as
-    ///  <code>precisionStep</code>). Using <seealso cref="IntField"/>,
-    ///  <seealso cref="LongField"/>, <seealso cref="FloatField"/> or <seealso cref="DoubleField"/> for sorting
+    ///  <code>precisionStep</code>). Using <seealso cref="Int32Field"/>,
+    ///  <seealso cref="Int64Field"/>, <seealso cref="SingleField"/> or <seealso cref="DoubleField"/> for sorting
     ///  is ideal, because building the field cache is much faster than with text-only numbers.
     ///  These fields have one term per value and therefore also work with term enumeration for building distinct lists
     ///  (e.g. facets / preselected values to search for).
@@ -361,7 +361,7 @@ namespace Lucene.Net.Search
                                 maxBound--;
                             }
 
-                            NumericUtils.SplitInt64Range(new LongRangeBuilderAnonymousInnerClassHelper(this), this.outerInstance.precisionStep, minBound, maxBound);
+                            NumericUtils.SplitInt64Range(new Int64RangeBuilderAnonymousInnerClassHelper(this), this.outerInstance.precisionStep, minBound, maxBound);
                             break;
                         }
 
@@ -408,7 +408,7 @@ namespace Lucene.Net.Search
                                 maxBound--;
                             }
 
-                            NumericUtils.SplitInt32Range(new IntRangeBuilderAnonymousInnerClassHelper(this), this.outerInstance.precisionStep, minBound, maxBound);
+                            NumericUtils.SplitInt32Range(new Int32RangeBuilderAnonymousInnerClassHelper(this), this.outerInstance.precisionStep, minBound, maxBound);
                             break;
                         }
 
@@ -420,11 +420,11 @@ namespace Lucene.Net.Search
                 termComp = Comparer;
             }
 
-            private class LongRangeBuilderAnonymousInnerClassHelper : NumericUtils.LongRangeBuilder
+            private class Int64RangeBuilderAnonymousInnerClassHelper : NumericUtils.Int64RangeBuilder
             {
                 private readonly NumericRangeTermsEnum outerInstance;
 
-                public LongRangeBuilderAnonymousInnerClassHelper(NumericRangeTermsEnum outerInstance)
+                public Int64RangeBuilderAnonymousInnerClassHelper(NumericRangeTermsEnum outerInstance)
                 {
                     this.outerInstance = outerInstance;
                 }
@@ -436,11 +436,11 @@ namespace Lucene.Net.Search
                 }
             }
 
-            private class IntRangeBuilderAnonymousInnerClassHelper : NumericUtils.IntRangeBuilder
+            private class Int32RangeBuilderAnonymousInnerClassHelper : NumericUtils.Int32RangeBuilder
             {
                 private readonly NumericRangeTermsEnum outerInstance;
 
-                public IntRangeBuilderAnonymousInnerClassHelper(NumericRangeTermsEnum outerInstance)
+                public Int32RangeBuilderAnonymousInnerClassHelper(NumericRangeTermsEnum outerInstance)
                 {
                     this.outerInstance = outerInstance;
                 }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Search/Similarities/BM25Similarity.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Search/Similarities/BM25Similarity.cs b/src/Lucene.Net.Core/Search/Similarities/BM25Similarity.cs
index 2f363d8..86ae76f 100644
--- a/src/Lucene.Net.Core/Search/Similarities/BM25Similarity.cs
+++ b/src/Lucene.Net.Core/Search/Similarities/BM25Similarity.cs
@@ -23,7 +23,7 @@ namespace Lucene.Net.Search.Similarities
     using BytesRef = Lucene.Net.Util.BytesRef;
     using FieldInvertState = Lucene.Net.Index.FieldInvertState;
     using NumericDocValues = Lucene.Net.Index.NumericDocValues;
-    using SmallFloat = Lucene.Net.Util.SmallFloat;
+    using SmallSingle = Lucene.Net.Util.SmallSingle;
 
     /// <summary>
     /// BM25 Similarity. Introduced in Stephen E. Robertson, Steve Walker,
@@ -102,18 +102,18 @@ namespace Lucene.Net.Search.Similarities
 
         /// <summary>
         /// The default implementation encodes <code>boost / sqrt(length)</code>
-        /// with <seealso cref="SmallFloat#floatToByte315(float)"/>.  this is compatible with
+        /// with <seealso cref="SmallSingle#floatToByte315(float)"/>.  this is compatible with
         /// Lucene's default implementation.  If you change this, then you should
         /// change <seealso cref="#decodeNormValue(byte)"/> to match.
         /// </summary>
         protected internal virtual sbyte EncodeNormValue(float boost, int fieldLength) // LUCENENET TODO: Can we use byte?
         {
-            return SmallFloat.SingleToByte315(boost / (float)Math.Sqrt(fieldLength));
+            return SmallSingle.SingleToByte315(boost / (float)Math.Sqrt(fieldLength));
         }
 
         /// <summary>
         /// The default implementation returns <code>1 / f<sup>2</sup></code>
-        /// where <code>f</code> is <seealso cref="SmallFloat#byte315ToFloat(byte)"/>.
+        /// where <code>f</code> is <seealso cref="SmallSingle#byte315ToFloat(byte)"/>.
         /// </summary>
         protected internal virtual float DecodeNormValue(sbyte b) // LUCENENET TODO: Can we use byte?
         {
@@ -151,7 +151,7 @@ namespace Lucene.Net.Search.Similarities
         {
             for (int i = 0; i < 256; i++)
             {
-                float f = SmallFloat.Byte315ToSingle((sbyte)i);
+                float f = SmallSingle.Byte315ToSingle((sbyte)i);
                 NORM_TABLE[i] = 1.0f / (f * f);
             }
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Search/Similarities/DefaultSimilarity.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Search/Similarities/DefaultSimilarity.cs b/src/Lucene.Net.Core/Search/Similarities/DefaultSimilarity.cs
index 2ea6e9a..b2a84a9 100644
--- a/src/Lucene.Net.Core/Search/Similarities/DefaultSimilarity.cs
+++ b/src/Lucene.Net.Core/Search/Similarities/DefaultSimilarity.cs
@@ -21,7 +21,7 @@ namespace Lucene.Net.Search.Similarities
 
     using BytesRef = Lucene.Net.Util.BytesRef;
     using FieldInvertState = Lucene.Net.Index.FieldInvertState;
-    using SmallFloat = Lucene.Net.Util.SmallFloat;
+    using SmallSingle = Lucene.Net.Util.SmallSingle;
 
     /// <summary>
     /// Expert: Default scoring implementation which {@link #encodeNormValue(float)
@@ -54,7 +54,7 @@ namespace Lucene.Net.Search.Similarities
         {
             for (int i = 0; i < 256; i++)
             {
-                NORM_TABLE[i] = SmallFloat.Byte315ToSingle((sbyte)i);
+                NORM_TABLE[i] = SmallSingle.Byte315ToSingle((sbyte)i);
             }
         }
 
@@ -90,10 +90,10 @@ namespace Lucene.Net.Search.Similarities
         /// representable value.
         /// </summary>
         /// <seealso cref= Lucene.Net.Document.Field#setBoost(float) </seealso>
-        /// <seealso cref= Lucene.Net.Util.SmallFloat </seealso>
+        /// <seealso cref= Lucene.Net.Util.SmallSingle </seealso>
         public override sealed long EncodeNormValue(float f)
         {
-            return SmallFloat.SingleToByte315(f);
+            return SmallSingle.SingleToByte315(f);
         }
 
         /// <summary>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Search/Similarities/SimilarityBase.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Search/Similarities/SimilarityBase.cs b/src/Lucene.Net.Core/Search/Similarities/SimilarityBase.cs
index 9337174..4ddaeb6 100644
--- a/src/Lucene.Net.Core/Search/Similarities/SimilarityBase.cs
+++ b/src/Lucene.Net.Core/Search/Similarities/SimilarityBase.cs
@@ -4,7 +4,7 @@ using AtomicReaderContext = Lucene.Net.Index.AtomicReaderContext;
 using BytesRef = Lucene.Net.Util.BytesRef;
 using FieldInvertState = Lucene.Net.Index.FieldInvertState;
 using NumericDocValues = Lucene.Net.Index.NumericDocValues;
-using SmallFloat = Lucene.Net.Util.SmallFloat;
+using SmallSingle = Lucene.Net.Util.SmallSingle;
 
 namespace Lucene.Net.Search.Similarities
 {
@@ -235,7 +235,7 @@ namespace Lucene.Net.Search.Similarities
         {
             for (int i = 0; i < 256; i++)
             {
-                float floatNorm = SmallFloat.Byte315ToSingle((sbyte)i);
+                float floatNorm = SmallSingle.Byte315ToSingle((sbyte)i);
                 NORM_TABLE[i] = 1.0f / (floatNorm * floatNorm);
             }
         }
@@ -268,7 +268,7 @@ namespace Lucene.Net.Search.Similarities
         /// Encodes the length to a byte via SmallFloat. </summary>
         protected internal virtual sbyte EncodeNormValue(float boost, float length) // LUCENENET TODO: Can this be byte?
         {
-            return SmallFloat.SingleToByte315((boost / (float)Math.Sqrt(length)));
+            return SmallSingle.SingleToByte315((boost / (float)Math.Sqrt(length)));
         }
 
         // ----------------------------- Static methods ------------------------------

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Search/SortField.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Search/SortField.cs b/src/Lucene.Net.Core/Search/SortField.cs
index 7f2a474..f0c9d7a 100644
--- a/src/Lucene.Net.Core/Search/SortField.cs
+++ b/src/Lucene.Net.Core/Search/SortField.cs
@@ -130,15 +130,15 @@ namespace Lucene.Net.Search
         ///  subclass an existing numeric parser, or field is null </exception>
         public SortField(string field, FieldCache.IParser parser, bool reverse)
         {
-            if (parser is FieldCache.IIntParser)
+            if (parser is FieldCache.IInt32Parser)
             {
                 InitFieldType(field, SortFieldType.INT);
             }
-            else if (parser is FieldCache.IFloatParser)
+            else if (parser is FieldCache.ISingleParser)
             {
                 InitFieldType(field, SortFieldType.FLOAT);
             }
-            else if (parser is FieldCache.IShortParser)
+            else if (parser is FieldCache.IInt16Parser)
             {
 #pragma warning disable 612, 618
                 InitFieldType(field, SortFieldType.SHORT);
@@ -148,7 +148,7 @@ namespace Lucene.Net.Search
                 InitFieldType(field, SortFieldType.BYTE);
 #pragma warning restore 612, 618
             }
-            else if (parser is FieldCache.ILongParser)
+            else if (parser is FieldCache.IInt64Parser)
             {
                 InitFieldType(field, SortFieldType.LONG);
             }
@@ -467,13 +467,13 @@ namespace Lucene.Net.Search
                     return new FieldComparer.DocComparer(numHits);
 
                 case SortFieldType.INT:
-                    return new FieldComparer.IntComparer(numHits, field, parser, (int?)m_missingValue);
+                    return new FieldComparer.Int32Comparer(numHits, field, parser, (int?)m_missingValue);
 
                 case SortFieldType.FLOAT:
-                    return new FieldComparer.FloatComparer(numHits, field, parser, (float?)m_missingValue);
+                    return new FieldComparer.SingleComparer(numHits, field, parser, (float?)m_missingValue);
 
                 case SortFieldType.LONG:
-                    return new FieldComparer.LongComparer(numHits, field, parser, (long?)m_missingValue);
+                    return new FieldComparer.Int64Comparer(numHits, field, parser, (long?)m_missingValue);
 
                 case SortFieldType.DOUBLE:
                     return new FieldComparer.DoubleComparer(numHits, field, parser, (double?)m_missingValue);
@@ -483,7 +483,7 @@ namespace Lucene.Net.Search
                     return new FieldComparer.ByteComparer(numHits, field, parser, (sbyte?)m_missingValue);
 
                 case SortFieldType.SHORT:
-                    return new FieldComparer.ShortComparer(numHits, field, parser, (short?)m_missingValue);
+                    return new FieldComparer.Int16Comparer(numHits, field, parser, (short?)m_missingValue);
 #pragma warning restore 612, 618
 
                 case SortFieldType.CUSTOM:

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Store/RAMDirectory.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Store/RAMDirectory.cs b/src/Lucene.Net.Core/Store/RAMDirectory.cs
index 98bc160..2bbd2ac 100644
--- a/src/Lucene.Net.Core/Store/RAMDirectory.cs
+++ b/src/Lucene.Net.Core/Store/RAMDirectory.cs
@@ -45,7 +45,7 @@ namespace Lucene.Net.Store
     public class RAMDirectory : BaseDirectory
     {
         protected internal readonly IDictionary<string, RAMFile> m_fileMap = new ConcurrentDictionary<string, RAMFile>();
-        protected internal readonly AtomicLong m_sizeInBytes = new AtomicLong(0);
+        protected internal readonly AtomicInt64 m_sizeInBytes = new AtomicInt64(0);
 
         // *****
         // Lock acquisition sequence:  RAMDirectory, then RAMFile

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Support/AtomicInteger.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Support/AtomicInteger.cs b/src/Lucene.Net.Core/Support/AtomicInteger.cs
index 5a010e3..4c07b65 100644
--- a/src/Lucene.Net.Core/Support/AtomicInteger.cs
+++ b/src/Lucene.Net.Core/Support/AtomicInteger.cs
@@ -2,16 +2,19 @@
 
 namespace Lucene.Net.Support
 {
-    public class AtomicInteger
+    /// <summary>
+    /// NOTE: This was AtomicInteger in the JDK
+    /// </summary>
+    public class AtomicInt32
     {
         private int value;
 
-        public AtomicInteger()
+        public AtomicInt32()
             : this(0)
         {
         }
 
-        public AtomicInteger(int value_)
+        public AtomicInt32(int value_)
         {
             Interlocked.Exchange(ref value, value_);
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Support/AtomicLong.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Support/AtomicLong.cs b/src/Lucene.Net.Core/Support/AtomicLong.cs
index 92c5b2b..3e330eb 100644
--- a/src/Lucene.Net.Core/Support/AtomicLong.cs
+++ b/src/Lucene.Net.Core/Support/AtomicLong.cs
@@ -2,16 +2,19 @@
 
 namespace Lucene.Net.Support
 {
-    public class AtomicLong
+    /// <summary>
+    /// NOTE: This was AtomicLong in the JDK
+    /// </summary>
+    public class AtomicInt64
     {
         private long value;
 
-        public AtomicLong()
+        public AtomicInt64()
             : this(0)
         {
         }
 
-        public AtomicLong(long value)
+        public AtomicInt64(long value)
         {
             Interlocked.Exchange(ref this.value, value);
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Support/Buffer.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Support/Buffer.cs b/src/Lucene.Net.Core/Support/Buffer.cs
index f40bcef..60df952 100644
--- a/src/Lucene.Net.Core/Support/Buffer.cs
+++ b/src/Lucene.Net.Core/Support/Buffer.cs
@@ -3,7 +3,7 @@
 namespace Lucene.Net.Support
 {
     /// <summary>
-    /// Base class for <see cref="ByteBuffer"/> and <see cref="LongBuffer"/> (ported from Java)
+    /// Base class for <see cref="ByteBuffer"/> and <see cref="Int64Buffer"/> (ported from Java)
     /// </summary>
     public abstract class Buffer
     {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Support/ByteBuffer.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Support/ByteBuffer.cs b/src/Lucene.Net.Core/Support/ByteBuffer.cs
index 051d724..3d0a908 100644
--- a/src/Lucene.Net.Core/Support/ByteBuffer.cs
+++ b/src/Lucene.Net.Core/Support/ByteBuffer.cs
@@ -596,7 +596,7 @@ namespace Lucene.Net.Support
         /// <summary>
         /// NOTE: This was asLongBuffer() in the JDK
         /// </summary>
-        public abstract LongBuffer AsInt64Buffer();
+        public abstract Int64Buffer AsInt64Buffer();
 
         /// <summary>
         /// NOTE: This was getFloat() in the JDK
@@ -1093,11 +1093,11 @@ namespace Lucene.Net.Support
             /// <summary>
             /// NOTE: This was asLongBuffer() in the JDK
             /// </summary>
-            public override LongBuffer AsInt64Buffer()
+            public override Int64Buffer AsInt64Buffer()
             {
                 int size = this.Remaining >> 3;
                 int off = offset + Position;
-                return (new ByteBufferAsLongBuffer(bigEndian,
+                return (new ByteBufferAsInt64Buffer(bigEndian,
                     this,
                     -1,
                     0,
@@ -1499,7 +1499,7 @@ namespace Lucene.Net.Support
             /// <summary>
             /// NOTE: This was asLongBuffer() in the JDK
             /// </summary>
-            public override LongBuffer AsInt64Buffer()
+            public override Int64Buffer AsInt64Buffer()
             {
                 throw new NotImplementedException();
                 //int size = this.remaining() >> 3;
@@ -1589,14 +1589,16 @@ namespace Lucene.Net.Support
             //}
         }
 
-
-        internal class ByteBufferAsLongBuffer : LongBuffer
+        /// <summary>
+        /// NOTE: This was ByteBufferAsLongBuffer in the JDK
+        /// </summary>
+        internal class ByteBufferAsInt64Buffer : Int64Buffer
         {
             protected readonly ByteBuffer bb;
             new protected readonly int offset;
             protected readonly bool bigEndian;
 
-            internal ByteBufferAsLongBuffer(bool bigEndian, ByteBuffer bb)
+            internal ByteBufferAsInt64Buffer(bool bigEndian, ByteBuffer bb)
                 : base(-1, 0,
                       bb.Remaining >> 3,
                       bb.Remaining >> 3)
@@ -1611,7 +1613,7 @@ namespace Lucene.Net.Support
                 this.bigEndian = bigEndian;
             }
 
-            internal ByteBufferAsLongBuffer(bool bigEndian, ByteBuffer bb,
+            internal ByteBufferAsInt64Buffer(bool bigEndian, ByteBuffer bb,
                                              int mark, int pos, int lim, int cap,
                                              int off)
                 : base(mark, pos, lim, cap)
@@ -1621,7 +1623,7 @@ namespace Lucene.Net.Support
                 this.bigEndian = bigEndian;
             }
 
-            public override LongBuffer Slice()
+            public override Int64Buffer Slice()
             {
                 int pos = this.Position;
                 int lim = this.Limit;
@@ -1629,12 +1631,12 @@ namespace Lucene.Net.Support
                 int rem = (pos <= lim ? lim - pos : 0);
                 int off = (pos << 3) + offset;
                 Debug.Assert(off >= 0);
-                return new ByteBufferAsLongBuffer(this.bigEndian, bb, -1, 0, rem, rem, off);
+                return new ByteBufferAsInt64Buffer(this.bigEndian, bb, -1, 0, rem, rem, off);
             }
 
-            public override LongBuffer Duplicate()
+            public override Int64Buffer Duplicate()
             {
-                return new ByteBufferAsLongBuffer(this.bigEndian,
+                return new ByteBufferAsInt64Buffer(this.bigEndian,
                                             bb,
                                             this.MarkValue,
                                             this.Position,
@@ -1643,7 +1645,7 @@ namespace Lucene.Net.Support
                                             offset);
             }
 
-            public override LongBuffer AsReadOnlyBuffer()
+            public override Int64Buffer AsReadOnlyBuffer()
             {
                 throw new NotImplementedException();
                 //return new ByteBufferAsLongBufferRB(bb,
@@ -1685,13 +1687,13 @@ namespace Lucene.Net.Support
                 return littleEndian;
             }
 
-            public override LongBuffer Put(long value)
+            public override Int64Buffer Put(long value)
             {
                 PutImpl(Ix(NextPutIndex()), value);
                 return this;
             }
 
-            public override LongBuffer Put(int index, long value)
+            public override Int64Buffer Put(int index, long value)
             {
                 PutImpl(Ix(CheckIndex(index)), value);
                 return this;
@@ -1712,7 +1714,7 @@ namespace Lucene.Net.Support
             }
 
 
-            public override LongBuffer Compact()
+            public override Int64Buffer Compact()
             {
                 int pos = Position;
                 int lim = Limit;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Support/LongBuffer.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Support/LongBuffer.cs b/src/Lucene.Net.Core/Support/LongBuffer.cs
index 0bfdcf2..5d8290c 100644
--- a/src/Lucene.Net.Core/Support/LongBuffer.cs
+++ b/src/Lucene.Net.Core/Support/LongBuffer.cs
@@ -6,7 +6,7 @@ namespace Lucene.Net.Support
     /// <summary>
     /// Ported from Java's nio.LongBuffer
     /// </summary>
-    public abstract class LongBuffer : Buffer, IComparable<LongBuffer> // LUCENENET TODO: Rename Int64Buffer
+    public abstract class Int64Buffer : Buffer, IComparable<Int64Buffer>
     {
         // These fields are declared here rather than in Heap-X-Buffer in order to
         // reduce the number of virtual method invocations needed to access these
@@ -19,7 +19,7 @@ namespace Lucene.Net.Support
         /// <summary>
         /// Creates a new buffer with the given mark, position, limit, capacity, backing array, and array offset
         /// </summary>
-        public LongBuffer(int mark, int pos, int lim, int cap,
+        public Int64Buffer(int mark, int pos, int lim, int cap,
             long[] hb, int offset) 
             : base(mark, pos, lim, cap)
         {
@@ -30,25 +30,25 @@ namespace Lucene.Net.Support
         /// <summary>
         /// Creates a new buffer with the given mark, position, limit, and capacity
         /// </summary>
-        public LongBuffer(int mark, int pos, int lim, int cap)
+        public Int64Buffer(int mark, int pos, int lim, int cap)
             : this(mark, pos, lim, cap, null, 0)
         {
         }
 
-        public static LongBuffer Allocate(int capacity)
+        public static Int64Buffer Allocate(int capacity)
         {
             if (capacity < 0)
                 throw new ArgumentException();
-            return new HeapLongBuffer(capacity, capacity);
+            return new HeapInt64Buffer(capacity, capacity);
         }
 
 
-        public static LongBuffer Wrap(long[] array,
+        public static Int64Buffer Wrap(long[] array,
                                     int offset, int length)
         {
             try
             {
-                return new HeapLongBuffer(array, offset, length);
+                return new HeapInt64Buffer(array, offset, length);
             }
 #pragma warning disable 168
             catch (ArgumentException x)
@@ -58,29 +58,29 @@ namespace Lucene.Net.Support
             }
         }
 
-        public static LongBuffer Wrap(long[] array)
+        public static Int64Buffer Wrap(long[] array)
         {
             return Wrap(array, 0, array.Length);
         }
 
 
-        public abstract LongBuffer Slice();
+        public abstract Int64Buffer Slice();
 
-        public abstract LongBuffer Duplicate();
+        public abstract Int64Buffer Duplicate();
 
-        public abstract LongBuffer AsReadOnlyBuffer();
+        public abstract Int64Buffer AsReadOnlyBuffer();
 
         public abstract long Get();
 
-        public abstract LongBuffer Put(long l);
+        public abstract Int64Buffer Put(long l);
 
         public abstract long Get(int index);
 
-        public abstract LongBuffer Put(int index, long l);
+        public abstract Int64Buffer Put(int index, long l);
 
         // -- Bulk get operations --
 
-        public virtual LongBuffer Get(long[] dst, int offset, int length)
+        public virtual Int64Buffer Get(long[] dst, int offset, int length)
         {
             CheckBounds(offset, length, dst.Length);
             if (length > Remaining)
@@ -91,14 +91,14 @@ namespace Lucene.Net.Support
             return this;
         }
 
-        public virtual LongBuffer Get(long[] dst)
+        public virtual Int64Buffer Get(long[] dst)
         {
             return Get(dst, 0, dst.Length);
         }
 
         // -- Bulk put operations --
 
-        public virtual LongBuffer Put(LongBuffer src)
+        public virtual Int64Buffer Put(Int64Buffer src)
         {
             if (src == this)
                 throw new ArgumentException();
@@ -112,7 +112,7 @@ namespace Lucene.Net.Support
             return this;
         }
 
-        public virtual LongBuffer Put(long[] src, int offset, int length)
+        public virtual Int64Buffer Put(long[] src, int offset, int length)
         {
             CheckBounds(offset, length, src.Length);
             if (length > Remaining)
@@ -123,7 +123,7 @@ namespace Lucene.Net.Support
             return this;
         }
 
-        public LongBuffer Put(long[] src)
+        public Int64Buffer Put(long[] src)
         {
             return Put(src, 0, src.Length);
         }
@@ -160,7 +160,7 @@ namespace Lucene.Net.Support
             }
         }
 
-        public abstract LongBuffer Compact();
+        public abstract Int64Buffer Compact();
 
         //public override bool IsDirect { get; }
 
@@ -193,9 +193,9 @@ namespace Lucene.Net.Support
         {
             if (this == obj)
                 return true;
-            if (!(obj is LongBuffer))
+            if (!(obj is Int64Buffer))
             return false;
-            LongBuffer that = (LongBuffer)obj;
+            Int64Buffer that = (Int64Buffer)obj;
             if (this.Remaining != that.Remaining)
                 return false;
             int p = this.Position;
@@ -210,7 +210,7 @@ namespace Lucene.Net.Support
             return x == y;
         }
 
-        public int CompareTo(LongBuffer other)
+        public int CompareTo(Int64Buffer other)
         {
             int n = this.Position + Math.Min(this.Remaining, other.Remaining);
             for (int i = this.Position, j = other.Position; i < n; i++, j++)
@@ -237,7 +237,10 @@ namespace Lucene.Net.Support
         public abstract ByteOrder Order { get; }
 
 
-        public class HeapLongBuffer : LongBuffer
+        /// <summary>
+        /// NOTE: This was HeapLongBuffer in the JDK
+        /// </summary>
+        public class HeapInt64Buffer : Int64Buffer
         {
             // For speed these fields are actually declared in X-Buffer;
             // these declarations are here as documentation
@@ -248,7 +251,7 @@ namespace Lucene.Net.Support
 
             */
 
-            internal HeapLongBuffer(int cap, int lim)
+            internal HeapInt64Buffer(int cap, int lim)
                 : base(-1, 0, lim, cap, new long[cap], 0)
             {
                 /*
@@ -257,7 +260,7 @@ namespace Lucene.Net.Support
                 */
             }
 
-            internal HeapLongBuffer(long[] buf, int off, int len)
+            internal HeapInt64Buffer(long[] buf, int off, int len)
                 : base(-1, off, off + len, buf.Length, buf, 0)
             {
                 /*
@@ -266,7 +269,7 @@ namespace Lucene.Net.Support
                 */
             }
 
-            protected HeapLongBuffer(long[] buf,
+            protected HeapInt64Buffer(long[] buf,
                                    int mark, int pos, int lim, int cap,
                                    int off)
                 : base(mark, pos, lim, cap, buf, off)
@@ -277,9 +280,9 @@ namespace Lucene.Net.Support
                 */
             }
 
-            public override LongBuffer Slice()
+            public override Int64Buffer Slice()
             {
-                return new HeapLongBuffer(hb,
+                return new HeapInt64Buffer(hb,
                                         -1,
                                         0,
                                         this.Remaining,
@@ -287,9 +290,9 @@ namespace Lucene.Net.Support
                                         this.Position + offset);
             }
 
-            public override LongBuffer Duplicate()
+            public override Int64Buffer Duplicate()
             {
-                return new HeapLongBuffer(hb,
+                return new HeapInt64Buffer(hb,
                                         this.MarkValue,
                                         this.Position,
                                         this.Limit,
@@ -297,7 +300,7 @@ namespace Lucene.Net.Support
                                         offset);
             }
 
-            public override LongBuffer AsReadOnlyBuffer()
+            public override Int64Buffer AsReadOnlyBuffer()
             {
                 throw new NotImplementedException();
                 //return new HeapLongBufferR(hb,
@@ -323,7 +326,7 @@ namespace Lucene.Net.Support
                 return hb[Ix(CheckIndex(index))];
             }
 
-            public override LongBuffer Get(long[] dst, int offset, int length)
+            public override Int64Buffer Get(long[] dst, int offset, int length)
             {
                 CheckBounds(offset, length, dst.Length);
                 if (length > Remaining)
@@ -350,19 +353,19 @@ namespace Lucene.Net.Support
                 }
             }
 
-            public override LongBuffer Put(long l)
+            public override Int64Buffer Put(long l)
             {
                 hb[Ix(NextPutIndex())] = l;
                 return this;
             }
 
-            public override LongBuffer Put(int index, long l)
+            public override Int64Buffer Put(int index, long l)
             {
                 hb[Ix(CheckIndex(index))] = l;
                 return this;
             }
 
-            public override LongBuffer Put(long[] src, int offset, int length)
+            public override Int64Buffer Put(long[] src, int offset, int length)
             {
 
                 CheckBounds(offset, length, src.Length);
@@ -373,13 +376,13 @@ namespace Lucene.Net.Support
                 return this;
             }
 
-            public override LongBuffer Put(LongBuffer src)
+            public override Int64Buffer Put(Int64Buffer src)
             {
 
-                if (src is HeapLongBuffer) {
+                if (src is HeapInt64Buffer) {
                     if (src == this)
                         throw new ArgumentException();
-                    HeapLongBuffer sb = (HeapLongBuffer)src;
+                    HeapInt64Buffer sb = (HeapInt64Buffer)src;
                     int n = sb.Remaining;
                     if (n > Remaining)
                         throw new BufferOverflowException();
@@ -402,7 +405,7 @@ namespace Lucene.Net.Support
                 return this;
             }
 
-            public override LongBuffer Compact()
+            public override Int64Buffer Compact()
             {
                 System.Array.Copy(hb, Ix(Position), hb, Ix(0), Remaining);
                 SetPosition(Remaining);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Support/MemoryMappedFileByteBuffer.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Support/MemoryMappedFileByteBuffer.cs b/src/Lucene.Net.Core/Support/MemoryMappedFileByteBuffer.cs
index 2d29ae7..0f9d73f 100644
--- a/src/Lucene.Net.Core/Support/MemoryMappedFileByteBuffer.cs
+++ b/src/Lucene.Net.Core/Support/MemoryMappedFileByteBuffer.cs
@@ -372,7 +372,7 @@ namespace Lucene.Net.Support
         /// <summary>
         /// NOTE: This was asLongBuffer() in the JDK
         /// </summary>
-        public override LongBuffer AsInt64Buffer()
+        public override Int64Buffer AsInt64Buffer()
         {
             throw new NotSupportedException();
         }


[38/53] [abbrv] lucenenet git commit: Added EnableHacks flag to BreakIterator tests

Posted by ni...@apache.org.
Added EnableHacks flag to BreakIterator tests


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

Branch: refs/heads/api-work
Commit: 253382fd594efd191994b3734f457cd20a513586
Parents: 34075f2
Author: Shad Storhaug <sh...@shadstorhaug.com>
Authored: Wed Feb 8 13:13:11 2017 +0700
Committer: Shad Storhaug <sh...@shadstorhaug.com>
Committed: Wed Feb 8 21:08:24 2017 +0700

----------------------------------------------------------------------
 src/Lucene.Net.Tests.Highlighter/TestBreakIterator.cs            | 2 +-
 .../VectorHighlight/BreakIteratorBoundaryScannerTest.cs          | 4 ++--
 2 files changed, 3 insertions(+), 3 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/lucenenet/blob/253382fd/src/Lucene.Net.Tests.Highlighter/TestBreakIterator.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests.Highlighter/TestBreakIterator.cs b/src/Lucene.Net.Tests.Highlighter/TestBreakIterator.cs
index 41a9875..4fa1781 100644
--- a/src/Lucene.Net.Tests.Highlighter/TestBreakIterator.cs
+++ b/src/Lucene.Net.Tests.Highlighter/TestBreakIterator.cs
@@ -37,7 +37,7 @@ namespace Lucene.Net.Search
         private BreakIterator GetWordInstance(CultureInfo locale)
         {
             //return new WordBreakIterator(locale);
-            return new IcuBreakIterator(Icu.BreakIterator.UBreakIteratorType.WORD, locale);
+            return new IcuBreakIterator(Icu.BreakIterator.UBreakIteratorType.WORD, locale) { EnableHacks = true };
         }
 
         private BreakIterator GetSentenceInstance(CultureInfo locale)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/253382fd/src/Lucene.Net.Tests.Highlighter/VectorHighlight/BreakIteratorBoundaryScannerTest.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests.Highlighter/VectorHighlight/BreakIteratorBoundaryScannerTest.cs b/src/Lucene.Net.Tests.Highlighter/VectorHighlight/BreakIteratorBoundaryScannerTest.cs
index f7d0049..71d3016 100644
--- a/src/Lucene.Net.Tests.Highlighter/VectorHighlight/BreakIteratorBoundaryScannerTest.cs
+++ b/src/Lucene.Net.Tests.Highlighter/VectorHighlight/BreakIteratorBoundaryScannerTest.cs
@@ -54,7 +54,7 @@ namespace Lucene.Net.Search.VectorHighlight
             StringBuilder text = new StringBuilder(TEXT);
             //BreakIterator bi = BreakIterator.getWordInstance(Locale.ROOT);
             //BreakIterator bi = new WordBreakIterator(CultureInfo.CurrentCulture);
-            BreakIterator bi = new IcuBreakIterator(Icu.BreakIterator.UBreakIteratorType.WORD, CultureInfo.InvariantCulture);
+            BreakIterator bi = new IcuBreakIterator(Icu.BreakIterator.UBreakIteratorType.WORD, CultureInfo.InvariantCulture) { EnableHacks = true };
             IBoundaryScanner scanner = new BreakIteratorBoundaryScanner(bi);
 
             int start = TEXT.IndexOf("formance");
@@ -71,7 +71,7 @@ namespace Lucene.Net.Search.VectorHighlight
             StringBuilder text = new StringBuilder(TEXT);
             // we test this with default locale, its randomized by LuceneTestCase
             //BreakIterator bi = BreakIterator.getSentenceInstance(Locale.getDefault());
-            BreakIterator bi = new IcuBreakIterator(Icu.BreakIterator.UBreakIteratorType.SENTENCE, CultureInfo.CurrentCulture);
+            BreakIterator bi = new IcuBreakIterator(Icu.BreakIterator.UBreakIteratorType.SENTENCE, CultureInfo.CurrentCulture) { EnableHacks = true };
             IBoundaryScanner scanner = new BreakIteratorBoundaryScanner(bi);
 
             int start = TEXT.IndexOf("any application");


[43/53] [abbrv] lucenenet git commit: SWEEP: Renamed constant and enum value names from Short, Int, Long, and Float to match CLR types Int16, Int32, Int64, and Single, respectively.

Posted by ni...@apache.org.
SWEEP: Renamed constant and enum value names from Short, Int, Long, and Float to match CLR types Int16, Int32, Int64, and Single, respectively.


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

Branch: refs/heads/api-work
Commit: 73cb5b22693ffcbbc27059d9e80fa96ccdd8d8d0
Parents: 253382f
Author: Shad Storhaug <sh...@shadstorhaug.com>
Authored: Wed Feb 8 16:35:27 2017 +0700
Committer: Shad Storhaug <sh...@shadstorhaug.com>
Committed: Wed Feb 8 21:08:24 2017 +0700

----------------------------------------------------------------------
 .../Analysis/Synonym/SynonymFilter.cs           |  4 +-
 .../CompressingStoredFieldsReader.cs            | 12 ++--
 .../CompressingStoredFieldsWriter.cs            | 36 ++++++++----
 .../Lucene45/Lucene45DocValuesProducer.cs       |  6 +-
 src/Lucene.Net.Core/Document/Field.cs           |  6 +-
 src/Lucene.Net.Core/Document/FieldType.cs       | 21 +++++--
 src/Lucene.Net.Core/Document/FloatField.cs      | 12 ++--
 src/Lucene.Net.Core/Document/IntField.cs        | 10 ++--
 src/Lucene.Net.Core/Document/LongField.cs       | 12 ++--
 src/Lucene.Net.Core/Index/BufferedUpdates.cs    | 19 ++++---
 src/Lucene.Net.Core/Index/CoalescedUpdates.cs   |  2 +-
 src/Lucene.Net.Core/Index/DocTermOrds.cs        |  2 +-
 src/Lucene.Net.Core/Index/DocValuesUpdate.cs    |  6 +-
 .../Index/DocumentsWriterDeleteQueue.cs         |  6 +-
 .../Index/DocumentsWriterPerThread.cs           |  8 +--
 .../Index/FreqProxTermsWriterPerField.cs        |  8 +--
 .../Index/FrozenBufferedUpdates.cs              |  2 +-
 .../Index/ParallelPostingsArray.cs              |  2 +-
 .../Index/SortedDocValuesWriter.cs              |  2 +-
 .../Index/SortedSetDocValuesWriter.cs           |  4 +-
 .../Index/TermVectorsConsumerPerField.cs        |  2 +-
 src/Lucene.Net.Core/Index/TermsHashPerField.cs  | 16 +++---
 src/Lucene.Net.Core/Search/CachingCollector.cs  | 14 +++--
 src/Lucene.Net.Core/Search/FieldCache.cs        | 49 +++++++++++-----
 src/Lucene.Net.Core/Search/FieldCacheImpl.cs    | 42 +++++++-------
 src/Lucene.Net.Core/Search/NumericRangeQuery.cs | 60 ++++++++++++--------
 src/Lucene.Net.Core/Search/ScoringRewrite.cs    |  2 +-
 src/Lucene.Net.Core/Search/SortField.cs         | 47 ++++++++-------
 src/Lucene.Net.Core/Util/ArrayUtil.cs           | 14 ++---
 .../Util/Automaton/SortedIntSet.cs              |  2 +-
 src/Lucene.Net.Core/Util/BytesRefArray.cs       |  4 +-
 src/Lucene.Net.Core/Util/BytesRefHash.cs        | 14 ++---
 .../Util/FieldCacheSanityChecker.cs             |  2 +-
 src/Lucene.Net.Core/Util/Fst/FST.cs             | 34 ++++++-----
 src/Lucene.Net.Core/Util/IntBlockPool.cs        | 53 ++++++++++-------
 src/Lucene.Net.Core/Util/IntsRef.cs             | 17 +++---
 src/Lucene.Net.Core/Util/LongsRef.cs            | 19 ++++---
 src/Lucene.Net.Core/Util/NumericUtils.cs        | 48 +++++++++-------
 .../Util/Packed/AbstractAppendingLongBuffer.cs  |  8 +--
 .../Util/Packed/AbstractPagedMutable.cs         |  2 +-
 src/Lucene.Net.Core/Util/Packed/Direct16.cs     |  2 +-
 src/Lucene.Net.Core/Util/Packed/Direct32.cs     |  2 +-
 src/Lucene.Net.Core/Util/Packed/Direct64.cs     |  2 +-
 src/Lucene.Net.Core/Util/Packed/Direct8.cs      |  2 +-
 .../Util/Packed/EliasFanoDecoder.cs             | 29 +++++-----
 .../Util/Packed/EliasFanoEncoder.cs             | 12 ++--
 .../Util/Packed/GrowableWriter.cs               |  4 +-
 .../Util/Packed/Packed16ThreeBlocks.cs          |  2 +-
 src/Lucene.Net.Core/Util/Packed/Packed64.cs     |  4 +-
 .../Util/Packed/Packed64SingleBlock.cs          |  2 +-
 .../Util/Packed/Packed8ThreeBlocks.cs           |  2 +-
 src/Lucene.Net.Core/Util/Packed/PackedInts.cs   |  2 +-
 .../Util/Packed/PagedGrowableWriter.cs          |  2 +-
 src/Lucene.Net.Core/Util/RamUsageEstimator.cs   | 42 +++++++++-----
 .../Util/RecyclingIntBlockAllocator.cs          | 14 ++---
 src/Lucene.Net.Core/Util/WAH8DocIdSet.cs        |  2 +-
 src/Lucene.Net.Expressions/SimpleBindings.cs    |  6 +-
 src/Lucene.Net.Memory/MemoryIndex.cs            | 12 ++--
 .../Builders/NumericRangeQueryNodeBuilder.cs    |  6 +-
 .../Standard/Nodes/NumericRangeQueryNode.cs     |  6 +-
 .../Processors/NumericQueryNodeProcessor.cs     |  6 +-
 .../NumericRangeQueryNodeProcessor.cs           |  6 +-
 .../Analyzing/AnalyzingInfixSuggester.cs        |  2 +-
 .../Index/BaseStoredFieldsFormatTestCase.cs     |  6 +-
 .../Util/ApiScanTestBase.cs                     |  5 ++
 src/Lucene.Net.TestFramework/Util/TestUtil.cs   |  6 +-
 .../TestDemoExpressions.cs                      |  2 +-
 .../TestExpressionRescorer.cs                   |  2 +-
 .../TestExpressionSortField.cs                  | 10 ++--
 .../TestExpressionSorts.cs                      | 10 ++--
 .../TestExpressionValidation.cs                 | 10 ++--
 .../TestExpressionValueSource.cs                | 16 +++---
 src/Lucene.Net.Tests.Facet/TestDrillSideways.cs |  2 +-
 .../AllGroupHeadsCollectorTest.cs               |  4 +-
 src/Lucene.Net.Tests.Grouping/TestGrouping.cs   |  2 +-
 src/Lucene.Net.Tests.Join/TestBlockJoin.cs      |  2 +-
 .../Index/Sorter/IndexSortingTest.cs            |  4 +-
 .../Index/Sorter/SortingAtomicReaderTest.cs     |  2 +-
 .../Index/Sorter/TestBlockJoinSorter.cs         |  4 +-
 .../Index/Sorter/TestEarlyTermination.cs        |  8 +--
 .../Index/Sorter/TestSortingMergePolicy.cs      |  2 +-
 .../Flexible/Standard/TestNumericQueryParser.cs | 32 +++++------
 src/Lucene.Net.Tests.Spatial/SpatialExample.cs  |  2 +-
 .../Index/TestDocumentsWriterDeleteQueue.cs     |  4 +-
 .../core/Index/TestIntBlockPool.cs              | 10 ++--
 .../core/Search/TestFieldCache.cs               |  8 +--
 .../core/Search/TestNumericRangeQuery32.cs      |  4 +-
 .../core/Search/TestNumericRangeQuery64.cs      |  4 +-
 .../core/Search/TestSearchAfter.cs              | 30 +++++-----
 .../core/Search/TestShardSearching.cs           |  2 +-
 src/Lucene.Net.Tests/core/Search/TestSort.cs    | 40 ++++++-------
 .../core/Search/TestSortDocValues.cs            | 28 ++++-----
 .../core/Search/TestSortRescorer.cs             |  4 +-
 .../core/Search/TestTopDocsMerge.cs             |  8 +--
 src/Lucene.Net.Tests/core/TestSearch.cs         |  2 +-
 .../core/TestSearchForDuplicates.cs             |  2 +-
 .../core/Util/TestFieldCacheSanityChecker.cs    |  4 +-
 src/Lucene.Net.Tests/core/Util/TestIntsRef.cs   |  2 +-
 .../core/Util/TestNumericUtils.cs               | 16 +++---
 99 files changed, 615 insertions(+), 482 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Analysis.Common/Analysis/Synonym/SynonymFilter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Analysis.Common/Analysis/Synonym/SynonymFilter.cs b/src/Lucene.Net.Analysis.Common/Analysis/Synonym/SynonymFilter.cs
index 647d8ff..052c985 100644
--- a/src/Lucene.Net.Analysis.Common/Analysis/Synonym/SynonymFilter.cs
+++ b/src/Lucene.Net.Analysis.Common/Analysis/Synonym/SynonymFilter.cs
@@ -213,13 +213,13 @@ namespace Lucene.Net.Analysis.Synonym
                 }
                 if (count == endOffsets.Length)
                 {
-                    int[] next = new int[ArrayUtil.Oversize(1 + count, RamUsageEstimator.NUM_BYTES_INT)];
+                    int[] next = new int[ArrayUtil.Oversize(1 + count, RamUsageEstimator.NUM_BYTES_INT32)];
                     Array.Copy(endOffsets, 0, next, 0, count);
                     endOffsets = next;
                 }
                 if (count == posLengths.Length)
                 {
-                    int[] next = new int[ArrayUtil.Oversize(1 + count, RamUsageEstimator.NUM_BYTES_INT)];
+                    int[] next = new int[ArrayUtil.Oversize(1 + count, RamUsageEstimator.NUM_BYTES_INT32)];
                     Array.Copy(posLengths, 0, next, 0, count);
                     posLengths = next;
                 }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Core/Codecs/Compressing/CompressingStoredFieldsReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/Compressing/CompressingStoredFieldsReader.cs b/src/Lucene.Net.Core/Codecs/Compressing/CompressingStoredFieldsReader.cs
index 6fcb5e9..48d55d8 100644
--- a/src/Lucene.Net.Core/Codecs/Compressing/CompressingStoredFieldsReader.cs
+++ b/src/Lucene.Net.Core/Codecs/Compressing/CompressingStoredFieldsReader.cs
@@ -203,15 +203,15 @@ namespace Lucene.Net.Codecs.Compressing
 #pragma warning restore 612, 618
                     break;
 
-                case CompressingStoredFieldsWriter.NUMERIC_INT:
+                case CompressingStoredFieldsWriter.NUMERIC_INT32:
                     visitor.Int32Field(info, @in.ReadInt32());
                     break;
 
-                case CompressingStoredFieldsWriter.NUMERIC_FLOAT:
+                case CompressingStoredFieldsWriter.NUMERIC_SINGLE:
                     visitor.SingleField(info, Number.Int32BitsToSingle(@in.ReadInt32()));
                     break;
 
-                case CompressingStoredFieldsWriter.NUMERIC_LONG:
+                case CompressingStoredFieldsWriter.NUMERIC_INT64:
                     visitor.Int64Field(info, @in.ReadInt64());
                     break;
 
@@ -234,12 +234,12 @@ namespace Lucene.Net.Codecs.Compressing
                     @in.SkipBytes(length);
                     break;
 
-                case CompressingStoredFieldsWriter.NUMERIC_INT:
-                case CompressingStoredFieldsWriter.NUMERIC_FLOAT:
+                case CompressingStoredFieldsWriter.NUMERIC_INT32:
+                case CompressingStoredFieldsWriter.NUMERIC_SINGLE:
                     @in.ReadInt32();
                     break;
 
-                case CompressingStoredFieldsWriter.NUMERIC_LONG:
+                case CompressingStoredFieldsWriter.NUMERIC_INT64:
                 case CompressingStoredFieldsWriter.NUMERIC_DOUBLE:
                     @in.ReadInt64();
                     break;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Core/Codecs/Compressing/CompressingStoredFieldsWriter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/Compressing/CompressingStoredFieldsWriter.cs b/src/Lucene.Net.Core/Codecs/Compressing/CompressingStoredFieldsWriter.cs
index 1097cb2..6767d26 100644
--- a/src/Lucene.Net.Core/Codecs/Compressing/CompressingStoredFieldsWriter.cs
+++ b/src/Lucene.Net.Core/Codecs/Compressing/CompressingStoredFieldsWriter.cs
@@ -38,9 +38,21 @@ namespace Lucene.Net.Codecs.Compressing
 
         internal const int STRING = 0x00;
         internal const int BYTE_ARR = 0x01;
-        internal const int NUMERIC_INT = 0x02;
-        internal const int NUMERIC_FLOAT = 0x03;
-        internal const int NUMERIC_LONG = 0x04;
+
+        /// <summary>
+        /// NOTE: This was NUMERIC_INT in Lucene
+        /// </summary>
+        internal const int NUMERIC_INT32 = 0x02;
+
+        /// <summary>
+        /// NOTE: This was NUMERIC_FLOAT in Lucene
+        /// </summary>
+        internal const int NUMERIC_SINGLE = 0x03;
+
+        /// <summary>
+        /// NOTE:This was NUMERIC_LONG in Lucene
+        /// </summary>
+        internal const int NUMERIC_INT64 = 0x04;
         internal const int NUMERIC_DOUBLE = 0x05;
 
         internal static readonly int TYPE_BITS = PackedInt32s.BitsRequired(NUMERIC_DOUBLE);
@@ -270,15 +282,15 @@ namespace Lucene.Net.Codecs.Compressing
                     double dummyDouble;
                     if (sbyte.TryParse(numStr, out dummySbyte) || short.TryParse(numStr, out dummyShort) || int.TryParse(numStr, out dummyInt))
                     {
-                        bits = NUMERIC_INT;
+                        bits = NUMERIC_INT32;
                     }
                     else if (long.TryParse(numStr, out dummyLong))
                     {
-                        bits = NUMERIC_LONG;
+                        bits = NUMERIC_INT64;
                     }
                     else if (float.TryParse(numStr, out dummyFloat))
                     {
-                        bits = NUMERIC_FLOAT;
+                        bits = NUMERIC_SINGLE;
                     }
                     else if (double.TryParse(numStr, out dummyDouble))
                     {
@@ -293,15 +305,15 @@ namespace Lucene.Net.Codecs.Compressing
                 {
                     if (number is sbyte || number is short || number is int)
                     {
-                        bits = NUMERIC_INT;
+                        bits = NUMERIC_INT32;
                     }
                     else if (number is long)
                     {
-                        bits = NUMERIC_LONG;
+                        bits = NUMERIC_INT64;
                     }
                     else if (number is float)
                     {
-                        bits = NUMERIC_FLOAT;
+                        bits = NUMERIC_SINGLE;
                     }
                     else if (number is double)
                     {
@@ -361,15 +373,15 @@ namespace Lucene.Net.Codecs.Compressing
                     if (sbyte.TryParse(numStr, out dummySbyte) || short.TryParse(numStr, out dummyShort) ||
                         int.TryParse(numStr, out dummyInt))
                     {
-                        bits = NUMERIC_INT;
+                        bits = NUMERIC_INT32;
                     }
                     else if (long.TryParse(numStr, out dummyLong))
                     {
-                        bits = NUMERIC_LONG;
+                        bits = NUMERIC_INT64;
                     }
                     else if (float.TryParse(numStr, out dummyFloat))
                     {
-                        bits = NUMERIC_FLOAT;
+                        bits = NUMERIC_SINGLE;
                     }
                     else if (double.TryParse(numStr, out dummyDouble))
                     {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Core/Codecs/Lucene45/Lucene45DocValuesProducer.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/Lucene45/Lucene45DocValuesProducer.cs b/src/Lucene.Net.Core/Codecs/Lucene45/Lucene45DocValuesProducer.cs
index a6f15d4..6626f00 100644
--- a/src/Lucene.Net.Core/Codecs/Lucene45/Lucene45DocValuesProducer.cs
+++ b/src/Lucene.Net.Core/Codecs/Lucene45/Lucene45DocValuesProducer.cs
@@ -515,7 +515,7 @@ namespace Lucene.Net.Codecs.Lucene45
                     data.Seek(bytes.AddressesOffset);
                     addrInstance = new MonotonicBlockPackedReader(data, bytes.PackedInt32sVersion, bytes.BlockSize, bytes.Count, false);
                     addressInstances[field.Number] = addrInstance;
-                    ramBytesUsed.AddAndGet(addrInstance.RamBytesUsed() + RamUsageEstimator.NUM_BYTES_INT);
+                    ramBytesUsed.AddAndGet(addrInstance.RamBytesUsed() + RamUsageEstimator.NUM_BYTES_INT32);
                 }
                 addresses = addrInstance;
             }
@@ -595,7 +595,7 @@ namespace Lucene.Net.Codecs.Lucene45
                     }
                     addrInstance = new MonotonicBlockPackedReader(data, bytes.PackedInt32sVersion, bytes.BlockSize, size, false);
                     addressInstances[field.Number] = addrInstance;
-                    ramBytesUsed.AddAndGet(addrInstance.RamBytesUsed() + RamUsageEstimator.NUM_BYTES_INT);
+                    ramBytesUsed.AddAndGet(addrInstance.RamBytesUsed() + RamUsageEstimator.NUM_BYTES_INT32);
                 }
                 addresses = addrInstance;
             }
@@ -697,7 +697,7 @@ namespace Lucene.Net.Codecs.Lucene45
                     data.Seek(entry.Offset);
                     ordIndexInstance = new MonotonicBlockPackedReader(data, entry.PackedInt32sVersion, entry.BlockSize, entry.Count, false);
                     ordIndexInstances[field.Number] = ordIndexInstance;
-                    ramBytesUsed.AddAndGet(ordIndexInstance.RamBytesUsed() + RamUsageEstimator.NUM_BYTES_INT);
+                    ramBytesUsed.AddAndGet(ordIndexInstance.RamBytesUsed() + RamUsageEstimator.NUM_BYTES_INT32);
                 }
                 ordIndex = ordIndexInstance;
             }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Core/Document/Field.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Document/Field.cs b/src/Lucene.Net.Core/Document/Field.cs
index fffd5d1..fb55704 100644
--- a/src/Lucene.Net.Core/Document/Field.cs
+++ b/src/Lucene.Net.Core/Document/Field.cs
@@ -576,15 +576,15 @@ namespace Lucene.Net.Documents
                 object val = m_fieldsData;
                 switch (numericType)
                 {
-                    case NumericType.INT:
+                    case NumericType.INT32:
                         nts.SetInt32Value(Convert.ToInt32(val));
                         break;
 
-                    case NumericType.LONG:
+                    case NumericType.INT64:
                         nts.SetInt64Value(Convert.ToInt64(val));
                         break;
 
-                    case NumericType.FLOAT:
+                    case NumericType.SINGLE:
                         nts.SetSingleValue(Convert.ToSingle(val));
                         break;
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Core/Document/FieldType.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Document/FieldType.cs b/src/Lucene.Net.Core/Document/FieldType.cs
index 065f28a..24bbc6f 100644
--- a/src/Lucene.Net.Core/Document/FieldType.cs
+++ b/src/Lucene.Net.Core/Document/FieldType.cs
@@ -406,16 +406,25 @@ namespace Lucene.Net.Documents
     public enum NumericType
     {
         /// <summary>
-        /// 32-bit integer numeric type </summary>
-        INT,
+        /// 32-bit integer numeric type
+        /// <para/>
+        /// NOTE: This was INT in Lucene
+        /// </summary>
+        INT32,
 
         /// <summary>
-        /// 64-bit long numeric type </summary>
-        LONG,
+        /// 64-bit long numeric type
+        /// <para/>
+        /// NOTE: This was LONG in Lucene
+        /// </summary>
+        INT64,
 
         /// <summary>
-        /// 32-bit float numeric type </summary>
-        FLOAT,
+        /// 32-bit float numeric type
+        /// <para/>
+        /// NOTE: This was FLOAT in Lucene
+        /// </summary>
+        SINGLE,
 
         /// <summary>
         /// 64-bit double numeric type </summary>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Core/Document/FloatField.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Document/FloatField.cs b/src/Lucene.Net.Core/Document/FloatField.cs
index 57aa6da..aecce21 100644
--- a/src/Lucene.Net.Core/Document/FloatField.cs
+++ b/src/Lucene.Net.Core/Document/FloatField.cs
@@ -52,7 +52,7 @@ namespace Lucene.Net.Documents
     /// <code>FloatField</code>, use <seealso cref="NumericRangeQuery"/> or {@link
     /// NumericRangeFilter}.  To sort according to a
     /// <code>FloatField</code>, use the normal numeric sort types, eg
-    /// <seealso cref="Lucene.Net.Search.SortField.Type#FLOAT"/>. <code>FloatField</code>
+    /// <seealso cref="Lucene.Net.Search.SortFieldType.SINGLE"/>. <code>FloatField</code>
     /// values can also be loaded directly from <seealso cref="IFieldCache"/>.</p>
     ///
     /// <p>You may add the same field name as an <code>FloatField</code> to
@@ -123,14 +123,14 @@ namespace Lucene.Net.Documents
             TYPE_NOT_STORED.IsTokenized = true;
             TYPE_NOT_STORED.OmitNorms = true;
             TYPE_NOT_STORED.IndexOptions = IndexOptions.DOCS_ONLY;
-            TYPE_NOT_STORED.NumericType = NumericType.FLOAT;
+            TYPE_NOT_STORED.NumericType = NumericType.SINGLE;
             TYPE_NOT_STORED.Freeze();
 
             TYPE_STORED.IsIndexed = true;
             TYPE_STORED.IsTokenized = true;
             TYPE_STORED.OmitNorms = true;
             TYPE_STORED.IndexOptions = IndexOptions.DOCS_ONLY;
-            TYPE_STORED.NumericType = NumericType.FLOAT;
+            TYPE_STORED.NumericType = NumericType.SINGLE;
             TYPE_STORED.IsStored = true;
             TYPE_STORED.Freeze();
         }
@@ -159,15 +159,15 @@ namespace Lucene.Net.Documents
         /// Expert: allows you to customize the {@link
         ///  FieldType}. </summary>
         ///  <param name="name"> field name </param>
-        ///  <param name="value"> 32-bit float value </param>
+        ///  <param name="value"> 32-bit <see cref="float"/> value </param>
         ///  <param name="type"> customized field type: must have <seealso cref="FieldType#numericType()"/>
-        ///         of <seealso cref="NumericType#FLOAT"/>. </param>
+        ///         of <seealso cref="NumericType.SINGLE"/>. </param>
         ///  <exception cref="IllegalArgumentException"> if the field name or type is null, or
         ///          if the field type does not have a FLOAT numericType() </exception>
         public SingleField(string name, float value, FieldType type)
             : base(name, type)
         {
-            if (type.NumericType != NumericType.FLOAT)
+            if (type.NumericType != NumericType.SINGLE)
             {
                 throw new System.ArgumentException("type.numericType() must be FLOAT but got " + type.NumericType);
             }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Core/Document/IntField.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Document/IntField.cs b/src/Lucene.Net.Core/Document/IntField.cs
index b5f2f54..1bf05f8 100644
--- a/src/Lucene.Net.Core/Document/IntField.cs
+++ b/src/Lucene.Net.Core/Document/IntField.cs
@@ -52,7 +52,7 @@ namespace Lucene.Net.Documents
     /// <code>IntField</code>, use <seealso cref="NumericRangeQuery"/> or {@link
     /// NumericRangeFilter}.  To sort according to a
     /// <code>IntField</code>, use the normal numeric sort types, eg
-    /// <seealso cref="Lucene.Net.Search.SortField.Type#INT"/>. <code>IntField</code>
+    /// <seealso cref="Lucene.Net.Search.SortFieldType.INT32"/>. <code>IntField</code>
     /// values can also be loaded directly from <seealso cref="IFieldCache"/>.</p>
     ///
     /// <p>You may add the same field name as an <code>IntField</code> to
@@ -123,14 +123,14 @@ namespace Lucene.Net.Documents
             TYPE_NOT_STORED.IsTokenized = true;
             TYPE_NOT_STORED.OmitNorms = true;
             TYPE_NOT_STORED.IndexOptions = IndexOptions.DOCS_ONLY;
-            TYPE_NOT_STORED.NumericType = NumericType.INT;
+            TYPE_NOT_STORED.NumericType = NumericType.INT32;
             TYPE_NOT_STORED.Freeze();
 
             TYPE_STORED.IsIndexed = true;
             TYPE_STORED.IsTokenized = true;
             TYPE_STORED.OmitNorms = true;
             TYPE_STORED.IndexOptions = IndexOptions.DOCS_ONLY;
-            TYPE_STORED.NumericType = NumericType.INT;
+            TYPE_STORED.NumericType = NumericType.INT32;
             TYPE_STORED.IsStored = true;
             TYPE_STORED.Freeze();
         }
@@ -161,13 +161,13 @@ namespace Lucene.Net.Documents
         ///  <param name="name"> field name </param>
         ///  <param name="value"> 32-bit integer value </param>
         ///  <param name="type"> customized field type: must have <seealso cref="FieldType#numericType()"/>
-        ///         of <seealso cref="NumericType#INT"/>. </param>
+        ///         of <seealso cref="NumericType.INT32"/>. </param>
         ///  <exception cref="IllegalArgumentException"> if the field name or type is null, or
         ///          if the field type does not have a INT numericType() </exception>
         public Int32Field(string name, int value, FieldType type)
             : base(name, type)
         {
-            if (type.NumericType != NumericType.INT)
+            if (type.NumericType != NumericType.INT32)
             {
                 throw new System.ArgumentException("type.NumericType must be INT but got " + type.NumericType);
             }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Core/Document/LongField.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Document/LongField.cs b/src/Lucene.Net.Core/Document/LongField.cs
index 8296269..b78e633 100644
--- a/src/Lucene.Net.Core/Document/LongField.cs
+++ b/src/Lucene.Net.Core/Document/LongField.cs
@@ -62,7 +62,7 @@ namespace Lucene.Net.Documents
     /// <code>LongField</code>, use <seealso cref="NumericRangeQuery"/> or {@link
     /// NumericRangeFilter}.  To sort according to a
     /// <code>LongField</code>, use the normal numeric sort types, eg
-    /// <seealso cref="Lucene.Net.Search.SortField.Type#LONG"/>. <code>LongField</code>
+    /// <seealso cref="Lucene.Net.Search.SortFieldType.INT64"/>. <code>LongField</code>
     /// values can also be loaded directly from <seealso cref="FieldCache"/>.</p>
     ///
     /// <p>You may add the same field name as an <code>LongField</code> to
@@ -133,14 +133,14 @@ namespace Lucene.Net.Documents
             TYPE_NOT_STORED.IsTokenized = true;
             TYPE_NOT_STORED.OmitNorms = true;
             TYPE_NOT_STORED.IndexOptions = IndexOptions.DOCS_ONLY;
-            TYPE_NOT_STORED.NumericType = NumericType.LONG;
+            TYPE_NOT_STORED.NumericType = NumericType.INT64;
             TYPE_NOT_STORED.Freeze();
 
             TYPE_STORED.IsIndexed = true;
             TYPE_STORED.IsTokenized = true;
             TYPE_STORED.OmitNorms = true;
             TYPE_STORED.IndexOptions = IndexOptions.DOCS_ONLY;
-            TYPE_STORED.NumericType = NumericType.LONG;
+            TYPE_STORED.NumericType = NumericType.INT64;
             TYPE_STORED.IsStored = true;
             TYPE_STORED.Freeze();
         }
@@ -169,15 +169,15 @@ namespace Lucene.Net.Documents
         /// Expert: allows you to customize the {@link
         ///  FieldType}. </summary>
         ///  <param name="name"> field name </param>
-        ///  <param name="value"> 64-bit long value </param>
+        ///  <param name="value"> 64-bit <see cref="long"/> value </param>
         ///  <param name="type"> customized field type: must have <seealso cref="FieldType#numericType()"/>
-        ///         of <seealso cref="NumericType#LONG"/>. </param>
+        ///         of <seealso cref="NumericType.INT64"/>. </param>
         ///  <exception cref="IllegalArgumentException"> if the field name or type is null, or
         ///          if the field type does not have a LONG numericType() </exception>
         public Int64Field(string name, long value, FieldType type)
             : base(name, type)
         {
-            if (type.NumericType != NumericType.LONG)
+            if (type.NumericType != NumericType.INT64)
             {
                 throw new System.ArgumentException("type.numericType() must be LONG but got " + type.NumericType);
             }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Core/Index/BufferedUpdates.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Index/BufferedUpdates.cs b/src/Lucene.Net.Core/Index/BufferedUpdates.cs
index 3f66ed5..4496998 100644
--- a/src/Lucene.Net.Core/Index/BufferedUpdates.cs
+++ b/src/Lucene.Net.Core/Index/BufferedUpdates.cs
@@ -49,19 +49,19 @@ namespace Lucene.Net.Index
            Term's text is String (OBJ_HEADER + 4*INT + POINTER +
            OBJ_HEADER + string.length*CHAR).  Integer is
            OBJ_HEADER + INT. */
-        internal static readonly int BYTES_PER_DEL_TERM = 9 * RamUsageEstimator.NUM_BYTES_OBJECT_REF + 7 * RamUsageEstimator.NUM_BYTES_OBJECT_HEADER + 10 * RamUsageEstimator.NUM_BYTES_INT;
+        internal static readonly int BYTES_PER_DEL_TERM = 9 * RamUsageEstimator.NUM_BYTES_OBJECT_REF + 7 * RamUsageEstimator.NUM_BYTES_OBJECT_HEADER + 10 * RamUsageEstimator.NUM_BYTES_INT32;
 
         /* Rough logic: del docIDs are List<Integer>.  Say list
            allocates ~2X size (2*POINTER).  Integer is OBJ_HEADER
            + int */
-        internal static readonly int BYTES_PER_DEL_DOCID = 2 * RamUsageEstimator.NUM_BYTES_OBJECT_REF + RamUsageEstimator.NUM_BYTES_OBJECT_HEADER + RamUsageEstimator.NUM_BYTES_INT;
+        internal static readonly int BYTES_PER_DEL_DOCID = 2 * RamUsageEstimator.NUM_BYTES_OBJECT_REF + RamUsageEstimator.NUM_BYTES_OBJECT_HEADER + RamUsageEstimator.NUM_BYTES_INT32;
 
         /* Rough logic: HashMap has an array[Entry] w/ varying
            load factor (say 2 * POINTER).  Entry is object w/
            Query key, Integer val, int hash, Entry next
            (OBJ_HEADER + 3*POINTER + INT).  Query we often
            undercount (say 24 bytes).  Integer is OBJ_HEADER + INT. */
-        internal static readonly int BYTES_PER_DEL_QUERY = 5 * RamUsageEstimator.NUM_BYTES_OBJECT_REF + 2 * RamUsageEstimator.NUM_BYTES_OBJECT_HEADER + 2 * RamUsageEstimator.NUM_BYTES_INT + 24;
+        internal static readonly int BYTES_PER_DEL_QUERY = 5 * RamUsageEstimator.NUM_BYTES_OBJECT_REF + 2 * RamUsageEstimator.NUM_BYTES_OBJECT_HEADER + 2 * RamUsageEstimator.NUM_BYTES_INT32 + 24;
 
         /* Rough logic: NumericUpdate calculates its actual size,
          * including the update Term and DV field (String). The
@@ -77,7 +77,7 @@ namespace Lucene.Net.Index
          * LinkedHashMap (val) is counted as OBJ_HEADER, array[Entry] ref + header, 4*INT, 1*FLOAT,
          * Set (entrySet) (2*OBJ_HEADER + ARRAY_HEADER + 2*POINTER + 4*INT + FLOAT)
          */
-        internal static readonly int BYTES_PER_NUMERIC_FIELD_ENTRY = 7 * RamUsageEstimator.NUM_BYTES_OBJECT_REF + 3 * RamUsageEstimator.NUM_BYTES_OBJECT_HEADER + RamUsageEstimator.NUM_BYTES_ARRAY_HEADER + 5 * RamUsageEstimator.NUM_BYTES_INT + RamUsageEstimator.NUM_BYTES_FLOAT;
+        internal static readonly int BYTES_PER_NUMERIC_FIELD_ENTRY = 7 * RamUsageEstimator.NUM_BYTES_OBJECT_REF + 3 * RamUsageEstimator.NUM_BYTES_OBJECT_HEADER + RamUsageEstimator.NUM_BYTES_ARRAY_HEADER + 5 * RamUsageEstimator.NUM_BYTES_INT32 + RamUsageEstimator.NUM_BYTES_SINGLE;
 
         /* Rough logic: Incremented when we see another Term for an already updated
          * field.
@@ -88,7 +88,7 @@ namespace Lucene.Net.Index
          * Term (key) is counted only as POINTER.
          * NumericUpdate (val) counts its own size and isn't accounted for here.
          */
-        internal static readonly int BYTES_PER_NUMERIC_UPDATE_ENTRY = 7 * RamUsageEstimator.NUM_BYTES_OBJECT_REF + RamUsageEstimator.NUM_BYTES_OBJECT_HEADER + RamUsageEstimator.NUM_BYTES_INT;
+        internal static readonly int BYTES_PER_NUMERIC_UPDATE_ENTRY = 7 * RamUsageEstimator.NUM_BYTES_OBJECT_REF + RamUsageEstimator.NUM_BYTES_OBJECT_HEADER + RamUsageEstimator.NUM_BYTES_INT32;
 
         /* Rough logic: BinaryUpdate calculates its actual size,
          * including the update Term and DV field (String). The
@@ -104,7 +104,7 @@ namespace Lucene.Net.Index
          * LinkedHashMap (val) is counted as OBJ_HEADER, array[Entry] ref + header, 4*INT, 1*FLOAT,
          * Set (entrySet) (2*OBJ_HEADER + ARRAY_HEADER + 2*POINTER + 4*INT + FLOAT)
          */
-        internal static readonly int BYTES_PER_BINARY_FIELD_ENTRY = 7 * RamUsageEstimator.NUM_BYTES_OBJECT_REF + 3 * RamUsageEstimator.NUM_BYTES_OBJECT_HEADER + RamUsageEstimator.NUM_BYTES_ARRAY_HEADER + 5 * RamUsageEstimator.NUM_BYTES_INT + RamUsageEstimator.NUM_BYTES_FLOAT;
+        internal static readonly int BYTES_PER_BINARY_FIELD_ENTRY = 7 * RamUsageEstimator.NUM_BYTES_OBJECT_REF + 3 * RamUsageEstimator.NUM_BYTES_OBJECT_HEADER + RamUsageEstimator.NUM_BYTES_ARRAY_HEADER + 5 * RamUsageEstimator.NUM_BYTES_INT32 + RamUsageEstimator.NUM_BYTES_SINGLE;
 
         /* Rough logic: Incremented when we see another Term for an already updated
          * field.
@@ -115,7 +115,7 @@ namespace Lucene.Net.Index
          * Term (key) is counted only as POINTER.
          * BinaryUpdate (val) counts its own size and isn't accounted for here.
          */
-        internal static readonly int BYTES_PER_BINARY_UPDATE_ENTRY = 7 * RamUsageEstimator.NUM_BYTES_OBJECT_REF + RamUsageEstimator.NUM_BYTES_OBJECT_HEADER + RamUsageEstimator.NUM_BYTES_INT;
+        internal static readonly int BYTES_PER_BINARY_UPDATE_ENTRY = 7 * RamUsageEstimator.NUM_BYTES_OBJECT_REF + RamUsageEstimator.NUM_BYTES_OBJECT_HEADER + RamUsageEstimator.NUM_BYTES_INT32;
 
         internal readonly AtomicInt32 numTermDeletes = new AtomicInt32();
         internal readonly AtomicInt32 numNumericUpdates = new AtomicInt32();
@@ -143,7 +143,10 @@ namespace Lucene.Net.Index
         // only once).
         internal readonly IDictionary<string, LinkedHashMap<Term, BinaryDocValuesUpdate>> binaryUpdates = new Dictionary<string, LinkedHashMap<Term, BinaryDocValuesUpdate>>();
 
-        public static readonly int MAX_INT = Convert.ToInt32(int.MaxValue);
+        /// <summary>
+        /// NOTE: This was MAX_INT in Lucene
+        /// </summary>
+        public static readonly int MAX_INT32 = Convert.ToInt32(int.MaxValue);
 
         internal readonly AtomicInt64 bytesUsed;
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Core/Index/CoalescedUpdates.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Index/CoalescedUpdates.cs b/src/Lucene.Net.Core/Index/CoalescedUpdates.cs
index 330cdc6..5b27296 100644
--- a/src/Lucene.Net.Core/Index/CoalescedUpdates.cs
+++ b/src/Lucene.Net.Core/Index/CoalescedUpdates.cs
@@ -48,7 +48,7 @@ namespace Lucene.Net.Index
             for (int queryIdx = 0; queryIdx < @in.queries.Length; queryIdx++)
             {
                 Query query = @in.queries[queryIdx];
-                queries[query] = BufferedUpdates.MAX_INT;
+                queries[query] = BufferedUpdates.MAX_INT32;
             }
 
             foreach (NumericDocValuesUpdate nu in @in.numericDVUpdates)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Core/Index/DocTermOrds.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Index/DocTermOrds.cs b/src/Lucene.Net.Core/Index/DocTermOrds.cs
index 6e2e076..0c087ca 100644
--- a/src/Lucene.Net.Core/Index/DocTermOrds.cs
+++ b/src/Lucene.Net.Core/Index/DocTermOrds.cs
@@ -43,7 +43,7 @@ namespace Lucene.Net.Index
     ///
     /// While normally term ords are type long, in this API they are
     /// int as the internal representation here cannot address
-    /// more than MAX_INT unique terms.  Also, typically this
+    /// more than MAX_INT32 unique terms.  Also, typically this
     /// class is used on fields with relatively few unique terms
     /// vs the number of documents.  In addition, there is an
     /// internal limit (16 MB) on how many bytes each chunk of

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Core/Index/DocValuesUpdate.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Index/DocValuesUpdate.cs b/src/Lucene.Net.Core/Index/DocValuesUpdate.cs
index 52aeef5..fa9ac1f 100644
--- a/src/Lucene.Net.Core/Index/DocValuesUpdate.cs
+++ b/src/Lucene.Net.Core/Index/DocValuesUpdate.cs
@@ -34,7 +34,7 @@ namespace Lucene.Net.Index
          * String: 2*OBJ_HEADER + 4*INT + PTR + string.length*CHAR
          * T: OBJ_HEADER
          */
-        private static readonly int RAW_SIZE_IN_BYTES = 8 * RamUsageEstimator.NUM_BYTES_OBJECT_HEADER + 8 * RamUsageEstimator.NUM_BYTES_OBJECT_REF + 8 * RamUsageEstimator.NUM_BYTES_INT;
+        private static readonly int RAW_SIZE_IN_BYTES = 8 * RamUsageEstimator.NUM_BYTES_OBJECT_HEADER + 8 * RamUsageEstimator.NUM_BYTES_OBJECT_REF + 8 * RamUsageEstimator.NUM_BYTES_INT32;
 
         internal readonly DocValuesFieldUpdates.Type type;
         internal readonly Term term;
@@ -78,7 +78,7 @@ namespace Lucene.Net.Index
         public sealed class BinaryDocValuesUpdate : DocValuesUpdate
         {
             /* Size of BytesRef: 2*INT + ARRAY_HEADER + PTR */
-            private static readonly long RAW_VALUE_SIZE_IN_BYTES = RamUsageEstimator.NUM_BYTES_ARRAY_HEADER + 2 * RamUsageEstimator.NUM_BYTES_INT + RamUsageEstimator.NUM_BYTES_OBJECT_REF;
+            private static readonly long RAW_VALUE_SIZE_IN_BYTES = RamUsageEstimator.NUM_BYTES_ARRAY_HEADER + 2 * RamUsageEstimator.NUM_BYTES_INT32 + RamUsageEstimator.NUM_BYTES_OBJECT_REF;
 
             internal static readonly BytesRef MISSING = new BytesRef();
 
@@ -106,7 +106,7 @@ namespace Lucene.Net.Index
 
             internal override long ValueSizeInBytes()
             {
-                return RamUsageEstimator.NUM_BYTES_LONG;
+                return RamUsageEstimator.NUM_BYTES_INT64;
             }
         }
     }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Core/Index/DocumentsWriterDeleteQueue.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Index/DocumentsWriterDeleteQueue.cs b/src/Lucene.Net.Core/Index/DocumentsWriterDeleteQueue.cs
index 634c0c1..4beaf41 100644
--- a/src/Lucene.Net.Core/Index/DocumentsWriterDeleteQueue.cs
+++ b/src/Lucene.Net.Core/Index/DocumentsWriterDeleteQueue.cs
@@ -224,7 +224,7 @@ namespace Lucene.Net.Index
                     if (UpdateSlice(globalSlice))
                     {
                         //          System.out.println(Thread.currentThread() + ": apply globalSlice");
-                        globalSlice.Apply(globalBufferedUpdates, BufferedUpdates.MAX_INT);
+                        globalSlice.Apply(globalBufferedUpdates, BufferedUpdates.MAX_INT32);
                     }
                 }
                 finally
@@ -255,7 +255,7 @@ namespace Lucene.Net.Index
                 if (globalSlice.sliceTail != currentTail)
                 {
                     globalSlice.sliceTail = currentTail;
-                    globalSlice.Apply(globalBufferedUpdates, BufferedUpdates.MAX_INT);
+                    globalSlice.Apply(globalBufferedUpdates, BufferedUpdates.MAX_INT32);
                 }
 
                 FrozenBufferedUpdates packet = new FrozenBufferedUpdates(globalBufferedUpdates, false);
@@ -496,7 +496,7 @@ namespace Lucene.Net.Index
                 if (globalSlice.sliceTail != currentTail)
                 {
                     globalSlice.sliceTail = currentTail;
-                    globalSlice.Apply(globalBufferedUpdates, BufferedUpdates.MAX_INT);
+                    globalSlice.Apply(globalBufferedUpdates, BufferedUpdates.MAX_INT32);
                 }
                 return globalBufferedUpdates.Any();
             }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Core/Index/DocumentsWriterPerThread.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Index/DocumentsWriterPerThread.cs b/src/Lucene.Net.Core/Index/DocumentsWriterPerThread.cs
index 56e01ec..a46ecdd 100644
--- a/src/Lucene.Net.Core/Index/DocumentsWriterPerThread.cs
+++ b/src/Lucene.Net.Core/Index/DocumentsWriterPerThread.cs
@@ -713,7 +713,7 @@ namespace Lucene.Net.Index
             private readonly Counter bytesUsed;
 
             public Int32BlockAllocator(Counter bytesUsed)
-                : base(Int32BlockPool.INT_BLOCK_SIZE)
+                : base(Int32BlockPool.INT32_BLOCK_SIZE)
             {
                 this.bytesUsed = bytesUsed;
             }
@@ -722,14 +722,14 @@ namespace Lucene.Net.Index
 
             public override int[] GetInt32Block()
             {
-                int[] b = new int[Int32BlockPool.INT_BLOCK_SIZE];
-                bytesUsed.AddAndGet(Int32BlockPool.INT_BLOCK_SIZE * RamUsageEstimator.NUM_BYTES_INT);
+                int[] b = new int[Int32BlockPool.INT32_BLOCK_SIZE];
+                bytesUsed.AddAndGet(Int32BlockPool.INT32_BLOCK_SIZE * RamUsageEstimator.NUM_BYTES_INT32);
                 return b;
             }
 
             public override void RecycleInt32Blocks(int[][] blocks, int offset, int length)
             {
-                bytesUsed.AddAndGet(-(length * (Int32BlockPool.INT_BLOCK_SIZE * RamUsageEstimator.NUM_BYTES_INT)));
+                bytesUsed.AddAndGet(-(length * (Int32BlockPool.INT32_BLOCK_SIZE * RamUsageEstimator.NUM_BYTES_INT32)));
             }
         }
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Core/Index/FreqProxTermsWriterPerField.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Index/FreqProxTermsWriterPerField.cs b/src/Lucene.Net.Core/Index/FreqProxTermsWriterPerField.cs
index 1ab3f51..b3bfdc5 100644
--- a/src/Lucene.Net.Core/Index/FreqProxTermsWriterPerField.cs
+++ b/src/Lucene.Net.Core/Index/FreqProxTermsWriterPerField.cs
@@ -364,18 +364,18 @@ namespace Lucene.Net.Index
 
             internal override int BytesPerPosting()
             {
-                int bytes = ParallelPostingsArray.BYTES_PER_POSTING + 2 * RamUsageEstimator.NUM_BYTES_INT;
+                int bytes = ParallelPostingsArray.BYTES_PER_POSTING + 2 * RamUsageEstimator.NUM_BYTES_INT32;
                 if (lastPositions != null)
                 {
-                    bytes += RamUsageEstimator.NUM_BYTES_INT;
+                    bytes += RamUsageEstimator.NUM_BYTES_INT32;
                 }
                 if (lastOffsets != null)
                 {
-                    bytes += RamUsageEstimator.NUM_BYTES_INT;
+                    bytes += RamUsageEstimator.NUM_BYTES_INT32;
                 }
                 if (termFreqs != null)
                 {
-                    bytes += RamUsageEstimator.NUM_BYTES_INT;
+                    bytes += RamUsageEstimator.NUM_BYTES_INT32;
                 }
 
                 return bytes;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Core/Index/FrozenBufferedUpdates.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Index/FrozenBufferedUpdates.cs b/src/Lucene.Net.Core/Index/FrozenBufferedUpdates.cs
index 1d9ecff..571fdb3 100644
--- a/src/Lucene.Net.Core/Index/FrozenBufferedUpdates.cs
+++ b/src/Lucene.Net.Core/Index/FrozenBufferedUpdates.cs
@@ -39,7 +39,7 @@ namespace Lucene.Net.Index
     internal class FrozenBufferedUpdates
     {
         /* Query we often undercount (say 24 bytes), plus int. */
-        internal static readonly int BYTES_PER_DEL_QUERY = RamUsageEstimator.NUM_BYTES_OBJECT_REF + RamUsageEstimator.NUM_BYTES_INT + 24;
+        internal static readonly int BYTES_PER_DEL_QUERY = RamUsageEstimator.NUM_BYTES_OBJECT_REF + RamUsageEstimator.NUM_BYTES_INT32 + 24;
 
         // Terms, in sorted order:
         internal readonly PrefixCodedTerms terms;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Core/Index/ParallelPostingsArray.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Index/ParallelPostingsArray.cs b/src/Lucene.Net.Core/Index/ParallelPostingsArray.cs
index 6feef8f..dc1b314 100644
--- a/src/Lucene.Net.Core/Index/ParallelPostingsArray.cs
+++ b/src/Lucene.Net.Core/Index/ParallelPostingsArray.cs
@@ -24,7 +24,7 @@ namespace Lucene.Net.Index
 
     internal class ParallelPostingsArray
     {
-        internal static readonly int BYTES_PER_POSTING = 3 * RamUsageEstimator.NUM_BYTES_INT;
+        internal static readonly int BYTES_PER_POSTING = 3 * RamUsageEstimator.NUM_BYTES_INT32;
 
         internal readonly int size;
         internal readonly int[] textStarts;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Core/Index/SortedDocValuesWriter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Index/SortedDocValuesWriter.cs b/src/Lucene.Net.Core/Index/SortedDocValuesWriter.cs
index 881de17..6473a00 100644
--- a/src/Lucene.Net.Core/Index/SortedDocValuesWriter.cs
+++ b/src/Lucene.Net.Core/Index/SortedDocValuesWriter.cs
@@ -93,7 +93,7 @@ namespace Lucene.Net.Index
                 // 1. when indexing, when hash is 50% full, rehash() suddenly needs 2*size ints.
                 //    TODO: can this same OOM happen in THPF?
                 // 2. when flushing, we need 1 int per value (slot in the ordMap).
-                iwBytesUsed.AddAndGet(2 * RamUsageEstimator.NUM_BYTES_INT);
+                iwBytesUsed.AddAndGet(2 * RamUsageEstimator.NUM_BYTES_INT32);
             }
 
             pending.Add(termID);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Core/Index/SortedSetDocValuesWriter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Index/SortedSetDocValuesWriter.cs b/src/Lucene.Net.Core/Index/SortedSetDocValuesWriter.cs
index a0515ec..d892a34 100644
--- a/src/Lucene.Net.Core/Index/SortedSetDocValuesWriter.cs
+++ b/src/Lucene.Net.Core/Index/SortedSetDocValuesWriter.cs
@@ -136,7 +136,7 @@ namespace Lucene.Net.Index
                 // 1. when indexing, when hash is 50% full, rehash() suddenly needs 2*size ints.
                 //    TODO: can this same OOM happen in THPF?
                 // 2. when flushing, we need 1 int per value (slot in the ordMap).
-                iwBytesUsed.AddAndGet(2 * RamUsageEstimator.NUM_BYTES_INT);
+                iwBytesUsed.AddAndGet(2 * RamUsageEstimator.NUM_BYTES_INT32);
             }
 
             if (currentUpto == currentValues.Length)
@@ -144,7 +144,7 @@ namespace Lucene.Net.Index
                 currentValues = ArrayUtil.Grow(currentValues, currentValues.Length + 1);
                 // reserve additional space for max # values per-doc
                 // when flushing, we need an int[] to sort the mapped-ords within the doc
-                iwBytesUsed.AddAndGet((currentValues.Length - currentUpto) * 2 * RamUsageEstimator.NUM_BYTES_INT);
+                iwBytesUsed.AddAndGet((currentValues.Length - currentUpto) * 2 * RamUsageEstimator.NUM_BYTES_INT32);
             }
 
             currentValues[currentUpto] = termID;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Core/Index/TermVectorsConsumerPerField.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Index/TermVectorsConsumerPerField.cs b/src/Lucene.Net.Core/Index/TermVectorsConsumerPerField.cs
index bec57fb..13128b3 100644
--- a/src/Lucene.Net.Core/Index/TermVectorsConsumerPerField.cs
+++ b/src/Lucene.Net.Core/Index/TermVectorsConsumerPerField.cs
@@ -358,7 +358,7 @@ namespace Lucene.Net.Index
 
             internal override int BytesPerPosting()
             {
-                return base.BytesPerPosting() + 3 * RamUsageEstimator.NUM_BYTES_INT;
+                return base.BytesPerPosting() + 3 * RamUsageEstimator.NUM_BYTES_INT32;
             }
         }
     }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Core/Index/TermsHashPerField.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Index/TermsHashPerField.cs b/src/Lucene.Net.Core/Index/TermsHashPerField.cs
index 649be47..dac6c81 100644
--- a/src/Lucene.Net.Core/Index/TermsHashPerField.cs
+++ b/src/Lucene.Net.Core/Index/TermsHashPerField.cs
@@ -112,8 +112,8 @@ namespace Lucene.Net.Index
         {
             Debug.Assert(stream < streamCount);
             int intStart = postingsArray.intStarts[termID];
-            int[] ints = intPool.Buffers[intStart >> Int32BlockPool.INT_BLOCK_SHIFT];
-            int upto = intStart & Int32BlockPool.INT_BLOCK_MASK;
+            int[] ints = intPool.Buffers[intStart >> Int32BlockPool.INT32_BLOCK_SHIFT];
+            int upto = intStart & Int32BlockPool.INT32_BLOCK_MASK;
             reader.Init(bytePool, postingsArray.byteStarts[termID] + stream * ByteBlockPool.FIRST_LEVEL_SIZE, ints[upto + stream]);
         }
 
@@ -160,7 +160,7 @@ namespace Lucene.Net.Index
                 // First time we are seeing this token since we last
                 // flushed the hash.
                 // Init stream slices
-                if (numPostingInt + intPool.Int32Upto > Int32BlockPool.INT_BLOCK_SIZE)
+                if (numPostingInt + intPool.Int32Upto > Int32BlockPool.INT32_BLOCK_SIZE)
                 {
                     intPool.NextBuffer();
                 }
@@ -189,8 +189,8 @@ namespace Lucene.Net.Index
             {
                 termID = (-termID) - 1;
                 int intStart = postingsArray.intStarts[termID];
-                intUptos = intPool.Buffers[intStart >> Int32BlockPool.INT_BLOCK_SHIFT];
-                intUptoStart = intStart & Int32BlockPool.INT_BLOCK_MASK;
+                intUptos = intPool.Buffers[intStart >> Int32BlockPool.INT32_BLOCK_SHIFT];
+                intUptoStart = intStart & Int32BlockPool.INT32_BLOCK_MASK;
                 consumer.AddTerm(termID);
             }
         }
@@ -235,7 +235,7 @@ namespace Lucene.Net.Index
             {
                 bytesHash.ByteStart(termID);
                 // Init stream slices
-                if (numPostingInt + intPool.Int32Upto > Int32BlockPool.INT_BLOCK_SIZE)
+                if (numPostingInt + intPool.Int32Upto > Int32BlockPool.INT32_BLOCK_SIZE)
                 {
                     intPool.NextBuffer();
                 }
@@ -264,8 +264,8 @@ namespace Lucene.Net.Index
             {
                 termID = (-termID) - 1;
                 int intStart = postingsArray.intStarts[termID];
-                intUptos = intPool.Buffers[intStart >> Int32BlockPool.INT_BLOCK_SHIFT];
-                intUptoStart = intStart & Int32BlockPool.INT_BLOCK_MASK;
+                intUptos = intPool.Buffers[intStart >> Int32BlockPool.INT32_BLOCK_SHIFT];
+                intUptoStart = intStart & Int32BlockPool.INT32_BLOCK_MASK;
                 consumer.AddTerm(termID);
             }
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Core/Search/CachingCollector.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Search/CachingCollector.cs b/src/Lucene.Net.Core/Search/CachingCollector.cs
index dff66c6..ebce3e4 100644
--- a/src/Lucene.Net.Core/Search/CachingCollector.cs
+++ b/src/Lucene.Net.Core/Search/CachingCollector.cs
@@ -52,7 +52,11 @@ namespace Lucene.Net.Search
         private const int MAX_ARRAY_SIZE = 512 * 1024;
 
         private const int INITIAL_ARRAY_SIZE = 128;
-        private static readonly int[] EMPTY_INT_ARRAY = new int[0];
+
+        /// <summary>
+        /// NOTE: This was EMPTY_INT_ARRAY in Lucene
+        /// </summary>
+        private static readonly int[] EMPTY_INT32_ARRAY = new int[0];
 
         private class SegStart
         {
@@ -202,7 +206,7 @@ namespace Lucene.Net.Search
                 int curUpto = 0;
                 int curBase = 0;
                 int chunkUpto = 0;
-                m_curDocs = EMPTY_INT_ARRAY;
+                m_curDocs = EMPTY_INT32_ARRAY;
                 foreach (SegStart seg in m_cachedSegs)
                 {
                     other.SetNextReader(seg.ReaderContext);
@@ -309,7 +313,7 @@ namespace Lucene.Net.Search
                 int curUpto = 0;
                 int curbase = 0;
                 int chunkUpto = 0;
-                m_curDocs = EMPTY_INT_ARRAY;
+                m_curDocs = EMPTY_INT32_ARRAY;
                 foreach (SegStart seg in m_cachedSegs)
                 {
                     other.SetNextReader(seg.ReaderContext);
@@ -448,10 +452,10 @@ namespace Lucene.Net.Search
             m_curDocs = new int[INITIAL_ARRAY_SIZE];
             m_cachedDocs.Add(m_curDocs);
 
-            int bytesPerDoc = RamUsageEstimator.NUM_BYTES_INT;
+            int bytesPerDoc = RamUsageEstimator.NUM_BYTES_INT32;
             if (cacheScores)
             {
-                bytesPerDoc += RamUsageEstimator.NUM_BYTES_FLOAT;
+                bytesPerDoc += RamUsageEstimator.NUM_BYTES_SINGLE;
             }
             m_maxDocsToCache = (int)((maxRAMMB * 1024 * 1024) / bytesPerDoc);
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Core/Search/FieldCache.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Search/FieldCache.cs b/src/Lucene.Net.Core/Search/FieldCache.cs
index 4e082ea..bb34675 100644
--- a/src/Lucene.Net.Core/Search/FieldCache.cs
+++ b/src/Lucene.Net.Core/Search/FieldCache.cs
@@ -572,7 +572,10 @@ namespace Lucene.Net.Search
             }
         }
 
-        public static readonly IInt16Parser DEFAULT_SHORT_PARSER = new AnonymousInt16Parser(); // LUCENENET TODO: Rename DEFAULT_INT16_PARSER
+        /// <summary>
+        /// NOTE: This was DEFAULT_SHORT_PARSER in Lucene
+        /// </summary>
+        public static readonly IInt16Parser DEFAULT_INT16_PARSER = new AnonymousInt16Parser();
 
 
         private sealed class AnonymousInt16Parser : IInt16Parser
@@ -591,7 +594,7 @@ namespace Lucene.Net.Search
 
             public override string ToString()
             {
-                return typeof(IFieldCache).FullName + ".DEFAULT_SHORT_PARSER"; // LUCENENET TODO: Rename DEFAULT_INT16_PARSER
+                return typeof(IFieldCache).FullName + ".DEFAULT_INT16_PARSER";
             }
 
             public TermsEnum TermsEnum(Terms terms)
@@ -600,7 +603,10 @@ namespace Lucene.Net.Search
             }
         }
 
-        public static readonly IInt32Parser DEFAULT_INT_PARSER = new AnonymousInt32Parser(); // LUCENENET TODO: Rename DEFAULT_INT32_PARSER
+        /// <summary>
+        /// NOTE: This was DEFAULT_INT_PARSER in Lucene
+        /// </summary>
+        public static readonly IInt32Parser DEFAULT_INT32_PARSER = new AnonymousInt32Parser();
 
         private sealed class AnonymousInt32Parser : IInt32Parser
         {
@@ -623,11 +629,14 @@ namespace Lucene.Net.Search
 
             public override string ToString()
             {
-                return typeof(IFieldCache).FullName + ".DEFAULT_INT_PARSER"; // LUCENENET TODO: Rename DEFAULT_INT32_PARSER
+                return typeof(IFieldCache).FullName + ".DEFAULT_INT32_PARSER";
             }
         }
 
-        public static readonly ISingleParser DEFAULT_FLOAT_PARSER = new AnonymousSingleParser();  // LUCENENET TODO: Rename DEFAULT_SINGLE_PARSER
+        /// <summary>
+        /// NOTE: This was DEFAULT_FLOAT_PARSER in Lucene
+        /// </summary>
+        public static readonly ISingleParser DEFAULT_SINGLE_PARSER = new AnonymousSingleParser();
 
         private sealed class AnonymousSingleParser : ISingleParser
         {
@@ -654,11 +663,14 @@ namespace Lucene.Net.Search
 
             public override string ToString()
             {
-                return typeof(IFieldCache).FullName + ".DEFAULT_FLOAT_PARSER"; // LUCENENET TODO: Rename DEFAULT_SINGLE_PARSER
+                return typeof(IFieldCache).FullName + ".DEFAULT_SINGLE_PARSER";
             }
         }
 
-        public static readonly IInt64Parser DEFAULT_LONG_PARSER = new AnonymousInt64Parser(); // LUCENENET TODO: Rename DEFAULT_INT64_PARSER
+        /// <summary>
+        /// NOTE: This was DEFAULT_LONG_PARSER in Lucene
+        /// </summary>
+        public static readonly IInt64Parser DEFAULT_INT64_PARSER = new AnonymousInt64Parser();
 
         private sealed class AnonymousInt64Parser : IInt64Parser
         {
@@ -681,7 +693,7 @@ namespace Lucene.Net.Search
 
             public override string ToString()
             {
-                return typeof(IFieldCache).FullName + ".DEFAULT_LONG_PARSER"; // LUCENENET TODO: Rename DEFAULT_INT64_PARSER
+                return typeof(IFieldCache).FullName + ".DEFAULT_INT64_PARSER";
             }
         }
 
@@ -709,7 +721,10 @@ namespace Lucene.Net.Search
             }
         }
 
-        public static readonly IInt32Parser NUMERIC_UTILS_INT_PARSER = new AnonymousNumericUtilsInt32Parser(); // LUCENENET TODO: Rename NUMERIC_UTILS_INT32_PARSER
+        /// <summary>
+        /// NOTE: This was NUMERIC_UTILS_INT_PARSER in Lucene
+        /// </summary>
+        public static readonly IInt32Parser NUMERIC_UTILS_INT32_PARSER = new AnonymousNumericUtilsInt32Parser();
 
         private sealed class AnonymousNumericUtilsInt32Parser : IInt32Parser
         {
@@ -728,11 +743,14 @@ namespace Lucene.Net.Search
 
             public override string ToString()
             {
-                return typeof(IFieldCache).FullName + ".NUMERIC_UTILS_INT_PARSER";
+                return typeof(IFieldCache).FullName + ".NUMERIC_UTILS_INT32_PARSER";
             }
         }
 
-        public static readonly ISingleParser NUMERIC_UTILS_FLOAT_PARSER = new AnonymousNumericUtilsSingleParser(); // LUCENENET TODO: Rename NUMERIC_UTILS_SINGLE_PARSER
+        /// <summary>
+        /// NOTE: This was NUMERIC_UTILS_FLOAT_PARSER in Lucene
+        /// </summary>
+        public static readonly ISingleParser NUMERIC_UTILS_SINGLE_PARSER = new AnonymousNumericUtilsSingleParser();
 
         private sealed class AnonymousNumericUtilsSingleParser : ISingleParser
         {
@@ -746,7 +764,7 @@ namespace Lucene.Net.Search
 
             public override string ToString()
             {
-                return typeof(IFieldCache).FullName + ".NUMERIC_UTILS_FLOAT_PARSER";
+                return typeof(IFieldCache).FullName + ".NUMERIC_UTILS_SINGLE_PARSER";
             }
 
             public TermsEnum TermsEnum(Terms terms)
@@ -755,7 +773,10 @@ namespace Lucene.Net.Search
             }
         }
 
-        public static readonly IInt64Parser NUMERIC_UTILS_LONG_PARSER = new AnonymousNumericUtilsInt64Parser(); // LUCENENET TODO: Rename NUMERIC_UTILS_INT64_PARSER
+        /// <summary>
+        /// NOTE: This was NUMERIC_UTILS_LONG_PARSER in Lucene
+        /// </summary>
+        public static readonly IInt64Parser NUMERIC_UTILS_INT64_PARSER = new AnonymousNumericUtilsInt64Parser();
 
         private sealed class AnonymousNumericUtilsInt64Parser : IInt64Parser
         {
@@ -769,7 +790,7 @@ namespace Lucene.Net.Search
 
             public override string ToString()
             {
-                return typeof(IFieldCache).FullName + ".NUMERIC_UTILS_LONG_PARSER";
+                return typeof(IFieldCache).FullName + ".NUMERIC_UTILS_INT64_PARSER";
             }
 
             public TermsEnum TermsEnum(Terms terms)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Core/Search/FieldCacheImpl.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Search/FieldCacheImpl.cs b/src/Lucene.Net.Core/Search/FieldCacheImpl.cs
index 8891e73..d2857c0 100644
--- a/src/Lucene.Net.Core/Search/FieldCacheImpl.cs
+++ b/src/Lucene.Net.Core/Search/FieldCacheImpl.cs
@@ -555,8 +555,8 @@ namespace Lucene.Net.Search
                 if (parser == null)
                 {
                     // Confusing: must delegate to wrapper (vs simply
-                    // setting parser = DEFAULT_SHORT_PARSER) so cache
-                    // key includes DEFAULT_SHORT_PARSER:
+                    // setting parser = DEFAULT_INT16_PARSER) so cache
+                    // key includes DEFAULT_INT16_PARSER:
                     return wrapper.GetBytes(reader, key.field, FieldCache.DEFAULT_BYTE_PARSER, setDocsWithField);
                 }
 
@@ -699,9 +699,9 @@ namespace Lucene.Net.Search
                 if (parser == null)
                 {
                     // Confusing: must delegate to wrapper (vs simply
-                    // setting parser = DEFAULT_SHORT_PARSER) so cache
-                    // key includes DEFAULT_SHORT_PARSER:
-                    return wrapper.GetInt16s(reader, key.field, FieldCache.DEFAULT_SHORT_PARSER, setDocsWithField);
+                    // setting parser = DEFAULT_INT16_PARSER) so cache
+                    // key includes DEFAULT_INT16_PARSER:
+                    return wrapper.GetInt16s(reader, key.field, FieldCache.DEFAULT_INT16_PARSER, setDocsWithField);
                 }
 
                 values = new short[maxDoc];
@@ -873,16 +873,16 @@ namespace Lucene.Net.Search
                 {
                     // Confusing: must delegate to wrapper (vs simply
                     // setting parser =
-                    // DEFAULT_INT_PARSER/NUMERIC_UTILS_INT_PARSER) so
+                    // DEFAULT_INT32_PARSER/NUMERIC_UTILS_INT32_PARSER) so
                     // cache key includes
-                    // DEFAULT_INT_PARSER/NUMERIC_UTILS_INT_PARSER:
+                    // DEFAULT_INT32_PARSER/NUMERIC_UTILS_INT32_PARSER:
                     try
                     {
-                        return wrapper.GetInt32s(reader, key.field, FieldCache.DEFAULT_INT_PARSER, setDocsWithField);
+                        return wrapper.GetInt32s(reader, key.field, FieldCache.DEFAULT_INT32_PARSER, setDocsWithField);
                     }
                     catch (System.FormatException)
                     {
-                        return wrapper.GetInt32s(reader, key.field, FieldCache.NUMERIC_UTILS_INT_PARSER, setDocsWithField);
+                        return wrapper.GetInt32s(reader, key.field, FieldCache.NUMERIC_UTILS_INT32_PARSER, setDocsWithField);
                     }
                 }
 
@@ -931,7 +931,7 @@ namespace Lucene.Net.Search
                     {
                         // Lazy alloc so for the numeric field case
                         // (which will hit a System.FormatException
-                        // when we first try the DEFAULT_INT_PARSER),
+                        // when we first try the DEFAULT_INT32_PARSER),
                         // we don't double-alloc:
                         int startBitsPerValue;
                         // Make sure than missing values (0) can be stored without resizing
@@ -1144,16 +1144,16 @@ namespace Lucene.Net.Search
                 {
                     // Confusing: must delegate to wrapper (vs simply
                     // setting parser =
-                    // DEFAULT_FLOAT_PARSER/NUMERIC_UTILS_FLOAT_PARSER) so
+                    // DEFAULT_SINGLE_PARSER/NUMERIC_UTILS_SINGLE_PARSER) so
                     // cache key includes
-                    // DEFAULT_FLOAT_PARSER/NUMERIC_UTILS_FLOAT_PARSER:
+                    // DEFAULT_SINGLE_PARSER/NUMERIC_UTILS_SINGLE_PARSER:
                     try
                     {
-                        return wrapper.GetSingles(reader, key.field, FieldCache.DEFAULT_FLOAT_PARSER, setDocsWithField);
+                        return wrapper.GetSingles(reader, key.field, FieldCache.DEFAULT_SINGLE_PARSER, setDocsWithField);
                     }
                     catch (System.FormatException)
                     {
-                        return wrapper.GetSingles(reader, key.field, FieldCache.NUMERIC_UTILS_FLOAT_PARSER, setDocsWithField);
+                        return wrapper.GetSingles(reader, key.field, FieldCache.NUMERIC_UTILS_SINGLE_PARSER, setDocsWithField);
                     }
                 }
 
@@ -1202,7 +1202,7 @@ namespace Lucene.Net.Search
                     {
                         // Lazy alloc so for the numeric field case
                         // (which will hit a System.FormatException
-                        // when we first try the DEFAULT_INT_PARSER),
+                        // when we first try the DEFAULT_INT32_PARSER),
                         // we don't double-alloc:
                         values = new float[reader.MaxDoc];
                         valuesRef.Set(values);
@@ -1315,16 +1315,16 @@ namespace Lucene.Net.Search
                 {
                     // Confusing: must delegate to wrapper (vs simply
                     // setting parser =
-                    // DEFAULT_LONG_PARSER/NUMERIC_UTILS_LONG_PARSER) so
+                    // DEFAULT_INT64_PARSER/NUMERIC_UTILS_INT64_PARSER) so
                     // cache key includes
-                    // DEFAULT_LONG_PARSER/NUMERIC_UTILS_LONG_PARSER:
+                    // DEFAULT_INT64_PARSER/NUMERIC_UTILS_INT64_PARSER:
                     try
                     {
-                        return wrapper.GetInt64s(reader, key.field, FieldCache.DEFAULT_LONG_PARSER, setDocsWithField);
+                        return wrapper.GetInt64s(reader, key.field, FieldCache.DEFAULT_INT64_PARSER, setDocsWithField);
                     }
                     catch (System.FormatException)
                     {
-                        return wrapper.GetInt64s(reader, key.field, FieldCache.NUMERIC_UTILS_LONG_PARSER, setDocsWithField);
+                        return wrapper.GetInt64s(reader, key.field, FieldCache.NUMERIC_UTILS_INT64_PARSER, setDocsWithField);
                     }
                 }
 
@@ -1373,7 +1373,7 @@ namespace Lucene.Net.Search
                     {
                         // Lazy alloc so for the numeric field case
                         // (which will hit a System.FormatException
-                        // when we first try the DEFAULT_INT_PARSER),
+                        // when we first try the DEFAULT_INT32_PARSER),
                         // we don't double-alloc:
                         int startBitsPerValue;
                         // Make sure than missing values (0) can be stored without resizing
@@ -1545,7 +1545,7 @@ namespace Lucene.Net.Search
                     {
                         // Lazy alloc so for the numeric field case
                         // (which will hit a System.FormatException
-                        // when we first try the DEFAULT_INT_PARSER),
+                        // when we first try the DEFAULT_INT32_PARSER),
                         // we don't double-alloc:
                         values = new double[reader.MaxDoc];
                         valuesRef.Set(values);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Core/Search/NumericRangeQuery.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Search/NumericRangeQuery.cs b/src/Lucene.Net.Core/Search/NumericRangeQuery.cs
index 08a86c4..684f07d 100644
--- a/src/Lucene.Net.Core/Search/NumericRangeQuery.cs
+++ b/src/Lucene.Net.Core/Search/NumericRangeQuery.cs
@@ -287,11 +287,25 @@ namespace Lucene.Net.Search
         internal readonly bool minInclusive, maxInclusive;
 
         // used to handle float/double infinity correcty
-        internal static readonly long LONG_NEGATIVE_INFINITY = NumericUtils.DoubleToSortableInt64(double.NegativeInfinity);
+        /// <summary>
+        /// NOTE: This was LONG_NEGATIVE_INFINITY in Lucene
+        /// </summary>
+        internal static readonly long INT64_NEGATIVE_INFINITY = NumericUtils.DoubleToSortableInt64(double.NegativeInfinity);
+
+        /// <summary>
+        /// NOTE: This was LONG_NEGATIVE_INFINITY in Lucene
+        /// </summary>
+        internal static readonly long INT64_POSITIVE_INFINITY = NumericUtils.DoubleToSortableInt64(double.PositiveInfinity);
 
-        internal static readonly long LONG_POSITIVE_INFINITY = NumericUtils.DoubleToSortableInt64(double.PositiveInfinity);
-        internal static readonly int INT_NEGATIVE_INFINITY = NumericUtils.SingleToSortableInt32(float.NegativeInfinity);
-        internal static readonly int INT_POSITIVE_INFINITY = NumericUtils.SingleToSortableInt32(float.PositiveInfinity);
+        /// <summary>
+        /// NOTE: This was INT_NEGATIVE_INFINITY in Lucene
+        /// </summary>
+        internal static readonly int INT32_NEGATIVE_INFINITY = NumericUtils.SingleToSortableInt32(float.NegativeInfinity);
+
+        /// <summary>
+        /// NOTE: This was INT_POSITIVE_INFINITY in Lucene
+        /// </summary>
+        internal static readonly int INT32_POSITIVE_INFINITY = NumericUtils.SingleToSortableInt32(float.PositiveInfinity);
 
         /// <summary>
         /// Subclass of FilteredTermsEnum for enumerating all terms that match the
@@ -318,19 +332,19 @@ namespace Lucene.Net.Search
                 this.outerInstance = outerInstance;
                 switch (this.outerInstance.dataType)
                 {
-                    case NumericType.LONG:
+                    case NumericType.INT64:
                     case NumericType.DOUBLE:
                         {
                             // lower
                             long minBound;
-                            if (this.outerInstance.dataType == NumericType.LONG)
+                            if (this.outerInstance.dataType == NumericType.INT64)
                             {
                                 minBound = (this.outerInstance.min == null) ? long.MinValue : Convert.ToInt64(this.outerInstance.min.Value);
                             }
                             else
                             {
                                 Debug.Assert(this.outerInstance.dataType == NumericType.DOUBLE);
-                                minBound = (this.outerInstance.min == null) ? LONG_NEGATIVE_INFINITY : NumericUtils.DoubleToSortableInt64(Convert.ToDouble(this.outerInstance.min.Value));
+                                minBound = (this.outerInstance.min == null) ? INT64_NEGATIVE_INFINITY : NumericUtils.DoubleToSortableInt64(Convert.ToDouble(this.outerInstance.min.Value));
                             }
                             if (!this.outerInstance.minInclusive && this.outerInstance.min != null)
                             {
@@ -343,14 +357,14 @@ namespace Lucene.Net.Search
 
                             // upper
                             long maxBound;
-                            if (this.outerInstance.dataType == NumericType.LONG)
+                            if (this.outerInstance.dataType == NumericType.INT64)
                             {
                                 maxBound = (this.outerInstance.max == null) ? long.MaxValue : Convert.ToInt64(this.outerInstance.max);
                             }
                             else
                             {
                                 Debug.Assert(this.outerInstance.dataType == NumericType.DOUBLE);
-                                maxBound = (this.outerInstance.max == null) ? LONG_POSITIVE_INFINITY : NumericUtils.DoubleToSortableInt64(Convert.ToDouble(this.outerInstance.max));
+                                maxBound = (this.outerInstance.max == null) ? INT64_POSITIVE_INFINITY : NumericUtils.DoubleToSortableInt64(Convert.ToDouble(this.outerInstance.max));
                             }
                             if (!this.outerInstance.maxInclusive && this.outerInstance.max != null)
                             {
@@ -365,19 +379,19 @@ namespace Lucene.Net.Search
                             break;
                         }
 
-                    case NumericType.INT:
-                    case NumericType.FLOAT:
+                    case NumericType.INT32:
+                    case NumericType.SINGLE:
                         {
                             // lower
                             int minBound;
-                            if (this.outerInstance.dataType == NumericType.INT)
+                            if (this.outerInstance.dataType == NumericType.INT32)
                             {
                                 minBound = (this.outerInstance.min == null) ? int.MinValue : Convert.ToInt32(this.outerInstance.min);
                             }
                             else
                             {
-                                Debug.Assert(this.outerInstance.dataType == NumericType.FLOAT);
-                                minBound = (this.outerInstance.min == null) ? INT_NEGATIVE_INFINITY : NumericUtils.SingleToSortableInt32(Convert.ToSingle(this.outerInstance.min));
+                                Debug.Assert(this.outerInstance.dataType == NumericType.SINGLE);
+                                minBound = (this.outerInstance.min == null) ? INT32_NEGATIVE_INFINITY : NumericUtils.SingleToSortableInt32(Convert.ToSingle(this.outerInstance.min));
                             }
                             if (!this.outerInstance.minInclusive && this.outerInstance.min != null)
                             {
@@ -390,14 +404,14 @@ namespace Lucene.Net.Search
 
                             // upper
                             int maxBound;
-                            if (this.outerInstance.dataType == NumericType.INT)
+                            if (this.outerInstance.dataType == NumericType.INT32)
                             {
                                 maxBound = (this.outerInstance.max == null) ? int.MaxValue : Convert.ToInt32(this.outerInstance.max);
                             }
                             else
                             {
-                                Debug.Assert(this.outerInstance.dataType == NumericType.FLOAT);
-                                maxBound = (this.outerInstance.max == null) ? INT_POSITIVE_INFINITY : NumericUtils.SingleToSortableInt32(Convert.ToSingle(this.outerInstance.max));
+                                Debug.Assert(this.outerInstance.dataType == NumericType.SINGLE);
+                                maxBound = (this.outerInstance.max == null) ? INT32_POSITIVE_INFINITY : NumericUtils.SingleToSortableInt32(Convert.ToSingle(this.outerInstance.max));
                             }
                             if (!this.outerInstance.maxInclusive && this.outerInstance.max != null)
                             {
@@ -519,7 +533,7 @@ namespace Lucene.Net.Search
         /// </summary>
         public static NumericRangeQuery<long> NewInt64Range(string field, int precisionStep, long? min, long? max, bool minInclusive, bool maxInclusive)
         {
-            return new NumericRangeQuery<long>(field, precisionStep, NumericType.LONG, min, max, minInclusive, maxInclusive);
+            return new NumericRangeQuery<long>(field, precisionStep, NumericType.INT64, min, max, minInclusive, maxInclusive);
         }
 
         /// <summary>
@@ -533,7 +547,7 @@ namespace Lucene.Net.Search
         /// </summary>
         public static NumericRangeQuery<long> NewInt64Range(string field, long? min, long? max, bool minInclusive, bool maxInclusive)
         {
-            return new NumericRangeQuery<long>(field, NumericUtils.PRECISION_STEP_DEFAULT, NumericType.LONG, min, max, minInclusive, maxInclusive);
+            return new NumericRangeQuery<long>(field, NumericUtils.PRECISION_STEP_DEFAULT, NumericType.INT64, min, max, minInclusive, maxInclusive);
         }
 
         /// <summary>
@@ -547,7 +561,7 @@ namespace Lucene.Net.Search
         /// </summary>
         public static NumericRangeQuery<int> NewInt32Range(string field, int precisionStep, int? min, int? max, bool minInclusive, bool maxInclusive)
         {
-            return new NumericRangeQuery<int>(field, precisionStep, NumericType.INT, min, max, minInclusive, maxInclusive);
+            return new NumericRangeQuery<int>(field, precisionStep, NumericType.INT32, min, max, minInclusive, maxInclusive);
         }
 
         /// <summary>
@@ -561,7 +575,7 @@ namespace Lucene.Net.Search
         /// </summary>
         public static NumericRangeQuery<int> NewInt32Range(string field, int? min, int? max, bool minInclusive, bool maxInclusive)
         {
-            return new NumericRangeQuery<int>(field, NumericUtils.PRECISION_STEP_DEFAULT, NumericType.INT, min, max, minInclusive, maxInclusive);
+            return new NumericRangeQuery<int>(field, NumericUtils.PRECISION_STEP_DEFAULT, NumericType.INT32, min, max, minInclusive, maxInclusive);
         }
 
         /// <summary>
@@ -605,7 +619,7 @@ namespace Lucene.Net.Search
         /// </summary>
         public static NumericRangeQuery<float> NewSingleRange(string field, int precisionStep, float? min, float? max, bool minInclusive, bool maxInclusive)
         {
-            return new NumericRangeQuery<float>(field, precisionStep, NumericType.FLOAT, min, max, minInclusive, maxInclusive);
+            return new NumericRangeQuery<float>(field, precisionStep, NumericType.SINGLE, min, max, minInclusive, maxInclusive);
         }
 
         /// <summary>
@@ -621,7 +635,7 @@ namespace Lucene.Net.Search
         /// </summary>
         public static NumericRangeQuery<float> NewSingleRange(string field, float? min, float? max, bool minInclusive, bool maxInclusive)
         {
-            return new NumericRangeQuery<float>(field, NumericUtils.PRECISION_STEP_DEFAULT, NumericType.FLOAT, min, max, minInclusive, maxInclusive);
+            return new NumericRangeQuery<float>(field, NumericUtils.PRECISION_STEP_DEFAULT, NumericType.SINGLE, min, max, minInclusive, maxInclusive);
         }
     }
 }
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Core/Search/ScoringRewrite.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Search/ScoringRewrite.cs b/src/Lucene.Net.Core/Search/ScoringRewrite.cs
index 480209d..17d7c56 100644
--- a/src/Lucene.Net.Core/Search/ScoringRewrite.cs
+++ b/src/Lucene.Net.Core/Search/ScoringRewrite.cs
@@ -207,7 +207,7 @@ namespace Lucene.Net.Search
             public override int[] Init()
             {
                 int[] ord = base.Init();
-                boost = new float[ArrayUtil.Oversize(ord.Length, RamUsageEstimator.NUM_BYTES_FLOAT)];
+                boost = new float[ArrayUtil.Oversize(ord.Length, RamUsageEstimator.NUM_BYTES_SINGLE)];
                 termState = new TermContext[ArrayUtil.Oversize(ord.Length, RamUsageEstimator.NUM_BYTES_OBJECT_REF)];
                 Debug.Assert(termState.Length >= ord.Length && boost.Length >= ord.Length);
                 return ord;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Core/Search/SortField.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Search/SortField.cs b/src/Lucene.Net.Core/Search/SortField.cs
index f0c9d7a..46ddb35 100644
--- a/src/Lucene.Net.Core/Search/SortField.cs
+++ b/src/Lucene.Net.Core/Search/SortField.cs
@@ -67,9 +67,9 @@ namespace Lucene.Net.Search
                     }
                 }
 #pragma warning disable 612, 618
-                else if (type != SortFieldType.BYTE && type != SortFieldType.SHORT
+                else if (type != SortFieldType.BYTE && type != SortFieldType.INT16
 #pragma warning restore 612, 618
-                    && type != SortFieldType.INT && type != SortFieldType.FLOAT && type != SortFieldType.LONG && type != SortFieldType.DOUBLE)
+                    && type != SortFieldType.INT32 && type != SortFieldType.SINGLE && type != SortFieldType.INT64 && type != SortFieldType.DOUBLE)
                 {
                     throw new System.ArgumentException("Missing value only works for numeric or STRING types");
                 }
@@ -132,16 +132,16 @@ namespace Lucene.Net.Search
         {
             if (parser is FieldCache.IInt32Parser)
             {
-                InitFieldType(field, SortFieldType.INT);
+                InitFieldType(field, SortFieldType.INT32);
             }
             else if (parser is FieldCache.ISingleParser)
             {
-                InitFieldType(field, SortFieldType.FLOAT);
+                InitFieldType(field, SortFieldType.SINGLE);
             }
             else if (parser is FieldCache.IInt16Parser)
             {
 #pragma warning disable 612, 618
-                InitFieldType(field, SortFieldType.SHORT);
+                InitFieldType(field, SortFieldType.INT16);
             }
             else if (parser is FieldCache.IByteParser)
             {
@@ -150,7 +150,7 @@ namespace Lucene.Net.Search
             }
             else if (parser is FieldCache.IInt64Parser)
             {
-                InitFieldType(field, SortFieldType.LONG);
+                InitFieldType(field, SortFieldType.INT64);
             }
             else if (parser is FieldCache.IDoubleParser)
             {
@@ -272,7 +272,8 @@ namespace Lucene.Net.Search
 
         /// <summary>
         /// Returns the type of contents in the field. </summary>
-        /// <returns> One of the constants SCORE, DOC, STRING, INT or FLOAT. </returns>
+        /// <returns> One of <see cref="SortFieldType.SCORE"/>, <see cref="SortFieldType.DOC"/>, 
+        /// <see cref="SortFieldType.STRING"/>, <see cref="SortFieldType.INT32"/> or <see cref="SortFieldType.SINGLE"/>. </returns>
         public virtual SortFieldType Type
         {
             get
@@ -342,20 +343,20 @@ namespace Lucene.Net.Search
                     buffer.Append("<byte: \"").Append(field).Append("\">");
                     break;
 
-                case SortFieldType.SHORT:
+                case SortFieldType.INT16:
 #pragma warning restore 612, 618
                     buffer.Append("<short: \"").Append(field).Append("\">");
                     break;
 
-                case SortFieldType.INT:
+                case SortFieldType.INT32:
                     buffer.Append("<int" + ": \"").Append(field).Append("\">");
                     break;
 
-                case SortFieldType.LONG:
+                case SortFieldType.INT64:
                     buffer.Append("<long: \"").Append(field).Append("\">");
                     break;
 
-                case SortFieldType.FLOAT:
+                case SortFieldType.SINGLE:
                     buffer.Append("<float" + ": \"").Append(field).Append("\">");
                     break;
 
@@ -466,13 +467,13 @@ namespace Lucene.Net.Search
                 case SortFieldType.DOC:
                     return new FieldComparer.DocComparer(numHits);
 
-                case SortFieldType.INT:
+                case SortFieldType.INT32:
                     return new FieldComparer.Int32Comparer(numHits, field, parser, (int?)m_missingValue);
 
-                case SortFieldType.FLOAT:
+                case SortFieldType.SINGLE:
                     return new FieldComparer.SingleComparer(numHits, field, parser, (float?)m_missingValue);
 
-                case SortFieldType.LONG:
+                case SortFieldType.INT64:
                     return new FieldComparer.Int64Comparer(numHits, field, parser, (long?)m_missingValue);
 
                 case SortFieldType.DOUBLE:
@@ -482,7 +483,7 @@ namespace Lucene.Net.Search
                 case SortFieldType.BYTE:
                     return new FieldComparer.ByteComparer(numHits, field, parser, (sbyte?)m_missingValue);
 
-                case SortFieldType.SHORT:
+                case SortFieldType.INT16:
                     return new FieldComparer.Int16Comparer(numHits, field, parser, (short?)m_missingValue);
 #pragma warning restore 612, 618
 
@@ -553,20 +554,26 @@ namespace Lucene.Net.Search
         /// <summary>
         /// Sort using term values as encoded Integers.  Sort values are Integer and
         /// lower values are at the front.
+        /// <para/>
+        /// NOTE: This was INT in Lucene
         /// </summary>
-        INT, // LUCENENET TODO: Rename to INT32 ?
+        INT32,
 
         /// <summary>
         /// Sort using term values as encoded Floats.  Sort values are Float and
         /// lower values are at the front.
+        /// <para/>
+        /// NOTE: This was FLOAT in Lucene
         /// </summary>
-        FLOAT, // LUCENENET TODO: Rename to SINGLE ?
+        SINGLE,
 
         /// <summary>
         /// Sort using term values as encoded Longs.  Sort values are Long and
         /// lower values are at the front.
+        /// <para/>
+        /// NOTE: This was LONG in Lucene
         /// </summary>
-        LONG,  // LUCENENET TODO: Rename to INT64 ?
+        INT64,
 
         /// <summary>
         /// Sort using term values as encoded Doubles.  Sort values are Double and
@@ -577,9 +584,11 @@ namespace Lucene.Net.Search
         /// <summary>
         /// Sort using term values as encoded Shorts.  Sort values are Short and
         /// lower values are at the front.
+        /// <para/>
+        /// NOTE: This was SHORT in Lucene
         /// </summary>
         [System.Obsolete]
-        SHORT, // LUCENENET TODO: Rename to INT16 ?
+        INT16,
 
         /// <summary>
         /// Sort using a custom Comparer.  Sort values are any Comparable and

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Core/Util/ArrayUtil.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/ArrayUtil.cs b/src/Lucene.Net.Core/Util/ArrayUtil.cs
index 474bb64..9fc79e0 100644
--- a/src/Lucene.Net.Core/Util/ArrayUtil.cs
+++ b/src/Lucene.Net.Core/Util/ArrayUtil.cs
@@ -278,7 +278,7 @@ namespace Lucene.Net.Util
             Debug.Assert(minSize >= 0, "size must be positive (got " + minSize + "): likely integer overflow?");
             if (array.Length < minSize)
             {
-                short[] newArray = new short[Oversize(minSize, RamUsageEstimator.NUM_BYTES_SHORT)];
+                short[] newArray = new short[Oversize(minSize, RamUsageEstimator.NUM_BYTES_INT16)];
                 Array.Copy(array, 0, newArray, 0, array.Length);
                 return newArray;
             }
@@ -298,7 +298,7 @@ namespace Lucene.Net.Util
             Debug.Assert(minSize >= 0, "size must be positive (got " + minSize + "): likely integer overflow?");
             if (array.Length < minSize)
             {
-                float[] newArray = new float[Oversize(minSize, RamUsageEstimator.NUM_BYTES_FLOAT)];
+                float[] newArray = new float[Oversize(minSize, RamUsageEstimator.NUM_BYTES_SINGLE)];
                 Array.Copy(array, 0, newArray, 0, array.Length);
                 return newArray;
             }
@@ -336,7 +336,7 @@ namespace Lucene.Net.Util
         public static short[] Shrink(short[] array, int targetSize)
         {
             Debug.Assert(targetSize >= 0, "size must be positive (got " + targetSize + "): likely integer overflow?");
-            int newSize = GetShrinkSize(array.Length, targetSize, RamUsageEstimator.NUM_BYTES_SHORT);
+            int newSize = GetShrinkSize(array.Length, targetSize, RamUsageEstimator.NUM_BYTES_INT16);
             if (newSize != array.Length)
             {
                 short[] newArray = new short[newSize];
@@ -354,7 +354,7 @@ namespace Lucene.Net.Util
             Debug.Assert(minSize >= 0, "size must be positive (got " + minSize + "): likely integer overflow?");
             if (array.Length < minSize)
             {
-                int[] newArray = new int[Oversize(minSize, RamUsageEstimator.NUM_BYTES_INT)];
+                int[] newArray = new int[Oversize(minSize, RamUsageEstimator.NUM_BYTES_INT32)];
                 Array.Copy(array, 0, newArray, 0, array.Length);
                 return newArray;
             }
@@ -372,7 +372,7 @@ namespace Lucene.Net.Util
         public static int[] Shrink(int[] array, int targetSize)
         {
             Debug.Assert(targetSize >= 0, "size must be positive (got " + targetSize + "): likely integer overflow?");
-            int newSize = GetShrinkSize(array.Length, targetSize, RamUsageEstimator.NUM_BYTES_INT);
+            int newSize = GetShrinkSize(array.Length, targetSize, RamUsageEstimator.NUM_BYTES_INT32);
             if (newSize != array.Length)
             {
                 int[] newArray = new int[newSize];
@@ -390,7 +390,7 @@ namespace Lucene.Net.Util
             Debug.Assert(minSize >= 0, "size must be positive (got " + minSize + "): likely integer overflow?");
             if (array.Length < minSize)
             {
-                long[] newArray = new long[Oversize(minSize, RamUsageEstimator.NUM_BYTES_LONG)];
+                long[] newArray = new long[Oversize(minSize, RamUsageEstimator.NUM_BYTES_INT64)];
                 Array.Copy(array, 0, newArray, 0, array.Length);
                 return newArray;
             }
@@ -408,7 +408,7 @@ namespace Lucene.Net.Util
         public static long[] Shrink(long[] array, int targetSize)
         {
             Debug.Assert(targetSize >= 0, "size must be positive (got " + targetSize + "): likely integer overflow?");
-            int newSize = GetShrinkSize(array.Length, targetSize, RamUsageEstimator.NUM_BYTES_LONG);
+            int newSize = GetShrinkSize(array.Length, targetSize, RamUsageEstimator.NUM_BYTES_INT64);
             if (newSize != array.Length)
             {
                 long[] newArray = new long[newSize];


[29/53] [abbrv] lucenenet git commit: Lucene.Net.Core: Renamed all type-derived classes and interfaces from Short, Int, Long, and Float to match CLR types Int16, Int32, Int64, and Single, respectively.

Posted by ni...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Codecs/Compressing/CompressingTermVectorsReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/Compressing/CompressingTermVectorsReader.cs b/src/Lucene.Net.Core/Codecs/Compressing/CompressingTermVectorsReader.cs
index af107da..12cd209 100644
--- a/src/Lucene.Net.Core/Codecs/Compressing/CompressingTermVectorsReader.cs
+++ b/src/Lucene.Net.Core/Codecs/Compressing/CompressingTermVectorsReader.cs
@@ -260,7 +260,7 @@ namespace Lucene.Net.Codecs.Compressing
                     totalDistinctFields += vectorsStream.ReadVInt32();
                 }
                 ++totalDistinctFields;
-                PackedInts.IReaderIterator it = PackedInts.GetReaderIteratorNoHeader(vectorsStream, PackedInts.Format.PACKED, packedIntsVersion, totalDistinctFields, bitsPerFieldNum, 1);
+                PackedInt32s.IReaderIterator it = PackedInt32s.GetReaderIteratorNoHeader(vectorsStream, PackedInt32s.Format.PACKED, packedIntsVersion, totalDistinctFields, bitsPerFieldNum, 1);
                 fieldNums = new int[totalDistinctFields];
                 for (int i = 0; i < totalDistinctFields; ++i)
                 {
@@ -270,15 +270,15 @@ namespace Lucene.Net.Codecs.Compressing
 
             // read field numbers and flags
             int[] fieldNumOffs = new int[numFields];
-            PackedInts.Reader flags;
+            PackedInt32s.Reader flags;
             {
-                int bitsPerOff = PackedInts.BitsRequired(fieldNums.Length - 1);
-                PackedInts.Reader allFieldNumOffs = PackedInts.GetReaderNoHeader(vectorsStream, PackedInts.Format.PACKED, packedIntsVersion, totalFields, bitsPerOff);
+                int bitsPerOff = PackedInt32s.BitsRequired(fieldNums.Length - 1);
+                PackedInt32s.Reader allFieldNumOffs = PackedInt32s.GetReaderNoHeader(vectorsStream, PackedInt32s.Format.PACKED, packedIntsVersion, totalFields, bitsPerOff);
                 switch (vectorsStream.ReadVInt32())
                 {
                     case 0:
-                        PackedInts.Reader fieldFlags = PackedInts.GetReaderNoHeader(vectorsStream, PackedInts.Format.PACKED, packedIntsVersion, fieldNums.Length, CompressingTermVectorsWriter.FLAGS_BITS);
-                        PackedInts.Mutable f = PackedInts.GetMutable(totalFields, CompressingTermVectorsWriter.FLAGS_BITS, PackedInts.COMPACT);
+                        PackedInt32s.Reader fieldFlags = PackedInt32s.GetReaderNoHeader(vectorsStream, PackedInt32s.Format.PACKED, packedIntsVersion, fieldNums.Length, CompressingTermVectorsWriter.FLAGS_BITS);
+                        PackedInt32s.Mutable f = PackedInt32s.GetMutable(totalFields, CompressingTermVectorsWriter.FLAGS_BITS, PackedInt32s.COMPACT);
                         for (int i = 0; i < totalFields; ++i)
                         {
                             int fieldNumOff = (int)allFieldNumOffs.Get(i);
@@ -290,7 +290,7 @@ namespace Lucene.Net.Codecs.Compressing
                         break;
 
                     case 1:
-                        flags = PackedInts.GetReaderNoHeader(vectorsStream, PackedInts.Format.PACKED, packedIntsVersion, totalFields, CompressingTermVectorsWriter.FLAGS_BITS);
+                        flags = PackedInt32s.GetReaderNoHeader(vectorsStream, PackedInt32s.Format.PACKED, packedIntsVersion, totalFields, CompressingTermVectorsWriter.FLAGS_BITS);
                         break;
 
                     default:
@@ -303,11 +303,11 @@ namespace Lucene.Net.Codecs.Compressing
             }
 
             // number of terms per field for all fields
-            PackedInts.Reader numTerms;
+            PackedInt32s.Reader numTerms;
             int totalTerms;
             {
                 int bitsRequired = vectorsStream.ReadVInt32();
-                numTerms = PackedInts.GetReaderNoHeader(vectorsStream, PackedInts.Format.PACKED, packedIntsVersion, totalFields, bitsRequired);
+                numTerms = PackedInt32s.GetReaderNoHeader(vectorsStream, PackedInt32s.Format.PACKED, packedIntsVersion, totalFields, bitsRequired);
                 int sum = 0;
                 for (int i = 0; i < totalFields; ++i)
                 {
@@ -338,7 +338,7 @@ namespace Lucene.Net.Codecs.Compressing
                     prefixLengths[i] = fieldPrefixLengths;
                     for (int j = 0; j < termCount; )
                     {
-                        LongsRef next = reader.Next(termCount - j);
+                        Int64sRef next = reader.Next(termCount - j);
                         for (int k = 0; k < next.Length; ++k)
                         {
                             fieldPrefixLengths[j++] = (int)next.Int64s[next.Offset + k];
@@ -364,7 +364,7 @@ namespace Lucene.Net.Codecs.Compressing
                     suffixLengths[i] = fieldSuffixLengths;
                     for (int j = 0; j < termCount; )
                     {
-                        LongsRef next = reader.Next(termCount - j);
+                        Int64sRef next = reader.Next(termCount - j);
                         for (int k = 0; k < next.Length; ++k)
                         {
                             fieldSuffixLengths[j++] = (int)next.Int64s[next.Offset + k];
@@ -389,7 +389,7 @@ namespace Lucene.Net.Codecs.Compressing
                 reader.Reset(vectorsStream, totalTerms);
                 for (int i = 0; i < totalTerms; )
                 {
-                    LongsRef next = reader.Next(totalTerms - i);
+                    Int64sRef next = reader.Next(totalTerms - i);
                     for (int k = 0; k < next.Length; ++k)
                     {
                         termFreqs[i++] = 1 + (int)next.Int64s[next.Offset + k];
@@ -619,7 +619,7 @@ namespace Lucene.Net.Codecs.Compressing
         }
 
         // field -> term index -> position index
-        private int[][] PositionIndex(int skip, int numFields, PackedInts.Reader numTerms, int[] termFreqs)
+        private int[][] PositionIndex(int skip, int numFields, PackedInt32s.Reader numTerms, int[] termFreqs)
         {
             int[][] positionIndex = new int[numFields][];
             int termIndex = 0;
@@ -642,7 +642,7 @@ namespace Lucene.Net.Codecs.Compressing
             return positionIndex;
         }
 
-        private int[][] ReadPositions(int skip, int numFields, PackedInts.Reader flags, PackedInts.Reader numTerms, int[] termFreqs, int flag, int totalPositions, int[][] positionIndex)
+        private int[][] ReadPositions(int skip, int numFields, PackedInt32s.Reader flags, PackedInt32s.Reader numTerms, int[] termFreqs, int flag, int totalPositions, int[][] positionIndex)
         {
             int[][] positions = new int[numFields][];
             reader.Reset(vectorsStream, totalPositions);
@@ -676,7 +676,7 @@ namespace Lucene.Net.Codecs.Compressing
                     positions[i] = fieldPositions;
                     for (int j = 0; j < totalFreq; )
                     {
-                        LongsRef nextPositions = reader.Next(totalFreq - j);
+                        Int64sRef nextPositions = reader.Next(totalFreq - j);
                         for (int k = 0; k < nextPositions.Length; ++k)
                         {
                             fieldPositions[j++] = (int)nextPositions.Int64s[nextPositions.Offset + k];

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Codecs/Compressing/CompressingTermVectorsWriter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/Compressing/CompressingTermVectorsWriter.cs b/src/Lucene.Net.Core/Codecs/Compressing/CompressingTermVectorsWriter.cs
index 275ca91..956b9f7 100644
--- a/src/Lucene.Net.Core/Codecs/Compressing/CompressingTermVectorsWriter.cs
+++ b/src/Lucene.Net.Core/Codecs/Compressing/CompressingTermVectorsWriter.cs
@@ -42,7 +42,7 @@ namespace Lucene.Net.Codecs.Compressing
     using IOContext = Lucene.Net.Store.IOContext;
     using IOUtils = Lucene.Net.Util.IOUtils;
     using MergeState = Lucene.Net.Index.MergeState;
-    using PackedInts = Lucene.Net.Util.Packed.PackedInts;
+    using PackedInt32s = Lucene.Net.Util.Packed.PackedInt32s;
     using SegmentInfo = Lucene.Net.Index.SegmentInfo;
     using SegmentReader = Lucene.Net.Index.SegmentReader;
     using StringHelper = Lucene.Net.Util.StringHelper;
@@ -71,7 +71,7 @@ namespace Lucene.Net.Codecs.Compressing
         internal const int POSITIONS = 0x01;
         internal const int OFFSETS = 0x02;
         internal const int PAYLOADS = 0x04;
-        internal static readonly int FLAGS_BITS = PackedInts.BitsRequired(POSITIONS | OFFSETS | PAYLOADS);
+        internal static readonly int FLAGS_BITS = PackedInt32s.BitsRequired(POSITIONS | OFFSETS | PAYLOADS);
 
         private readonly Directory directory;
         private readonly string segment;
@@ -268,7 +268,7 @@ namespace Lucene.Net.Codecs.Compressing
                 indexWriter = new CompressingStoredFieldsIndexWriter(indexStream);
                 indexStream = null;
 
-                vectorsStream.WriteVInt32(PackedInts.VERSION_CURRENT);
+                vectorsStream.WriteVInt32(PackedInt32s.VERSION_CURRENT);
                 vectorsStream.WriteVInt32(chunkSize);
                 writer = new BlockPackedWriter(vectorsStream, BLOCK_SIZE);
 
@@ -455,14 +455,14 @@ namespace Lucene.Net.Codecs.Compressing
 
             int numDistinctFields = fieldNums.Count;
             Debug.Assert(numDistinctFields > 0);
-            int bitsRequired = PackedInts.BitsRequired(fieldNums.Last());
+            int bitsRequired = PackedInt32s.BitsRequired(fieldNums.Last());
             int token = (Math.Min(numDistinctFields - 1, 0x07) << 5) | bitsRequired;
             vectorsStream.WriteByte((byte)(sbyte)token);
             if (numDistinctFields - 1 >= 0x07)
             {
                 vectorsStream.WriteVInt32(numDistinctFields - 1 - 0x07);
             }
-            PackedInts.Writer writer = PackedInts.GetWriterNoHeader(vectorsStream, PackedInts.Format.PACKED, fieldNums.Count, bitsRequired, 1);
+            PackedInt32s.Writer writer = PackedInt32s.GetWriterNoHeader(vectorsStream, PackedInt32s.Format.PACKED, fieldNums.Count, bitsRequired, 1);
             foreach (int fieldNum in fieldNums)
             {
                 writer.Add(fieldNum);
@@ -480,7 +480,7 @@ namespace Lucene.Net.Codecs.Compressing
 
         private void FlushFields(int totalFields, int[] fieldNums)
         {
-            PackedInts.Writer writer = PackedInts.GetWriterNoHeader(vectorsStream, PackedInts.Format.PACKED, totalFields, PackedInts.BitsRequired(fieldNums.Length - 1), 1);
+            PackedInt32s.Writer writer = PackedInt32s.GetWriterNoHeader(vectorsStream, PackedInt32s.Format.PACKED, totalFields, PackedInt32s.BitsRequired(fieldNums.Length - 1), 1);
             foreach (DocData dd in pendingDocs)
             {
                 foreach (FieldData fd in dd.fields)
@@ -525,7 +525,7 @@ namespace Lucene.Net.Codecs.Compressing
             {
                 // write one flag per field num
                 vectorsStream.WriteVInt32(0);
-                PackedInts.Writer writer = PackedInts.GetWriterNoHeader(vectorsStream, PackedInts.Format.PACKED, fieldFlags.Length, FLAGS_BITS, 1);
+                PackedInt32s.Writer writer = PackedInt32s.GetWriterNoHeader(vectorsStream, PackedInt32s.Format.PACKED, fieldFlags.Length, FLAGS_BITS, 1);
                 foreach (int flags in fieldFlags)
                 {
                     Debug.Assert(flags >= 0);
@@ -538,7 +538,7 @@ namespace Lucene.Net.Codecs.Compressing
             {
                 // write one flag for every field instance
                 vectorsStream.WriteVInt32(1);
-                PackedInts.Writer writer = PackedInts.GetWriterNoHeader(vectorsStream, PackedInts.Format.PACKED, totalFields, FLAGS_BITS, 1);
+                PackedInt32s.Writer writer = PackedInt32s.GetWriterNoHeader(vectorsStream, PackedInt32s.Format.PACKED, totalFields, FLAGS_BITS, 1);
                 foreach (DocData dd in pendingDocs)
                 {
                     foreach (FieldData fd in dd.fields)
@@ -561,9 +561,9 @@ namespace Lucene.Net.Codecs.Compressing
                     maxNumTerms |= fd.numTerms;
                 }
             }
-            int bitsRequired = PackedInts.BitsRequired(maxNumTerms);
+            int bitsRequired = PackedInt32s.BitsRequired(maxNumTerms);
             vectorsStream.WriteVInt32(bitsRequired);
-            PackedInts.Writer writer = PackedInts.GetWriterNoHeader(vectorsStream, PackedInts.Format.PACKED, totalFields, bitsRequired, 1);
+            PackedInt32s.Writer writer = PackedInt32s.GetWriterNoHeader(vectorsStream, PackedInt32s.Format.PACKED, totalFields, bitsRequired, 1);
             foreach (DocData dd in pendingDocs)
             {
                 foreach (FieldData fd in dd.fields)
@@ -884,7 +884,7 @@ namespace Lucene.Net.Codecs.Compressing
                 int maxDoc = reader.MaxDoc;
                 IBits liveDocs = reader.LiveDocs;
 
-                if (matchingVectorsReader == null || matchingVectorsReader.Version != VERSION_CURRENT || matchingVectorsReader.CompressionMode != compressionMode || matchingVectorsReader.ChunkSize != chunkSize || matchingVectorsReader.PackedInt32sVersion != PackedInts.VERSION_CURRENT)
+                if (matchingVectorsReader == null || matchingVectorsReader.Version != VERSION_CURRENT || matchingVectorsReader.CompressionMode != compressionMode || matchingVectorsReader.ChunkSize != chunkSize || matchingVectorsReader.PackedInt32sVersion != PackedInt32s.VERSION_CURRENT)
                 {
                     // naive merge...
                     for (int i = NextLiveDoc(0, liveDocs, maxDoc); i < maxDoc; i = NextLiveDoc(i + 1, liveDocs, maxDoc))

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Codecs/Compressing/LZ4.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/Compressing/LZ4.cs b/src/Lucene.Net.Core/Codecs/Compressing/LZ4.cs
index b4316bb..cf05994 100644
--- a/src/Lucene.Net.Core/Codecs/Compressing/LZ4.cs
+++ b/src/Lucene.Net.Core/Codecs/Compressing/LZ4.cs
@@ -23,7 +23,7 @@ namespace Lucene.Net.Codecs.Compressing
 
     using DataInput = Lucene.Net.Store.DataInput;
     using DataOutput = Lucene.Net.Store.DataOutput;
-    using PackedInts = Lucene.Net.Util.Packed.PackedInts;
+    using PackedInt32s = Lucene.Net.Util.Packed.PackedInt32s;
 
     /// <summary>
     /// LZ4 compression and decompression routines.
@@ -222,16 +222,16 @@ namespace Lucene.Net.Codecs.Compressing
         public sealed class HashTable
         {
             internal int hashLog;
-            internal PackedInts.Mutable hashTable;
+            internal PackedInt32s.Mutable hashTable;
 
             internal void Reset(int len)
             {
-                int bitsPerOffset = PackedInts.BitsRequired(len - LAST_LITERALS);
+                int bitsPerOffset = PackedInt32s.BitsRequired(len - LAST_LITERALS);
                 int bitsPerOffsetLog = 32 - Number.NumberOfLeadingZeros(bitsPerOffset - 1);
                 hashLog = MEMORY_USAGE + 3 - bitsPerOffsetLog;
                 if (hashTable == null || hashTable.Count < 1 << hashLog || hashTable.BitsPerValue < bitsPerOffset)
                 {
-                    hashTable = PackedInts.GetMutable(1 << hashLog, bitsPerOffset, PackedInts.DEFAULT);
+                    hashTable = PackedInt32s.GetMutable(1 << hashLog, bitsPerOffset, PackedInt32s.DEFAULT);
                 }
                 else
                 {
@@ -258,7 +258,7 @@ namespace Lucene.Net.Codecs.Compressing
                 int matchLimit = limit - MIN_MATCH;
                 ht.Reset(len);
                 int hashLog = ht.hashLog;
-                PackedInts.Mutable hashTable = ht.hashTable;
+                PackedInt32s.Mutable hashTable = ht.hashTable;
 
                 while (off <= limit)
                 {
@@ -273,7 +273,7 @@ namespace Lucene.Net.Codecs.Compressing
                         int v = ReadInt32(bytes, off);
                         int h = Hash(v, hashLog);
                         @ref = @base + (int)hashTable.Get(h);
-                        Debug.Assert(PackedInts.BitsRequired(off - @base) <= hashTable.BitsPerValue);
+                        Debug.Assert(PackedInt32s.BitsRequired(off - @base) <= hashTable.BitsPerValue);
                         hashTable.Set(h, off - @base);
                         if (off - @ref < MAX_DISTANCE && ReadInt32(bytes, @ref) == v)
                         {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Codecs/DocValuesConsumer.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/DocValuesConsumer.cs b/src/Lucene.Net.Core/Codecs/DocValuesConsumer.cs
index 2418d3f..999d719 100644
--- a/src/Lucene.Net.Core/Codecs/DocValuesConsumer.cs
+++ b/src/Lucene.Net.Core/Codecs/DocValuesConsumer.cs
@@ -29,7 +29,7 @@ namespace Lucene.Net.Codecs
     using BytesRef = Lucene.Net.Util.BytesRef;
     using FieldInfo = Lucene.Net.Index.FieldInfo;
     using FilteredTermsEnum = Lucene.Net.Index.FilteredTermsEnum;
-    using LongBitSet = Lucene.Net.Util.LongBitSet;
+    using Int64BitSet = Lucene.Net.Util.Int64BitSet;
     using MergeState = Lucene.Net.Index.MergeState;
     using NumericDocValues = Lucene.Net.Index.NumericDocValues;
     using OrdinalMap = Lucene.Net.Index.MultiDocValues.OrdinalMap;
@@ -252,7 +252,7 @@ namespace Lucene.Net.Codecs
                 }
                 else
                 {
-                    var bitset = new LongBitSet(dv.ValueCount);
+                    var bitset = new Int64BitSet(dv.ValueCount);
                     for (int i = 0; i < reader.MaxDoc; i++)
                     {
                         if (liveDocs.Get(i))
@@ -510,7 +510,7 @@ namespace Lucene.Net.Codecs
                 }
                 else
                 {
-                    var bitset = new LongBitSet(dv.ValueCount);
+                    var bitset = new Int64BitSet(dv.ValueCount);
                     for (int i = 0; i < reader.MaxDoc; i++)
                     {
                         if (liveDocs.Get(i))
@@ -939,9 +939,9 @@ namespace Lucene.Net.Codecs
         // TODO: seek-by-ord to nextSetBit
         internal class BitsFilteredTermsEnum : FilteredTermsEnum
         {
-            internal readonly LongBitSet liveTerms;
+            internal readonly Int64BitSet liveTerms;
 
-            internal BitsFilteredTermsEnum(TermsEnum @in, LongBitSet liveTerms)
+            internal BitsFilteredTermsEnum(TermsEnum @in, Int64BitSet liveTerms)
                 : base(@in, false)
             {
                 Debug.Assert(liveTerms != null);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Codecs/Lucene3x/Lucene3xNormsProducer.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/Lucene3x/Lucene3xNormsProducer.cs b/src/Lucene.Net.Core/Codecs/Lucene3x/Lucene3xNormsProducer.cs
index 6bba207..68abb4d 100644
--- a/src/Lucene.Net.Core/Codecs/Lucene3x/Lucene3xNormsProducer.cs
+++ b/src/Lucene.Net.Core/Codecs/Lucene3x/Lucene3xNormsProducer.cs
@@ -69,7 +69,7 @@ namespace Lucene.Net.Codecs.Lucene3x
 
         internal readonly int maxdoc;
 
-        private readonly AtomicLong ramBytesUsed;
+        private readonly AtomicInt64 ramBytesUsed;
 
         // note: just like segmentreader in 3.x, we open up all the files here (including separate norms) up front.
         // but we just don't do any seeks or reading yet.
@@ -142,7 +142,7 @@ namespace Lucene.Net.Codecs.Lucene3x
                     IOUtils.CloseWhileHandlingException(openFiles);
                 }
             }
-            ramBytesUsed = new AtomicLong();
+            ramBytesUsed = new AtomicInt64();
         }
 
         protected override void Dispose(bool disposing)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Codecs/Lucene3x/TermInfosReaderIndex.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/Lucene3x/TermInfosReaderIndex.cs b/src/Lucene.Net.Core/Codecs/Lucene3x/TermInfosReaderIndex.cs
index f726eec..7ed2ded 100644
--- a/src/Lucene.Net.Core/Codecs/Lucene3x/TermInfosReaderIndex.cs
+++ b/src/Lucene.Net.Core/Codecs/Lucene3x/TermInfosReaderIndex.cs
@@ -24,7 +24,7 @@ namespace Lucene.Net.Codecs.Lucene3x
     using BytesRef = Lucene.Net.Util.BytesRef;
     using GrowableWriter = Lucene.Net.Util.Packed.GrowableWriter;
     using MathUtil = Lucene.Net.Util.MathUtil;
-    using PackedInts = Lucene.Net.Util.Packed.PackedInts;
+    using PackedInt32s = Lucene.Net.Util.Packed.PackedInt32s;
     using PagedBytes = Lucene.Net.Util.PagedBytes;
     using PagedBytesDataInput = Lucene.Net.Util.PagedBytes.PagedBytesDataInput;
     using PagedBytesDataOutput = Lucene.Net.Util.PagedBytes.PagedBytesDataOutput;
@@ -45,7 +45,7 @@ namespace Lucene.Net.Codecs.Lucene3x
         private int totalIndexInterval;
         private IComparer<BytesRef> comparer = BytesRef.UTF8SortedAsUTF16Comparer;
         private readonly PagedBytesDataInput dataInput;
-        private readonly PackedInts.Reader indexToDataOffset;
+        private readonly PackedInt32s.Reader indexToDataOffset;
         private readonly int indexSize;
         private readonly int skipInterval;
         private readonly long ramBytesUsed;
@@ -73,7 +73,7 @@ namespace Lucene.Net.Codecs.Lucene3x
             PagedBytesDataOutput dataOutput = dataPagedBytes.GetDataOutput();
 
             int bitEstimate = 1 + MathUtil.Log(tiiFileLength, 2);
-            GrowableWriter indexToTerms = new GrowableWriter(bitEstimate, indexSize, PackedInts.DEFAULT);
+            GrowableWriter indexToTerms = new GrowableWriter(bitEstimate, indexSize, PackedInt32s.DEFAULT);
 
             string currentField = null;
             IList<string> fieldStrs = new List<string>();

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Codecs/Lucene40/Lucene40DocValuesReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/Lucene40/Lucene40DocValuesReader.cs b/src/Lucene.Net.Core/Codecs/Lucene40/Lucene40DocValuesReader.cs
index 7f53820..2bbc0b4 100644
--- a/src/Lucene.Net.Core/Codecs/Lucene40/Lucene40DocValuesReader.cs
+++ b/src/Lucene.Net.Core/Codecs/Lucene40/Lucene40DocValuesReader.cs
@@ -33,7 +33,7 @@ namespace Lucene.Net.Codecs.Lucene40
     using IOUtils = Lucene.Net.Util.IOUtils;
     using LegacyDocValuesType = Lucene.Net.Codecs.Lucene40.Lucene40FieldInfosReader.LegacyDocValuesType;
     using NumericDocValues = Lucene.Net.Index.NumericDocValues;
-    using PackedInts = Lucene.Net.Util.Packed.PackedInts;
+    using PackedInt32s = Lucene.Net.Util.Packed.PackedInt32s;
     using PagedBytes = Lucene.Net.Util.PagedBytes;
     using RamUsageEstimator = Lucene.Net.Util.RamUsageEstimator;
     using SegmentReadState = Lucene.Net.Index.SegmentReadState;
@@ -58,14 +58,14 @@ namespace Lucene.Net.Codecs.Lucene40
         private readonly IDictionary<int, BinaryDocValues> binaryInstances = new Dictionary<int, BinaryDocValues>();
         private readonly IDictionary<int, SortedDocValues> sortedInstances = new Dictionary<int, SortedDocValues>();
 
-        private readonly AtomicLong ramBytesUsed;
+        private readonly AtomicInt64 ramBytesUsed;
 
         internal Lucene40DocValuesReader(SegmentReadState state, string filename, string legacyKey)
         {
             this.state = state;
             this.legacyKey = legacyKey;
             this.dir = new CompoundFileDirectory(state.Directory, filename, state.Context, false);
-            ramBytesUsed = new AtomicLong(RamUsageEstimator.ShallowSizeOf(this.GetType()));
+            ramBytesUsed = new AtomicInt64(RamUsageEstimator.ShallowSizeOf(this.GetType()));
         }
 
         public override NumericDocValues GetNumeric(FieldInfo field)
@@ -159,7 +159,7 @@ namespace Lucene.Net.Codecs.Lucene40
             {
                 long minValue = input.ReadInt64();
                 long defaultValue = input.ReadInt64();
-                PackedInts.Reader reader = PackedInts.GetReader(input);
+                PackedInt32s.Reader reader = PackedInt32s.GetReader(input);
                 ramBytesUsed.AddAndGet(reader.RamBytesUsed());
                 return new NumericDocValuesAnonymousInnerClassHelper2(minValue, defaultValue, reader);
             }
@@ -188,9 +188,9 @@ namespace Lucene.Net.Codecs.Lucene40
         {
             private readonly long minValue;
             private readonly long defaultValue;
-            private readonly PackedInts.Reader reader;
+            private readonly PackedInt32s.Reader reader;
 
-            public NumericDocValuesAnonymousInnerClassHelper2(long minValue, long defaultValue, PackedInts.Reader reader)
+            public NumericDocValuesAnonymousInnerClassHelper2(long minValue, long defaultValue, PackedInt32s.Reader reader)
             {
                 this.minValue = minValue;
                 this.defaultValue = defaultValue;
@@ -517,7 +517,7 @@ namespace Lucene.Net.Codecs.Lucene40
                 PagedBytes bytes = new PagedBytes(16);
                 bytes.Copy(data, totalBytes);
                 PagedBytes.Reader bytesReader = bytes.Freeze(true);
-                PackedInts.Reader reader = PackedInts.GetReader(index);
+                PackedInt32s.Reader reader = PackedInt32s.GetReader(index);
                 CodecUtil.CheckEOF(data);
                 CodecUtil.CheckEOF(index);
                 success = true;
@@ -540,9 +540,9 @@ namespace Lucene.Net.Codecs.Lucene40
         private class BinaryDocValuesAnonymousInnerClassHelper2 : BinaryDocValues
         {
             private readonly PagedBytes.Reader bytesReader;
-            private readonly PackedInts.Reader reader;
+            private readonly PackedInt32s.Reader reader;
 
-            public BinaryDocValuesAnonymousInnerClassHelper2(PagedBytes.Reader bytesReader, PackedInts.Reader reader)
+            public BinaryDocValuesAnonymousInnerClassHelper2(PagedBytes.Reader bytesReader, PackedInt32s.Reader reader)
             {
                 this.bytesReader = bytesReader;
                 this.reader = reader;
@@ -575,7 +575,7 @@ namespace Lucene.Net.Codecs.Lucene40
                 PagedBytes bytes = new PagedBytes(16);
                 bytes.Copy(data, fixedLength * (long)valueCount);
                 PagedBytes.Reader bytesReader = bytes.Freeze(true);
-                PackedInts.Reader reader = PackedInts.GetReader(index);
+                PackedInt32s.Reader reader = PackedInt32s.GetReader(index);
                 CodecUtil.CheckEOF(data);
                 CodecUtil.CheckEOF(index);
                 ramBytesUsed.AddAndGet(bytes.RamBytesUsed() + reader.RamBytesUsed());
@@ -599,9 +599,9 @@ namespace Lucene.Net.Codecs.Lucene40
         {
             private readonly int fixedLength;
             private readonly PagedBytes.Reader bytesReader;
-            private readonly PackedInts.Reader reader;
+            private readonly PackedInt32s.Reader reader;
 
-            public BinaryDocValuesAnonymousInnerClassHelper3(int fixedLength, PagedBytes.Reader bytesReader, PackedInts.Reader reader)
+            public BinaryDocValuesAnonymousInnerClassHelper3(int fixedLength, PagedBytes.Reader bytesReader, PackedInt32s.Reader reader)
             {
                 this.fixedLength = fixedLength;
                 this.bytesReader = bytesReader;
@@ -633,7 +633,7 @@ namespace Lucene.Net.Codecs.Lucene40
                 PagedBytes bytes = new PagedBytes(16);
                 bytes.Copy(data, totalBytes);
                 PagedBytes.Reader bytesReader = bytes.Freeze(true);
-                PackedInts.Reader reader = PackedInts.GetReader(index);
+                PackedInt32s.Reader reader = PackedInt32s.GetReader(index);
                 CodecUtil.CheckEOF(data);
                 CodecUtil.CheckEOF(index);
                 ramBytesUsed.AddAndGet(bytes.RamBytesUsed() + reader.RamBytesUsed());
@@ -656,9 +656,9 @@ namespace Lucene.Net.Codecs.Lucene40
         private class BinaryDocValuesAnonymousInnerClassHelper4 : BinaryDocValues
         {
             private readonly PagedBytes.Reader bytesReader;
-            private readonly PackedInts.Reader reader;
+            private readonly PackedInt32s.Reader reader;
 
-            public BinaryDocValuesAnonymousInnerClassHelper4(PagedBytes.Reader bytesReader, PackedInts.Reader reader)
+            public BinaryDocValuesAnonymousInnerClassHelper4(PagedBytes.Reader bytesReader, PackedInt32s.Reader reader)
             {
                 this.bytesReader = bytesReader;
                 this.reader = reader;
@@ -748,7 +748,7 @@ namespace Lucene.Net.Codecs.Lucene40
             PagedBytes bytes = new PagedBytes(16);
             bytes.Copy(data, fixedLength * (long)valueCount);
             PagedBytes.Reader bytesReader = bytes.Freeze(true);
-            PackedInts.Reader reader = PackedInts.GetReader(index);
+            PackedInt32s.Reader reader = PackedInt32s.GetReader(index);
             ramBytesUsed.AddAndGet(bytes.RamBytesUsed() + reader.RamBytesUsed());
 
             return CorrectBuggyOrds(new SortedDocValuesAnonymousInnerClassHelper(fixedLength, valueCount, bytesReader, reader));
@@ -759,9 +759,9 @@ namespace Lucene.Net.Codecs.Lucene40
             private readonly int fixedLength;
             private readonly int valueCount;
             private readonly PagedBytes.Reader bytesReader;
-            private readonly PackedInts.Reader reader;
+            private readonly PackedInt32s.Reader reader;
 
-            public SortedDocValuesAnonymousInnerClassHelper(int fixedLength, int valueCount, PagedBytes.Reader bytesReader, PackedInts.Reader reader)
+            public SortedDocValuesAnonymousInnerClassHelper(int fixedLength, int valueCount, PagedBytes.Reader bytesReader, PackedInt32s.Reader reader)
             {
                 this.fixedLength = fixedLength;
                 this.valueCount = valueCount;
@@ -797,8 +797,8 @@ namespace Lucene.Net.Codecs.Lucene40
             PagedBytes bytes = new PagedBytes(16);
             bytes.Copy(data, maxAddress);
             PagedBytes.Reader bytesReader = bytes.Freeze(true);
-            PackedInts.Reader addressReader = PackedInts.GetReader(index);
-            PackedInts.Reader ordsReader = PackedInts.GetReader(index);
+            PackedInt32s.Reader addressReader = PackedInt32s.GetReader(index);
+            PackedInt32s.Reader ordsReader = PackedInt32s.GetReader(index);
 
             int valueCount = addressReader.Count - 1;
             ramBytesUsed.AddAndGet(bytes.RamBytesUsed() + addressReader.RamBytesUsed() + ordsReader.RamBytesUsed());
@@ -809,11 +809,11 @@ namespace Lucene.Net.Codecs.Lucene40
         private class SortedDocValuesAnonymousInnerClassHelper2 : SortedDocValues
         {
             private readonly PagedBytes.Reader bytesReader;
-            private readonly PackedInts.Reader addressReader;
-            private readonly PackedInts.Reader ordsReader;
+            private readonly PackedInt32s.Reader addressReader;
+            private readonly PackedInt32s.Reader ordsReader;
             private readonly int valueCount;
 
-            public SortedDocValuesAnonymousInnerClassHelper2(PagedBytes.Reader bytesReader, PackedInts.Reader addressReader, PackedInts.Reader ordsReader, int valueCount)
+            public SortedDocValuesAnonymousInnerClassHelper2(PagedBytes.Reader bytesReader, PackedInt32s.Reader addressReader, PackedInt32s.Reader ordsReader, int valueCount)
             {
                 this.bytesReader = bytesReader;
                 this.addressReader = addressReader;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Codecs/Lucene41/ForUtil.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/Lucene41/ForUtil.cs b/src/Lucene.Net.Core/Codecs/Lucene41/ForUtil.cs
index 2c17527..7a6d3eb 100644
--- a/src/Lucene.Net.Core/Codecs/Lucene41/ForUtil.cs
+++ b/src/Lucene.Net.Core/Codecs/Lucene41/ForUtil.cs
@@ -61,9 +61,9 @@ namespace Lucene.Net.Codecs.Lucene41
         static ForUtil()
         {
             int maxDataSize = 0;
-            for (int version = PackedInts.VERSION_START; version <= PackedInts.VERSION_CURRENT; version++)
+            for (int version = PackedInt32s.VERSION_START; version <= PackedInt32s.VERSION_CURRENT; version++)
             {
-                foreach (PackedInts.Format format in PackedInts.Format.Values()/* Enum.GetValues(typeof(PackedInts.Format))*/)
+                foreach (PackedInt32s.Format format in PackedInt32s.Format.Values()/* Enum.GetValues(typeof(PackedInts.Format))*/)
                 {
                     for (int bpv = 1; bpv <= 32; ++bpv)
                     {
@@ -71,7 +71,7 @@ namespace Lucene.Net.Codecs.Lucene41
                         {
                             continue;
                         }
-                        PackedInts.IDecoder decoder = PackedInts.GetDecoder(format, version, bpv);
+                        PackedInt32s.IDecoder decoder = PackedInt32s.GetDecoder(format, version, bpv);
                         int iterations = ComputeIterations(decoder);
                         maxDataSize = Math.Max(maxDataSize, iterations * decoder.ByteValueCount);
                     }
@@ -84,7 +84,7 @@ namespace Lucene.Net.Codecs.Lucene41
         /// Compute the number of iterations required to decode <code>BLOCK_SIZE</code>
         /// values with the provided <seealso cref="Decoder"/>.
         /// </summary>
-        private static int ComputeIterations(PackedInts.IDecoder decoder)
+        private static int ComputeIterations(PackedInt32s.IDecoder decoder)
         {
             return (int)Math.Ceiling((float)Lucene41PostingsFormat.BLOCK_SIZE / decoder.ByteValueCount);
         }
@@ -93,7 +93,7 @@ namespace Lucene.Net.Codecs.Lucene41
         /// Compute the number of bytes required to encode a block of values that require
         /// <code>bitsPerValue</code> bits per value with format <code>format</code>.
         /// </summary>
-        private static int EncodedSize(PackedInts.Format format, int packedIntsVersion, int bitsPerValue)
+        private static int EncodedSize(PackedInt32s.Format format, int packedIntsVersion, int bitsPerValue)
         {
             long byteCount = format.ByteCount(packedIntsVersion, Lucene41PostingsFormat.BLOCK_SIZE, bitsPerValue);
             Debug.Assert(byteCount >= 0 && byteCount <= int.MaxValue, byteCount.ToString());
@@ -101,8 +101,8 @@ namespace Lucene.Net.Codecs.Lucene41
         }
 
         private readonly int[] encodedSizes;
-        private readonly PackedInts.IEncoder[] encoders;
-        private readonly PackedInts.IDecoder[] decoders;
+        private readonly PackedInt32s.IEncoder[] encoders;
+        private readonly PackedInt32s.IDecoder[] decoders;
         private readonly int[] iterations;
 
         /// <summary>
@@ -110,20 +110,20 @@ namespace Lucene.Net.Codecs.Lucene41
         /// </summary>
         internal ForUtil(float acceptableOverheadRatio, DataOutput @out)
         {
-            @out.WriteVInt32(PackedInts.VERSION_CURRENT);
+            @out.WriteVInt32(PackedInt32s.VERSION_CURRENT);
             encodedSizes = new int[33];
-            encoders = new PackedInts.IEncoder[33];
-            decoders = new PackedInts.IDecoder[33];
+            encoders = new PackedInt32s.IEncoder[33];
+            decoders = new PackedInt32s.IDecoder[33];
             iterations = new int[33];
 
             for (int bpv = 1; bpv <= 32; ++bpv)
             {
-                PackedInts.FormatAndBits formatAndBits = PackedInts.FastestFormatAndBits(Lucene41PostingsFormat.BLOCK_SIZE, bpv, acceptableOverheadRatio);
+                PackedInt32s.FormatAndBits formatAndBits = PackedInt32s.FastestFormatAndBits(Lucene41PostingsFormat.BLOCK_SIZE, bpv, acceptableOverheadRatio);
                 Debug.Assert(formatAndBits.Format.IsSupported(formatAndBits.BitsPerValue));
                 Debug.Assert(formatAndBits.BitsPerValue <= 32);
-                encodedSizes[bpv] = EncodedSize(formatAndBits.Format, PackedInts.VERSION_CURRENT, formatAndBits.BitsPerValue);
-                encoders[bpv] = PackedInts.GetEncoder(formatAndBits.Format, PackedInts.VERSION_CURRENT, formatAndBits.BitsPerValue);
-                decoders[bpv] = PackedInts.GetDecoder(formatAndBits.Format, PackedInts.VERSION_CURRENT, formatAndBits.BitsPerValue);
+                encodedSizes[bpv] = EncodedSize(formatAndBits.Format, PackedInt32s.VERSION_CURRENT, formatAndBits.BitsPerValue);
+                encoders[bpv] = PackedInt32s.GetEncoder(formatAndBits.Format, PackedInt32s.VERSION_CURRENT, formatAndBits.BitsPerValue);
+                decoders[bpv] = PackedInt32s.GetDecoder(formatAndBits.Format, PackedInt32s.VERSION_CURRENT, formatAndBits.BitsPerValue);
                 iterations[bpv] = ComputeIterations(decoders[bpv]);
 
                 @out.WriteVInt32(formatAndBits.Format.Id << 5 | (formatAndBits.BitsPerValue - 1));
@@ -136,10 +136,10 @@ namespace Lucene.Net.Codecs.Lucene41
         internal ForUtil(DataInput @in)
         {
             int packedIntsVersion = @in.ReadVInt32();
-            PackedInts.CheckVersion(packedIntsVersion);
+            PackedInt32s.CheckVersion(packedIntsVersion);
             encodedSizes = new int[33];
-            encoders = new PackedInts.IEncoder[33];
-            decoders = new PackedInts.IDecoder[33];
+            encoders = new PackedInt32s.IEncoder[33];
+            decoders = new PackedInt32s.IDecoder[33];
             iterations = new int[33];
 
             for (int bpv = 1; bpv <= 32; ++bpv)
@@ -148,11 +148,11 @@ namespace Lucene.Net.Codecs.Lucene41
                 var formatId = (int)((uint)code >> 5);
                 var bitsPerValue = (code & 31) + 1;
 
-                PackedInts.Format format = PackedInts.Format.ById(formatId);
+                PackedInt32s.Format format = PackedInt32s.Format.ById(formatId);
                 Debug.Assert(format.IsSupported(bitsPerValue));
                 encodedSizes[bpv] = EncodedSize(format, packedIntsVersion, bitsPerValue);
-                encoders[bpv] = PackedInts.GetEncoder(format, packedIntsVersion, bitsPerValue);
-                decoders[bpv] = PackedInts.GetDecoder(format, packedIntsVersion, bitsPerValue);
+                encoders[bpv] = PackedInt32s.GetEncoder(format, packedIntsVersion, bitsPerValue);
+                decoders[bpv] = PackedInt32s.GetDecoder(format, packedIntsVersion, bitsPerValue);
                 iterations[bpv] = ComputeIterations(decoders[bpv]);
             }
         }
@@ -175,7 +175,7 @@ namespace Lucene.Net.Codecs.Lucene41
 
             int numBits = BitsRequired(data);
             Debug.Assert(numBits > 0 && numBits <= 32, numBits.ToString());
-            PackedInts.IEncoder encoder = encoders[numBits];
+            PackedInt32s.IEncoder encoder = encoders[numBits];
             int iters = iterations[numBits];
             Debug.Assert(iters * encoder.ByteValueCount >= Lucene41PostingsFormat.BLOCK_SIZE);
             int encodedSize = encodedSizes[numBits];
@@ -209,7 +209,7 @@ namespace Lucene.Net.Codecs.Lucene41
             int encodedSize = encodedSizes[numBits];
             @in.ReadBytes(encoded, 0, encodedSize);
 
-            PackedInts.IDecoder decoder = decoders[numBits];
+            PackedInt32s.IDecoder decoder = decoders[numBits];
             int iters = iterations[numBits];
             Debug.Assert(iters * decoder.ByteValueCount >= Lucene41PostingsFormat.BLOCK_SIZE);
 
@@ -259,7 +259,7 @@ namespace Lucene.Net.Codecs.Lucene41
                 Debug.Assert(data[i] >= 0);
                 or |= (uint)data[i];
             }
-            return PackedInts.BitsRequired(or);
+            return PackedInt32s.BitsRequired(or);
         }
     }
 }
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Codecs/Lucene41/Lucene41PostingsReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/Lucene41/Lucene41PostingsReader.cs b/src/Lucene.Net.Core/Codecs/Lucene41/Lucene41PostingsReader.cs
index d32ec16..1d68cad 100644
--- a/src/Lucene.Net.Core/Codecs/Lucene41/Lucene41PostingsReader.cs
+++ b/src/Lucene.Net.Core/Codecs/Lucene41/Lucene41PostingsReader.cs
@@ -126,7 +126,7 @@ namespace Lucene.Net.Codecs.Lucene41
 
         public override BlockTermState NewTermState()
         {
-            return new Lucene41PostingsWriter.IntBlockTermState();
+            return new Lucene41PostingsWriter.Int32BlockTermState();
         }
 
         protected override void Dispose(bool disposing)
@@ -137,7 +137,7 @@ namespace Lucene.Net.Codecs.Lucene41
 
         public override void DecodeTerm(long[] longs, DataInput @in, FieldInfo fieldInfo, BlockTermState termState, bool absolute)
         {
-            Lucene41PostingsWriter.IntBlockTermState termState2 = (Lucene41PostingsWriter.IntBlockTermState)termState;
+            Lucene41PostingsWriter.Int32BlockTermState termState2 = (Lucene41PostingsWriter.Int32BlockTermState)termState;
             bool fieldHasPositions = fieldInfo.IndexOptions >= IndexOptions.DOCS_AND_FREQS_AND_POSITIONS;
             bool fieldHasOffsets = fieldInfo.IndexOptions >= IndexOptions.DOCS_AND_FREQS_AND_POSITIONS_AND_OFFSETS;
             bool fieldHasPayloads = fieldInfo.HasPayloads;
@@ -191,7 +191,7 @@ namespace Lucene.Net.Codecs.Lucene41
             }
         }
 
-        private void DecodeTerm(DataInput @in, FieldInfo fieldInfo, Lucene41PostingsWriter.IntBlockTermState termState)
+        private void DecodeTerm(DataInput @in, FieldInfo fieldInfo, Lucene41PostingsWriter.Int32BlockTermState termState)
         {
             bool fieldHasPositions = fieldInfo.IndexOptions >= IndexOptions.DOCS_AND_FREQS_AND_POSITIONS;
             bool fieldHasOffsets = fieldInfo.IndexOptions >= IndexOptions.DOCS_AND_FREQS_AND_POSITIONS_AND_OFFSETS;
@@ -246,7 +246,7 @@ namespace Lucene.Net.Codecs.Lucene41
             {
                 docsEnum = new BlockDocsEnum(this, fieldInfo);
             }
-            return docsEnum.Reset(liveDocs, (Lucene41PostingsWriter.IntBlockTermState)termState, flags);
+            return docsEnum.Reset(liveDocs, (Lucene41PostingsWriter.Int32BlockTermState)termState, flags);
         }
 
         // TODO: specialize to liveDocs vs not
@@ -271,7 +271,7 @@ namespace Lucene.Net.Codecs.Lucene41
                 {
                     docsAndPositionsEnum = new BlockDocsAndPositionsEnum(this, fieldInfo);
                 }
-                return docsAndPositionsEnum.Reset(liveDocs, (Lucene41PostingsWriter.IntBlockTermState)termState);
+                return docsAndPositionsEnum.Reset(liveDocs, (Lucene41PostingsWriter.Int32BlockTermState)termState);
             }
             else
             {
@@ -288,7 +288,7 @@ namespace Lucene.Net.Codecs.Lucene41
                 {
                     everythingEnum = new EverythingEnum(this, fieldInfo);
                 }
-                return everythingEnum.Reset(liveDocs, (Lucene41PostingsWriter.IntBlockTermState)termState, flags);
+                return everythingEnum.Reset(liveDocs, (Lucene41PostingsWriter.Int32BlockTermState)termState, flags);
             }
         }
 
@@ -355,7 +355,7 @@ namespace Lucene.Net.Codecs.Lucene41
                 return docIn == startDocIn && indexHasFreq == (fieldInfo.IndexOptions >= IndexOptions.DOCS_AND_FREQS) && indexHasPos == (fieldInfo.IndexOptions >= IndexOptions.DOCS_AND_FREQS_AND_POSITIONS) && indexHasPayloads == fieldInfo.HasPayloads;
             }
 
-            public DocsEnum Reset(IBits liveDocs, Lucene41PostingsWriter.IntBlockTermState termState, int flags)
+            public DocsEnum Reset(IBits liveDocs, Lucene41PostingsWriter.Int32BlockTermState termState, int flags)
             {
                 this.liveDocs = liveDocs;
                 // if (DEBUG) {
@@ -677,7 +677,7 @@ namespace Lucene.Net.Codecs.Lucene41
                 return docIn == startDocIn && indexHasOffsets == (fieldInfo.IndexOptions >= IndexOptions.DOCS_AND_FREQS_AND_POSITIONS_AND_OFFSETS) && indexHasPayloads == fieldInfo.HasPayloads;
             }
 
-            public DocsAndPositionsEnum Reset(IBits liveDocs, Lucene41PostingsWriter.IntBlockTermState termState)
+            public DocsAndPositionsEnum Reset(IBits liveDocs, Lucene41PostingsWriter.Int32BlockTermState termState)
             {
                 this.liveDocs = liveDocs;
                 // if (DEBUG) {
@@ -1188,7 +1188,7 @@ namespace Lucene.Net.Codecs.Lucene41
                 return docIn == startDocIn && indexHasOffsets == (fieldInfo.IndexOptions >= IndexOptions.DOCS_AND_FREQS_AND_POSITIONS_AND_OFFSETS) && indexHasPayloads == fieldInfo.HasPayloads;
             }
 
-            public EverythingEnum Reset(IBits liveDocs, Lucene41PostingsWriter.IntBlockTermState termState, int flags)
+            public EverythingEnum Reset(IBits liveDocs, Lucene41PostingsWriter.Int32BlockTermState termState, int flags)
             {
                 this.liveDocs = liveDocs;
                 // if (DEBUG) {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Codecs/Lucene41/Lucene41PostingsWriter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/Lucene41/Lucene41PostingsWriter.cs b/src/Lucene.Net.Core/Codecs/Lucene41/Lucene41PostingsWriter.cs
index 68abbed..9c8af79 100644
--- a/src/Lucene.Net.Core/Codecs/Lucene41/Lucene41PostingsWriter.cs
+++ b/src/Lucene.Net.Core/Codecs/Lucene41/Lucene41PostingsWriter.cs
@@ -28,7 +28,7 @@ namespace Lucene.Net.Codecs.Lucene41
     using IndexOptions = Lucene.Net.Index.IndexOptions;
     using IndexOutput = Store.IndexOutput;
     using IOUtils = Util.IOUtils;
-    using PackedInts = Util.Packed.PackedInts;
+    using PackedInt32s = Util.Packed.PackedInt32s;
     using SegmentWriteState = Index.SegmentWriteState;
     using TermState = Index.TermState;
 
@@ -64,8 +64,8 @@ namespace Lucene.Net.Codecs.Lucene41
         internal IndexOutput posOut;
         internal IndexOutput payOut;
 
-        internal static readonly IntBlockTermState emptyState = new IntBlockTermState();
-        internal IntBlockTermState lastState;
+        internal static readonly Int32BlockTermState emptyState = new Int32BlockTermState();
+        internal Int32BlockTermState lastState;
 
         // How current field indexes postings:
         private bool fieldHasFreqs;
@@ -189,11 +189,14 @@ namespace Lucene.Net.Codecs.Lucene41
         /// <summary>
         /// Creates a postings writer with <code>PackedInts.COMPACT</code> </summary>
         public Lucene41PostingsWriter(SegmentWriteState state)
-            : this(state, PackedInts.COMPACT)
+            : this(state, PackedInt32s.COMPACT)
         {
         }
 
-        public sealed class IntBlockTermState : BlockTermState
+        /// <summary>
+        /// NOTE: This was IntBlockTermState in Lucene
+        /// </summary>
+        public sealed class Int32BlockTermState : BlockTermState
         {
             internal long docStartFP = 0;
             internal long posStartFP = 0;
@@ -207,7 +210,7 @@ namespace Lucene.Net.Codecs.Lucene41
 
             public override object Clone()
             {
-                IntBlockTermState other = new IntBlockTermState();
+                Int32BlockTermState other = new Int32BlockTermState();
                 other.CopyFrom(this);
                 return other;
             }
@@ -215,7 +218,7 @@ namespace Lucene.Net.Codecs.Lucene41
             public override void CopyFrom(TermState other)
             {
                 base.CopyFrom(other);
-                IntBlockTermState other2 = (IntBlockTermState)other;
+                Int32BlockTermState other2 = (Int32BlockTermState)other;
                 docStartFP = other2.docStartFP;
                 posStartFP = other2.posStartFP;
                 payStartFP = other2.payStartFP;
@@ -232,7 +235,7 @@ namespace Lucene.Net.Codecs.Lucene41
 
         public override BlockTermState NewTermState()
         {
-            return new IntBlockTermState();
+            return new Int32BlockTermState();
         }
 
         public override void Init(IndexOutput termsOut)
@@ -433,7 +436,7 @@ namespace Lucene.Net.Codecs.Lucene41
         /// Called when we are done adding docs to this term </summary>
         public override void FinishTerm(BlockTermState state)
         {
-            IntBlockTermState state2 = (IntBlockTermState)state;
+            Int32BlockTermState state2 = (Int32BlockTermState)state;
             Debug.Assert(state2.DocFreq > 0);
 
             // TODO: wasteful we are counting this (counting # docs
@@ -617,7 +620,7 @@ namespace Lucene.Net.Codecs.Lucene41
 
         public override void EncodeTerm(long[] longs, DataOutput @out, FieldInfo fieldInfo, BlockTermState state, bool absolute)
         {
-            IntBlockTermState state2 = (IntBlockTermState)state;
+            Int32BlockTermState state2 = (Int32BlockTermState)state;
             if (absolute)
             {
                 lastState = emptyState;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Codecs/Lucene42/Lucene42DocValuesFormat.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/Lucene42/Lucene42DocValuesFormat.cs b/src/Lucene.Net.Core/Codecs/Lucene42/Lucene42DocValuesFormat.cs
index 9e2a865..3b1e9c5 100644
--- a/src/Lucene.Net.Core/Codecs/Lucene42/Lucene42DocValuesFormat.cs
+++ b/src/Lucene.Net.Core/Codecs/Lucene42/Lucene42DocValuesFormat.cs
@@ -19,7 +19,7 @@ namespace Lucene.Net.Codecs.Lucene42
      * limitations under the License.
      */
 
-    using PackedInts = Lucene.Net.Util.Packed.PackedInts;
+    using PackedInt32s = Lucene.Net.Util.Packed.PackedInt32s;
     using SegmentReadState = Lucene.Net.Index.SegmentReadState;
     using SegmentWriteState = Lucene.Net.Index.SegmentWriteState;
 
@@ -104,7 +104,7 @@ namespace Lucene.Net.Codecs.Lucene42
     ///     <li>BinaryData --&gt;  <seealso cref="DataOutput#writeByte Byte"/><sup>DataLength</sup>,Addresses</li>
     ///     <li>SortedData --&gt; <seealso cref="FST FST&lt;Int64&gt;"/></li>
     ///     <li>DeltaCompressedNumerics --&gt; <seealso cref="BlockPackedWriter BlockPackedInts(blockSize=4096)"/></li>
-    ///     <li>TableCompressedNumerics --&gt; TableSize,<seealso cref="DataOutput#writeLong Int64"/><sup>TableSize</sup>,<seealso cref="PackedInts PackedInts"/></li>
+    ///     <li>TableCompressedNumerics --&gt; TableSize,<seealso cref="DataOutput#writeLong Int64"/><sup>TableSize</sup>,<seealso cref="PackedInt32s PackedInts"/></li>
     ///     <li>UncompressedNumerics --&gt; <seealso cref="DataOutput#writeByte Byte"/><sup>maxdoc</sup></li>
     ///     <li>Addresses --&gt; <seealso cref="MonotonicBlockPackedWriter MonotonicBlockPackedInts(blockSize=4096)"/></li>
     ///     <li>Footer --&gt; <seealso cref="CodecUtil#writeFooter CodecFooter"/></li>
@@ -132,7 +132,7 @@ namespace Lucene.Net.Codecs.Lucene42
         /// Lucene42DocValuesFormat(PackedInts.DEFAULT)}
         /// </summary>
         public Lucene42DocValuesFormat()
-            : this(PackedInts.DEFAULT)
+            : this(PackedInt32s.DEFAULT)
         {
         }
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Codecs/Lucene42/Lucene42DocValuesProducer.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/Lucene42/Lucene42DocValuesProducer.cs b/src/Lucene.Net.Core/Codecs/Lucene42/Lucene42DocValuesProducer.cs
index a6b1ed0..3346e6c 100644
--- a/src/Lucene.Net.Core/Codecs/Lucene42/Lucene42DocValuesProducer.cs
+++ b/src/Lucene.Net.Core/Codecs/Lucene42/Lucene42DocValuesProducer.cs
@@ -38,13 +38,13 @@ namespace Lucene.Net.Codecs.Lucene42
     using FieldInfos = Lucene.Net.Index.FieldInfos;
     using IndexFileNames = Lucene.Net.Index.IndexFileNames;
     using IndexInput = Lucene.Net.Store.IndexInput;
-    using IntsRef = Lucene.Net.Util.IntsRef;
+    using Int32sRef = Lucene.Net.Util.Int32sRef;
     using IOUtils = Lucene.Net.Util.IOUtils;
     using MonotonicBlockPackedReader = Lucene.Net.Util.Packed.MonotonicBlockPackedReader;
     using NumericDocValues = Lucene.Net.Index.NumericDocValues;
-    using PackedInts = Lucene.Net.Util.Packed.PackedInts;
+    using PackedInt32s = Lucene.Net.Util.Packed.PackedInt32s;
     using PagedBytes = Lucene.Net.Util.PagedBytes;
-    using PositiveIntOutputs = Lucene.Net.Util.Fst.PositiveIntOutputs;
+    using PositiveInt32Outputs = Lucene.Net.Util.Fst.PositiveInt32Outputs;
     using RamUsageEstimator = Lucene.Net.Util.RamUsageEstimator;
     using SegmentReadState = Lucene.Net.Index.SegmentReadState;
     using SortedDocValues = Lucene.Net.Index.SortedDocValues;
@@ -72,7 +72,7 @@ namespace Lucene.Net.Codecs.Lucene42
         private readonly IDictionary<int, FST<long?>> fstInstances = new Dictionary<int, FST<long?>>();
 
         private readonly int maxDoc;
-        private readonly AtomicLong ramBytesUsed;
+        private readonly AtomicInt64 ramBytesUsed;
 
         internal const sbyte NUMBER = 0;
         internal const sbyte BYTES = 1;
@@ -97,7 +97,7 @@ namespace Lucene.Net.Codecs.Lucene42
             // read in the entries from the metadata file.
             ChecksumIndexInput @in = state.Directory.OpenChecksumInput(metaName, state.Context);
             bool success = false;
-            ramBytesUsed = new AtomicLong(RamUsageEstimator.ShallowSizeOfInstance(this.GetType()));
+            ramBytesUsed = new AtomicInt64(RamUsageEstimator.ShallowSizeOfInstance(this.GetType()));
             try
             {
                 version = CodecUtil.CheckHeader(@in, metaCodec, VERSION_START, VERSION_CURRENT);
@@ -263,7 +263,7 @@ namespace Lucene.Net.Codecs.Lucene42
                     }
                     int formatID = data.ReadVInt32();
                     int bitsPerValue = data.ReadVInt32();
-                    PackedInts.Reader ordsReader = PackedInts.GetReaderNoHeader(data, PackedInts.Format.ById(formatID), entry.PackedInt32sVersion, maxDoc, bitsPerValue);
+                    PackedInt32s.Reader ordsReader = PackedInt32s.GetReaderNoHeader(data, PackedInt32s.Format.ById(formatID), entry.PackedInt32sVersion, maxDoc, bitsPerValue);
                     ramBytesUsed.AddAndGet(RamUsageEstimator.SizeOf(decode) + ordsReader.RamBytesUsed());
                     return new NumericDocValuesAnonymousInnerClassHelper(decode, ordsReader);
 
@@ -295,9 +295,9 @@ namespace Lucene.Net.Codecs.Lucene42
         private class NumericDocValuesAnonymousInnerClassHelper : NumericDocValues
         {
             private readonly long[] decode;
-            private readonly PackedInts.Reader ordsReader;
+            private readonly PackedInt32s.Reader ordsReader;
 
-            public NumericDocValuesAnonymousInnerClassHelper(long[] decode, PackedInts.Reader ordsReader)
+            public NumericDocValuesAnonymousInnerClassHelper(long[] decode, PackedInt32s.Reader ordsReader)
             {
                 this.decode = decode;
                 this.ordsReader = ordsReader;
@@ -423,7 +423,7 @@ namespace Lucene.Net.Codecs.Lucene42
                 if (!fstInstances.TryGetValue(field.Number, out instance))
                 {
                     data.Seek(entry.Offset);
-                    instance = new FST<long?>(data, PositiveIntOutputs.Singleton);
+                    instance = new FST<long?>(data, PositiveInt32Outputs.Singleton);
                     ramBytesUsed.AddAndGet(instance.SizeInBytes());
                     fstInstances[field.Number] = instance;
                 }
@@ -435,7 +435,7 @@ namespace Lucene.Net.Codecs.Lucene42
             var @in = fst.GetBytesReader();
             var firstArc = new FST.Arc<long?>();
             var scratchArc = new FST.Arc<long?>();
-            var scratchInts = new IntsRef();
+            var scratchInts = new Int32sRef();
             var fstEnum = new BytesRefFSTEnum<long?>(fst);
 
             return new SortedDocValuesAnonymousInnerClassHelper(entry, docToOrd, fst, @in, firstArc, scratchArc, scratchInts, fstEnum);
@@ -449,10 +449,10 @@ namespace Lucene.Net.Codecs.Lucene42
             private readonly FST.BytesReader @in;
             private readonly FST.Arc<long?> firstArc;
             private readonly FST.Arc<long?> scratchArc;
-            private readonly IntsRef scratchInts;
+            private readonly Int32sRef scratchInts;
             private readonly BytesRefFSTEnum<long?> fstEnum;
 
-            public SortedDocValuesAnonymousInnerClassHelper(FSTEntry entry, NumericDocValues docToOrd, FST<long?> fst, FST.BytesReader @in, FST.Arc<long?> firstArc, FST.Arc<long?> scratchArc, IntsRef scratchInts, BytesRefFSTEnum<long?> fstEnum)
+            public SortedDocValuesAnonymousInnerClassHelper(FSTEntry entry, NumericDocValues docToOrd, FST<long?> fst, FST.BytesReader @in, FST.Arc<long?> firstArc, FST.Arc<long?> scratchArc, Int32sRef scratchInts, BytesRefFSTEnum<long?> fstEnum)
             {
                 this.entry = entry;
                 this.docToOrd = docToOrd;
@@ -475,7 +475,7 @@ namespace Lucene.Net.Codecs.Lucene42
                 {
                     @in.Position = 0;
                     fst.GetFirstArc(firstArc);
-                    IntsRef output = Lucene.Net.Util.Fst.Util.GetByOutput(fst, ord, @in, firstArc, scratchArc, scratchInts);
+                    Int32sRef output = Lucene.Net.Util.Fst.Util.GetByOutput(fst, ord, @in, firstArc, scratchArc, scratchInts);
                     result.Bytes = new byte[output.Length];
                     result.Offset = 0;
                     result.Length = 0;
@@ -538,7 +538,7 @@ namespace Lucene.Net.Codecs.Lucene42
                 if (!fstInstances.TryGetValue(field.Number, out instance))
                 {
                     data.Seek(entry.Offset);
-                    instance = new FST<long?>((DataInput)data, Lucene.Net.Util.Fst.PositiveIntOutputs.Singleton);
+                    instance = new FST<long?>((DataInput)data, Lucene.Net.Util.Fst.PositiveInt32Outputs.Singleton);
                     ramBytesUsed.AddAndGet(instance.SizeInBytes());
                     fstInstances[field.Number] = instance;
                 }
@@ -550,7 +550,7 @@ namespace Lucene.Net.Codecs.Lucene42
             var @in = fst.GetBytesReader();
             var firstArc = new FST.Arc<long?>();
             var scratchArc = new FST.Arc<long?>();
-            var scratchInts = new IntsRef();
+            var scratchInts = new Int32sRef();
             var fstEnum = new BytesRefFSTEnum<long?>(fst);
             var @ref = new BytesRef();
             var input = new ByteArrayDataInput();
@@ -565,12 +565,12 @@ namespace Lucene.Net.Codecs.Lucene42
             private readonly FST.BytesReader @in;
             private readonly FST.Arc<long?> firstArc;
             private readonly FST.Arc<long?> scratchArc;
-            private readonly IntsRef scratchInts;
+            private readonly Int32sRef scratchInts;
             private readonly BytesRefFSTEnum<long?> fstEnum;
             private readonly BytesRef @ref;
             private readonly ByteArrayDataInput input;
 
-            public SortedSetDocValuesAnonymousInnerClassHelper(FSTEntry entry, BinaryDocValues docToOrds, FST<long?> fst, FST.BytesReader @in, FST.Arc<long?> firstArc, FST.Arc<long?> scratchArc, IntsRef scratchInts, BytesRefFSTEnum<long?> fstEnum, BytesRef @ref, ByteArrayDataInput input)
+            public SortedSetDocValuesAnonymousInnerClassHelper(FSTEntry entry, BinaryDocValues docToOrds, FST<long?> fst, FST.BytesReader @in, FST.Arc<long?> firstArc, FST.Arc<long?> scratchArc, Int32sRef scratchInts, BytesRefFSTEnum<long?> fstEnum, BytesRef @ref, ByteArrayDataInput input)
             {
                 this.entry = entry;
                 this.docToOrds = docToOrds;
@@ -612,7 +612,7 @@ namespace Lucene.Net.Codecs.Lucene42
                 {
                     @in.Position = 0;
                     fst.GetFirstArc(firstArc);
-                    IntsRef output = Lucene.Net.Util.Fst.Util.GetByOutput(fst, ord, @in, firstArc, scratchArc, scratchInts);
+                    Int32sRef output = Lucene.Net.Util.Fst.Util.GetByOutput(fst, ord, @in, firstArc, scratchArc, scratchInts);
                     result.Bytes = new byte[output.Length];
                     result.Offset = 0;
                     result.Length = 0;
@@ -725,7 +725,7 @@ namespace Lucene.Net.Codecs.Lucene42
             internal readonly FST.BytesReader bytesReader;
             internal readonly FST.Arc<long?> firstArc = new FST.Arc<long?>();
             internal readonly FST.Arc<long?> scratchArc = new FST.Arc<long?>();
-            internal readonly IntsRef scratchInts = new IntsRef();
+            internal readonly Int32sRef scratchInts = new Int32sRef();
             internal readonly BytesRef scratchBytes = new BytesRef();
 
             internal FSTTermsEnum(FST<long?> fst)
@@ -792,7 +792,7 @@ namespace Lucene.Net.Codecs.Lucene42
                 // but we dont want to introduce a bug that corrupts our enum state!
                 bytesReader.Position = 0;
                 fst.GetFirstArc(firstArc);
-                IntsRef output = Lucene.Net.Util.Fst.Util.GetByOutput(fst, ord, bytesReader, firstArc, scratchArc, scratchInts);
+                Int32sRef output = Lucene.Net.Util.Fst.Util.GetByOutput(fst, ord, bytesReader, firstArc, scratchArc, scratchInts);
                 scratchBytes.Bytes = new byte[output.Length];
                 scratchBytes.Offset = 0;
                 scratchBytes.Length = 0;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Codecs/Lucene42/Lucene42NormsConsumer.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/Lucene42/Lucene42NormsConsumer.cs b/src/Lucene.Net.Core/Codecs/Lucene42/Lucene42NormsConsumer.cs
index 55697a3..5a4b7be 100644
--- a/src/Lucene.Net.Core/Codecs/Lucene42/Lucene42NormsConsumer.cs
+++ b/src/Lucene.Net.Core/Codecs/Lucene42/Lucene42NormsConsumer.cs
@@ -25,12 +25,12 @@ namespace Lucene.Net.Codecs.Lucene42
     using BlockPackedWriter = Lucene.Net.Util.Packed.BlockPackedWriter;
     using BytesRef = Lucene.Net.Util.BytesRef;
     using FieldInfo = Lucene.Net.Index.FieldInfo;
-    using FormatAndBits = Lucene.Net.Util.Packed.PackedInts.FormatAndBits;
+    using FormatAndBits = Lucene.Net.Util.Packed.PackedInt32s.FormatAndBits;
     using IndexFileNames = Lucene.Net.Index.IndexFileNames;
     using IndexOutput = Lucene.Net.Store.IndexOutput;
     using IOUtils = Lucene.Net.Util.IOUtils;
     using MathUtil = Lucene.Net.Util.MathUtil;
-    using PackedInts = Lucene.Net.Util.Packed.PackedInts;
+    using PackedInt32s = Lucene.Net.Util.Packed.PackedInt32s;
     using SegmentWriteState = Lucene.Net.Index.SegmentWriteState;
 
     /// <summary>
@@ -132,8 +132,8 @@ namespace Lucene.Net.Codecs.Lucene42
             if (uniqueValues != null)
             {
                 // small number of unique values
-                int bitsPerValue = PackedInts.BitsRequired(uniqueValues.Count - 1);
-                FormatAndBits formatAndBits = PackedInts.FastestFormatAndBits(maxDoc, bitsPerValue, acceptableOverheadRatio);
+                int bitsPerValue = PackedInt32s.BitsRequired(uniqueValues.Count - 1);
+                FormatAndBits formatAndBits = PackedInt32s.FastestFormatAndBits(maxDoc, bitsPerValue, acceptableOverheadRatio);
                 if (formatAndBits.BitsPerValue == 8 && minValue >= sbyte.MinValue && maxValue <= sbyte.MaxValue)
                 {
                     meta.WriteByte((byte)UNCOMPRESSED); // uncompressed
@@ -154,11 +154,11 @@ namespace Lucene.Net.Codecs.Lucene42
                         encode[decode[i]] = i;
                     }
 
-                    meta.WriteVInt32(PackedInts.VERSION_CURRENT);
+                    meta.WriteVInt32(PackedInt32s.VERSION_CURRENT);
                     data.WriteVInt32(formatAndBits.Format.Id);
                     data.WriteVInt32(formatAndBits.BitsPerValue);
 
-                    PackedInts.Writer writer = PackedInts.GetWriterNoHeader(data, formatAndBits.Format, maxDoc, formatAndBits.BitsPerValue, PackedInts.DEFAULT_BUFFER_SIZE);
+                    PackedInt32s.Writer writer = PackedInt32s.GetWriterNoHeader(data, formatAndBits.Format, maxDoc, formatAndBits.BitsPerValue, PackedInt32s.DEFAULT_BUFFER_SIZE);
                     foreach (long? nv in values)
                     {
                         writer.Add(encode[nv == null ? 0 : nv.Value]);
@@ -169,7 +169,7 @@ namespace Lucene.Net.Codecs.Lucene42
             else if (gcd != 0 && gcd != 1)
             {
                 meta.WriteByte((byte)GCD_COMPRESSED);
-                meta.WriteVInt32(PackedInts.VERSION_CURRENT);
+                meta.WriteVInt32(PackedInt32s.VERSION_CURRENT);
                 data.WriteInt64(minValue);
                 data.WriteInt64(gcd);
                 data.WriteVInt32(BLOCK_SIZE);
@@ -186,7 +186,7 @@ namespace Lucene.Net.Codecs.Lucene42
             {
                 meta.WriteByte((byte)DELTA_COMPRESSED); // delta-compressed
 
-                meta.WriteVInt32(PackedInts.VERSION_CURRENT);
+                meta.WriteVInt32(PackedInt32s.VERSION_CURRENT);
                 data.WriteVInt32(BLOCK_SIZE);
 
                 var writer = new BlockPackedWriter(data, BLOCK_SIZE);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Codecs/Lucene42/Lucene42NormsFormat.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/Lucene42/Lucene42NormsFormat.cs b/src/Lucene.Net.Core/Codecs/Lucene42/Lucene42NormsFormat.cs
index e0f155b..66e0c3c 100644
--- a/src/Lucene.Net.Core/Codecs/Lucene42/Lucene42NormsFormat.cs
+++ b/src/Lucene.Net.Core/Codecs/Lucene42/Lucene42NormsFormat.cs
@@ -17,7 +17,7 @@ namespace Lucene.Net.Codecs.Lucene42
      * limitations under the License.
      */
 
-    using PackedInts = Lucene.Net.Util.Packed.PackedInts;
+    using PackedInt32s = Lucene.Net.Util.Packed.PackedInt32s;
     using SegmentReadState = Lucene.Net.Index.SegmentReadState;
     using SegmentWriteState = Lucene.Net.Index.SegmentWriteState;
 
@@ -26,7 +26,7 @@ namespace Lucene.Net.Codecs.Lucene42
     /// <p>
     /// NOTE: this uses the same format as <seealso cref="Lucene42DocValuesFormat"/>
     /// Numeric DocValues, but with different file extensions, and passing
-    /// <seealso cref="PackedInts#FASTEST"/> for uncompressed encoding: trading off
+    /// <seealso cref="PackedInt32s#FASTEST"/> for uncompressed encoding: trading off
     /// space for performance.
     /// <p>
     /// Files:
@@ -44,7 +44,7 @@ namespace Lucene.Net.Codecs.Lucene42
         /// Lucene42DocValuesFormat(PackedInts.FASTEST)}
         /// </summary>
         public Lucene42NormsFormat()
-            : this(PackedInts.FASTEST)
+            : this(PackedInt32s.FASTEST)
         {
             // note: we choose FASTEST here (otherwise our norms are half as big but 15% slower than previous lucene)
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Codecs/Lucene45/Lucene45DocValuesConsumer.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/Lucene45/Lucene45DocValuesConsumer.cs b/src/Lucene.Net.Core/Codecs/Lucene45/Lucene45DocValuesConsumer.cs
index ef643b8..360d68a 100644
--- a/src/Lucene.Net.Core/Codecs/Lucene45/Lucene45DocValuesConsumer.cs
+++ b/src/Lucene.Net.Core/Codecs/Lucene45/Lucene45DocValuesConsumer.cs
@@ -31,7 +31,7 @@ namespace Lucene.Net.Codecs.Lucene45
     using IOUtils = Lucene.Net.Util.IOUtils;
     using MathUtil = Lucene.Net.Util.MathUtil;
     using MonotonicBlockPackedWriter = Lucene.Net.Util.Packed.MonotonicBlockPackedWriter;
-    using PackedInts = Lucene.Net.Util.Packed.PackedInts;
+    using PackedInt32s = Lucene.Net.Util.Packed.PackedInt32s;
     using RAMOutputStream = Lucene.Net.Store.RAMOutputStream;
     using SegmentWriteState = Lucene.Net.Index.SegmentWriteState;
     using StringHelper = Lucene.Net.Util.StringHelper;
@@ -183,7 +183,7 @@ namespace Lucene.Net.Codecs.Lucene45
             long delta = maxValue - minValue;
 
             int format;
-            if (uniqueValues != null && (delta < 0L || PackedInts.BitsRequired(uniqueValues.Count - 1) < PackedInts.BitsRequired(delta)) && count <= int.MaxValue)
+            if (uniqueValues != null && (delta < 0L || PackedInt32s.BitsRequired(uniqueValues.Count - 1) < PackedInt32s.BitsRequired(delta)) && count <= int.MaxValue)
             {
                 format = TABLE_COMPRESSED;
             }
@@ -207,7 +207,7 @@ namespace Lucene.Net.Codecs.Lucene45
             {
                 meta.WriteInt64(-1L);
             }
-            meta.WriteVInt32(PackedInts.VERSION_CURRENT);
+            meta.WriteVInt32(PackedInt32s.VERSION_CURRENT);
             meta.WriteInt64(data.FilePointer);
             meta.WriteVInt64(count);
             meta.WriteVInt32(BLOCK_SIZE);
@@ -246,8 +246,8 @@ namespace Lucene.Net.Codecs.Lucene45
                         meta.WriteInt64(decode[i]);
                         encode[decode[i]] = i;
                     }
-                    int bitsRequired = PackedInts.BitsRequired(uniqueValues.Count - 1);
-                    PackedInts.Writer ordsWriter = PackedInts.GetWriterNoHeader(data, PackedInts.Format.PACKED, (int)count, bitsRequired, PackedInts.DEFAULT_BUFFER_SIZE);
+                    int bitsRequired = PackedInt32s.BitsRequired(uniqueValues.Count - 1);
+                    PackedInt32s.Writer ordsWriter = PackedInt32s.GetWriterNoHeader(data, PackedInt32s.Format.PACKED, (int)count, bitsRequired, PackedInt32s.DEFAULT_BUFFER_SIZE);
                     foreach (long? nv in values)
                     {
                         ordsWriter.Add(encode[nv == null ? 0 : nv.Value]);
@@ -336,7 +336,7 @@ namespace Lucene.Net.Codecs.Lucene45
             if (minLength != maxLength)
             {
                 meta.WriteInt64(data.FilePointer);
-                meta.WriteVInt32(PackedInts.VERSION_CURRENT);
+                meta.WriteVInt32(PackedInt32s.VERSION_CURRENT);
                 meta.WriteVInt32(BLOCK_SIZE);
 
                 MonotonicBlockPackedWriter writer = new MonotonicBlockPackedWriter(data, BLOCK_SIZE);
@@ -414,7 +414,7 @@ namespace Lucene.Net.Codecs.Lucene45
                 meta.WriteInt64(startFP);
                 meta.WriteVInt32(ADDRESS_INTERVAL);
                 meta.WriteInt64(indexStartFP);
-                meta.WriteVInt32(PackedInts.VERSION_CURRENT);
+                meta.WriteVInt32(PackedInt32s.VERSION_CURRENT);
                 meta.WriteVInt32(BLOCK_SIZE);
             }
         }
@@ -459,7 +459,7 @@ namespace Lucene.Net.Codecs.Lucene45
             meta.WriteByte((byte)Lucene45DocValuesFormat.NUMERIC);
             meta.WriteVInt32(DELTA_COMPRESSED);
             meta.WriteInt64(-1L);
-            meta.WriteVInt32(PackedInts.VERSION_CURRENT);
+            meta.WriteVInt32(PackedInt32s.VERSION_CURRENT);
             meta.WriteInt64(data.FilePointer);
             meta.WriteVInt64(maxDoc);
             meta.WriteVInt32(BLOCK_SIZE);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Codecs/Lucene45/Lucene45DocValuesProducer.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/Lucene45/Lucene45DocValuesProducer.cs b/src/Lucene.Net.Core/Codecs/Lucene45/Lucene45DocValuesProducer.cs
index e6ccc17..a6f15d4 100644
--- a/src/Lucene.Net.Core/Codecs/Lucene45/Lucene45DocValuesProducer.cs
+++ b/src/Lucene.Net.Core/Codecs/Lucene45/Lucene45DocValuesProducer.cs
@@ -36,10 +36,10 @@ namespace Lucene.Net.Codecs.Lucene45
     using IndexFileNames = Lucene.Net.Index.IndexFileNames;
     using IndexInput = Lucene.Net.Store.IndexInput;
     using IOUtils = Lucene.Net.Util.IOUtils;
-    using LongValues = Lucene.Net.Util.LongValues;
+    using Int64Values = Lucene.Net.Util.Int64Values;
     using MonotonicBlockPackedReader = Lucene.Net.Util.Packed.MonotonicBlockPackedReader;
     using NumericDocValues = Lucene.Net.Index.NumericDocValues;
-    using PackedInts = Lucene.Net.Util.Packed.PackedInts;
+    using PackedInt32s = Lucene.Net.Util.Packed.PackedInt32s;
     using RamUsageEstimator = Lucene.Net.Util.RamUsageEstimator;
     using RandomAccessOrds = Lucene.Net.Index.RandomAccessOrds;
     using SegmentReadState = Lucene.Net.Index.SegmentReadState;
@@ -56,7 +56,7 @@ namespace Lucene.Net.Codecs.Lucene45
         private readonly IDictionary<int, SortedSetEntry> sortedSets;
         private readonly IDictionary<int, NumericEntry> ords;
         private readonly IDictionary<int, NumericEntry> ordIndexes;
-        private readonly AtomicLong ramBytesUsed;
+        private readonly AtomicInt64 ramBytesUsed;
         private readonly IndexInput data;
         private readonly int maxDoc;
         private readonly int version;
@@ -131,7 +131,7 @@ namespace Lucene.Net.Codecs.Lucene45
                 }
             }
 
-            ramBytesUsed = new AtomicLong(RamUsageEstimator.ShallowSizeOfInstance(this.GetType()));
+            ramBytesUsed = new AtomicInt64(RamUsageEstimator.ShallowSizeOfInstance(this.GetType()));
         }
 
         private void ReadSortedField(int fieldNumber, IndexInput meta, FieldInfos infos)
@@ -369,7 +369,7 @@ namespace Lucene.Net.Codecs.Lucene45
             }
         }
 
-        internal virtual LongValues GetNumeric(NumericEntry entry)
+        internal virtual Int64Values GetNumeric(NumericEntry entry)
         {
             IndexInput data = (IndexInput)this.data.Clone();
             data.Seek(entry.Offset);
@@ -384,20 +384,20 @@ namespace Lucene.Net.Codecs.Lucene45
                     long min = entry.minValue;
                     long mult = entry.gcd;
                     BlockPackedReader quotientReader = new BlockPackedReader(data, entry.PackedInt32sVersion, entry.BlockSize, entry.Count, true);
-                    return new LongValuesAnonymousInnerClassHelper(this, min, mult, quotientReader);
+                    return new Int64ValuesAnonymousInnerClassHelper(this, min, mult, quotientReader);
 
                 case Lucene45DocValuesConsumer.TABLE_COMPRESSED:
                     long[] table = entry.table;
-                    int bitsRequired = PackedInts.BitsRequired(table.Length - 1);
-                    PackedInts.Reader ords = PackedInts.GetDirectReaderNoHeader(data, PackedInts.Format.PACKED, entry.PackedInt32sVersion, (int)entry.Count, bitsRequired);
-                    return new LongValuesAnonymousInnerClassHelper2(this, table, ords);
+                    int bitsRequired = PackedInt32s.BitsRequired(table.Length - 1);
+                    PackedInt32s.Reader ords = PackedInt32s.GetDirectReaderNoHeader(data, PackedInt32s.Format.PACKED, entry.PackedInt32sVersion, (int)entry.Count, bitsRequired);
+                    return new Int64ValuesAnonymousInnerClassHelper2(this, table, ords);
 
                 default:
                     throw new Exception();
             }
         }
 
-        private class LongValuesAnonymousInnerClassHelper : LongValues
+        private class Int64ValuesAnonymousInnerClassHelper : Int64Values
         {
             private readonly Lucene45DocValuesProducer outerInstance;
 
@@ -405,7 +405,7 @@ namespace Lucene.Net.Codecs.Lucene45
             private long mult;
             private BlockPackedReader quotientReader;
 
-            public LongValuesAnonymousInnerClassHelper(Lucene45DocValuesProducer outerInstance, long min, long mult, BlockPackedReader quotientReader)
+            public Int64ValuesAnonymousInnerClassHelper(Lucene45DocValuesProducer outerInstance, long min, long mult, BlockPackedReader quotientReader)
             {
                 this.outerInstance = outerInstance;
                 this.min = min;
@@ -419,14 +419,14 @@ namespace Lucene.Net.Codecs.Lucene45
             }
         }
 
-        private class LongValuesAnonymousInnerClassHelper2 : LongValues
+        private class Int64ValuesAnonymousInnerClassHelper2 : Int64Values
         {
             private readonly Lucene45DocValuesProducer outerInstance;
 
             private long[] table;
-            private PackedInts.Reader ords;
+            private PackedInt32s.Reader ords;
 
-            public LongValuesAnonymousInnerClassHelper2(Lucene45DocValuesProducer outerInstance, long[] table, PackedInts.Reader ords)
+            public Int64ValuesAnonymousInnerClassHelper2(Lucene45DocValuesProducer outerInstance, long[] table, PackedInt32s.Reader ords)
             {
                 this.outerInstance = outerInstance;
                 this.table = table;
@@ -462,17 +462,17 @@ namespace Lucene.Net.Codecs.Lucene45
         {
             IndexInput data = (IndexInput)this.data.Clone();
 
-            return new LongBinaryDocValuesAnonymousInnerClassHelper(this, bytes, data);
+            return new Int64BinaryDocValuesAnonymousInnerClassHelper(this, bytes, data);
         }
 
-        private class LongBinaryDocValuesAnonymousInnerClassHelper : LongBinaryDocValues
+        private class Int64BinaryDocValuesAnonymousInnerClassHelper : Int64BinaryDocValues
         {
             private readonly Lucene45DocValuesProducer outerInstance;
 
             private Lucene45DocValuesProducer.BinaryEntry bytes;
             private IndexInput data;
 
-            public LongBinaryDocValuesAnonymousInnerClassHelper(Lucene45DocValuesProducer outerInstance, Lucene45DocValuesProducer.BinaryEntry bytes, IndexInput data)
+            public Int64BinaryDocValuesAnonymousInnerClassHelper(Lucene45DocValuesProducer outerInstance, Lucene45DocValuesProducer.BinaryEntry bytes, IndexInput data)
             {
                 this.outerInstance = outerInstance;
                 this.bytes = bytes;
@@ -528,10 +528,10 @@ namespace Lucene.Net.Codecs.Lucene45
 
             MonotonicBlockPackedReader addresses = GetAddressInstance(data, field, bytes);
 
-            return new LongBinaryDocValuesAnonymousInnerClassHelper2(this, bytes, data, addresses);
+            return new Int64BinaryDocValuesAnonymousInnerClassHelper2(this, bytes, data, addresses);
         }
 
-        private class LongBinaryDocValuesAnonymousInnerClassHelper2 : LongBinaryDocValues
+        private class Int64BinaryDocValuesAnonymousInnerClassHelper2 : Int64BinaryDocValues
         {
             private readonly Lucene45DocValuesProducer outerInstance;
 
@@ -539,7 +539,7 @@ namespace Lucene.Net.Codecs.Lucene45
             private IndexInput data;
             private MonotonicBlockPackedReader addresses;
 
-            public LongBinaryDocValuesAnonymousInnerClassHelper2(Lucene45DocValuesProducer outerInstance, Lucene45DocValuesProducer.BinaryEntry bytes, IndexInput data, MonotonicBlockPackedReader addresses)
+            public Int64BinaryDocValuesAnonymousInnerClassHelper2(Lucene45DocValuesProducer outerInstance, Lucene45DocValuesProducer.BinaryEntry bytes, IndexInput data, MonotonicBlockPackedReader addresses)
             {
                 this.outerInstance = outerInstance;
                 this.bytes = bytes;
@@ -720,8 +720,8 @@ namespace Lucene.Net.Codecs.Lucene45
             IndexInput data = (IndexInput)this.data.Clone();
             long valueCount = binaries[field.Number].Count;
             // we keep the byte[]s and list of ords on disk, these could be large
-            LongBinaryDocValues binary = (LongBinaryDocValues)GetBinary(field);
-            LongValues ordinals = GetNumeric(ords[field.Number]);
+            Int64BinaryDocValues binary = (Int64BinaryDocValues)GetBinary(field);
+            Int64Values ordinals = GetNumeric(ords[field.Number]);
             // but the addresses to the ord stream are in RAM
             MonotonicBlockPackedReader ordIndex = GetOrdIndexInstance(data, field, ordIndexes[field.Number]);
 
@@ -733,11 +733,11 @@ namespace Lucene.Net.Codecs.Lucene45
             private readonly Lucene45DocValuesProducer outerInstance;
 
             private long valueCount;
-            private Lucene45DocValuesProducer.LongBinaryDocValues binary;
-            private LongValues ordinals;
+            private Lucene45DocValuesProducer.Int64BinaryDocValues binary;
+            private Int64Values ordinals;
             private MonotonicBlockPackedReader ordIndex;
 
-            public RandomAccessOrdsAnonymousInnerClassHelper(Lucene45DocValuesProducer outerInstance, long valueCount, Lucene45DocValuesProducer.LongBinaryDocValues binary, LongValues ordinals, MonotonicBlockPackedReader ordIndex)
+            public RandomAccessOrdsAnonymousInnerClassHelper(Lucene45DocValuesProducer outerInstance, long valueCount, Lucene45DocValuesProducer.Int64BinaryDocValues binary, Int64Values ordinals, MonotonicBlockPackedReader ordIndex)
             {
                 this.outerInstance = outerInstance;
                 this.valueCount = valueCount;
@@ -990,7 +990,10 @@ namespace Lucene.Net.Codecs.Lucene45
         }
 
         // internally we compose complex dv (sorted/sortedset) from other ones
-        internal abstract class LongBinaryDocValues : BinaryDocValues
+        /// <summary>
+        /// NOTE: This was LongBinaryDocValues in Lucene
+        /// </summary>
+        internal abstract class Int64BinaryDocValues : BinaryDocValues
         {
             public override sealed void Get(int docID, BytesRef result)
             {
@@ -1002,7 +1005,7 @@ namespace Lucene.Net.Codecs.Lucene45
 
         // in the compressed case, we add a few additional operations for
         // more efficient reverse lookup and enumeration
-        internal class CompressedBinaryDocValues : LongBinaryDocValues
+        internal class CompressedBinaryDocValues : Int64BinaryDocValues
         {
             internal readonly BinaryEntry bytes;
             internal readonly long interval;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Document/DateTools.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Document/DateTools.cs b/src/Lucene.Net.Core/Document/DateTools.cs
index 63d0e2a..7154124 100644
--- a/src/Lucene.Net.Core/Document/DateTools.cs
+++ b/src/Lucene.Net.Core/Document/DateTools.cs
@@ -35,7 +35,7 @@ namespace Lucene.Net.Documents
     /// date/time are.
     /// For indexing a <seealso cref="Date"/> or <seealso cref="Calendar"/>, just get the unix timestamp as
     /// <code>long</code> using <seealso cref="Date#getTime"/> or <seealso cref="Calendar#getTimeInMillis"/> and
-    /// index this as a numeric value with <seealso cref="LongField"/>
+    /// index this as a numeric value with <seealso cref="Int64Field"/>
     /// and use <seealso cref="NumericRangeQuery"/> to query it.
     /// </summary>
     public static class DateTools

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Document/Document.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Document/Document.cs b/src/Lucene.Net.Core/Document/Document.cs
index 09d0a89..0918802 100644
--- a/src/Lucene.Net.Core/Document/Document.cs
+++ b/src/Lucene.Net.Core/Document/Document.cs
@@ -228,7 +228,7 @@ namespace Lucene.Net.Documents
         /// Returns an array of values of the field specified as the method parameter.
         /// this method returns an empty array when there are no
         /// matching fields.  It never returns null.
-        /// For <seealso cref="IntField"/>, <seealso cref="LongField"/>, {@link
+        /// For <seealso cref="Int32Field"/>, <seealso cref="Int64Field"/>, {@link
         /// FloatField} and <seealso cref="DoubleField"/> it returns the string value of the number. If you want
         /// the actual numeric field instances back, use <seealso cref="#getFields"/>. </summary>
         /// <param name="name"> the name of the field </param>
@@ -257,7 +257,7 @@ namespace Lucene.Net.Documents
         /// this document, or null.  If multiple fields exist with this name, this
         /// method returns the first value added. If only binary fields with this name
         /// exist, returns null.
-        /// For <seealso cref="IntField"/>, <seealso cref="LongField"/>, {@link
+        /// For <seealso cref="Int32Field"/>, <seealso cref="Int64Field"/>, {@link
         /// FloatField} and <seealso cref="DoubleField"/> it returns the string value of the number. If you want
         /// the actual numeric field instance back, use <seealso cref="#getField"/>.
         /// </summary>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Document/DoubleField.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Document/DoubleField.cs b/src/Lucene.Net.Core/Document/DoubleField.cs
index 22c5ba8..d53c652 100644
--- a/src/Lucene.Net.Core/Document/DoubleField.cs
+++ b/src/Lucene.Net.Core/Document/DoubleField.cs
@@ -45,7 +45,7 @@ namespace Lucene.Net.Documents
     ///  }
     /// </pre>
     ///
-    /// See also <seealso cref="IntField"/>, <seealso cref="LongField"/>, {@link
+    /// See also <seealso cref="Int32Field"/>, <seealso cref="Int64Field"/>, {@link
     /// FloatField}.</p>
     ///
     /// <p>To perform range querying or filtering against a

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Document/Field.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Document/Field.cs b/src/Lucene.Net.Core/Document/Field.cs
index dfffb9e..fffd5d1 100644
--- a/src/Lucene.Net.Core/Document/Field.cs
+++ b/src/Lucene.Net.Core/Document/Field.cs
@@ -28,7 +28,7 @@ namespace Lucene.Net.Documents
     /// <summary>
     /// Expert: directly create a field for a document.  Most
     /// users should use one of the sugar subclasses: {@link
-    /// IntField}, <seealso cref="LongField"/>, <seealso cref="FloatField"/>, {@link
+    /// IntField}, <seealso cref="Int64Field"/>, <seealso cref="SingleField"/>, {@link
     /// DoubleField}, <seealso cref="BinaryDocValuesField"/>, {@link
     /// NumericDocValuesField}, <seealso cref="SortedDocValuesField"/>, {@link
     /// StringField}, <seealso cref="TextField"/>, <seealso cref="StoredField"/>.

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Document/FloatDocValuesField.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Document/FloatDocValuesField.cs b/src/Lucene.Net.Core/Document/FloatDocValuesField.cs
index 8c02eca..fb0d171 100644
--- a/src/Lucene.Net.Core/Document/FloatDocValuesField.cs
+++ b/src/Lucene.Net.Core/Document/FloatDocValuesField.cs
@@ -20,22 +20,26 @@ namespace Lucene.Net.Documents
     /// <summary>
     /// Syntactic sugar for encoding floats as NumericDocValues
     /// via <seealso cref="Float#floatToRawIntBits(float)"/>.
-    /// <p>
+    /// <para>
     /// Per-document floating point values can be retrieved via
-    /// <seealso cref="IFieldCache#getFloats(AtomicReader, String, boolean)"/>.</p>
-    /// <p>
+    /// <seealso cref="IFieldCache#getFloats(AtomicReader, String, boolean)"/>.</para>
+    /// <para>
     /// <b>NOTE</b>: In most all cases this will be rather inefficient,
     /// requiring four bytes per document. Consider encoding floating
-    /// point values yourself with only as much precision as you require.</p>
+    /// point values yourself with only as much precision as you require.
+    /// </para>
+    /// <para>
+    /// NOTE: This was FloatDocValuesField in Lucene
+    /// </para>
     /// </summary>
-    public class FloatDocValuesField : NumericDocValuesField
+    public class SingleDocValuesField : NumericDocValuesField
     {
         /// <summary>
-        /// Creates a new DocValues field with the specified 32-bit float value </summary>
+        /// Creates a new DocValues field with the specified 32-bit <see cref="float"/> value </summary>
         /// <param name="name"> field name </param>
-        /// <param name="value"> 32-bit float value </param>
+        /// <param name="value"> 32-bit <see cref="float"/> value </param>
         /// <exception cref="ArgumentException"> if the field name is null </exception>
-        public FloatDocValuesField(string name, float value)
+        public SingleDocValuesField(string name, float value)
             : base(name, Support.Number.SingleToInt32Bits(value))
         {
         }


[34/53] [abbrv] lucenenet git commit: Lucene.Net.Codecs: Renamed all type-derived classes and interfaces from Short, Int, Long, and Float to match CLR types Int16, Int32, Int64, and Single, respectively.

Posted by ni...@apache.org.
Lucene.Net.Codecs: Renamed all type-derived classes and interfaces from Short, Int, Long, and Float to match CLR types Int16, Int32, Int64, and Single, respectively.


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

Branch: refs/heads/api-work
Commit: d3dfb9500a8f2af50c8783d141745f568795988c
Parents: 0ff7988
Author: Shad Storhaug <sh...@shadstorhaug.com>
Authored: Wed Feb 8 02:33:23 2017 +0700
Committer: Shad Storhaug <sh...@shadstorhaug.com>
Committed: Wed Feb 8 21:08:23 2017 +0700

----------------------------------------------------------------------
 .../IntBlock/FixedIntBlockIndexInput.cs         | 10 +++--
 .../IntBlock/FixedIntBlockIndexOutput.cs        | 20 +++++-----
 .../IntBlock/VariableIntBlockIndexInput.cs      | 10 +++--
 .../IntBlock/VariableIntBlockIndexOutput.cs     | 20 +++++-----
 .../Memory/DirectPostingsFormat.cs              |  7 +++-
 src/Lucene.Net.Codecs/Sep/IntIndexInput.cs      | 12 +++---
 src/Lucene.Net.Codecs/Sep/IntIndexOutput.cs     |  4 +-
 src/Lucene.Net.Codecs/Sep/IntStreamFactory.cs   | 12 +++---
 src/Lucene.Net.Codecs/Sep/SepPostingsReader.cs  | 40 ++++++++++----------
 src/Lucene.Net.Codecs/Sep/SepPostingsWriter.cs  | 22 +++++------
 src/Lucene.Net.Codecs/Sep/SepSkipListReader.cs  | 30 +++++++--------
 src/Lucene.Net.Codecs/Sep/SepSkipListWriter.cs  | 26 ++++++-------
 .../MockFixedIntBlockPostingsFormat.cs          | 14 +++----
 .../MockVariableIntBlockPostingsFormat.cs       | 12 +++---
 .../Codecs/MockSep/MockSingleIntFactory.cs      |  6 +--
 .../Codecs/MockSep/MockSingleIntIndexInput.cs   |  2 +-
 .../Codecs/MockSep/MockSingleIntIndexOutput.cs  |  2 +-
 .../IntBlock/TestIntBlockCodec.cs               | 14 +++----
 18 files changed, 140 insertions(+), 123 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/lucenenet/blob/d3dfb950/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
index 23cbd4c..4cce99b 100644
--- a/src/Lucene.Net.Codecs/IntBlock/FixedIntBlockIndexInput.cs
+++ b/src/Lucene.Net.Codecs/IntBlock/FixedIntBlockIndexInput.cs
@@ -31,15 +31,17 @@ namespace Lucene.Net.Codecs.IntBlock
     ///  more performant approach would directly create an impl
     ///  of IntIndexInput inside Directory.  Wrapping a generic
     ///  IndexInput will likely cost performance.
+    /// <para/>
+    /// NOTE: This was FixedIntBlockIndexInput in Lucene
     /// 
     /// @lucene.experimental
     /// </summary>
-    public abstract class FixedIntBlockIndexInput : IntIndexInput
+    public abstract class FixedInt32BlockIndexInput : Int32IndexInput
     {
         private readonly IndexInput input;
         protected readonly int m_blockSize;
 
-        public FixedIntBlockIndexInput(IndexInput @in)
+        public FixedInt32BlockIndexInput(IndexInput @in)
         {
             input = @in;
             m_blockSize = @in.ReadVInt32();
@@ -132,9 +134,9 @@ namespace Lucene.Net.Codecs.IntBlock
 
         private class Index : AbstractIndex
         {
-            private readonly FixedIntBlockIndexInput outerInstance;
+            private readonly FixedInt32BlockIndexInput outerInstance;
 
-            public Index(FixedIntBlockIndexInput outerInstance)
+            public Index(FixedInt32BlockIndexInput outerInstance)
             {
                 this.outerInstance = outerInstance;
             }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/d3dfb950/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
index 90672d5..b60b70a 100644
--- a/src/Lucene.Net.Codecs/IntBlock/FixedIntBlockIndexOutput.cs
+++ b/src/Lucene.Net.Codecs/IntBlock/FixedIntBlockIndexOutput.cs
@@ -21,11 +21,11 @@ namespace Lucene.Net.Codecs.IntBlock
      * limitations under the License.
      */
 
-    /// <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. 
-    /// </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. 
+
 
 
     /// <summary>
@@ -34,17 +34,19 @@ namespace Lucene.Net.Codecs.IntBlock
     ///  more performant approach would directly create an impl
     ///  of IntIndexOutput inside Directory.  Wrapping a generic
     ///  IndexInput will likely cost performance.
+    /// <para/>
+    /// NOTE: This was FixedIntBlockIndexOutput in Lucene
     /// 
     /// @lucene.experimental
     /// </summary>
-    public abstract class FixedIntBlockIndexOutput : IntIndexOutput
+    public abstract class FixedInt32BlockIndexOutput : Int32IndexOutput
     {
         protected readonly IndexOutput m_output;
         private readonly int blockSize;
         protected readonly int[] m_buffer;
         private int upto;
 
-        protected FixedIntBlockIndexOutput(IndexOutput output, int fixedBlockSize)
+        protected FixedInt32BlockIndexOutput(IndexOutput output, int fixedBlockSize)
         {
             blockSize = fixedBlockSize;
             this.m_output = output;
@@ -61,9 +63,9 @@ namespace Lucene.Net.Codecs.IntBlock
 
         private class Index : AbstractIndex
         {
-            private readonly FixedIntBlockIndexOutput outerInstance;
+            private readonly FixedInt32BlockIndexOutput outerInstance;
 
-            public Index(FixedIntBlockIndexOutput outerInstance)
+            public Index(FixedInt32BlockIndexOutput outerInstance)
             {
                 this.outerInstance = outerInstance;
             }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/d3dfb950/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
index e388124..1fda534 100644
--- a/src/Lucene.Net.Codecs/IntBlock/VariableIntBlockIndexInput.cs
+++ b/src/Lucene.Net.Codecs/IntBlock/VariableIntBlockIndexInput.cs
@@ -35,15 +35,17 @@ namespace Lucene.Net.Codecs.IntBlock
     /// more performant approach would directly create an impl
     /// of IntIndexInput inside Directory.  Wrapping a generic
     /// IndexInput will likely cost performance.
+    /// <para/>
+    /// NOTE: This was VariableIntBlockIndexInput in Lucene
     /// 
     /// @lucene.experimental
     /// </summary>
-    public abstract class VariableIntBlockIndexInput : IntIndexInput
+    public abstract class VariableInt32BlockIndexInput : Int32IndexInput
     {
         private readonly IndexInput input;
         protected readonly int m_maxBlockSize;
 
-        protected internal VariableIntBlockIndexInput(IndexInput input)
+        protected internal VariableInt32BlockIndexInput(IndexInput input)
         {
             this.input = input;
             m_maxBlockSize = input.ReadInt32();
@@ -165,9 +167,9 @@ namespace Lucene.Net.Codecs.IntBlock
 
         private class Index : AbstractIndex
         {
-            private readonly VariableIntBlockIndexInput outerInstance;
+            private readonly VariableInt32BlockIndexInput outerInstance;
 
-            public Index(VariableIntBlockIndexInput outerInstance)
+            public Index(VariableInt32BlockIndexInput outerInstance)
             {
                 this.outerInstance = outerInstance;
             }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/d3dfb950/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
index b52ae38..a59a6b1 100644
--- a/src/Lucene.Net.Codecs/IntBlock/VariableIntBlockIndexOutput.cs
+++ b/src/Lucene.Net.Codecs/IntBlock/VariableIntBlockIndexOutput.cs
@@ -21,11 +21,11 @@ namespace Lucene.Net.Codecs.IntBlock
      * limitations under the License.
      */
 
-    /// <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. 
-    /// </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. 
+
 
 
     // TODO: much of this can be shared code w/ the fixed case
@@ -36,10 +36,12 @@ namespace Lucene.Net.Codecs.IntBlock
     ///  more performant approach would directly create an impl
     ///  of IntIndexOutput inside Directory.  Wrapping a generic
     ///  IndexInput will likely cost performance.
+    /// <para/>
+    /// NOTE: This was VariableIntBlockIndexOutput in Lucene
     /// 
     /// @lucene.experimental
     /// </summary>
-    public abstract class VariableIntBlockIndexOutput : IntIndexOutput
+    public abstract class VariableInt32BlockIndexOutput : Int32IndexOutput
     {
         protected readonly IndexOutput m_output;
 
@@ -55,7 +57,7 @@ namespace Lucene.Net.Codecs.IntBlock
         ///  requires lookahead=1 because on seeing the Nth value
         ///  it knows it must now encode the N-1 values before it. 
         /// </summary>
-        protected VariableIntBlockIndexOutput(IndexOutput output, int maxBlockSize)
+        protected VariableInt32BlockIndexOutput(IndexOutput output, int maxBlockSize)
         {
             this.m_output = output;
             this.m_output.WriteInt32(maxBlockSize);
@@ -74,9 +76,9 @@ namespace Lucene.Net.Codecs.IntBlock
 
         private class Index : AbstractIndex
         {
-            private readonly VariableIntBlockIndexOutput outerInstance;
+            private readonly VariableInt32BlockIndexOutput outerInstance;
 
-            public Index(VariableIntBlockIndexOutput outerInstance)
+            public Index(VariableInt32BlockIndexOutput outerInstance)
             {
                 this.outerInstance = outerInstance;
             }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/d3dfb950/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
index 063d2f2..6bfbedf 100644
--- a/src/Lucene.Net.Codecs/Memory/DirectPostingsFormat.cs
+++ b/src/Lucene.Net.Codecs/Memory/DirectPostingsFormat.cs
@@ -355,7 +355,10 @@ namespace Lucene.Net.Codecs.Memory
             private int[] sameCounts = new int[10];
             private readonly int minSkipCount;
 
-            private sealed class IntArrayWriter
+            /// <summary>
+            /// NOTE: This was IntArrayWriter in Lucene
+            /// </summary>
+            private sealed class Int32ArrayWriter
             {
                 private int[] ints = new int[10];
                 private int upto;
@@ -409,7 +412,7 @@ namespace Lucene.Net.Codecs.Memory
                 TermsEnum termsEnum = termsIn.GetIterator(null);
                 int termOffset = 0;
 
-                IntArrayWriter scratch = new IntArrayWriter();
+                Int32ArrayWriter scratch = new Int32ArrayWriter();
 
                 // Used for payloads, if any:
                 RAMOutputStream ros = new RAMOutputStream();

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/d3dfb950/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
index 5cc867e..efb853e 100644
--- a/src/Lucene.Net.Codecs/Sep/IntIndexInput.cs
+++ b/src/Lucene.Net.Codecs/Sep/IntIndexInput.cs
@@ -21,20 +21,22 @@ namespace Lucene.Net.Codecs.Sep
      */
 
     /// <summary>
-    /// Defines basic API for writing ints to an IndexOutput.
-    ///  IntBlockCodec interacts with this API. @see
-    ///  IntBlockReader
+    /// Defines basic API for writing ints to an <see cref="IndexOutput"/>.
+    /// IntBlockCodec interacts with this API. @see
+    /// IntBlockReader
+    /// <para/>
+    /// NOTE: This was IntIndexInput in Lucene
     /// 
     /// @lucene.experimental 
     /// </summary>
-    public abstract class IntIndexInput : IDisposable
+    public abstract class Int32IndexInput : IDisposable
     {
         public abstract AbstractReader GetReader();
         public abstract void Dispose();
         public abstract AbstractIndex GetIndex();
 
         /// <summary>
-        /// Records a single skip-point in the <see cref="IntIndexInput.GetReader"/>. </summary>
+        /// Records a single skip-point in the <see cref="Int32IndexInput.GetReader"/>. </summary>
         public abstract class AbstractIndex
         {
             public abstract void Read(DataInput indexIn, bool absolute);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/d3dfb950/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
index 2744ae2..65eecec 100644
--- a/src/Lucene.Net.Codecs/Sep/IntIndexOutput.cs
+++ b/src/Lucene.Net.Codecs/Sep/IntIndexOutput.cs
@@ -25,6 +25,8 @@ namespace Lucene.Net.Codecs.Sep
     /// IntBlockCodec interacts with this API. @see IntBlockReader.
     /// 
     /// NOTE: block sizes could be variable
+    /// <para/>
+    /// NOTE: This was IntIndexOutput in Lucene
     /// 
     /// @lucene.experimental 
     /// </summary>
@@ -32,7 +34,7 @@ namespace Lucene.Net.Codecs.Sep
     /// TODO: We may want tighter integration w/IndexOutput
     /// may give better performance
     /// </remarks>
-    public abstract class IntIndexOutput : IDisposable
+    public abstract class Int32IndexOutput : IDisposable
     {
         /// <summary>
         /// Write an int to the primary file.  The value must be

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/d3dfb950/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
index f3f0c49..09f0915 100644
--- a/src/Lucene.Net.Codecs/Sep/IntStreamFactory.cs
+++ b/src/Lucene.Net.Codecs/Sep/IntStreamFactory.cs
@@ -21,19 +21,21 @@ namespace Lucene.Net.Codecs.Sep
 
     /// <summary>
     /// Provides int reader and writer to specified files.
+    /// <para/>
+    /// NOTE: This was IntStreamFactory in Lucene
     /// 
     /// @lucene.experimental 
     /// </summary>
-    public abstract class IntStreamFactory
+    public abstract class Int32StreamFactory
     {
         /// <summary>
-        /// Create an <seealso cref="IntIndexInput"/> on the provided fileName. 
+        /// Create an <seealso cref="Int32IndexInput"/> on the provided fileName. 
         /// </summary>
-        public abstract IntIndexInput OpenInput(Directory dir, string fileName, IOContext context);
+        public abstract Int32IndexInput OpenInput(Directory dir, string fileName, IOContext context);
 
         /// <summary>
-        /// Create an <seealso cref="IntIndexOutput"/> on the provided fileName. 
+        /// Create an <seealso cref="Int32IndexOutput"/> on the provided fileName. 
         /// </summary>
-        public abstract IntIndexOutput CreateOutput(Directory dir, string fileName, IOContext context);
+        public abstract Int32IndexOutput CreateOutput(Directory dir, string fileName, IOContext context);
     }
 }
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/d3dfb950/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
index 97f35db..e4243dd 100644
--- a/src/Lucene.Net.Codecs/Sep/SepPostingsReader.cs
+++ b/src/Lucene.Net.Codecs/Sep/SepPostingsReader.cs
@@ -35,9 +35,9 @@ namespace Lucene.Net.Codecs.Sep
     /// </remarks>
     public class SepPostingsReader : PostingsReaderBase
     {
-        private readonly IntIndexInput _freqIn;
-        private readonly IntIndexInput _docIn;
-        private readonly IntIndexInput _posIn;
+        private readonly Int32IndexInput _freqIn;
+        private readonly Int32IndexInput _docIn;
+        private readonly Int32IndexInput _posIn;
         private readonly IndexInput _payloadIn;
         private readonly IndexInput _skipIn;
 
@@ -46,7 +46,7 @@ namespace Lucene.Net.Codecs.Sep
         private int _skipMinimum;
 
         public SepPostingsReader(Directory dir, FieldInfos fieldInfos, SegmentInfo segmentInfo, IOContext context,
-            IntStreamFactory intFactory, string segmentSuffix)
+            Int32StreamFactory intFactory, string segmentSuffix)
         {
             var success = false;
             try
@@ -119,9 +119,9 @@ namespace Lucene.Net.Codecs.Sep
             // 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:
-            internal IntIndexInput.AbstractIndex DOC_INDEX;
-            internal IntIndexInput.AbstractIndex POS_INDEX;
-            internal IntIndexInput.AbstractIndex FREQ_INDEX;
+            internal Int32IndexInput.AbstractIndex DOC_INDEX;
+            internal Int32IndexInput.AbstractIndex POS_INDEX;
+            internal Int32IndexInput.AbstractIndex FREQ_INDEX;
             internal long PAYLOAD_FP;
             internal long SKIP_FP;
 
@@ -308,14 +308,14 @@ namespace Lucene.Net.Codecs.Sep
             private IndexOptions _indexOptions;
             private bool _storePayloads;
             private IBits _liveDocs;
-            private readonly IntIndexInput.AbstractReader _docReader;
-            private readonly IntIndexInput.AbstractReader _freqReader;
+            private readonly Int32IndexInput.AbstractReader _docReader;
+            private readonly Int32IndexInput.AbstractReader _freqReader;
             private long _skipFp;
 
-            private readonly IntIndexInput.AbstractIndex _docIndex;
-            private readonly IntIndexInput.AbstractIndex _freqIndex;
-            private readonly IntIndexInput.AbstractIndex _posIndex;
-            internal IntIndexInput startDocIn;
+            private readonly Int32IndexInput.AbstractIndex _docIndex;
+            private readonly Int32IndexInput.AbstractIndex _freqIndex;
+            private readonly Int32IndexInput.AbstractIndex _posIndex;
+            internal Int32IndexInput startDocIn;
 
             // TODO: -- should we do hasProx with 2 different enum classes?
 
@@ -485,16 +485,16 @@ namespace Lucene.Net.Codecs.Sep
 
             private bool _storePayloads;
             private IBits _liveDocs;
-            private readonly IntIndexInput.AbstractReader _docReader;
-            private readonly IntIndexInput.AbstractReader _freqReader;
-            private readonly IntIndexInput.AbstractReader _posReader;
+            private readonly Int32IndexInput.AbstractReader _docReader;
+            private readonly Int32IndexInput.AbstractReader _freqReader;
+            private readonly Int32IndexInput.AbstractReader _posReader;
             private readonly IndexInput _payloadIn;
             private long _skipFp;
 
-            private readonly IntIndexInput.AbstractIndex _docIndex;
-            private readonly IntIndexInput.AbstractIndex _freqIndex;
-            private readonly IntIndexInput.AbstractIndex _posIndex;
-            internal IntIndexInput startDocIn;
+            private readonly Int32IndexInput.AbstractIndex _docIndex;
+            private readonly Int32IndexInput.AbstractIndex _freqIndex;
+            private readonly Int32IndexInput.AbstractIndex _posIndex;
+            internal Int32IndexInput startDocIn;
 
             private long _payloadFp;
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/d3dfb950/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
index ad2f89f..53dee93 100644
--- a/src/Lucene.Net.Codecs/Sep/SepPostingsWriter.cs
+++ b/src/Lucene.Net.Codecs/Sep/SepPostingsWriter.cs
@@ -42,14 +42,14 @@ namespace Lucene.Net.Codecs.Sep
         internal const int VERSION_START = 0;
         internal const int VERSION_CURRENT = VERSION_START;
 
-        internal IntIndexOutput freqOut;
-        internal IntIndexOutput.AbstractIndex freqIndex;
+        internal Int32IndexOutput freqOut;
+        internal Int32IndexOutput.AbstractIndex freqIndex;
 
-        internal IntIndexOutput posOut;
-        internal IntIndexOutput.AbstractIndex posIndex;
+        internal Int32IndexOutput posOut;
+        internal Int32IndexOutput.AbstractIndex posIndex;
 
-        internal IntIndexOutput docOut;
-        internal IntIndexOutput.AbstractIndex docIndex;
+        internal Int32IndexOutput docOut;
+        internal Int32IndexOutput.AbstractIndex docIndex;
 
         internal IndexOutput payloadOut;
 
@@ -96,12 +96,12 @@ namespace Lucene.Net.Codecs.Sep
         internal long lastPayloadFP;
         internal long lastSkipFP; 
 
-        public SepPostingsWriter(SegmentWriteState state, IntStreamFactory factory)
+        public SepPostingsWriter(SegmentWriteState state, Int32StreamFactory factory)
             : this(state, factory, DEFAULT_SKIP_INTERVAL)
         {
         }
 
-        public SepPostingsWriter(SegmentWriteState state, IntStreamFactory factory, int skipInterval)
+        public SepPostingsWriter(SegmentWriteState state, Int32StreamFactory factory, int skipInterval)
         {
             freqOut = null;
             freqIndex = null;
@@ -302,9 +302,9 @@ namespace Lucene.Net.Codecs.Sep
 
         private class SepTermState : BlockTermState
         {
-            public IntIndexOutput.AbstractIndex DocIndex { get; set; }
-            public IntIndexOutput.AbstractIndex FreqIndex { get; set; }
-            public IntIndexOutput.AbstractIndex PosIndex { get; set; }
+            public Int32IndexOutput.AbstractIndex DocIndex { get; set; }
+            public Int32IndexOutput.AbstractIndex FreqIndex { get; set; }
+            public Int32IndexOutput.AbstractIndex PosIndex { get; set; }
             public long PayloadFp { get; set; }
             public long SkipFp { get; set; }
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/d3dfb950/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
index aa090b5..09c677f 100644
--- a/src/Lucene.Net.Codecs/Sep/SepSkipListReader.cs
+++ b/src/Lucene.Net.Codecs/Sep/SepSkipListReader.cs
@@ -33,30 +33,30 @@ namespace Lucene.Net.Codecs.Sep
     internal class SepSkipListReader : MultiLevelSkipListReader
     {
         private bool _currentFieldStoresPayloads;
-        private readonly IntIndexInput.AbstractIndex[] _freqIndex;
-        private readonly IntIndexInput.AbstractIndex[] _docIndex;
-        private readonly IntIndexInput.AbstractIndex[] _posIndex;
+        private readonly Int32IndexInput.AbstractIndex[] _freqIndex;
+        private readonly Int32IndexInput.AbstractIndex[] _docIndex;
+        private readonly Int32IndexInput.AbstractIndex[] _posIndex;
         private readonly long[] _payloadPointer;
         private readonly int[] _payloadLength;
 
-        private readonly IntIndexInput.AbstractIndex _lastFreqIndex;
-        private readonly IntIndexInput.AbstractIndex _lastDocIndex;
-        private readonly IntIndexInput.AbstractIndex _lastPosIndex;
+        private readonly Int32IndexInput.AbstractIndex _lastFreqIndex;
+        private readonly Int32IndexInput.AbstractIndex _lastDocIndex;
+        private readonly Int32IndexInput.AbstractIndex _lastPosIndex;
 
         private long _lastPayloadPointer;
         private int _lastPayloadLength;
 
-        internal SepSkipListReader(IndexInput skipStream, IntIndexInput freqIn, IntIndexInput docIn, IntIndexInput posIn,
+        internal SepSkipListReader(IndexInput skipStream, Int32IndexInput freqIn, Int32IndexInput docIn, Int32IndexInput posIn,
             int maxSkipLevels, int skipInterval)
             : base(skipStream, maxSkipLevels, skipInterval)
         {
             if (freqIn != null)
-                _freqIndex = new IntIndexInput.AbstractIndex[maxSkipLevels];
+                _freqIndex = new Int32IndexInput.AbstractIndex[maxSkipLevels];
 
-            _docIndex = new IntIndexInput.AbstractIndex[maxSkipLevels];
+            _docIndex = new Int32IndexInput.AbstractIndex[maxSkipLevels];
 
             if (posIn != null)
-                _posIndex = new IntIndexInput.AbstractIndex[m_maxNumberOfSkipLevels];
+                _posIndex = new Int32IndexInput.AbstractIndex[m_maxNumberOfSkipLevels];
 
             for (var i = 0; i < maxSkipLevels; i++)
             {
@@ -84,8 +84,8 @@ namespace Lucene.Net.Codecs.Sep
             _indexOptions = v;
         }
 
-        internal virtual void Init(long skipPointer, IntIndexInput.AbstractIndex docBaseIndex, IntIndexInput.AbstractIndex freqBaseIndex,
-            IntIndexInput.AbstractIndex posBaseIndex, long payloadBasePointer, int df, bool storesPayloads)
+        internal virtual void Init(long skipPointer, Int32IndexInput.AbstractIndex docBaseIndex, Int32IndexInput.AbstractIndex freqBaseIndex,
+            Int32IndexInput.AbstractIndex posBaseIndex, long payloadBasePointer, int df, bool storesPayloads)
         {
             base.Init(skipPointer, df);
             _currentFieldStoresPayloads = storesPayloads;
@@ -153,17 +153,17 @@ namespace Lucene.Net.Codecs.Sep
                 _posIndex[level - 1].CopyFrom(_posIndex[level]);
         }
 
-        internal virtual IntIndexInput.AbstractIndex FreqIndex
+        internal virtual Int32IndexInput.AbstractIndex FreqIndex
         {
             get { return _lastFreqIndex; }
         }
 
-        internal virtual IntIndexInput.AbstractIndex PosIndex
+        internal virtual Int32IndexInput.AbstractIndex PosIndex
         {
             get { return _lastPosIndex; }
         }
 
-        internal virtual IntIndexInput.AbstractIndex DocIndex
+        internal virtual Int32IndexInput.AbstractIndex DocIndex
         {
             get { return _lastDocIndex; }
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/d3dfb950/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
index 6e5bc5c..e596347 100644
--- a/src/Lucene.Net.Codecs/Sep/SepSkipListWriter.cs
+++ b/src/Lucene.Net.Codecs/Sep/SepSkipListWriter.cs
@@ -38,12 +38,12 @@ namespace Lucene.Net.Codecs.Sep
         private readonly int[] _lastSkipPayloadLength;
         private readonly long[] _lastSkipPayloadPointer;
 
-        private readonly IntIndexOutput.AbstractIndex[] _docIndex;
-        private readonly IntIndexOutput.AbstractIndex[] _freqIndex;
-        private readonly IntIndexOutput.AbstractIndex[] _posIndex;
+        private readonly Int32IndexOutput.AbstractIndex[] _docIndex;
+        private readonly Int32IndexOutput.AbstractIndex[] _freqIndex;
+        private readonly Int32IndexOutput.AbstractIndex[] _posIndex;
 
-        private readonly IntIndexOutput _freqOutput;
-        private IntIndexOutput _posOutput;
+        private readonly Int32IndexOutput _freqOutput;
+        private Int32IndexOutput _posOutput;
         private IndexOutput _payloadOutput;
 
         private int _curDoc;
@@ -51,8 +51,8 @@ namespace Lucene.Net.Codecs.Sep
         private int _curPayloadLength;
         private long _curPayloadPointer;
 
-        internal SepSkipListWriter(int skipInterval, int numberOfSkipLevels, int docCount, IntIndexOutput freqOutput,
-            IntIndexOutput docOutput, IntIndexOutput posOutput, IndexOutput payloadOutput)
+        internal SepSkipListWriter(int skipInterval, int numberOfSkipLevels, int docCount, Int32IndexOutput freqOutput,
+            Int32IndexOutput docOutput, Int32IndexOutput posOutput, IndexOutput payloadOutput)
             : base(skipInterval, numberOfSkipLevels, docCount)
         {
 
@@ -65,9 +65,9 @@ namespace Lucene.Net.Codecs.Sep
             // TODO: -- also cutover normal IndexOutput to use getIndex()?
             _lastSkipPayloadPointer = new long[numberOfSkipLevels];
 
-            _freqIndex = new IntIndexOutput.AbstractIndex[numberOfSkipLevels];
-            _docIndex = new IntIndexOutput.AbstractIndex[numberOfSkipLevels];
-            _posIndex = new IntIndexOutput.AbstractIndex[numberOfSkipLevels];
+            _freqIndex = new Int32IndexOutput.AbstractIndex[numberOfSkipLevels];
+            _docIndex = new Int32IndexOutput.AbstractIndex[numberOfSkipLevels];
+            _posIndex = new Int32IndexOutput.AbstractIndex[numberOfSkipLevels];
 
             for (var i = 0; i < numberOfSkipLevels; i++)
             {
@@ -90,7 +90,7 @@ namespace Lucene.Net.Codecs.Sep
             _indexOptions = v;
         }
 
-        internal virtual void SetPosOutput(IntIndexOutput posOutput) 
+        internal virtual void SetPosOutput(Int32IndexOutput posOutput) 
         {
             _posOutput = posOutput;
             for (var i = 0; i < m_numberOfSkipLevels; i++)
@@ -122,8 +122,8 @@ namespace Lucene.Net.Codecs.Sep
         /// <summary>
         /// Called @ start of new term
         /// </summary>
-        protected internal virtual void ResetSkip(IntIndexOutput.AbstractIndex topDocIndex, IntIndexOutput.AbstractIndex topFreqIndex,
-            IntIndexOutput.AbstractIndex topPosIndex)
+        protected internal virtual void ResetSkip(Int32IndexOutput.AbstractIndex topDocIndex, Int32IndexOutput.AbstractIndex topFreqIndex,
+            Int32IndexOutput.AbstractIndex topPosIndex)
         {
             base.ResetSkip();
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/d3dfb950/src/Lucene.Net.TestFramework/Codecs/MockIntBlock/MockFixedIntBlockPostingsFormat.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.TestFramework/Codecs/MockIntBlock/MockFixedIntBlockPostingsFormat.cs b/src/Lucene.Net.TestFramework/Codecs/MockIntBlock/MockFixedIntBlockPostingsFormat.cs
index 7a3fc76..79f1332 100644
--- a/src/Lucene.Net.TestFramework/Codecs/MockIntBlock/MockFixedIntBlockPostingsFormat.cs
+++ b/src/Lucene.Net.TestFramework/Codecs/MockIntBlock/MockFixedIntBlockPostingsFormat.cs
@@ -49,7 +49,7 @@ namespace Lucene.Net.Codecs.IntBlock
         }
 
         // only for testing
-        public IntStreamFactory getIntFactory()
+        public Int32StreamFactory getIntFactory()
         {
             return new MockIntFactory(blockSize);
         }
@@ -57,7 +57,7 @@ namespace Lucene.Net.Codecs.IntBlock
         /**
          * Encodes blocks as vInts of a fixed block size.
          */
-        public class MockIntFactory : IntStreamFactory
+        public class MockIntFactory : Int32StreamFactory
         {
             private readonly int blockSize;
 
@@ -66,12 +66,12 @@ namespace Lucene.Net.Codecs.IntBlock
                 this.blockSize = blockSize;
             }
 
-            public override IntIndexInput OpenInput(Directory dir, string fileName, IOContext context)
+            public override Int32IndexInput OpenInput(Directory dir, string fileName, IOContext context)
             {
                 return new FixedIntBlockIndexInputAnonymousHelper(this, dir.OpenInput(fileName, context));
             }
 
-            private class FixedIntBlockIndexInputAnonymousHelper : FixedIntBlockIndexInput
+            private class FixedIntBlockIndexInputAnonymousHelper : FixedInt32BlockIndexInput
             {
                 private readonly MockIntFactory outerInstance;
 
@@ -86,7 +86,7 @@ namespace Lucene.Net.Codecs.IntBlock
                     return new BlockReaderAnonymousHelper(outerInstance, @in, buffer);
                 }
 
-                private class BlockReaderAnonymousHelper : FixedIntBlockIndexInput.IBlockReader
+                private class BlockReaderAnonymousHelper : FixedInt32BlockIndexInput.IBlockReader
                 {
                     private readonly MockIntFactory outerInstance;
                     private readonly IndexInput @in;
@@ -113,7 +113,7 @@ namespace Lucene.Net.Codecs.IntBlock
             }
 
 
-            public override IntIndexOutput CreateOutput(Directory dir, string fileName, IOContext context)
+            public override Int32IndexOutput CreateOutput(Directory dir, string fileName, IOContext context)
             {
                 IndexOutput output = dir.CreateOutput(fileName, context);
                 bool success = false;
@@ -134,7 +134,7 @@ namespace Lucene.Net.Codecs.IntBlock
             }
         }
 
-        private class FixedIntBlockIndexOutputAnonymousHelper : FixedIntBlockIndexOutput
+        private class FixedIntBlockIndexOutputAnonymousHelper : FixedInt32BlockIndexOutput
         {
             public FixedIntBlockIndexOutputAnonymousHelper(IndexOutput output, int blockSize)
                 : base(output, blockSize)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/d3dfb950/src/Lucene.Net.TestFramework/Codecs/MockIntBlock/MockVariableIntBlockPostingsFormat.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.TestFramework/Codecs/MockIntBlock/MockVariableIntBlockPostingsFormat.cs b/src/Lucene.Net.TestFramework/Codecs/MockIntBlock/MockVariableIntBlockPostingsFormat.cs
index 99878b0..cce4b37 100644
--- a/src/Lucene.Net.TestFramework/Codecs/MockIntBlock/MockVariableIntBlockPostingsFormat.cs
+++ b/src/Lucene.Net.TestFramework/Codecs/MockIntBlock/MockVariableIntBlockPostingsFormat.cs
@@ -55,7 +55,7 @@ namespace Lucene.Net.Codecs.IntBlock
          * If the first value is &lt;= 3, writes baseBlockSize vInts at once,
          * otherwise writes 2*baseBlockSize vInts.
          */
-        public class MockIntFactory : IntStreamFactory
+        public class MockIntFactory : Int32StreamFactory
         {
 
             private readonly int baseBlockSize;
@@ -65,14 +65,14 @@ namespace Lucene.Net.Codecs.IntBlock
                 this.baseBlockSize = baseBlockSize;
             }
 
-            public override IntIndexInput OpenInput(Directory dir, string fileName, IOContext context)
+            public override Int32IndexInput OpenInput(Directory dir, string fileName, IOContext context)
             {
                 IndexInput input = dir.OpenInput(fileName, context);
                 int baseBlockSize = input.ReadInt32();
                 return new VariableIntBlockIndexInputAnonymousHelper(input, baseBlockSize);
             }
 
-            private class VariableIntBlockIndexInputAnonymousHelper : VariableIntBlockIndexInput
+            private class VariableIntBlockIndexInputAnonymousHelper : VariableInt32BlockIndexInput
             {
                 private readonly int baseBlockSize;
 
@@ -117,14 +117,14 @@ namespace Lucene.Net.Codecs.IntBlock
                 }
             }
 
-            public override IntIndexOutput CreateOutput(Directory dir, string fileName, IOContext context)
+            public override Int32IndexOutput CreateOutput(Directory dir, string fileName, IOContext context)
             {
                 IndexOutput output = dir.CreateOutput(fileName, context);
                 bool success = false;
                 try
                 {
                     output.WriteInt32(baseBlockSize);
-                    VariableIntBlockIndexOutput ret = new VariableIntBlockIndexOutputAnonymousHelper(output, 2 * baseBlockSize);
+                    VariableInt32BlockIndexOutput ret = new VariableIntBlockIndexOutputAnonymousHelper(output, 2 * baseBlockSize);
                     success = true;
                     return ret;
                 }
@@ -138,7 +138,7 @@ namespace Lucene.Net.Codecs.IntBlock
             }
         }
 
-        private class VariableIntBlockIndexOutputAnonymousHelper : VariableIntBlockIndexOutput
+        private class VariableIntBlockIndexOutputAnonymousHelper : VariableInt32BlockIndexOutput
         {
             private readonly int baseBlockSize;
             public VariableIntBlockIndexOutputAnonymousHelper(IndexOutput output, int baseBlockSize)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/d3dfb950/src/Lucene.Net.TestFramework/Codecs/MockSep/MockSingleIntFactory.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.TestFramework/Codecs/MockSep/MockSingleIntFactory.cs b/src/Lucene.Net.TestFramework/Codecs/MockSep/MockSingleIntFactory.cs
index 853202d..b51b46d 100644
--- a/src/Lucene.Net.TestFramework/Codecs/MockSep/MockSingleIntFactory.cs
+++ b/src/Lucene.Net.TestFramework/Codecs/MockSep/MockSingleIntFactory.cs
@@ -20,14 +20,14 @@ namespace Lucene.Net.Codecs.MockSep
      * limitations under the License.
      */
 
-    public class MockSingleIntFactory : IntStreamFactory
+    public class MockSingleIntFactory : Int32StreamFactory
     {
-        public override IntIndexInput OpenInput(Directory dir, string fileName, IOContext context)
+        public override Int32IndexInput OpenInput(Directory dir, string fileName, IOContext context)
         {
             return new MockSingleIntIndexInput(dir, fileName, context);
         }
 
-        public override IntIndexOutput CreateOutput(Directory dir, string fileName, IOContext context)
+        public override Int32IndexOutput CreateOutput(Directory dir, string fileName, IOContext context)
         {
             return new MockSingleIntIndexOutput(dir, fileName, context);
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/d3dfb950/src/Lucene.Net.TestFramework/Codecs/MockSep/MockSingleIntIndexInput.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.TestFramework/Codecs/MockSep/MockSingleIntIndexInput.cs b/src/Lucene.Net.TestFramework/Codecs/MockSep/MockSingleIntIndexInput.cs
index e949505..a750735 100644
--- a/src/Lucene.Net.TestFramework/Codecs/MockSep/MockSingleIntIndexInput.cs
+++ b/src/Lucene.Net.TestFramework/Codecs/MockSep/MockSingleIntIndexInput.cs
@@ -28,7 +28,7 @@ namespace Lucene.Net.Codecs.MockSep
     /// 
     /// @lucene.experimental
     /// </summary>
-    public class MockSingleIntIndexInput : IntIndexInput
+    public class MockSingleIntIndexInput : Int32IndexInput
     {
         private readonly IndexInput @in;
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/d3dfb950/src/Lucene.Net.TestFramework/Codecs/MockSep/MockSingleIntIndexOutput.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.TestFramework/Codecs/MockSep/MockSingleIntIndexOutput.cs b/src/Lucene.Net.TestFramework/Codecs/MockSep/MockSingleIntIndexOutput.cs
index 47d6a29..99a067b 100644
--- a/src/Lucene.Net.TestFramework/Codecs/MockSep/MockSingleIntIndexOutput.cs
+++ b/src/Lucene.Net.TestFramework/Codecs/MockSep/MockSingleIntIndexOutput.cs
@@ -10,7 +10,7 @@ namespace Lucene.Net.Codecs.MockSep
     /// 
     /// @lucene.experimental
     /// </summary>
-    public class MockSingleIntIndexOutput : IntIndexOutput
+    public class MockSingleIntIndexOutput : Int32IndexOutput
     {
         private readonly IndexOutput @out;
         internal const string CODEC = "SINGLE_INTS";

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/d3dfb950/src/Lucene.Net.Tests.Codecs/IntBlock/TestIntBlockCodec.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests.Codecs/IntBlock/TestIntBlockCodec.cs b/src/Lucene.Net.Tests.Codecs/IntBlock/TestIntBlockCodec.cs
index 7d38c4d..582a684 100644
--- a/src/Lucene.Net.Tests.Codecs/IntBlock/TestIntBlockCodec.cs
+++ b/src/Lucene.Net.Tests.Codecs/IntBlock/TestIntBlockCodec.cs
@@ -30,17 +30,17 @@ namespace Lucene.Net.Codecs.IntBlock
         {
             Directory dir = NewDirectory();
 
-            IntStreamFactory f = (new MockFixedIntBlockPostingsFormat(128)).getIntFactory();
+            Int32StreamFactory f = (new MockFixedIntBlockPostingsFormat(128)).getIntFactory();
 
-            IntIndexOutput @out = f.CreateOutput(dir, "test", NewIOContext(Random()));
+            Int32IndexOutput @out = f.CreateOutput(dir, "test", NewIOContext(Random()));
             for (int i = 0; i < 11777; i++)
             {
                 @out.Write(i);
             }
             @out.Dispose();
 
-            IntIndexInput @in = f.OpenInput(dir, "test", NewIOContext(Random()));
-            IntIndexInput.AbstractReader r = @in.GetReader();
+            Int32IndexInput @in = f.OpenInput(dir, "test", NewIOContext(Random()));
+            Int32IndexInput.AbstractReader r = @in.GetReader();
 
             for (int i = 0; i < 11777; i++)
             {
@@ -56,13 +56,13 @@ namespace Lucene.Net.Codecs.IntBlock
         {
             Directory dir = NewDirectory();
 
-            IntStreamFactory f = (new MockFixedIntBlockPostingsFormat(128)).getIntFactory();
-            IntIndexOutput @out = f.CreateOutput(dir, "test", NewIOContext(Random()));
+            Int32StreamFactory f = (new MockFixedIntBlockPostingsFormat(128)).getIntFactory();
+            Int32IndexOutput @out = f.CreateOutput(dir, "test", NewIOContext(Random()));
 
             // write no ints
             @out.Dispose();
 
-            IntIndexInput @in = f.OpenInput(dir, "test", NewIOContext(Random()));
+            Int32IndexInput @in = f.OpenInput(dir, "test", NewIOContext(Random()));
             @in.GetReader();
             // read no ints
             @in.Dispose();


[06/53] [abbrv] lucenenet git commit: Lucene.Net.Core: Renamed all type-derived properties and methods from Short, Int, Long, and Float to match CLR types Int16, Int32, Int64, and Single, respectively.

Posted by ni...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Util/Fst/IntSequenceOutputs.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Fst/IntSequenceOutputs.cs b/src/Lucene.Net.Core/Util/Fst/IntSequenceOutputs.cs
index a031d83..0db64a6 100644
--- a/src/Lucene.Net.Core/Util/Fst/IntSequenceOutputs.cs
+++ b/src/Lucene.Net.Core/Util/Fst/IntSequenceOutputs.cs
@@ -56,7 +56,7 @@ namespace Lucene.Net.Util.Fst
             int stopAt1 = pos1 + Math.Min(output1.Length, output2.Length);
             while (pos1 < stopAt1)
             {
-                if (output1.Ints[pos1] != output2.Ints[pos2])
+                if (output1.Int32s[pos1] != output2.Int32s[pos2])
                 {
                     break;
                 }
@@ -81,7 +81,7 @@ namespace Lucene.Net.Util.Fst
             }
             else
             {
-                return new IntsRef(output1.Ints, output1.Offset, pos1 - output1.Offset);
+                return new IntsRef(output1.Int32s, output1.Offset, pos1 - output1.Offset);
             }
         }
 
@@ -103,7 +103,7 @@ namespace Lucene.Net.Util.Fst
             {
                 Debug.Assert(inc.Length < output.Length, "inc.length=" + inc.Length + " vs output.length=" + output.Length);
                 Debug.Assert(inc.Length > 0);
-                return new IntsRef(output.Ints, output.Offset + inc.Length, output.Length - inc.Length);
+                return new IntsRef(output.Int32s, output.Offset + inc.Length, output.Length - inc.Length);
             }
         }
 
@@ -124,8 +124,8 @@ namespace Lucene.Net.Util.Fst
                 Debug.Assert(prefix.Length > 0);
                 Debug.Assert(output.Length > 0);
                 IntsRef result = new IntsRef(prefix.Length + output.Length);
-                Array.Copy(prefix.Ints, prefix.Offset, result.Ints, 0, prefix.Length);
-                Array.Copy(output.Ints, output.Offset, result.Ints, prefix.Length, output.Length);
+                Array.Copy(prefix.Int32s, prefix.Offset, result.Int32s, 0, prefix.Length);
+                Array.Copy(output.Int32s, output.Offset, result.Int32s, prefix.Length, output.Length);
                 result.Length = prefix.Length + output.Length;
                 return result;
             }
@@ -134,16 +134,16 @@ namespace Lucene.Net.Util.Fst
         public override void Write(IntsRef prefix, DataOutput @out)
         {
             Debug.Assert(prefix != null);
-            @out.WriteVInt(prefix.Length);
+            @out.WriteVInt32(prefix.Length);
             for (int idx = 0; idx < prefix.Length; idx++)
             {
-                @out.WriteVInt(prefix.Ints[prefix.Offset + idx]);
+                @out.WriteVInt32(prefix.Int32s[prefix.Offset + idx]);
             }
         }
 
         public override IntsRef Read(DataInput @in)
         {
-            int len = @in.ReadVInt();
+            int len = @in.ReadVInt32();
             if (len == 0)
             {
                 return NO_OUTPUT;
@@ -153,7 +153,7 @@ namespace Lucene.Net.Util.Fst
                 IntsRef output = new IntsRef(len);
                 for (int idx = 0; idx < len; idx++)
                 {
-                    output.Ints[idx] = @in.ReadVInt();
+                    output.Int32s[idx] = @in.ReadVInt32();
                 }
                 output.Length = len;
                 return output;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Util/Fst/IntsRefFSTEnum.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Fst/IntsRefFSTEnum.cs b/src/Lucene.Net.Core/Util/Fst/IntsRefFSTEnum.cs
index 2f2edd9..fba0afb 100644
--- a/src/Lucene.Net.Core/Util/Fst/IntsRefFSTEnum.cs
+++ b/src/Lucene.Net.Core/Util/Fst/IntsRefFSTEnum.cs
@@ -108,7 +108,7 @@ namespace Lucene.Net.Util.Fst
                 }
                 else
                 {
-                    return target.Ints[target.Offset + m_upto - 1];
+                    return target.Int32s[target.Offset + m_upto - 1];
                 }
             }
         }
@@ -118,17 +118,17 @@ namespace Lucene.Net.Util.Fst
             get
             {
                 // current.offset fixed at 1
-                return current.Ints[m_upto];
+                return current.Int32s[m_upto];
             }
             set
             {
-                current.Ints[m_upto] = value;
+                current.Int32s[m_upto] = value;
             }
         }
 
         protected override void Grow()
         {
-            current.Ints = ArrayUtil.Grow(current.Ints, m_upto + 1);
+            current.Int32s = ArrayUtil.Grow(current.Int32s, m_upto + 1);
         }
 
         private IntsRefFSTEnum.InputOutput<T> SetResult()

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Util/Fst/PositiveIntOutputs.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Fst/PositiveIntOutputs.cs b/src/Lucene.Net.Core/Util/Fst/PositiveIntOutputs.cs
index f06ece2..3713f83 100644
--- a/src/Lucene.Net.Core/Util/Fst/PositiveIntOutputs.cs
+++ b/src/Lucene.Net.Core/Util/Fst/PositiveIntOutputs.cs
@@ -104,12 +104,12 @@ namespace Lucene.Net.Util.Fst
         public override void Write(long? output, DataOutput @out)
         {
             Debug.Assert(Valid(output));
-            @out.WriteVLong(output.Value);
+            @out.WriteVInt64(output.Value);
         }
 
         public override long? Read(DataInput @in)
         {
-            long v = @in.ReadVLong();
+            long v = @in.ReadVInt64();
             if (v == 0)
             {
                 return NO_OUTPUT;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Util/Fst/Util.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Fst/Util.cs b/src/Lucene.Net.Core/Util/Fst/Util.cs
index ad7d2cb..e3329c2 100644
--- a/src/Lucene.Net.Core/Util/Fst/Util.cs
+++ b/src/Lucene.Net.Core/Util/Fst/Util.cs
@@ -50,7 +50,7 @@ namespace Lucene.Net.Util.Fst
             T output = fst.Outputs.NoOutput;
             for (int i = 0; i < input.Length; i++)
             {
-                if (fst.FindTargetArc(input.Ints[input.Offset + i], arc, arc, fstReader) == null)
+                if (fst.FindTargetArc(input.Int32s[input.Offset + i], arc, arc, fstReader) == null)
                 {
                     return default(T);
                 }
@@ -165,7 +165,7 @@ namespace Lucene.Net.Util.Fst
                 if (FST<long?>.TargetHasArcs(arc))
                 {
                     //System.out.println("  targetHasArcs");
-                    if (result.Ints.Length == upto)
+                    if (result.Int32s.Length == upto)
                     {
                         result.Grow(1 + upto);
                     }
@@ -225,7 +225,7 @@ namespace Lucene.Net.Util.Fst
                         }
 
                         fst.ReadNextRealArc(arc, @in);
-                        result.Ints[upto++] = arc.Label;
+                        result.Int32s[upto++] = arc.Label;
                         output += arc.Output.Value;
                     }
                     else
@@ -245,7 +245,7 @@ namespace Lucene.Net.Util.Fst
                                 // Recurse on this arc:
                                 //System.out.println("  match!  break");
                                 output = minArcOutput;
-                                result.Ints[upto++] = arc.Label;
+                                result.Int32s[upto++] = arc.Label;
                                 break;
                             }
                             else if (minArcOutput > targetOutput)
@@ -259,7 +259,7 @@ namespace Lucene.Net.Util.Fst
                                 {
                                     // Recurse on previous arc:
                                     arc.CopyFrom(prevArc);
-                                    result.Ints[upto++] = arc.Label;
+                                    result.Int32s[upto++] = arc.Label;
                                     output += arc.Output.Value;
                                     //System.out.println("    recurse prev label=" + (char) arc.label + " output=" + output);
                                     break;
@@ -270,7 +270,7 @@ namespace Lucene.Net.Util.Fst
                                 // Recurse on this arc:
                                 output = minArcOutput;
                                 //System.out.println("    recurse last label=" + (char) arc.label + " output=" + output);
-                                result.Ints[upto++] = arc.Label;
+                                result.Int32s[upto++] = arc.Label;
                                 break;
                             }
                             else
@@ -402,7 +402,7 @@ namespace Lucene.Net.Util.Fst
                     {
                         // Tie break by alpha sort on the input:
                         path.Input.Grow(path.Input.Length + 1);
-                        path.Input.Ints[path.Input.Length++] = path.Arc.Label;
+                        path.Input.Int32s[path.Input.Length++] = path.Arc.Label;
                         int cmp = bottom.Input.CompareTo(path.Input);
                         path.Input.Length--;
 
@@ -425,8 +425,8 @@ namespace Lucene.Net.Util.Fst
                 // copy over the current input to the new input
                 // and add the arc.label to the end
                 IntsRef newInput = new IntsRef(path.Input.Length + 1);
-                Array.Copy(path.Input.Ints, 0, newInput.Ints, 0, path.Input.Length);
-                newInput.Ints[path.Input.Length] = path.Arc.Label;
+                Array.Copy(path.Input.Int32s, 0, newInput.Int32s, 0, path.Input.Length);
+                newInput.Int32s[path.Input.Length] = path.Arc.Label;
                 newInput.Length = path.Input.Length + 1;
                 FSTPath<T> newPath = new FSTPath<T>(cost, path.Arc, newInput);
 
@@ -625,7 +625,7 @@ namespace Lucene.Net.Util.Fst
                         else
                         {
                             path.Input.Grow(1 + path.Input.Length);
-                            path.Input.Ints[path.Input.Length] = path.Arc.Label;
+                            path.Input.Int32s[path.Input.Length] = path.Arc.Label;
                             path.Input.Length++;
                             path.Cost = fst.Outputs.Add(path.Cost, path.Arc.Output);
                         }
@@ -986,7 +986,7 @@ namespace Lucene.Net.Util.Fst
             scratch.Grow(charLimit);
             for (int idx = 0; idx < charLimit; idx++)
             {
-                scratch.Ints[idx] = (int)s[idx];
+                scratch.Int32s[idx] = (int)s[idx];
             }
             return scratch;
         }
@@ -1005,7 +1005,7 @@ namespace Lucene.Net.Util.Fst
             {
                 scratch.Grow(intIdx + 1);
                 int utf32 = Character.CodePointAt(s, charIdx);
-                scratch.Ints[intIdx] = utf32;
+                scratch.Int32s[intIdx] = utf32;
                 charIdx += Character.CharCount(utf32);
                 intIdx++;
             }
@@ -1027,7 +1027,7 @@ namespace Lucene.Net.Util.Fst
             {
                 scratch.Grow(intIdx + 1);
                 int utf32 = Character.CodePointAt(s, charIdx, charLimit);
-                scratch.Ints[intIdx] = utf32;
+                scratch.Int32s[intIdx] = utf32;
                 charIdx += Character.CharCount(utf32);
                 intIdx++;
             }
@@ -1037,14 +1037,16 @@ namespace Lucene.Net.Util.Fst
 
         /// <summary>
         /// Just takes unsigned byte values from the BytesRef and
-        ///  converts into an IntsRef.
+        /// converts into an IntsRef.
+        /// <para/>
+        /// NOTE: This was toIntsRef() in Lucene
         /// </summary>
-        public static IntsRef ToIntsRef(BytesRef input, IntsRef scratch)
+        public static IntsRef ToInt32sRef(BytesRef input, IntsRef scratch)
         {
             scratch.Grow(input.Length);
             for (int i = 0; i < input.Length; i++)
             {
-                scratch.Ints[i] = input.Bytes[i + input.Offset] & 0xFF;
+                scratch.Int32s[i] = input.Bytes[i + input.Offset] & 0xFF;
             }
             scratch.Length = input.Length;
             return scratch;
@@ -1059,7 +1061,7 @@ namespace Lucene.Net.Util.Fst
             scratch.Grow(input.Length);
             for (int i = 0; i < input.Length; i++)
             {
-                int value = input.Ints[i + input.Offset];
+                int value = input.Int32s[i + input.Offset];
                 // NOTE: we allow -128 to 255
                 Debug.Assert(value >= sbyte.MinValue && value <= 255, "value " + value + " doesn't fit into byte");
                 scratch.Bytes[i] = (byte)value;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Util/IntBlockPool.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/IntBlockPool.cs b/src/Lucene.Net.Core/Util/IntBlockPool.cs
index 7b0ec79..0216498 100644
--- a/src/Lucene.Net.Core/Util/IntBlockPool.cs
+++ b/src/Lucene.Net.Core/Util/IntBlockPool.cs
@@ -45,9 +45,15 @@ namespace Lucene.Net.Util
                 this.m_blockSize = blockSize;
             }
 
-            public abstract void RecycleIntBlocks(int[][] blocks, int start, int end);
+            /// <summary>
+            /// NOTE: This was recycleIntBlocks() in Lucene
+            /// </summary>
+            public abstract void RecycleInt32Blocks(int[][] blocks, int start, int end);
 
-            public virtual int[] GetIntBlock() // LUCENENET TODO: Rename GetInt32Block() ?
+            /// <summary>
+            /// NOTE: This was getIntBlock() in Lucene
+            /// </summary>
+            public virtual int[] GetInt32Block()
             {
                 return new int[m_blockSize];
             }
@@ -65,7 +71,10 @@ namespace Lucene.Net.Util
             {
             }
 
-            public override void RecycleIntBlocks(int[][] blocks, int start, int end)
+            /// <summary>
+            /// NOTE: This was recycleIntBlocks() in Lucene
+            /// </summary>
+            public override void RecycleInt32Blocks(int[][] blocks, int start, int end)
             {
             }
         }
@@ -86,8 +95,11 @@ namespace Lucene.Net.Util
         private int bufferUpto = -1;
 
         /// <summary>
-        /// Pointer to the current position in head buffer </summary>
-        public int IntUpto { get; set; }
+        /// Pointer to the current position in head buffer
+        /// <para/>
+        /// NOTE: This was intUpto in Lucene
+        /// </summary>
+        public int Int32Upto { get; set; }
 
         /// <summary>
         /// Current head buffer </summary>
@@ -101,8 +113,11 @@ namespace Lucene.Net.Util
         private int[] buffer;
 
         /// <summary>
-        /// Current head offset </summary>
-        public int IntOffset { get; set; }
+        /// Current head offset 
+        /// <para/>
+        /// NOTE: This was intOffset in Lucene
+        /// </summary>
+        public int Int32Offset { get; set; }
 
         private readonly Allocator allocator;
 
@@ -120,8 +135,8 @@ namespace Lucene.Net.Util
         public IntBlockPool(Allocator allocator)
         {
             // set defaults
-            IntUpto = INT_BLOCK_SIZE;
-            IntOffset = -INT_BLOCK_SIZE;
+            Int32Upto = INT_BLOCK_SIZE;
+            Int32Offset = -INT_BLOCK_SIZE;
 
             this.allocator = allocator;
         }
@@ -157,29 +172,29 @@ namespace Lucene.Net.Util
                         Arrays.Fill(buffers[i], 0);
                     }
                     // Partial zero fill the final buffer
-                    Arrays.Fill(buffers[bufferUpto], 0, IntUpto, 0);
+                    Arrays.Fill(buffers[bufferUpto], 0, Int32Upto, 0);
                 }
 
                 if (bufferUpto > 0 || !reuseFirst)
                 {
                     int offset = reuseFirst ? 1 : 0;
                     // Recycle all but the first buffer
-                    allocator.RecycleIntBlocks(buffers, offset, 1 + bufferUpto);
+                    allocator.RecycleInt32Blocks(buffers, offset, 1 + bufferUpto);
                     Arrays.Fill(buffers, offset, bufferUpto + 1, null);
                 }
                 if (reuseFirst)
                 {
                     // Re-use the first buffer
                     bufferUpto = 0;
-                    IntUpto = 0;
-                    IntOffset = 0;
+                    Int32Upto = 0;
+                    Int32Offset = 0;
                     buffer = buffers[0];
                 }
                 else
                 {
                     bufferUpto = -1;
-                    IntUpto = INT_BLOCK_SIZE;
-                    IntOffset = -INT_BLOCK_SIZE;
+                    Int32Upto = INT_BLOCK_SIZE;
+                    Int32Offset = -INT_BLOCK_SIZE;
                     buffer = null;
                 }
             }
@@ -199,11 +214,11 @@ namespace Lucene.Net.Util
                 Array.Copy(buffers, 0, newBuffers, 0, buffers.Length);
                 buffers = newBuffers;
             }
-            buffer = buffers[1 + bufferUpto] = allocator.GetIntBlock();
+            buffer = buffers[1 + bufferUpto] = allocator.GetInt32Block();
             bufferUpto++;
 
-            IntUpto = 0;
-            IntOffset += INT_BLOCK_SIZE;
+            Int32Upto = 0;
+            Int32Offset += INT_BLOCK_SIZE;
         }
 
         /// <summary>
@@ -211,15 +226,15 @@ namespace Lucene.Net.Util
         /// <seealso cref= SliceReader </seealso>
         private int NewSlice(int size)
         {
-            if (IntUpto > INT_BLOCK_SIZE - size)
+            if (Int32Upto > INT_BLOCK_SIZE - size)
             {
                 NextBuffer();
                 Debug.Assert(AssertSliceBuffer(buffer));
             }
 
-            int upto = IntUpto;
-            IntUpto += size;
-            buffer[IntUpto - 1] = 1;
+            int upto = Int32Upto;
+            Int32Upto += size;
+            buffer[Int32Upto - 1] = 1;
             return upto;
         }
 
@@ -260,20 +275,20 @@ namespace Lucene.Net.Util
             int newLevel = NEXT_LEVEL_ARRAY[level - 1];
             int newSize = LEVEL_SIZE_ARRAY[newLevel];
             // Maybe allocate another block
-            if (IntUpto > INT_BLOCK_SIZE - newSize)
+            if (Int32Upto > INT_BLOCK_SIZE - newSize)
             {
                 NextBuffer();
                 Debug.Assert(AssertSliceBuffer(buffer));
             }
 
-            int newUpto = IntUpto;
-            int offset = newUpto + IntOffset;
-            IntUpto += newSize;
+            int newUpto = Int32Upto;
+            int offset = newUpto + Int32Offset;
+            Int32Upto += newSize;
             // Write forwarding address at end of last slice:
             slice[sliceOffset] = offset;
 
             // Write new level:
-            buffer[IntUpto - 1] = newLevel;
+            buffer[Int32Upto - 1] = newLevel;
 
             return newUpto;
         }
@@ -301,8 +316,10 @@ namespace Lucene.Net.Util
 
             /// <summary>
             /// Writes the given value into the slice and resizes the slice if needed
+            /// <para/>
+            /// NOTE: This was writeInt() in Lucene
             /// </summary>
-            public virtual void WriteInt(int value) // LUCENENET TODO: rename WriteInt32 ?
+            public virtual void WriteInt32(int value)
             {
                 int[] ints = pool.buffers[offset >> INT_BLOCK_SHIFT];
                 Debug.Assert(ints != null);
@@ -312,7 +329,7 @@ namespace Lucene.Net.Util
                     // End of slice; allocate a new one
                     relativeOffset = pool.AllocSlice(ints, relativeOffset);
                     ints = pool.buffer;
-                    offset = relativeOffset + pool.IntOffset;
+                    offset = relativeOffset + pool.Int32Offset;
                 }
                 ints[relativeOffset] = value;
                 offset++;
@@ -324,7 +341,7 @@ namespace Lucene.Net.Util
             /// </summary>
             public virtual int StartNewSlice()
             {
-                return offset = pool.NewSlice(FIRST_LEVEL_SIZE) + pool.IntOffset;
+                return offset = pool.NewSlice(FIRST_LEVEL_SIZE) + pool.Int32Offset;
             }
 
             /// <summary>
@@ -403,9 +420,12 @@ namespace Lucene.Net.Util
             }
 
             /// <summary>
-            /// Reads the next int from the current slice and returns it. </summary>
+            /// Reads the next int from the current slice and returns it. 
+            /// <para/>
+            /// NOTE: This was readInt() in Lucene
+            /// </summary>
             /// <seealso cref= SliceReader#endOfSlice() </seealso>
-            public int ReadInt() // LUCENENET TODO: Rename ReadInt32() ?
+            public int ReadInt32()
             {
                 Debug.Assert(!EndOfSlice());
                 Debug.Assert(upto <= limit);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Util/IntsRef.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/IntsRef.cs b/src/Lucene.Net.Core/Util/IntsRef.cs
index 67c50d8..26dd154 100644
--- a/src/Lucene.Net.Core/Util/IntsRef.cs
+++ b/src/Lucene.Net.Core/Util/IntsRef.cs
@@ -37,10 +37,13 @@ namespace Lucene.Net.Util
         public static readonly int[] EMPTY_INTS = new int[0];
 
         /// <summary>
-        /// The contents of the IntsRef. Should never be {@code null}. </summary>
+        /// The contents of the IntsRef. Should never be {@code null}. 
+        /// <para/>
+        /// NOTE: This was ints (field) in Lucene
+        /// </summary>
         [WritableArray]
         [SuppressMessage("Microsoft.Performance", "CA1819", Justification = "Lucene's design requires some writable array properties")]
-        public int[] Ints
+        public int[] Int32s
         {
             get { return ints; }
             set
@@ -121,12 +124,15 @@ namespace Lucene.Net.Util
             }
             if (other is IntsRef)
             {
-                return this.IntsEquals((IntsRef)other);
+                return this.Int32sEquals((IntsRef)other);
             }
             return false;
         }
 
-        public bool IntsEquals(IntsRef other)
+        /// <summary>
+        /// NOTE: This was intsEquals() in Lucene
+        /// </summary>
+        public bool Int32sEquals(IntsRef other)
         {
             if (Length == other.Length)
             {
@@ -182,7 +188,10 @@ namespace Lucene.Net.Util
             return this.Length - other.Length;
         }
 
-        public void CopyInts(IntsRef other)
+        /// <summary>
+        /// NOTE: This was copyInts() in Lucene
+        /// </summary>
+        public void CopyInt32s(IntsRef other)
         {
             if (ints.Length - Offset < other.Length)
             {
@@ -235,7 +244,7 @@ namespace Lucene.Net.Util
         public static IntsRef DeepCopyOf(IntsRef other)
         {
             IntsRef clone = new IntsRef();
-            clone.CopyInts(other);
+            clone.CopyInt32s(other);
             return clone;
         }
 
@@ -255,7 +264,7 @@ namespace Lucene.Net.Util
             }
             if (Length > ints.Length)
             {
-                throw new InvalidOperationException("length is out of bounds: " + Length + ",ints.length=" + Ints.Length);
+                throw new InvalidOperationException("length is out of bounds: " + Length + ",ints.length=" + Int32s.Length);
             }
             if (Offset < 0)
             {
@@ -263,15 +272,15 @@ namespace Lucene.Net.Util
             }
             if (Offset > ints.Length)
             {
-                throw new InvalidOperationException("offset out of bounds: " + Offset + ",ints.length=" + Ints.Length);
+                throw new InvalidOperationException("offset out of bounds: " + Offset + ",ints.length=" + Int32s.Length);
             }
             if (Offset + Length < 0)
             {
                 throw new InvalidOperationException("offset+length is negative: offset=" + Offset + ",length=" + Length);
             }
-            if (Offset + Length > Ints.Length)
+            if (Offset + Length > Int32s.Length)
             {
-                throw new InvalidOperationException("offset+length out of bounds: offset=" + Offset + ",length=" + Length + ",ints.length=" + Ints.Length);
+                throw new InvalidOperationException("offset+length out of bounds: offset=" + Offset + ",length=" + Length + ",ints.length=" + Int32s.Length);
             }
             return true;
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Util/LongsRef.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/LongsRef.cs b/src/Lucene.Net.Core/Util/LongsRef.cs
index 2a1fa1e..6bfd5f1 100644
--- a/src/Lucene.Net.Core/Util/LongsRef.cs
+++ b/src/Lucene.Net.Core/Util/LongsRef.cs
@@ -37,10 +37,13 @@ namespace Lucene.Net.Util
         public static readonly long[] EMPTY_LONGS = new long[0];
 
         /// <summary>
-        /// The contents of the LongsRef. Should never be {@code null}. </summary>
+        /// The contents of the LongsRef. Should never be {@code null}. 
+        /// <para/>
+        /// NOTE: This was longs (field) in Lucene
+        /// </summary>
         [WritableArray]
         [SuppressMessage("Microsoft.Performance", "CA1819", Justification = "Lucene's design requires some writable array properties")]
-        public long[] Longs
+        public long[] Int64s
         {
             get { return longs; }
             set
@@ -121,12 +124,15 @@ namespace Lucene.Net.Util
             }
             if (other is LongsRef)
             {
-                return this.LongsEquals((LongsRef)other);
+                return this.Int64sEquals((LongsRef)other);
             }
             return false;
         }
 
-        public bool LongsEquals(LongsRef other)
+        /// <summary>
+        /// NOTE: This was longsEquals() in Lucene
+        /// </summary>
+        public bool Int64sEquals(LongsRef other)
         {
             if (Length == other.Length)
             {
@@ -182,7 +188,10 @@ namespace Lucene.Net.Util
             return this.Length - other.Length;
         }
 
-        public void CopyLongs(LongsRef other)
+        /// <summary>
+        /// NOTE: This was copyLongs() in Lucene
+        /// </summary>
+        public void CopyInt64s(LongsRef other)
         {
             if (longs.Length - Offset < other.Length)
             {
@@ -235,7 +244,7 @@ namespace Lucene.Net.Util
         public static LongsRef DeepCopyOf(LongsRef other)
         {
             LongsRef clone = new LongsRef();
-            clone.CopyLongs(other);
+            clone.CopyInt64s(other);
             return clone;
         }
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Util/Mutable/MutableValueFloat.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Mutable/MutableValueFloat.cs b/src/Lucene.Net.Core/Util/Mutable/MutableValueFloat.cs
index ccbdb13..a71386b 100644
--- a/src/Lucene.Net.Core/Util/Mutable/MutableValueFloat.cs
+++ b/src/Lucene.Net.Core/Util/Mutable/MutableValueFloat.cs
@@ -70,7 +70,7 @@ namespace Lucene.Net.Util.Mutable
 
         public override int GetHashCode()
         {
-            return Number.FloatToIntBits(Value);
+            return Number.SingleToInt32Bits(Value);
         }
     }
 }
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Util/NumericUtils.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/NumericUtils.cs b/src/Lucene.Net.Core/Util/NumericUtils.cs
index 894e33b..b66a134 100644
--- a/src/Lucene.Net.Core/Util/NumericUtils.cs
+++ b/src/Lucene.Net.Core/Util/NumericUtils.cs
@@ -100,35 +100,44 @@ namespace Lucene.Net.Util
         /// <summary>
         /// Returns prefix coded bits after reducing the precision by <code>shift</code> bits.
         /// this is method is used by <seealso cref="NumericTokenStream"/>.
-        /// After encoding, {@code bytes.offset} will always be 0. </summary>
+        /// After encoding, {@code bytes.offset} will always be 0. 
+        /// <para/>
+        /// NOTE: This was longToPrefixCoded() in Lucene
+        /// </summary>
         /// <param name="val"> the numeric value </param>
         /// <param name="shift"> how many bits to strip from the right </param>
         /// <param name="bytes"> will contain the encoded value </param>
-        public static void LongToPrefixCoded(long val, int shift, BytesRef bytes) // LUCENENET TODO: Rename to Int64ToPrefixCoded ?
+        public static void Int64ToPrefixCoded(long val, int shift, BytesRef bytes)
         {
-            LongToPrefixCodedBytes(val, shift, bytes);
+            Int64ToPrefixCodedBytes(val, shift, bytes);
         }
 
         /// <summary>
         /// Returns prefix coded bits after reducing the precision by <code>shift</code> bits.
         /// this is method is used by <seealso cref="NumericTokenStream"/>.
-        /// After encoding, {@code bytes.offset} will always be 0. </summary>
+        /// After encoding, {@code bytes.offset} will always be 0. 
+        /// <para/>
+        /// NOTE: This was intToPrefixCoded() in Lucene
+        /// </summary>
         /// <param name="val"> the numeric value </param>
         /// <param name="shift"> how many bits to strip from the right </param>
         /// <param name="bytes"> will contain the encoded value </param>
-        public static void IntToPrefixCoded(int val, int shift, BytesRef bytes) // LUCENENET TODO: Rename to Int32ToPrefixCoded ?
+        public static void Int32ToPrefixCoded(int val, int shift, BytesRef bytes)
         {
-            IntToPrefixCodedBytes(val, shift, bytes);
+            Int32ToPrefixCodedBytes(val, shift, bytes);
         }
 
         /// <summary>
         /// Returns prefix coded bits after reducing the precision by <code>shift</code> bits.
         /// this is method is used by <seealso cref="NumericTokenStream"/>.
-        /// After encoding, {@code bytes.offset} will always be 0. </summary>
+        /// After encoding, {@code bytes.offset} will always be 0. 
+        /// <para/>
+        /// NOTE: This was longToPrefixCodedBytes() in Lucene
+        /// </summary>
         /// <param name="val"> the numeric value </param>
         /// <param name="shift"> how many bits to strip from the right </param>
         /// <param name="bytes"> will contain the encoded value </param>
-        public static void LongToPrefixCodedBytes(long val, int shift, BytesRef bytes) // LUCENENET TODO: Rename to Int64ToPrefixCodedBytes ?
+        public static void Int64ToPrefixCodedBytes(long val, int shift, BytesRef bytes)
         {
             if ((shift & ~0x3f) != 0) // ensure shift is 0..63
             {
@@ -156,11 +165,14 @@ namespace Lucene.Net.Util
         /// <summary>
         /// Returns prefix coded bits after reducing the precision by <code>shift</code> bits.
         /// this is method is used by <seealso cref="NumericTokenStream"/>.
-        /// After encoding, {@code bytes.offset} will always be 0. </summary>
+        /// After encoding, {@code bytes.offset} will always be 0. 
+        /// <para/>
+        /// NOTE: This was intToPrefixCodedBytes() in Lucene
+        /// </summary>
         /// <param name="val"> the numeric value </param>
         /// <param name="shift"> how many bits to strip from the right </param>
         /// <param name="bytes"> will contain the encoded value </param>
-        public static void IntToPrefixCodedBytes(int val, int shift, BytesRef bytes) // LUCENENET TODO: Int64ToPrefixCodedBytes ?
+        public static void Int32ToPrefixCodedBytes(int val, int shift, BytesRef bytes)
         {
             if ((shift & ~0x1f) != 0) // ensure shift is 0..31
             {
@@ -186,10 +198,13 @@ namespace Lucene.Net.Util
         }
 
         /// <summary>
-        /// Returns the shift value from a prefix encoded {@code long}. </summary>
+        /// Returns the shift value from a prefix encoded {@code long}. 
+        /// <para/>
+        /// NOTE: This was getPrefixCodedLongShift() in Lucene
+        /// </summary>
         /// <exception cref="NumberFormatException"> if the supplied <seealso cref="BytesRef"/> is
         /// not correctly prefix encoded. </exception>
-        public static int GetPrefixCodedLongShift(BytesRef val) // LUCENENET TODO: Rename to GetPrefixCodedInt64Shift ?
+        public static int GetPrefixCodedInt64Shift(BytesRef val)
         {
             int shift = val.Bytes[val.Offset] - SHIFT_START_LONG;
             if (shift > 63 || shift < 0)
@@ -200,10 +215,13 @@ namespace Lucene.Net.Util
         }
 
         /// <summary>
-        /// Returns the shift value from a prefix encoded {@code int}. </summary>
+        /// Returns the shift value from a prefix encoded {@code int}. 
+        /// <para/>
+        /// NOTE: This was getPrefixCodedIntShift() in Lucene
+        /// </summary>
         /// <exception cref="NumberFormatException"> if the supplied <seealso cref="BytesRef"/> is
         /// not correctly prefix encoded. </exception>
-        public static int GetPrefixCodedIntShift(BytesRef val) // LUCENENET TODO: Rename GetPrefixCodedInt32Shift ?
+        public static int GetPrefixCodedInt32Shift(BytesRef val)
         {
             int shift = val.Bytes[val.Offset] - SHIFT_START_INT;
             if (shift > 31 || shift < 0)
@@ -216,11 +234,14 @@ namespace Lucene.Net.Util
         /// <summary>
         /// Returns a long from prefixCoded bytes.
         /// Rightmost bits will be zero for lower precision codes.
-        /// this method can be used to decode a term's value. </summary>
+        /// this method can be used to decode a term's value. 
+        /// <para/>
+        /// NOTE: This was prefixCodedToLong() in Lucene
+        /// </summary>
         /// <exception cref="NumberFormatException"> if the supplied <seealso cref="BytesRef"/> is
         /// not correctly prefix encoded. </exception>
         /// <seealso cref= #longToPrefixCodedBytes </seealso>
-        public static long PrefixCodedToLong(BytesRef val) // LUCENENET TODO: Rename PrefixCodedToInt64 ?
+        public static long PrefixCodedToInt64(BytesRef val)
         {
             long sortableBits = 0L;
             for (int i = val.Offset + 1, limit = val.Offset + val.Length; i < limit; i++)
@@ -233,17 +254,20 @@ namespace Lucene.Net.Util
                 }
                 sortableBits |= (byte)b;
             }
-            return (long)((ulong)(sortableBits << GetPrefixCodedLongShift(val)) ^ 0x8000000000000000L);
+            return (long)((ulong)(sortableBits << GetPrefixCodedInt64Shift(val)) ^ 0x8000000000000000L);
         }
 
         /// <summary>
         /// Returns an int from prefixCoded bytes.
         /// Rightmost bits will be zero for lower precision codes.
-        /// this method can be used to decode a term's value. </summary>
+        /// this method can be used to decode a term's value. 
+        /// <para/>
+        /// NOTE: This was prefixCodedToInt() in Lucene
+        /// </summary>
         /// <exception cref="NumberFormatException"> if the supplied <seealso cref="BytesRef"/> is
         /// not correctly prefix encoded. </exception>
         /// <seealso cref= #intToPrefixCodedBytes </seealso>
-        public static int PrefixCodedToInt(BytesRef val) // LUCENENET TODO: Rename PrefixCodedToInt32 ?
+        public static int PrefixCodedToInt32(BytesRef val)
         {
             long sortableBits = 0;
             for (int i = val.Offset, limit = val.Offset + val.Length; i < limit; i++)
@@ -256,7 +280,7 @@ namespace Lucene.Net.Util
                 }
                 sortableBits |= (sbyte)b;
             }
-            return (int)((sortableBits << GetPrefixCodedIntShift(val)) ^ 0x80000000);
+            return (int)((sortableBits << GetPrefixCodedInt32Shift(val)) ^ 0x80000000);
         }
 
         /// <summary>
@@ -265,11 +289,14 @@ namespace Lucene.Net.Util
         /// bit layout and then some bits are swapped, to be able to compare the result as long.
         /// By this the precision is not reduced, but the value can easily used as a long.
         /// The sort order (including <seealso cref="Double#NaN"/>) is defined by
-        /// <seealso cref="Double#compareTo"/>; {@code NaN} is greater than positive infinity. </summary>
+        /// <seealso cref="Double#compareTo"/>; {@code NaN} is greater than positive infinity. 
+        /// <para/>
+        /// NOTE: This was doubleToSortableLong() in Lucene
+        /// </summary>
         /// <seealso cref= #sortableLongToDouble </seealso>
-        public static long DoubleToSortableLong(double val) // LUCENENET TODO: Rename DoubleToSortableInt64 ?
+        public static long DoubleToSortableInt64(double val)
         {
-            long f = Number.DoubleToLongBits(val);
+            long f = Number.DoubleToInt64Bits(val);
             if (f < 0)
             {
                 f ^= 0x7fffffffffffffffL;
@@ -278,9 +305,12 @@ namespace Lucene.Net.Util
         }
 
         /// <summary>
-        /// Converts a sortable <code>long</code> back to a <code>double</code>. </summary>
+        /// Converts a sortable <code>long</code> back to a <code>double</code>. 
+        /// <para/>
+        /// NOTE: This was sortableLongToDouble() in Lucene
+        /// </summary>
         /// <seealso cref= #doubleToSortableLong </seealso>
-        public static double SortableLongToDouble(long val) // LUCENENET TODO: Rename SortableInt64ToDouble ?
+        public static double SortableInt64ToDouble(long val)
         {
             if (val < 0)
             {
@@ -295,11 +325,14 @@ namespace Lucene.Net.Util
         /// bit layout and then some bits are swapped, to be able to compare the result as int.
         /// By this the precision is not reduced, but the value can easily used as an int.
         /// The sort order (including <seealso cref="Float#NaN"/>) is defined by
-        /// <seealso cref="Float#compareTo"/>; {@code NaN} is greater than positive infinity. </summary>
+        /// <seealso cref="Float#compareTo"/>; {@code NaN} is greater than positive infinity. 
+        /// <para/>
+        /// NOTE: This was floatToSortableInt() in Lucene
+        /// </summary>
         /// <seealso cref= #sortableIntToFloat </seealso>
-        public static int FloatToSortableInt(float val) // LUCENENET TODO: rename SingleToSortableInt32 ?
+        public static int SingleToSortableInt32(float val)
         {
-            int f = Number.FloatToIntBits(val);
+            int f = Number.SingleToInt32Bits(val);
             if (f < 0)
             {
                 f ^= 0x7fffffff;
@@ -308,15 +341,18 @@ namespace Lucene.Net.Util
         }
 
         /// <summary>
-        /// Converts a sortable <code>int</code> back to a <code>float</code>. </summary>
-        /// <seealso cref= #floatToSortableInt </seealso>
-        public static float SortableIntToFloat(int val) // LUCENENET TODO: rename SortableInt32ToSingle ?
+        /// Converts a sortable <see cref="int"/> back to a <see cref="float"/>. 
+        /// <para/>
+        /// NOTE: This was sortableIntToFloat() in Lucene
+        /// </summary>
+        /// <seealso cref="SingleToSortableInt32"/>
+        public static float SortableInt32ToSingle(int val)
         {
             if (val < 0)
             {
                 val ^= 0x7fffffff;
             }
-            return Number.IntBitsToFloat(val);
+            return Number.Int32BitsToSingle(val);
         }
 
         /// <summary>
@@ -325,9 +361,12 @@ namespace Lucene.Net.Util
         /// <seealso cref="Lucene.Net.Search.BooleanQuery"/> for each call to its
         /// <seealso cref="LongRangeBuilder#addRange(BytesRef,BytesRef)"/>
         /// method.
-        /// <p>this method is used by <seealso cref="NumericRangeQuery"/>.
+        /// <para/>
+        /// this method is used by <seealso cref="NumericRangeQuery"/>.
+        /// <para/>
+        /// NOTE: This was splitLongRange() in Lucene
         /// </summary>
-        public static void SplitLongRange(LongRangeBuilder builder, int precisionStep, long minBound, long maxBound) // LUCENENET TODO: Rename SplitIn64Range ?
+        public static void SplitInt64Range(LongRangeBuilder builder, int precisionStep, long minBound, long maxBound)
         {
             SplitRange(builder, 64, precisionStep, minBound, maxBound);
         }
@@ -338,9 +377,12 @@ namespace Lucene.Net.Util
         /// <seealso cref="Lucene.Net.Search.BooleanQuery"/> for each call to its
         /// <seealso cref="IntRangeBuilder#addRange(BytesRef,BytesRef)"/>
         /// method.
-        /// <p>this method is used by <seealso cref="NumericRangeQuery"/>.
+        /// <para/>
+        /// this method is used by <seealso cref="NumericRangeQuery"/>.
+        /// <para/>
+        /// NOTE: This was splitIntRange() in Lucene
         /// </summary>
-        public static void SplitIntRange(IntRangeBuilder builder, int precisionStep, int minBound, int maxBound) // LUCENENET TODO: rename SplitInt32Range ?
+        public static void SplitInt32Range(IntRangeBuilder builder, int precisionStep, int minBound, int maxBound)
         {
             SplitRange(builder, 32, precisionStep, minBound, maxBound);
         }
@@ -438,8 +480,8 @@ namespace Lucene.Net.Util
             public virtual void AddRange(long min, long max, int shift)
             {
                 BytesRef minBytes = new BytesRef(BUF_SIZE_LONG), maxBytes = new BytesRef(BUF_SIZE_LONG);
-                LongToPrefixCodedBytes(min, shift, minBytes);
-                LongToPrefixCodedBytes(max, shift, maxBytes);
+                Int64ToPrefixCodedBytes(min, shift, minBytes);
+                Int64ToPrefixCodedBytes(max, shift, maxBytes);
                 AddRange(minBytes, maxBytes);
             }
         }
@@ -468,8 +510,8 @@ namespace Lucene.Net.Util
             public virtual void AddRange(int min, int max, int shift)
             {
                 BytesRef minBytes = new BytesRef(BUF_SIZE_INT), maxBytes = new BytesRef(BUF_SIZE_INT);
-                IntToPrefixCodedBytes(min, shift, minBytes);
-                IntToPrefixCodedBytes(max, shift, maxBytes);
+                Int32ToPrefixCodedBytes(min, shift, minBytes);
+                Int32ToPrefixCodedBytes(max, shift, maxBytes);
                 AddRange(minBytes, maxBytes);
             }
         }
@@ -477,12 +519,14 @@ namespace Lucene.Net.Util
         /// <summary>
         /// Filters the given <seealso cref="TermsEnum"/> by accepting only prefix coded 64 bit
         /// terms with a shift value of <tt>0</tt>.
+        /// <para/>
+        /// NOTE: This was filterPrefixCodedLongs() in Lucene
         /// </summary>
         /// <param name="termsEnum">
         ///          the terms enum to filter </param>
         /// <returns> a filtered <seealso cref="TermsEnum"/> that only returns prefix coded 64 bit
         ///         terms with a shift value of <tt>0</tt>. </returns>
-        public static TermsEnum FilterPrefixCodedLongs(TermsEnum termsEnum) // LUCENENET TODO: Rename FilterPrefixCodedInt64s ?
+        public static TermsEnum FilterPrefixCodedInt64s(TermsEnum termsEnum)
         {
             return new FilteredTermsEnumAnonymousInnerClassHelper(termsEnum);
         }
@@ -496,19 +540,21 @@ namespace Lucene.Net.Util
 
             protected override AcceptStatus Accept(BytesRef term)
             {
-                return NumericUtils.GetPrefixCodedLongShift(term) == 0 ? AcceptStatus.YES : AcceptStatus.END;
+                return NumericUtils.GetPrefixCodedInt64Shift(term) == 0 ? AcceptStatus.YES : AcceptStatus.END;
             }
         }
 
         /// <summary>
         /// Filters the given <seealso cref="TermsEnum"/> by accepting only prefix coded 32 bit
         /// terms with a shift value of <tt>0</tt>.
+        /// <para/>
+        /// NOTE: This was filterPrefixCodedInts() in Lucene
         /// </summary>
         /// <param name="termsEnum">
         ///          the terms enum to filter </param>
         /// <returns> a filtered <seealso cref="TermsEnum"/> that only returns prefix coded 32 bit
         ///         terms with a shift value of <tt>0</tt>. </returns>
-        public static TermsEnum FilterPrefixCodedInts(TermsEnum termsEnum) // LUCENENET TODO: Rename FilterPrefixCodedInt32s ?
+        public static TermsEnum FilterPrefixCodedInt32s(TermsEnum termsEnum)
         {
             return new FilteredTermsEnumAnonymousInnerClassHelper2(termsEnum);
         }
@@ -522,7 +568,7 @@ namespace Lucene.Net.Util
 
             protected override AcceptStatus Accept(BytesRef term)
             {
-                return NumericUtils.GetPrefixCodedIntShift(term) == 0 ? AcceptStatus.YES : AcceptStatus.END;
+                return NumericUtils.GetPrefixCodedInt32Shift(term) == 0 ? AcceptStatus.YES : AcceptStatus.END;
             }
         }
     }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Util/OfflineSorter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/OfflineSorter.cs b/src/Lucene.Net.Core/Util/OfflineSorter.cs
index 72a2aea..379d6a8 100644
--- a/src/Lucene.Net.Core/Util/OfflineSorter.cs
+++ b/src/Lucene.Net.Core/Util/OfflineSorter.cs
@@ -571,7 +571,7 @@ namespace Lucene.Net.Util
                 Debug.Assert(bytes != null);
                 Debug.Assert(off >= 0 && off + len <= bytes.Length);
                 Debug.Assert(len >= 0);
-                os.WriteShort((short)len);
+                os.WriteInt16((short)len);
                 os.WriteBytes(bytes, off, len); // LUCENENET NOTE: We call WriteBytes, since there is no Write() on Lucene's version of DataOutput
             }
 
@@ -622,7 +622,7 @@ namespace Lucene.Net.Util
                 ushort length;
                 try
                 {
-                    length = (ushort)inputStream.ReadShort();
+                    length = (ushort)inputStream.ReadInt16();
                 }
                 catch (Exception)
                 {
@@ -649,7 +649,7 @@ namespace Lucene.Net.Util
                 ushort length;
                 try
                 {
-                    length = (ushort)inputStream.ReadShort();
+                    length = (ushort)inputStream.ReadInt16();
                 }
 #pragma warning disable 168
                 catch (Exception e)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Util/Packed/AbstractBlockPackedWriter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Packed/AbstractBlockPackedWriter.cs b/src/Lucene.Net.Core/Util/Packed/AbstractBlockPackedWriter.cs
index 70e2905..250fa7d 100644
--- a/src/Lucene.Net.Core/Util/Packed/AbstractBlockPackedWriter.cs
+++ b/src/Lucene.Net.Core/Util/Packed/AbstractBlockPackedWriter.cs
@@ -35,8 +35,11 @@ namespace Lucene.Net.Util.Packed
             return (n >> 63) ^ (n << 1);
         }
 
-        // same as DataOutput.writeVLong but accepts negative values
-        internal static void WriteVLong(DataOutput @out, long i)
+        // same as DataOutput.WriteVInt64 but accepts negative values
+        /// <summary>
+        /// NOTE: This was writeVLong() in Lucene
+        /// </summary>
+        internal static void WriteVInt64(DataOutput @out, long i)
         {
             int k = 0;
             while ((i & ~0x7FL) != 0L && k++ < 8)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Util/Packed/BlockPackedReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Packed/BlockPackedReader.cs b/src/Lucene.Net.Core/Util/Packed/BlockPackedReader.cs
index 7e87b6e..43f1a0d 100644
--- a/src/Lucene.Net.Core/Util/Packed/BlockPackedReader.cs
+++ b/src/Lucene.Net.Core/Util/Packed/BlockPackedReader.cs
@@ -56,7 +56,7 @@ namespace Lucene.Net.Util.Packed
                     {
                         minValues = new long[numBlocks];
                     }
-                    minValues[i] = BlockPackedReaderIterator.ZigZagDecode(1L + BlockPackedReaderIterator.ReadVLong(@in));
+                    minValues[i] = BlockPackedReaderIterator.ZigZagDecode(1L + BlockPackedReaderIterator.ReadVInt64(@in));
                 }
                 if (bitsPerValue == 0)
                 {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Util/Packed/BlockPackedReaderIterator.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Packed/BlockPackedReaderIterator.cs b/src/Lucene.Net.Core/Util/Packed/BlockPackedReaderIterator.cs
index c46123c..f837834 100644
--- a/src/Lucene.Net.Core/Util/Packed/BlockPackedReaderIterator.cs
+++ b/src/Lucene.Net.Core/Util/Packed/BlockPackedReaderIterator.cs
@@ -35,8 +35,11 @@ namespace Lucene.Net.Util.Packed
             return (((long)((ulong)n >> 1)) ^ -(n & 1));
         }
 
-        // same as DataInput.readVLong but supports negative values
-        internal static long ReadVLong(DataInput @in) // LUCENENET TODO: rename to ReadVInt64 ?
+        // same as DataInput.ReadVInt64 but supports negative values
+        /// <summary>
+        /// NOTE: This was readVLong() in Lucene
+        /// </summary>
+        internal static long ReadVInt64(DataInput @in)
         {
             byte b = @in.ReadByte();
             if ((sbyte)b >= 0)
@@ -161,7 +164,7 @@ namespace Lucene.Net.Util.Packed
                 }
                 if ((token & AbstractBlockPackedWriter.MIN_VALUE_EQUALS_0) == 0)
                 {
-                    ReadVLong(@in);
+                    ReadVInt64(@in);
                 }
                 long blockBytes = PackedInts.Format.PACKED.ByteCount(packedIntsVersion, blockSize, bitsPerValue);
                 SkipBytes(blockBytes);
@@ -253,7 +256,7 @@ namespace Lucene.Net.Util.Packed
             {
                 throw new System.IO.IOException("Corrupted");
             }
-            long minValue = minEquals0 ? 0L : ZigZagDecode(1L + ReadVLong(@in));
+            long minValue = minEquals0 ? 0L : ZigZagDecode(1L + ReadVInt64(@in));
             Debug.Assert(minEquals0 || minValue != 0);
 
             if (bitsPerValue == 0)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Util/Packed/BlockPackedWriter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Packed/BlockPackedWriter.cs b/src/Lucene.Net.Core/Util/Packed/BlockPackedWriter.cs
index 20d0edd..bbcf981 100644
--- a/src/Lucene.Net.Core/Util/Packed/BlockPackedWriter.cs
+++ b/src/Lucene.Net.Core/Util/Packed/BlockPackedWriter.cs
@@ -93,7 +93,7 @@ namespace Lucene.Net.Util.Packed
 
             if (min != 0)
             {
-                WriteVLong(m_out, ZigZagEncode(min) - 1);
+                WriteVInt64(m_out, ZigZagEncode(min) - 1);
             }
 
             if (bitsRequired > 0)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Util/Packed/BulkOperation.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Packed/BulkOperation.cs b/src/Lucene.Net.Core/Util/Packed/BulkOperation.cs
index 486612d..9bcc8f2 100644
--- a/src/Lucene.Net.Core/Util/Packed/BulkOperation.cs
+++ b/src/Lucene.Net.Core/Util/Packed/BulkOperation.cs
@@ -47,9 +47,15 @@ namespace Lucene.Net.Util.Packed
 
         public abstract int ByteBlockCount { get; }
 
-        public abstract int LongValueCount { get; } // LUCENENET TODO: Rename Int64ValueCount ?
+        /// <summary>
+        /// NOTE: This was longValueCount() in Lucene
+        /// </summary>
+        public abstract int Int64ValueCount { get; }
 
-        public abstract int LongBlockCount { get; } // LUCENENET TODO: Rename Int64BlockCount ?
+        /// <summary>
+        /// NOTE: This was longBlockCount() in Lucene
+        /// </summary>
+        public abstract int Int64BlockCount { get; }
 
         private static readonly BulkOperation[] packedBulkOps = new BulkOperation[] {
             new BulkOperationPacked1(),
@@ -172,7 +178,10 @@ namespace Lucene.Net.Util.Packed
             }
         }
 
-        protected virtual int WriteLong(long block, byte[] blocks, int blocksOffset) // LUCENENET TODO: Rename WriteInt64 ?
+        /// <summary>
+        /// NOTE: This was writeLong() in Lucene
+        /// </summary>
+        protected virtual int WriteInt64(long block, byte[] blocks, int blocksOffset)
         {
             for (int j = 1; j <= 8; ++j)
             {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Util/Packed/BulkOperationPacked.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Packed/BulkOperationPacked.cs b/src/Lucene.Net.Core/Util/Packed/BulkOperationPacked.cs
index 83ebd19..2c32f31 100644
--- a/src/Lucene.Net.Core/Util/Packed/BulkOperationPacked.cs
+++ b/src/Lucene.Net.Core/Util/Packed/BulkOperationPacked.cs
@@ -64,12 +64,18 @@ namespace Lucene.Net.Util.Packed
             Debug.Assert(longValueCount * bitsPerValue == 64 * longBlockCount);
         }
 
-        public override int LongBlockCount
+        /// <summary>
+        /// NOTE: This was longBlockCount() in Lucene
+        /// </summary>
+        public override int Int64BlockCount
         {
             get { return longBlockCount; }
         }
 
-        public override int LongValueCount
+        /// <summary>
+        /// NOTE: This was longValueCount() in Lucene
+        /// </summary>
+        public override int Int64ValueCount
         {
             get { return longValueCount; }
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Util/Packed/BulkOperationPackedSingleBlock.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Packed/BulkOperationPackedSingleBlock.cs b/src/Lucene.Net.Core/Util/Packed/BulkOperationPackedSingleBlock.cs
index 93ada86..a8cfa90 100644
--- a/src/Lucene.Net.Core/Util/Packed/BulkOperationPackedSingleBlock.cs
+++ b/src/Lucene.Net.Core/Util/Packed/BulkOperationPackedSingleBlock.cs
@@ -35,7 +35,10 @@ namespace Lucene.Net.Util.Packed
             this.mask = (1L << bitsPerValue) - 1;
         }
 
-        public override sealed int LongBlockCount
+        /// <summary>
+        /// NOTE: This was longBlockCount() in Lucene
+        /// </summary>
+        public override sealed int Int64BlockCount
         {
             get { return BLOCK_COUNT; }
         }
@@ -45,7 +48,10 @@ namespace Lucene.Net.Util.Packed
             get { return BLOCK_COUNT * 8; }
         }
 
-        public override int LongValueCount
+        /// <summary>
+        /// NOTE: This was longValueCount() in Lucene
+        /// </summary>
+        public override int Int64ValueCount
         {
             get { return valueCount; }
         }
@@ -55,7 +61,10 @@ namespace Lucene.Net.Util.Packed
             get { return valueCount; }
         }
 
-        private static long ReadLong(byte[] blocks, int blocksOffset)
+        /// <summary>
+        /// NOTE: This was readLong() in Lucene
+        /// </summary>
+        private static long ReadInt64(byte[] blocks, int blocksOffset)
         {
             return (((sbyte)blocks[blocksOffset++]) & 0xFFL) << 56 | (((sbyte)blocks[blocksOffset++]) & 0xFFL) << 48 | 
                 (((sbyte)blocks[blocksOffset++]) & 0xFFL) << 40 | (((sbyte)blocks[blocksOffset++]) & 0xFFL) << 32 |
@@ -118,7 +127,7 @@ namespace Lucene.Net.Util.Packed
         {
             for (int i = 0; i < iterations; ++i)
             {
-                long block = ReadLong(blocks, blocksOffset);
+                long block = ReadInt64(blocks, blocksOffset);
                 blocksOffset += 8;
                 valuesOffset = Decode(block, values, valuesOffset);
             }
@@ -145,7 +154,7 @@ namespace Lucene.Net.Util.Packed
             }
             for (int i = 0; i < iterations; ++i)
             {
-                long block = ReadLong(blocks, blocksOffset);
+                long block = ReadInt64(blocks, blocksOffset);
                 blocksOffset += 8;
                 valuesOffset = Decode(block, values, valuesOffset);
             }
@@ -175,7 +184,7 @@ namespace Lucene.Net.Util.Packed
             {
                 long block = Encode(values, valuesOffset);
                 valuesOffset += valueCount;
-                blocksOffset = WriteLong(block, blocks, blocksOffset);
+                blocksOffset = WriteInt64(block, blocks, blocksOffset);
             }
         }
 
@@ -185,7 +194,7 @@ namespace Lucene.Net.Util.Packed
             {
                 long block = Encode(values, valuesOffset);
                 valuesOffset += valueCount;
-                blocksOffset = WriteLong(block, blocks, blocksOffset);
+                blocksOffset = WriteInt64(block, blocks, blocksOffset);
             }
         }
     }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Util/Packed/Direct16.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Packed/Direct16.cs b/src/Lucene.Net.Core/Util/Packed/Direct16.cs
index b1ad785..1a834ea 100644
--- a/src/Lucene.Net.Core/Util/Packed/Direct16.cs
+++ b/src/Lucene.Net.Core/Util/Packed/Direct16.cs
@@ -44,7 +44,7 @@ namespace Lucene.Net.Util.Packed
         {
             for (int i = 0; i < valueCount; ++i)
             {
-                values[i] = @in.ReadShort();
+                values[i] = @in.ReadInt16();
             }
             // because packed ints have not always been byte-aligned
             int remaining = (int)(PackedInts.Format.PACKED.ByteCount(packedIntsVersion, valueCount, 16) - 2L * valueCount);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Util/Packed/Direct32.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Packed/Direct32.cs b/src/Lucene.Net.Core/Util/Packed/Direct32.cs
index c74cb23..f9d62c2 100644
--- a/src/Lucene.Net.Core/Util/Packed/Direct32.cs
+++ b/src/Lucene.Net.Core/Util/Packed/Direct32.cs
@@ -44,7 +44,7 @@ namespace Lucene.Net.Util.Packed
         {
             for (int i = 0; i < valueCount; ++i)
             {
-                values[i] = @in.ReadInt();
+                values[i] = @in.ReadInt32();
             }
             // because packed ints have not always been byte-aligned
             int remaining = (int)(PackedInts.Format.PACKED.ByteCount(packedIntsVersion, valueCount, 32) - 4L * valueCount);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Util/Packed/Direct64.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Packed/Direct64.cs b/src/Lucene.Net.Core/Util/Packed/Direct64.cs
index 978a23c..0c7cb36 100644
--- a/src/Lucene.Net.Core/Util/Packed/Direct64.cs
+++ b/src/Lucene.Net.Core/Util/Packed/Direct64.cs
@@ -44,7 +44,7 @@ namespace Lucene.Net.Util.Packed
         {
             for (int i = 0; i < valueCount; ++i)
             {
-                values[i] = @in.ReadLong();
+                values[i] = @in.ReadInt64();
             }
         }
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Util/Packed/DirectPacked64SingleBlockReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Packed/DirectPacked64SingleBlockReader.cs b/src/Lucene.Net.Core/Util/Packed/DirectPacked64SingleBlockReader.cs
index 34bfbf5..1ca3e1f 100644
--- a/src/Lucene.Net.Core/Util/Packed/DirectPacked64SingleBlockReader.cs
+++ b/src/Lucene.Net.Core/Util/Packed/DirectPacked64SingleBlockReader.cs
@@ -45,7 +45,7 @@ namespace Lucene.Net.Util.Packed
             {
                 @in.Seek(startPointer + skip);
 
-                long block = @in.ReadLong();
+                long block = @in.ReadInt64();
                 int offsetInBlock = index % valuesPerBlock;
                 return ((long)((ulong)block >> (offsetInBlock * m_bitsPerValue))) & mask;
             }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Util/Packed/DirectPackedReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Packed/DirectPackedReader.cs b/src/Lucene.Net.Core/Util/Packed/DirectPackedReader.cs
index c63f34a..a6a2aac 100644
--- a/src/Lucene.Net.Core/Util/Packed/DirectPackedReader.cs
+++ b/src/Lucene.Net.Core/Util/Packed/DirectPackedReader.cs
@@ -67,37 +67,37 @@ namespace Lucene.Net.Util.Packed
                         break;
 
                     case 2:
-                        rawValue = @in.ReadShort();
+                        rawValue = @in.ReadInt16();
                         break;
 
                     case 3:
-                        rawValue = ((long)@in.ReadShort() << 8) | (@in.ReadByte() & 0xFFL);
+                        rawValue = ((long)@in.ReadInt16() << 8) | (@in.ReadByte() & 0xFFL);
                         break;
 
                     case 4:
-                        rawValue = @in.ReadInt();
+                        rawValue = @in.ReadInt32();
                         break;
 
                     case 5:
-                        rawValue = ((long)@in.ReadInt() << 8) | (@in.ReadByte() & 0xFFL);
+                        rawValue = ((long)@in.ReadInt32() << 8) | (@in.ReadByte() & 0xFFL);
                         break;
 
                     case 6:
-                        rawValue = ((long)@in.ReadInt() << 16) | (@in.ReadShort() & 0xFFFFL);
+                        rawValue = ((long)@in.ReadInt32() << 16) | (@in.ReadInt16() & 0xFFFFL);
                         break;
 
                     case 7:
-                        rawValue = ((long)@in.ReadInt() << 24) | ((@in.ReadShort() & 0xFFFFL) << 8) | (@in.ReadByte() & 0xFFL);
+                        rawValue = ((long)@in.ReadInt32() << 24) | ((@in.ReadInt16() & 0xFFFFL) << 8) | (@in.ReadByte() & 0xFFL);
                         break;
 
                     case 8:
-                        rawValue = @in.ReadLong();
+                        rawValue = @in.ReadInt64();
                         break;
 
                     case 9:
                         // We must be very careful not to shift out relevant bits. So we account for right shift
                         // we would normally do on return here, and reset it.
-                        rawValue = (@in.ReadLong() << (8 - shiftRightBits)) | ((int)((uint)(@in.ReadByte() & 0xFFL) >> shiftRightBits));
+                        rawValue = (@in.ReadInt64() << (8 - shiftRightBits)) | ((int)((uint)(@in.ReadByte() & 0xFFL) >> shiftRightBits));
                         shiftRightBits = 0;
                         break;
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Util/Packed/EliasFanoDecoder.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Packed/EliasFanoDecoder.cs b/src/Lucene.Net.Core/Util/Packed/EliasFanoDecoder.cs
index 581044d..7e4c1d6 100644
--- a/src/Lucene.Net.Core/Util/Packed/EliasFanoDecoder.cs
+++ b/src/Lucene.Net.Core/Util/Packed/EliasFanoDecoder.cs
@@ -194,9 +194,11 @@ namespace Lucene.Net.Util.Packed
 
         /// <summary>
         /// The current high long has been determined to not contain the set bit that is needed.
-        ///  Increment setBitForIndex to the next high long and set curHighLong accordingly.
+        /// Increment setBitForIndex to the next high long and set curHighLong accordingly.
+        /// <para/>
+        /// NOTE: this was toNextHighLong() in Lucene
         /// </summary>
-        private void ToNextHighLong()
+        private void ToNextHighInt64()
         {
             setBitForIndex += (sizeof(long) * 8) - (setBitForIndex & ((sizeof(long) * 8) - 1));
             //assert getCurrentRightShift() == 0;
@@ -212,7 +214,7 @@ namespace Lucene.Net.Util.Packed
         {
             while (curHighLong == 0L)
             {
-                ToNextHighLong(); // inlining and unrolling would simplify somewhat
+                ToNextHighInt64(); // inlining and unrolling would simplify somewhat
             }
             setBitForIndex += Number.NumberOfTrailingZeros(curHighLong);
         }
@@ -265,7 +267,7 @@ namespace Lucene.Net.Util.Packed
             while ((efIndex + curSetBits) < index) // curHighLong has not enough set bits to reach index
             {
                 efIndex += curSetBits;
-                ToNextHighLong();
+                ToNextHighInt64();
                 curSetBits = Number.BitCount(curHighLong);
             }
             // curHighLong has enough set bits to reach index
@@ -449,9 +451,11 @@ namespace Lucene.Net.Util.Packed
 
         /// <summary>
         /// The current high long has been determined to not contain the set bit that is needed.
-        ///  Decrement setBitForIndex to the previous high long and set curHighLong accordingly.
+        /// Decrement setBitForIndex to the previous high long and set curHighLong accordingly.
+        /// <para/>
+        /// NOTE: this was toPreviousHighLong() in Lucene
         /// </summary>
-        private void ToPreviousHighLong()
+        private void ToPreviousHighInt64()
         {
             setBitForIndex -= (setBitForIndex & ((sizeof(long) * 8) - 1)) + 1;
             //assert getCurrentLeftShift() == 0;
@@ -467,7 +471,7 @@ namespace Lucene.Net.Util.Packed
         {
             while (curHighLong == 0L)
             {
-                ToPreviousHighLong(); // inlining and unrolling would simplify somewhat
+                ToPreviousHighInt64(); // inlining and unrolling would simplify somewhat
             }
             setBitForIndex -= Number.NumberOfLeadingZeros(curHighLong);
             return CurrentHighValue();
@@ -506,7 +510,7 @@ namespace Lucene.Net.Util.Packed
                 {
                     return NO_MORE_VALUES;
                 }
-                ToPreviousHighLong();
+                ToPreviousHighInt64();
                 //assert getCurrentLeftShift() == 0;
                 curSetBits = Number.BitCount(curHighLong);
                 curClearBits = (sizeof(long) * 8) - curSetBits;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Util/Packed/EliasFanoEncoder.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Packed/EliasFanoEncoder.cs b/src/Lucene.Net.Core/Util/Packed/EliasFanoEncoder.cs
index cdf6231..2e09188 100644
--- a/src/Lucene.Net.Core/Util/Packed/EliasFanoEncoder.cs
+++ b/src/Lucene.Net.Core/Util/Packed/EliasFanoEncoder.cs
@@ -162,7 +162,7 @@ namespace Lucene.Net.Util.Packed
             this.numLowBits = nLowBits;
             this.lowerBitsMask = (long)(unchecked((ulong)long.MaxValue) >> (sizeof(long) * 8 - 1 - this.numLowBits));
 
-            long numLongsForLowBits = NumLongsForBits(numValues * numLowBits);
+            long numLongsForLowBits = NumInt64sForBits(numValues * numLowBits);
             if (numLongsForLowBits > int.MaxValue)
             {
                 throw new System.ArgumentException("numLongsForLowBits too large to index a long array: " + numLongsForLowBits);
@@ -173,7 +173,7 @@ namespace Lucene.Net.Util.Packed
             Debug.Assert(numHighBitsClear <= (2 * this.numValues));
             long numHighBitsSet = this.numValues;
 
-            long numLongsForHighBits = NumLongsForBits(numHighBitsClear + numHighBitsSet);
+            long numLongsForHighBits = NumInt64sForBits(numHighBitsClear + numHighBitsSet);
             if (numLongsForHighBits > int.MaxValue)
             {
                 throw new System.ArgumentException("numLongsForHighBits too large to index a long array: " + numLongsForHighBits);
@@ -189,7 +189,7 @@ namespace Lucene.Net.Util.Packed
             this.numIndexEntries = (nIndexEntries >= 0) ? nIndexEntries : 0;
             long maxIndexEntry = maxHighValue + numValues - 1; // clear upper bits, set upper bits, start at zero
             this.nIndexEntryBits = (maxIndexEntry <= 0) ? 0 : (64 - Number.NumberOfLeadingZeros(maxIndexEntry));
-            long numLongsForIndexBits = NumLongsForBits(numIndexEntries * nIndexEntryBits);
+            long numLongsForIndexBits = NumInt64sForBits(numIndexEntries * nIndexEntryBits);
             if (numLongsForIndexBits > int.MaxValue)
             {
                 throw new System.ArgumentException("numLongsForIndexBits too large to index a long array: " + numLongsForIndexBits);
@@ -207,7 +207,10 @@ namespace Lucene.Net.Util.Packed
         {
         }
 
-        private static long NumLongsForBits(long numBits) // Note: int version in FixedBitSet.bits2words()
+        /// <summary>
+        /// NOTE: This was numLongsForBits() in Lucene
+        /// </summary>
+        private static long NumInt64sForBits(long numBits) // Note: int version in FixedBitSet.bits2words()
         {
             Debug.Assert(numBits >= 0, numBits.ToString());
             return (long)((ulong)(numBits + (sizeof(long) * 8 - 1)) >> LOG2_LONG_SIZE);
@@ -350,18 +353,18 @@ namespace Lucene.Net.Util.Packed
             s.Append("\nupperLongs[" + upperLongs.Length + "]");
             for (int i = 0; i < upperLongs.Length; i++)
             {
-                s.Append(" " + ToStringUtils.LongHex(upperLongs[i]));
+                s.Append(" " + ToStringUtils.Int64Hex(upperLongs[i]));
             }
             s.Append("\nlowerLongs[" + lowerLongs.Length + "]");
             for (int i = 0; i < lowerLongs.Length; i++)
             {
-                s.Append(" " + ToStringUtils.LongHex(lowerLongs[i]));
+                s.Append(" " + ToStringUtils.Int64Hex(lowerLongs[i]));
             }
             s.Append("\nindexInterval: " + indexInterval + ", nIndexEntryBits: " + nIndexEntryBits);
             s.Append("\nupperZeroBitPositionIndex[" + upperZeroBitPositionIndex.Length + "]");
             for (int i = 0; i < upperZeroBitPositionIndex.Length; i++)
             {
-                s.Append(" " + ToStringUtils.LongHex(upperZeroBitPositionIndex[i]));
+                s.Append(" " + ToStringUtils.Int64Hex(upperZeroBitPositionIndex[i]));
             }
             return s.ToString();
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Util/Packed/MonotonicBlockPackedReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Packed/MonotonicBlockPackedReader.cs b/src/Lucene.Net.Core/Util/Packed/MonotonicBlockPackedReader.cs
index d7ac447..e9dcbf3 100644
--- a/src/Lucene.Net.Core/Util/Packed/MonotonicBlockPackedReader.cs
+++ b/src/Lucene.Net.Core/Util/Packed/MonotonicBlockPackedReader.cs
@@ -48,9 +48,9 @@ namespace Lucene.Net.Util.Packed
             subReaders = new PackedInts.Reader[numBlocks];
             for (int i = 0; i < numBlocks; ++i)
             {
-                minValues[i] = @in.ReadVLong();
-                averages[i] = Number.IntBitsToFloat(@in.ReadInt());
-                int bitsPerValue = @in.ReadVInt();
+                minValues[i] = @in.ReadVInt64();
+                averages[i] = Number.Int32BitsToSingle(@in.ReadInt32());
+                int bitsPerValue = @in.ReadVInt32();
                 if (bitsPerValue > 64)
                 {
                     throw new Exception("Corrupted");

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Util/Packed/MonotonicBlockPackedWriter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Packed/MonotonicBlockPackedWriter.cs b/src/Lucene.Net.Core/Util/Packed/MonotonicBlockPackedWriter.cs
index 545da3c..9d017bb 100644
--- a/src/Lucene.Net.Core/Util/Packed/MonotonicBlockPackedWriter.cs
+++ b/src/Lucene.Net.Core/Util/Packed/MonotonicBlockPackedWriter.cs
@@ -83,16 +83,16 @@ namespace Lucene.Net.Util.Packed
                 maxZigZagDelta = Math.Max(maxZigZagDelta, m_values[i]);
             }
 
-            m_out.WriteVLong(min);
-            m_out.WriteInt(Number.FloatToIntBits(avg));
+            m_out.WriteVInt64(min);
+            m_out.WriteInt32(Number.SingleToInt32Bits(avg));
             if (maxZigZagDelta == 0)
             {
-                m_out.WriteVInt(0);
+                m_out.WriteVInt32(0);
             }
             else
             {
                 int bitsRequired = PackedInts.BitsRequired(maxZigZagDelta);
-                m_out.WriteVInt(bitsRequired);
+                m_out.WriteVInt32(bitsRequired);
                 WriteValues(bitsRequired);
             }
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Util/Packed/Packed16ThreeBlocks.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Packed/Packed16ThreeBlocks.cs b/src/Lucene.Net.Core/Util/Packed/Packed16ThreeBlocks.cs
index 5d9dea6..470ebb8 100644
--- a/src/Lucene.Net.Core/Util/Packed/Packed16ThreeBlocks.cs
+++ b/src/Lucene.Net.Core/Util/Packed/Packed16ThreeBlocks.cs
@@ -50,7 +50,7 @@ namespace Lucene.Net.Util.Packed
         {
             for (int i = 0; i < 3 * valueCount; ++i)
             {
-                blocks[i] = @in.ReadShort();
+                blocks[i] = @in.ReadInt16();
             }
             // because packed ints have not always been byte-aligned
             int remaining = (int)(PackedInts.Format.PACKED.ByteCount(packedIntsVersion, valueCount, 48) - 3L * valueCount * 2);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Util/Packed/Packed64.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Packed/Packed64.cs b/src/Lucene.Net.Core/Util/Packed/Packed64.cs
index cd3e1dc..9f2edf7 100644
--- a/src/Lucene.Net.Core/Util/Packed/Packed64.cs
+++ b/src/Lucene.Net.Core/Util/Packed/Packed64.cs
@@ -72,7 +72,7 @@ namespace Lucene.Net.Util.Packed
             : base(valueCount, bitsPerValue)
         {
             PackedInts.Format format = PackedInts.Format.PACKED;
-            int longCount = format.LongCount(PackedInts.VERSION_CURRENT, valueCount, bitsPerValue);
+            int longCount = format.Int64Count(PackedInts.VERSION_CURRENT, valueCount, bitsPerValue);
             this.blocks = new long[longCount];
             //            MaskRight = ~0L << (int)((uint)(BLOCK_SIZE - bitsPerValue) >> (BLOCK_SIZE - bitsPerValue));    //original
             //            MaskRight = (uint)(~0L << (BLOCK_SIZE - bitsPerValue)) >> (BLOCK_SIZE - bitsPerValue);          //mod
@@ -100,12 +100,12 @@ namespace Lucene.Net.Util.Packed
         {
             PackedInts.Format format = PackedInts.Format.PACKED;
             long byteCount = format.ByteCount(packedIntsVersion, valueCount, bitsPerValue); // to know how much to read
-            int longCount = format.LongCount(PackedInts.VERSION_CURRENT, valueCount, bitsPerValue); // to size the array
+            int longCount = format.Int64Count(PackedInts.VERSION_CURRENT, valueCount, bitsPerValue); // to size the array
             blocks = new long[longCount];
             // read as many longs as we can
             for (int i = 0; i < byteCount / 8; ++i)
             {
-                blocks[i] = @in.ReadLong();
+                blocks[i] = @in.ReadInt64();
             }
             int remaining = (int)(byteCount % 8);
             if (remaining != 0)
@@ -183,10 +183,10 @@ namespace Lucene.Net.Util.Packed
             PackedInts.IDecoder decoder = BulkOperation.Of(PackedInts.Format.PACKED, m_bitsPerValue);
 
             // go to the next block where the value does not span across two blocks
-            int offsetInBlocks = index % decoder.LongValueCount;
+            int offsetInBlocks = index % decoder.Int64ValueCount;
             if (offsetInBlocks != 0)
             {
-                for (int i = offsetInBlocks; i < decoder.LongValueCount && len > 0; ++i)
+                for (int i = offsetInBlocks; i < decoder.Int64ValueCount && len > 0; ++i)
                 {
                     arr[off++] = Get(index++);
                     --len;
@@ -198,12 +198,12 @@ namespace Lucene.Net.Util.Packed
             }
 
             // bulk get
-            Debug.Assert(index % decoder.LongValueCount == 0);
+            Debug.Assert(index % decoder.Int64ValueCount == 0);
             int blockIndex = (int)((ulong)((long)index * m_bitsPerValue) >> BLOCK_BITS);
             Debug.Assert((((long)index * m_bitsPerValue) & MOD_MASK) == 0);
-            int iterations = len / decoder.LongValueCount;
+            int iterations = len / decoder.Int64ValueCount;
             decoder.Decode(blocks, blockIndex, arr, off, iterations);
-            int gotValues = iterations * decoder.LongValueCount;
+            int gotValues = iterations * decoder.Int64ValueCount;
             index += gotValues;
             len -= gotValues;
             Debug.Assert(len >= 0);
@@ -251,10 +251,10 @@ namespace Lucene.Net.Util.Packed
             PackedInts.IEncoder encoder = BulkOperation.Of(PackedInts.Format.PACKED, m_bitsPerValue);
 
             // go to the next block where the value does not span across two blocks
-            int offsetInBlocks = index % encoder.LongValueCount;
+            int offsetInBlocks = index % encoder.Int64ValueCount;
             if (offsetInBlocks != 0)
             {
-                for (int i = offsetInBlocks; i < encoder.LongValueCount && len > 0; ++i)
+                for (int i = offsetInBlocks; i < encoder.Int64ValueCount && len > 0; ++i)
                 {
                     Set(index++, arr[off++]);
                     --len;
@@ -266,12 +266,12 @@ namespace Lucene.Net.Util.Packed
             }
 
             // bulk set
-            Debug.Assert(index % encoder.LongValueCount == 0);
+            Debug.Assert(index % encoder.Int64ValueCount == 0);
             int blockIndex = (int)((ulong)((long)index * m_bitsPerValue) >> BLOCK_BITS);
             Debug.Assert((((long)index * m_bitsPerValue) & MOD_MASK) == 0);
-            int iterations = len / encoder.LongValueCount;
+            int iterations = len / encoder.Int64ValueCount;
             encoder.Encode(arr, off, blocks, blockIndex, iterations);
-            int setValues = iterations * encoder.LongValueCount;
+            int setValues = iterations * encoder.Int64ValueCount;
             index += setValues;
             len -= setValues;
             Debug.Assert(len >= 0);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Util/Packed/Packed64SingleBlock.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Packed/Packed64SingleBlock.cs b/src/Lucene.Net.Core/Util/Packed/Packed64SingleBlock.cs
index 5b48982..7c3f9ff 100644
--- a/src/Lucene.Net.Core/Util/Packed/Packed64SingleBlock.cs
+++ b/src/Lucene.Net.Core/Util/Packed/Packed64SingleBlock.cs
@@ -98,8 +98,8 @@ namespace Lucene.Net.Util.Packed
             // bulk get
             Debug.Assert(index % valuesPerBlock == 0);
             PackedInts.IDecoder decoder = BulkOperation.Of(PackedInts.Format.PACKED_SINGLE_BLOCK, m_bitsPerValue);
-            Debug.Assert(decoder.LongBlockCount == 1);
-            Debug.Assert(decoder.LongValueCount == valuesPerBlock);
+            Debug.Assert(decoder.Int64BlockCount == 1);
+            Debug.Assert(decoder.Int64ValueCount == valuesPerBlock);
             int blockIndex = index / valuesPerBlock;
             int nblocks = (index + len) / valuesPerBlock - blockIndex;
             decoder.Decode(blocks, blockIndex, arr, off, nblocks);
@@ -149,8 +149,8 @@ namespace Lucene.Net.Util.Packed
             // bulk set
             Debug.Assert(index % valuesPerBlock == 0);
             BulkOperation op = BulkOperation.Of(PackedInts.Format.PACKED_SINGLE_BLOCK, m_bitsPerValue);
-            Debug.Assert(op.LongBlockCount == 1);
-            Debug.Assert(op.LongValueCount == valuesPerBlock);
+            Debug.Assert(op.Int64BlockCount == 1);
+            Debug.Assert(op.Int64ValueCount == valuesPerBlock);
             int blockIndex = index / valuesPerBlock;
             int nblocks = (index + len) / valuesPerBlock - blockIndex;
             op.Encode(arr, off, blocks, blockIndex, nblocks);
@@ -235,7 +235,7 @@ namespace Lucene.Net.Util.Packed
             Packed64SingleBlock reader = Create(valueCount, bitsPerValue);
             for (int i = 0; i < reader.blocks.Length; ++i)
             {
-                reader.blocks[i] = @in.ReadLong();
+                reader.blocks[i] = @in.ReadInt64();
             }
             return reader;
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Util/Packed/PackedDataInput.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Packed/PackedDataInput.cs b/src/Lucene.Net.Core/Util/Packed/PackedDataInput.cs
index a5ec9e7..4fb79b4 100644
--- a/src/Lucene.Net.Core/Util/Packed/PackedDataInput.cs
+++ b/src/Lucene.Net.Core/Util/Packed/PackedDataInput.cs
@@ -45,8 +45,10 @@ namespace Lucene.Net.Util.Packed
 
         /// <summary>
         /// Read the next long using exactly <code>bitsPerValue</code> bits.
+        /// <para/>
+        /// NOTE: This was readLong() in Lucene
         /// </summary>
-        public long ReadLong(int bitsPerValue)
+        public long ReadInt64(int bitsPerValue)
         {
             Debug.Assert(bitsPerValue > 0 && bitsPerValue <= 64, bitsPerValue.ToString());
             long r = 0;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Util/Packed/PackedDataOutput.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Packed/PackedDataOutput.cs b/src/Lucene.Net.Core/Util/Packed/PackedDataOutput.cs
index bbb5d0e..6ebe366 100644
--- a/src/Lucene.Net.Core/Util/Packed/PackedDataOutput.cs
+++ b/src/Lucene.Net.Core/Util/Packed/PackedDataOutput.cs
@@ -45,8 +45,10 @@ namespace Lucene.Net.Util.Packed
 
         /// <summary>
         /// Write a value using exactly <code>bitsPerValue</code> bits.
+        /// <para/>
+        /// NOTE: This was writeLong() in Lucene
         /// </summary>
-        public void WriteLong(long value, int bitsPerValue) // LUCENENET TODO: Rename WriteInt64 ?
+        public void WriteInt64(long value, int bitsPerValue)
         {
             Debug.Assert(bitsPerValue == 64 || (value >= 0 && value <= PackedInts.MaxValue(bitsPerValue)));
             while (bitsPerValue > 0)


[25/53] [abbrv] lucenenet git commit: Lucene.Net.Core: Renamed all type-derived classes and interfaces from Short, Int, Long, and Float to match CLR types Int16, Int32, Int64, and Single, respectively.

Posted by ni...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Util/Packed/AbstractBlockPackedWriter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Packed/AbstractBlockPackedWriter.cs b/src/Lucene.Net.Core/Util/Packed/AbstractBlockPackedWriter.cs
index 250fa7d..79c72b8 100644
--- a/src/Lucene.Net.Core/Util/Packed/AbstractBlockPackedWriter.cs
+++ b/src/Lucene.Net.Core/Util/Packed/AbstractBlockPackedWriter.cs
@@ -62,7 +62,7 @@ namespace Lucene.Net.Util.Packed
         /// <param name="blockSize"> the number of values of a single block, must be a multiple of <tt>64</tt> </param>
         public AbstractBlockPackedWriter(DataOutput @out, int blockSize)
         {
-            PackedInts.CheckBlockSize(blockSize, MIN_BLOCK_SIZE, MAX_BLOCK_SIZE);
+            PackedInt32s.CheckBlockSize(blockSize, MIN_BLOCK_SIZE, MAX_BLOCK_SIZE);
             Reset(@out);
             m_values = new long[blockSize];
         }
@@ -142,7 +142,7 @@ namespace Lucene.Net.Util.Packed
 
         protected void WriteValues(int bitsRequired)
         {
-            PackedInts.IEncoder encoder = PackedInts.GetEncoder(PackedInts.Format.PACKED, PackedInts.VERSION_CURRENT, bitsRequired);
+            PackedInt32s.IEncoder encoder = PackedInt32s.GetEncoder(PackedInt32s.Format.PACKED, PackedInt32s.VERSION_CURRENT, bitsRequired);
             int iterations = m_values.Length / encoder.ByteValueCount;
             int blockSize = encoder.ByteBlockCount * iterations;
             if (m_blocks == null || m_blocks.Length < blockSize)
@@ -154,7 +154,7 @@ namespace Lucene.Net.Util.Packed
                 Arrays.Fill(m_values, m_off, m_values.Length, 0L);
             }
             encoder.Encode(m_values, 0, m_blocks, 0, iterations);
-            int blockCount = (int)PackedInts.Format.PACKED.ByteCount(PackedInts.VERSION_CURRENT, m_off, bitsRequired);
+            int blockCount = (int)PackedInt32s.Format.PACKED.ByteCount(PackedInt32s.VERSION_CURRENT, m_off, bitsRequired);
             m_out.WriteBytes(m_blocks, blockCount);
         }
     }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Util/Packed/AbstractPagedMutable.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Packed/AbstractPagedMutable.cs b/src/Lucene.Net.Core/Util/Packed/AbstractPagedMutable.cs
index c576ee9..f3c88a0 100644
--- a/src/Lucene.Net.Core/Util/Packed/AbstractPagedMutable.cs
+++ b/src/Lucene.Net.Core/Util/Packed/AbstractPagedMutable.cs
@@ -24,7 +24,7 @@ namespace Lucene.Net.Util.Packed
     /// Base implementation for <seealso cref="PagedMutable"/> and <seealso cref="PagedGrowableWriter"/>.
     /// @lucene.internal
     /// </summary>
-    public abstract class AbstractPagedMutable<T> : LongValues where T : AbstractPagedMutable<T> // LUCENENET NOTE: made public rather than internal because has public subclasses
+    public abstract class AbstractPagedMutable<T> : Int64Values where T : AbstractPagedMutable<T> // LUCENENET NOTE: made public rather than internal because has public subclasses
     {
         internal static readonly int MIN_BLOCK_SIZE = 1 << 6;
         internal static readonly int MAX_BLOCK_SIZE = 1 << 30;
@@ -32,22 +32,22 @@ namespace Lucene.Net.Util.Packed
         internal readonly long size;
         internal readonly int pageShift;
         internal readonly int pageMask;
-        internal readonly PackedInts.Mutable[] subMutables;
+        internal readonly PackedInt32s.Mutable[] subMutables;
         internal readonly int bitsPerValue;
 
         internal AbstractPagedMutable(int bitsPerValue, long size, int pageSize)
         {
             this.bitsPerValue = bitsPerValue;
             this.size = size;
-            pageShift = PackedInts.CheckBlockSize(pageSize, MIN_BLOCK_SIZE, MAX_BLOCK_SIZE);
+            pageShift = PackedInt32s.CheckBlockSize(pageSize, MIN_BLOCK_SIZE, MAX_BLOCK_SIZE);
             pageMask = pageSize - 1;
-            int numPages = PackedInts.NumBlocks(size, pageSize);
-            subMutables = new PackedInts.Mutable[numPages];
+            int numPages = PackedInt32s.NumBlocks(size, pageSize);
+            subMutables = new PackedInt32s.Mutable[numPages];
         }
 
         protected void FillPages()
         {
-            int numPages = PackedInts.NumBlocks(size, PageSize);
+            int numPages = PackedInt32s.NumBlocks(size, PageSize);
             for (int i = 0; i < numPages; ++i)
             {
                 // do not allocate for more entries than necessary on the last page
@@ -56,7 +56,7 @@ namespace Lucene.Net.Util.Packed
             }
         }
 
-        protected abstract PackedInts.Mutable NewMutable(int valueCount, int bitsPerValue);
+        protected abstract PackedInt32s.Mutable NewMutable(int valueCount, int bitsPerValue);
 
         internal int LastPageSize(long size)
         {
@@ -117,7 +117,7 @@ namespace Lucene.Net.Util.Packed
         {
             long bytesUsed = RamUsageEstimator.AlignObjectSize(BaseRamBytesUsed());
             bytesUsed += RamUsageEstimator.AlignObjectSize(RamUsageEstimator.NUM_BYTES_ARRAY_HEADER + (long)RamUsageEstimator.NUM_BYTES_OBJECT_REF * subMutables.Length);
-            foreach (PackedInts.Mutable gw in subMutables)
+            foreach (PackedInt32s.Mutable gw in subMutables)
             {
                 bytesUsed += gw.RamBytesUsed();
             }
@@ -144,7 +144,7 @@ namespace Lucene.Net.Util.Packed
                 if (i < numCommonPages)
                 {
                     int copyLength = Math.Min(valueCount, subMutables[i].Count);
-                    PackedInts.Copy(subMutables[i], 0, copy.subMutables[i], 0, copyLength, copyBuffer);
+                    PackedInt32s.Copy(subMutables[i], 0, copy.subMutables[i], 0, copyLength, copyBuffer);
                 }
             }
             return copy;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Util/Packed/AppendingDeltaPackedLongBuffer.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Packed/AppendingDeltaPackedLongBuffer.cs b/src/Lucene.Net.Core/Util/Packed/AppendingDeltaPackedLongBuffer.cs
index 812368f..e6da8cd 100644
--- a/src/Lucene.Net.Core/Util/Packed/AppendingDeltaPackedLongBuffer.cs
+++ b/src/Lucene.Net.Core/Util/Packed/AppendingDeltaPackedLongBuffer.cs
@@ -24,38 +24,40 @@ namespace Lucene.Net.Util.Packed
     /// Utility class to buffer a list of signed longs in memory. this class only
     /// supports appending and is optimized for the case where values are close to
     /// each other.
+    /// <para/>
+    /// NOTE: This was AppendingDeltaPackedLongBuffer in Lucene
     ///
     /// @lucene.internal
     /// </summary>
-    public sealed class AppendingDeltaPackedLongBuffer : AbstractAppendingLongBuffer
+    public sealed class AppendingDeltaPackedInt64Buffer : AbstractAppendingInt64Buffer
     {
         internal long[] minValues;
 
         /// <summary>
-        /// Create <seealso cref="AppendingDeltaPackedLongBuffer"/> </summary>
+        /// Create <seealso cref="AppendingDeltaPackedInt64Buffer"/> </summary>
         /// <param name="initialPageCount">        the initial number of pages </param>
         /// <param name="pageSize">                the size of a single page </param>
         /// <param name="acceptableOverheadRatio"> an acceptable overhead ratio per value </param>
-        public AppendingDeltaPackedLongBuffer(int initialPageCount, int pageSize, float acceptableOverheadRatio)
+        public AppendingDeltaPackedInt64Buffer(int initialPageCount, int pageSize, float acceptableOverheadRatio)
             : base(initialPageCount, pageSize, acceptableOverheadRatio)
         {
             minValues = new long[values.Length];
         }
 
         /// <summary>
-        /// Create an <seealso cref="AppendingDeltaPackedLongBuffer"/> with initialPageCount=16,
-        /// pageSize=1024 and acceptableOverheadRatio=<seealso cref="PackedInts#DEFAULT"/>
+        /// Create an <seealso cref="AppendingDeltaPackedInt64Buffer"/> with initialPageCount=16,
+        /// pageSize=1024 and acceptableOverheadRatio=<seealso cref="PackedInt32s#DEFAULT"/>
         /// </summary>
-        public AppendingDeltaPackedLongBuffer()
-            : this(16, 1024, PackedInts.DEFAULT)
+        public AppendingDeltaPackedInt64Buffer()
+            : this(16, 1024, PackedInt32s.DEFAULT)
         {
         }
 
         /// <summary>
-        /// Create an <seealso cref="AppendingDeltaPackedLongBuffer"/> with initialPageCount=16,
+        /// Create an <seealso cref="AppendingDeltaPackedInt64Buffer"/> with initialPageCount=16,
         /// pageSize=1024
         /// </summary>
-        public AppendingDeltaPackedLongBuffer(float acceptableOverheadRatio)
+        public AppendingDeltaPackedInt64Buffer(float acceptableOverheadRatio)
             : this(16, 1024, acceptableOverheadRatio)
         {
         }
@@ -112,17 +114,17 @@ namespace Lucene.Net.Util.Packed
             minValues[valuesOff] = minValue;
             if (delta == 0)
             {
-                values[valuesOff] = new PackedInts.NullReader(pendingOff);
+                values[valuesOff] = new PackedInt32s.NullReader(pendingOff);
             }
             else
             {
                 // build a new packed reader
-                int bitsRequired = delta < 0 ? 64 : PackedInts.BitsRequired(delta);
+                int bitsRequired = delta < 0 ? 64 : PackedInt32s.BitsRequired(delta);
                 for (int i = 0; i < pendingOff; ++i)
                 {
                     pending[i] -= minValue;
                 }
-                PackedInts.Mutable mutable = PackedInts.GetMutable(pendingOff, bitsRequired, acceptableOverheadRatio);
+                PackedInt32s.Mutable mutable = PackedInt32s.GetMutable(pendingOff, bitsRequired, acceptableOverheadRatio);
                 for (int i = 0; i < pendingOff; )
                 {
                     i += mutable.Set(i, pending, i, pendingOff - i);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Util/Packed/AppendingPackedLongBuffer.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Packed/AppendingPackedLongBuffer.cs b/src/Lucene.Net.Core/Util/Packed/AppendingPackedLongBuffer.cs
index 0ebec70..2fa6402 100644
--- a/src/Lucene.Net.Core/Util/Packed/AppendingPackedLongBuffer.cs
+++ b/src/Lucene.Net.Core/Util/Packed/AppendingPackedLongBuffer.cs
@@ -22,35 +22,37 @@ namespace Lucene.Net.Util.Packed
     /// <summary>
     /// Utility class to buffer a list of signed longs in memory. this class only
     /// supports appending and is optimized for non-negative numbers with a uniform distribution over a fixed (limited) range
-    ///
+    /// <para/>
+    /// NOTE: This was AppendingPackedLongBuffer in Lucene
+    /// 
     /// @lucene.internal
     /// </summary>
-    public sealed class AppendingPackedLongBuffer : AbstractAppendingLongBuffer
+    public sealed class AppendingPackedInt64Buffer : AbstractAppendingInt64Buffer
     {
         /// <summary>
-        ///<seealso cref="AppendingPackedLongBuffer"/> </summary>
+        ///<seealso cref="AppendingPackedInt64Buffer"/> </summary>
         /// <param name="initialPageCount">        the initial number of pages </param>
         /// <param name="pageSize">                the size of a single page </param>
         /// <param name="acceptableOverheadRatio"> an acceptable overhead ratio per value </param>
-        public AppendingPackedLongBuffer(int initialPageCount, int pageSize, float acceptableOverheadRatio)
+        public AppendingPackedInt64Buffer(int initialPageCount, int pageSize, float acceptableOverheadRatio)
             : base(initialPageCount, pageSize, acceptableOverheadRatio)
         {
         }
 
         /// <summary>
-        /// Create an <seealso cref="AppendingPackedLongBuffer"/> with initialPageCount=16,
-        /// pageSize=1024 and acceptableOverheadRatio=<seealso cref="PackedInts#DEFAULT"/>
+        /// Create an <seealso cref="AppendingPackedInt64Buffer"/> with initialPageCount=16,
+        /// pageSize=1024 and acceptableOverheadRatio=<seealso cref="PackedInt32s#DEFAULT"/>
         /// </summary>
-        public AppendingPackedLongBuffer()
-            : this(16, 1024, PackedInts.DEFAULT)
+        public AppendingPackedInt64Buffer()
+            : this(16, 1024, PackedInt32s.DEFAULT)
         {
         }
 
         /// <summary>
-        /// Create an <seealso cref="AppendingPackedLongBuffer"/> with initialPageCount=16,
+        /// Create an <seealso cref="AppendingPackedInt64Buffer"/> with initialPageCount=16,
         /// pageSize=1024
         /// </summary>
-        public AppendingPackedLongBuffer(float acceptableOverheadRatio)
+        public AppendingPackedInt64Buffer(float acceptableOverheadRatio)
             : this(16, 1024, acceptableOverheadRatio)
         {
         }
@@ -94,8 +96,8 @@ namespace Lucene.Net.Util.Packed
             }
 
             // build a new packed reader
-            int bitsRequired = minValue < 0 ? 64 : PackedInts.BitsRequired(maxValue);
-            PackedInts.Mutable mutable = PackedInts.GetMutable(pendingOff, bitsRequired, acceptableOverheadRatio);
+            int bitsRequired = minValue < 0 ? 64 : PackedInt32s.BitsRequired(maxValue);
+            PackedInt32s.Mutable mutable = PackedInt32s.GetMutable(pendingOff, bitsRequired, acceptableOverheadRatio);
             for (int i = 0; i < pendingOff; )
             {
                 i += mutable.Set(i, pending, i, pendingOff - i);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Util/Packed/BlockPackedReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Packed/BlockPackedReader.cs b/src/Lucene.Net.Core/Util/Packed/BlockPackedReader.cs
index 43f1a0d..de46fc3 100644
--- a/src/Lucene.Net.Core/Util/Packed/BlockPackedReader.cs
+++ b/src/Lucene.Net.Core/Util/Packed/BlockPackedReader.cs
@@ -25,23 +25,23 @@ namespace Lucene.Net.Util.Packed
     /// Provides random access to a stream written with <seealso cref="BlockPackedWriter"/>.
     /// @lucene.internal
     /// </summary>
-    public sealed class BlockPackedReader : LongValues
+    public sealed class BlockPackedReader : Int64Values
     {
         private readonly int blockShift, blockMask;
         private readonly long valueCount;
         private readonly long[] minValues;
-        private readonly PackedInts.Reader[] subReaders;
+        private readonly PackedInt32s.Reader[] subReaders;
 
         /// <summary>
         /// Sole constructor. </summary>
         public BlockPackedReader(IndexInput @in, int packedIntsVersion, int blockSize, long valueCount, bool direct)
         {
             this.valueCount = valueCount;
-            blockShift = PackedInts.CheckBlockSize(blockSize, AbstractBlockPackedWriter.MIN_BLOCK_SIZE, AbstractBlockPackedWriter.MAX_BLOCK_SIZE);
+            blockShift = PackedInt32s.CheckBlockSize(blockSize, AbstractBlockPackedWriter.MIN_BLOCK_SIZE, AbstractBlockPackedWriter.MAX_BLOCK_SIZE);
             blockMask = blockSize - 1;
-            int numBlocks = PackedInts.NumBlocks(valueCount, blockSize);
+            int numBlocks = PackedInt32s.NumBlocks(valueCount, blockSize);
             long[] minValues = null;
-            subReaders = new PackedInts.Reader[numBlocks];
+            subReaders = new PackedInt32s.Reader[numBlocks];
             for (int i = 0; i < numBlocks; ++i)
             {
                 int token = @in.ReadByte() & 0xFF;
@@ -60,7 +60,7 @@ namespace Lucene.Net.Util.Packed
                 }
                 if (bitsPerValue == 0)
                 {
-                    subReaders[i] = new PackedInts.NullReader(blockSize);
+                    subReaders[i] = new PackedInt32s.NullReader(blockSize);
                 }
                 else
                 {
@@ -68,12 +68,12 @@ namespace Lucene.Net.Util.Packed
                     if (direct)
                     {
                         long pointer = @in.FilePointer;
-                        subReaders[i] = PackedInts.GetDirectReaderNoHeader(@in, PackedInts.Format.PACKED, packedIntsVersion, size, bitsPerValue);
-                        @in.Seek(pointer + PackedInts.Format.PACKED.ByteCount(packedIntsVersion, size, bitsPerValue));
+                        subReaders[i] = PackedInt32s.GetDirectReaderNoHeader(@in, PackedInt32s.Format.PACKED, packedIntsVersion, size, bitsPerValue);
+                        @in.Seek(pointer + PackedInt32s.Format.PACKED.ByteCount(packedIntsVersion, size, bitsPerValue));
                     }
                     else
                     {
-                        subReaders[i] = PackedInts.GetReaderNoHeader(@in, PackedInts.Format.PACKED, packedIntsVersion, size, bitsPerValue);
+                        subReaders[i] = PackedInt32s.GetReaderNoHeader(@in, PackedInt32s.Format.PACKED, packedIntsVersion, size, bitsPerValue);
                     }
                 }
             }
@@ -93,7 +93,7 @@ namespace Lucene.Net.Util.Packed
         public long RamBytesUsed()
         {
             long size = 0;
-            foreach (PackedInts.Reader reader in subReaders)
+            foreach (PackedInt32s.Reader reader in subReaders)
             {
                 size += reader.RamBytesUsed();
             }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Util/Packed/BlockPackedReaderIterator.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Packed/BlockPackedReaderIterator.cs b/src/Lucene.Net.Core/Util/Packed/BlockPackedReaderIterator.cs
index f837834..08a13f7 100644
--- a/src/Lucene.Net.Core/Util/Packed/BlockPackedReaderIterator.cs
+++ b/src/Lucene.Net.Core/Util/Packed/BlockPackedReaderIterator.cs
@@ -99,7 +99,7 @@ namespace Lucene.Net.Util.Packed
         internal long valueCount;
         internal readonly int blockSize;
         internal readonly long[] values;
-        internal readonly LongsRef valuesRef;
+        internal readonly Int64sRef valuesRef;
         internal byte[] blocks;
         internal int off;
         internal long ord;
@@ -111,11 +111,11 @@ namespace Lucene.Net.Util.Packed
         ///                  been used to write the stream </param>
         public BlockPackedReaderIterator(DataInput @in, int packedIntsVersion, int blockSize, long valueCount)
         {
-            PackedInts.CheckBlockSize(blockSize, AbstractBlockPackedWriter.MIN_BLOCK_SIZE, AbstractBlockPackedWriter.MAX_BLOCK_SIZE);
+            PackedInt32s.CheckBlockSize(blockSize, AbstractBlockPackedWriter.MIN_BLOCK_SIZE, AbstractBlockPackedWriter.MAX_BLOCK_SIZE);
             this.packedIntsVersion = packedIntsVersion;
             this.blockSize = blockSize;
             this.values = new long[blockSize];
-            this.valuesRef = new LongsRef(this.values, 0, 0);
+            this.valuesRef = new Int64sRef(this.values, 0, 0);
             Reset(@in, valueCount);
         }
 
@@ -166,7 +166,7 @@ namespace Lucene.Net.Util.Packed
                 {
                     ReadVInt64(@in);
                 }
-                long blockBytes = PackedInts.Format.PACKED.ByteCount(packedIntsVersion, blockSize, bitsPerValue);
+                long blockBytes = PackedInt32s.Format.PACKED.ByteCount(packedIntsVersion, blockSize, bitsPerValue);
                 SkipBytes(blockBytes);
                 ord += blockSize;
                 count -= blockSize;
@@ -225,7 +225,7 @@ namespace Lucene.Net.Util.Packed
 
         /// <summary>
         /// Read between <tt>1</tt> and <code>count</code> values. </summary>
-        public LongsRef Next(int count)
+        public Int64sRef Next(int count)
         {
             Debug.Assert(count > 0);
             if (ord == valueCount)
@@ -265,7 +265,7 @@ namespace Lucene.Net.Util.Packed
             }
             else
             {
-                PackedInts.IDecoder decoder = PackedInts.GetDecoder(PackedInts.Format.PACKED, packedIntsVersion, bitsPerValue);
+                PackedInt32s.IDecoder decoder = PackedInt32s.GetDecoder(PackedInt32s.Format.PACKED, packedIntsVersion, bitsPerValue);
                 int iterations = blockSize / decoder.ByteValueCount;
                 int blocksSize = iterations * decoder.ByteBlockCount;
                 if (blocks == null || blocks.Length < blocksSize)
@@ -274,7 +274,7 @@ namespace Lucene.Net.Util.Packed
                 }
 
                 int valueCount = (int)Math.Min(this.valueCount - ord, blockSize);
-                int blocksCount = (int)PackedInts.Format.PACKED.ByteCount(packedIntsVersion, valueCount, bitsPerValue);
+                int blocksCount = (int)PackedInt32s.Format.PACKED.ByteCount(packedIntsVersion, valueCount, bitsPerValue);
                 @in.ReadBytes(blocks, 0, blocksCount);
 
                 decoder.Decode(blocks, 0, values, 0, iterations);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Util/Packed/BlockPackedWriter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Packed/BlockPackedWriter.cs b/src/Lucene.Net.Core/Util/Packed/BlockPackedWriter.cs
index bbcf981..96e4bd8 100644
--- a/src/Lucene.Net.Core/Util/Packed/BlockPackedWriter.cs
+++ b/src/Lucene.Net.Core/Util/Packed/BlockPackedWriter.cs
@@ -48,7 +48,7 @@ namespace Lucene.Net.Util.Packed
     ///     values
     /// <li>Ints: If the number of bits per value is <tt>0</tt>, then there is
     ///     nothing to decode and all ints are equal to MinValue. Otherwise: BlockSize
-    ///     <seealso cref="PackedInts packed ints"/> encoded on exactly <tt>bitsPerValue</tt>
+    ///     <seealso cref="PackedInt32s packed ints"/> encoded on exactly <tt>bitsPerValue</tt>
     ///     bits per value. They are the subtraction of the original values and
     ///     MinValue
     /// </ul> </summary>
@@ -76,7 +76,7 @@ namespace Lucene.Net.Util.Packed
             }
 
             long delta = max - min;
-            int bitsRequired = delta < 0 ? 64 : delta == 0L ? 0 : PackedInts.BitsRequired(delta);
+            int bitsRequired = delta < 0 ? 64 : delta == 0L ? 0 : PackedInt32s.BitsRequired(delta);
             if (bitsRequired == 64)
             {
                 // no need to delta-encode
@@ -85,7 +85,7 @@ namespace Lucene.Net.Util.Packed
             else if (min > 0L)
             {
                 // make min as small as possible so that writeVLong requires fewer bytes
-                min = Math.Max(0L, max - PackedInts.MaxValue(bitsRequired));
+                min = Math.Max(0L, max - PackedInt32s.MaxValue(bitsRequired));
             }
 
             int token = (bitsRequired << BPV_SHIFT) | (min == 0 ? MIN_VALUE_EQUALS_0 : 0);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Util/Packed/BulkOperation.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Packed/BulkOperation.cs b/src/Lucene.Net.Core/Util/Packed/BulkOperation.cs
index 9bcc8f2..8ede6e2 100644
--- a/src/Lucene.Net.Core/Util/Packed/BulkOperation.cs
+++ b/src/Lucene.Net.Core/Util/Packed/BulkOperation.cs
@@ -25,7 +25,7 @@ namespace Lucene.Net.Util.Packed
     /// <summary>
     /// Efficient sequential read/write of packed integers.
     /// </summary>
-    internal abstract class BulkOperation : PackedInts.IDecoder, PackedInts.IEncoder
+    internal abstract class BulkOperation : PackedInt32s.IDecoder, PackedInt32s.IEncoder
     {
         public abstract void Encode(int[] values, int valuesOffset, byte[] blocks, int blocksOffset, int iterations);
 
@@ -160,14 +160,14 @@ namespace Lucene.Net.Util.Packed
             new BulkOperationPackedSingleBlock(32)
         };
 
-        public static BulkOperation Of(PackedInts.Format format, int bitsPerValue)
+        public static BulkOperation Of(PackedInt32s.Format format, int bitsPerValue)
         {
-            if (format == PackedInts.Format.PACKED)
+            if (format == PackedInt32s.Format.PACKED)
             {
                 Debug.Assert(packedBulkOps[bitsPerValue - 1] != null);
                 return packedBulkOps[bitsPerValue - 1];
             }
-            else if (format == PackedInts.Format.PACKED_SINGLE_BLOCK)
+            else if (format == PackedInt32s.Format.PACKED_SINGLE_BLOCK)
             {
                 Debug.Assert(packedSingleBlockBulkOps[bitsPerValue - 1] != null);
                 return packedSingleBlockBulkOps[bitsPerValue - 1];

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Util/Packed/BulkOperationPacked.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Packed/BulkOperationPacked.cs b/src/Lucene.Net.Core/Util/Packed/BulkOperationPacked.cs
index 2c32f31..1a627f5 100644
--- a/src/Lucene.Net.Core/Util/Packed/BulkOperationPacked.cs
+++ b/src/Lucene.Net.Core/Util/Packed/BulkOperationPacked.cs
@@ -20,7 +20,7 @@ namespace Lucene.Net.Util.Packed
      */
 
     /// <summary>
-    /// Non-specialized <seealso cref="BulkOperation"/> for <seealso cref="PackedInts.Format#PACKED"/>.
+    /// Non-specialized <seealso cref="BulkOperation"/> for <seealso cref="PackedInt32s.Format#PACKED"/>.
     /// </summary>
     internal class BulkOperationPacked : BulkOperation
     {
@@ -255,7 +255,7 @@ namespace Lucene.Net.Util.Packed
             for (int i = 0; i < byteValueCount * iterations; ++i)
             {
                 long v = values[valuesOffset++];
-                Debug.Assert(bitsPerValue == 64 || PackedInts.BitsRequired(v) <= bitsPerValue);
+                Debug.Assert(bitsPerValue == 64 || PackedInt32s.BitsRequired(v) <= bitsPerValue);
                 if (bitsPerValue < bitsLeft)
                 {
                     // just buffer
@@ -287,7 +287,7 @@ namespace Lucene.Net.Util.Packed
             for (int i = 0; i < byteValueCount * iterations; ++i)
             {
                 int v = values[valuesOffset++];
-                Debug.Assert(PackedInts.BitsRequired(v & 0xFFFFFFFFL) <= bitsPerValue);
+                Debug.Assert(PackedInt32s.BitsRequired(v & 0xFFFFFFFFL) <= bitsPerValue);
                 if (bitsPerValue < bitsLeft)
                 {
                     // just buffer

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Util/Packed/BulkOperationPackedSingleBlock.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Packed/BulkOperationPackedSingleBlock.cs b/src/Lucene.Net.Core/Util/Packed/BulkOperationPackedSingleBlock.cs
index a8cfa90..976784c 100644
--- a/src/Lucene.Net.Core/Util/Packed/BulkOperationPackedSingleBlock.cs
+++ b/src/Lucene.Net.Core/Util/Packed/BulkOperationPackedSingleBlock.cs
@@ -18,7 +18,7 @@ namespace Lucene.Net.Util.Packed
      */
 
     /// <summary>
-    /// Non-specialized <seealso cref="BulkOperation"/> for <seealso cref="PackedInts.Format#PACKED_SINGLE_BLOCK"/>.
+    /// Non-specialized <seealso cref="BulkOperation"/> for <seealso cref="PackedInt32s.Format#PACKED_SINGLE_BLOCK"/>.
     /// </summary>
     internal sealed class BulkOperationPackedSingleBlock : BulkOperation
     {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Util/Packed/Direct16.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Packed/Direct16.cs b/src/Lucene.Net.Core/Util/Packed/Direct16.cs
index 1a834ea..75e2d37 100644
--- a/src/Lucene.Net.Core/Util/Packed/Direct16.cs
+++ b/src/Lucene.Net.Core/Util/Packed/Direct16.cs
@@ -29,7 +29,7 @@ namespace Lucene.Net.Util.Packed
     /// Direct wrapping of 16-bits values to a backing array.
     /// @lucene.internal
     /// </summary>
-    internal sealed class Direct16 : PackedInts.MutableImpl
+    internal sealed class Direct16 : PackedInt32s.MutableImpl
     {
         internal readonly short[] values;
 
@@ -47,7 +47,7 @@ namespace Lucene.Net.Util.Packed
                 values[i] = @in.ReadInt16();
             }
             // because packed ints have not always been byte-aligned
-            int remaining = (int)(PackedInts.Format.PACKED.ByteCount(packedIntsVersion, valueCount, 16) - 2L * valueCount);
+            int remaining = (int)(PackedInt32s.Format.PACKED.ByteCount(packedIntsVersion, valueCount, 16) - 2L * valueCount);
             for (int i = 0; i < remaining; ++i)
             {
                 @in.ReadByte();

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Util/Packed/Direct32.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Packed/Direct32.cs b/src/Lucene.Net.Core/Util/Packed/Direct32.cs
index f9d62c2..575f2bf 100644
--- a/src/Lucene.Net.Core/Util/Packed/Direct32.cs
+++ b/src/Lucene.Net.Core/Util/Packed/Direct32.cs
@@ -29,7 +29,7 @@ namespace Lucene.Net.Util.Packed
     /// Direct wrapping of 32-bits values to a backing array.
     /// @lucene.internal
     /// </summary>
-    internal sealed class Direct32 : PackedInts.MutableImpl
+    internal sealed class Direct32 : PackedInt32s.MutableImpl
     {
         internal readonly int[] values;
 
@@ -47,7 +47,7 @@ namespace Lucene.Net.Util.Packed
                 values[i] = @in.ReadInt32();
             }
             // because packed ints have not always been byte-aligned
-            int remaining = (int)(PackedInts.Format.PACKED.ByteCount(packedIntsVersion, valueCount, 32) - 4L * valueCount);
+            int remaining = (int)(PackedInt32s.Format.PACKED.ByteCount(packedIntsVersion, valueCount, 32) - 4L * valueCount);
             for (int i = 0; i < remaining; ++i)
             {
                 @in.ReadByte();

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Util/Packed/Direct64.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Packed/Direct64.cs b/src/Lucene.Net.Core/Util/Packed/Direct64.cs
index 0c7cb36..9a56944 100644
--- a/src/Lucene.Net.Core/Util/Packed/Direct64.cs
+++ b/src/Lucene.Net.Core/Util/Packed/Direct64.cs
@@ -29,7 +29,7 @@ namespace Lucene.Net.Util.Packed
     /// Direct wrapping of 64-bits values to a backing array.
     /// @lucene.internal
     /// </summary>
-    internal sealed class Direct64 : PackedInts.MutableImpl
+    internal sealed class Direct64 : PackedInt32s.MutableImpl
     {
         internal readonly long[] values;
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Util/Packed/Direct8.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Packed/Direct8.cs b/src/Lucene.Net.Core/Util/Packed/Direct8.cs
index e1c090e..40ba1c5 100644
--- a/src/Lucene.Net.Core/Util/Packed/Direct8.cs
+++ b/src/Lucene.Net.Core/Util/Packed/Direct8.cs
@@ -29,7 +29,7 @@ namespace Lucene.Net.Util.Packed
     /// Direct wrapping of 8-bits values to a backing array.
     /// @lucene.internal
     /// </summary>
-    internal sealed class Direct8 : PackedInts.MutableImpl
+    internal sealed class Direct8 : PackedInt32s.MutableImpl
     {
         readonly byte[] values;
 
@@ -44,7 +44,7 @@ namespace Lucene.Net.Util.Packed
         {
             @in.ReadBytes(values, 0, valueCount);
             // because packed ints have not always been byte-aligned
-            int remaining = (int)(PackedInts.Format.PACKED.ByteCount(packedIntsVersion, valueCount, 8) - 1L * valueCount);
+            int remaining = (int)(PackedInt32s.Format.PACKED.ByteCount(packedIntsVersion, valueCount, 8) - 1L * valueCount);
             for (int i = 0; i < remaining; ++i)
             {
                 @in.ReadByte();

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Util/Packed/DirectPacked64SingleBlockReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Packed/DirectPacked64SingleBlockReader.cs b/src/Lucene.Net.Core/Util/Packed/DirectPacked64SingleBlockReader.cs
index 1ca3e1f..0526989 100644
--- a/src/Lucene.Net.Core/Util/Packed/DirectPacked64SingleBlockReader.cs
+++ b/src/Lucene.Net.Core/Util/Packed/DirectPacked64SingleBlockReader.cs
@@ -21,7 +21,7 @@ namespace Lucene.Net.Util.Packed
 
     using IndexInput = Lucene.Net.Store.IndexInput;
 
-    internal sealed class DirectPacked64SingleBlockReader : PackedInts.ReaderImpl
+    internal sealed class DirectPacked64SingleBlockReader : PackedInt32s.ReaderImpl
     {
         private readonly IndexInput @in;
         private readonly long startPointer;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Util/Packed/DirectPackedReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Packed/DirectPackedReader.cs b/src/Lucene.Net.Core/Util/Packed/DirectPackedReader.cs
index a6a2aac..9014bcc 100644
--- a/src/Lucene.Net.Core/Util/Packed/DirectPackedReader.cs
+++ b/src/Lucene.Net.Core/Util/Packed/DirectPackedReader.cs
@@ -23,7 +23,7 @@ namespace Lucene.Net.Util.Packed
 
     /* Reads directly from disk on each get */
 
-    internal class DirectPackedReader : PackedInts.ReaderImpl
+    internal class DirectPackedReader : PackedInt32s.ReaderImpl
     {
         private readonly IndexInput @in;
         private readonly long startPointer;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Util/Packed/GrowableWriter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Packed/GrowableWriter.cs b/src/Lucene.Net.Core/Util/Packed/GrowableWriter.cs
index 5cf713e..590746a 100644
--- a/src/Lucene.Net.Core/Util/Packed/GrowableWriter.cs
+++ b/src/Lucene.Net.Core/Util/Packed/GrowableWriter.cs
@@ -23,17 +23,17 @@ namespace Lucene.Net.Util.Packed
     using DataOutput = Lucene.Net.Store.DataOutput;
 
     /// <summary>
-    /// Implements <seealso cref="PackedInts.Mutable"/>, but grows the
+    /// Implements <seealso cref="PackedInt32s.Mutable"/>, but grows the
     /// bit count of the underlying packed ints on-demand.
     /// <p>Beware that this class will accept to set negative values but in order
     /// to do this, it will grow the number of bits per value to 64.
     ///
     /// <p>@lucene.internal</p>
     /// </summary>
-    public class GrowableWriter : PackedInts.Mutable
+    public class GrowableWriter : PackedInt32s.Mutable
     {
         private long currentMask;
-        private PackedInts.Mutable current;
+        private PackedInt32s.Mutable current;
         private readonly float acceptableOverheadRatio;
 
         /// <param name="startBitsPerValue">       the initial number of bits per value, may grow depending on the data </param>
@@ -42,13 +42,13 @@ namespace Lucene.Net.Util.Packed
         public GrowableWriter(int startBitsPerValue, int valueCount, float acceptableOverheadRatio)
         {
             this.acceptableOverheadRatio = acceptableOverheadRatio;
-            current = PackedInts.GetMutable(valueCount, startBitsPerValue, this.acceptableOverheadRatio);
+            current = PackedInt32s.GetMutable(valueCount, startBitsPerValue, this.acceptableOverheadRatio);
             currentMask = Mask(current.BitsPerValue);
         }
 
         private static long Mask(int bitsPerValue)
         {
-            return bitsPerValue == 64 ? ~0L : PackedInts.MaxValue(bitsPerValue);
+            return bitsPerValue == 64 ? ~0L : PackedInt32s.MaxValue(bitsPerValue);
         }
 
         public override long Get(int index)
@@ -69,7 +69,7 @@ namespace Lucene.Net.Util.Packed
             }
         }
 
-        public virtual PackedInts.Mutable Mutable
+        public virtual PackedInt32s.Mutable Mutable
         {
             get
             {
@@ -93,11 +93,11 @@ namespace Lucene.Net.Util.Packed
             {
                 return;
             }
-            int bitsRequired = value < 0 ? 64 : PackedInts.BitsRequired(value);
+            int bitsRequired = value < 0 ? 64 : PackedInt32s.BitsRequired(value);
             Debug.Assert(bitsRequired > current.BitsPerValue);
             int valueCount = Count;
-            PackedInts.Mutable next = PackedInts.GetMutable(valueCount, bitsRequired, acceptableOverheadRatio);
-            PackedInts.Copy(current, 0, next, 0, valueCount, PackedInts.DEFAULT_BUFFER_SIZE);
+            PackedInt32s.Mutable next = PackedInt32s.GetMutable(valueCount, bitsRequired, acceptableOverheadRatio);
+            PackedInt32s.Copy(current, 0, next, 0, valueCount, PackedInt32s.DEFAULT_BUFFER_SIZE);
             current = next;
             currentMask = Mask(current.BitsPerValue);
         }
@@ -117,7 +117,7 @@ namespace Lucene.Net.Util.Packed
         {
             GrowableWriter next = new GrowableWriter(BitsPerValue, newSize, acceptableOverheadRatio);
             int limit = Math.Min(Count, newSize);
-            PackedInts.Copy(current, 0, next, 0, limit, PackedInts.DEFAULT_BUFFER_SIZE);
+            PackedInt32s.Copy(current, 0, next, 0, limit, PackedInt32s.DEFAULT_BUFFER_SIZE);
             return next;
         }
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Util/Packed/MonotonicAppendingLongBuffer.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Packed/MonotonicAppendingLongBuffer.cs b/src/Lucene.Net.Core/Util/Packed/MonotonicAppendingLongBuffer.cs
index b5df85d..c8dd211 100644
--- a/src/Lucene.Net.Core/Util/Packed/MonotonicAppendingLongBuffer.cs
+++ b/src/Lucene.Net.Core/Util/Packed/MonotonicAppendingLongBuffer.cs
@@ -25,10 +25,12 @@ namespace Lucene.Net.Util.Packed
     /// Utility class to buffer signed longs in memory, which is optimized for the
     /// case where the sequence is monotonic, although it can encode any sequence of
     /// arbitrary longs. It only supports appending.
-    ///
+    /// <para/>
+    /// NOTE: This was MonotonicAppendingLongBuffer in Lucene
+    /// 
     /// @lucene.internal
     /// </summary>
-    public sealed class MonotonicAppendingLongBuffer : AbstractAppendingLongBuffer
+    public sealed class MonotonicAppendingInt64Buffer : AbstractAppendingInt64Buffer
     {
         internal static long ZigZagDecode(long n)
         {
@@ -46,7 +48,7 @@ namespace Lucene.Net.Util.Packed
         /// <param name="initialPageCount">        the initial number of pages </param>
         /// <param name="pageSize">                the size of a single page </param>
         /// <param name="acceptableOverheadRatio"> an acceptable overhead ratio per value </param>
-        public MonotonicAppendingLongBuffer(int initialPageCount, int pageSize, float acceptableOverheadRatio)
+        public MonotonicAppendingInt64Buffer(int initialPageCount, int pageSize, float acceptableOverheadRatio)
             : base(initialPageCount, pageSize, acceptableOverheadRatio)
         {
             averages = new float[values.Length];
@@ -54,19 +56,19 @@ namespace Lucene.Net.Util.Packed
         }
 
         /// <summary>
-        /// Create an <seealso cref="MonotonicAppendingLongBuffer"/> with initialPageCount=16,
-        /// pageSize=1024 and acceptableOverheadRatio=<seealso cref="PackedInts#DEFAULT"/>
+        /// Create an <seealso cref="MonotonicAppendingInt64Buffer"/> with initialPageCount=16,
+        /// pageSize=1024 and acceptableOverheadRatio=<seealso cref="PackedInt32s#DEFAULT"/>
         /// </summary>
-        public MonotonicAppendingLongBuffer()
-            : this(16, 1024, PackedInts.DEFAULT)
+        public MonotonicAppendingInt64Buffer()
+            : this(16, 1024, PackedInt32s.DEFAULT)
         {
         }
 
         /// <summary>
-        /// Create an <seealso cref="AppendingDeltaPackedLongBuffer"/> with initialPageCount=16,
+        /// Create an <seealso cref="AppendingDeltaPackedInt64Buffer"/> with initialPageCount=16,
         /// pageSize=1024
         /// </summary>
-        public MonotonicAppendingLongBuffer(float acceptableOverheadRatio)
+        public MonotonicAppendingInt64Buffer(float acceptableOverheadRatio)
             : this(16, 1024, acceptableOverheadRatio)
         {
         }
@@ -155,12 +157,12 @@ namespace Lucene.Net.Util.Packed
             }
             if (maxDelta == 0)
             {
-                values[valuesOff] = new PackedInts.NullReader(pendingOff);
+                values[valuesOff] = new PackedInt32s.NullReader(pendingOff);
             }
             else
             {
-                int bitsRequired = maxDelta < 0 ? 64 : PackedInts.BitsRequired(maxDelta);
-                PackedInts.Mutable mutable = PackedInts.GetMutable(pendingOff, bitsRequired, acceptableOverheadRatio);
+                int bitsRequired = maxDelta < 0 ? 64 : PackedInt32s.BitsRequired(maxDelta);
+                PackedInt32s.Mutable mutable = PackedInt32s.GetMutable(pendingOff, bitsRequired, acceptableOverheadRatio);
                 for (int i = 0; i < pendingOff; )
                 {
                     i += mutable.Set(i, pending, i, pendingOff - i);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Util/Packed/MonotonicBlockPackedReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Packed/MonotonicBlockPackedReader.cs b/src/Lucene.Net.Core/Util/Packed/MonotonicBlockPackedReader.cs
index e9dcbf3..49269c1 100644
--- a/src/Lucene.Net.Core/Util/Packed/MonotonicBlockPackedReader.cs
+++ b/src/Lucene.Net.Core/Util/Packed/MonotonicBlockPackedReader.cs
@@ -27,25 +27,25 @@ namespace Lucene.Net.Util.Packed
     /// <seealso cref="MonotonicBlockPackedWriter"/>.
     /// @lucene.internal
     /// </summary>
-    public sealed class MonotonicBlockPackedReader : LongValues
+    public sealed class MonotonicBlockPackedReader : Int64Values
     {
         private readonly int blockShift, blockMask;
         private readonly long valueCount;
         private readonly long[] minValues;
         private readonly float[] averages;
-        private readonly PackedInts.Reader[] subReaders;
+        private readonly PackedInt32s.Reader[] subReaders;
 
         /// <summary>
         /// Sole constructor. </summary>
         public MonotonicBlockPackedReader(IndexInput @in, int packedIntsVersion, int blockSize, long valueCount, bool direct)
         {
             this.valueCount = valueCount;
-            blockShift = PackedInts.CheckBlockSize(blockSize, AbstractBlockPackedWriter.MIN_BLOCK_SIZE, AbstractBlockPackedWriter.MAX_BLOCK_SIZE);
+            blockShift = PackedInt32s.CheckBlockSize(blockSize, AbstractBlockPackedWriter.MIN_BLOCK_SIZE, AbstractBlockPackedWriter.MAX_BLOCK_SIZE);
             blockMask = blockSize - 1;
-            int numBlocks = PackedInts.NumBlocks(valueCount, blockSize);
+            int numBlocks = PackedInt32s.NumBlocks(valueCount, blockSize);
             minValues = new long[numBlocks];
             averages = new float[numBlocks];
-            subReaders = new PackedInts.Reader[numBlocks];
+            subReaders = new PackedInt32s.Reader[numBlocks];
             for (int i = 0; i < numBlocks; ++i)
             {
                 minValues[i] = @in.ReadVInt64();
@@ -57,7 +57,7 @@ namespace Lucene.Net.Util.Packed
                 }
                 if (bitsPerValue == 0)
                 {
-                    subReaders[i] = new PackedInts.NullReader(blockSize);
+                    subReaders[i] = new PackedInt32s.NullReader(blockSize);
                 }
                 else
                 {
@@ -65,12 +65,12 @@ namespace Lucene.Net.Util.Packed
                     if (direct)
                     {
                         long pointer = @in.FilePointer;
-                        subReaders[i] = PackedInts.GetDirectReaderNoHeader(@in, PackedInts.Format.PACKED, packedIntsVersion, size, bitsPerValue);
-                        @in.Seek(pointer + PackedInts.Format.PACKED.ByteCount(packedIntsVersion, size, bitsPerValue));
+                        subReaders[i] = PackedInt32s.GetDirectReaderNoHeader(@in, PackedInt32s.Format.PACKED, packedIntsVersion, size, bitsPerValue);
+                        @in.Seek(pointer + PackedInt32s.Format.PACKED.ByteCount(packedIntsVersion, size, bitsPerValue));
                     }
                     else
                     {
-                        subReaders[i] = PackedInts.GetReaderNoHeader(@in, PackedInts.Format.PACKED, packedIntsVersion, size, bitsPerValue);
+                        subReaders[i] = PackedInt32s.GetReaderNoHeader(@in, PackedInt32s.Format.PACKED, packedIntsVersion, size, bitsPerValue);
                     }
                 }
             }
@@ -100,7 +100,7 @@ namespace Lucene.Net.Util.Packed
             long sizeInBytes = 0;
             sizeInBytes += RamUsageEstimator.SizeOf(minValues);
             sizeInBytes += RamUsageEstimator.SizeOf(averages);
-            foreach (PackedInts.Reader reader in subReaders)
+            foreach (PackedInt32s.Reader reader in subReaders)
             {
                 sizeInBytes += reader.RamBytesUsed();
             }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Util/Packed/MonotonicBlockPackedWriter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Packed/MonotonicBlockPackedWriter.cs b/src/Lucene.Net.Core/Util/Packed/MonotonicBlockPackedWriter.cs
index 9d017bb..2a43385 100644
--- a/src/Lucene.Net.Core/Util/Packed/MonotonicBlockPackedWriter.cs
+++ b/src/Lucene.Net.Core/Util/Packed/MonotonicBlockPackedWriter.cs
@@ -47,7 +47,7 @@ namespace Lucene.Net.Util.Packed
     ///     all values perfectly match the result of the function. Otherwise, these
     ///     are the
     ///     <a href="https://developers.google.com/protocol-buffers/docs/encoding#types">zigzag-encoded</a>
-    ///     <seealso cref="PackedInts packed"/> deltas from the expected value (computed from
+    ///     <seealso cref="PackedInt32s packed"/> deltas from the expected value (computed from
     ///     the function) using exaclty BitsPerValue bits per value
     /// </ul> </summary>
     /// <seealso cref= MonotonicBlockPackedReader
@@ -91,7 +91,7 @@ namespace Lucene.Net.Util.Packed
             }
             else
             {
-                int bitsRequired = PackedInts.BitsRequired(maxZigZagDelta);
+                int bitsRequired = PackedInt32s.BitsRequired(maxZigZagDelta);
                 m_out.WriteVInt32(bitsRequired);
                 WriteValues(bitsRequired);
             }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Util/Packed/Packed16ThreeBlocks.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Packed/Packed16ThreeBlocks.cs b/src/Lucene.Net.Core/Util/Packed/Packed16ThreeBlocks.cs
index 470ebb8..2323d1d 100644
--- a/src/Lucene.Net.Core/Util/Packed/Packed16ThreeBlocks.cs
+++ b/src/Lucene.Net.Core/Util/Packed/Packed16ThreeBlocks.cs
@@ -29,7 +29,7 @@ namespace Lucene.Net.Util.Packed
     /// Packs integers into 3 shorts (48 bits per value).
     /// @lucene.internal
     /// </summary>
-    internal sealed class Packed16ThreeBlocks : PackedInts.MutableImpl
+    internal sealed class Packed16ThreeBlocks : PackedInt32s.MutableImpl
     {
         internal readonly short[] blocks;
 
@@ -53,7 +53,7 @@ namespace Lucene.Net.Util.Packed
                 blocks[i] = @in.ReadInt16();
             }
             // because packed ints have not always been byte-aligned
-            int remaining = (int)(PackedInts.Format.PACKED.ByteCount(packedIntsVersion, valueCount, 48) - 3L * valueCount * 2);
+            int remaining = (int)(PackedInt32s.Format.PACKED.ByteCount(packedIntsVersion, valueCount, 48) - 3L * valueCount * 2);
             for (int i = 0; i < remaining; ++i)
             {
                 @in.ReadByte();

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Util/Packed/Packed64.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Packed/Packed64.cs b/src/Lucene.Net.Core/Util/Packed/Packed64.cs
index 9f2edf7..f6f56bd 100644
--- a/src/Lucene.Net.Core/Util/Packed/Packed64.cs
+++ b/src/Lucene.Net.Core/Util/Packed/Packed64.cs
@@ -42,7 +42,7 @@ namespace Lucene.Net.Util.Packed
     /// See https://issues.apache.org/jira/browse/LUCENE-4062 for details.
     ///
     /// </summary>
-    public class Packed64 : PackedInts.MutableImpl
+    public class Packed64 : PackedInt32s.MutableImpl
     {
         internal const int BLOCK_SIZE = 64; // 32 = int, 64 = long
         internal const int BLOCK_BITS = 6; // The #bits representing BLOCK_SIZE
@@ -71,8 +71,8 @@ namespace Lucene.Net.Util.Packed
         public Packed64(int valueCount, int bitsPerValue)
             : base(valueCount, bitsPerValue)
         {
-            PackedInts.Format format = PackedInts.Format.PACKED;
-            int longCount = format.Int64Count(PackedInts.VERSION_CURRENT, valueCount, bitsPerValue);
+            PackedInt32s.Format format = PackedInt32s.Format.PACKED;
+            int longCount = format.Int64Count(PackedInt32s.VERSION_CURRENT, valueCount, bitsPerValue);
             this.blocks = new long[longCount];
             //            MaskRight = ~0L << (int)((uint)(BLOCK_SIZE - bitsPerValue) >> (BLOCK_SIZE - bitsPerValue));    //original
             //            MaskRight = (uint)(~0L << (BLOCK_SIZE - bitsPerValue)) >> (BLOCK_SIZE - bitsPerValue);          //mod
@@ -98,9 +98,9 @@ namespace Lucene.Net.Util.Packed
         public Packed64(int packedIntsVersion, DataInput @in, int valueCount, int bitsPerValue)
             : base(valueCount, bitsPerValue)
         {
-            PackedInts.Format format = PackedInts.Format.PACKED;
+            PackedInt32s.Format format = PackedInt32s.Format.PACKED;
             long byteCount = format.ByteCount(packedIntsVersion, valueCount, bitsPerValue); // to know how much to read
-            int longCount = format.Int64Count(PackedInts.VERSION_CURRENT, valueCount, bitsPerValue); // to size the array
+            int longCount = format.Int64Count(PackedInt32s.VERSION_CURRENT, valueCount, bitsPerValue); // to size the array
             blocks = new long[longCount];
             // read as many longs as we can
             for (int i = 0; i < byteCount / 8; ++i)
@@ -180,7 +180,7 @@ namespace Lucene.Net.Util.Packed
             Debug.Assert(off + len <= arr.Length);
 
             int originalIndex = index;
-            PackedInts.IDecoder decoder = BulkOperation.Of(PackedInts.Format.PACKED, m_bitsPerValue);
+            PackedInt32s.IDecoder decoder = BulkOperation.Of(PackedInt32s.Format.PACKED, m_bitsPerValue);
 
             // go to the next block where the value does not span across two blocks
             int offsetInBlocks = index % decoder.Int64ValueCount;
@@ -248,7 +248,7 @@ namespace Lucene.Net.Util.Packed
             Debug.Assert(off + len <= arr.Length);
 
             int originalIndex = index;
-            PackedInts.IEncoder encoder = BulkOperation.Of(PackedInts.Format.PACKED, m_bitsPerValue);
+            PackedInt32s.IEncoder encoder = BulkOperation.Of(PackedInt32s.Format.PACKED, m_bitsPerValue);
 
             // go to the next block where the value does not span across two blocks
             int offsetInBlocks = index % encoder.Int64ValueCount;
@@ -306,7 +306,7 @@ namespace Lucene.Net.Util.Packed
 
         public override void Fill(int fromIndex, int toIndex, long val)
         {
-            Debug.Assert(PackedInts.BitsRequired(val) <= BitsPerValue);
+            Debug.Assert(PackedInt32s.BitsRequired(val) <= BitsPerValue);
             Debug.Assert(fromIndex <= toIndex);
 
             // minimum number of values that use an exact number of full blocks

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Util/Packed/Packed64SingleBlock.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Packed/Packed64SingleBlock.cs b/src/Lucene.Net.Core/Util/Packed/Packed64SingleBlock.cs
index 7c3f9ff..4119a4b 100644
--- a/src/Lucene.Net.Core/Util/Packed/Packed64SingleBlock.cs
+++ b/src/Lucene.Net.Core/Util/Packed/Packed64SingleBlock.cs
@@ -31,7 +31,7 @@ namespace Lucene.Net.Util.Packed
     /// speed by ensuring that a single block needs to be read/written in order to
     /// read/write a value.
     /// </summary>
-    internal abstract class Packed64SingleBlock : PackedInts.MutableImpl
+    internal abstract class Packed64SingleBlock : PackedInt32s.MutableImpl
     {
         public const int MAX_SUPPORTED_BITS_PER_VALUE = 32;
         private static readonly int[] SUPPORTED_BITS_PER_VALUE = new int[] { 1, 2, 3, 4, 5, 6, 7, 8, 9, 10, 12, 16, 21, 32 };
@@ -97,7 +97,7 @@ namespace Lucene.Net.Util.Packed
 
             // bulk get
             Debug.Assert(index % valuesPerBlock == 0);
-            PackedInts.IDecoder decoder = BulkOperation.Of(PackedInts.Format.PACKED_SINGLE_BLOCK, m_bitsPerValue);
+            PackedInt32s.IDecoder decoder = BulkOperation.Of(PackedInt32s.Format.PACKED_SINGLE_BLOCK, m_bitsPerValue);
             Debug.Assert(decoder.Int64BlockCount == 1);
             Debug.Assert(decoder.Int64ValueCount == valuesPerBlock);
             int blockIndex = index / valuesPerBlock;
@@ -148,7 +148,7 @@ namespace Lucene.Net.Util.Packed
 
             // bulk set
             Debug.Assert(index % valuesPerBlock == 0);
-            BulkOperation op = BulkOperation.Of(PackedInts.Format.PACKED_SINGLE_BLOCK, m_bitsPerValue);
+            BulkOperation op = BulkOperation.Of(PackedInt32s.Format.PACKED_SINGLE_BLOCK, m_bitsPerValue);
             Debug.Assert(op.Int64BlockCount == 1);
             Debug.Assert(op.Int64ValueCount == valuesPerBlock);
             int blockIndex = index / valuesPerBlock;
@@ -176,7 +176,7 @@ namespace Lucene.Net.Util.Packed
         {
             Debug.Assert(fromIndex >= 0);
             Debug.Assert(fromIndex <= toIndex);
-            Debug.Assert(PackedInts.BitsRequired(val) <= m_bitsPerValue);
+            Debug.Assert(PackedInt32s.BitsRequired(val) <= m_bitsPerValue);
 
             int valuesPerBlock = 64 / m_bitsPerValue;
             if (toIndex - fromIndex <= valuesPerBlock << 1)
@@ -217,11 +217,11 @@ namespace Lucene.Net.Util.Packed
             }
         }
 
-        internal override PackedInts.Format Format
+        internal override PackedInt32s.Format Format
         {
             get
             {
-                return PackedInts.Format.PACKED_SINGLE_BLOCK;
+                return PackedInt32s.Format.PACKED_SINGLE_BLOCK;
             }
         }
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Util/Packed/Packed8ThreeBlocks.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Packed/Packed8ThreeBlocks.cs b/src/Lucene.Net.Core/Util/Packed/Packed8ThreeBlocks.cs
index 160b154..eac8677 100644
--- a/src/Lucene.Net.Core/Util/Packed/Packed8ThreeBlocks.cs
+++ b/src/Lucene.Net.Core/Util/Packed/Packed8ThreeBlocks.cs
@@ -29,7 +29,7 @@ namespace Lucene.Net.Util.Packed
     /// Packs integers into 3 bytes (24 bits per value).
     /// @lucene.internal
     /// </summary>
-    internal sealed class Packed8ThreeBlocks : PackedInts.MutableImpl
+    internal sealed class Packed8ThreeBlocks : PackedInt32s.MutableImpl
     {
         readonly byte[] blocks;
 
@@ -50,7 +50,7 @@ namespace Lucene.Net.Util.Packed
         {
             @in.ReadBytes(blocks, 0, 3 * valueCount);
             // because packed ints have not always been byte-aligned
-            var remaining = (int)(PackedInts.Format.PACKED.ByteCount(packedIntsVersion, valueCount, 24) - 3L * valueCount * 1);
+            var remaining = (int)(PackedInt32s.Format.PACKED.ByteCount(packedIntsVersion, valueCount, 24) - 3L * valueCount * 1);
             for (int i = 0; i < remaining; ++i)
             {
                 @in.ReadByte();

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Util/Packed/PackedDataInput.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Packed/PackedDataInput.cs b/src/Lucene.Net.Core/Util/Packed/PackedDataInput.cs
index 4fb79b4..6dd5694 100644
--- a/src/Lucene.Net.Core/Util/Packed/PackedDataInput.cs
+++ b/src/Lucene.Net.Core/Util/Packed/PackedDataInput.cs
@@ -24,7 +24,7 @@ namespace Lucene.Net.Util.Packed
 
     /// <summary>
     /// A <seealso cref="DataInput"/> wrapper to read unaligned, variable-length packed
-    /// integers. this API is much slower than the <seealso cref="PackedInts"/> fixed-length
+    /// integers. this API is much slower than the <seealso cref="PackedInt32s"/> fixed-length
     /// API but can be convenient to save space. </summary>
     /// <seealso cref= PackedDataOutput
     /// @lucene.internal </seealso>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Util/Packed/PackedDataOutput.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Packed/PackedDataOutput.cs b/src/Lucene.Net.Core/Util/Packed/PackedDataOutput.cs
index 6ebe366..109fae3 100644
--- a/src/Lucene.Net.Core/Util/Packed/PackedDataOutput.cs
+++ b/src/Lucene.Net.Core/Util/Packed/PackedDataOutput.cs
@@ -50,7 +50,7 @@ namespace Lucene.Net.Util.Packed
         /// </summary>
         public void WriteInt64(long value, int bitsPerValue)
         {
-            Debug.Assert(bitsPerValue == 64 || (value >= 0 && value <= PackedInts.MaxValue(bitsPerValue)));
+            Debug.Assert(bitsPerValue == 64 || (value >= 0 && value <= PackedInt32s.MaxValue(bitsPerValue)));
             while (bitsPerValue > 0)
             {
                 if (remainingBits == 0)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Util/Packed/PackedInts.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Packed/PackedInts.cs b/src/Lucene.Net.Core/Util/Packed/PackedInts.cs
index 6b2997a..a440651 100644
--- a/src/Lucene.Net.Core/Util/Packed/PackedInts.cs
+++ b/src/Lucene.Net.Core/Util/Packed/PackedInts.cs
@@ -33,10 +33,12 @@ namespace Lucene.Net.Util.Packed
     /// Each value is >= 0 and &lt;= a specified maximum value.  The
     /// values are stored as packed ints, with each value
     /// consuming a fixed number of bits.
+    /// <para/>
+    /// NOTE: This was PackedInts in Lucene
     ///
     /// @lucene.internal
     /// </summary>
-    public class PackedInts
+    public class PackedInt32s
     {
         /// <summary>
         /// At most 700% memory overhead, always select a direct implementation.
@@ -98,7 +100,7 @@ namespace Lucene.Net.Util.Packed
         /// A format that may insert padding bits to improve encoding and decoding
         /// speed. Since this format doesn't support all possible bits per value, you
         /// should never use it directly, but rather use
-        /// <seealso cref="PackedInts#fastestFormatAndBits(int, int, float)"/> to find the
+        /// <seealso cref="PackedInt32s#fastestFormatAndBits(int, int, float)"/> to find the
         /// format that best suits your needs.
         /// </summary>
 
@@ -375,7 +377,7 @@ namespace Lucene.Net.Util.Packed
         /// The <code>acceptableOverheadRatio</code> parameter makes sense for
         /// random-access <seealso cref="Reader"/>s. In case you only plan to perform
         /// sequential access on this stream later on, you should probably use
-        /// <seealso cref="PackedInts#COMPACT"/>.
+        /// <seealso cref="PackedInt32s#COMPACT"/>.
         /// </p><p>
         /// If you don't know how many values you are going to write, use
         /// <code>valueCount = -1</code>.
@@ -690,7 +692,7 @@ namespace Lucene.Net.Util.Packed
             /// Returns at least 1 and at most <code>count</code> next values,
             /// the returned ref MUST NOT be modified
             /// </summary>
-            LongsRef Next(int count);
+            Int64sRef Next(int count);
 
             /// <summary>
             /// Returns number of bits per value </summary>
@@ -723,7 +725,7 @@ namespace Lucene.Net.Util.Packed
 
             public virtual long Next()
             {
-                LongsRef nextValues = Next(1);
+                Int64sRef nextValues = Next(1);
                 Debug.Assert(nextValues.Length > 0);
                 long result = nextValues.Int64s[nextValues.Offset];
                 ++nextValues.Offset;
@@ -731,7 +733,7 @@ namespace Lucene.Net.Util.Packed
                 return result;
             }
 
-            public abstract LongsRef Next(int count);
+            public abstract Int64sRef Next(int count);
 
             public virtual int BitsPerValue
             {
@@ -964,7 +966,7 @@ namespace Lucene.Net.Util.Packed
 
             /// <summary>
             /// The format used to serialize values. </summary>
-            protected internal abstract PackedInts.Format Format { get; }
+            protected internal abstract PackedInt32s.Format Format { get; }
 
             /// <summary>
             /// Add a value to the stream. </summary>
@@ -1018,7 +1020,7 @@ namespace Lucene.Net.Util.Packed
         /// Expert: Restore a <seealso cref="Reader"/> from a stream without reading metadata at
         /// the beginning of the stream. this method is useful to restore data from
         /// streams which have been created using
-        /// <seealso cref="PackedInts#getWriterNoHeader(DataOutput, Format, int, int, int)"/>.
+        /// <seealso cref="PackedInt32s#getWriterNoHeader(DataOutput, Format, int, int, int)"/>.
         /// </summary>
         /// <param name="in">           the stream to read data from, positioned at the beginning of the packed values </param>
         /// <param name="format">       the format used to serialize </param>
@@ -1027,17 +1029,17 @@ namespace Lucene.Net.Util.Packed
         /// <param name="bitsPerValue"> the number of bits per value </param>
         /// <returns>             a Reader </returns>
         /// <exception cref="IOException"> If there is a low-level I/O error </exception>
-        /// <seealso cref= PackedInts#getWriterNoHeader(DataOutput, Format, int, int, int)
+        /// <seealso cref= PackedInt32s#getWriterNoHeader(DataOutput, Format, int, int, int)
         /// @lucene.internal </seealso>
         public static Reader GetReaderNoHeader(DataInput @in, Format format, int version, int valueCount, int bitsPerValue)
         {
             CheckVersion(version);
 
-            if (format == PackedInts.Format.PACKED_SINGLE_BLOCK)
+            if (format == PackedInt32s.Format.PACKED_SINGLE_BLOCK)
             {
                 return Packed64SingleBlock.Create(@in, valueCount, bitsPerValue);
             }
-            else if (format == PackedInts.Format.PACKED)
+            else if (format == PackedInt32s.Format.PACKED)
             {
                 switch (bitsPerValue)
                 {
@@ -1113,7 +1115,7 @@ namespace Lucene.Net.Util.Packed
         /// Expert: Restore a <seealso cref="IReaderIterator"/> from a stream without reading
         /// metadata at the beginning of the stream. this method is useful to restore
         /// data from streams which have been created using
-        /// <seealso cref="PackedInts#getWriterNoHeader(DataOutput, Format, int, int, int)"/>.
+        /// <seealso cref="PackedInt32s#getWriterNoHeader(DataOutput, Format, int, int, int)"/>.
         /// </summary>
         /// <param name="in">           the stream to read data from, positioned at the beginning of the packed values </param>
         /// <param name="format">       the format used to serialize </param>
@@ -1122,7 +1124,7 @@ namespace Lucene.Net.Util.Packed
         /// <param name="bitsPerValue"> the number of bits per value </param>
         /// <param name="mem">          how much memory the iterator is allowed to use to read-ahead (likely to speed up iteration) </param>
         /// <returns>             a ReaderIterator </returns>
-        /// <seealso cref= PackedInts#getWriterNoHeader(DataOutput, Format, int, int, int)
+        /// <seealso cref= PackedInt32s#getWriterNoHeader(DataOutput, Format, int, int, int)
         /// @lucene.internal </seealso>
         public static IReaderIterator GetReaderIteratorNoHeader(DataInput @in, Format format, int version, int valueCount, int bitsPerValue, int mem)
         {
@@ -1151,7 +1153,7 @@ namespace Lucene.Net.Util.Packed
         /// Expert: Construct a direct <seealso cref="Reader"/> from a stream without reading
         /// metadata at the beginning of the stream. this method is useful to restore
         /// data from streams which have been created using
-        /// <seealso cref="PackedInts#getWriterNoHeader(DataOutput, Format, int, int, int)"/>.
+        /// <seealso cref="PackedInt32s#getWriterNoHeader(DataOutput, Format, int, int, int)"/>.
         /// </p><p>
         /// The returned reader will have very little memory overhead, but every call
         /// to <seealso cref="Reader#get(int)"/> is likely to perform a disk seek.
@@ -1167,11 +1169,11 @@ namespace Lucene.Net.Util.Packed
         {
             CheckVersion(version);
 
-            if (format == PackedInts.Format.PACKED_SINGLE_BLOCK)
+            if (format == PackedInt32s.Format.PACKED_SINGLE_BLOCK)
             {
                 return new DirectPacked64SingleBlockReader(bitsPerValue, valueCount, @in);
             }
-            else if (format == PackedInts.Format.PACKED)
+            else if (format == PackedInt32s.Format.PACKED)
             {
                 long byteCount = format.ByteCount(version, valueCount, bitsPerValue);
                 if (byteCount != format.ByteCount(VERSION_CURRENT, valueCount, bitsPerValue))
@@ -1248,7 +1250,7 @@ namespace Lucene.Net.Util.Packed
         /// <summary>
         /// Construct a direct <seealso cref="Reader"/> from an <seealso cref="IndexInput"/>. this method
         /// is useful to restore data from streams which have been created using
-        /// <seealso cref="PackedInts#getWriter(DataOutput, int, int, float)"/>.
+        /// <seealso cref="PackedInt32s#getWriter(DataOutput, int, int, float)"/>.
         /// </p><p>
         /// The returned reader will have very little memory overhead, but every call
         /// to <seealso cref="Reader#get(int)"/> is likely to perform a disk seek.
@@ -1275,8 +1277,8 @@ namespace Lucene.Net.Util.Packed
         /// Positive values of <code>acceptableOverheadRatio</code> will trade space
         /// for speed by selecting a faster but potentially less memory-efficient
         /// implementation. An <code>acceptableOverheadRatio</code> of
-        /// <seealso cref="PackedInts#COMPACT"/> will make sure that the most memory-efficient
-        /// implementation is selected whereas <seealso cref="PackedInts#FASTEST"/> will make sure
+        /// <seealso cref="PackedInt32s#COMPACT"/> will make sure that the most memory-efficient
+        /// implementation is selected whereas <seealso cref="PackedInt32s#FASTEST"/> will make sure
         /// that the fastest implementation is selected.
         /// </summary>
         /// <param name="valueCount">   the number of elements </param>
@@ -1296,15 +1298,15 @@ namespace Lucene.Net.Util.Packed
         ///  of bits per value and format.
         ///  @lucene.internal
         /// </summary>
-        public static Mutable GetMutable(int valueCount, int bitsPerValue, PackedInts.Format format)
+        public static Mutable GetMutable(int valueCount, int bitsPerValue, PackedInt32s.Format format)
         {
             Debug.Assert(valueCount >= 0);
 
-            if (format == PackedInts.Format.PACKED_SINGLE_BLOCK)
+            if (format == PackedInt32s.Format.PACKED_SINGLE_BLOCK)
             {
                 return Packed64SingleBlock.Create(valueCount, bitsPerValue);
             }
-            else if (format == PackedInts.Format.PACKED)
+            else if (format == PackedInt32s.Format.PACKED)
             {
                 switch (bitsPerValue)
                 {
@@ -1381,7 +1383,7 @@ namespace Lucene.Net.Util.Packed
         /// <param name="bitsPerValue"> the number of bits per value </param>
         /// <param name="mem">          how much memory (in bytes) can be used to speed up serialization </param>
         /// <returns>             a Writer </returns>
-        /// <seealso cref= PackedInts#getReaderIteratorNoHeader(DataInput, Format, int, int, int, int) </seealso>
+        /// <seealso cref= PackedInt32s#getReaderIteratorNoHeader(DataInput, Format, int, int, int, int) </seealso>
         /// <seealso cref= PackedInts#getReaderNoHeader(DataInput, Format, int, int, int)
         /// @lucene.internal </seealso>
         public static Writer GetWriterNoHeader(DataOutput @out, Format format, int valueCount, int bitsPerValue, int mem)
@@ -1408,11 +1410,11 @@ namespace Lucene.Net.Util.Packed
         /// readers that will be restored from this stream trade space
         /// for speed by selecting a faster but potentially less memory-efficient
         /// implementation. An <code>acceptableOverheadRatio</code> of
-        /// <seealso cref="PackedInts#COMPACT"/> will make sure that the most memory-efficient
-        /// implementation is selected whereas <seealso cref="PackedInts#FASTEST"/> will make sure
+        /// <seealso cref="PackedInt32s#COMPACT"/> will make sure that the most memory-efficient
+        /// implementation is selected whereas <seealso cref="PackedInt32s#FASTEST"/> will make sure
         /// that the fastest implementation is selected. In case you are only interested
         /// in reading this stream sequentially later on, you should probably use
-        /// <seealso cref="PackedInts#COMPACT"/>.
+        /// <seealso cref="PackedInt32s#COMPACT"/>.
         /// </summary>
         /// <param name="out">          the data output </param>
         /// <param name="valueCount">   the number of values </param>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Util/Packed/PackedReaderIterator.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Packed/PackedReaderIterator.cs b/src/Lucene.Net.Core/Util/Packed/PackedReaderIterator.cs
index 27a0680..90e5503 100644
--- a/src/Lucene.Net.Core/Util/Packed/PackedReaderIterator.cs
+++ b/src/Lucene.Net.Core/Util/Packed/PackedReaderIterator.cs
@@ -23,17 +23,17 @@ namespace Lucene.Net.Util.Packed
 
     using DataInput = Lucene.Net.Store.DataInput;
 
-    internal sealed class PackedReaderIterator : PackedInts.ReaderIterator
+    internal sealed class PackedReaderIterator : PackedInt32s.ReaderIterator
     {
         internal readonly int packedIntsVersion;
-        internal readonly PackedInts.Format format;
+        internal readonly PackedInt32s.Format format;
         internal readonly BulkOperation bulkOperation;
         internal readonly byte[] nextBlocks;
-        internal readonly LongsRef nextValues;
+        internal readonly Int64sRef nextValues;
         internal readonly int iterations;
         internal int position;
 
-        internal PackedReaderIterator(PackedInts.Format format, int packedIntsVersion, int valueCount, int bitsPerValue, DataInput @in, int mem)
+        internal PackedReaderIterator(PackedInt32s.Format format, int packedIntsVersion, int valueCount, int bitsPerValue, DataInput @in, int mem)
             : base(valueCount, bitsPerValue, @in)
         {
             this.format = format;
@@ -42,7 +42,7 @@ namespace Lucene.Net.Util.Packed
             iterations = Iterations(mem);
             Debug.Assert(valueCount == 0 || iterations > 0);
             nextBlocks = new byte[iterations * bulkOperation.ByteBlockCount];
-            nextValues = new LongsRef(new long[iterations * bulkOperation.ByteValueCount], 0, 0);
+            nextValues = new Int64sRef(new long[iterations * bulkOperation.ByteValueCount], 0, 0);
             nextValues.Offset = nextValues.Int64s.Length;
             position = -1;
         }
@@ -50,7 +50,7 @@ namespace Lucene.Net.Util.Packed
         private int Iterations(int mem)
         {
             int iterations = bulkOperation.ComputeIterations(m_valueCount, mem);
-            if (packedIntsVersion < PackedInts.VERSION_BYTE_ALIGNED)
+            if (packedIntsVersion < PackedInt32s.VERSION_BYTE_ALIGNED)
             {
                 // make sure iterations is a multiple of 8
                 iterations = (iterations + 7) & unchecked((int)0xFFFFFFF8);
@@ -58,7 +58,7 @@ namespace Lucene.Net.Util.Packed
             return iterations;
         }
 
-        public override LongsRef Next(int count)
+        public override Int64sRef Next(int count)
         {
             Debug.Assert(nextValues.Length >= 0);
             Debug.Assert(count > 0);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Util/Packed/PackedWriter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Packed/PackedWriter.cs b/src/Lucene.Net.Core/Util/Packed/PackedWriter.cs
index 53283d4..4e52033 100644
--- a/src/Lucene.Net.Core/Util/Packed/PackedWriter.cs
+++ b/src/Lucene.Net.Core/Util/Packed/PackedWriter.cs
@@ -25,10 +25,10 @@ namespace Lucene.Net.Util.Packed
     // Packs high order byte first, to match
     // IndexOutput.writeInt/Long/Short byte order
 
-    internal sealed class PackedWriter : PackedInts.Writer
+    internal sealed class PackedWriter : PackedInt32s.Writer
     {
         internal bool finished;
-        internal readonly PackedInts.Format format;
+        internal readonly PackedInt32s.Format format;
         internal readonly BulkOperation encoder;
         internal readonly byte[] nextBlocks;
         internal readonly long[] nextValues;
@@ -36,7 +36,7 @@ namespace Lucene.Net.Util.Packed
         internal int off;
         internal int written;
 
-        internal PackedWriter(PackedInts.Format format, DataOutput @out, int valueCount, int bitsPerValue, int mem)
+        internal PackedWriter(PackedInt32s.Format format, DataOutput @out, int valueCount, int bitsPerValue, int mem)
             : base(@out, valueCount, bitsPerValue)
         {
             this.format = format;
@@ -49,7 +49,7 @@ namespace Lucene.Net.Util.Packed
             finished = false;
         }
 
-        protected internal override PackedInts.Format Format
+        protected internal override PackedInt32s.Format Format
         {
             get
             {
@@ -59,7 +59,7 @@ namespace Lucene.Net.Util.Packed
 
         public override void Add(long v)
         {
-            Debug.Assert(m_bitsPerValue == 64 || (v >= 0 && v <= PackedInts.MaxValue(m_bitsPerValue)), m_bitsPerValue.ToString());
+            Debug.Assert(m_bitsPerValue == 64 || (v >= 0 && v <= PackedInt32s.MaxValue(m_bitsPerValue)), m_bitsPerValue.ToString());
             Debug.Assert(!finished);
             if (m_valueCount != -1 && written >= m_valueCount)
             {
@@ -90,7 +90,7 @@ namespace Lucene.Net.Util.Packed
         private void Flush()
         {
             encoder.Encode(nextValues, 0, nextBlocks, 0, iterations);
-            int blockCount = (int)format.ByteCount(PackedInts.VERSION_CURRENT, off, m_bitsPerValue);
+            int blockCount = (int)format.ByteCount(PackedInt32s.VERSION_CURRENT, off, m_bitsPerValue);
             m_out.WriteBytes(nextBlocks, blockCount);
             Arrays.Fill(nextValues, 0L);
             off = 0;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Util/Packed/PagedGrowableWriter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Packed/PagedGrowableWriter.cs b/src/Lucene.Net.Core/Util/Packed/PagedGrowableWriter.cs
index e8547db..3de2bb8 100644
--- a/src/Lucene.Net.Core/Util/Packed/PagedGrowableWriter.cs
+++ b/src/Lucene.Net.Core/Util/Packed/PagedGrowableWriter.cs
@@ -17,12 +17,12 @@ namespace Lucene.Net.Util.Packed
      * limitations under the License.
      */
 
-    using Mutable = Lucene.Net.Util.Packed.PackedInts.Mutable;
+    using Mutable = Lucene.Net.Util.Packed.PackedInt32s.Mutable;
 
     /// <summary>
     /// A <seealso cref="PagedGrowableWriter"/>. this class slices data into fixed-size blocks
     /// which have independent numbers of bits per value and grow on-demand.
-    /// <p>You should use this class instead of the <seealso cref="AbstractAppendingLongBuffer"/> related ones only when
+    /// <p>You should use this class instead of the <seealso cref="AbstractAppendingInt64Buffer"/> related ones only when
     /// you need random write-access. Otherwise this class will likely be slower and
     /// less memory-efficient.
     /// @lucene.internal

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Util/Packed/PagedMutable.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Packed/PagedMutable.cs b/src/Lucene.Net.Core/Util/Packed/PagedMutable.cs
index 091ed47..d7912df 100644
--- a/src/Lucene.Net.Core/Util/Packed/PagedMutable.cs
+++ b/src/Lucene.Net.Core/Util/Packed/PagedMutable.cs
@@ -19,17 +19,17 @@ namespace Lucene.Net.Util.Packed
      * limitations under the License.
      */
 
-    using Mutable = Lucene.Net.Util.Packed.PackedInts.Mutable;
+    using Mutable = Lucene.Net.Util.Packed.PackedInt32s.Mutable;
 
     /// <summary>
     /// A <seealso cref="PagedMutable"/>. this class slices data into fixed-size blocks
     /// which have the same number of bits per value. It can be a useful replacement
-    /// for <seealso cref="PackedInts.Mutable"/> to store more than 2B values.
+    /// for <seealso cref="PackedInt32s.Mutable"/> to store more than 2B values.
     /// @lucene.internal
     /// </summary>
     public sealed class PagedMutable : AbstractPagedMutable<PagedMutable>
     {
-        internal readonly PackedInts.Format format;
+        internal readonly PackedInt32s.Format format;
 
         /// <summary>
         /// Create a new <seealso cref="PagedMutable"/> instance.
@@ -39,17 +39,17 @@ namespace Lucene.Net.Util.Packed
         /// <param name="bitsPerValue"> the number of bits per value </param>
         /// <param name="acceptableOverheadRatio"> an acceptable overhead ratio </param>
         public PagedMutable(long size, int pageSize, int bitsPerValue, float acceptableOverheadRatio)
-            : this(size, pageSize, PackedInts.FastestFormatAndBits(pageSize, bitsPerValue, acceptableOverheadRatio))
+            : this(size, pageSize, PackedInt32s.FastestFormatAndBits(pageSize, bitsPerValue, acceptableOverheadRatio))
         {
             FillPages();
         }
 
-        internal PagedMutable(long size, int pageSize, PackedInts.FormatAndBits formatAndBits)
+        internal PagedMutable(long size, int pageSize, PackedInt32s.FormatAndBits formatAndBits)
             : this(size, pageSize, formatAndBits.BitsPerValue, formatAndBits.Format)
         {
         }
 
-        internal PagedMutable(long size, int pageSize, int bitsPerValue, PackedInts.Format format)
+        internal PagedMutable(long size, int pageSize, int bitsPerValue, PackedInt32s.Format format)
             : base(bitsPerValue, size, pageSize)
         {
             this.format = format;
@@ -58,7 +58,7 @@ namespace Lucene.Net.Util.Packed
         protected override Mutable NewMutable(int valueCount, int bitsPerValue)
         {
             Debug.Assert(this.bitsPerValue >= bitsPerValue);
-            return PackedInts.GetMutable(valueCount, this.bitsPerValue, format);
+            return PackedInt32s.GetMutable(valueCount, this.bitsPerValue, format);
         }
 
         protected override PagedMutable NewUnfilledCopy(long newSize)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Util/RecyclingIntBlockAllocator.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/RecyclingIntBlockAllocator.cs b/src/Lucene.Net.Core/Util/RecyclingIntBlockAllocator.cs
index 19e7537..271515e 100644
--- a/src/Lucene.Net.Core/Util/RecyclingIntBlockAllocator.cs
+++ b/src/Lucene.Net.Core/Util/RecyclingIntBlockAllocator.cs
@@ -20,18 +20,21 @@ namespace Lucene.Net.Util
      * limitations under the License.
      */
 
-    using Allocator = Lucene.Net.Util.IntBlockPool.Allocator;
+    using Allocator = Lucene.Net.Util.Int32BlockPool.Allocator;
 
     /// <summary>
     /// A <seealso cref="Allocator"/> implementation that recycles unused int
     /// blocks in a buffer and reuses them in subsequent calls to
     /// <seealso cref="#getIntBlock()"/>.
-    /// <p>
+    /// <para>
     /// Note: this class is not thread-safe
-    /// </p>
+    /// </para>
+    /// <para>
+    /// NOTE: This was RecyclingIntBlockAllocator in Lucene
+    /// </para>
     /// @lucene.internal
     /// </summary>
-    public sealed class RecyclingIntBlockAllocator : Allocator // LUCENENET TODO: Rename RecyclingInt32BlockAllocator ?
+    public sealed class RecyclingInt32BlockAllocator : Allocator
     {
         private int[][] freeByteBlocks;
         private readonly int maxBufferedBlocks;
@@ -40,7 +43,7 @@ namespace Lucene.Net.Util
         public const int DEFAULT_BUFFERED_BLOCKS = 64;
 
         /// <summary>
-        /// Creates a new <seealso cref="RecyclingIntBlockAllocator"/>
+        /// Creates a new <seealso cref="RecyclingInt32BlockAllocator"/>
         /// </summary>
         /// <param name="blockSize">
         ///          the block size in bytes </param>
@@ -48,7 +51,7 @@ namespace Lucene.Net.Util
         ///          maximum number of buffered int block </param>
         /// <param name="bytesUsed">
         ///          <seealso cref="Counter"/> reference counting internally allocated bytes </param>
-        public RecyclingIntBlockAllocator(int blockSize, int maxBufferedBlocks, Counter bytesUsed)
+        public RecyclingInt32BlockAllocator(int blockSize, int maxBufferedBlocks, Counter bytesUsed)
             : base(blockSize)
         {
             freeByteBlocks = new int[maxBufferedBlocks][];
@@ -57,25 +60,25 @@ namespace Lucene.Net.Util
         }
 
         /// <summary>
-        /// Creates a new <seealso cref="RecyclingIntBlockAllocator"/>.
+        /// Creates a new <seealso cref="RecyclingInt32BlockAllocator"/>.
         /// </summary>
         /// <param name="blockSize">
         ///          the size of each block returned by this allocator </param>
         /// <param name="maxBufferedBlocks">
         ///          maximum number of buffered int blocks </param>
-        public RecyclingIntBlockAllocator(int blockSize, int maxBufferedBlocks)
+        public RecyclingInt32BlockAllocator(int blockSize, int maxBufferedBlocks)
             : this(blockSize, maxBufferedBlocks, Counter.NewCounter(false))
         {
         }
 
         /// <summary>
-        /// Creates a new <seealso cref="RecyclingIntBlockAllocator"/> with a block size of
-        /// <seealso cref="IntBlockPool#INT_BLOCK_SIZE"/>, upper buffered docs limit of
+        /// Creates a new <seealso cref="RecyclingInt32BlockAllocator"/> with a block size of
+        /// <seealso cref="Int32BlockPool#INT_BLOCK_SIZE"/>, upper buffered docs limit of
         /// <seealso cref="#DEFAULT_BUFFERED_BLOCKS"/> ({@value #DEFAULT_BUFFERED_BLOCKS}).
         ///
         /// </summary>
-        public RecyclingIntBlockAllocator()
-            : this(IntBlockPool.INT_BLOCK_SIZE, 64, Counter.NewCounter(false))
+        public RecyclingInt32BlockAllocator()
+            : this(Int32BlockPool.INT_BLOCK_SIZE, 64, Counter.NewCounter(false))
         {
         }
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Util/SentinelIntSet.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/SentinelIntSet.cs b/src/Lucene.Net.Core/Util/SentinelIntSet.cs
index e7a9a0b..079c212 100644
--- a/src/Lucene.Net.Core/Util/SentinelIntSet.cs
+++ b/src/Lucene.Net.Core/Util/SentinelIntSet.cs
@@ -28,19 +28,21 @@ namespace Lucene.Net.Util
     /// would make it >= 75% full.  Consider extending and over-riding <seealso cref="#hash(int)"/> if the values might be poor
     /// hash keys; Lucene docids should be fine.
     /// The internal fields are exposed publicly to enable more efficient use at the expense of better O-O principles.
-    /// <p/>
+    /// <para/>
     /// To iterate over the integers held in this set, simply use code like this:
-    /// <pre class="prettyprint">
+    /// <code>
     /// SentinelIntSet set = ...
     /// for (int v : set.keys) {
     ///   if (v == set.emptyVal)
     ///     continue;
     ///   //use v...
-    /// }</pre>
+    /// }</code>
+    /// <para/>
+    /// NOTE: This was SentinelIntSet in Lucene
     ///
     /// @lucene.internal
     /// </summary>
-    public class SentinelIntSet
+    public class SentinelInt32Set
     {
         /// <summary>
         /// A power-of-2 over-sized array holding the integers in the set along with empty values. </summary>
@@ -66,7 +68,7 @@ namespace Lucene.Net.Util
         /// <param name="size">  The minimum number of elements this set should be able to hold without rehashing
         ///              (i.e. the slots are guaranteed not to change) </param>
         /// <param name="emptyVal"> The integer value to use for EMPTY </param>
-        public SentinelIntSet(int size, int emptyVal)
+        public SentinelInt32Set(int size, int emptyVal)
         {
             this.EmptyVal = emptyVal;
             int tsize = Math.Max(Lucene.Net.Util.BitUtil.NextHighestPowerOfTwo(size), 1);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Util/SmallFloat.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/SmallFloat.cs b/src/Lucene.Net.Core/Util/SmallFloat.cs
index ca87e46..2bff9ff 100644
--- a/src/Lucene.Net.Core/Util/SmallFloat.cs
+++ b/src/Lucene.Net.Core/Util/SmallFloat.cs
@@ -21,14 +21,16 @@ namespace Lucene.Net.Util
 
     /// <summary>
     /// Floating point numbers smaller than 32 bits.
+    /// <para/>
+    /// NOTE: This was SmallFloat in Lucene
     ///
     /// @lucene.internal
     /// </summary>
-    public class SmallFloat
+    public class SmallSingle
     {
         /// <summary>
         /// No instance </summary>
-        private SmallFloat()
+        private SmallSingle()
         {
         }
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Util/UnicodeUtil.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/UnicodeUtil.cs b/src/Lucene.Net.Core/Util/UnicodeUtil.cs
index a9d1e34..ad07d11 100644
--- a/src/Lucene.Net.Core/Util/UnicodeUtil.cs
+++ b/src/Lucene.Net.Core/Util/UnicodeUtil.cs
@@ -534,7 +534,7 @@ namespace Lucene.Net.Util
         /// </summary>
         /// <exception cref="IllegalArgumentException"> If invalid codepoint header byte occurs or the
         ///    content is prematurely truncated. </exception>
-        public static void UTF8toUTF32(BytesRef utf8, IntsRef utf32)
+        public static void UTF8toUTF32(BytesRef utf8, Int32sRef utf32)
         {
             // TODO: broken if incoming result.offset != 0
             // pre-alloc for worst case


[15/53] [abbrv] lucenenet git commit: Lucene.Net.Facet.Taxonomy.Directory.DirectoryTaxonomyReader refactor: Renamed IntClass > Int32Class, IntItem > Value. Made the Value non-nullable, since it is already wrapped in a reference type. Changed Int32Class a

Posted by ni...@apache.org.
Lucene.Net.Facet.Taxonomy.Directory.DirectoryTaxonomyReader refactor: Renamed IntClass > Int32Class, IntItem > Value. Made the Value non-nullable, since it is already wrapped in a reference type. Changed Int32Class and constructor from internal to private, since they are not used outside of the class anyway.


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

Branch: refs/heads/api-work
Commit: ffa0fbf6ed9e90e25b3858ca52a5ba1c0f8e14c9
Parents: 4c08260
Author: Shad Storhaug <sh...@shadstorhaug.com>
Authored: Tue Feb 7 20:45:14 2017 +0700
Committer: Shad Storhaug <sh...@shadstorhaug.com>
Committed: Wed Feb 8 21:08:21 2017 +0700

----------------------------------------------------------------------
 .../Directory/DirectoryTaxonomyReader.cs        | 32 ++++++++++++--------
 1 file changed, 19 insertions(+), 13 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/lucenenet/blob/ffa0fbf6/src/Lucene.Net.Facet/Taxonomy/Directory/DirectoryTaxonomyReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Facet/Taxonomy/Directory/DirectoryTaxonomyReader.cs b/src/Lucene.Net.Facet/Taxonomy/Directory/DirectoryTaxonomyReader.cs
index 2e71b8b..b66517e 100644
--- a/src/Lucene.Net.Facet/Taxonomy/Directory/DirectoryTaxonomyReader.cs
+++ b/src/Lucene.Net.Facet/Taxonomy/Directory/DirectoryTaxonomyReader.cs
@@ -47,9 +47,15 @@ namespace Lucene.Net.Facet.Taxonomy.Directory
     /// </summary>
     public class DirectoryTaxonomyReader : TaxonomyReader, IDisposable
     {
-        public class IntClass
+        /// <summary>
+        /// LUCENENET specific class to make an <see cref="int"/> type into a reference type.
+        /// </summary>
+        private class Int32Class
         {
-            public int? IntItem { get; set; }
+            /// <summary>
+            /// NOTE: This was intItem (field) in Lucene
+            /// </summary>
+            public int Value { get; set; }
         }
         private const int DEFAULT_CACHE_VALUE = 4000;
 
@@ -58,7 +64,7 @@ namespace Lucene.Net.Facet.Taxonomy.Directory
         private readonly DirectoryReader indexReader;
 
         // TODO: test DoubleBarrelLRUCache and consider using it instead
-        private LRUHashMap<FacetLabel, IntClass> ordinalCache;
+        private LRUHashMap<FacetLabel, Int32Class> ordinalCache;
         private LRUHashMap<int, FacetLabel> categoryCache;
 
         private volatile TaxonomyIndexArrays taxoArrays;
@@ -68,8 +74,8 @@ namespace Lucene.Net.Facet.Taxonomy.Directory
         /// recreated, you should pass <c>null</c> as the caches and parent/children
         /// arrays.
         /// </summary>
-        internal DirectoryTaxonomyReader(DirectoryReader indexReader, DirectoryTaxonomyWriter taxoWriter, 
-            LRUHashMap<FacetLabel, IntClass> ordinalCache, LRUHashMap<int, FacetLabel> categoryCache, 
+        private DirectoryTaxonomyReader(DirectoryReader indexReader, DirectoryTaxonomyWriter taxoWriter, 
+            LRUHashMap<FacetLabel, Int32Class> ordinalCache, LRUHashMap<int, FacetLabel> categoryCache, 
             TaxonomyIndexArrays taxoArrays)
         {
             this.indexReader = indexReader;
@@ -77,7 +83,7 @@ namespace Lucene.Net.Facet.Taxonomy.Directory
             this.taxoEpoch = taxoWriter == null ? -1 : taxoWriter.TaxonomyEpoch;
 
             // use the same instance of the cache, note the protective code in getOrdinal and getPath
-            this.ordinalCache = ordinalCache == null ? new LRUHashMap<FacetLabel, IntClass>(DEFAULT_CACHE_VALUE) : ordinalCache;
+            this.ordinalCache = ordinalCache == null ? new LRUHashMap<FacetLabel, Int32Class>(DEFAULT_CACHE_VALUE) : ordinalCache;
             this.categoryCache = categoryCache == null ? new LRUHashMap<int, FacetLabel>(DEFAULT_CACHE_VALUE) : categoryCache;
 
             this.taxoArrays = taxoArrays != null ? new TaxonomyIndexArrays(indexReader, taxoArrays) : null;
@@ -98,7 +104,7 @@ namespace Lucene.Net.Facet.Taxonomy.Directory
             // These are the default cache sizes; they can be configured after
             // construction with the cache's setMaxSize() method
 
-            ordinalCache = new LRUHashMap<FacetLabel, IntClass>(DEFAULT_CACHE_VALUE);
+            ordinalCache = new LRUHashMap<FacetLabel, Int32Class>(DEFAULT_CACHE_VALUE);
             categoryCache = new LRUHashMap<int, FacetLabel>(DEFAULT_CACHE_VALUE);
         }
 
@@ -118,7 +124,7 @@ namespace Lucene.Net.Facet.Taxonomy.Directory
             // These are the default cache sizes; they can be configured after
             // construction with the cache's setMaxSize() method
 
-            ordinalCache = new LRUHashMap<FacetLabel, IntClass>(DEFAULT_CACHE_VALUE);
+            ordinalCache = new LRUHashMap<FacetLabel, Int32Class>(DEFAULT_CACHE_VALUE);
             categoryCache = new LRUHashMap<int, FacetLabel>(DEFAULT_CACHE_VALUE);
         }
 
@@ -290,15 +296,15 @@ namespace Lucene.Net.Facet.Taxonomy.Directory
 
             // LUCENENET: Lock was removed here because the underlying cache is thread-safe,
             // and removing the lock seems to make the performance better.
-            IntClass res = ordinalCache.Get(cp);
-            if (res != null && res.IntItem != null)
+            Int32Class res = ordinalCache.Get(cp);
+            if (res != null)
             {
-                if ((int)res.IntItem.Value < indexReader.MaxDoc)
+                if ((int)res.Value < indexReader.MaxDoc)
                 {
                     // Since the cache is shared with DTR instances allocated from
                     // doOpenIfChanged, we need to ensure that the ordinal is one that
                     // this DTR instance recognizes.
-                    return (int)res.IntItem.Value;
+                    return (int)res.Value;
                 }
                 else
                 {
@@ -326,7 +332,7 @@ namespace Lucene.Net.Facet.Taxonomy.Directory
 
                 // LUCENENET: Lock was removed here because the underlying cache is thread-safe,
                 // and removing the lock seems to make the performance better.
-                ordinalCache.Put(cp, new IntClass { IntItem = Convert.ToInt32(ret) });
+                ordinalCache.Put(cp, new Int32Class { Value = Convert.ToInt32(ret) });
             }
 
             return ret;


[45/53] [abbrv] lucenenet git commit: Lucene.Net.Core.Index: Added exceptions to the .NET numeric convention rule for SkippingLongTerm() (which although there isn't any way to confirm, it sounds like they are not referring to the datatype long)

Posted by ni...@apache.org.
Lucene.Net.Core.Index: Added exceptions to the .NET numeric convention rule for SkippingLongTerm() (which although there isn't any way to confirm, it sounds like they are not referring to the datatype long)


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

Branch: refs/heads/api-work
Commit: e67e0b572c7de8c2d32cd083b6b556a13222feab
Parents: 96dd76c
Author: Shad Storhaug <sh...@shadstorhaug.com>
Authored: Wed Feb 8 17:46:58 2017 +0700
Committer: Shad Storhaug <sh...@shadstorhaug.com>
Committed: Wed Feb 8 21:08:25 2017 +0700

----------------------------------------------------------------------
 src/Lucene.Net.Core/Index/FreqProxTermsWriterPerField.cs | 2 ++
 src/Lucene.Net.Core/Index/TermVectorsConsumerPerField.cs | 2 ++
 src/Lucene.Net.Core/Index/TermsHashConsumerPerField.cs   | 3 +++
 3 files changed, 7 insertions(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/lucenenet/blob/e67e0b57/src/Lucene.Net.Core/Index/FreqProxTermsWriterPerField.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Index/FreqProxTermsWriterPerField.cs b/src/Lucene.Net.Core/Index/FreqProxTermsWriterPerField.cs
index b3bfdc5..9ba48d7 100644
--- a/src/Lucene.Net.Core/Index/FreqProxTermsWriterPerField.cs
+++ b/src/Lucene.Net.Core/Index/FreqProxTermsWriterPerField.cs
@@ -1,4 +1,5 @@
 using Lucene.Net.Analysis.TokenAttributes;
+using Lucene.Net.Support;
 using System;
 using System.Collections.Generic;
 using System.Diagnostics;
@@ -83,6 +84,7 @@ namespace Lucene.Net.Index
 
         internal bool hasPayloads;
 
+        [ExceptionToNetNumericConvention]
         internal override void SkippingLongTerm()
         {
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/e67e0b57/src/Lucene.Net.Core/Index/TermVectorsConsumerPerField.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Index/TermVectorsConsumerPerField.cs b/src/Lucene.Net.Core/Index/TermVectorsConsumerPerField.cs
index 13128b3..f81208b 100644
--- a/src/Lucene.Net.Core/Index/TermVectorsConsumerPerField.cs
+++ b/src/Lucene.Net.Core/Index/TermVectorsConsumerPerField.cs
@@ -1,4 +1,5 @@
 using Lucene.Net.Analysis.TokenAttributes;
+using Lucene.Net.Support;
 using System;
 using System.Diagnostics;
 
@@ -316,6 +317,7 @@ namespace Lucene.Net.Index
             WriteProx(postings, termID);
         }
 
+        [ExceptionToNetNumericConvention]
         internal override void SkippingLongTerm()
         {
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/e67e0b57/src/Lucene.Net.Core/Index/TermsHashConsumerPerField.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Index/TermsHashConsumerPerField.cs b/src/Lucene.Net.Core/Index/TermsHashConsumerPerField.cs
index 3469ad0..c0400e3 100644
--- a/src/Lucene.Net.Core/Index/TermsHashConsumerPerField.cs
+++ b/src/Lucene.Net.Core/Index/TermsHashConsumerPerField.cs
@@ -1,3 +1,5 @@
+using Lucene.Net.Support;
+
 namespace Lucene.Net.Index
 {
     /*
@@ -29,6 +31,7 @@ namespace Lucene.Net.Index
 
         internal abstract void Finish();
 
+        [ExceptionToNetNumericConvention]
         internal abstract void SkippingLongTerm();
 
         internal abstract void Start(IIndexableField field);


[18/53] [abbrv] lucenenet git commit: Lucene.Net.Queries: Renamed all type-derived properties and methods from Short, Int, Long, and Float to match CLR types Int16, Int32, Int64, and Single, respectively.

Posted by ni...@apache.org.
Lucene.Net.Queries: Renamed all type-derived properties and methods from Short, Int, Long, and Float to match CLR types Int16, Int32, Int64, and Single, respectively.


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

Branch: refs/heads/api-work
Commit: ec70857f3c41e1fa663487b6ab8446cf085096e4
Parents: bb41cd1
Author: Shad Storhaug <sh...@shadstorhaug.com>
Authored: Wed Feb 8 00:29:57 2017 +0700
Committer: Shad Storhaug <sh...@shadstorhaug.com>
Committed: Wed Feb 8 21:08:21 2017 +0700

----------------------------------------------------------------------
 src/Lucene.Net.Facet/Range/LongRange.cs         |  2 +-
 .../Range/LongRangeFacetCounts.cs               |  4 +-
 src/Lucene.Net.Queries/Function/BoostedQuery.cs |  6 +-
 .../Function/DocValues/BoolDocValues.cs         | 20 ++++--
 .../Function/DocValues/DoubleDocValues.cs       | 20 ++++--
 .../Function/DocValues/FloatDocValues.cs        | 38 +++++++----
 .../Function/DocValues/IntDocValues.cs          | 40 ++++++++----
 .../Function/DocValues/LongDocValues.cs         | 48 ++++++++------
 .../Function/FunctionQuery.cs                   |  4 +-
 .../Function/FunctionValues.cs                  | 56 +++++++++++-----
 .../Function/ValueSourceScorer.cs               |  4 +-
 .../Function/ValueSources/ByteFieldSource.cs    | 20 ++++--
 .../Function/ValueSources/ConstNumberSource.cs  | 17 ++++-
 .../Function/ValueSources/ConstValueSource.cs   | 32 ++++++++--
 .../Function/ValueSources/DefFunction.cs        | 28 +++++---
 .../Function/ValueSources/DivFloatFunction.cs   |  2 +-
 .../Function/ValueSources/DocFreqValueSource.cs | 34 ++++++++--
 .../ValueSources/DoubleConstValueSource.cs      | 30 +++++++--
 .../Function/ValueSources/DualFloatFunction.cs  |  5 +-
 .../Function/ValueSources/EnumFieldSource.cs    | 38 ++++++++---
 .../Function/ValueSources/FloatFieldSource.cs   |  5 +-
 .../Function/ValueSources/IfFunction.cs         | 28 +++++---
 .../Function/ValueSources/IntFieldSource.cs     | 17 +++--
 .../ValueSources/JoinDocFreqValueSource.cs      |  5 +-
 .../ValueSources/LinearFloatFunction.cs         |  7 +-
 .../Function/ValueSources/LongFieldSource.cs    | 40 ++++++++----
 .../Function/ValueSources/MaxFloatFunction.cs   |  2 +-
 .../Function/ValueSources/MinFloatFunction.cs   |  2 +-
 .../Function/ValueSources/MultiFloatFunction.cs |  5 +-
 .../Function/ValueSources/NormValueSource.cs    |  5 +-
 .../Function/ValueSources/OrdFieldSource.cs     |  6 +-
 .../Function/ValueSources/PowFloatFunction.cs   |  2 +-
 .../ValueSources/ProductFloatFunction.cs        |  2 +-
 .../Function/ValueSources/QueryValueSource.cs   |  7 +-
 .../ValueSources/RangeMapFloatFunction.cs       |  9 ++-
 .../ValueSources/ReciprocalFloatFunction.cs     |  7 +-
 .../ValueSources/ReverseOrdFieldSource.cs       |  5 +-
 .../Function/ValueSources/ScaleFloatFunction.cs |  9 ++-
 .../Function/ValueSources/ShortFieldSource.cs   | 22 +++++--
 .../ValueSources/SimpleFloatFunction.cs         |  5 +-
 .../Function/ValueSources/SumFloatFunction.cs   |  2 +-
 .../ValueSources/SumTotalTermFreqValueSource.cs |  5 +-
 .../Function/ValueSources/TFValueSource.cs      |  5 +-
 .../ValueSources/TermFreqValueSource.cs         |  5 +-
 .../ValueSources/TotalTermFreqValueSource.cs    |  5 +-
 .../Function/ValueSources/VectorValueSource.cs  | 67 ++++++++++++++------
 .../Util/CachingDoubleValueSource.cs            |  5 +-
 .../Util/ShapeFieldCacheDistanceValueSource.cs  |  7 +-
 .../Vector/DistanceValueSource.cs               |  7 +-
 .../Suggest/DocumentValueSourceDictionary.cs    |  2 +-
 .../TestExpressionValueSource.cs                | 24 +++----
 .../Function/TestDocValuesFieldSources.cs       |  4 +-
 52 files changed, 556 insertions(+), 220 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/lucenenet/blob/ec70857f/src/Lucene.Net.Facet/Range/LongRange.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Facet/Range/LongRange.cs b/src/Lucene.Net.Facet/Range/LongRange.cs
index e8eec95..8267328 100644
--- a/src/Lucene.Net.Facet/Range/LongRange.cs
+++ b/src/Lucene.Net.Facet/Range/LongRange.cs
@@ -214,7 +214,7 @@ namespace Lucene.Net.Facet.Range
                         {
                             return false;
                         }
-                        return outerInstance.outerInstance.outerInstance.Accept(outerInstance.values.LongVal(docID));
+                        return outerInstance.outerInstance.outerInstance.Accept(outerInstance.values.Int64Val(docID));
                     }
 
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/ec70857f/src/Lucene.Net.Facet/Range/LongRangeFacetCounts.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Facet/Range/LongRangeFacetCounts.cs b/src/Lucene.Net.Facet/Range/LongRangeFacetCounts.cs
index 7d5954e..81debc7 100644
--- a/src/Lucene.Net.Facet/Range/LongRangeFacetCounts.cs
+++ b/src/Lucene.Net.Facet/Range/LongRangeFacetCounts.cs
@@ -31,7 +31,7 @@ namespace Lucene.Net.Facet.Range
     /// <summary>
     /// <see cref="Facets"/> implementation that computes counts for
     /// dynamic long ranges from a provided <see cref="ValueSource"/>,
-    /// using <see cref="FunctionValues.LongVal(int)"/> or <see cref="FunctionValues.LongVal(int, long[])"/>.  Use
+    /// using <see cref="FunctionValues.Int64Val(int)"/> or <see cref="FunctionValues.Int64Val(int, long[])"/>.  Use
     /// this for dimensions that change in real-time (e.g. a
     /// relative time based dimension like "Past day", "Past 2
     /// days", etc.) or that change for each request (e.g. 
@@ -120,7 +120,7 @@ namespace Lucene.Net.Facet.Range
                     // Skip missing docs:
                     if (fv.Exists(doc))
                     {
-                        counter.Add(fv.LongVal(doc));
+                        counter.Add(fv.Int64Val(doc));
                     }
                     else
                     {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/ec70857f/src/Lucene.Net.Queries/Function/BoostedQuery.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/BoostedQuery.cs b/src/Lucene.Net.Queries/Function/BoostedQuery.cs
index 1cd591e..a82f01b 100644
--- a/src/Lucene.Net.Queries/Function/BoostedQuery.cs
+++ b/src/Lucene.Net.Queries/Function/BoostedQuery.cs
@@ -134,7 +134,7 @@ namespace Lucene.Net.Queries.Function
                     return subQueryExpl;
                 }
                 FunctionValues vals = outerInstance.boostVal.GetValues(fcontext, readerContext);
-                float sc = subQueryExpl.Value * vals.FloatVal(doc);
+                float sc = subQueryExpl.Value * vals.SingleVal(doc);
                 Explanation res = new ComplexExplanation(true, sc, outerInstance.ToString() + ", product of:");
                 res.AddDetail(subQueryExpl);
                 res.AddDetail(vals.Explain(doc));
@@ -180,7 +180,7 @@ namespace Lucene.Net.Queries.Function
 
             public override float GetScore()
             {
-                float score = qWeight * scorer.GetScore() * vals.FloatVal(scorer.DocID);
+                float score = qWeight * scorer.GetScore() * vals.SingleVal(scorer.DocID);
 
                 // Current Lucene priority queues can't handle NaN and -Infinity, so
                 // map to -Float.MAX_VALUE. This conditional handles both -infinity
@@ -205,7 +205,7 @@ namespace Lucene.Net.Queries.Function
                 {
                     return subQueryExpl;
                 }
-                float sc = subQueryExpl.Value * vals.FloatVal(doc);
+                float sc = subQueryExpl.Value * vals.SingleVal(doc);
                 Explanation res = new ComplexExplanation(true, sc, outerInstance.ToString() + ", product of:");
                 res.AddDetail(subQueryExpl);
                 res.AddDetail(vals.Explain(doc));

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/ec70857f/src/Lucene.Net.Queries/Function/DocValues/BoolDocValues.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/DocValues/BoolDocValues.cs b/src/Lucene.Net.Queries/Function/DocValues/BoolDocValues.cs
index 2efbd85..233d55e 100644
--- a/src/Lucene.Net.Queries/Function/DocValues/BoolDocValues.cs
+++ b/src/Lucene.Net.Queries/Function/DocValues/BoolDocValues.cs
@@ -40,22 +40,34 @@ namespace Lucene.Net.Queries.Function.DocValues
             return BoolVal(doc) ? (byte)1 : (byte)0;
         }
 
-        public override short ShortVal(int doc)
+        /// <summary>
+        /// NOTE: This was shortVal() in Lucene
+        /// </summary>
+        public override short Int16Val(int doc)
         {
             return BoolVal(doc) ? (short)1 : (short)0;
         }
 
-        public override float FloatVal(int doc)
+        /// <summary>
+        /// NOTE: This was floatVal() in Lucene
+        /// </summary>
+        public override float SingleVal(int doc)
         {
             return BoolVal(doc) ? 1f : 0f;
         }
 
-        public override int IntVal(int doc)
+        /// <summary>
+        /// NOTE: This was intVal() in Lucene
+        /// </summary>
+        public override int Int32Val(int doc)
         {
             return BoolVal(doc) ? 1 : 0;
         }
 
-        public override long LongVal(int doc)
+        /// <summary>
+        /// NOTE: This was longVal() in Lucene
+        /// </summary>
+        public override long Int64Val(int doc)
         {
             return BoolVal(doc) ? 1 : 0;
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/ec70857f/src/Lucene.Net.Queries/Function/DocValues/DoubleDocValues.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/DocValues/DoubleDocValues.cs b/src/Lucene.Net.Queries/Function/DocValues/DoubleDocValues.cs
index 03bc61c..98e6b67 100644
--- a/src/Lucene.Net.Queries/Function/DocValues/DoubleDocValues.cs
+++ b/src/Lucene.Net.Queries/Function/DocValues/DoubleDocValues.cs
@@ -39,22 +39,34 @@ namespace Lucene.Net.Queries.Function.DocValues
             return (byte)DoubleVal(doc);
         }
 
-        public override short ShortVal(int doc)
+        /// <summary>
+        /// NOTE: This was shortVal() in Lucene
+        /// </summary>
+        public override short Int16Val(int doc)
         {
             return (short)DoubleVal(doc);
         }
 
-        public override float FloatVal(int doc)
+        /// <summary>
+        /// NOTE: This was floatVal() in Lucene
+        /// </summary>
+        public override float SingleVal(int doc)
         {
             return (float)DoubleVal(doc);
         }
 
-        public override int IntVal(int doc)
+        /// <summary>
+        /// NOTE: This was intVal() in Lucene
+        /// </summary>
+        public override int Int32Val(int doc)
         {
             return (int)DoubleVal(doc);
         }
 
-        public override long LongVal(int doc)
+        /// <summary>
+        /// NOTE: This was longVal() in Lucene
+        /// </summary>
+        public override long Int64Val(int doc)
         {
             return (long)DoubleVal(doc);
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/ec70857f/src/Lucene.Net.Queries/Function/DocValues/FloatDocValues.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/DocValues/FloatDocValues.cs b/src/Lucene.Net.Queries/Function/DocValues/FloatDocValues.cs
index a0927af..6b0d93d 100644
--- a/src/Lucene.Net.Queries/Function/DocValues/FloatDocValues.cs
+++ b/src/Lucene.Net.Queries/Function/DocValues/FloatDocValues.cs
@@ -22,7 +22,7 @@ namespace Lucene.Net.Queries.Function.DocValues
 
     /// <summary>
     /// Abstract <see cref="FunctionValues"/> implementation which supports retrieving <see cref="float"/> values.
-    /// Implementations can control how the <see cref="float"/> values are loaded through <see cref="FloatVal(int)"/>
+    /// Implementations can control how the <see cref="float"/> values are loaded through <see cref="SingleVal(int)"/>
     /// </summary>
     public abstract class FloatDocValues : FunctionValues
     {
@@ -35,39 +35,51 @@ namespace Lucene.Net.Queries.Function.DocValues
 
         public override byte ByteVal(int doc)
         {
-            return (byte)FloatVal(doc);
+            return (byte)SingleVal(doc);
         }
 
-        public override short ShortVal(int doc)
+        /// <summary>
+        /// NOTE: This was shortVal() in Lucene
+        /// </summary>
+        public override short Int16Val(int doc)
         {
-            return (short)FloatVal(doc);
+            return (short)SingleVal(doc);
         }
 
-        public override abstract float FloatVal(int doc);
+        /// <summary>
+        /// NOTE: This was floatVal() in Lucene
+        /// </summary>
+        public override abstract float SingleVal(int doc);
 
-        public override int IntVal(int doc)
+        /// <summary>
+        /// NOTE: This was intVal() in Lucene
+        /// </summary>
+        public override int Int32Val(int doc)
         {
-            return (int)FloatVal(doc);
+            return (int)SingleVal(doc);
         }
 
-        public override long LongVal(int doc)
+        /// <summary>
+        /// NOTE: This was longVal() in Lucene
+        /// </summary>
+        public override long Int64Val(int doc)
         {
-            return (long)FloatVal(doc);
+            return (long)SingleVal(doc);
         }
 
         public override double DoubleVal(int doc)
         {
-            return (double)FloatVal(doc);
+            return (double)SingleVal(doc);
         }
 
         public override string StrVal(int doc)
         {
-            return Convert.ToString(FloatVal(doc));
+            return Convert.ToString(SingleVal(doc));
         }
 
         public override object ObjectVal(int doc)
         {
-            return Exists(doc) ? FloatVal(doc) : (float?)null;
+            return Exists(doc) ? SingleVal(doc) : (float?)null;
         }
 
         public override string ToString(int doc)
@@ -102,7 +114,7 @@ namespace Lucene.Net.Queries.Function.DocValues
 
             public override void FillValue(int doc)
             {
-                mval.Value = outerInstance.FloatVal(doc);
+                mval.Value = outerInstance.SingleVal(doc);
                 mval.Exists = outerInstance.Exists(doc);
             }
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/ec70857f/src/Lucene.Net.Queries/Function/DocValues/IntDocValues.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/DocValues/IntDocValues.cs b/src/Lucene.Net.Queries/Function/DocValues/IntDocValues.cs
index a8c1f3b..1b78344 100644
--- a/src/Lucene.Net.Queries/Function/DocValues/IntDocValues.cs
+++ b/src/Lucene.Net.Queries/Function/DocValues/IntDocValues.cs
@@ -23,7 +23,7 @@ namespace Lucene.Net.Queries.Function.DocValues
 
     /// <summary>
     /// Abstract <see cref="FunctionValues"/> implementation which supports retrieving <see cref="int"/> values.
-    /// Implementations can control how the <see cref="int"/> values are loaded through <see cref="IntVal(int)"/>
+    /// Implementations can control how the <see cref="int"/> values are loaded through <see cref="Int32Val(int)"/>
     /// </summary>
     public abstract class IntDocValues : FunctionValues
     {
@@ -36,39 +36,51 @@ namespace Lucene.Net.Queries.Function.DocValues
 
         public override byte ByteVal(int doc)
         {
-            return (byte)IntVal(doc);
+            return (byte)Int32Val(doc);
         }
 
-        public override short ShortVal(int doc)
+        /// <summary>
+        /// NOTE: This was shortVal() in Lucene
+        /// </summary>
+        public override short Int16Val(int doc)
         {
-            return (short)IntVal(doc);
+            return (short)Int32Val(doc);
         }
 
-        public override float FloatVal(int doc)
+        /// <summary>
+        /// NOTE: This was floatVal() in Lucene
+        /// </summary>
+        public override float SingleVal(int doc)
         {
-            return (float)IntVal(doc);
+            return (float)Int32Val(doc);
         }
 
-        public override abstract int IntVal(int doc);
+        /// <summary>
+        /// NOTE: This was intVal() in Lucene
+        /// </summary>
+        public override abstract int Int32Val(int doc);
 
-        public override long LongVal(int doc)
+        /// <summary>
+        /// NOTE: This was longVal() in Lucene
+        /// </summary>
+        public override long Int64Val(int doc)
         {
-            return (long)IntVal(doc);
+            return (long)Int32Val(doc);
         }
 
         public override double DoubleVal(int doc)
         {
-            return (double)IntVal(doc);
+            return (double)Int32Val(doc);
         }
 
         public override string StrVal(int doc)
         {
-            return Convert.ToString(IntVal(doc));
+            return Convert.ToString(Int32Val(doc));
         }
 
         public override object ObjectVal(int doc)
         {
-            return Exists(doc) ? IntVal(doc) : (int?)null;
+            return Exists(doc) ? Int32Val(doc) : (int?)null;
         }
 
         public override string ToString(int doc)
@@ -131,7 +143,7 @@ namespace Lucene.Net.Queries.Function.DocValues
 
             public override bool MatchesValue(int doc)
             {
-                int val = outerInstance.IntVal(doc);
+                int val = outerInstance.Int32Val(doc);
                 // only check for deleted if it's the default value
                 // if (val==0 && reader.isDeleted(doc)) return false;
                 return val >= ll && val <= uu;
@@ -165,7 +177,7 @@ namespace Lucene.Net.Queries.Function.DocValues
 
             public override void FillValue(int doc)
             {
-                mval.Value = outerInstance.IntVal(doc);
+                mval.Value = outerInstance.Int32Val(doc);
                 mval.Exists = outerInstance.Exists(doc);
             }
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/ec70857f/src/Lucene.Net.Queries/Function/DocValues/LongDocValues.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/DocValues/LongDocValues.cs b/src/Lucene.Net.Queries/Function/DocValues/LongDocValues.cs
index 081d710..851db41 100644
--- a/src/Lucene.Net.Queries/Function/DocValues/LongDocValues.cs
+++ b/src/Lucene.Net.Queries/Function/DocValues/LongDocValues.cs
@@ -23,7 +23,7 @@ namespace Lucene.Net.Queries.Function.DocValues
 
     /// <summary>
     /// Abstract <see cref="FunctionValues"/> implementation which supports retrieving <see cref="long"/> values.
-    /// Implementations can control how the <see cref="long"/> values are loaded through <see cref="LongVal(int)"/>
+    /// Implementations can control how the <see cref="long"/> values are loaded through <see cref="Int64Val(int)"/>
     /// </summary>
     public abstract class LongDocValues : FunctionValues
     {
@@ -36,44 +36,53 @@ namespace Lucene.Net.Queries.Function.DocValues
 
         public override byte ByteVal(int doc)
         {
-            return (byte)LongVal(doc);
+            return (byte)Int64Val(doc);
         }
 
-        public override short ShortVal(int doc)
+        /// <summary>
+        /// NOTE: This was shortVal() in Lucene
+        /// </summary>
+        public override short Int16Val(int doc)
         {
-            return (short)LongVal(doc);
+            return (short)Int64Val(doc);
         }
 
-        public override float FloatVal(int doc)
+        /// <summary>
+        /// NOTE: This was floatVal() in Lucene
+        /// </summary>
+        public override float SingleVal(int doc)
         {
-            return (float)LongVal(doc);
+            return (float)Int64Val(doc);
         }
 
-        public override int IntVal(int doc)
+        /// <summary>
+        /// NOTE: This was intVal() in Lucene
+        /// </summary>
+        public override int Int32Val(int doc)
         {
-            return (int)LongVal(doc);
+            return (int)Int64Val(doc);
         }
 
-        public override abstract long LongVal(int doc);
+        public override abstract long Int64Val(int doc);
 
         public override double DoubleVal(int doc)
         {
-            return (double)LongVal(doc);
+            return (double)Int64Val(doc);
         }
 
         public override bool BoolVal(int doc)
         {
-            return LongVal(doc) != 0;
+            return Int64Val(doc) != 0;
         }
 
         public override string StrVal(int doc)
         {
-            return Convert.ToString(LongVal(doc));
+            return Convert.ToString(Int64Val(doc));
         }
 
         public override object ObjectVal(int doc)
         {
-            return Exists(doc) ? LongVal(doc) : (long?)null;
+            return Exists(doc) ? Int64Val(doc) : (long?)null;
         }
 
         public override string ToString(int doc)
@@ -81,7 +90,10 @@ namespace Lucene.Net.Queries.Function.DocValues
             return m_vs.GetDescription() + '=' + StrVal(doc);
         }
 
-        protected virtual long ExternalToLong(string extVal)
+        /// <summary>
+        /// NOTE: This was externalToLong() in Lucene
+        /// </summary>
+        protected virtual long ExternalToInt64(string extVal)
         {
             return Convert.ToInt64(extVal);
         }
@@ -98,7 +110,7 @@ namespace Lucene.Net.Queries.Function.DocValues
             }
             else
             {
-                lower = ExternalToLong(lowerVal);
+                lower = ExternalToInt64(lowerVal);
                 if (!includeLower && lower < long.MaxValue)
                 {
                     lower++;
@@ -111,7 +123,7 @@ namespace Lucene.Net.Queries.Function.DocValues
             }
             else
             {
-                upper = ExternalToLong(upperVal);
+                upper = ExternalToInt64(upperVal);
                 if (!includeUpper && upper > long.MinValue)
                 {
                     upper--;
@@ -141,7 +153,7 @@ namespace Lucene.Net.Queries.Function.DocValues
 
             public override bool MatchesValue(int doc)
             {
-                long val = outerInstance.LongVal(doc);
+                long val = outerInstance.Int64Val(doc);
                 // only check for deleted if it's the default value
                 // if (val==0 && reader.isDeleted(doc)) return false;
                 return val >= ll && val <= uu;
@@ -175,7 +187,7 @@ namespace Lucene.Net.Queries.Function.DocValues
 
             public override void FillValue(int doc)
             {
-                mval.Value = outerInstance.LongVal(doc);
+                mval.Value = outerInstance.Int64Val(doc);
                 mval.Exists = outerInstance.Exists(doc);
             }
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/ec70857f/src/Lucene.Net.Queries/Function/FunctionQuery.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/FunctionQuery.cs b/src/Lucene.Net.Queries/Function/FunctionQuery.cs
index a82ec72..10a16fc 100644
--- a/src/Lucene.Net.Queries/Function/FunctionQuery.cs
+++ b/src/Lucene.Net.Queries/Function/FunctionQuery.cs
@@ -166,7 +166,7 @@ namespace Lucene.Net.Queries.Function
 
             public override float GetScore()
             {
-                float score = qWeight * vals.FloatVal(doc);
+                float score = qWeight * vals.SingleVal(doc);
 
                 // Current Lucene priority queues can't handle NaN and -Infinity, so
                 // map to -Float.MAX_VALUE. This conditional handles both -infinity
@@ -186,7 +186,7 @@ namespace Lucene.Net.Queries.Function
 
             public virtual Explanation Explain(int d)
             {
-                float sc = qWeight * vals.FloatVal(d);
+                float sc = qWeight * vals.SingleVal(d);
 
                 Explanation result = new ComplexExplanation(true, sc, "FunctionQuery(" + outerInstance.func + "), product of:");
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/ec70857f/src/Lucene.Net.Queries/Function/FunctionValues.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/FunctionValues.cs b/src/Lucene.Net.Queries/Function/FunctionValues.cs
index 4ead9c8..d2f4063 100644
--- a/src/Lucene.Net.Queries/Function/FunctionValues.cs
+++ b/src/Lucene.Net.Queries/Function/FunctionValues.cs
@@ -41,22 +41,34 @@ namespace Lucene.Net.Queries.Function
             throw new System.NotSupportedException();
         }
 
-        public virtual short ShortVal(int doc) // LUCENENET TODO: Rename Int16Val ?
+        /// <summary>
+        /// NOTE: This was shortVal() in Lucene
+        /// </summary>
+        public virtual short Int16Val(int doc) 
         {
             throw new System.NotSupportedException();
         }
 
-        public virtual float FloatVal(int doc) // LUCENENET TODO: Rename SingleVal ?
+        /// <summary>
+        /// NOTE: This was floatVal() in Lucene
+        /// </summary>
+        public virtual float SingleVal(int doc)
         {
             throw new System.NotSupportedException();
         }
 
-        public virtual int IntVal(int doc) // LUCENENET TODO: Rename Int32Val ?
+        /// <summary>
+        /// NOTE: This was intVal() in Lucene
+        /// </summary>
+        public virtual int Int32Val(int doc)
         {
             throw new System.NotSupportedException();
         }
 
-        public virtual long LongVal(int doc) // LUCENENET TODO: Rename Int64Val ?
+        /// <summary>
+        /// NOTE: This was longVal() in Lucene
+        /// </summary>
+        public virtual long Int64Val(int doc)
         {
             throw new System.NotSupportedException();
         }
@@ -74,7 +86,7 @@ namespace Lucene.Net.Queries.Function
 
         public virtual bool BoolVal(int doc)
         {
-            return IntVal(doc) != 0;
+            return Int32Val(doc) != 0;
         }
 
         /// <summary>
@@ -96,7 +108,7 @@ namespace Lucene.Net.Queries.Function
         public virtual object ObjectVal(int doc)
         {
             // most FunctionValues are functions, so by default return a Float()
-            return FloatVal(doc);
+            return SingleVal(doc);
         }
 
         /// <summary>
@@ -167,7 +179,7 @@ namespace Lucene.Net.Queries.Function
 
             public override void FillValue(int doc)
             {
-                mval.Value = outerInstance.FloatVal(doc);
+                mval.Value = outerInstance.SingleVal(doc);
             }
         }
 
@@ -177,22 +189,34 @@ namespace Lucene.Net.Queries.Function
             throw new System.NotSupportedException();
         }
 
-        public virtual void ShortVal(int doc, short[] vals) // LUCENENET TODO: Rename Int16Val ?
+        /// <summary>
+        /// NOTE: This was shortVal() in Lucene
+        /// </summary>
+        public virtual void Int16Val(int doc, short[] vals)
         {
             throw new System.NotSupportedException();
         }
 
-        public virtual void FloatVal(int doc, float[] vals) // LUCENENET TODO: Rename SingleVal ?
+        /// <summary>
+        /// NOTE: This was floatVal() in Lucene
+        /// </summary>
+        public virtual void SingleVal(int doc, float[] vals)
         {
             throw new System.NotSupportedException();
         }
 
-        public virtual void IntVal(int doc, int[] vals) // LUCENENET TODO: Rename Int32Val ?
+        /// <summary>
+        /// NOTE: This was intVal() in Lucene
+        /// </summary>
+        public virtual void Int32Val(int doc, int[] vals)
         {
             throw new System.NotSupportedException();
         }
 
-        public virtual void LongVal(int doc, long[] vals) // LUCENENET TODO: Rename Int64Val ?
+        /// <summary>
+        /// NOTE: This was longVal() in Lucene
+        /// </summary>
+        public virtual void Int64Val(int doc, long[] vals)
         {
             throw new System.NotSupportedException();
         }
@@ -210,7 +234,7 @@ namespace Lucene.Net.Queries.Function
 
         public virtual Explanation Explain(int doc)
         {
-            return new Explanation(FloatVal(doc), ToString(doc));
+            return new Explanation(SingleVal(doc), ToString(doc));
         }
 
         public virtual ValueSourceScorer GetScorer(IndexReader reader)
@@ -284,7 +308,7 @@ namespace Lucene.Net.Queries.Function
 
             public override bool MatchesValue(int doc)
             {
-                float docVal = outerInstance.FloatVal(doc);
+                float docVal = outerInstance.SingleVal(doc);
                 return docVal >= l && docVal <= u;
             }
         }
@@ -307,7 +331,7 @@ namespace Lucene.Net.Queries.Function
 
             public override bool MatchesValue(int doc)
             {
-                float docVal = outerInstance.FloatVal(doc);
+                float docVal = outerInstance.SingleVal(doc);
                 return docVal >= l && docVal < u;
             }
         }
@@ -330,7 +354,7 @@ namespace Lucene.Net.Queries.Function
 
             public override bool MatchesValue(int doc)
             {
-                float docVal = outerInstance.FloatVal(doc);
+                float docVal = outerInstance.SingleVal(doc);
                 return docVal > l && docVal <= u;
             }
         }
@@ -353,7 +377,7 @@ namespace Lucene.Net.Queries.Function
 
             public override bool MatchesValue(int doc)
             {
-                float docVal = outerInstance.FloatVal(doc);
+                float docVal = outerInstance.SingleVal(doc);
                 return docVal > l && docVal < u;
             }
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/ec70857f/src/Lucene.Net.Queries/Function/ValueSourceScorer.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSourceScorer.cs b/src/Lucene.Net.Queries/Function/ValueSourceScorer.cs
index cd2f0a7..1702ecf 100644
--- a/src/Lucene.Net.Queries/Function/ValueSourceScorer.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSourceScorer.cs
@@ -22,7 +22,7 @@ namespace Lucene.Net.Queries.Function
      */
     
     /// <summary>
-    /// <see cref="Scorer"/> which returns the result of <see cref="FunctionValues.FloatVal(int)"/> as
+    /// <see cref="Scorer"/> which returns the result of <see cref="FunctionValues.SingleVal(int)"/> as
     /// the score for a document.
     /// </summary>
     public class ValueSourceScorer : Scorer
@@ -97,7 +97,7 @@ namespace Lucene.Net.Queries.Function
 
         public override float GetScore()
         {
-            return m_values.FloatVal(doc);
+            return m_values.SingleVal(doc);
         }
 
         public override int Freq

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/ec70857f/src/Lucene.Net.Queries/Function/ValueSources/ByteFieldSource.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/ByteFieldSource.cs b/src/Lucene.Net.Queries/Function/ValueSources/ByteFieldSource.cs
index e915d36..f9cecc2 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/ByteFieldSource.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/ByteFieldSource.cs
@@ -71,22 +71,34 @@ namespace Lucene.Net.Queries.Function.ValueSources
                 return (byte)arr.Get(doc);
             }
 
-            public override short ShortVal(int doc)
+            /// <summary>
+            /// NOTE: This was shortVal() in Lucene
+            /// </summary>
+            public override short Int16Val(int doc)
             {
                 return (short)arr.Get(doc);
             }
 
-            public override float FloatVal(int doc)
+            /// <summary>
+            /// NOTE: This was floatVal() in Lucene
+            /// </summary>
+            public override float SingleVal(int doc)
             {
                 return (float)arr.Get(doc);
             }
 
-            public override int IntVal(int doc)
+            /// <summary>
+            /// NOTE: This was intVal() in Lucene
+            /// </summary>
+            public override int Int32Val(int doc)
             {
                 return (int)arr.Get(doc);
             }
 
-            public override long LongVal(int doc)
+            /// <summary>
+            /// NOTE: This was longVal() in Lucene
+            /// </summary>
+            public override long Int64Val(int doc)
             {
                 return (long)arr.Get(doc);
             }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/ec70857f/src/Lucene.Net.Queries/Function/ValueSources/ConstNumberSource.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/ConstNumberSource.cs b/src/Lucene.Net.Queries/Function/ValueSources/ConstNumberSource.cs
index 90edc0a..3a33ae7 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/ConstNumberSource.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/ConstNumberSource.cs
@@ -22,9 +22,20 @@
     /// </summary>
     public abstract class ConstNumberSource : ValueSource
     {
-        public abstract int Int { get; } // LUCENENET TODO: Rename Int32?
-        public abstract long Long { get; } // LUCENENET TODO: Rename Int64?
-        public abstract float Float { get; } // LUCENENET TODO: Rename Single?
+        /// <summary>
+        /// NOTE: This was getInt() in Lucene
+        /// </summary>
+        public abstract int Int32 { get; }
+
+        /// <summary>
+        /// NOTE: This was getLong() in Lucene
+        /// </summary>
+        public abstract long Int64 { get; }
+
+        /// <summary>
+        /// NOTE: This was getFloat() in Lucene
+        /// </summary>
+        public abstract float Single { get; }
         public abstract double Double { get; }
         //public abstract Number Number { get; }
         public abstract bool Bool { get; }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/ec70857f/src/Lucene.Net.Queries/Function/ValueSources/ConstValueSource.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/ConstValueSource.cs b/src/Lucene.Net.Queries/Function/ValueSources/ConstValueSource.cs
index bd9a8aa..a9bd1b5 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/ConstValueSource.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/ConstValueSource.cs
@@ -56,15 +56,26 @@ namespace Lucene.Net.Queries.Function.ValueSources
                 this.outerInstance = outerInstance;
             }
 
-            public override float FloatVal(int doc)
+            /// <summary>
+            /// NOTE: This was floatVal() in Lucene
+            /// </summary>
+            public override float SingleVal(int doc)
             {
                 return outerInstance.constant;
             }
-            public override int IntVal(int doc)
+
+            /// <summary>
+            /// NOTE: This was intVal() in Lucene
+            /// </summary>
+            public override int Int32Val(int doc)
             {
                 return (int)outerInstance.constant;
             }
-            public override long LongVal(int doc)
+
+            /// <summary>
+            /// NOTE: This was longVal() in Lucene
+            /// </summary>
+            public override long Int64Val(int doc)
             {
                 return (long)outerInstance.constant;
             }
@@ -101,7 +112,10 @@ namespace Lucene.Net.Queries.Function.ValueSources
             return this.constant == other.constant;
         }
 
-        public override int Int
+        /// <summary>
+        /// NOTE: This was getInt() in Lucene
+        /// </summary>
+        public override int Int32
         {
             get
             {
@@ -109,7 +123,10 @@ namespace Lucene.Net.Queries.Function.ValueSources
             }
         }
 
-        public override long Long
+        /// <summary>
+        /// NOTE: This was getLong() in Lucene
+        /// </summary>
+        public override long Int64
         {
             get
             {
@@ -117,7 +134,10 @@ namespace Lucene.Net.Queries.Function.ValueSources
             }
         }
 
-        public override float Float
+        /// <summary>
+        /// NOTE: This was getFloat() in Lucene
+        /// </summary>
+        public override float Single
         {
             get
             {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/ec70857f/src/Lucene.Net.Queries/Function/ValueSources/DefFunction.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/DefFunction.cs b/src/Lucene.Net.Queries/Function/ValueSources/DefFunction.cs
index 9f3aba2..e0d1115 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/DefFunction.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/DefFunction.cs
@@ -77,24 +77,36 @@ namespace Lucene.Net.Queries.Function.ValueSources
                 return Get(doc).ByteVal(doc);
             }
 
-            public override short ShortVal(int doc)
+            /// <summary>
+            /// NOTE: This was shortVal() in Lucene
+            /// </summary>
+            public override short Int16Val(int doc)
             {
-                return Get(doc).ShortVal(doc);
+                return Get(doc).Int16Val(doc);
             }
 
-            public override float FloatVal(int doc)
+            /// <summary>
+            /// NOTE: This was floatVal() in Lucene
+            /// </summary>
+            public override float SingleVal(int doc)
             {
-                return Get(doc).FloatVal(doc);
+                return Get(doc).SingleVal(doc);
             }
 
-            public override int IntVal(int doc)
+            /// <summary>
+            /// NOTE: This was intVal() in Lucene
+            /// </summary>
+            public override int Int32Val(int doc)
             {
-                return Get(doc).IntVal(doc);
+                return Get(doc).Int32Val(doc);
             }
 
-            public override long LongVal(int doc)
+            /// <summary>
+            /// NOTE: This was longVal() in Lucene
+            /// </summary>
+            public override long Int64Val(int doc)
             {
-                return Get(doc).LongVal(doc);
+                return Get(doc).Int64Val(doc);
             }
 
             public override double DoubleVal(int doc)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/ec70857f/src/Lucene.Net.Queries/Function/ValueSources/DivFloatFunction.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/DivFloatFunction.cs b/src/Lucene.Net.Queries/Function/ValueSources/DivFloatFunction.cs
index d52340d..1ee5d96 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/DivFloatFunction.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/DivFloatFunction.cs
@@ -36,7 +36,7 @@
 
         protected override float Func(int doc, FunctionValues aVals, FunctionValues bVals)
         {
-            return aVals.FloatVal(doc) / bVals.FloatVal(doc);
+            return aVals.SingleVal(doc) / bVals.SingleVal(doc);
         }
     }
 }
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/ec70857f/src/Lucene.Net.Queries/Function/ValueSources/DocFreqValueSource.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/DocFreqValueSource.cs b/src/Lucene.Net.Queries/Function/ValueSources/DocFreqValueSource.cs
index fd29bf4..5e46da2 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/DocFreqValueSource.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/DocFreqValueSource.cs
@@ -44,15 +44,26 @@ namespace Lucene.Net.Queries.Function.ValueSources
             this.parent = parent;
         }
 
-        public override float FloatVal(int doc)
+        /// <summary>
+        /// NOTE: This was floatVal() in Lucene
+        /// </summary>
+        public override float SingleVal(int doc)
         {
             return fval;
         }
-        public override int IntVal(int doc)
+
+        /// <summary>
+        /// NOTE: This was intVal() in Lucene
+        /// </summary>
+        public override int Int32Val(int doc)
         {
             return ival;
         }
-        public override long LongVal(int doc)
+
+        /// <summary>
+        /// NOTE: This was longVal() in Lucene
+        /// </summary>
+        public override long Int64Val(int doc)
         {
             return lval;
         }
@@ -90,15 +101,26 @@ namespace Lucene.Net.Queries.Function.ValueSources
             this.parent = parent;
         }
 
-        public override float FloatVal(int doc)
+        /// <summary>
+        /// NOTE: This was floatVal() in Lucene
+        /// </summary>
+        public override float SingleVal(int doc)
         {
             return fval;
         }
-        public override int IntVal(int doc)
+
+        /// <summary>
+        /// NOTE: This was intVal() in Lucene
+        /// </summary>
+        public override int Int32Val(int doc)
         {
             return ival;
         }
-        public override long LongVal(int doc)
+
+        /// <summary>
+        /// NOTE: This was longVal() in Lucene
+        /// </summary>
+        public override long Int64Val(int doc)
         {
             return lval;
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/ec70857f/src/Lucene.Net.Queries/Function/ValueSources/DoubleConstValueSource.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/DoubleConstValueSource.cs b/src/Lucene.Net.Queries/Function/ValueSources/DoubleConstValueSource.cs
index 73407ae..618205d 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/DoubleConstValueSource.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/DoubleConstValueSource.cs
@@ -58,17 +58,26 @@ namespace Lucene.Net.Queries.Function.ValueSources
                 this.outerInstance = outerInstance;
             }
 
-            public override float FloatVal(int doc)
+            /// <summary>
+            /// NOTE: This was floatVal() in Lucene
+            /// </summary>
+            public override float SingleVal(int doc)
             {
                 return outerInstance.fv;
             }
 
-            public override int IntVal(int doc)
+            /// <summary>
+            /// NOTE: This was intVal() in Lucene
+            /// </summary>
+            public override int Int32Val(int doc)
             {
                 return (int)outerInstance.lv;
             }
 
-            public override long LongVal(int doc)
+            /// <summary>
+            /// NOTE: This was longVal() in Lucene
+            /// </summary>
+            public override long Int64Val(int doc)
             {
                 return outerInstance.lv;
             }
@@ -110,7 +119,10 @@ namespace Lucene.Net.Queries.Function.ValueSources
             return this.constant == other.constant;
         }
 
-        public override int Int
+        /// <summary>
+        /// NOTE: This was getInt() in Lucene
+        /// </summary>
+        public override int Int32
         {
             get
             {
@@ -118,7 +130,10 @@ namespace Lucene.Net.Queries.Function.ValueSources
             }
         }
 
-        public override long Long
+        /// <summary>
+        /// NOTE: This was getLong() in Lucene
+        /// </summary>
+        public override long Int64
         {
             get
             {
@@ -126,7 +141,10 @@ namespace Lucene.Net.Queries.Function.ValueSources
             }
         }
 
-        public override float Float
+        /// <summary>
+        /// NOTE: This was getFloat() in Lucene
+        /// </summary>
+        public override float Single
         {
             get
             {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/ec70857f/src/Lucene.Net.Queries/Function/ValueSources/DualFloatFunction.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/DualFloatFunction.cs b/src/Lucene.Net.Queries/Function/ValueSources/DualFloatFunction.cs
index 0b46252..7d43753 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/DualFloatFunction.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/DualFloatFunction.cs
@@ -69,7 +69,10 @@ namespace Lucene.Net.Queries.Function.ValueSources
                 this.bVals = bVals;
             }
 
-            public override float FloatVal(int doc)
+            /// <summary>
+            /// NOTE: This was floatVal() in Lucene
+            /// </summary>
+            public override float SingleVal(int doc)
             {
                 return outerInstance.Func(doc, aVals, bVals);
             }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/ec70857f/src/Lucene.Net.Queries/Function/ValueSources/EnumFieldSource.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/EnumFieldSource.cs b/src/Lucene.Net.Queries/Function/ValueSources/EnumFieldSource.cs
index a642ab8..747c0b4 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/EnumFieldSource.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/EnumFieldSource.cs
@@ -48,7 +48,10 @@ namespace Lucene.Net.Queries.Function.ValueSources
             this.enumStringToIntMap = enumStringToIntMap;
         }
 
-        private static int? TryParseInt(string valueStr) // LUCENENET TODO: Rename TryParseInt32 ?
+        /// <summary>
+        /// NOTE: This was tryParseInt() in Lucene
+        /// </summary>
+        private static int? TryParseInt32(string valueStr) 
         {
             int? intValue = null;
             try
@@ -61,7 +64,10 @@ namespace Lucene.Net.Queries.Function.ValueSources
             return intValue;
         }
 
-        private string IntValueToStringValue(int? intVal) // LUCENENET TODO: Rename Int32ToStringValue ?
+        /// <summary>
+        /// NOTE: This was intValueToStringValue() in Lucene
+        /// </summary>
+        private string Int32ValueToStringValue(int? intVal)
         {
             if (intVal == null)
             {
@@ -77,7 +83,10 @@ namespace Lucene.Net.Queries.Function.ValueSources
             return DEFAULT_VALUE.ToString(CultureInfo.InvariantCulture);
         }
 
-        private int? StringValueToIntValue(string stringVal) // LUCENENET TODO: Rename StringValueToInt32Value ?
+        /// <summary>
+        /// NOTE: This was stringValueToIntValue() in Lucene
+        /// </summary>
+        private int? StringValueToInt32Value(string stringVal)
         {
             if (stringVal == null)
             {
@@ -92,7 +101,7 @@ namespace Lucene.Net.Queries.Function.ValueSources
             }
 
             //enum int not found for str
-            intValue = TryParseInt(stringVal);
+            intValue = TryParseInt32(stringVal);
             if (intValue == null) //not Integer
             {
                 intValue = DEFAULT_VALUE;
@@ -138,17 +147,26 @@ namespace Lucene.Net.Queries.Function.ValueSources
 
             private readonly MutableValueInt val;
 
-            public override float FloatVal(int doc)
+            /// <summary>
+            /// NOTE: This was floatVal() in Lucene
+            /// </summary>
+            public override float SingleVal(int doc)
             {
                 return (float)arr.Get(doc);
             }
 
-            public override int IntVal(int doc)
+            /// <summary>
+            /// NOTE: This was intVal() in Lucene
+            /// </summary>
+            public override int Int32Val(int doc)
             {
                 return arr.Get(doc);
             }
 
-            public override long LongVal(int doc)
+            /// <summary>
+            /// NOTE: This was longVal() in Lucene
+            /// </summary>
+            public override long Int64Val(int doc)
             {
                 return (long)arr.Get(doc);
             }
@@ -161,7 +179,7 @@ namespace Lucene.Net.Queries.Function.ValueSources
             public override string StrVal(int doc)
             {
                 int? intValue = arr.Get(doc);
-                return outerInstance.IntValueToStringValue(intValue);
+                return outerInstance.Int32ValueToStringValue(intValue);
             }
 
             public override object ObjectVal(int doc)
@@ -182,8 +200,8 @@ namespace Lucene.Net.Queries.Function.ValueSources
 
             public override ValueSourceScorer GetRangeScorer(IndexReader reader, string lowerVal, string upperVal, bool includeLower, bool includeUpper)
             {
-                int? lower = outerInstance.StringValueToIntValue(lowerVal);
-                int? upper = outerInstance.StringValueToIntValue(upperVal);
+                int? lower = outerInstance.StringValueToInt32Value(lowerVal);
+                int? upper = outerInstance.StringValueToInt32Value(upperVal);
 
                 // instead of using separate comparison functions, adjust the endpoints.
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/ec70857f/src/Lucene.Net.Queries/Function/ValueSources/FloatFieldSource.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/FloatFieldSource.cs b/src/Lucene.Net.Queries/Function/ValueSources/FloatFieldSource.cs
index 3207939..7a14135 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/FloatFieldSource.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/FloatFieldSource.cs
@@ -67,7 +67,10 @@ namespace Lucene.Net.Queries.Function.ValueSources
                 this.valid = valid;
             }
 
-            public override float FloatVal(int doc)
+            /// <summary>
+            /// NOTE: This was floatVal() in Lucene
+            /// </summary>
+            public override float SingleVal(int doc)
             {
                 return arr.Get(doc);
             }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/ec70857f/src/Lucene.Net.Queries/Function/ValueSources/IfFunction.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/IfFunction.cs b/src/Lucene.Net.Queries/Function/ValueSources/IfFunction.cs
index 605589e..39207eb 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/IfFunction.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/IfFunction.cs
@@ -66,24 +66,36 @@ namespace Lucene.Net.Queries.Function.ValueSources
                 return ifVals.BoolVal(doc) ? trueVals.ByteVal(doc) : falseVals.ByteVal(doc);
             }
 
-            public override short ShortVal(int doc)
+            /// <summary>
+            /// NOTE: This was shortVal() in Lucene
+            /// </summary>
+            public override short Int16Val(int doc)
             {
-                return ifVals.BoolVal(doc) ? trueVals.ShortVal(doc) : falseVals.ShortVal(doc);
+                return ifVals.BoolVal(doc) ? trueVals.Int16Val(doc) : falseVals.Int16Val(doc);
             }
 
-            public override float FloatVal(int doc)
+            /// <summary>
+            /// NOTE: This was floatVal() in Lucene
+            /// </summary>
+            public override float SingleVal(int doc)
             {
-                return ifVals.BoolVal(doc) ? trueVals.FloatVal(doc) : falseVals.FloatVal(doc);
+                return ifVals.BoolVal(doc) ? trueVals.SingleVal(doc) : falseVals.SingleVal(doc);
             }
 
-            public override int IntVal(int doc)
+            /// <summary>
+            /// NOTE: This was intVal() in Lucene
+            /// </summary>
+            public override int Int32Val(int doc)
             {
-                return ifVals.BoolVal(doc) ? trueVals.IntVal(doc) : falseVals.IntVal(doc);
+                return ifVals.BoolVal(doc) ? trueVals.Int32Val(doc) : falseVals.Int32Val(doc);
             }
 
-            public override long LongVal(int doc)
+            /// <summary>
+            /// NOTE: This was longVal() in Lucene
+            /// </summary>
+            public override long Int64Val(int doc)
             {
-                return ifVals.BoolVal(doc) ? trueVals.LongVal(doc) : falseVals.LongVal(doc);
+                return ifVals.BoolVal(doc) ? trueVals.Int64Val(doc) : falseVals.Int64Val(doc);
             }
 
             public override double DoubleVal(int doc)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/ec70857f/src/Lucene.Net.Queries/Function/ValueSources/IntFieldSource.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/IntFieldSource.cs b/src/Lucene.Net.Queries/Function/ValueSources/IntFieldSource.cs
index e4af2e0..0d81135 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/IntFieldSource.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/IntFieldSource.cs
@@ -75,17 +75,26 @@ namespace Lucene.Net.Queries.Function.ValueSources
 
             private readonly MutableValueInt val;
 
-            public override float FloatVal(int doc)
+            /// <summary>
+            /// NOTE: This was floatVal() in Lucene
+            /// </summary>
+            public override float SingleVal(int doc)
             {
                 return (float)arr.Get(doc);
             }
 
-            public override int IntVal(int doc)
+            /// <summary>
+            /// NOTE: This was intVal() in Lucene
+            /// </summary>
+            public override int Int32Val(int doc)
             {
                 return arr.Get(doc);
             }
 
-            public override long LongVal(int doc)
+            /// <summary>
+            /// NOTE: This was longVal() in Lucene
+            /// </summary>
+            public override long Int64Val(int doc)
             {
                 return (long)arr.Get(doc);
             }
@@ -112,7 +121,7 @@ namespace Lucene.Net.Queries.Function.ValueSources
 
             public override string ToString(int doc)
             {
-                return outerInstance.GetDescription() + '=' + IntVal(doc);
+                return outerInstance.GetDescription() + '=' + Int32Val(doc);
             }
 
             public override ValueFiller GetValueFiller()

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/ec70857f/src/Lucene.Net.Queries/Function/ValueSources/JoinDocFreqValueSource.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/JoinDocFreqValueSource.cs b/src/Lucene.Net.Queries/Function/ValueSources/JoinDocFreqValueSource.cs
index 19cc714..a9ce522 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/JoinDocFreqValueSource.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/JoinDocFreqValueSource.cs
@@ -75,7 +75,10 @@ namespace Lucene.Net.Queries.Function.ValueSources
 
             private readonly BytesRef @ref;
 
-            public override int IntVal(int doc)
+            /// <summary>
+            /// NOTE: This was intVal() in Lucene
+            /// </summary>
+            public override int Int32Val(int doc)
             {
                 try
                 {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/ec70857f/src/Lucene.Net.Queries/Function/ValueSources/LinearFloatFunction.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/LinearFloatFunction.cs b/src/Lucene.Net.Queries/Function/ValueSources/LinearFloatFunction.cs
index df56910..179995f 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/LinearFloatFunction.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/LinearFloatFunction.cs
@@ -65,9 +65,12 @@ namespace Lucene.Net.Queries.Function.ValueSources
                 this.vals = vals;
             }
 
-            public override float FloatVal(int doc)
+            /// <summary>
+            /// NOTE: This was floatVal() in Lucene
+            /// </summary>
+            public override float SingleVal(int doc)
             {
-                return vals.FloatVal(doc) * outerInstance.m_slope + outerInstance.m_intercept;
+                return vals.SingleVal(doc) * outerInstance.m_slope + outerInstance.m_intercept;
             }
             public override string ToString(int doc)
             {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/ec70857f/src/Lucene.Net.Queries/Function/ValueSources/LongFieldSource.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/LongFieldSource.cs b/src/Lucene.Net.Queries/Function/ValueSources/LongFieldSource.cs
index c057651..fa0ad17 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/LongFieldSource.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/LongFieldSource.cs
@@ -49,19 +49,28 @@ namespace Lucene.Net.Queries.Function.ValueSources
             return "long(" + m_field + ')';
         }
 
-        public virtual long ExternalToLong(string extVal)
+        /// <summary>
+        /// NOTE: This was externalToLong() in Lucene
+        /// </summary>
+        public virtual long ExternalToInt64(string extVal)
         {
             return Convert.ToInt64(extVal);
         }
 
-        public virtual object LongToObject(long val)
+        /// <summary>
+        /// NOTE: This was longToObject() in Lucene
+        /// </summary>
+        public virtual object Int64ToObject(long val)
         {
             return val;
         }
 
-        public virtual string LongToString(long val)
+        /// <summary>
+        /// NOTE: This was longToString() in Lucene
+        /// </summary>
+        public virtual string Int64ToString(long val)
         {
-            return LongToObject(val).ToString();
+            return Int64ToObject(val).ToString();
         }
 
         public override FunctionValues GetValues(IDictionary context, AtomicReaderContext readerContext)
@@ -86,7 +95,10 @@ namespace Lucene.Net.Queries.Function.ValueSources
                 this.valid = valid;
             }
 
-            public override long LongVal(int doc)
+            /// <summary>
+            /// NOTE: This was longVal() in Lucene
+            /// </summary>
+            public override long Int64Val(int doc)
             {
                 return arr.Get(doc);
             }
@@ -98,17 +110,20 @@ namespace Lucene.Net.Queries.Function.ValueSources
 
             public override object ObjectVal(int doc)
             {
-                return valid.Get(doc) ? outerInstance.LongToObject(arr.Get(doc)) : null;
+                return valid.Get(doc) ? outerInstance.Int64ToObject(arr.Get(doc)) : null;
             }
 
             public override string StrVal(int doc)
             {
-                return valid.Get(doc) ? outerInstance.LongToString(arr.Get(doc)) : null;
+                return valid.Get(doc) ? outerInstance.Int64ToString(arr.Get(doc)) : null;
             }
 
-            protected override long ExternalToLong(string extVal)
+            /// <summary>
+            /// NOTE: This was externalToLong() in Lucene
+            /// </summary>
+            protected override long ExternalToInt64(string extVal)
             {
-                return outerInstance.ExternalToLong(extVal);
+                return outerInstance.ExternalToInt64(extVal);
             }
 
             public override ValueFiller GetValueFiller()
@@ -123,7 +138,7 @@ namespace Lucene.Net.Queries.Function.ValueSources
                 public ValueFillerAnonymousInnerClassHelper(LongDocValuesAnonymousInnerClassHelper outerInstance)
                 {
                     this.outerInstance = outerInstance;
-                    mval = outerInstance.outerInstance.NewMutableValueLong();
+                    mval = outerInstance.outerInstance.NewMutableValueInt64();
                 }
 
                 private readonly MutableValueLong mval;
@@ -144,7 +159,10 @@ namespace Lucene.Net.Queries.Function.ValueSources
             }
         }
 
-        protected virtual MutableValueLong NewMutableValueLong()
+        /// <summary>
+        /// NOTE: This was longToString() in Lucene
+        /// </summary>
+        protected virtual MutableValueLong NewMutableValueInt64()
         {
             return new MutableValueLong();
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/ec70857f/src/Lucene.Net.Queries/Function/ValueSources/MaxFloatFunction.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/MaxFloatFunction.cs b/src/Lucene.Net.Queries/Function/ValueSources/MaxFloatFunction.cs
index 7e8913e..914df30 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/MaxFloatFunction.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/MaxFloatFunction.cs
@@ -40,7 +40,7 @@ namespace Lucene.Net.Queries.Function.ValueSources
             {
                 return 0.0f;
             }
-            return valsArr.Select(vals => vals.FloatVal(doc)).Concat(new[] {float.NegativeInfinity}).Max();
+            return valsArr.Select(vals => vals.SingleVal(doc)).Concat(new[] {float.NegativeInfinity}).Max();
         }
     }
 }
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/ec70857f/src/Lucene.Net.Queries/Function/ValueSources/MinFloatFunction.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/MinFloatFunction.cs b/src/Lucene.Net.Queries/Function/ValueSources/MinFloatFunction.cs
index ca5cf7b..83e6784 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/MinFloatFunction.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/MinFloatFunction.cs
@@ -40,7 +40,7 @@ namespace Lucene.Net.Queries.Function.ValueSources
             {
                 return 0.0f;
             }
-            return valsArr.Select(vals => vals.FloatVal(doc)).Concat(new[] {float.PositiveInfinity}).Min();
+            return valsArr.Select(vals => vals.SingleVal(doc)).Concat(new[] {float.PositiveInfinity}).Min();
         }
     }
 }
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/ec70857f/src/Lucene.Net.Queries/Function/ValueSources/MultiFloatFunction.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/MultiFloatFunction.cs b/src/Lucene.Net.Queries/Function/ValueSources/MultiFloatFunction.cs
index c3bd1c8..a4ac19c 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/MultiFloatFunction.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/MultiFloatFunction.cs
@@ -86,7 +86,10 @@ namespace Lucene.Net.Queries.Function.ValueSources
                 this.valsArr = valsArr;
             }
 
-            public override float FloatVal(int doc)
+            /// <summary>
+            /// NOTE: This was floatVal() in Lucene
+            /// </summary>
+            public override float SingleVal(int doc)
             {
                 return outerInstance.Func(doc, valsArr);
             }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/ec70857f/src/Lucene.Net.Queries/Function/ValueSources/NormValueSource.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/NormValueSource.cs b/src/Lucene.Net.Queries/Function/ValueSources/NormValueSource.cs
index a6fcd89..5fd0546 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/NormValueSource.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/NormValueSource.cs
@@ -88,7 +88,10 @@ namespace Lucene.Net.Queries.Function.ValueSources
                 this.norms = norms;
             }
 
-            public override float FloatVal(int doc)
+            /// <summary>
+            /// NOTE: This was floatVal() in Lucene
+            /// </summary>
+            public override float SingleVal(int doc)
             {
                 return similarity.DecodeNormValue(norms.Get(doc));
             }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/ec70857f/src/Lucene.Net.Queries/Function/ValueSources/OrdFieldSource.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/OrdFieldSource.cs b/src/Lucene.Net.Queries/Function/ValueSources/OrdFieldSource.cs
index cb016d7..967045f 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/OrdFieldSource.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/OrdFieldSource.cs
@@ -87,7 +87,11 @@ namespace Lucene.Net.Queries.Function.ValueSources
             {
                 return readableValue;
             }
-            public override int IntVal(int doc)
+
+            /// <summary>
+            /// NOTE: This was intVal() in Lucene
+            /// </summary>
+            public override int Int32Val(int doc)
             {
                 return sindex.GetOrd(doc + off);
             }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/ec70857f/src/Lucene.Net.Queries/Function/ValueSources/PowFloatFunction.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/PowFloatFunction.cs b/src/Lucene.Net.Queries/Function/ValueSources/PowFloatFunction.cs
index c2a8a93..8a2a10b 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/PowFloatFunction.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/PowFloatFunction.cs
@@ -38,7 +38,7 @@ namespace Lucene.Net.Queries.Function.ValueSources
 
         protected override float Func(int doc, FunctionValues aVals, FunctionValues bVals)
         {
-            return (float)Math.Pow(aVals.FloatVal(doc), bVals.FloatVal(doc));
+            return (float)Math.Pow(aVals.SingleVal(doc), bVals.SingleVal(doc));
         }
     }
 }
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/ec70857f/src/Lucene.Net.Queries/Function/ValueSources/ProductFloatFunction.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/ProductFloatFunction.cs b/src/Lucene.Net.Queries/Function/ValueSources/ProductFloatFunction.cs
index 87673f9..1fda318 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/ProductFloatFunction.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/ProductFloatFunction.cs
@@ -36,7 +36,7 @@ namespace Lucene.Net.Queries.Function.ValueSources
 
         protected override float Func(int doc, FunctionValues[] valsArr)
         {
-            return valsArr.Aggregate(1.0f, (current, vals) => current * vals.FloatVal(doc));
+            return valsArr.Aggregate(1.0f, (current, vals) => current * vals.SingleVal(doc));
         }
     }
 }
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/ec70857f/src/Lucene.Net.Queries/Function/ValueSources/QueryValueSource.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/QueryValueSource.cs b/src/Lucene.Net.Queries/Function/ValueSources/QueryValueSource.cs
index 833f72d..b11a93c 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/QueryValueSource.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/QueryValueSource.cs
@@ -139,7 +139,10 @@ namespace Lucene.Net.Queries.Function.ValueSources
             weight = w;
         }
 
-        public override float FloatVal(int doc)
+        /// <summary>
+        /// NOTE: This was floatVal() in Lucene
+        /// </summary>
+        public override float SingleVal(int doc)
         {
             try
             {
@@ -311,7 +314,7 @@ namespace Lucene.Net.Queries.Function.ValueSources
 
         public override string ToString(int doc)
         {
-            return "query(" + q + ",def=" + defVal + ")=" + FloatVal(doc);
+            return "query(" + q + ",def=" + defVal + ")=" + SingleVal(doc);
         }
     }
 }
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/ec70857f/src/Lucene.Net.Queries/Function/ValueSources/RangeMapFloatFunction.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/RangeMapFloatFunction.cs b/src/Lucene.Net.Queries/Function/ValueSources/RangeMapFloatFunction.cs
index a3f1f19..3d7ecc6 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/RangeMapFloatFunction.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/RangeMapFloatFunction.cs
@@ -81,10 +81,13 @@ namespace Lucene.Net.Queries.Function.ValueSources
                 this.defaults = defaults;
             }
 
-            public override float FloatVal(int doc)
+            /// <summary>
+            /// NOTE: This was floatVal() in Lucene
+            /// </summary>
+            public override float SingleVal(int doc)
             {
-                float val = vals.FloatVal(doc);
-                return (val >= outerInstance.m_min && val <= outerInstance.m_max) ? targets.FloatVal(doc) : (outerInstance.m_defaultVal == null ? val : defaults.FloatVal(doc));
+                float val = vals.SingleVal(doc);
+                return (val >= outerInstance.m_min && val <= outerInstance.m_max) ? targets.SingleVal(doc) : (outerInstance.m_defaultVal == null ? val : defaults.SingleVal(doc));
             }
             public override string ToString(int doc)
             {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/ec70857f/src/Lucene.Net.Queries/Function/ValueSources/ReciprocalFloatFunction.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/ReciprocalFloatFunction.cs b/src/Lucene.Net.Queries/Function/ValueSources/ReciprocalFloatFunction.cs
index 02de918..a803e8c 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/ReciprocalFloatFunction.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/ReciprocalFloatFunction.cs
@@ -74,9 +74,12 @@ namespace Lucene.Net.Queries.Function.ValueSources
                 this.vals = vals;
             }
 
-            public override float FloatVal(int doc)
+            /// <summary>
+            /// NOTE: This was floatVal() in Lucene
+            /// </summary>
+            public override float SingleVal(int doc)
             {
-                return outerInstance.m_a / (outerInstance.m_m * vals.FloatVal(doc) + outerInstance.m_b);
+                return outerInstance.m_a / (outerInstance.m_m * vals.SingleVal(doc) + outerInstance.m_b);
             }
             public override string ToString(int doc)
             {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/ec70857f/src/Lucene.Net.Queries/Function/ValueSources/ReverseOrdFieldSource.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/ReverseOrdFieldSource.cs b/src/Lucene.Net.Queries/Function/ValueSources/ReverseOrdFieldSource.cs
index 01015f4..88c9d1b 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/ReverseOrdFieldSource.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/ReverseOrdFieldSource.cs
@@ -91,7 +91,10 @@ namespace Lucene.Net.Queries.Function.ValueSources
                 this.end = end;
             }
 
-            public override int IntVal(int doc)
+            /// <summary>
+            /// NOTE: This was intVal() in Lucene
+            /// </summary>
+            public override int Int32Val(int doc)
             {
                 return (end - sindex.GetOrd(doc + off) - 1);
             }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/ec70857f/src/Lucene.Net.Queries/Function/ValueSources/ScaleFloatFunction.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/ScaleFloatFunction.cs b/src/Lucene.Net.Queries/Function/ValueSources/ScaleFloatFunction.cs
index 2be917d..ffae7c7 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/ScaleFloatFunction.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/ScaleFloatFunction.cs
@@ -72,7 +72,7 @@ namespace Lucene.Net.Queries.Function.ValueSources
                 for (int i = 0; i < maxDoc; i++)
                 {
 
-                    float val = vals.FloatVal(i);
+                    float val = vals.SingleVal(i);
                     if ((Number.SingleToRawInt32Bits(val) & (0xff << 23)) == 0xff << 23)
                     {
                         // if the exponent in the float is all ones, then this is +Inf, -Inf or NaN
@@ -137,9 +137,12 @@ namespace Lucene.Net.Queries.Function.ValueSources
                 this.vals = vals;
             }
 
-            public override float FloatVal(int doc)
+            /// <summary>
+            /// NOTE: This was floatVal() in Lucene
+            /// </summary>
+            public override float SingleVal(int doc)
             {
-                return (vals.FloatVal(doc) - minSource) * scale + outerInstance.m_min;
+                return (vals.SingleVal(doc) - minSource) * scale + outerInstance.m_min;
             }
             public override string ToString(int doc)
             {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/ec70857f/src/Lucene.Net.Queries/Function/ValueSources/ShortFieldSource.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/ShortFieldSource.cs b/src/Lucene.Net.Queries/Function/ValueSources/ShortFieldSource.cs
index 7419010..a1ef324 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/ShortFieldSource.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/ShortFieldSource.cs
@@ -70,22 +70,34 @@ namespace Lucene.Net.Queries.Function.ValueSources
                 return (byte)arr.Get(doc);
             }
 
-            public override short ShortVal(int doc)
+            /// <summary>
+            /// NOTE: This was shortVal() in Lucene
+            /// </summary>
+            public override short Int16Val(int doc)
             {
                 return arr.Get(doc);
             }
 
-            public override float FloatVal(int doc)
+            /// <summary>
+            /// NOTE: This was floatVal() in Lucene
+            /// </summary>
+            public override float SingleVal(int doc)
             {
                 return (float)arr.Get(doc);
             }
 
-            public override int IntVal(int doc)
+            /// <summary>
+            /// NOTE: This was intVal() in Lucene
+            /// </summary>
+            public override int Int32Val(int doc)
             {
                 return (int)arr.Get(doc);
             }
 
-            public override long LongVal(int doc)
+            /// <summary>
+            /// NOTE: This was longVal() in Lucene
+            /// </summary>
+            public override long Int64Val(int doc)
             {
                 return (long)arr.Get(doc);
             }
@@ -102,7 +114,7 @@ namespace Lucene.Net.Queries.Function.ValueSources
 
             public override string ToString(int doc)
             {
-                return outerInstance.GetDescription() + '=' + ShortVal(doc);
+                return outerInstance.GetDescription() + '=' + Int16Val(doc);
             }
         }
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/ec70857f/src/Lucene.Net.Queries/Function/ValueSources/SimpleFloatFunction.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/SimpleFloatFunction.cs b/src/Lucene.Net.Queries/Function/ValueSources/SimpleFloatFunction.cs
index 16809f7..400e496 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/SimpleFloatFunction.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/SimpleFloatFunction.cs
@@ -51,7 +51,10 @@ namespace Lucene.Net.Queries.Function.ValueSources
                 this.vals = vals;
             }
 
-            public override float FloatVal(int doc)
+            /// <summary>
+            /// NOTE: This was floatVal() in Lucene
+            /// </summary>
+            public override float SingleVal(int doc)
             {
                 return outerInstance.Func(doc, vals);
             }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/ec70857f/src/Lucene.Net.Queries/Function/ValueSources/SumFloatFunction.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/SumFloatFunction.cs b/src/Lucene.Net.Queries/Function/ValueSources/SumFloatFunction.cs
index fcff158..90472a2 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/SumFloatFunction.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/SumFloatFunction.cs
@@ -36,7 +36,7 @@ namespace Lucene.Net.Queries.Function.ValueSources
 
         protected override float Func(int doc, FunctionValues[] valsArr)
         {
-            return valsArr.Sum(vals => vals.FloatVal(doc));
+            return valsArr.Sum(vals => vals.SingleVal(doc));
         }
     }
 }
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/ec70857f/src/Lucene.Net.Queries/Function/ValueSources/SumTotalTermFreqValueSource.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/SumTotalTermFreqValueSource.cs b/src/Lucene.Net.Queries/Function/ValueSources/SumTotalTermFreqValueSource.cs
index f46ca0e..27de789 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/SumTotalTermFreqValueSource.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/SumTotalTermFreqValueSource.cs
@@ -96,7 +96,10 @@ namespace Lucene.Net.Queries.Function.ValueSources
                 this.ttf = ttf;
             }
 
-            public override long LongVal(int doc)
+            /// <summary>
+            /// NOTE: This was longVal() in Lucene
+            /// </summary>
+            public override long Int64Val(int doc)
             {
                 return ttf;
             }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/ec70857f/src/Lucene.Net.Queries/Function/ValueSources/TFValueSource.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/TFValueSource.cs b/src/Lucene.Net.Queries/Function/ValueSources/TFValueSource.cs
index 1be78d0..e9bbee7 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/TFValueSource.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/TFValueSource.cs
@@ -149,7 +149,10 @@ namespace Lucene.Net.Queries.Function.ValueSources
                 }
             }
 
-            public override float FloatVal(int doc)
+            /// <summary>
+            /// NOTE: This was floatVal() in Lucene
+            /// </summary>
+            public override float SingleVal(int doc)
             {
                 try
                 {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/ec70857f/src/Lucene.Net.Queries/Function/ValueSources/TermFreqValueSource.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/TermFreqValueSource.cs b/src/Lucene.Net.Queries/Function/ValueSources/TermFreqValueSource.cs
index 3019d79..749c208 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/TermFreqValueSource.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/TermFreqValueSource.cs
@@ -134,7 +134,10 @@ namespace Lucene.Net.Queries.Function.ValueSources
                 }
             }
 
-            public override int IntVal(int doc)
+            /// <summary>
+            /// NOTE: This was intVal() in Lucene
+            /// </summary>
+            public override int Int32Val(int doc)
             {
                 try
                 {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/ec70857f/src/Lucene.Net.Queries/Function/ValueSources/TotalTermFreqValueSource.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/TotalTermFreqValueSource.cs b/src/Lucene.Net.Queries/Function/ValueSources/TotalTermFreqValueSource.cs
index 6da5703..86511b7 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/TotalTermFreqValueSource.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/TotalTermFreqValueSource.cs
@@ -93,7 +93,10 @@ namespace Lucene.Net.Queries.Function.ValueSources
                 this.ttf = ttf;
             }
 
-            public override long LongVal(int doc)
+            /// <summary>
+            /// NOTE: This was longVal() in Lucene
+            /// </summary>
+            public override long Int64Val(int doc)
             {
                 return ttf;
             }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/ec70857f/src/Lucene.Net.Queries/Function/ValueSources/VectorValueSource.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/VectorValueSource.cs b/src/Lucene.Net.Queries/Function/ValueSources/VectorValueSource.cs
index 1bae536..90850d2 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/VectorValueSource.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/VectorValueSource.cs
@@ -96,25 +96,40 @@ namespace Lucene.Net.Queries.Function.ValueSources
                 vals[1] = y.ByteVal(doc);
             }
 
-            public override void ShortVal(int doc, short[] vals)
+            /// <summary>
+            /// NOTE: This was shortVal() in Lucene
+            /// </summary>
+            public override void Int16Val(int doc, short[] vals)
             {
-                vals[0] = x.ShortVal(doc);
-                vals[1] = y.ShortVal(doc);
+                vals[0] = x.Int16Val(doc);
+                vals[1] = y.Int16Val(doc);
             }
-            public override void IntVal(int doc, int[] vals)
+
+            /// <summary>
+            /// NOTE: This was intVal() in Lucene
+            /// </summary>
+            public override void Int32Val(int doc, int[] vals)
             {
-                vals[0] = x.IntVal(doc);
-                vals[1] = y.IntVal(doc);
+                vals[0] = x.Int32Val(doc);
+                vals[1] = y.Int32Val(doc);
             }
-            public override void LongVal(int doc, long[] vals)
+
+            /// <summary>
+            /// NOTE: This was longVal() in Lucene
+            /// </summary>
+            public override void Int64Val(int doc, long[] vals)
             {
-                vals[0] = x.LongVal(doc);
-                vals[1] = y.LongVal(doc);
+                vals[0] = x.Int64Val(doc);
+                vals[1] = y.Int64Val(doc);
             }
-            public override void FloatVal(int doc, float[] vals)
+
+            /// <summary>
+            /// NOTE: This was floatVal() in Lucene
+            /// </summary>
+            public override void SingleVal(int doc, float[] vals)
             {
-                vals[0] = x.FloatVal(doc);
-                vals[1] = y.FloatVal(doc);
+                vals[0] = x.SingleVal(doc);
+                vals[1] = y.SingleVal(doc);
             }
             public override void DoubleVal(int doc, double[] vals)
             {
@@ -151,35 +166,47 @@ namespace Lucene.Net.Queries.Function.ValueSources
                 }
             }
 
-            public override void ShortVal(int doc, short[] vals)
+            /// <summary>
+            /// NOTE: This was shortVal() in Lucene
+            /// </summary>
+            public override void Int16Val(int doc, short[] vals)
             {
                 for (int i = 0; i < valsArr.Length; i++)
                 {
-                    vals[i] = valsArr[i].ShortVal(doc);
+                    vals[i] = valsArr[i].Int16Val(doc);
                 }
             }
 
-            public override void FloatVal(int doc, float[] vals)
+            /// <summary>
+            /// NOTE: This was floatVal() in Lucene
+            /// </summary>
+            public override void SingleVal(int doc, float[] vals)
             {
                 for (int i = 0; i < valsArr.Length; i++)
                 {
-                    vals[i] = valsArr[i].FloatVal(doc);
+                    vals[i] = valsArr[i].SingleVal(doc);
                 }
             }
 
-            public override void IntVal(int doc, int[] vals)
+            /// <summary>
+            /// NOTE: This was intVal() in Lucene
+            /// </summary>
+            public override void Int32Val(int doc, int[] vals)
             {
                 for (int i = 0; i < valsArr.Length; i++)
                 {
-                    vals[i] = valsArr[i].IntVal(doc);
+                    vals[i] = valsArr[i].Int32Val(doc);
                 }
             }
 
-            public override void LongVal(int doc, long[] vals)
+            /// <summary>
+            /// NOTE: This was longVal() in Lucene
+            /// </summary>
+            public override void Int64Val(int doc, long[] vals)
             {
                 for (int i = 0; i < valsArr.Length; i++)
                 {
-                    vals[i] = valsArr[i].LongVal(doc);
+                    vals[i] = valsArr[i].Int64Val(doc);
                 }
             }
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/ec70857f/src/Lucene.Net.Spatial/Util/CachingDoubleValueSource.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Spatial/Util/CachingDoubleValueSource.cs b/src/Lucene.Net.Spatial/Util/CachingDoubleValueSource.cs
index 7d9522c..eae1e4f 100644
--- a/src/Lucene.Net.Spatial/Util/CachingDoubleValueSource.cs
+++ b/src/Lucene.Net.Spatial/Util/CachingDoubleValueSource.cs
@@ -78,7 +78,10 @@ namespace Lucene.Net.Spatial.Util
                 return v;
             }
 
-            public override float FloatVal(int doc)
+            /// <summary>
+            /// NOTE: This was floatVal() in Lucene
+            /// </summary>
+            public override float SingleVal(int doc)
             {
                 return (float)DoubleVal(doc);
             }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/ec70857f/src/Lucene.Net.Spatial/Util/ShapeFieldCacheDistanceValueSource.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Spatial/Util/ShapeFieldCacheDistanceValueSource.cs b/src/Lucene.Net.Spatial/Util/ShapeFieldCacheDistanceValueSource.cs
index 642d689..ffb8c56 100644
--- a/src/Lucene.Net.Spatial/Util/ShapeFieldCacheDistanceValueSource.cs
+++ b/src/Lucene.Net.Spatial/Util/ShapeFieldCacheDistanceValueSource.cs
@@ -77,7 +77,10 @@ namespace Lucene.Net.Spatial.Util
                 nullValue = (enclosingInstance.ctx.IsGeo ? 180 * enclosingInstance.multiplier : double.MaxValue);
             }
 
-            public override float FloatVal(int doc)
+            /// <summary>
+            /// NOTE: This was floatVal() in Lucene
+            /// </summary>
+            public override float SingleVal(int doc)
             {
                 return (float)DoubleVal(doc);
             }
@@ -99,7 +102,7 @@ namespace Lucene.Net.Spatial.Util
 
             public override string ToString(int doc)
             {
-                return enclosingInstance.GetDescription() + "=" + FloatVal(doc);
+                return enclosingInstance.GetDescription() + "=" + SingleVal(doc);
             }
         }
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/ec70857f/src/Lucene.Net.Spatial/Vector/DistanceValueSource.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Spatial/Vector/DistanceValueSource.cs b/src/Lucene.Net.Spatial/Vector/DistanceValueSource.cs
index 36f5d53..327093e 100644
--- a/src/Lucene.Net.Spatial/Vector/DistanceValueSource.cs
+++ b/src/Lucene.Net.Spatial/Vector/DistanceValueSource.cs
@@ -90,7 +90,10 @@ namespace Lucene.Net.Spatial.Vector
                 nullValue = (outerInstance.strategy.SpatialContext.IsGeo ? 180 * outerInstance.multiplier : double.MaxValue);
             }
 
-            public override float FloatVal(int doc)
+            /// <summary>
+            /// NOTE: This was floatVal() in Lucene
+            /// </summary>
+            public override float SingleVal(int doc)
             {
                 return (float)DoubleVal(doc);
             }
@@ -108,7 +111,7 @@ namespace Lucene.Net.Spatial.Vector
 
             public override string ToString(int doc)
             {
-                return outerInstance.GetDescription() + "=" + FloatVal(doc);
+                return outerInstance.GetDescription() + "=" + SingleVal(doc);
             }
         }
 


[14/53] [abbrv] lucenenet git commit: Lucene.Net.Facet: Renamed all type-derived properties and methods from Short, Int, Long, and Float to match CLR types Int16, Int32, Int64, and Single, respectively.

Posted by ni...@apache.org.
Lucene.Net.Facet: Renamed all type-derived properties and methods from Short, Int, Long, and Float to match CLR types Int16, Int32, Int64, and Single, respectively.


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

Branch: refs/heads/api-work
Commit: bb41cd171a7b6c88c9bf887b393883364d3f971b
Parents: ffa0fbf
Author: Shad Storhaug <sh...@shadstorhaug.com>
Authored: Tue Feb 7 20:46:02 2017 +0700
Committer: Shad Storhaug <sh...@shadstorhaug.com>
Committed: Wed Feb 8 21:08:21 2017 +0700

----------------------------------------------------------------------
 .../RandomSamplingFacetsCollector.cs                | 14 +++++++++-----
 src/Lucene.Net.Facet/Range/DoubleRange.cs           |  5 ++++-
 src/Lucene.Net.Facet/Taxonomy/CategoryPath.cs       |  4 +++-
 src/Lucene.Net.Facet/Taxonomy/FacetLabel.cs         |  6 ++++--
 .../Taxonomy/FloatAssociationFacetField.cs          | 16 ++++++++++------
 .../Taxonomy/IntAssociationFacetField.cs            | 15 +++++++++------
 .../Taxonomy/WriterCache/NameHashIntCacheLRU.cs     |  4 ++--
 .../Taxonomy/TestFacetLabel.cs                      |  6 +++---
 8 files changed, 44 insertions(+), 26 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/lucenenet/blob/bb41cd17/src/Lucene.Net.Facet/RandomSamplingFacetsCollector.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Facet/RandomSamplingFacetsCollector.cs b/src/Lucene.Net.Facet/RandomSamplingFacetsCollector.cs
index d853ebd..40ef17d 100644
--- a/src/Lucene.Net.Facet/RandomSamplingFacetsCollector.cs
+++ b/src/Lucene.Net.Facet/RandomSamplingFacetsCollector.cs
@@ -65,8 +65,10 @@ namespace Lucene.Net.Facet
 
             /// <summary>
             /// Get the next random long value
+            /// <para/>
+            /// NOTE: This was randomLong() in Lucene
             /// </summary>
-            public virtual long RandomLong()
+            public virtual long RandomInt64()
             {
                 x ^= (x << 21);
                 x ^= ((long)((ulong)x >> 35));
@@ -76,10 +78,12 @@ namespace Lucene.Net.Facet
 
             /// <summary>
             /// Get the next random int, between 0 (inclusive) and <paramref name="n"/> (exclusive)
+            /// <para/>
+            /// NOTE: This was nextInt() in Lucene
             /// </summary>
-            public virtual int NextInt(int n)
+            public virtual int NextInt32(int n)
             {
-                int res = (int)(RandomLong() % n);
+                int res = (int)(RandomInt64() % n);
                 return (res < 0) ? -res : res;
             }
         }
@@ -209,7 +213,7 @@ namespace Lucene.Net.Facet
                 else
                 {
                     limit = binSize;
-                    randomIndex = random.NextInt(binSize);
+                    randomIndex = random.NextInt32(binSize);
                 }
                 DocIdSetIterator it = docs.Bits.GetIterator();
                 for (int doc = it.NextDoc(); doc != DocIdSetIterator.NO_MORE_DOCS; doc = it.NextDoc())
@@ -223,7 +227,7 @@ namespace Lucene.Net.Facet
                     {
                         counter = 0;
                         limit = binSize;
-                        randomIndex = random.NextInt(binSize);
+                        randomIndex = random.NextInt32(binSize);
                     }
                 }
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/bb41cd17/src/Lucene.Net.Facet/Range/DoubleRange.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Facet/Range/DoubleRange.cs b/src/Lucene.Net.Facet/Range/DoubleRange.cs
index 3f3d034..c8201bc 100644
--- a/src/Lucene.Net.Facet/Range/DoubleRange.cs
+++ b/src/Lucene.Net.Facet/Range/DoubleRange.cs
@@ -105,7 +105,10 @@ namespace Lucene.Net.Facet.Range
             return value >= minIncl && value <= maxIncl;
         }
 
-        internal LongRange ToLongRange()
+        /// <summary>
+        /// NOTE: This was toLongRange() in Lucene
+        /// </summary>
+        internal LongRange ToInt64Range()
         {
             return new LongRange(Label, NumericUtils.DoubleToSortableInt64(minIncl), true, NumericUtils.DoubleToSortableInt64(maxIncl), true);
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/bb41cd17/src/Lucene.Net.Facet/Taxonomy/CategoryPath.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Facet/Taxonomy/CategoryPath.cs b/src/Lucene.Net.Facet/Taxonomy/CategoryPath.cs
index eca4372..870771f 100644
--- a/src/Lucene.Net.Facet/Taxonomy/CategoryPath.cs
+++ b/src/Lucene.Net.Facet/Taxonomy/CategoryPath.cs
@@ -248,8 +248,10 @@ namespace Lucene.Net.Facet.Taxonomy
 
         /// <summary>
         /// Calculate a 64-bit hash function for this path.
+        /// <para/>
+        /// NOTE: This was longHashCode() in Lucene
         /// </summary>
-        public virtual long LongHashCode()
+        public virtual long Int64HashCode()
         {
             if (Length == 0)
             {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/bb41cd17/src/Lucene.Net.Facet/Taxonomy/FacetLabel.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Facet/Taxonomy/FacetLabel.cs b/src/Lucene.Net.Facet/Taxonomy/FacetLabel.cs
index 10ff894..1a54c0d 100644
--- a/src/Lucene.Net.Facet/Taxonomy/FacetLabel.cs
+++ b/src/Lucene.Net.Facet/Taxonomy/FacetLabel.cs
@@ -179,9 +179,11 @@ namespace Lucene.Net.Facet.Taxonomy
         /// Calculate a 64-bit hash function for this path.  This
         /// is necessary for <see cref="NameHashIntCacheLRU"/> (the
         /// default cache impl for <see cref="LruTaxonomyWriterCache"/>) 
-        /// to reduce the chance of "silent but deadly" collisions. 
+        /// to reduce the chance of "silent but deadly" collisions.
+        /// <para/>
+        /// NOTE: This was longHashCode() in Lucene
         /// </summary>
-        public virtual long LongHashCode()
+        public virtual long Int64HashCode()
         {
             if (Length == 0)
             {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/bb41cd17/src/Lucene.Net.Facet/Taxonomy/FloatAssociationFacetField.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Facet/Taxonomy/FloatAssociationFacetField.cs b/src/Lucene.Net.Facet/Taxonomy/FloatAssociationFacetField.cs
index 67026cc..1257ff6 100644
--- a/src/Lucene.Net.Facet/Taxonomy/FloatAssociationFacetField.cs
+++ b/src/Lucene.Net.Facet/Taxonomy/FloatAssociationFacetField.cs
@@ -37,30 +37,34 @@ namespace Lucene.Net.Facet.Taxonomy
         /// float association 
         /// </summary>
         public FloatAssociationFacetField(float assoc, string dim, params string[] path) 
-            : base(FloatToBytesRef(assoc), dim, path)
+            : base(SingleToBytesRef(assoc), dim, path)
         {
         }
 
         /// <summary>
         /// Encodes a <see cref="float"/> as a 4-byte <see cref="BytesRef"/>.
+        /// <para/>
+        /// NOTE: This was floatToBytesRef() in Lucene
         /// </summary>
-        public static BytesRef FloatToBytesRef(float v)
+        public static BytesRef SingleToBytesRef(float v)
         {
-            return IntAssociationFacetField.IntToBytesRef(Number.SingleToInt32Bits(v));
+            return IntAssociationFacetField.Int32ToBytesRef(Number.SingleToInt32Bits(v));
         }
 
         /// <summary>
         /// Decodes a previously encoded <see cref="float"/>.
+        /// <para/>
+        /// NOTE: This was bytesRefToFloat() in Lucene
         /// </summary>
-        public static float BytesRefToFloat(BytesRef b)
+        public static float BytesRefToSingle(BytesRef b)
         {
-            return Number.Int32BitsToSingle(IntAssociationFacetField.BytesRefToInt(b));
+            return Number.Int32BitsToSingle(IntAssociationFacetField.BytesRefToInt32(b));
         }
 
         public override string ToString()
         {
             return "FloatAssociationFacetField(dim=" + Dim + " path=" + Arrays.ToString(Path) + 
-                " value=" + BytesRefToFloat(Assoc).ToString("0.0#####", CultureInfo.InvariantCulture) + ")";
+                " value=" + BytesRefToSingle(Assoc).ToString("0.0#####", CultureInfo.InvariantCulture) + ")";
         }
     }
 }
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/bb41cd17/src/Lucene.Net.Facet/Taxonomy/IntAssociationFacetField.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Facet/Taxonomy/IntAssociationFacetField.cs b/src/Lucene.Net.Facet/Taxonomy/IntAssociationFacetField.cs
index 3cdf528..3385cdb 100644
--- a/src/Lucene.Net.Facet/Taxonomy/IntAssociationFacetField.cs
+++ b/src/Lucene.Net.Facet/Taxonomy/IntAssociationFacetField.cs
@@ -36,17 +36,18 @@ namespace Lucene.Net.Facet.Taxonomy
         /// int association 
         /// </summary>
         public IntAssociationFacetField(int assoc, string dim, params string[] path)
-            : base(IntToBytesRef(assoc), dim, path)
+            : base(Int32ToBytesRef(assoc), dim, path)
         {
         }
 
         /// <summary>
         /// Encodes an <see cref="int"/> as a 4-byte <see cref="BytesRef"/>,
-        /// big-endian. 
+        /// big-endian.
+        /// <para/>
+        /// NOTE: This was intToBytesRef() in Lucene
         /// </summary>
-        public static BytesRef IntToBytesRef(int v)
+        public static BytesRef Int32ToBytesRef(int v)
         {
-
             byte[] bytes = new byte[4];
             // big-endian:
             bytes[0] = (byte)(v >> 24);
@@ -58,8 +59,10 @@ namespace Lucene.Net.Facet.Taxonomy
 
         /// <summary>
         /// Decodes a previously encoded <see cref="int"/>.
+        /// <para/>
+        /// NOTE: This was bytesRefToInt() in Lucene
         /// </summary>
-        public static int BytesRefToInt(BytesRef b)
+        public static int BytesRefToInt32(BytesRef b)
         {
             return ((b.Bytes[b.Offset] & 0xFF) << 24) | ((b.Bytes[b.Offset + 1] & 0xFF) << 16) | 
                 ((b.Bytes[b.Offset + 2] & 0xFF) << 8) | (b.Bytes[b.Offset + 3] & 0xFF);
@@ -67,7 +70,7 @@ namespace Lucene.Net.Facet.Taxonomy
 
         public override string ToString()
         {
-            return "IntAssociationFacetField(dim=" + Dim + " path=" + Arrays.ToString(Path) + " value=" + BytesRefToInt(Assoc) + ")";
+            return "IntAssociationFacetField(dim=" + Dim + " path=" + Arrays.ToString(Path) + " value=" + BytesRefToInt32(Assoc) + ")";
         }
     }
 }
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/bb41cd17/src/Lucene.Net.Facet/Taxonomy/WriterCache/NameHashIntCacheLRU.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Facet/Taxonomy/WriterCache/NameHashIntCacheLRU.cs b/src/Lucene.Net.Facet/Taxonomy/WriterCache/NameHashIntCacheLRU.cs
index 40d67f5..7e2c95e 100644
--- a/src/Lucene.Net.Facet/Taxonomy/WriterCache/NameHashIntCacheLRU.cs
+++ b/src/Lucene.Net.Facet/Taxonomy/WriterCache/NameHashIntCacheLRU.cs
@@ -35,12 +35,12 @@
 
         internal override object Key(FacetLabel name)
         {
-            return new long?(name.LongHashCode());
+            return new long?(name.Int64HashCode());
         }
 
         internal override object Key(FacetLabel name, int prefixLen)
         {
-            return new long?(name.Subpath(prefixLen).LongHashCode());
+            return new long?(name.Subpath(prefixLen).Int64HashCode());
         }
     }
 }
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/bb41cd17/src/Lucene.Net.Tests.Facet/Taxonomy/TestFacetLabel.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests.Facet/Taxonomy/TestFacetLabel.cs b/src/Lucene.Net.Tests.Facet/Taxonomy/TestFacetLabel.cs
index 0226137..2b87829 100644
--- a/src/Lucene.Net.Tests.Facet/Taxonomy/TestFacetLabel.cs
+++ b/src/Lucene.Net.Tests.Facet/Taxonomy/TestFacetLabel.cs
@@ -124,9 +124,9 @@ namespace Lucene.Net.Facet.Taxonomy
         [Test]
         public virtual void TestLongHashCode()
         {
-            Assert.AreEqual((new FacetLabel()).LongHashCode(), (new FacetLabel()).LongHashCode());
-            Assert.False((new FacetLabel()).LongHashCode() == (new FacetLabel("hi")).LongHashCode());
-            Assert.AreEqual((new FacetLabel("hello", "world")).LongHashCode(), (new FacetLabel("hello", "world")).LongHashCode());
+            Assert.AreEqual((new FacetLabel()).Int64HashCode(), (new FacetLabel()).Int64HashCode());
+            Assert.False((new FacetLabel()).Int64HashCode() == (new FacetLabel("hi")).Int64HashCode());
+            Assert.AreEqual((new FacetLabel("hello", "world")).Int64HashCode(), (new FacetLabel("hello", "world")).Int64HashCode());
         }
 
         [Test]


[10/53] [abbrv] lucenenet git commit: Lucene.Net.Core: Renamed all type-derived properties and methods from Short, Int, Long, and Float to match CLR types Int16, Int32, Int64, and Single, respectively.

Posted by ni...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Codecs/Lucene3x/Lucene3xSegmentInfoReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/Lucene3x/Lucene3xSegmentInfoReader.cs b/src/Lucene.Net.Core/Codecs/Lucene3x/Lucene3xSegmentInfoReader.cs
index 94e1f46..09db0fc 100644
--- a/src/Lucene.Net.Core/Codecs/Lucene3x/Lucene3xSegmentInfoReader.cs
+++ b/src/Lucene.Net.Core/Codecs/Lucene3x/Lucene3xSegmentInfoReader.cs
@@ -43,10 +43,10 @@ namespace Lucene.Net.Codecs.Lucene3x
     {
         public static void ReadLegacyInfos(SegmentInfos infos, Directory directory, IndexInput input, int format)
         {
-            infos.Version = input.ReadLong(); // read version
-            infos.Counter = input.ReadInt(); // read counter
+            infos.Version = input.ReadInt64(); // read version
+            infos.Counter = input.ReadInt32(); // read counter
             Lucene3xSegmentInfoReader reader = new Lucene3xSegmentInfoReader();
-            for (int i = input.ReadInt(); i > 0; i--) // read segmentInfos
+            for (int i = input.ReadInt32(); i > 0; i--) // read segmentInfos
             {
                 SegmentCommitInfo siPerCommit = reader.ReadLegacySegmentInfo(directory, format, input);
                 SegmentInfo si = siPerCommit.Info;
@@ -161,10 +161,10 @@ namespace Lucene.Net.Codecs.Lucene3x
 
             string name = input.ReadString();
 
-            int docCount = input.ReadInt();
-            long delGen = input.ReadLong();
+            int docCount = input.ReadInt32();
+            long delGen = input.ReadInt64();
 
-            int docStoreOffset = input.ReadInt();
+            int docStoreOffset = input.ReadInt32();
             IDictionary<string, string> attributes = new Dictionary<string, string>();
 
             // parse the docstore stuff and shove it into attributes
@@ -190,7 +190,7 @@ namespace Lucene.Net.Codecs.Lucene3x
             //System.out.println("version=" + version + " name=" + name + " docCount=" + docCount + " delGen=" + delGen + " dso=" + docStoreOffset + " dss=" + docStoreSegment + " dssCFs=" + docStoreIsCompoundFile + " b=" + b + " format=" + format);
 
             Debug.Assert(1 == b, "expected 1 but was: " + b + " format: " + format);
-            int numNormGen = input.ReadInt();
+            int numNormGen = input.ReadInt32();
             IDictionary<int, long> normGen;
             if (numNormGen == SegmentInfo.NO)
             {
@@ -201,12 +201,12 @@ namespace Lucene.Net.Codecs.Lucene3x
                 normGen = new Dictionary<int, long>();
                 for (int j = 0; j < numNormGen; j++)
                 {
-                    normGen[j] = input.ReadLong();
+                    normGen[j] = input.ReadInt64();
                 }
             }
             bool isCompoundFile = input.ReadByte() == SegmentInfo.YES;
 
-            int delCount = input.ReadInt();
+            int delCount = input.ReadInt32();
             Debug.Assert(delCount <= docCount);
 
             bool hasProx = input.ReadByte() == 1;
@@ -296,7 +296,7 @@ namespace Lucene.Net.Codecs.Lucene3x
             CodecUtil.CheckHeader(input, Lucene3xSegmentInfoFormat.UPGRADED_SI_CODEC_NAME, Lucene3xSegmentInfoFormat.UPGRADED_SI_VERSION_START, Lucene3xSegmentInfoFormat.UPGRADED_SI_VERSION_CURRENT);
             string version = input.ReadString();
 
-            int docCount = input.ReadInt();
+            int docCount = input.ReadInt32();
 
             IDictionary<string, string> attributes = input.ReadStringStringMap();
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Codecs/Lucene3x/Lucene3xSkipListReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/Lucene3x/Lucene3xSkipListReader.cs b/src/Lucene.Net.Core/Codecs/Lucene3x/Lucene3xSkipListReader.cs
index 328b092..baa16b3 100644
--- a/src/Lucene.Net.Core/Codecs/Lucene3x/Lucene3xSkipListReader.cs
+++ b/src/Lucene.Net.Core/Codecs/Lucene3x/Lucene3xSkipListReader.cs
@@ -119,20 +119,20 @@ namespace Lucene.Net.Codecs.Lucene3x
                 // to read the current payload length
                 // because it differs from the length of the
                 // previous payload
-                delta = skipStream.ReadVInt();
+                delta = skipStream.ReadVInt32();
                 if ((delta & 1) != 0)
                 {
-                    payloadLength[level] = skipStream.ReadVInt();
+                    payloadLength[level] = skipStream.ReadVInt32();
                 }
                 delta = (int)((uint)delta >> 1);
             }
             else
             {
-                delta = skipStream.ReadVInt();
+                delta = skipStream.ReadVInt32();
             }
 
-            freqPointer[level] += skipStream.ReadVInt();
-            proxPointer[level] += skipStream.ReadVInt();
+            freqPointer[level] += skipStream.ReadVInt32();
+            proxPointer[level] += skipStream.ReadVInt32();
 
             return delta;
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Codecs/Lucene3x/Lucene3xStoredFieldsReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/Lucene3x/Lucene3xStoredFieldsReader.cs b/src/Lucene.Net.Core/Codecs/Lucene3x/Lucene3xStoredFieldsReader.cs
index b7cb10b..b30b083 100644
--- a/src/Lucene.Net.Core/Codecs/Lucene3x/Lucene3xStoredFieldsReader.cs
+++ b/src/Lucene.Net.Core/Codecs/Lucene3x/Lucene3xStoredFieldsReader.cs
@@ -120,7 +120,7 @@ namespace Lucene.Net.Codecs.Lucene3x
 
             try
             {
-                int format = idxStream.ReadInt();
+                int format = idxStream.ReadInt32();
                 if (format < FORMAT_MINIMUM)
                 {
                     throw new IndexFormatTooOldException(idxStream, format, FORMAT_MINIMUM, FORMAT_CURRENT);
@@ -170,7 +170,7 @@ namespace Lucene.Net.Codecs.Lucene3x
                 string indexStreamFN = IndexFileNames.SegmentFileName(segment, "", FIELDS_INDEX_EXTENSION);
                 indexStream = d.OpenInput(indexStreamFN, context);
 
-                format = indexStream.ReadInt();
+                format = indexStream.ReadInt32();
 
                 if (format < FORMAT_MINIMUM)
                 {
@@ -262,12 +262,12 @@ namespace Lucene.Net.Codecs.Lucene3x
         public override sealed void VisitDocument(int n, StoredFieldVisitor visitor)
         {
             SeekIndex(n);
-            fieldsStream.Seek(indexStream.ReadLong());
+            fieldsStream.Seek(indexStream.ReadInt64());
 
-            int numFields = fieldsStream.ReadVInt();
+            int numFields = fieldsStream.ReadVInt32();
             for (int fieldIDX = 0; fieldIDX < numFields; fieldIDX++)
             {
-                int fieldNumber = fieldsStream.ReadVInt();
+                int fieldNumber = fieldsStream.ReadVInt32();
                 FieldInfo fieldInfo = fieldInfos.FieldInfo(fieldNumber);
 
                 int bits = fieldsStream.ReadByte() & 0xFF;
@@ -297,19 +297,19 @@ namespace Lucene.Net.Codecs.Lucene3x
                 switch (numeric)
                 {
                     case FIELD_IS_NUMERIC_INT:
-                        visitor.Int32Field(info, fieldsStream.ReadInt());
+                        visitor.Int32Field(info, fieldsStream.ReadInt32());
                         return;
 
                     case FIELD_IS_NUMERIC_LONG:
-                        visitor.Int64Field(info, fieldsStream.ReadLong());
+                        visitor.Int64Field(info, fieldsStream.ReadInt64());
                         return;
 
                     case FIELD_IS_NUMERIC_FLOAT:
-                        visitor.SingleField(info, Number.IntBitsToFloat(fieldsStream.ReadInt()));
+                        visitor.SingleField(info, Number.Int32BitsToSingle(fieldsStream.ReadInt32()));
                         return;
 
                     case FIELD_IS_NUMERIC_DOUBLE:
-                        visitor.DoubleField(info, BitConverter.Int64BitsToDouble(fieldsStream.ReadLong()));
+                        visitor.DoubleField(info, BitConverter.Int64BitsToDouble(fieldsStream.ReadInt64()));
                         return;
 
                     default:
@@ -318,7 +318,7 @@ namespace Lucene.Net.Codecs.Lucene3x
             }
             else
             {
-                int length = fieldsStream.ReadVInt();
+                int length = fieldsStream.ReadVInt32();
                 var bytes = new byte[length];
                 fieldsStream.ReadBytes(bytes, 0, length);
                 if ((bits & FIELD_IS_BINARY) != 0)
@@ -341,12 +341,12 @@ namespace Lucene.Net.Codecs.Lucene3x
                 {
                     case FIELD_IS_NUMERIC_INT:
                     case FIELD_IS_NUMERIC_FLOAT:
-                        fieldsStream.ReadInt();
+                        fieldsStream.ReadInt32();
                         return;
 
                     case FIELD_IS_NUMERIC_LONG:
                     case FIELD_IS_NUMERIC_DOUBLE:
-                        fieldsStream.ReadLong();
+                        fieldsStream.ReadInt64();
                         return;
 
                     default:
@@ -355,7 +355,7 @@ namespace Lucene.Net.Codecs.Lucene3x
             }
             else
             {
-                int length = fieldsStream.ReadVInt();
+                int length = fieldsStream.ReadVInt32();
                 fieldsStream.Seek(fieldsStream.FilePointer + length);
             }
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Codecs/Lucene3x/Lucene3xTermVectorsReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/Lucene3x/Lucene3xTermVectorsReader.cs b/src/Lucene.Net.Core/Codecs/Lucene3x/Lucene3xTermVectorsReader.cs
index 75331bb..86f8692 100644
--- a/src/Lucene.Net.Core/Codecs/Lucene3x/Lucene3xTermVectorsReader.cs
+++ b/src/Lucene.Net.Core/Codecs/Lucene3x/Lucene3xTermVectorsReader.cs
@@ -190,7 +190,7 @@ namespace Lucene.Net.Codecs.Lucene3x
 
         private int CheckValidFormat(IndexInput @in)
         {
-            int format = @in.ReadInt();
+            int format = @in.ReadInt32();
             if (format < FORMAT_MINIMUM)
             {
                 throw new IndexFormatTooOldException(@in, format, FORMAT_MINIMUM, FORMAT_CURRENT);
@@ -228,9 +228,9 @@ namespace Lucene.Net.Codecs.Lucene3x
             {
                 this.outerInstance = outerInstance;
                 outerInstance.SeekTvx(docID);
-                outerInstance.tvd.Seek(outerInstance.tvx.ReadLong());
+                outerInstance.tvd.Seek(outerInstance.tvx.ReadInt64());
 
-                int fieldCount = outerInstance.tvd.ReadVInt();
+                int fieldCount = outerInstance.tvd.ReadVInt32();
                 Debug.Assert(fieldCount >= 0);
                 if (fieldCount != 0)
                 {
@@ -238,16 +238,16 @@ namespace Lucene.Net.Codecs.Lucene3x
                     fieldFPs = new long[fieldCount];
                     for (int fieldUpto = 0; fieldUpto < fieldCount; fieldUpto++)
                     {
-                        int fieldNumber = outerInstance.tvd.ReadVInt();
+                        int fieldNumber = outerInstance.tvd.ReadVInt32();
                         fieldNumbers[fieldUpto] = fieldNumber;
                         fieldNumberToIndex[fieldNumber] = fieldUpto;
                     }
 
-                    long position = outerInstance.tvx.ReadLong();
+                    long position = outerInstance.tvx.ReadInt64();
                     fieldFPs[0] = position;
                     for (int fieldUpto = 1; fieldUpto < fieldCount; fieldUpto++)
                     {
-                        position += outerInstance.tvd.ReadVLong();
+                        position += outerInstance.tvd.ReadVInt64();
                         fieldFPs[fieldUpto] = position;
                     }
                 }
@@ -364,7 +364,7 @@ namespace Lucene.Net.Codecs.Lucene3x
             {
                 this.outerInstance = outerInstance;
                 outerInstance.tvf.Seek(tvfFP);
-                numTerms = outerInstance.tvf.ReadVInt();
+                numTerms = outerInstance.tvf.ReadVInt32();
                 byte bits = outerInstance.tvf.ReadByte();
                 storePositions = (bits & STORE_POSITIONS_WITH_TERMVECTOR) != 0;
                 storeOffsets = (bits & STORE_OFFSET_WITH_TERMVECTOR) != 0;
@@ -532,13 +532,13 @@ namespace Lucene.Net.Codecs.Lucene3x
                     TermAndPostings t = new TermAndPostings();
                     BytesRef term = new BytesRef();
                     term.CopyBytes(lastTerm);
-                    int start = tvf.ReadVInt();
-                    int deltaLen = tvf.ReadVInt();
+                    int start = tvf.ReadVInt32();
+                    int deltaLen = tvf.ReadVInt32();
                     term.Length = start + deltaLen;
                     term.Grow(term.Length);
                     tvf.ReadBytes(term.Bytes, start, deltaLen);
                     t.Term = term;
-                    int freq = tvf.ReadVInt();
+                    int freq = tvf.ReadVInt32();
                     t.Freq = freq;
 
                     if (storePositions)
@@ -547,7 +547,7 @@ namespace Lucene.Net.Codecs.Lucene3x
                         int pos = 0;
                         for (int posUpto = 0; posUpto < freq; posUpto++)
                         {
-                            int delta = tvf.ReadVInt();
+                            int delta = tvf.ReadVInt32();
                             if (delta == -1)
                             {
                                 delta = 0; // LUCENE-1542 correction
@@ -565,8 +565,8 @@ namespace Lucene.Net.Codecs.Lucene3x
                         int offset = 0;
                         for (int posUpto = 0; posUpto < freq; posUpto++)
                         {
-                            startOffsets[posUpto] = offset + tvf.ReadVInt();
-                            offset = endOffsets[posUpto] = startOffsets[posUpto] + tvf.ReadVInt();
+                            startOffsets[posUpto] = offset + tvf.ReadVInt32();
+                            offset = endOffsets[posUpto] = startOffsets[posUpto] + tvf.ReadVInt32();
                         }
                         t.StartOffsets = startOffsets;
                         t.EndOffsets = endOffsets;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Codecs/Lucene3x/SegmentTermDocs.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/Lucene3x/SegmentTermDocs.cs b/src/Lucene.Net.Core/Codecs/Lucene3x/SegmentTermDocs.cs
index 348ca04..ae409c3 100644
--- a/src/Lucene.Net.Core/Codecs/Lucene3x/SegmentTermDocs.cs
+++ b/src/Lucene.Net.Core/Codecs/Lucene3x/SegmentTermDocs.cs
@@ -165,7 +165,7 @@ namespace Lucene.Net.Codecs.Lucene3x
                 {
                     return false;
                 }
-                int docCode = m_freqStream.ReadVInt();
+                int docCode = m_freqStream.ReadVInt32();
 
                 if (m_indexOptions == IndexOptions.DOCS_ONLY)
                 {
@@ -180,7 +180,7 @@ namespace Lucene.Net.Codecs.Lucene3x
                     }
                     else
                     {
-                        freq = m_freqStream.ReadVInt(); // else read freq
+                        freq = m_freqStream.ReadVInt32(); // else read freq
                         Debug.Assert(freq != 1);
                     }
                 }
@@ -211,7 +211,7 @@ namespace Lucene.Net.Codecs.Lucene3x
                 while (i < length && m_count < m_df)
                 {
                     // manually inlined call to next() for speed
-                    int docCode = m_freqStream.ReadVInt();
+                    int docCode = m_freqStream.ReadVInt32();
                     doc += (int)((uint)docCode >> 1); // shift off low bit
                     if ((docCode & 1) != 0) // if low bit is set
                     {
@@ -219,7 +219,7 @@ namespace Lucene.Net.Codecs.Lucene3x
                     }
                     else
                     {
-                        freq = m_freqStream.ReadVInt(); // else read freq
+                        freq = m_freqStream.ReadVInt32(); // else read freq
                     }
                     m_count++;
 
@@ -240,7 +240,7 @@ namespace Lucene.Net.Codecs.Lucene3x
             while (i < length && m_count < m_df)
             {
                 // manually inlined call to next() for speed
-                doc += m_freqStream.ReadVInt();
+                doc += m_freqStream.ReadVInt32();
                 m_count++;
 
                 if (m_liveDocs == null || m_liveDocs.Get(doc))

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Codecs/Lucene3x/SegmentTermEnum.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/Lucene3x/SegmentTermEnum.cs b/src/Lucene.Net.Core/Codecs/Lucene3x/SegmentTermEnum.cs
index 720c216..68d5a73 100644
--- a/src/Lucene.Net.Core/Codecs/Lucene3x/SegmentTermEnum.cs
+++ b/src/Lucene.Net.Core/Codecs/Lucene3x/SegmentTermEnum.cs
@@ -71,7 +71,7 @@ namespace Lucene.Net.Codecs.Lucene3x
             isIndex = isi;
             maxSkipLevels = 1; // use single-level skip lists for formats > -3
 
-            int firstInt = input.ReadInt();
+            int firstInt = input.ReadInt32();
             if (firstInt >= 0)
             {
                 // original-format file, without explicit format version number
@@ -97,11 +97,11 @@ namespace Lucene.Net.Codecs.Lucene3x
                     throw new IndexFormatTooNewException(input, format, FORMAT_MINIMUM, FORMAT_CURRENT);
                 }
 
-                size = input.ReadLong(); // read the size
+                size = input.ReadInt64(); // read the size
 
-                indexInterval = input.ReadInt();
-                skipInterval = input.ReadInt();
-                maxSkipLevels = input.ReadInt();
+                indexInterval = input.ReadInt32();
+                skipInterval = input.ReadInt32();
+                maxSkipLevels = input.ReadInt32();
                 Debug.Assert(indexInterval > 0, "indexInterval=" + indexInterval + " is negative; must be > 0");
                 Debug.Assert(skipInterval > 0, "skipInterval=" + skipInterval + " is negative; must be > 0");
             }
@@ -158,18 +158,18 @@ namespace Lucene.Net.Codecs.Lucene3x
             termBuffer.Read(input, fieldInfos);
             newSuffixStart = termBuffer.newSuffixStart;
 
-            termInfo.DocFreq = input.ReadVInt(); // read doc freq
-            termInfo.FreqPointer += input.ReadVLong(); // read freq pointer
-            termInfo.ProxPointer += input.ReadVLong(); // read prox pointer
+            termInfo.DocFreq = input.ReadVInt32(); // read doc freq
+            termInfo.FreqPointer += input.ReadVInt64(); // read freq pointer
+            termInfo.ProxPointer += input.ReadVInt64(); // read prox pointer
 
             if (termInfo.DocFreq >= skipInterval)
             {
-                termInfo.SkipOffset = input.ReadVInt();
+                termInfo.SkipOffset = input.ReadVInt32();
             }
 
             if (isIndex)
             {
-                indexPointer += input.ReadVLong(); // read index pointer
+                indexPointer += input.ReadVInt64(); // read index pointer
             }
 
             //System.out.println("  ste ret term=" + term());

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Codecs/Lucene3x/SegmentTermPositions.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/Lucene3x/SegmentTermPositions.cs b/src/Lucene.Net.Core/Codecs/Lucene3x/SegmentTermPositions.cs
index 95893dc..97fc5b2 100644
--- a/src/Lucene.Net.Core/Codecs/Lucene3x/SegmentTermPositions.cs
+++ b/src/Lucene.Net.Core/Codecs/Lucene3x/SegmentTermPositions.cs
@@ -107,7 +107,7 @@ namespace Lucene.Net.Codecs.Lucene3x
 
         private int ReadDeltaPosition()
         {
-            int delta = proxStream.ReadVInt();
+            int delta = proxStream.ReadVInt32();
             if (m_currentFieldStoresPayloads)
             {
                 // if the current field stores payloads then
@@ -116,7 +116,7 @@ namespace Lucene.Net.Codecs.Lucene3x
                 // payload length
                 if ((delta & 1) != 0)
                 {
-                    payloadLength = proxStream.ReadVInt();
+                    payloadLength = proxStream.ReadVInt32();
                 }
                 delta = (int)((uint)delta >> 1);
                 needToLoadPayload = true;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Codecs/Lucene3x/TermBuffer.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/Lucene3x/TermBuffer.cs b/src/Lucene.Net.Core/Codecs/Lucene3x/TermBuffer.cs
index d7dc011..79744f2 100644
--- a/src/Lucene.Net.Core/Codecs/Lucene3x/TermBuffer.cs
+++ b/src/Lucene.Net.Core/Codecs/Lucene3x/TermBuffer.cs
@@ -62,8 +62,8 @@ namespace Lucene.Net.Codecs.Lucene3x
         public void Read(IndexInput input, FieldInfos fieldInfos)
         {
             this.term = null; // invalidate cache
-            newSuffixStart = input.ReadVInt();
-            int length = input.ReadVInt();
+            newSuffixStart = input.ReadVInt32();
+            int length = input.ReadVInt32();
             int totalLength = newSuffixStart + length;
             Debug.Assert(totalLength <= ByteBlockPool.BYTE_BLOCK_SIZE - 2, "termLength=" + totalLength + ",resource=" + input);
             if (bytes.Bytes.Length < totalLength)
@@ -72,7 +72,7 @@ namespace Lucene.Net.Codecs.Lucene3x
             }
             bytes.Length = totalLength;
             input.ReadBytes(bytes.Bytes, newSuffixStart, length);
-            int fieldNumber = input.ReadVInt();
+            int fieldNumber = input.ReadVInt32();
             if (fieldNumber != currentFieldNumber)
             {
                 currentFieldNumber = fieldNumber;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Codecs/Lucene3x/TermInfosReaderIndex.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/Lucene3x/TermInfosReaderIndex.cs b/src/Lucene.Net.Core/Codecs/Lucene3x/TermInfosReaderIndex.cs
index f322684..f726eec 100644
--- a/src/Lucene.Net.Core/Codecs/Lucene3x/TermInfosReaderIndex.cs
+++ b/src/Lucene.Net.Core/Codecs/Lucene3x/TermInfosReaderIndex.cs
@@ -89,16 +89,16 @@ namespace Lucene.Net.Codecs.Lucene3x
                 }
                 TermInfo termInfo = indexEnum.TermInfo();
                 indexToTerms.Set(i, dataOutput.Position);
-                dataOutput.WriteVInt(fieldCounter);
+                dataOutput.WriteVInt32(fieldCounter);
                 dataOutput.WriteString(term.Text());
-                dataOutput.WriteVInt(termInfo.DocFreq);
+                dataOutput.WriteVInt32(termInfo.DocFreq);
                 if (termInfo.DocFreq >= skipInterval)
                 {
-                    dataOutput.WriteVInt(termInfo.SkipOffset);
+                    dataOutput.WriteVInt32(termInfo.SkipOffset);
                 }
-                dataOutput.WriteVLong(termInfo.FreqPointer);
-                dataOutput.WriteVLong(termInfo.ProxPointer);
-                dataOutput.WriteVLong(indexEnum.indexPointer);
+                dataOutput.WriteVInt64(termInfo.FreqPointer);
+                dataOutput.WriteVInt64(termInfo.ProxPointer);
+                dataOutput.WriteVInt64(indexEnum.indexPointer);
                 for (int j = 1; j < indexDivisor; j++)
                 {
                     if (!indexEnum.Next())
@@ -133,25 +133,25 @@ namespace Lucene.Net.Codecs.Lucene3x
             input.SetPosition(indexToDataOffset.Get(indexOffset));
 
             // read the term
-            int fieldId = input.ReadVInt();
+            int fieldId = input.ReadVInt32();
             Term field = fields[fieldId];
             Term term = new Term(field.Field, input.ReadString());
 
             // read the terminfo
             var termInfo = new TermInfo();
-            termInfo.DocFreq = input.ReadVInt();
+            termInfo.DocFreq = input.ReadVInt32();
             if (termInfo.DocFreq >= skipInterval)
             {
-                termInfo.SkipOffset = input.ReadVInt();
+                termInfo.SkipOffset = input.ReadVInt32();
             }
             else
             {
                 termInfo.SkipOffset = 0;
             }
-            termInfo.FreqPointer = input.ReadVLong();
-            termInfo.ProxPointer = input.ReadVLong();
+            termInfo.FreqPointer = input.ReadVInt64();
+            termInfo.ProxPointer = input.ReadVInt64();
 
-            long pointer = input.ReadVLong();
+            long pointer = input.ReadVInt64();
 
             // perform the seek
             enumerator.Seek(pointer, ((long)indexOffset * totalIndexInterval) - 1, term, termInfo);
@@ -202,7 +202,7 @@ namespace Lucene.Net.Codecs.Lucene3x
             input.SetPosition(indexToDataOffset.Get(termIndex));
 
             // read the term
-            int fieldId = input.ReadVInt();
+            int fieldId = input.ReadVInt32();
             Term field = fields[fieldId];
             return new Term(field.Field, input.ReadString());
         }
@@ -250,7 +250,7 @@ namespace Lucene.Net.Codecs.Lucene3x
             int c = CompareField(term, termIndex, input);
             if (c == 0)
             {
-                reuse.Length = input.ReadVInt();
+                reuse.Length = input.ReadVInt32();
                 reuse.Grow(reuse.Length);
                 input.ReadBytes(reuse.Bytes, 0, reuse.Length);
                 return comparer.Compare(term.Bytes, reuse);
@@ -272,7 +272,7 @@ namespace Lucene.Net.Codecs.Lucene3x
         private int CompareField(Term term, int termIndex, PagedBytesDataInput input)
         {
             input.SetPosition(indexToDataOffset.Get(termIndex));
-            return System.String.Compare(term.Field, fields[input.ReadVInt()].Field, System.StringComparison.Ordinal);
+            return System.String.Compare(term.Field, fields[input.ReadVInt32()].Field, System.StringComparison.Ordinal);
         }
 
         internal virtual long RamBytesUsed()

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Codecs/Lucene40/BitVector.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/Lucene40/BitVector.cs b/src/Lucene.Net.Core/Codecs/Lucene40/BitVector.cs
index 7a468e4..39af20a 100644
--- a/src/Lucene.Net.Core/Codecs/Lucene40/BitVector.cs
+++ b/src/Lucene.Net.Core/Codecs/Lucene40/BitVector.cs
@@ -267,7 +267,7 @@ namespace Lucene.Net.Codecs.Lucene40
             IndexOutput output = d.CreateOutput(name, context);
             try
             {
-                output.WriteInt(-2);
+                output.WriteInt32(-2);
                 CodecUtil.WriteHeader(output, CODEC, VERSION_CURRENT);
                 if (IsSparse)
                 {
@@ -333,8 +333,8 @@ namespace Lucene.Net.Codecs.Lucene40
         /// Write as a bit set </summary>
         private void WriteBits(IndexOutput output)
         {
-            output.WriteInt(Length); // write size
-            output.WriteInt(Count()); // write count
+            output.WriteInt32(Length); // write size
+            output.WriteInt32(Count()); // write count
             output.WriteBytes(bits, bits.Length);
         }
 
@@ -342,16 +342,16 @@ namespace Lucene.Net.Codecs.Lucene40
         /// Write as a d-gaps list </summary>
         private void WriteClearedDgaps(IndexOutput output)
         {
-            output.WriteInt(-1); // mark using d-gaps
-            output.WriteInt(Length); // write size
-            output.WriteInt(Count()); // write count
+            output.WriteInt32(-1); // mark using d-gaps
+            output.WriteInt32(Length); // write size
+            output.WriteInt32(Count()); // write count
             int last = 0;
             int numCleared = Length - Count();
             for (int i = 0; i < bits.Length && numCleared > 0; i++)
             {
                 if (bits[i] != unchecked((byte)0xff))
                 {
-                    output.WriteVInt(i - last);
+                    output.WriteVInt32(i - last);
                     output.WriteByte(bits[i]);
                     last = i;
                     numCleared -= (8 - BitUtil.BitCount(bits[i]));
@@ -420,13 +420,13 @@ namespace Lucene.Net.Codecs.Lucene40
 
             try
             {
-                int firstInt = input.ReadInt();
+                int firstInt = input.ReadInt32();
 
                 if (firstInt == -2)
                 {
                     // New format, with full header & version:
                     version = CodecUtil.CheckHeader(input, CODEC, VERSION_START, VERSION_CURRENT);
-                    size = input.ReadInt();
+                    size = input.ReadInt32();
                 }
                 else
                 {
@@ -486,7 +486,7 @@ namespace Lucene.Net.Codecs.Lucene40
         /// Read as a bit set </summary>
         private void ReadBits(IndexInput input)
         {
-            count = input.ReadInt(); // read count
+            count = input.ReadInt32(); // read count
             bits = new byte[GetNumBytes(size)]; // allocate bits
             input.ReadBytes(bits, 0, bits.Length);
         }
@@ -495,14 +495,14 @@ namespace Lucene.Net.Codecs.Lucene40
         /// read as a d-gaps list </summary>
         private void ReadSetDgaps(IndexInput input)
         {
-            size = input.ReadInt(); // (re)read size
-            count = input.ReadInt(); // read count
+            size = input.ReadInt32(); // (re)read size
+            count = input.ReadInt32(); // read count
             bits = new byte[GetNumBytes(size)]; // allocate bits
             int last = 0;
             int n = Count();
             while (n > 0)
             {
-                last += input.ReadVInt();
+                last += input.ReadVInt32();
                 bits[last] = input.ReadByte();
                 n -= BitUtil.BitCount(bits[last]);
                 Debug.Assert(n >= 0);
@@ -513,8 +513,8 @@ namespace Lucene.Net.Codecs.Lucene40
         /// read as a d-gaps cleared bits list </summary>
         private void ReadClearedDgaps(IndexInput input)
         {
-            size = input.ReadInt(); // (re)read size
-            count = input.ReadInt(); // read count
+            size = input.ReadInt32(); // (re)read size
+            count = input.ReadInt32(); // read count
             bits = new byte[GetNumBytes(size)]; // allocate bits
             for (int i = 0; i < bits.Length; ++i)
             {
@@ -525,7 +525,7 @@ namespace Lucene.Net.Codecs.Lucene40
             int numCleared = Length - Count();
             while (numCleared > 0)
             {
-                last += input.ReadVInt();
+                last += input.ReadVInt32();
                 bits[last] = input.ReadByte();
                 numCleared -= 8 - BitUtil.BitCount(bits[last]);
                 Debug.Assert(numCleared >= 0 || (last == (bits.Length - 1) && numCleared == -(8 - (size & 7))));

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Codecs/Lucene40/Lucene40DocValuesReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/Lucene40/Lucene40DocValuesReader.cs b/src/Lucene.Net.Core/Codecs/Lucene40/Lucene40DocValuesReader.cs
index e9039f5..7f53820 100644
--- a/src/Lucene.Net.Core/Codecs/Lucene40/Lucene40DocValuesReader.cs
+++ b/src/Lucene.Net.Core/Codecs/Lucene40/Lucene40DocValuesReader.cs
@@ -86,7 +86,7 @@ namespace Lucene.Net.Codecs.Lucene40
                         //{
                         if (type == LegacyDocValuesType.VAR_INTS)
                         {
-                            instance = LoadVarIntsField(field, input);
+                            instance = LoadVarInt32sField(field, input);
                         }
                         else if (type == LegacyDocValuesType.FIXED_INTS_8)
                         {
@@ -94,19 +94,19 @@ namespace Lucene.Net.Codecs.Lucene40
                         }
                         else if (type == LegacyDocValuesType.FIXED_INTS_16)
                         {
-                            instance = LoadShortField(field, input);
+                            instance = LoadInt16Field(field, input);
                         }
                         else if (type == LegacyDocValuesType.FIXED_INTS_32)
                         {
-                            instance = LoadIntField(field, input);
+                            instance = LoadInt32Field(field, input);
                         }
                         else if (type == LegacyDocValuesType.FIXED_INTS_64)
                         {
-                            instance = LoadLongField(field, input);
+                            instance = LoadInt64Field(field, input);
                         }
                         else if (type == LegacyDocValuesType.FLOAT_32)
                         {
-                            instance = LoadFloatField(field, input);
+                            instance = LoadSingleField(field, input);
                         }
                         else if (type == LegacyDocValuesType.FLOAT_64)
                         {
@@ -137,7 +137,10 @@ namespace Lucene.Net.Codecs.Lucene40
             }
         }
 
-        private NumericDocValues LoadVarIntsField(FieldInfo field, IndexInput input)
+        /// <summary>
+        /// NOTE: This was loadVarIntsField() in Lucene
+        /// </summary>
+        private NumericDocValues LoadVarInt32sField(FieldInfo field, IndexInput input)
         {
             CodecUtil.CheckHeader(input, Lucene40DocValuesFormat.VAR_INTS_CODEC_NAME, Lucene40DocValuesFormat.VAR_INTS_VERSION_START, Lucene40DocValuesFormat.VAR_INTS_VERSION_CURRENT);
             var header = (sbyte)input.ReadByte();
@@ -147,15 +150,15 @@ namespace Lucene.Net.Codecs.Lucene40
                 var values = new long[maxDoc];
                 for (int i = 0; i < values.Length; i++)
                 {
-                    values[i] = input.ReadLong();
+                    values[i] = input.ReadInt64();
                 }
                 ramBytesUsed.AddAndGet(RamUsageEstimator.SizeOf(values));
                 return new NumericDocValuesAnonymousInnerClassHelper(values);
             }
             else if (header == Lucene40DocValuesFormat.VAR_INTS_PACKED)
             {
-                long minValue = input.ReadLong();
-                long defaultValue = input.ReadLong();
+                long minValue = input.ReadInt64();
+                long defaultValue = input.ReadInt64();
                 PackedInts.Reader reader = PackedInts.GetReader(input);
                 ramBytesUsed.AddAndGet(reader.RamBytesUsed());
                 return new NumericDocValuesAnonymousInnerClassHelper2(minValue, defaultValue, reader);
@@ -211,7 +214,7 @@ namespace Lucene.Net.Codecs.Lucene40
         private NumericDocValues LoadByteField(FieldInfo field, IndexInput input)
         {
             CodecUtil.CheckHeader(input, Lucene40DocValuesFormat.INTS_CODEC_NAME, Lucene40DocValuesFormat.INTS_VERSION_START, Lucene40DocValuesFormat.INTS_VERSION_CURRENT);
-            int valueSize = input.ReadInt();
+            int valueSize = input.ReadInt32();
             if (valueSize != 1)
             {
                 throw new CorruptIndexException("invalid valueSize: " + valueSize);
@@ -238,10 +241,13 @@ namespace Lucene.Net.Codecs.Lucene40
             }
         }
 
-        private NumericDocValues LoadShortField(FieldInfo field, IndexInput input)
+        /// <summary>
+        /// NOTE: This was loadShortField() in Lucene
+        /// </summary>
+        private NumericDocValues LoadInt16Field(FieldInfo field, IndexInput input)
         {
             CodecUtil.CheckHeader(input, Lucene40DocValuesFormat.INTS_CODEC_NAME, Lucene40DocValuesFormat.INTS_VERSION_START, Lucene40DocValuesFormat.INTS_VERSION_CURRENT);
-            int valueSize = input.ReadInt();
+            int valueSize = input.ReadInt32();
             if (valueSize != 2)
             {
                 throw new CorruptIndexException("invalid valueSize: " + valueSize);
@@ -250,7 +256,7 @@ namespace Lucene.Net.Codecs.Lucene40
             short[] values = new short[maxDoc];
             for (int i = 0; i < values.Length; i++)
             {
-                values[i] = input.ReadShort();
+                values[i] = input.ReadInt16();
             }
             ramBytesUsed.AddAndGet(RamUsageEstimator.SizeOf(values));
             return new NumericDocValuesAnonymousInnerClassHelper4(values);
@@ -271,10 +277,13 @@ namespace Lucene.Net.Codecs.Lucene40
             }
         }
 
-        private NumericDocValues LoadIntField(FieldInfo field, IndexInput input)
+        /// <summary>
+        /// NOTE: This was loadIntField() in Lucene
+        /// </summary>
+        private NumericDocValues LoadInt32Field(FieldInfo field, IndexInput input)
         {
             CodecUtil.CheckHeader(input, Lucene40DocValuesFormat.INTS_CODEC_NAME, Lucene40DocValuesFormat.INTS_VERSION_START, Lucene40DocValuesFormat.INTS_VERSION_CURRENT);
-            int valueSize = input.ReadInt();
+            int valueSize = input.ReadInt32();
             if (valueSize != 4)
             {
                 throw new CorruptIndexException("invalid valueSize: " + valueSize);
@@ -283,7 +292,7 @@ namespace Lucene.Net.Codecs.Lucene40
             var values = new int[maxDoc];
             for (int i = 0; i < values.Length; i++)
             {
-                values[i] = input.ReadInt();
+                values[i] = input.ReadInt32();
             }
             ramBytesUsed.AddAndGet(RamUsageEstimator.SizeOf(values));
             return new NumericDocValuesAnonymousInnerClassHelper5(values);
@@ -304,10 +313,13 @@ namespace Lucene.Net.Codecs.Lucene40
             }
         }
 
-        private NumericDocValues LoadLongField(FieldInfo field, IndexInput input)
+        /// <summary>
+        /// NOTE: This was loadLongField() in Lucene
+        /// </summary>
+        private NumericDocValues LoadInt64Field(FieldInfo field, IndexInput input)
         {
             CodecUtil.CheckHeader(input, Lucene40DocValuesFormat.INTS_CODEC_NAME, Lucene40DocValuesFormat.INTS_VERSION_START, Lucene40DocValuesFormat.INTS_VERSION_CURRENT);
-            int valueSize = input.ReadInt();
+            int valueSize = input.ReadInt32();
             if (valueSize != 8)
             {
                 throw new CorruptIndexException("invalid valueSize: " + valueSize);
@@ -316,7 +328,7 @@ namespace Lucene.Net.Codecs.Lucene40
             long[] values = new long[maxDoc];
             for (int i = 0; i < values.Length; i++)
             {
-                values[i] = input.ReadLong();
+                values[i] = input.ReadInt64();
             }
             ramBytesUsed.AddAndGet(RamUsageEstimator.SizeOf(values));
             return new NumericDocValuesAnonymousInnerClassHelper6(values);
@@ -337,10 +349,13 @@ namespace Lucene.Net.Codecs.Lucene40
             }
         }
 
-        private NumericDocValues LoadFloatField(FieldInfo field, IndexInput input)
+        /// <summary>
+        /// NOTE: This was loadFloatField() in Lucene
+        /// </summary>
+        private NumericDocValues LoadSingleField(FieldInfo field, IndexInput input)
         {
             CodecUtil.CheckHeader(input, Lucene40DocValuesFormat.FLOATS_CODEC_NAME, Lucene40DocValuesFormat.FLOATS_VERSION_START, Lucene40DocValuesFormat.FLOATS_VERSION_CURRENT);
-            int valueSize = input.ReadInt();
+            int valueSize = input.ReadInt32();
             if (valueSize != 4)
             {
                 throw new CorruptIndexException("invalid valueSize: " + valueSize);
@@ -349,7 +364,7 @@ namespace Lucene.Net.Codecs.Lucene40
             int[] values = new int[maxDoc];
             for (int i = 0; i < values.Length; i++)
             {
-                values[i] = input.ReadInt();
+                values[i] = input.ReadInt32();
             }
             ramBytesUsed.AddAndGet(RamUsageEstimator.SizeOf(values));
             return new NumericDocValuesAnonymousInnerClassHelper7(values);
@@ -373,7 +388,7 @@ namespace Lucene.Net.Codecs.Lucene40
         private NumericDocValues LoadDoubleField(FieldInfo field, IndexInput input)
         {
             CodecUtil.CheckHeader(input, Lucene40DocValuesFormat.FLOATS_CODEC_NAME, Lucene40DocValuesFormat.FLOATS_VERSION_START, Lucene40DocValuesFormat.FLOATS_VERSION_CURRENT);
-            int valueSize = input.ReadInt();
+            int valueSize = input.ReadInt32();
             if (valueSize != 8)
             {
                 throw new CorruptIndexException("invalid valueSize: " + valueSize);
@@ -382,7 +397,7 @@ namespace Lucene.Net.Codecs.Lucene40
             long[] values = new long[maxDoc];
             for (int i = 0; i < values.Length; i++)
             {
-                values[i] = input.ReadLong();
+                values[i] = input.ReadInt64();
             }
             ramBytesUsed.AddAndGet(RamUsageEstimator.SizeOf(values));
             return new NumericDocValuesAnonymousInnerClassHelper8(values);
@@ -446,7 +461,7 @@ namespace Lucene.Net.Codecs.Lucene40
             try
             {
                 CodecUtil.CheckHeader(input, Lucene40DocValuesFormat.BYTES_FIXED_STRAIGHT_CODEC_NAME, Lucene40DocValuesFormat.BYTES_FIXED_STRAIGHT_VERSION_START, Lucene40DocValuesFormat.BYTES_FIXED_STRAIGHT_VERSION_CURRENT);
-                int fixedLength = input.ReadInt();
+                int fixedLength = input.ReadInt32();
                 var bytes = new PagedBytes(16);
                 bytes.Copy(input, fixedLength * (long)state.SegmentInfo.DocCount);
                 PagedBytes.Reader bytesReader = bytes.Freeze(true);
@@ -498,7 +513,7 @@ namespace Lucene.Net.Codecs.Lucene40
                 CodecUtil.CheckHeader(data, Lucene40DocValuesFormat.BYTES_VAR_STRAIGHT_CODEC_NAME_DAT, Lucene40DocValuesFormat.BYTES_VAR_STRAIGHT_VERSION_START, Lucene40DocValuesFormat.BYTES_VAR_STRAIGHT_VERSION_CURRENT);
                 index = dir.OpenInput(indexName, state.Context);
                 CodecUtil.CheckHeader(index, Lucene40DocValuesFormat.BYTES_VAR_STRAIGHT_CODEC_NAME_IDX, Lucene40DocValuesFormat.BYTES_VAR_STRAIGHT_VERSION_START, Lucene40DocValuesFormat.BYTES_VAR_STRAIGHT_VERSION_CURRENT);
-                long totalBytes = index.ReadVLong();
+                long totalBytes = index.ReadVInt64();
                 PagedBytes bytes = new PagedBytes(16);
                 bytes.Copy(data, totalBytes);
                 PagedBytes.Reader bytesReader = bytes.Freeze(true);
@@ -555,8 +570,8 @@ namespace Lucene.Net.Codecs.Lucene40
                 index = dir.OpenInput(indexName, state.Context);
                 CodecUtil.CheckHeader(index, Lucene40DocValuesFormat.BYTES_FIXED_DEREF_CODEC_NAME_IDX, Lucene40DocValuesFormat.BYTES_FIXED_DEREF_VERSION_START, Lucene40DocValuesFormat.BYTES_FIXED_DEREF_VERSION_CURRENT);
 
-                int fixedLength = data.ReadInt();
-                int valueCount = index.ReadInt();
+                int fixedLength = data.ReadInt32();
+                int valueCount = index.ReadInt32();
                 PagedBytes bytes = new PagedBytes(16);
                 bytes.Copy(data, fixedLength * (long)valueCount);
                 PagedBytes.Reader bytesReader = bytes.Freeze(true);
@@ -614,7 +629,7 @@ namespace Lucene.Net.Codecs.Lucene40
                 index = dir.OpenInput(indexName, state.Context);
                 CodecUtil.CheckHeader(index, Lucene40DocValuesFormat.BYTES_VAR_DEREF_CODEC_NAME_IDX, Lucene40DocValuesFormat.BYTES_VAR_DEREF_VERSION_START, Lucene40DocValuesFormat.BYTES_VAR_DEREF_VERSION_CURRENT);
 
-                long totalBytes = index.ReadLong();
+                long totalBytes = index.ReadInt64();
                 PagedBytes bytes = new PagedBytes(16);
                 bytes.Copy(data, totalBytes);
                 PagedBytes.Reader bytesReader = bytes.Freeze(true);
@@ -727,8 +742,8 @@ namespace Lucene.Net.Codecs.Lucene40
             CodecUtil.CheckHeader(data, Lucene40DocValuesFormat.BYTES_FIXED_SORTED_CODEC_NAME_DAT, Lucene40DocValuesFormat.BYTES_FIXED_SORTED_VERSION_START, Lucene40DocValuesFormat.BYTES_FIXED_SORTED_VERSION_CURRENT);
             CodecUtil.CheckHeader(index, Lucene40DocValuesFormat.BYTES_FIXED_SORTED_CODEC_NAME_IDX, Lucene40DocValuesFormat.BYTES_FIXED_SORTED_VERSION_START, Lucene40DocValuesFormat.BYTES_FIXED_SORTED_VERSION_CURRENT);
 
-            int fixedLength = data.ReadInt();
-            int valueCount = index.ReadInt();
+            int fixedLength = data.ReadInt32();
+            int valueCount = index.ReadInt32();
 
             PagedBytes bytes = new PagedBytes(16);
             bytes.Copy(data, fixedLength * (long)valueCount);
@@ -778,7 +793,7 @@ namespace Lucene.Net.Codecs.Lucene40
             CodecUtil.CheckHeader(data, Lucene40DocValuesFormat.BYTES_VAR_SORTED_CODEC_NAME_DAT, Lucene40DocValuesFormat.BYTES_VAR_SORTED_VERSION_START, Lucene40DocValuesFormat.BYTES_VAR_SORTED_VERSION_CURRENT);
             CodecUtil.CheckHeader(index, Lucene40DocValuesFormat.BYTES_VAR_SORTED_CODEC_NAME_IDX, Lucene40DocValuesFormat.BYTES_VAR_SORTED_VERSION_START, Lucene40DocValuesFormat.BYTES_VAR_SORTED_VERSION_CURRENT);
 
-            long maxAddress = index.ReadLong();
+            long maxAddress = index.ReadInt64();
             PagedBytes bytes = new PagedBytes(16);
             bytes.Copy(data, maxAddress);
             PagedBytes.Reader bytesReader = bytes.Freeze(true);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Codecs/Lucene40/Lucene40FieldInfosReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/Lucene40/Lucene40FieldInfosReader.cs b/src/Lucene.Net.Core/Codecs/Lucene40/Lucene40FieldInfosReader.cs
index d6c529e..20fb09d 100644
--- a/src/Lucene.Net.Core/Codecs/Lucene40/Lucene40FieldInfosReader.cs
+++ b/src/Lucene.Net.Core/Codecs/Lucene40/Lucene40FieldInfosReader.cs
@@ -57,13 +57,13 @@ namespace Lucene.Net.Codecs.Lucene40
             {
                 CodecUtil.CheckHeader(input, Lucene40FieldInfosFormat.CODEC_NAME, Lucene40FieldInfosFormat.FORMAT_START, Lucene40FieldInfosFormat.FORMAT_CURRENT);
 
-                int size = input.ReadVInt(); //read in the size
+                int size = input.ReadVInt32(); //read in the size
                 FieldInfo[] infos = new FieldInfo[size];
 
                 for (int i = 0; i < size; i++)
                 {
                     string name = input.ReadString();
-                    int fieldNumber = input.ReadVInt();
+                    int fieldNumber = input.ReadVInt32();
                     byte bits = input.ReadByte();
                     bool isIndexed = (bits & Lucene40FieldInfosFormat.IS_INDEXED) != 0;
                     bool storeTermVector = (bits & Lucene40FieldInfosFormat.STORE_TERMVECTOR) != 0;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Codecs/Lucene40/Lucene40PostingsReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/Lucene40/Lucene40PostingsReader.cs b/src/Lucene.Net.Core/Codecs/Lucene40/Lucene40PostingsReader.cs
index abb8876..2c2ffca 100644
--- a/src/Lucene.Net.Core/Codecs/Lucene40/Lucene40PostingsReader.cs
+++ b/src/Lucene.Net.Core/Codecs/Lucene40/Lucene40PostingsReader.cs
@@ -114,9 +114,9 @@ namespace Lucene.Net.Codecs.Lucene40
             // Make sure we are talking to the matching past writer
             CodecUtil.CheckHeader(termsIn, TERMS_CODEC, VERSION_START, VERSION_CURRENT);
 
-            skipInterval = termsIn.ReadInt();
-            maxSkipLevels = termsIn.ReadInt();
-            skipMinimum = termsIn.ReadInt();
+            skipInterval = termsIn.ReadInt32();
+            maxSkipLevels = termsIn.ReadInt32();
+            skipMinimum = termsIn.ReadInt32();
         }
 
         // Must keep final because we do non-standard clone
@@ -185,7 +185,7 @@ namespace Lucene.Net.Codecs.Lucene40
                 termState2.proxOffset = 0;
             }
 
-            termState2.freqOffset += @in.ReadVLong();
+            termState2.freqOffset += @in.ReadVInt64();
             /*
             if (DEBUG) {
               System.out.println("  dF=" + termState2.docFreq);
@@ -196,7 +196,7 @@ namespace Lucene.Net.Codecs.Lucene40
 
             if (termState2.DocFreq >= skipMinimum)
             {
-                termState2.skipOffset = @in.ReadVLong();
+                termState2.skipOffset = @in.ReadVInt64();
                 // if (DEBUG) System.out.println("  skipOffset=" + termState2.skipOffset + " vs freqIn.length=" + freqIn.length());
                 Debug.Assert(termState2.freqOffset + termState2.skipOffset < freqIn.Length);
             }
@@ -207,7 +207,7 @@ namespace Lucene.Net.Codecs.Lucene40
 
             if (fieldInfo.IndexOptions >= IndexOptions.DOCS_AND_FREQS_AND_POSITIONS)
             {
-                termState2.proxOffset += @in.ReadVLong();
+                termState2.proxOffset += @in.ReadVInt64();
                 // if (DEBUG) System.out.println("  proxFP=" + termState2.proxOffset);
             }
         }
@@ -435,7 +435,7 @@ namespace Lucene.Net.Codecs.Lucene40
                 }
                 else
                 {
-                    return freqIn.ReadVInt(); // else read freq
+                    return freqIn.ReadVInt32(); // else read freq
                 }
             }
 
@@ -475,7 +475,7 @@ namespace Lucene.Net.Codecs.Lucene40
                 int docAc = m_accum;
                 for (int i = 0; i < size; i++)
                 {
-                    docAc += freqIn.ReadVInt();
+                    docAc += freqIn.ReadVInt32();
                     docs[i] = docAc;
                 }
                 m_accum = docAc;
@@ -490,7 +490,7 @@ namespace Lucene.Net.Codecs.Lucene40
                 int docAc = m_accum;
                 for (int i = 0; i < size; i++)
                 {
-                    int code = freqIn.ReadVInt();
+                    int code = freqIn.ReadVInt32();
                     docAc += (int)((uint)code >> 1); // shift off low bit
                     freqs[i] = ReadFreq(freqIn, code);
                     docs[i] = docAc;
@@ -590,7 +590,7 @@ namespace Lucene.Net.Codecs.Lucene40
                 int loopLimit = m_limit;
                 for (int i = m_ord; i < loopLimit; i++)
                 {
-                    int code = freqIn.ReadVInt();
+                    int code = freqIn.ReadVInt32();
                     if (omitTF)
                     {
                         docAcc += code;
@@ -617,7 +617,7 @@ namespace Lucene.Net.Codecs.Lucene40
             {
                 if (m_ord++ < m_limit)
                 {
-                    int code = freqIn.ReadVInt();
+                    int code = freqIn.ReadVInt32();
                     if (m_indexOmitsTF)
                     {
                         m_accum += code;
@@ -692,7 +692,7 @@ namespace Lucene.Net.Codecs.Lucene40
                 IBits liveDocs = this.m_liveDocs;
                 for (int i = m_ord; i < loopLimit; i++)
                 {
-                    int code = freqIn.ReadVInt();
+                    int code = freqIn.ReadVInt32();
                     if (omitTF)
                     {
                         docAcc += code;
@@ -725,7 +725,7 @@ namespace Lucene.Net.Codecs.Lucene40
                 IBits liveDocs = this.m_liveDocs;
                 for (int i = m_ord; i < loopLimit; i++)
                 {
-                    int code = freqIn.ReadVInt();
+                    int code = freqIn.ReadVInt32();
                     if (omitTF)
                     {
                         docAcc += code;
@@ -832,7 +832,7 @@ namespace Lucene.Net.Codecs.Lucene40
                     ord++;
 
                     // Decode next doc/freq pair
-                    int code = freqIn.ReadVInt();
+                    int code = freqIn.ReadVInt32();
 
                     accum += (int)((uint)code >> 1); // shift off low bit
                     if ((code & 1) != 0) // if low bit is set
@@ -841,7 +841,7 @@ namespace Lucene.Net.Codecs.Lucene40
                     }
                     else
                     {
-                        freq = freqIn.ReadVInt(); // else read freq
+                        freq = freqIn.ReadVInt32(); // else read freq
                     }
                     posPendingCount += freq;
 
@@ -937,7 +937,7 @@ namespace Lucene.Net.Codecs.Lucene40
                     }
                 }
 
-                position += proxIn.ReadVInt();
+                position += proxIn.ReadVInt32();
 
                 posPendingCount--;
 
@@ -1068,7 +1068,7 @@ namespace Lucene.Net.Codecs.Lucene40
                     ord++;
 
                     // Decode next doc/freq pair
-                    int code = freqIn.ReadVInt();
+                    int code = freqIn.ReadVInt32();
 
                     accum += (int)((uint)code >> 1); // shift off low bit
                     if ((code & 1) != 0) // if low bit is set
@@ -1077,7 +1077,7 @@ namespace Lucene.Net.Codecs.Lucene40
                     }
                     else
                     {
-                        freq = freqIn.ReadVInt(); // else read freq
+                        freq = freqIn.ReadVInt32(); // else read freq
                     }
                     posPendingCount += freq;
 
@@ -1175,14 +1175,14 @@ namespace Lucene.Net.Codecs.Lucene40
                 // scan over any docs that were iterated without their positions
                 while (posPendingCount > freq)
                 {
-                    int code = proxIn.ReadVInt();
+                    int code = proxIn.ReadVInt32();
 
                     if (storePayloads)
                     {
                         if ((code & 1) != 0)
                         {
                             // new payload length
-                            payloadLength = proxIn.ReadVInt();
+                            payloadLength = proxIn.ReadVInt32();
                             Debug.Assert(payloadLength >= 0);
                         }
                         Debug.Assert(payloadLength != -1);
@@ -1190,10 +1190,10 @@ namespace Lucene.Net.Codecs.Lucene40
 
                     if (storeOffsets)
                     {
-                        if ((proxIn.ReadVInt() & 1) != 0)
+                        if ((proxIn.ReadVInt32() & 1) != 0)
                         {
                             // new offset length
-                            offsetLength = proxIn.ReadVInt();
+                            offsetLength = proxIn.ReadVInt32();
                         }
                     }
 
@@ -1216,13 +1216,13 @@ namespace Lucene.Net.Codecs.Lucene40
                     proxIn.Seek(proxIn.FilePointer + payloadLength);
                 }
 
-                int code_ = proxIn.ReadVInt();
+                int code_ = proxIn.ReadVInt32();
                 if (storePayloads)
                 {
                     if ((code_ & 1) != 0)
                     {
                         // new payload length
-                        payloadLength = proxIn.ReadVInt();
+                        payloadLength = proxIn.ReadVInt32();
                         Debug.Assert(payloadLength >= 0);
                     }
                     Debug.Assert(payloadLength != -1);
@@ -1234,11 +1234,11 @@ namespace Lucene.Net.Codecs.Lucene40
 
                 if (storeOffsets)
                 {
-                    int offsetCode = proxIn.ReadVInt();
+                    int offsetCode = proxIn.ReadVInt32();
                     if ((offsetCode & 1) != 0)
                     {
                         // new offset length
-                        offsetLength = proxIn.ReadVInt();
+                        offsetLength = proxIn.ReadVInt32();
                     }
                     startOffset += (int)((uint)offsetCode >> 1);
                 }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Codecs/Lucene40/Lucene40SegmentInfoReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/Lucene40/Lucene40SegmentInfoReader.cs b/src/Lucene.Net.Core/Codecs/Lucene40/Lucene40SegmentInfoReader.cs
index c53981f..aec213d 100644
--- a/src/Lucene.Net.Core/Codecs/Lucene40/Lucene40SegmentInfoReader.cs
+++ b/src/Lucene.Net.Core/Codecs/Lucene40/Lucene40SegmentInfoReader.cs
@@ -52,7 +52,7 @@ namespace Lucene.Net.Codecs.Lucene40
             {
                 CodecUtil.CheckHeader(input, Lucene40SegmentInfoFormat.CODEC_NAME, Lucene40SegmentInfoFormat.VERSION_START, Lucene40SegmentInfoFormat.VERSION_CURRENT);
                 string version = input.ReadString();
-                int docCount = input.ReadInt();
+                int docCount = input.ReadInt32();
                 if (docCount < 0)
                 {
                     throw new CorruptIndexException("invalid docCount: " + docCount + " (resource=" + input + ")");

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Codecs/Lucene40/Lucene40SegmentInfoWriter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/Lucene40/Lucene40SegmentInfoWriter.cs b/src/Lucene.Net.Core/Codecs/Lucene40/Lucene40SegmentInfoWriter.cs
index a75f066..a2d2925 100644
--- a/src/Lucene.Net.Core/Codecs/Lucene40/Lucene40SegmentInfoWriter.cs
+++ b/src/Lucene.Net.Core/Codecs/Lucene40/Lucene40SegmentInfoWriter.cs
@@ -57,7 +57,7 @@ namespace Lucene.Net.Codecs.Lucene40
                 CodecUtil.WriteHeader(output, Lucene40SegmentInfoFormat.CODEC_NAME, Lucene40SegmentInfoFormat.VERSION_CURRENT);
                 // Write the Lucene version that created this segment, since 3.1
                 output.WriteString(si.Version);
-                output.WriteInt(si.DocCount);
+                output.WriteInt32(si.DocCount);
 
                 output.WriteByte((byte)(sbyte)(si.UseCompoundFile ? SegmentInfo.YES : SegmentInfo.NO));
                 output.WriteStringStringMap(si.Diagnostics);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Codecs/Lucene40/Lucene40SkipListReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/Lucene40/Lucene40SkipListReader.cs b/src/Lucene.Net.Core/Codecs/Lucene40/Lucene40SkipListReader.cs
index 1230dec..cacafe5 100644
--- a/src/Lucene.Net.Core/Codecs/Lucene40/Lucene40SkipListReader.cs
+++ b/src/Lucene.Net.Core/Codecs/Lucene40/Lucene40SkipListReader.cs
@@ -148,27 +148,27 @@ namespace Lucene.Net.Codecs.Lucene40
                 // to read the current payload/offset lengths
                 // because it differs from the lengths of the
                 // previous payload/offset
-                delta = skipStream.ReadVInt();
+                delta = skipStream.ReadVInt32();
                 if ((delta & 1) != 0)
                 {
                     if (currentFieldStoresPayloads)
                     {
-                        payloadLength[level] = skipStream.ReadVInt();
+                        payloadLength[level] = skipStream.ReadVInt32();
                     }
                     if (currentFieldStoresOffsets)
                     {
-                        offsetLength[level] = skipStream.ReadVInt();
+                        offsetLength[level] = skipStream.ReadVInt32();
                     }
                 }
                 delta = (int)((uint)delta >> 1);
             }
             else
             {
-                delta = skipStream.ReadVInt();
+                delta = skipStream.ReadVInt32();
             }
 
-            freqPointer[level] += skipStream.ReadVInt();
-            proxPointer[level] += skipStream.ReadVInt();
+            freqPointer[level] += skipStream.ReadVInt32();
+            proxPointer[level] += skipStream.ReadVInt32();
 
             return delta;
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Codecs/Lucene40/Lucene40StoredFieldsReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/Lucene40/Lucene40StoredFieldsReader.cs b/src/Lucene.Net.Core/Codecs/Lucene40/Lucene40StoredFieldsReader.cs
index 9edb75e..ad88ab3 100644
--- a/src/Lucene.Net.Core/Codecs/Lucene40/Lucene40StoredFieldsReader.cs
+++ b/src/Lucene.Net.Core/Codecs/Lucene40/Lucene40StoredFieldsReader.cs
@@ -163,12 +163,12 @@ namespace Lucene.Net.Codecs.Lucene40
         public override void VisitDocument(int n, StoredFieldVisitor visitor)
         {
             SeekIndex(n);
-            fieldsStream.Seek(indexStream.ReadLong());
+            fieldsStream.Seek(indexStream.ReadInt64());
 
-            int numFields = fieldsStream.ReadVInt();
+            int numFields = fieldsStream.ReadVInt32();
             for (int fieldIDX = 0; fieldIDX < numFields; fieldIDX++)
             {
-                int fieldNumber = fieldsStream.ReadVInt();
+                int fieldNumber = fieldsStream.ReadVInt32();
                 FieldInfo fieldInfo = fieldInfos.FieldInfo(fieldNumber);
 
                 int bits = fieldsStream.ReadByte() & 0xFF;
@@ -198,19 +198,19 @@ namespace Lucene.Net.Codecs.Lucene40
                 switch (numeric)
                 {
                     case Lucene40StoredFieldsWriter.FIELD_IS_NUMERIC_INT:
-                        visitor.Int32Field(info, fieldsStream.ReadInt());
+                        visitor.Int32Field(info, fieldsStream.ReadInt32());
                         return;
 
                     case Lucene40StoredFieldsWriter.FIELD_IS_NUMERIC_LONG:
-                        visitor.Int64Field(info, fieldsStream.ReadLong());
+                        visitor.Int64Field(info, fieldsStream.ReadInt64());
                         return;
 
                     case Lucene40StoredFieldsWriter.FIELD_IS_NUMERIC_FLOAT:
-                        visitor.SingleField(info, Number.IntBitsToFloat(fieldsStream.ReadInt()));
+                        visitor.SingleField(info, Number.Int32BitsToSingle(fieldsStream.ReadInt32()));
                         return;
 
                     case Lucene40StoredFieldsWriter.FIELD_IS_NUMERIC_DOUBLE:
-                        visitor.DoubleField(info, BitConverter.Int64BitsToDouble(fieldsStream.ReadLong()));
+                        visitor.DoubleField(info, BitConverter.Int64BitsToDouble(fieldsStream.ReadInt64()));
                         return;
 
                     default:
@@ -219,7 +219,7 @@ namespace Lucene.Net.Codecs.Lucene40
             }
             else
             {
-                int length = fieldsStream.ReadVInt();
+                int length = fieldsStream.ReadVInt32();
                 var bytes = new byte[length];
                 fieldsStream.ReadBytes(bytes, 0, length);
                 if ((bits & Lucene40StoredFieldsWriter.FIELD_IS_BINARY) != 0)
@@ -244,12 +244,12 @@ namespace Lucene.Net.Codecs.Lucene40
                 {
                     case Lucene40StoredFieldsWriter.FIELD_IS_NUMERIC_INT:
                     case Lucene40StoredFieldsWriter.FIELD_IS_NUMERIC_FLOAT:
-                        fieldsStream.ReadInt();
+                        fieldsStream.ReadInt32();
                         return;
 
                     case Lucene40StoredFieldsWriter.FIELD_IS_NUMERIC_LONG:
                     case Lucene40StoredFieldsWriter.FIELD_IS_NUMERIC_DOUBLE:
-                        fieldsStream.ReadLong();
+                        fieldsStream.ReadInt64();
                         return;
 
                     default:
@@ -258,7 +258,7 @@ namespace Lucene.Net.Codecs.Lucene40
             }
             else
             {
-                int length = fieldsStream.ReadVInt();
+                int length = fieldsStream.ReadVInt32();
                 fieldsStream.Seek(fieldsStream.FilePointer + length);
             }
         }
@@ -272,7 +272,7 @@ namespace Lucene.Net.Codecs.Lucene40
         public IndexInput RawDocs(int[] lengths, int startDocID, int numDocs)
         {
             SeekIndex(startDocID);
-            long startOffset = indexStream.ReadLong();
+            long startOffset = indexStream.ReadInt64();
             long lastOffset = startOffset;
             int count = 0;
             while (count < numDocs)
@@ -282,7 +282,7 @@ namespace Lucene.Net.Codecs.Lucene40
                 Debug.Assert(docID <= numTotalDocs);
                 if (docID < numTotalDocs)
                 {
-                    offset = indexStream.ReadLong();
+                    offset = indexStream.ReadInt64();
                 }
                 else
                 {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Codecs/Lucene40/Lucene40StoredFieldsWriter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/Lucene40/Lucene40StoredFieldsWriter.cs b/src/Lucene.Net.Core/Codecs/Lucene40/Lucene40StoredFieldsWriter.cs
index 907b8b8..2083d1a 100644
--- a/src/Lucene.Net.Core/Codecs/Lucene40/Lucene40StoredFieldsWriter.cs
+++ b/src/Lucene.Net.Core/Codecs/Lucene40/Lucene40StoredFieldsWriter.cs
@@ -118,8 +118,8 @@ namespace Lucene.Net.Codecs.Lucene40
         // in the correct fields format.
         public override void StartDocument(int numStoredFields)
         {
-            indexStream.WriteLong(fieldsStream.FilePointer);
-            fieldsStream.WriteVInt(numStoredFields);
+            indexStream.WriteInt64(fieldsStream.FilePointer);
+            fieldsStream.WriteVInt32(numStoredFields);
         }
 
         protected override void Dispose(bool disposing)
@@ -151,7 +151,7 @@ namespace Lucene.Net.Codecs.Lucene40
 
         public override void WriteField(FieldInfo info, IIndexableField field)
         {
-            fieldsStream.WriteVInt(info.Number);
+            fieldsStream.WriteVInt32(info.Number);
             int bits = 0;
             BytesRef bytes;
             string @string;
@@ -208,7 +208,7 @@ namespace Lucene.Net.Codecs.Lucene40
 
             if (bytes != null)
             {
-                fieldsStream.WriteVInt(bytes.Length);
+                fieldsStream.WriteVInt32(bytes.Length);
                 fieldsStream.WriteBytes(bytes.Bytes, bytes.Offset, bytes.Length);
             }
             else if (@string != null)
@@ -219,19 +219,19 @@ namespace Lucene.Net.Codecs.Lucene40
             {
                 if (number is sbyte || number is short || number is int)
                 {
-                    fieldsStream.WriteInt((int)number);
+                    fieldsStream.WriteInt32((int)number);
                 }
                 else if (number is long)
                 {
-                    fieldsStream.WriteLong((long)number);
+                    fieldsStream.WriteInt64((long)number);
                 }
                 else if (number is float)
                 {
-                    fieldsStream.WriteInt(Number.FloatToIntBits((float)number));
+                    fieldsStream.WriteInt32(Number.SingleToInt32Bits((float)number));
                 }
                 else if (number is double)
                 {
-                    fieldsStream.WriteLong(BitConverter.DoubleToInt64Bits((double)number));
+                    fieldsStream.WriteInt64(BitConverter.DoubleToInt64Bits((double)number));
                 }
                 else
                 {
@@ -253,7 +253,7 @@ namespace Lucene.Net.Codecs.Lucene40
             long start = position;
             for (int i = 0; i < numDocs; i++)
             {
-                indexStream.WriteLong(position);
+                indexStream.WriteInt64(position);
                 position += lengths[i];
             }
             fieldsStream.CopyBytes(stream, position - start);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Codecs/Lucene40/Lucene40TermVectorsReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/Lucene40/Lucene40TermVectorsReader.cs b/src/Lucene.Net.Core/Codecs/Lucene40/Lucene40TermVectorsReader.cs
index d75ffef..52f3ea3 100644
--- a/src/Lucene.Net.Core/Codecs/Lucene40/Lucene40TermVectorsReader.cs
+++ b/src/Lucene.Net.Core/Codecs/Lucene40/Lucene40TermVectorsReader.cs
@@ -197,10 +197,10 @@ namespace Lucene.Net.Codecs.Lucene40
 
             SeekTvx(startDocID);
 
-            long tvdPosition = tvx.ReadLong();
+            long tvdPosition = tvx.ReadInt64();
             tvd.Seek(tvdPosition);
 
-            long tvfPosition = tvx.ReadLong();
+            long tvfPosition = tvx.ReadInt64();
             tvf.Seek(tvfPosition);
 
             long lastTvdPosition = tvdPosition;
@@ -213,8 +213,8 @@ namespace Lucene.Net.Codecs.Lucene40
                 Debug.Assert(docID <= numTotalDocs);
                 if (docID < numTotalDocs)
                 {
-                    tvdPosition = tvx.ReadLong();
-                    tvfPosition = tvx.ReadLong();
+                    tvdPosition = tvx.ReadInt64();
+                    tvfPosition = tvx.ReadInt64();
                 }
                 else
                 {
@@ -257,9 +257,9 @@ namespace Lucene.Net.Codecs.Lucene40
             {
                 this.outerInstance = outerInstance;
                 outerInstance.SeekTvx(docID);
-                outerInstance.tvd.Seek(outerInstance.tvx.ReadLong());
+                outerInstance.tvd.Seek(outerInstance.tvx.ReadInt64());
 
-                int fieldCount = outerInstance.tvd.ReadVInt();
+                int fieldCount = outerInstance.tvd.ReadVInt32();
                 Debug.Assert(fieldCount >= 0);
                 if (fieldCount != 0)
                 {
@@ -267,16 +267,16 @@ namespace Lucene.Net.Codecs.Lucene40
                     fieldFPs = new long[fieldCount];
                     for (int fieldUpto = 0; fieldUpto < fieldCount; fieldUpto++)
                     {
-                        int fieldNumber = outerInstance.tvd.ReadVInt();
+                        int fieldNumber = outerInstance.tvd.ReadVInt32();
                         fieldNumbers[fieldUpto] = fieldNumber;
                         fieldNumberToIndex[fieldNumber] = fieldUpto;
                     }
 
-                    long position = outerInstance.tvx.ReadLong();
+                    long position = outerInstance.tvx.ReadInt64();
                     fieldFPs[0] = position;
                     for (int fieldUpto = 1; fieldUpto < fieldCount; fieldUpto++)
                     {
-                        position += outerInstance.tvd.ReadVLong();
+                        position += outerInstance.tvd.ReadVInt64();
                         fieldFPs[fieldUpto] = position;
                     }
                 }
@@ -353,7 +353,7 @@ namespace Lucene.Net.Codecs.Lucene40
             {
                 this.outerInstance = outerInstance;
                 outerInstance.tvf.Seek(tvfFP);
-                numTerms = outerInstance.tvf.ReadVInt();
+                numTerms = outerInstance.tvf.ReadVInt32();
                 byte bits = outerInstance.tvf.ReadByte();
                 storePositions = (bits & STORE_POSITIONS_WITH_TERMVECTOR) != 0;
                 storeOffsets = (bits & STORE_OFFSET_WITH_TERMVECTOR) != 0;
@@ -542,12 +542,12 @@ namespace Lucene.Net.Codecs.Lucene40
                     return null;
                 }
                 term.CopyBytes(lastTerm);
-                int start = tvf.ReadVInt();
-                int deltaLen = tvf.ReadVInt();
+                int start = tvf.ReadVInt32();
+                int deltaLen = tvf.ReadVInt32();
                 term.Length = start + deltaLen;
                 term.Grow(term.Length);
                 tvf.ReadBytes(term.Bytes, start, deltaLen);
-                freq = tvf.ReadVInt();
+                freq = tvf.ReadVInt32();
 
                 if (storePayloads)
                 {
@@ -557,13 +557,13 @@ namespace Lucene.Net.Codecs.Lucene40
                     int pos = 0;
                     for (int posUpto = 0; posUpto < freq; posUpto++)
                     {
-                        int code = tvf.ReadVInt();
+                        int code = tvf.ReadVInt32();
                         pos += (int)((uint)code >> 1);
                         positions[posUpto] = pos;
                         if ((code & 1) != 0)
                         {
                             // length change
-                            lastPayloadLength = tvf.ReadVInt();
+                            lastPayloadLength = tvf.ReadVInt32();
                         }
                         payloadOffsets[posUpto] = totalPayloadLength;
                         totalPayloadLength += lastPayloadLength;
@@ -581,7 +581,7 @@ namespace Lucene.Net.Codecs.Lucene40
                     int pos = 0;
                     for (int posUpto = 0; posUpto < freq; posUpto++)
                     {
-                        pos += tvf.ReadVInt();
+                        pos += tvf.ReadVInt32();
                         positions[posUpto] = pos;
                     }
                 }
@@ -593,8 +593,8 @@ namespace Lucene.Net.Codecs.Lucene40
                     int offset = 0;
                     for (int posUpto = 0; posUpto < freq; posUpto++)
                     {
-                        startOffsets[posUpto] = offset + tvf.ReadVInt();
-                        offset = endOffsets[posUpto] = startOffsets[posUpto] + tvf.ReadVInt();
+                        startOffsets[posUpto] = offset + tvf.ReadVInt32();
+                        offset = endOffsets[posUpto] = startOffsets[posUpto] + tvf.ReadVInt32();
                     }
                 }
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Codecs/Lucene40/Lucene40TermVectorsWriter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/Lucene40/Lucene40TermVectorsWriter.cs b/src/Lucene.Net.Core/Codecs/Lucene40/Lucene40TermVectorsWriter.cs
index 0ed2847..d528a2c 100644
--- a/src/Lucene.Net.Core/Codecs/Lucene40/Lucene40TermVectorsWriter.cs
+++ b/src/Lucene.Net.Core/Codecs/Lucene40/Lucene40TermVectorsWriter.cs
@@ -93,9 +93,9 @@ namespace Lucene.Net.Codecs.Lucene40
         {
             lastFieldName = null;
             this.numVectorFields = numVectorFields;
-            tvx.WriteLong(tvd.FilePointer);
-            tvx.WriteLong(tvf.FilePointer);
-            tvd.WriteVInt(numVectorFields);
+            tvx.WriteInt64(tvd.FilePointer);
+            tvx.WriteInt64(tvf.FilePointer);
+            tvd.WriteVInt32(numVectorFields);
             fieldCount = 0;
             fps = ArrayUtil.Grow(fps, numVectorFields);
         }
@@ -115,8 +115,8 @@ namespace Lucene.Net.Codecs.Lucene40
             lastTerm.Length = 0;
             lastPayloadLength = -1; // force first payload to write its length
             fps[fieldCount++] = tvf.FilePointer;
-            tvd.WriteVInt(info.Number);
-            tvf.WriteVInt(numTerms);
+            tvd.WriteVInt32(info.Number);
+            tvf.WriteVInt32(numTerms);
             sbyte bits = 0x0;
             if (positions)
             {
@@ -138,7 +138,7 @@ namespace Lucene.Net.Codecs.Lucene40
             Debug.Assert(fieldCount == numVectorFields);
             for (int i = 1; i < fieldCount; i++)
             {
-                tvd.WriteVLong(fps[i] - fps[i - 1]);
+                tvd.WriteVInt64(fps[i] - fps[i - 1]);
             }
         }
 
@@ -160,10 +160,10 @@ namespace Lucene.Net.Codecs.Lucene40
         {
             int prefix = StringHelper.BytesDifference(lastTerm, term);
             int suffix = term.Length - prefix;
-            tvf.WriteVInt(prefix);
-            tvf.WriteVInt(suffix);
+            tvf.WriteVInt32(prefix);
+            tvf.WriteVInt32(suffix);
             tvf.WriteBytes(term.Bytes, term.Offset + prefix, suffix);
-            tvf.WriteVInt(freq);
+            tvf.WriteVInt32(freq);
             lastTerm.CopyBytes(term);
             lastPosition = lastOffset = 0;
 
@@ -192,10 +192,10 @@ namespace Lucene.Net.Codecs.Lucene40
                 // we do avoid buffering the offsets in RAM though.
                 for (int i = 0; i < numProx; i++)
                 {
-                    int code = positions.ReadVInt();
+                    int code = positions.ReadVInt32();
                     if ((code & 1) == 1)
                     {
-                        int length = positions.ReadVInt();
+                        int length = positions.ReadVInt32();
                         scratch.Grow(length);
                         scratch.Length = length;
                         positions.ReadBytes(scratch.Bytes, scratch.Offset, scratch.Length);
@@ -213,7 +213,7 @@ namespace Lucene.Net.Codecs.Lucene40
                 // pure positions, no payloads
                 for (int i = 0; i < numProx; i++)
                 {
-                    tvf.WriteVInt((int)((uint)positions.ReadVInt() >> 1));
+                    tvf.WriteVInt32((int)((uint)positions.ReadVInt32() >> 1));
                 }
             }
 
@@ -221,8 +221,8 @@ namespace Lucene.Net.Codecs.Lucene40
             {
                 for (int i = 0; i < numProx; i++)
                 {
-                    tvf.WriteVInt(offsets.ReadVInt());
-                    tvf.WriteVInt(offsets.ReadVInt());
+                    tvf.WriteVInt32(offsets.ReadVInt32());
+                    tvf.WriteVInt32(offsets.ReadVInt32());
                 }
             }
         }
@@ -253,8 +253,8 @@ namespace Lucene.Net.Codecs.Lucene40
             else if (offsets)
             {
                 // write offset deltas
-                tvf.WriteVInt(startOffset - lastOffset);
-                tvf.WriteVInt(endOffset - startOffset);
+                tvf.WriteVInt32(startOffset - lastOffset);
+                tvf.WriteVInt32(endOffset - startOffset);
                 lastOffset = endOffset;
             }
         }
@@ -274,8 +274,8 @@ namespace Lucene.Net.Codecs.Lucene40
                 {
                     for (int i = 0; i < bufferedIndex; i++)
                     {
-                        tvf.WriteVInt(offsetStartBuffer[i] - lastOffset);
-                        tvf.WriteVInt(offsetEndBuffer[i] - offsetStartBuffer[i]);
+                        tvf.WriteVInt32(offsetStartBuffer[i] - lastOffset);
+                        tvf.WriteVInt32(offsetEndBuffer[i] - offsetStartBuffer[i]);
                         lastOffset = offsetEndBuffer[i];
                     }
                 }
@@ -291,12 +291,12 @@ namespace Lucene.Net.Codecs.Lucene40
                 if (payloadLength != lastPayloadLength)
                 {
                     lastPayloadLength = payloadLength;
-                    tvf.WriteVInt((delta << 1) | 1);
-                    tvf.WriteVInt(payloadLength);
+                    tvf.WriteVInt32((delta << 1) | 1);
+                    tvf.WriteVInt32(payloadLength);
                 }
                 else
                 {
-                    tvf.WriteVInt(delta << 1);
+                    tvf.WriteVInt32(delta << 1);
                 }
                 if (payloadLength > 0)
                 {
@@ -311,7 +311,7 @@ namespace Lucene.Net.Codecs.Lucene40
             }
             else
             {
-                tvf.WriteVInt(delta);
+                tvf.WriteVInt32(delta);
             }
         }
 
@@ -345,9 +345,9 @@ namespace Lucene.Net.Codecs.Lucene40
             long tvfStart = tvfPosition;
             for (int i = 0; i < numDocs; i++)
             {
-                tvx.WriteLong(tvdPosition);
+                tvx.WriteInt64(tvdPosition);
                 tvdPosition += tvdLengths[i];
-                tvx.WriteLong(tvfPosition);
+                tvx.WriteInt64(tvfPosition);
                 tvfPosition += tvfLengths[i];
             }
             tvd.CopyBytes(reader.TvdStream, tvdPosition - tvdStart);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Codecs/Lucene41/ForUtil.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/Lucene41/ForUtil.cs b/src/Lucene.Net.Core/Codecs/Lucene41/ForUtil.cs
index aae7d91..2c17527 100644
--- a/src/Lucene.Net.Core/Codecs/Lucene41/ForUtil.cs
+++ b/src/Lucene.Net.Core/Codecs/Lucene41/ForUtil.cs
@@ -110,7 +110,7 @@ namespace Lucene.Net.Codecs.Lucene41
         /// </summary>
         internal ForUtil(float acceptableOverheadRatio, DataOutput @out)
         {
-            @out.WriteVInt(PackedInts.VERSION_CURRENT);
+            @out.WriteVInt32(PackedInts.VERSION_CURRENT);
             encodedSizes = new int[33];
             encoders = new PackedInts.IEncoder[33];
             decoders = new PackedInts.IDecoder[33];
@@ -126,7 +126,7 @@ namespace Lucene.Net.Codecs.Lucene41
                 decoders[bpv] = PackedInts.GetDecoder(formatAndBits.Format, PackedInts.VERSION_CURRENT, formatAndBits.BitsPerValue);
                 iterations[bpv] = ComputeIterations(decoders[bpv]);
 
-                @out.WriteVInt(formatAndBits.Format.Id << 5 | (formatAndBits.BitsPerValue - 1));
+                @out.WriteVInt32(formatAndBits.Format.Id << 5 | (formatAndBits.BitsPerValue - 1));
             }
         }
 
@@ -135,7 +135,7 @@ namespace Lucene.Net.Codecs.Lucene41
         /// </summary>
         internal ForUtil(DataInput @in)
         {
-            int packedIntsVersion = @in.ReadVInt();
+            int packedIntsVersion = @in.ReadVInt32();
             PackedInts.CheckVersion(packedIntsVersion);
             encodedSizes = new int[33];
             encoders = new PackedInts.IEncoder[33];
@@ -144,7 +144,7 @@ namespace Lucene.Net.Codecs.Lucene41
 
             for (int bpv = 1; bpv <= 32; ++bpv)
             {
-                var code = @in.ReadVInt();
+                var code = @in.ReadVInt32();
                 var formatId = (int)((uint)code >> 5);
                 var bitsPerValue = (code & 31) + 1;
 
@@ -169,7 +169,7 @@ namespace Lucene.Net.Codecs.Lucene41
             if (IsAllEqual(data))
             {
                 @out.WriteByte((byte)(sbyte)ALL_VALUES_EQUAL);
-                @out.WriteVInt(data[0]);
+                @out.WriteVInt32(data[0]);
                 return;
             }
 
@@ -201,7 +201,7 @@ namespace Lucene.Net.Codecs.Lucene41
 
             if (numBits == ALL_VALUES_EQUAL)
             {
-                int value = @in.ReadVInt();
+                int value = @in.ReadVInt32();
                 Arrays.Fill(decoded, 0, Lucene41PostingsFormat.BLOCK_SIZE, value);
                 return;
             }
@@ -226,7 +226,7 @@ namespace Lucene.Net.Codecs.Lucene41
             int numBits = @in.ReadByte();
             if (numBits == ALL_VALUES_EQUAL)
             {
-                @in.ReadVInt();
+                @in.ReadVInt32();
                 return;
             }
             Debug.Assert(numBits > 0 && numBits <= 32, numBits.ToString());


[52/53] [abbrv] lucenenet git commit: Lucene.Net.Core.Index.Fields refactor: Renamed Terms() > GetTerms()

Posted by ni...@apache.org.
Lucene.Net.Core.Index.Fields refactor: Renamed Terms() > GetTerms()


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

Branch: refs/heads/api-work
Commit: 52da783d84489904a083579a38b52d1620574dee
Parents: 4a28508
Author: Shad Storhaug <sh...@shadstorhaug.com>
Authored: Wed Feb 8 21:14:22 2017 +0700
Committer: Shad Storhaug <sh...@shadstorhaug.com>
Committed: Wed Feb 8 21:14:22 2017 +0700

----------------------------------------------------------------------
 .../BlockTerms/BlockTermsReader.cs                |  2 +-
 .../Bloom/BloomFilteringPostingsFormat.cs         |  6 +++---
 .../Memory/DirectPostingsFormat.cs                |  4 ++--
 src/Lucene.Net.Codecs/Memory/FSTOrdTermsReader.cs |  2 +-
 src/Lucene.Net.Codecs/Memory/FSTTermsReader.cs    |  2 +-
 .../Memory/MemoryPostingsFormat.cs                |  2 +-
 .../SimpleText/SimpleTextFieldsReader.cs          |  2 +-
 .../SimpleText/SimpleTextTermVectorsReader.cs     |  2 +-
 .../Codecs/BlockTreeTermsReader.cs                |  4 ++--
 .../Compressing/CompressingTermVectorsReader.cs   |  2 +-
 src/Lucene.Net.Core/Codecs/FieldsConsumer.cs      |  2 +-
 .../Codecs/Lucene3x/Lucene3xFields.cs             |  2 +-
 .../Codecs/Lucene3x/Lucene3xTermVectorsReader.cs  |  2 +-
 .../Codecs/Lucene40/Lucene40TermVectorsReader.cs  |  2 +-
 .../Codecs/Perfield/PerFieldPostingsFormat.cs     |  4 ++--
 src/Lucene.Net.Core/Codecs/TermVectorsWriter.cs   |  2 +-
 src/Lucene.Net.Core/Index/AtomicReader.cs         | 10 +++++-----
 .../Index/BufferedUpdatesStream.cs                |  4 ++--
 src/Lucene.Net.Core/Index/CheckIndex.cs           | 14 +++++++-------
 src/Lucene.Net.Core/Index/DocTermOrds.cs          |  6 +++---
 src/Lucene.Net.Core/Index/Fields.cs               |  6 +++---
 src/Lucene.Net.Core/Index/FilterAtomicReader.cs   |  4 ++--
 src/Lucene.Net.Core/Index/IndexReader.cs          |  2 +-
 src/Lucene.Net.Core/Index/MultiFields.cs          |  6 +++---
 src/Lucene.Net.Core/Index/ParallelAtomicReader.cs |  4 ++--
 src/Lucene.Net.Core/Index/TermContext.cs          |  2 +-
 .../Search/MultiTermQueryWrapperFilter.cs         |  2 +-
 src/Lucene.Net.Core/Search/Spans/SpanTermQuery.cs |  2 +-
 .../Search/TermCollectingRewrite.cs               |  2 +-
 .../Highlight/TokenSources.cs                     |  6 +++---
 .../Highlight/WeightedSpanTermExtractor.cs        |  4 ++--
 .../VectorHighlight/FieldTermStack.cs             |  2 +-
 .../MemoryIndex.MemoryIndexReader.cs              |  2 +-
 .../Index/Sorter/SortingAtomicReader.cs           |  4 ++--
 src/Lucene.Net.Misc/Misc/HighFreqTerms.cs         |  4 ++--
 src/Lucene.Net.Queries/CommonTermsQuery.cs        |  2 +-
 .../ValueSources/SumTotalTermFreqValueSource.cs   |  2 +-
 .../Function/ValueSources/TFValueSource.cs        |  2 +-
 .../Function/ValueSources/TermFreqValueSource.cs  |  2 +-
 src/Lucene.Net.Queries/Mlt/MoreLikeThis.cs        |  2 +-
 src/Lucene.Net.Queries/TermsFilter.cs             |  2 +-
 src/Lucene.Net.Sandbox/Queries/DuplicateFilter.cs |  4 ++--
 .../Codecs/asserting/AssertingPostingsFormat.cs   |  4 ++--
 .../Codecs/ramonly/RAMOnlyPostingsFormat.cs       |  2 +-
 .../Index/AssertingAtomicReader.cs                |  4 ++--
 .../Index/BasePostingsFormatTestCase.cs           |  2 +-
 .../Index/BaseTermVectorsFormatTestCase.cs        |  2 +-
 .../Index/FieldFilterAtomicReader.cs              |  4 ++--
 .../Index/ThreadedIndexingAndSearchingTestCase.cs |  2 +-
 .../Util/LuceneTestCase.cs                        |  2 +-
 .../Analysis/Sinks/TestTeeSinkTokenFilter.cs      |  2 +-
 .../Highlight/TokenSourcesTest.cs                 |  2 +-
 .../Index/Memory/MemoryIndexTest.cs               |  2 +-
 .../core/Analysis/TestMockAnalyzer.cs             |  2 +-
 .../core/Codecs/Lucene3x/TestSurrogates.cs        |  2 +-
 .../Codecs/Lucene3x/TestTermInfosReaderIndex.cs   |  2 +-
 .../core/Document/TestDocument.cs                 |  2 +-
 .../core/Index/TestBackwardsCompatibility.cs      |  4 ++--
 .../core/Index/TestBackwardsCompatibility3x.cs    |  4 ++--
 src/Lucene.Net.Tests/core/Index/TestCodecs.cs     |  4 ++--
 .../core/Index/TestDirectoryReader.cs             |  8 ++++----
 src/Lucene.Net.Tests/core/Index/TestDoc.cs        |  2 +-
 src/Lucene.Net.Tests/core/Index/TestDocCount.cs   |  2 +-
 .../core/Index/TestDocumentWriter.cs              |  4 ++--
 .../core/Index/TestFilterAtomicReader.cs          |  4 ++--
 src/Lucene.Net.Tests/core/Index/TestFlex.cs       |  2 +-
 .../core/Index/TestIndexWriter.cs                 |  8 ++++----
 .../core/Index/TestIndexWriterUnicode.cs          |  2 +-
 .../core/Index/TestIndexableField.cs              |  4 ++--
 .../core/Index/TestParallelTermEnum.cs            |  6 +++---
 src/Lucene.Net.Tests/core/Index/TestPayloads.cs   |  2 +-
 .../core/Index/TestPerSegmentDeletes.cs           |  2 +-
 .../core/Index/TestPostingsOffsets.cs             |  2 +-
 .../core/Index/TestSegmentMerger.cs               |  2 +-
 .../core/Index/TestSegmentReader.cs               |  4 ++--
 .../core/Index/TestSegmentTermDocs.cs             |  2 +-
 .../core/Index/TestSegmentTermEnum.cs             |  2 +-
 .../core/Index/TestStressAdvance.cs               |  2 +-
 .../core/Index/TestStressIndexing2.cs             | 18 +++++++++---------
 src/Lucene.Net.Tests/core/Index/TestSumDocFreq.cs |  2 +-
 .../core/Index/TestTermVectorsReader.cs           | 10 +++++-----
 .../core/Index/TestTermVectorsWriter.cs           | 16 ++++++++--------
 src/Lucene.Net.Tests/core/Index/TestTermsEnum.cs  |  6 +++---
 .../core/Search/TestMultiPhraseQuery.cs           |  2 +-
 .../core/Search/TestMultiThreadTermVectors.cs     |  4 ++--
 .../core/Search/TestPhrasePrefixQuery.cs          |  2 +-
 .../core/Search/TestSameScoresWithThreads.cs      |  2 +-
 .../core/Search/TestTermVectors.cs                |  4 ++--
 88 files changed, 159 insertions(+), 159 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/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
index 707bef3..9999cf6 100644
--- a/src/Lucene.Net.Codecs/BlockTerms/BlockTermsReader.cs
+++ b/src/Lucene.Net.Codecs/BlockTerms/BlockTermsReader.cs
@@ -248,7 +248,7 @@ namespace Lucene.Net.Codecs.BlockTerms
             return _fields.Keys.GetEnumerator();
         }
 
-        public override Terms Terms(string field)
+        public override Terms GetTerms(string field)
         {
             Debug.Assert(field != null);
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/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
index cb68c0f..8176fa3 100644
--- a/src/Lucene.Net.Codecs/Bloom/BloomFilteringPostingsFormat.cs
+++ b/src/Lucene.Net.Codecs/Bloom/BloomFilteringPostingsFormat.cs
@@ -186,13 +186,13 @@ namespace Lucene.Net.Codecs.Bloom
                 _delegateFieldsProducer.Dispose();
             }
 
-            public override Terms Terms(string field)
+            public override Terms GetTerms(string field)
             {
                 var filter = _bloomsByFieldName[field];
                 if (filter == null)
-                    return _delegateFieldsProducer.Terms(field);
+                    return _delegateFieldsProducer.GetTerms(field);
                 
-                var result = _delegateFieldsProducer.Terms(field);
+                var result = _delegateFieldsProducer.GetTerms(field);
                 return result == null ? null : new BloomFilteredTerms(result, filter);
             }
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/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
index 6bfbedf..20b8421 100644
--- a/src/Lucene.Net.Codecs/Memory/DirectPostingsFormat.cs
+++ b/src/Lucene.Net.Codecs/Memory/DirectPostingsFormat.cs
@@ -137,7 +137,7 @@ namespace Lucene.Net.Codecs.Memory
             {
                 foreach (string field in fields)
                 {
-                    this.fields[field] = new DirectField(state, field, fields.Terms(field), minSkipCount, lowFreqCutoff);
+                    this.fields[field] = new DirectField(state, field, fields.GetTerms(field), minSkipCount, lowFreqCutoff);
                 }
             }
 
@@ -146,7 +146,7 @@ namespace Lucene.Net.Codecs.Memory
                 return Collections.UnmodifiableSet<string>(fields.Keys).GetEnumerator();
             }
 
-            public override Terms Terms(string field)
+            public override Terms GetTerms(string field)
             {
                 return fields[field];
             }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/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
index f57f31f..168e298 100644
--- a/src/Lucene.Net.Codecs/Memory/FSTOrdTermsReader.cs
+++ b/src/Lucene.Net.Codecs/Memory/FSTOrdTermsReader.cs
@@ -160,7 +160,7 @@ namespace Lucene.Net.Codecs.Memory
             return Collections.UnmodifiableSet(fields.Keys).GetEnumerator();
         }
 
-        public override Terms Terms(string field)
+        public override Terms GetTerms(string field)
         {
             Debug.Assert(field != null);
             return fields[field];

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/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
index b2cf9b8..059a99e 100644
--- a/src/Lucene.Net.Codecs/Memory/FSTTermsReader.cs
+++ b/src/Lucene.Net.Codecs/Memory/FSTTermsReader.cs
@@ -162,7 +162,7 @@ namespace Lucene.Net.Codecs.Memory
             return Collections.UnmodifiableSet<string>(fields.Keys).GetEnumerator();
         }
 
-        public override Terms Terms(string field)
+        public override Terms GetTerms(string field)
         {
             Debug.Assert(field != null);
             return fields[field];

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/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
index 9ed0949..7795f85 100644
--- a/src/Lucene.Net.Codecs/Memory/MemoryPostingsFormat.cs
+++ b/src/Lucene.Net.Codecs/Memory/MemoryPostingsFormat.cs
@@ -1070,7 +1070,7 @@ namespace Lucene.Net.Codecs.Memory
                 return Collections.UnmodifiableSet<string>(_fields.Keys).GetEnumerator();
             }
 
-            public override Terms Terms(string field)
+            public override Terms GetTerms(string field)
             {
                 return _fields[field];
             }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/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
index 09bde88..139a2af 100644
--- a/src/Lucene.Net.Codecs/SimpleText/SimpleTextFieldsReader.cs
+++ b/src/Lucene.Net.Codecs/SimpleText/SimpleTextFieldsReader.cs
@@ -734,7 +734,7 @@ namespace Lucene.Net.Codecs.SimpleText
             return _fields.Keys.GetEnumerator();
         }
 
-        public override Terms Terms(string field)
+        public override Terms GetTerms(string field)
         {
             lock (this)
             {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.Codecs/SimpleText/SimpleTextTermVectorsReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Codecs/SimpleText/SimpleTextTermVectorsReader.cs b/src/Lucene.Net.Codecs/SimpleText/SimpleTextTermVectorsReader.cs
index aea82d4..900cf42 100644
--- a/src/Lucene.Net.Codecs/SimpleText/SimpleTextTermVectorsReader.cs
+++ b/src/Lucene.Net.Codecs/SimpleText/SimpleTextTermVectorsReader.cs
@@ -288,7 +288,7 @@ namespace Lucene.Net.Codecs.SimpleText
                 return _fields.Keys.GetEnumerator();
             }
 
-            public override Terms Terms(string field)
+            public override Terms GetTerms(string field)
             {
                 return _fields.ContainsKey(field) ? _fields[field] : null;
             }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.Core/Codecs/BlockTreeTermsReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/BlockTreeTermsReader.cs b/src/Lucene.Net.Core/Codecs/BlockTreeTermsReader.cs
index a9ecb01..2ce3b29 100644
--- a/src/Lucene.Net.Core/Codecs/BlockTreeTermsReader.cs
+++ b/src/Lucene.Net.Core/Codecs/BlockTreeTermsReader.cs
@@ -280,7 +280,7 @@ namespace Lucene.Net.Codecs
             return fields.Keys.GetEnumerator();
         }
 
-        public override Terms Terms(string field)
+        public override Terms GetTerms(string field)
         {
             Debug.Assert(field != null);
             FieldReader ret;
@@ -533,7 +533,7 @@ namespace Lucene.Net.Codecs
         internal BytesRef NO_OUTPUT;
 
         /// <summary>
-        /// BlockTree's implementation of <seealso cref="Terms"/>. </summary>
+        /// BlockTree's implementation of <seealso cref="GetTerms"/>. </summary>
         public sealed class FieldReader : Terms
         {
             private readonly BlockTreeTermsReader outerInstance;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.Core/Codecs/Compressing/CompressingTermVectorsReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/Compressing/CompressingTermVectorsReader.cs b/src/Lucene.Net.Core/Codecs/Compressing/CompressingTermVectorsReader.cs
index 12cd209..03e1191 100644
--- a/src/Lucene.Net.Core/Codecs/Compressing/CompressingTermVectorsReader.cs
+++ b/src/Lucene.Net.Core/Codecs/Compressing/CompressingTermVectorsReader.cs
@@ -733,7 +733,7 @@ namespace Lucene.Net.Codecs.Compressing
                 }
             }
 
-            public override Terms Terms(string field)
+            public override Terms GetTerms(string field)
             {
                 FieldInfo fieldInfo = outerInstance.fieldInfos.FieldInfo(field);
                 if (fieldInfo == null)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.Core/Codecs/FieldsConsumer.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/FieldsConsumer.cs b/src/Lucene.Net.Core/Codecs/FieldsConsumer.cs
index 948e121..d338fce 100644
--- a/src/Lucene.Net.Core/Codecs/FieldsConsumer.cs
+++ b/src/Lucene.Net.Core/Codecs/FieldsConsumer.cs
@@ -75,7 +75,7 @@ namespace Lucene.Net.Codecs
             {
                 FieldInfo info = mergeState.FieldInfos.FieldInfo(field);
                 Debug.Assert(info != null, "FieldInfo for field is null: " + field);
-                Terms terms = fields.Terms(field);
+                Terms terms = fields.GetTerms(field);
                 if (terms != null)
                 {
                     TermsConsumer termsConsumer = AddField(info);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.Core/Codecs/Lucene3x/Lucene3xFields.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/Lucene3x/Lucene3xFields.cs b/src/Lucene.Net.Core/Codecs/Lucene3x/Lucene3xFields.cs
index 57aab75..9ea1fdf 100644
--- a/src/Lucene.Net.Core/Codecs/Lucene3x/Lucene3xFields.cs
+++ b/src/Lucene.Net.Core/Codecs/Lucene3x/Lucene3xFields.cs
@@ -148,7 +148,7 @@ namespace Lucene.Net.Codecs.Lucene3x
             return fields.Keys.GetEnumerator();
         }
 
-        public override Terms Terms(string field)
+        public override Terms GetTerms(string field)
         {
             Terms ret;
             preTerms.TryGetValue(field, out ret);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.Core/Codecs/Lucene3x/Lucene3xTermVectorsReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/Lucene3x/Lucene3xTermVectorsReader.cs b/src/Lucene.Net.Core/Codecs/Lucene3x/Lucene3xTermVectorsReader.cs
index 86f8692..604ea8c 100644
--- a/src/Lucene.Net.Core/Codecs/Lucene3x/Lucene3xTermVectorsReader.cs
+++ b/src/Lucene.Net.Core/Codecs/Lucene3x/Lucene3xTermVectorsReader.cs
@@ -315,7 +315,7 @@ namespace Lucene.Net.Codecs.Lucene3x
                 }
             }
 
-            public override Terms Terms(string field)
+            public override Terms GetTerms(string field)
             {
                 FieldInfo fieldInfo = outerInstance.fieldInfos.FieldInfo(field);
                 if (fieldInfo == null)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.Core/Codecs/Lucene40/Lucene40TermVectorsReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/Lucene40/Lucene40TermVectorsReader.cs b/src/Lucene.Net.Core/Codecs/Lucene40/Lucene40TermVectorsReader.cs
index 52f3ea3..956257c 100644
--- a/src/Lucene.Net.Core/Codecs/Lucene40/Lucene40TermVectorsReader.cs
+++ b/src/Lucene.Net.Core/Codecs/Lucene40/Lucene40TermVectorsReader.cs
@@ -304,7 +304,7 @@ namespace Lucene.Net.Codecs.Lucene40
                 }
             }
 
-            public override Terms Terms(string field)
+            public override Terms GetTerms(string field)
             {
                 FieldInfo fieldInfo = outerInstance.fieldInfos.FieldInfo(field);
                 if (fieldInfo == null)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.Core/Codecs/Perfield/PerFieldPostingsFormat.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/Perfield/PerFieldPostingsFormat.cs b/src/Lucene.Net.Core/Codecs/Perfield/PerFieldPostingsFormat.cs
index 8aac700..4c4a30c 100644
--- a/src/Lucene.Net.Core/Codecs/Perfield/PerFieldPostingsFormat.cs
+++ b/src/Lucene.Net.Core/Codecs/Perfield/PerFieldPostingsFormat.cs
@@ -235,11 +235,11 @@ namespace Lucene.Net.Codecs.Perfield
                 return fields.Keys.GetEnumerator();
             }
 
-            public override Terms Terms(string field)
+            public override Terms GetTerms(string field)
             {
                 FieldsProducer fieldsProducer;
                 fields.TryGetValue(field, out fieldsProducer);
-                return fieldsProducer == null ? null : fieldsProducer.Terms(field);
+                return fieldsProducer == null ? null : fieldsProducer.GetTerms(field);
             }
 
             public override int Count

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.Core/Codecs/TermVectorsWriter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/TermVectorsWriter.cs b/src/Lucene.Net.Core/Codecs/TermVectorsWriter.cs
index 39563ec..e23b0ed 100644
--- a/src/Lucene.Net.Core/Codecs/TermVectorsWriter.cs
+++ b/src/Lucene.Net.Core/Codecs/TermVectorsWriter.cs
@@ -282,7 +282,7 @@ namespace Lucene.Net.Codecs
                 Debug.Assert(lastFieldName == null || fieldName.CompareTo(lastFieldName) > 0, "lastFieldName=" + lastFieldName + " fieldName=" + fieldName);
                 lastFieldName = fieldName;
 
-                Terms terms = vectors.Terms(fieldName);
+                Terms terms = vectors.GetTerms(fieldName);
                 if (terms == null)
                 {
                     // FieldsEnum shouldn't lie...

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.Core/Index/AtomicReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Index/AtomicReader.cs b/src/Lucene.Net.Core/Index/AtomicReader.cs
index 601fc41..24419ea 100644
--- a/src/Lucene.Net.Core/Index/AtomicReader.cs
+++ b/src/Lucene.Net.Core/Index/AtomicReader.cs
@@ -110,7 +110,7 @@ namespace Lucene.Net.Index
             {
                 return 0;
             }
-            Terms terms = fields.Terms(term.Field);
+            Terms terms = fields.GetTerms(term.Field);
             if (terms == null)
             {
                 return 0;
@@ -140,7 +140,7 @@ namespace Lucene.Net.Index
             {
                 return 0;
             }
-            Terms terms = fields.Terms(term.Field);
+            Terms terms = fields.GetTerms(term.Field);
             if (terms == null)
             {
                 return 0;
@@ -195,7 +195,7 @@ namespace Lucene.Net.Index
             {
                 return null;
             }
-            return fields.Terms(field);
+            return fields.GetTerms(field);
         }
 
         /// <summary>
@@ -210,7 +210,7 @@ namespace Lucene.Net.Index
             Fields fields = Fields;
             if (fields != null)
             {
-                Terms terms = fields.Terms(term.Field);
+                Terms terms = fields.GetTerms(term.Field);
                 if (terms != null)
                 {
                     TermsEnum termsEnum = terms.GetIterator(null);
@@ -235,7 +235,7 @@ namespace Lucene.Net.Index
             Fields fields = Fields;
             if (fields != null)
             {
-                Terms terms = fields.Terms(term.Field);
+                Terms terms = fields.GetTerms(term.Field);
                 if (terms != null)
                 {
                     TermsEnum termsEnum = terms.GetIterator(null);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.Core/Index/BufferedUpdatesStream.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Index/BufferedUpdatesStream.cs b/src/Lucene.Net.Core/Index/BufferedUpdatesStream.cs
index 4db8b0d..9ae9d7f 100644
--- a/src/Lucene.Net.Core/Index/BufferedUpdatesStream.cs
+++ b/src/Lucene.Net.Core/Index/BufferedUpdatesStream.cs
@@ -481,7 +481,7 @@ namespace Lucene.Net.Index
                     {
                         Debug.Assert(currentField == null || currentField.CompareTo(term.Field) < 0);
                         currentField = term.Field;
-                        Terms terms = fields.Terms(currentField);
+                        Terms terms = fields.GetTerms(currentField);
                         if (terms != null)
                         {
                             termsEnum = terms.GetIterator(termsEnum);
@@ -586,7 +586,7 @@ namespace Lucene.Net.Index
                         // if we change the code to process updates in terms order, enable this assert
                         //        assert currentField == null || currentField.compareTo(term.field()) < 0;
                         currentField = term.Field;
-                        Terms terms = fields.Terms(currentField);
+                        Terms terms = fields.GetTerms(currentField);
                         if (terms != null)
                         {
                             termsEnum = terms.GetIterator(termsEnum);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.Core/Index/CheckIndex.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Index/CheckIndex.cs b/src/Lucene.Net.Core/Index/CheckIndex.cs
index a26eb30..0468e20 100644
--- a/src/Lucene.Net.Core/Index/CheckIndex.cs
+++ b/src/Lucene.Net.Core/Index/CheckIndex.cs
@@ -1036,7 +1036,7 @@ namespace Lucene.Net.Index
                 // assert fields.terms(field) != null;
                 computedFieldCount++;
 
-                Terms terms = fields.Terms(field);
+                Terms terms = fields.GetTerms(field);
                 if (terms == null)
                 {
                     continue;
@@ -1443,7 +1443,7 @@ namespace Lucene.Net.Index
                     }
                 }
 
-                Terms fieldTerms = fields.Terms(field);
+                Terms fieldTerms = fields.GetTerms(field);
                 if (fieldTerms == null)
                 {
                     // Unusual: the FieldsEnum returned a field but
@@ -1467,7 +1467,7 @@ namespace Lucene.Net.Index
 
                     if (sumTotalTermFreq != 0)
                     {
-                        long v = fields.Terms(field).SumTotalTermFreq;
+                        long v = fields.GetTerms(field).SumTotalTermFreq;
                         if (v != -1 && sumTotalTermFreq != v)
                         {
                             throw new Exception("sumTotalTermFreq for field " + field + "=" + v + " != recomputed sumTotalTermFreq=" + sumTotalTermFreq);
@@ -1476,7 +1476,7 @@ namespace Lucene.Net.Index
 
                     if (sumDocFreq != 0)
                     {
-                        long v = fields.Terms(field).SumDocFreq;
+                        long v = fields.GetTerms(field).SumDocFreq;
                         if (v != -1 && sumDocFreq != v)
                         {
                             throw new Exception("sumDocFreq for field " + field + "=" + v + " != recomputed sumDocFreq=" + sumDocFreq);
@@ -1518,7 +1518,7 @@ namespace Lucene.Net.Index
 
                     if ((status.DelTermCount + status.TermCount) - termCountStart > 0)
                     {
-                        termCount = fields.Terms(field).Count;
+                        termCount = fields.GetTerms(field).Count;
 
                         if (termCount != -1 && termCount != status.DelTermCount + status.TermCount - termCountStart)
                         {
@@ -2132,13 +2132,13 @@ namespace Lucene.Net.Index
 
                             if (crossCheckTermVectors)
                             {
-                                Terms terms = tfv.Terms(field);
+                                Terms terms = tfv.GetTerms(field);
                                 termsEnum = terms.GetIterator(termsEnum);
                                 bool postingsHasFreq = fieldInfo.IndexOptions >= IndexOptions.DOCS_AND_FREQS;
                                 bool postingsHasPayload = fieldInfo.HasPayloads;
                                 bool vectorsHasPayload = terms.HasPayloads;
 
-                                Terms postingsTerms = postingsFields.Terms(field);
+                                Terms postingsTerms = postingsFields.GetTerms(field);
                                 if (postingsTerms == null)
                                 {
                                     throw new Exception("vector field=" + field + " does not exist in postings; doc=" + j);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.Core/Index/DocTermOrds.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Index/DocTermOrds.cs b/src/Lucene.Net.Core/Index/DocTermOrds.cs
index 0c087ca..5a6884c 100644
--- a/src/Lucene.Net.Core/Index/DocTermOrds.cs
+++ b/src/Lucene.Net.Core/Index/DocTermOrds.cs
@@ -270,7 +270,7 @@ namespace Lucene.Net.Index
                 {
                     return null;
                 }
-                Terms terms = fields.Terms(m_field);
+                Terms terms = fields.GetTerms(m_field);
                 if (terms == null)
                 {
                     return null;
@@ -345,7 +345,7 @@ namespace Lucene.Net.Index
                 // No terms
                 return;
             }
-            Terms terms = fields.Terms(m_field);
+            Terms terms = fields.GetTerms(m_field);
             if (terms == null)
             {
                 // No terms
@@ -750,7 +750,7 @@ namespace Lucene.Net.Index
 
                 InitializeInstanceFields();
                 Debug.Assert(outerInstance.m_indexedTermsArray != null);
-                termsEnum = reader.Fields.Terms(outerInstance.m_field).GetIterator(null);
+                termsEnum = reader.Fields.GetTerms(outerInstance.m_field).GetIterator(null);
             }
 
             public override IComparer<BytesRef> Comparer

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.Core/Index/Fields.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Index/Fields.cs b/src/Lucene.Net.Core/Index/Fields.cs
index f98fd98..c3ebb96 100644
--- a/src/Lucene.Net.Core/Index/Fields.cs
+++ b/src/Lucene.Net.Core/Index/Fields.cs
@@ -48,10 +48,10 @@ namespace Lucene.Net.Index
         }
 
         /// <summary>
-        /// Get the <seealso cref="Terms"/> for this field.  this will return
+        /// Get the <seealso cref="GetTerms"/> for this field.  this will return
         ///  null if the field does not exist.
         /// </summary>
-        public abstract Terms Terms(string field); // LUCENENET TODO: Rename GetTerms() ?
+        public abstract Terms GetTerms(string field);
 
         /// <summary>
         /// Gets the number of fields or -1 if the number of
@@ -79,7 +79,7 @@ namespace Lucene.Net.Index
                 long numTerms = 0;
                 foreach (string field in this)
                 {
-                    Terms terms = Terms(field);
+                    Terms terms = GetTerms(field);
                     if (terms != null)
                     {
                         long termCount = terms.Count;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.Core/Index/FilterAtomicReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Index/FilterAtomicReader.cs b/src/Lucene.Net.Core/Index/FilterAtomicReader.cs
index b700d1b..ceea3b5 100644
--- a/src/Lucene.Net.Core/Index/FilterAtomicReader.cs
+++ b/src/Lucene.Net.Core/Index/FilterAtomicReader.cs
@@ -81,9 +81,9 @@ namespace Lucene.Net.Index
                 return m_input.GetEnumerator();
             }
 
-            public override Terms Terms(string field)
+            public override Terms GetTerms(string field)
             {
-                return m_input.Terms(field);
+                return m_input.GetTerms(field);
             }
 
             public override int Count

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.Core/Index/IndexReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Index/IndexReader.cs b/src/Lucene.Net.Core/Index/IndexReader.cs
index f445715..8c839da 100644
--- a/src/Lucene.Net.Core/Index/IndexReader.cs
+++ b/src/Lucene.Net.Core/Index/IndexReader.cs
@@ -461,7 +461,7 @@ namespace Lucene.Net.Index
             {
                 return null;
             }
-            return vectors.Terms(field);
+            return vectors.GetTerms(field);
         }
 
         /// <summary>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.Core/Index/MultiFields.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Index/MultiFields.cs b/src/Lucene.Net.Core/Index/MultiFields.cs
index b4f0081..1b0ce69 100644
--- a/src/Lucene.Net.Core/Index/MultiFields.cs
+++ b/src/Lucene.Net.Core/Index/MultiFields.cs
@@ -150,7 +150,7 @@ namespace Lucene.Net.Index
             }
             else
             {
-                return fields.Terms(field);
+                return fields.GetTerms(field);
             }
         }
 
@@ -244,7 +244,7 @@ namespace Lucene.Net.Index
             return new MergedIterator<string>(subIterators);
         }
 
-        public override Terms Terms(string field)
+        public override Terms GetTerms(string field)
         {
             Terms result;
             terms.TryGetValue(field, out result);
@@ -261,7 +261,7 @@ namespace Lucene.Net.Index
             // Gather all sub-readers that share this field
             for (int i = 0; i < subs.Length; i++)
             {
-                Terms terms = subs[i].Terms(field);
+                Terms terms = subs[i].GetTerms(field);
                 if (terms != null)
                 {
                     subs2.Add(terms);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.Core/Index/ParallelAtomicReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Index/ParallelAtomicReader.cs b/src/Lucene.Net.Core/Index/ParallelAtomicReader.cs
index 67ca41a..3e89924 100644
--- a/src/Lucene.Net.Core/Index/ParallelAtomicReader.cs
+++ b/src/Lucene.Net.Core/Index/ParallelAtomicReader.cs
@@ -150,7 +150,7 @@ namespace Lucene.Net.Index
                         // only add if the reader responsible for that field name is the current:
                         if (fieldToReader[field].Equals(reader))
                         {
-                            this.fields.AddField(field, readerFields.Terms(field));
+                            this.fields.AddField(field, readerFields.GetTerms(field));
                         }
                     }
                 }
@@ -208,7 +208,7 @@ namespace Lucene.Net.Index
                 return fields.Keys.GetEnumerator();
             }
 
-            public override Terms Terms(string field)
+            public override Terms GetTerms(string field)
             {
                 Terms ret;
                 fields.TryGetValue(field, out ret);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.Core/Index/TermContext.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Index/TermContext.cs b/src/Lucene.Net.Core/Index/TermContext.cs
index 42a6afd..bf6244f 100644
--- a/src/Lucene.Net.Core/Index/TermContext.cs
+++ b/src/Lucene.Net.Core/Index/TermContext.cs
@@ -99,7 +99,7 @@ namespace Lucene.Net.Index
                 Fields fields = ctx.AtomicReader.Fields;
                 if (fields != null)
                 {
-                    Terms terms = fields.Terms(field);
+                    Terms terms = fields.GetTerms(field);
                     if (terms != null)
                     {
                         TermsEnum termsEnum = terms.GetIterator(null);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.Core/Search/MultiTermQueryWrapperFilter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Search/MultiTermQueryWrapperFilter.cs b/src/Lucene.Net.Core/Search/MultiTermQueryWrapperFilter.cs
index 189b1ca..17004d5 100644
--- a/src/Lucene.Net.Core/Search/MultiTermQueryWrapperFilter.cs
+++ b/src/Lucene.Net.Core/Search/MultiTermQueryWrapperFilter.cs
@@ -106,7 +106,7 @@ namespace Lucene.Net.Search
                 return null;
             }
 
-            Terms terms = fields.Terms(m_query.m_field);
+            Terms terms = fields.GetTerms(m_query.m_field);
             if (terms == null)
             {
                 // field does not exist

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.Core/Search/Spans/SpanTermQuery.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Search/Spans/SpanTermQuery.cs b/src/Lucene.Net.Core/Search/Spans/SpanTermQuery.cs
index 0d129a6..b96b5e5 100644
--- a/src/Lucene.Net.Core/Search/Spans/SpanTermQuery.cs
+++ b/src/Lucene.Net.Core/Search/Spans/SpanTermQuery.cs
@@ -132,7 +132,7 @@ namespace Lucene.Net.Search.Spans
                 Fields fields = context.AtomicReader.Fields;
                 if (fields != null)
                 {
-                    Terms terms = fields.Terms(m_term.Field);
+                    Terms terms = fields.GetTerms(m_term.Field);
                     if (terms != null)
                     {
                         TermsEnum termsEnum = terms.GetIterator(null);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.Core/Search/TermCollectingRewrite.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Search/TermCollectingRewrite.cs b/src/Lucene.Net.Core/Search/TermCollectingRewrite.cs
index c256e1a..d0ea128 100644
--- a/src/Lucene.Net.Core/Search/TermCollectingRewrite.cs
+++ b/src/Lucene.Net.Core/Search/TermCollectingRewrite.cs
@@ -60,7 +60,7 @@ namespace Lucene.Net.Search
                     continue;
                 }
 
-                Terms terms = fields.Terms(query.m_field);
+                Terms terms = fields.GetTerms(query.m_field);
                 if (terms == null)
                 {
                     // field does not exist

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.Highlighter/Highlight/TokenSources.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Highlighter/Highlight/TokenSources.cs b/src/Lucene.Net.Highlighter/Highlight/TokenSources.cs
index 5800ce5..842eedf 100644
--- a/src/Lucene.Net.Highlighter/Highlight/TokenSources.cs
+++ b/src/Lucene.Net.Highlighter/Highlight/TokenSources.cs
@@ -108,7 +108,7 @@ namespace Lucene.Net.Search.Highlight
             TokenStream ts = null;
 
             Fields vectors = reader.GetTermVectors(docId);
-            Terms vector = vectors?.Terms(field);
+            Terms vector = vectors?.GetTerms(field);
             if (vector != null)
             {
                 ts = GetTokenStream(vector);
@@ -131,7 +131,7 @@ namespace Lucene.Net.Search.Highlight
             TokenStream ts = null;
 
             Fields vectors = reader.GetTermVectors(docId);
-            Terms vector = vectors?.Terms(field);
+            Terms vector = vectors?.GetTerms(field);
             if (vector != null)
             {
                 ts = GetTokenStream(vector);
@@ -302,7 +302,7 @@ namespace Lucene.Net.Search.Highlight
                 return null;
             }
 
-            Terms vector = vectors.Terms(field);
+            Terms vector = vectors.GetTerms(field);
             if (vector == null) {
                 return null;
             }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.Highlighter/Highlight/WeightedSpanTermExtractor.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Highlighter/Highlight/WeightedSpanTermExtractor.cs b/src/Lucene.Net.Highlighter/Highlight/WeightedSpanTermExtractor.cs
index c31005e..029c047 100644
--- a/src/Lucene.Net.Highlighter/Highlight/WeightedSpanTermExtractor.cs
+++ b/src/Lucene.Net.Highlighter/Highlight/WeightedSpanTermExtractor.cs
@@ -418,9 +418,9 @@ namespace Lucene.Net.Search.Highlight
             {
                 public DelegatingFilterFields(Fields fields) : base(fields) { }
 
-                public override Terms Terms(string field)
+                public override Terms GetTerms(string field)
                 {
-                    return base.Terms(DelegatingAtomicReader.FIELD_NAME);
+                    return base.GetTerms(DelegatingAtomicReader.FIELD_NAME);
                 }
 
                 public override IEnumerator<string> GetEnumerator()

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.Highlighter/VectorHighlight/FieldTermStack.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Highlighter/VectorHighlight/FieldTermStack.cs b/src/Lucene.Net.Highlighter/VectorHighlight/FieldTermStack.cs
index 9b8b8e6..ad83dbc 100644
--- a/src/Lucene.Net.Highlighter/VectorHighlight/FieldTermStack.cs
+++ b/src/Lucene.Net.Highlighter/VectorHighlight/FieldTermStack.cs
@@ -81,7 +81,7 @@ namespace Lucene.Net.Search.VectorHighlight
                 return;
             }
 
-            Terms vector = vectors.Terms(fieldName);
+            Terms vector = vectors.GetTerms(fieldName);
             if (vector == null)
             {
                 // null snippet

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.Memory/MemoryIndex.MemoryIndexReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Memory/MemoryIndex.MemoryIndexReader.cs b/src/Lucene.Net.Memory/MemoryIndex.MemoryIndexReader.cs
index 636925f..2cf38f1 100644
--- a/src/Lucene.Net.Memory/MemoryIndex.MemoryIndexReader.cs
+++ b/src/Lucene.Net.Memory/MemoryIndex.MemoryIndexReader.cs
@@ -153,7 +153,7 @@ namespace Lucene.Net.Index.Memory
                     }
                 }
 
-                public override Terms Terms(string field)
+                public override Terms GetTerms(string field)
                 {
                     var searchField = new KeyValuePair<string, Info>(field, null);
                     int i = Array.BinarySearch(outerInstance.outerInstance.sortedFields, searchField, new TermComparer<string, Info>());

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.Misc/Index/Sorter/SortingAtomicReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Misc/Index/Sorter/SortingAtomicReader.cs b/src/Lucene.Net.Misc/Index/Sorter/SortingAtomicReader.cs
index 6b4e60d..79cb7e6 100644
--- a/src/Lucene.Net.Misc/Index/Sorter/SortingAtomicReader.cs
+++ b/src/Lucene.Net.Misc/Index/Sorter/SortingAtomicReader.cs
@@ -57,9 +57,9 @@ namespace Lucene.Net.Index.Sorter
                 this.infos = infos;
             }
 
-            public override Terms Terms(string field)
+            public override Terms GetTerms(string field)
             {
-                Terms terms = this.m_input.Terms(field);
+                Terms terms = this.m_input.GetTerms(field);
                 if (terms == null)
                 {
                     return null;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.Misc/Misc/HighFreqTerms.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Misc/Misc/HighFreqTerms.cs b/src/Lucene.Net.Misc/Misc/HighFreqTerms.cs
index 6675a52..b898e9a 100644
--- a/src/Lucene.Net.Misc/Misc/HighFreqTerms.cs
+++ b/src/Lucene.Net.Misc/Misc/HighFreqTerms.cs
@@ -105,7 +105,7 @@ namespace Lucene.Net.Misc
                 {
                     throw new Exception("field " + field + " not found");
                 }
-                Terms terms = fields.Terms(field);
+                Terms terms = fields.GetTerms(field);
                 if (terms != null)
                 {
                     TermsEnum termsEnum = terms.GetIterator(null);
@@ -123,7 +123,7 @@ namespace Lucene.Net.Misc
                 tiq = new TermStatsQueue(numTerms, comparer);
                 foreach (string fieldName in fields)
                 {
-                    Terms terms = fields.Terms(fieldName);
+                    Terms terms = fields.GetTerms(fieldName);
                     if (terms != null)
                     {
                         tiq.Fill(fieldName, terms.GetIterator(null));

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.Queries/CommonTermsQuery.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/CommonTermsQuery.cs b/src/Lucene.Net.Queries/CommonTermsQuery.cs
index 8735514..59a2620 100644
--- a/src/Lucene.Net.Queries/CommonTermsQuery.cs
+++ b/src/Lucene.Net.Queries/CommonTermsQuery.cs
@@ -260,7 +260,7 @@ namespace Lucene.Net.Queries
                 {
                     Term term = queryTerms[i];
                     TermContext termContext = contextArray[i];
-                    Terms terms = fields.Terms(term.Field);
+                    Terms terms = fields.GetTerms(term.Field);
                     if (terms == null)
                     {
                         // field does not exist

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.Queries/Function/ValueSources/SumTotalTermFreqValueSource.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/SumTotalTermFreqValueSource.cs b/src/Lucene.Net.Queries/Function/ValueSources/SumTotalTermFreqValueSource.cs
index 0ffc576..9b9e183 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/SumTotalTermFreqValueSource.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/SumTotalTermFreqValueSource.cs
@@ -63,7 +63,7 @@ namespace Lucene.Net.Queries.Function.ValueSources
                 {
                     continue;
                 }
-                Terms terms = fields.Terms(m_indexedField);
+                Terms terms = fields.GetTerms(m_indexedField);
                 if (terms == null)
                 {
                     continue;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.Queries/Function/ValueSources/TFValueSource.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/TFValueSource.cs b/src/Lucene.Net.Queries/Function/ValueSources/TFValueSource.cs
index 2ffe4f8..ecce892 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/TFValueSource.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/TFValueSource.cs
@@ -54,7 +54,7 @@ namespace Lucene.Net.Queries.Function.ValueSources
         public override FunctionValues GetValues(IDictionary context, AtomicReaderContext readerContext)
         {
             var fields = readerContext.AtomicReader.Fields;
-            var terms = fields.Terms(m_indexedField);
+            var terms = fields.GetTerms(m_indexedField);
             var searcher = (IndexSearcher)context["searcher"];
             var similarity = IDFValueSource.AsTFIDF(searcher.Similarity, m_indexedField);
             if (similarity == null)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.Queries/Function/ValueSources/TermFreqValueSource.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/TermFreqValueSource.cs b/src/Lucene.Net.Queries/Function/ValueSources/TermFreqValueSource.cs
index 96b9ad7..eefea68 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/TermFreqValueSource.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/TermFreqValueSource.cs
@@ -47,7 +47,7 @@ namespace Lucene.Net.Queries.Function.ValueSources
         public override FunctionValues GetValues(IDictionary context, AtomicReaderContext readerContext)
         {
             Fields fields = readerContext.AtomicReader.Fields;
-            Terms terms = fields.Terms(m_indexedField);
+            Terms terms = fields.GetTerms(m_indexedField);
 
             return new Int32DocValuesAnonymousInnerClassHelper(this, this, terms);
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.Queries/Mlt/MoreLikeThis.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Mlt/MoreLikeThis.cs b/src/Lucene.Net.Queries/Mlt/MoreLikeThis.cs
index 9ab7dc9..d557213 100644
--- a/src/Lucene.Net.Queries/Mlt/MoreLikeThis.cs
+++ b/src/Lucene.Net.Queries/Mlt/MoreLikeThis.cs
@@ -507,7 +507,7 @@ namespace Lucene.Net.Queries.Mlt
                 Terms vector;
                 if (vectors != null)
                 {
-                    vector = vectors.Terms(fieldName);
+                    vector = vectors.GetTerms(fieldName);
                 }
                 else
                 {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.Queries/TermsFilter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/TermsFilter.cs b/src/Lucene.Net.Queries/TermsFilter.cs
index 8e13032..3a82206 100644
--- a/src/Lucene.Net.Queries/TermsFilter.cs
+++ b/src/Lucene.Net.Queries/TermsFilter.cs
@@ -234,7 +234,7 @@ namespace Lucene.Net.Queries
             DocsEnum docs = null;
             foreach (TermsAndField termsAndField in this.termsAndFields)
             {
-                if ((terms = fields.Terms(termsAndField.field)) != null)
+                if ((terms = fields.GetTerms(termsAndField.field)) != null)
                 {
                     termsEnum = terms.GetIterator(termsEnum); // this won't return null
                     for (int i = termsAndField.start; i < termsAndField.end; i++)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.Sandbox/Queries/DuplicateFilter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Sandbox/Queries/DuplicateFilter.cs b/src/Lucene.Net.Sandbox/Queries/DuplicateFilter.cs
index 3b97d06..7e7cc39 100644
--- a/src/Lucene.Net.Sandbox/Queries/DuplicateFilter.cs
+++ b/src/Lucene.Net.Sandbox/Queries/DuplicateFilter.cs
@@ -72,7 +72,7 @@ namespace Lucene.Net.Sandbox.Queries
         private FixedBitSet CorrectBits(AtomicReader reader, IBits acceptDocs)
         {
             FixedBitSet bits = new FixedBitSet(reader.MaxDoc); //assume all are INvalid
-            Terms terms = reader.Fields.Terms(fieldName);
+            Terms terms = reader.Fields.GetTerms(fieldName);
 
             if (terms == null)
             {
@@ -122,7 +122,7 @@ namespace Lucene.Net.Sandbox.Queries
         {
             FixedBitSet bits = new FixedBitSet(reader.MaxDoc);
             bits.Set(0, reader.MaxDoc); //assume all are valid
-            Terms terms = reader.Fields.Terms(fieldName);
+            Terms terms = reader.Fields.GetTerms(fieldName);
 
             if (terms == null)
             {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.TestFramework/Codecs/asserting/AssertingPostingsFormat.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.TestFramework/Codecs/asserting/AssertingPostingsFormat.cs b/src/Lucene.Net.TestFramework/Codecs/asserting/AssertingPostingsFormat.cs
index 0fa200f..41e48e5 100644
--- a/src/Lucene.Net.TestFramework/Codecs/asserting/AssertingPostingsFormat.cs
+++ b/src/Lucene.Net.TestFramework/Codecs/asserting/AssertingPostingsFormat.cs
@@ -81,9 +81,9 @@ namespace Lucene.Net.Codecs.asserting
                 return iterator;
             }
 
-            public override Terms Terms(string field)
+            public override Terms GetTerms(string field)
             {
-                Terms terms = @in.Terms(field);
+                Terms terms = @in.GetTerms(field);
                 return terms == null ? null : new AssertingAtomicReader.AssertingTerms(terms);
             }
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.TestFramework/Codecs/ramonly/RAMOnlyPostingsFormat.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.TestFramework/Codecs/ramonly/RAMOnlyPostingsFormat.cs b/src/Lucene.Net.TestFramework/Codecs/ramonly/RAMOnlyPostingsFormat.cs
index 2a10d2b..b818169 100644
--- a/src/Lucene.Net.TestFramework/Codecs/ramonly/RAMOnlyPostingsFormat.cs
+++ b/src/Lucene.Net.TestFramework/Codecs/ramonly/RAMOnlyPostingsFormat.cs
@@ -109,7 +109,7 @@ namespace Lucene.Net.Codecs.ramonly
         {
             internal readonly IDictionary<string, RAMField> FieldToTerms = new SortedDictionary<string, RAMField>();
 
-            public override Terms Terms(string field)
+            public override Terms GetTerms(string field)
             {
                 return FieldToTerms[field];
             }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.TestFramework/Index/AssertingAtomicReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.TestFramework/Index/AssertingAtomicReader.cs b/src/Lucene.Net.TestFramework/Index/AssertingAtomicReader.cs
index 6fcdc14..a44c3e1 100644
--- a/src/Lucene.Net.TestFramework/Index/AssertingAtomicReader.cs
+++ b/src/Lucene.Net.TestFramework/Index/AssertingAtomicReader.cs
@@ -73,9 +73,9 @@ namespace Lucene.Net.Index
                 return iterator;
             }
 
-            public override Terms Terms(string field)
+            public override Terms GetTerms(string field)
             {
-                Terms terms = base.Terms(field);
+                Terms terms = base.GetTerms(field);
                 return terms == null ? null : new AssertingTerms(terms);
             }
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.TestFramework/Index/BasePostingsFormatTestCase.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.TestFramework/Index/BasePostingsFormatTestCase.cs b/src/Lucene.Net.TestFramework/Index/BasePostingsFormatTestCase.cs
index 4774c67..397050f 100644
--- a/src/Lucene.Net.TestFramework/Index/BasePostingsFormatTestCase.cs
+++ b/src/Lucene.Net.TestFramework/Index/BasePostingsFormatTestCase.cs
@@ -1145,7 +1145,7 @@ namespace Lucene.Net.Index
                     termState = termStates[idx];
                 }
 
-                Terms terms = fieldsSource.Terms(fieldAndTerm.Field);
+                Terms terms = fieldsSource.GetTerms(fieldAndTerm.Field);
                 Assert.IsNotNull(terms);
                 termsEnum = terms.GetIterator(null);
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.TestFramework/Index/BaseTermVectorsFormatTestCase.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.TestFramework/Index/BaseTermVectorsFormatTestCase.cs b/src/Lucene.Net.TestFramework/Index/BaseTermVectorsFormatTestCase.cs
index b3822d2..fb903a8 100644
--- a/src/Lucene.Net.TestFramework/Index/BaseTermVectorsFormatTestCase.cs
+++ b/src/Lucene.Net.TestFramework/Index/BaseTermVectorsFormatTestCase.cs
@@ -498,7 +498,7 @@ namespace Lucene.Net.Index
 
             for (int i = 0; i < doc.FieldNames.Length; ++i)
             {
-                AssertEquals(doc.TokenStreams[i], doc.FieldTypes[i], fields.Terms(doc.FieldNames[i]));
+                AssertEquals(doc.TokenStreams[i], doc.FieldTypes[i], fields.GetTerms(doc.FieldNames[i]));
             }
         }
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.TestFramework/Index/FieldFilterAtomicReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.TestFramework/Index/FieldFilterAtomicReader.cs b/src/Lucene.Net.TestFramework/Index/FieldFilterAtomicReader.cs
index a2414d2..e3e66dc 100644
--- a/src/Lucene.Net.TestFramework/Index/FieldFilterAtomicReader.cs
+++ b/src/Lucene.Net.TestFramework/Index/FieldFilterAtomicReader.cs
@@ -215,9 +215,9 @@ namespace Lucene.Net.Index
                 }
             }
 
-            public override Terms Terms(string field)
+            public override Terms GetTerms(string field)
             {
-                return OuterInstance.HasField(field) ? base.Terms(field) : null;
+                return OuterInstance.HasField(field) ? base.GetTerms(field) : null;
             }
         }
     }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.TestFramework/Index/ThreadedIndexingAndSearchingTestCase.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.TestFramework/Index/ThreadedIndexingAndSearchingTestCase.cs b/src/Lucene.Net.TestFramework/Index/ThreadedIndexingAndSearchingTestCase.cs
index f2ee00b..a751ff6 100644
--- a/src/Lucene.Net.TestFramework/Index/ThreadedIndexingAndSearchingTestCase.cs
+++ b/src/Lucene.Net.TestFramework/Index/ThreadedIndexingAndSearchingTestCase.cs
@@ -472,7 +472,7 @@ namespace Lucene.Net.Index
                                 {
                                     continue;
                                 }
-                                Terms terms = fields.Terms("body");
+                                Terms terms = fields.GetTerms("body");
                                 if (terms == null)
                                 {
                                     continue;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.TestFramework/Util/LuceneTestCase.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.TestFramework/Util/LuceneTestCase.cs b/src/Lucene.Net.TestFramework/Util/LuceneTestCase.cs
index 8bc158b..0111ce3 100644
--- a/src/Lucene.Net.TestFramework/Util/LuceneTestCase.cs
+++ b/src/Lucene.Net.TestFramework/Util/LuceneTestCase.cs
@@ -1890,7 +1890,7 @@ namespace Lucene.Net.Util
                 string field = leftEnum.Current;
                 rightEnum.MoveNext();
                 Assert.AreEqual(field, rightEnum.Current, info);
-                AssertTermsEquals(info, leftReader, leftFields.Terms(field), rightFields.Terms(field), deep);
+                AssertTermsEquals(info, leftReader, leftFields.GetTerms(field), rightFields.GetTerms(field), deep);
             }
             Assert.IsFalse(rightEnum.MoveNext());
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.Tests.Analysis.Common/Analysis/Sinks/TestTeeSinkTokenFilter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests.Analysis.Common/Analysis/Sinks/TestTeeSinkTokenFilter.cs b/src/Lucene.Net.Tests.Analysis.Common/Analysis/Sinks/TestTeeSinkTokenFilter.cs
index 161c3b9..43f4790 100644
--- a/src/Lucene.Net.Tests.Analysis.Common/Analysis/Sinks/TestTeeSinkTokenFilter.cs
+++ b/src/Lucene.Net.Tests.Analysis.Common/Analysis/Sinks/TestTeeSinkTokenFilter.cs
@@ -114,7 +114,7 @@ namespace Lucene.Net.Analysis.Sinks
             w.Dispose();
 
             IndexReader r = DirectoryReader.Open(dir);
-            Terms vector = r.GetTermVectors(0).Terms("field");
+            Terms vector = r.GetTermVectors(0).GetTerms("field");
             assertEquals(1, vector.Count);
             TermsEnum termsEnum = vector.GetIterator(null);
             termsEnum.Next();

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.Tests.Highlighter/Highlight/TokenSourcesTest.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests.Highlighter/Highlight/TokenSourcesTest.cs b/src/Lucene.Net.Tests.Highlighter/Highlight/TokenSourcesTest.cs
index 8ff521a..63b1db2 100644
--- a/src/Lucene.Net.Tests.Highlighter/Highlight/TokenSourcesTest.cs
+++ b/src/Lucene.Net.Tests.Highlighter/Highlight/TokenSourcesTest.cs
@@ -374,7 +374,7 @@ namespace Lucene.Net.Search.Highlight
                 // Do this twice, once passing true and then passing
                 // false: they are entirely different code paths
                 // under-the-hood:
-                TokenStream ts = TokenSources.GetTokenStream(reader.GetTermVectors(0).Terms("field"), i == 0);
+                TokenStream ts = TokenSources.GetTokenStream(reader.GetTermVectors(0).GetTerms("field"), i == 0);
 
                 ICharTermAttribute termAtt = ts.GetAttribute<ICharTermAttribute>();
                 IPositionIncrementAttribute posIncAtt = ts.GetAttribute<IPositionIncrementAttribute>();

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.Tests.Memory/Index/Memory/MemoryIndexTest.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests.Memory/Index/Memory/MemoryIndexTest.cs b/src/Lucene.Net.Tests.Memory/Index/Memory/MemoryIndexTest.cs
index ae11e87..fef76e2 100644
--- a/src/Lucene.Net.Tests.Memory/Index/Memory/MemoryIndexTest.cs
+++ b/src/Lucene.Net.Tests.Memory/Index/Memory/MemoryIndexTest.cs
@@ -131,7 +131,7 @@ namespace Lucene.Net.Index.Memory
             Fields memFields = memIndexReader.Fields;
             foreach (string field in competitor.Fields)
             {
-                Terms memTerms = memFields.Terms(field);
+                Terms memTerms = memFields.GetTerms(field);
                 Terms iwTerms = memIndexReader.Terms(field);
                 if (iwTerms == null)
                 {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.Tests/core/Analysis/TestMockAnalyzer.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Analysis/TestMockAnalyzer.cs b/src/Lucene.Net.Tests/core/Analysis/TestMockAnalyzer.cs
index d1f429c..cd8f315 100644
--- a/src/Lucene.Net.Tests/core/Analysis/TestMockAnalyzer.cs
+++ b/src/Lucene.Net.Tests/core/Analysis/TestMockAnalyzer.cs
@@ -367,7 +367,7 @@ namespace Lucene.Net.Analysis
             writer.AddDocument(doc, a);
             AtomicReader reader = GetOnlySegmentReader(writer.Reader);
             Fields fields = reader.GetTermVectors(0);
-            Terms terms = fields.Terms("f");
+            Terms terms = fields.GetTerms("f");
             TermsEnum te = terms.GetIterator(null);
             Assert.AreEqual(new BytesRef("a"), te.Next());
             DocsAndPositionsEnum dpe = te.DocsAndPositions(null, null);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.Tests/core/Codecs/Lucene3x/TestSurrogates.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Codecs/Lucene3x/TestSurrogates.cs b/src/Lucene.Net.Tests/core/Codecs/Lucene3x/TestSurrogates.cs
index 625e769..d4b1b63 100644
--- a/src/Lucene.Net.Tests/core/Codecs/Lucene3x/TestSurrogates.cs
+++ b/src/Lucene.Net.Tests/core/Codecs/Lucene3x/TestSurrogates.cs
@@ -137,7 +137,7 @@ namespace Lucene.Net.Codecs.Lucene3x
                 int termCount = 0;
                 foreach (string field in fields)
                 {
-                    Terms terms = fields.Terms(field);
+                    Terms terms = fields.GetTerms(field);
                     Assert.IsNotNull(terms);
                     TermsEnum termsEnum = terms.GetIterator(null);
                     BytesRef text;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.Tests/core/Codecs/Lucene3x/TestTermInfosReaderIndex.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Codecs/Lucene3x/TestTermInfosReaderIndex.cs b/src/Lucene.Net.Tests/core/Codecs/Lucene3x/TestTermInfosReaderIndex.cs
index b661f08..2d9dd05 100644
--- a/src/Lucene.Net.Tests/core/Codecs/Lucene3x/TestTermInfosReaderIndex.cs
+++ b/src/Lucene.Net.Tests/core/Codecs/Lucene3x/TestTermInfosReaderIndex.cs
@@ -169,7 +169,7 @@ namespace Lucene.Net.Codecs.Lucene3x
             Fields fields = MultiFields.GetFields(reader);
             foreach (string field in fields)
             {
-                Terms terms = fields.Terms(field);
+                Terms terms = fields.GetTerms(field);
                 Assert.IsNotNull(terms);
                 TermsEnum termsEnum = terms.GetIterator(null);
                 while (termsEnum.Next() != null)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.Tests/core/Document/TestDocument.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Document/TestDocument.cs b/src/Lucene.Net.Tests/core/Document/TestDocument.cs
index 11b108b..2a73911 100644
--- a/src/Lucene.Net.Tests/core/Document/TestDocument.cs
+++ b/src/Lucene.Net.Tests/core/Document/TestDocument.cs
@@ -406,7 +406,7 @@ namespace Lucene.Net.Documents
             foreach (string field in new string[] { "tv", "tv_pos", "tv_off", "tv_pos_off" })
             {
                 Fields tvFields = r.GetTermVectors(0);
-                Terms tvs = tvFields.Terms(field);
+                Terms tvs = tvFields.GetTerms(field);
                 Assert.IsNotNull(tvs);
                 Assert.AreEqual(2, tvs.Count);
                 TermsEnum tvsEnum = tvs.GetIterator(null);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.Tests/core/Index/TestBackwardsCompatibility.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Index/TestBackwardsCompatibility.cs b/src/Lucene.Net.Tests/core/Index/TestBackwardsCompatibility.cs
index 96c40ab..e46e342 100644
--- a/src/Lucene.Net.Tests/core/Index/TestBackwardsCompatibility.cs
+++ b/src/Lucene.Net.Tests/core/Index/TestBackwardsCompatibility.cs
@@ -476,7 +476,7 @@ namespace Lucene.Net.Index
 
                     Fields tfvFields = reader.GetTermVectors(i);
                     Assert.IsNotNull(tfvFields, "i=" + i);
-                    Terms tfv = tfvFields.Terms("utf8");
+                    Terms tfv = tfvFields.GetTerms("utf8");
                     Assert.IsNotNull(tfv, "docID=" + i + " index=" + oldName);
                 }
                 else
@@ -787,7 +787,7 @@ namespace Lucene.Net.Index
             {
                 Directory dir = OldIndexDirs[name];
                 IndexReader r = DirectoryReader.Open(dir);
-                TermsEnum terms = MultiFields.GetFields(r).Terms("content").GetIterator(null);
+                TermsEnum terms = MultiFields.GetFields(r).GetTerms("content").GetIterator(null);
                 BytesRef t = terms.Next();
                 Assert.IsNotNull(t);
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.Tests/core/Index/TestBackwardsCompatibility3x.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Index/TestBackwardsCompatibility3x.cs b/src/Lucene.Net.Tests/core/Index/TestBackwardsCompatibility3x.cs
index eeadaa4..45b09c1 100644
--- a/src/Lucene.Net.Tests/core/Index/TestBackwardsCompatibility3x.cs
+++ b/src/Lucene.Net.Tests/core/Index/TestBackwardsCompatibility3x.cs
@@ -447,7 +447,7 @@ namespace Lucene.Net.Index
 
                     Fields tfvFields = reader.GetTermVectors(i);
                     Assert.IsNotNull(tfvFields, "i=" + i);
-                    Terms tfv = tfvFields.Terms("utf8");
+                    Terms tfv = tfvFields.GetTerms("utf8");
                     Assert.IsNotNull(tfv, "docID=" + i + " index=" + oldName);
                 }
                 else
@@ -744,7 +744,7 @@ namespace Lucene.Net.Index
             {
                 Directory dir = OldIndexDirs[name];
                 IndexReader r = DirectoryReader.Open(dir);
-                TermsEnum terms = MultiFields.GetFields(r).Terms("content").GetIterator(null);
+                TermsEnum terms = MultiFields.GetFields(r).GetTerms("content").GetIterator(null);
                 BytesRef t = terms.Next();
                 Assert.IsNotNull(t);
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.Tests/core/Index/TestCodecs.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Index/TestCodecs.cs b/src/Lucene.Net.Tests/core/Index/TestCodecs.cs
index 80e1d87..e798da9 100644
--- a/src/Lucene.Net.Tests/core/Index/TestCodecs.cs
+++ b/src/Lucene.Net.Tests/core/Index/TestCodecs.cs
@@ -404,7 +404,7 @@ namespace Lucene.Net.Index
             fieldsEnum.MoveNext();
             string fieldName = fieldsEnum.Current;
             Assert.IsNotNull(fieldName);
-            Terms terms2 = reader.Terms(fieldName);
+            Terms terms2 = reader.GetTerms(fieldName);
             Assert.IsNotNull(terms2);
 
             TermsEnum termsEnum = terms2.GetIterator(null);
@@ -629,7 +629,7 @@ namespace Lucene.Net.Index
                 for (int iter = 0; iter < NUM_TEST_ITER; iter++)
                 {
                     FieldData field = Fields[Random().Next(Fields.Length)];
-                    TermsEnum termsEnum = TermsDict.Terms(field.FieldInfo.Name).GetIterator(null);
+                    TermsEnum termsEnum = TermsDict.GetTerms(field.FieldInfo.Name).GetIterator(null);
 #pragma warning disable 612, 618
                     if (Si.Codec is Lucene3xCodec)
 #pragma warning restore 612, 618

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.Tests/core/Index/TestDirectoryReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Index/TestDirectoryReader.cs b/src/Lucene.Net.Tests/core/Index/TestDirectoryReader.cs
index 62fd676..14fea69 100644
--- a/src/Lucene.Net.Tests/core/Index/TestDirectoryReader.cs
+++ b/src/Lucene.Net.Tests/core/Index/TestDirectoryReader.cs
@@ -68,7 +68,7 @@ namespace Lucene.Net.Index
             Document newDoc2 = reader.Document(1);
             Assert.IsTrue(newDoc2 != null);
             Assert.IsTrue(DocHelper.NumFields(newDoc2) == DocHelper.NumFields(doc2) - DocHelper.Unstored.Count);
-            Terms vector = reader.GetTermVectors(0).Terms(DocHelper.TEXT_FIELD_2_KEY);
+            Terms vector = reader.GetTermVectors(0).GetTerms(DocHelper.TEXT_FIELD_2_KEY);
             Assert.IsNotNull(vector);
 
             reader.Dispose();
@@ -662,15 +662,15 @@ namespace Lucene.Net.Index
             {
                 fenum2.MoveNext();
                 Assert.AreEqual(field1, fenum2.Current, "Different fields");
-                Terms terms1 = fields1.Terms(field1);
+                Terms terms1 = fields1.GetTerms(field1);
                 if (terms1 == null)
                 {
-                    Assert.IsNull(fields2.Terms(field1));
+                    Assert.IsNull(fields2.GetTerms(field1));
                     continue;
                 }
                 TermsEnum enum1 = terms1.GetIterator(null);
 
-                Terms terms2 = fields2.Terms(field1);
+                Terms terms2 = fields2.GetTerms(field1);
                 Assert.IsNotNull(terms2);
                 TermsEnum enum2 = terms2.GetIterator(null);
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.Tests/core/Index/TestDoc.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Index/TestDoc.cs b/src/Lucene.Net.Tests/core/Index/TestDoc.cs
index 482c3ec..bd65361 100644
--- a/src/Lucene.Net.Tests/core/Index/TestDoc.cs
+++ b/src/Lucene.Net.Tests/core/Index/TestDoc.cs
@@ -247,7 +247,7 @@ namespace Lucene.Net.Index
             Fields fields = reader.Fields;
             foreach (string field in fields)
             {
-                Terms terms = fields.Terms(field);
+                Terms terms = fields.GetTerms(field);
                 Assert.IsNotNull(terms);
                 TermsEnum tis = terms.GetIterator(null);
                 while (tis.Next() != null)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.Tests/core/Index/TestDocCount.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Index/TestDocCount.cs b/src/Lucene.Net.Tests/core/Index/TestDocCount.cs
index 6322786..3ac9a3c 100644
--- a/src/Lucene.Net.Tests/core/Index/TestDocCount.cs
+++ b/src/Lucene.Net.Tests/core/Index/TestDocCount.cs
@@ -78,7 +78,7 @@ namespace Lucene.Net.Index
             }
             foreach (string field in fields)
             {
-                Terms terms = fields.Terms(field);
+                Terms terms = fields.GetTerms(field);
                 if (terms == null)
                 {
                     continue;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.Tests/core/Index/TestDocumentWriter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Index/TestDocumentWriter.cs b/src/Lucene.Net.Tests/core/Index/TestDocumentWriter.cs
index ea81441..fe61f04 100644
--- a/src/Lucene.Net.Tests/core/Index/TestDocumentWriter.cs
+++ b/src/Lucene.Net.Tests/core/Index/TestDocumentWriter.cs
@@ -355,11 +355,11 @@ namespace Lucene.Net.Index
 
             IndexReader reader = DirectoryReader.Open(Dir);
             // f1
-            Terms tfv1 = reader.GetTermVectors(0).Terms("f1");
+            Terms tfv1 = reader.GetTermVectors(0).GetTerms("f1");
             Assert.IsNotNull(tfv1);
             Assert.AreEqual(2, tfv1.Count, "the 'with_tv' setting should rule!");
             // f2
-            Terms tfv2 = reader.GetTermVectors(0).Terms("f2");
+            Terms tfv2 = reader.GetTermVectors(0).GetTerms("f2");
             Assert.IsNotNull(tfv2);
             Assert.AreEqual(2, tfv2.Count, "the 'with_tv' setting should rule!");
             reader.Dispose();

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.Tests/core/Index/TestFilterAtomicReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Index/TestFilterAtomicReader.cs b/src/Lucene.Net.Tests/core/Index/TestFilterAtomicReader.cs
index ff95c85..f22c0ee 100644
--- a/src/Lucene.Net.Tests/core/Index/TestFilterAtomicReader.cs
+++ b/src/Lucene.Net.Tests/core/Index/TestFilterAtomicReader.cs
@@ -48,9 +48,9 @@ namespace Lucene.Net.Index
                 {
                 }
 
-                public override Terms Terms(string field)
+                public override Terms GetTerms(string field)
                 {
-                    return new TestTerms(base.Terms(field));
+                    return new TestTerms(base.GetTerms(field));
                 }
             }
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.Tests/core/Index/TestFlex.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Index/TestFlex.cs b/src/Lucene.Net.Tests/core/Index/TestFlex.cs
index 4c6a924..01cd762 100644
--- a/src/Lucene.Net.Tests/core/Index/TestFlex.cs
+++ b/src/Lucene.Net.Tests/core/Index/TestFlex.cs
@@ -80,7 +80,7 @@ namespace Lucene.Net.Index
             w.AddDocument(doc);
             w.ForceMerge(1);
             DirectoryReader r = w.Reader;
-            TermsEnum terms = GetOnlySegmentReader(r).Fields.Terms("f").GetIterator(null);
+            TermsEnum terms = GetOnlySegmentReader(r).Fields.GetTerms("f").GetIterator(null);
             Assert.IsTrue(terms.Next() != null);
             try
             {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.Tests/core/Index/TestIndexWriter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Index/TestIndexWriter.cs b/src/Lucene.Net.Tests/core/Index/TestIndexWriter.cs
index de2d69c..1c3a56a 100644
--- a/src/Lucene.Net.Tests/core/Index/TestIndexWriter.cs
+++ b/src/Lucene.Net.Tests/core/Index/TestIndexWriter.cs
@@ -917,7 +917,7 @@ namespace Lucene.Net.Index
             writer.Dispose();
             DirectoryReader reader = DirectoryReader.Open(dir);
             AtomicReader subreader = GetOnlySegmentReader(reader);
-            TermsEnum te = subreader.Fields.Terms("").GetIterator(null);
+            TermsEnum te = subreader.Fields.GetTerms("").GetIterator(null);
             Assert.AreEqual(new BytesRef("a"), te.Next());
             Assert.AreEqual(new BytesRef("b"), te.Next());
             Assert.AreEqual(new BytesRef("c"), te.Next());
@@ -940,7 +940,7 @@ namespace Lucene.Net.Index
             writer.Dispose();
             DirectoryReader reader = DirectoryReader.Open(dir);
             AtomicReader subreader = GetOnlySegmentReader(reader);
-            TermsEnum te = subreader.Fields.Terms("").GetIterator(null);
+            TermsEnum te = subreader.Fields.GetTerms("").GetIterator(null);
             Assert.AreEqual(new BytesRef(""), te.Next());
             Assert.AreEqual(new BytesRef("a"), te.Next());
             Assert.AreEqual(new BytesRef("b"), te.Next());
@@ -1077,7 +1077,7 @@ namespace Lucene.Net.Index
             w.Dispose();
 
             IndexReader r = DirectoryReader.Open(dir);
-            Terms tpv = r.GetTermVectors(0).Terms("field");
+            Terms tpv = r.GetTermVectors(0).GetTerms("field");
             TermsEnum termsEnum = tpv.GetIterator(null);
             Assert.IsNotNull(termsEnum.Next());
             DocsAndPositionsEnum dpEnum = termsEnum.DocsAndPositions(null, null);
@@ -1582,7 +1582,7 @@ namespace Lucene.Net.Index
             w.AddDocument(d);
 
             AtomicReader r = GetOnlySegmentReader(w.Reader);
-            TermsEnum t = r.Fields.Terms("field").GetIterator(null);
+            TermsEnum t = r.Fields.GetTerms("field").GetIterator(null);
             int count = 0;
             while (t.Next() != null)
             {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.Tests/core/Index/TestIndexWriterUnicode.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Index/TestIndexWriterUnicode.cs b/src/Lucene.Net.Tests/core/Index/TestIndexWriterUnicode.cs
index 251f05d..e9fdbf4 100644
--- a/src/Lucene.Net.Tests/core/Index/TestIndexWriterUnicode.cs
+++ b/src/Lucene.Net.Tests/core/Index/TestIndexWriterUnicode.cs
@@ -149,7 +149,7 @@ namespace Lucene.Net.Index
 
         private void CheckTermsOrder(IndexReader r, ISet<string> allTerms, bool isTop)
         {
-            TermsEnum terms = MultiFields.GetFields(r).Terms("f").GetIterator(null);
+            TermsEnum terms = MultiFields.GetFields(r).GetTerms("f").GetIterator(null);
 
             BytesRef last = new BytesRef();
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.Tests/core/Index/TestIndexableField.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Index/TestIndexableField.cs b/src/Lucene.Net.Tests/core/Index/TestIndexableField.cs
index a3d76b0..88402dd 100644
--- a/src/Lucene.Net.Tests/core/Index/TestIndexableField.cs
+++ b/src/Lucene.Net.Tests/core/Index/TestIndexableField.cs
@@ -318,7 +318,7 @@ namespace Lucene.Net.Index
                         bool tv = counter % 2 == 1 && fieldID != 9;
                         if (tv)
                         {
-                            Terms tfv = r.GetTermVectors(docID).Terms(name);
+                            Terms tfv = r.GetTermVectors(docID).GetTerms(name);
                             Assert.IsNotNull(tfv);
                             TermsEnum termsEnum = tfv.GetIterator(null);
                             Assert.AreEqual(new BytesRef("" + counter), termsEnum.Next());
@@ -342,7 +342,7 @@ namespace Lucene.Net.Index
                         else
                         {
                             Fields vectors = r.GetTermVectors(docID);
-                            Assert.IsTrue(vectors == null || vectors.Terms(name) == null);
+                            Assert.IsTrue(vectors == null || vectors.GetTerms(name) == null);
                         }
 
                         BooleanQuery bq = new BooleanQuery();

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.Tests/core/Index/TestParallelTermEnum.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Index/TestParallelTermEnum.cs b/src/Lucene.Net.Tests/core/Index/TestParallelTermEnum.cs
index db90e9f..9b6ac85 100644
--- a/src/Lucene.Net.Tests/core/Index/TestParallelTermEnum.cs
+++ b/src/Lucene.Net.Tests/core/Index/TestParallelTermEnum.cs
@@ -109,17 +109,17 @@ namespace Lucene.Net.Index
             fe.MoveNext();
             string f = fe.Current;
             Assert.AreEqual("field1", f);
-            CheckTerms(fields.Terms(f), liveDocs, "brown", "fox", "jumps", "quick", "the");
+            CheckTerms(fields.GetTerms(f), liveDocs, "brown", "fox", "jumps", "quick", "the");
 
             fe.MoveNext();
             f = fe.Current;
             Assert.AreEqual("field2", f);
-            CheckTerms(fields.Terms(f), liveDocs, "brown", "fox", "jumps", "quick", "the");
+            CheckTerms(fields.GetTerms(f), liveDocs, "brown", "fox", "jumps", "quick", "the");
 
             fe.MoveNext();
             f = fe.Current;
             Assert.AreEqual("field3", f);
-            CheckTerms(fields.Terms(f), liveDocs, "dog", "fox", "jumps", "lazy", "over", "the");
+            CheckTerms(fields.GetTerms(f), liveDocs, "dog", "fox", "jumps", "lazy", "over", "the");
 
             Assert.IsFalse(fe.MoveNext());
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.Tests/core/Index/TestPayloads.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Index/TestPayloads.cs b/src/Lucene.Net.Tests/core/Index/TestPayloads.cs
index ec64145..5c106d9 100644
--- a/src/Lucene.Net.Tests/core/Index/TestPayloads.cs
+++ b/src/Lucene.Net.Tests/core/Index/TestPayloads.cs
@@ -493,7 +493,7 @@ namespace Lucene.Net.Index
             }
             writer.Dispose();
             IndexReader reader = DirectoryReader.Open(dir);
-            TermsEnum terms = MultiFields.GetFields(reader).Terms(field).GetIterator(null);
+            TermsEnum terms = MultiFields.GetFields(reader).GetTerms(field).GetIterator(null);
             IBits liveDocs = MultiFields.GetLiveDocs(reader);
             DocsAndPositionsEnum tp = null;
             while (terms.Next() != null)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.Tests/core/Index/TestPerSegmentDeletes.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Index/TestPerSegmentDeletes.cs b/src/Lucene.Net.Tests/core/Index/TestPerSegmentDeletes.cs
index b52811b..ce7e767 100644
--- a/src/Lucene.Net.Tests/core/Index/TestPerSegmentDeletes.cs
+++ b/src/Lucene.Net.Tests/core/Index/TestPerSegmentDeletes.cs
@@ -245,7 +245,7 @@ namespace Lucene.Net.Index
         public virtual int[] ToDocsArray(Term term, IBits bits, IndexReader reader)
         {
             Fields fields = MultiFields.GetFields(reader);
-            Terms cterms = fields.Terms(term.Field);
+            Terms cterms = fields.GetTerms(term.Field);
             TermsEnum ctermsEnum = cterms.GetIterator(null);
             if (ctermsEnum.SeekExact(new BytesRef(term.Text())))
             {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.Tests/core/Index/TestPostingsOffsets.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Index/TestPostingsOffsets.cs b/src/Lucene.Net.Tests/core/Index/TestPostingsOffsets.cs
index 3d05e9a..706987e 100644
--- a/src/Lucene.Net.Tests/core/Index/TestPostingsOffsets.cs
+++ b/src/Lucene.Net.Tests/core/Index/TestPostingsOffsets.cs
@@ -327,7 +327,7 @@ namespace Lucene.Net.Index
                 // TODO: improve this
                 AtomicReader sub = (AtomicReader)ctx.Reader;
                 //System.out.println("\nsub=" + sub);
-                TermsEnum termsEnum = sub.Fields.Terms("content").GetIterator(null);
+                TermsEnum termsEnum = sub.Fields.GetTerms("content").GetIterator(null);
                 DocsEnum docs = null;
                 DocsAndPositionsEnum docsAndPositions = null;
                 DocsAndPositionsEnum docsAndPositionsAndOffsets = null;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.Tests/core/Index/TestSegmentMerger.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Index/TestSegmentMerger.cs b/src/Lucene.Net.Tests/core/Index/TestSegmentMerger.cs
index f73c270..30786b5 100644
--- a/src/Lucene.Net.Tests/core/Index/TestSegmentMerger.cs
+++ b/src/Lucene.Net.Tests/core/Index/TestSegmentMerger.cs
@@ -128,7 +128,7 @@ namespace Lucene.Net.Index
             //System.out.println("stored size: " + stored.Size());
             Assert.AreEqual(3, tvCount, "We do not have 3 fields that were indexed with term vector");
 
-            Terms vector = mergedReader.GetTermVectors(0).Terms(DocHelper.TEXT_FIELD_2_KEY);
+            Terms vector = mergedReader.GetTermVectors(0).GetTerms(DocHelper.TEXT_FIELD_2_KEY);
             Assert.IsNotNull(vector);
             Assert.AreEqual(3, vector.Count);
             TermsEnum termsEnum = vector.GetIterator(null);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.Tests/core/Index/TestSegmentReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Index/TestSegmentReader.cs b/src/Lucene.Net.Tests/core/Index/TestSegmentReader.cs
index effcd5c..b98287d 100644
--- a/src/Lucene.Net.Tests/core/Index/TestSegmentReader.cs
+++ b/src/Lucene.Net.Tests/core/Index/TestSegmentReader.cs
@@ -140,7 +140,7 @@ namespace Lucene.Net.Index
             Fields fields = MultiFields.GetFields(Reader);
             foreach (string field in fields)
             {
-                Terms terms = fields.Terms(field);
+                Terms terms = fields.GetTerms(field);
                 Assert.IsNotNull(terms);
                 TermsEnum termsEnum = terms.GetIterator(null);
                 while (termsEnum.Next() != null)
@@ -208,7 +208,7 @@ namespace Lucene.Net.Index
         [Test]
         public virtual void TestTermVectors()
         {
-            Terms result = Reader.GetTermVectors(0).Terms(DocHelper.TEXT_FIELD_2_KEY);
+            Terms result = Reader.GetTermVectors(0).GetTerms(DocHelper.TEXT_FIELD_2_KEY);
             Assert.IsNotNull(result);
             Assert.AreEqual(3, result.Count);
             TermsEnum termsEnum = result.GetIterator(null);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.Tests/core/Index/TestSegmentTermDocs.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Index/TestSegmentTermDocs.cs b/src/Lucene.Net.Tests/core/Index/TestSegmentTermDocs.cs
index dc8d8a9..f876774 100644
--- a/src/Lucene.Net.Tests/core/Index/TestSegmentTermDocs.cs
+++ b/src/Lucene.Net.Tests/core/Index/TestSegmentTermDocs.cs
@@ -73,7 +73,7 @@ namespace Lucene.Net.Index
             Assert.IsTrue(reader != null);
             Assert.AreEqual(indexDivisor, reader.TermInfosIndexDivisor);
 
-            TermsEnum terms = reader.Fields.Terms(DocHelper.TEXT_FIELD_2_KEY).GetIterator(null);
+            TermsEnum terms = reader.Fields.GetTerms(DocHelper.TEXT_FIELD_2_KEY).GetIterator(null);
             terms.SeekCeil(new BytesRef("field"));
             DocsEnum termDocs = TestUtil.Docs(Random(), terms, reader.LiveDocs, null, DocsEnum.FLAG_FREQS);
             if (termDocs.NextDoc() != DocIdSetIterator.NO_MORE_DOCS)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.Tests/core/Index/TestSegmentTermEnum.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Index/TestSegmentTermEnum.cs b/src/Lucene.Net.Tests/core/Index/TestSegmentTermEnum.cs
index e6bdca3..3ed504b 100644
--- a/src/Lucene.Net.Tests/core/Index/TestSegmentTermEnum.cs
+++ b/src/Lucene.Net.Tests/core/Index/TestSegmentTermEnum.cs
@@ -86,7 +86,7 @@ namespace Lucene.Net.Index
             AddDoc(writer, "aaa bbb");
             writer.Dispose();
             SegmentReader reader = GetOnlySegmentReader(DirectoryReader.Open(Dir));
-            TermsEnum terms = reader.Fields.Terms("content").GetIterator(null);
+            TermsEnum terms = reader.Fields.GetTerms("content").GetIterator(null);
             Assert.IsNotNull(terms.Next());
             Assert.AreEqual("aaa", terms.Term.Utf8ToString());
             Assert.IsNotNull(terms.Next());

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.Tests/core/Index/TestStressAdvance.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Index/TestStressAdvance.cs b/src/Lucene.Net.Tests/core/Index/TestStressAdvance.cs
index aeefc90..c6c4521 100644
--- a/src/Lucene.Net.Tests/core/Index/TestStressAdvance.cs
+++ b/src/Lucene.Net.Tests/core/Index/TestStressAdvance.cs
@@ -91,7 +91,7 @@ namespace Lucene.Net.Index
                         bDocIDs.Add(docID);
                     }
                 }
-                TermsEnum te = GetOnlySegmentReader(r).Fields.Terms("field").GetIterator(null);
+                TermsEnum te = GetOnlySegmentReader(r).Fields.GetTerms("field").GetIterator(null);
 
                 DocsEnum de = null;
                 for (int iter2 = 0; iter2 < 10; iter2++)


[22/53] [abbrv] lucenenet git commit: Lucene.Net.Core: Renamed all type-derived classes and interfaces from Short, Int, Long, and Float to match CLR types Int16, Int32, Int64, and Single, respectively.

Posted by ni...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Tests/core/Index/TestBinaryDocValuesUpdates.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Index/TestBinaryDocValuesUpdates.cs b/src/Lucene.Net.Tests/core/Index/TestBinaryDocValuesUpdates.cs
index 266b436..a9629fb 100644
--- a/src/Lucene.Net.Tests/core/Index/TestBinaryDocValuesUpdates.cs
+++ b/src/Lucene.Net.Tests/core/Index/TestBinaryDocValuesUpdates.cs
@@ -1230,7 +1230,7 @@ namespace Lucene.Net.Index
             }
 
             CountdownEvent done = new CountdownEvent(numThreads);
-            AtomicInteger numUpdates = new AtomicInteger(AtLeast(100));
+            AtomicInt32 numUpdates = new AtomicInt32(AtLeast(100));
 
             // same thread updates a field as well as reopens
             ThreadClass[] threads = new ThreadClass[numThreads];
@@ -1285,11 +1285,11 @@ namespace Lucene.Net.Index
             private IndexWriter Writer;
             private int NumDocs;
             private CountdownEvent Done;
-            private AtomicInteger NumUpdates;
+            private AtomicInt32 NumUpdates;
             private string f;
             private string Cf;
 
-            public ThreadAnonymousInnerClassHelper(TestBinaryDocValuesUpdates outerInstance, string str, IndexWriter writer, int numDocs, CountdownEvent done, AtomicInteger numUpdates, string f, string cf)
+            public ThreadAnonymousInnerClassHelper(TestBinaryDocValuesUpdates outerInstance, string str, IndexWriter writer, int numDocs, CountdownEvent done, AtomicInt32 numUpdates, string f, string cf)
                 : base(str)
             {
                 this.OuterInstance = outerInstance;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Tests/core/Index/TestConcurrentMergeScheduler.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Index/TestConcurrentMergeScheduler.cs b/src/Lucene.Net.Tests/core/Index/TestConcurrentMergeScheduler.cs
index 1cde70b..da0395e 100644
--- a/src/Lucene.Net.Tests/core/Index/TestConcurrentMergeScheduler.cs
+++ b/src/Lucene.Net.Tests/core/Index/TestConcurrentMergeScheduler.cs
@@ -291,7 +291,7 @@ namespace Lucene.Net.Index
             int maxMergeCount = TestUtil.NextInt(Random(), 1, 5);
             int maxMergeThreads = TestUtil.NextInt(Random(), 1, maxMergeCount);
             CountdownEvent enoughMergesWaiting = new CountdownEvent(maxMergeCount);
-            AtomicInteger runningMergeCount = new AtomicInteger(0);
+            AtomicInt32 runningMergeCount = new AtomicInt32(0);
             AtomicBoolean failed = new AtomicBoolean();
 
             if (VERBOSE)
@@ -329,10 +329,10 @@ namespace Lucene.Net.Index
 
             private int maxMergeCount;
             private CountdownEvent EnoughMergesWaiting;
-            private AtomicInteger RunningMergeCount;
+            private AtomicInt32 RunningMergeCount;
             private AtomicBoolean Failed;
 
-            public ConcurrentMergeSchedulerAnonymousInnerClassHelper(TestConcurrentMergeScheduler outerInstance, int maxMergeCount, CountdownEvent enoughMergesWaiting, AtomicInteger runningMergeCount, AtomicBoolean failed)
+            public ConcurrentMergeSchedulerAnonymousInnerClassHelper(TestConcurrentMergeScheduler outerInstance, int maxMergeCount, CountdownEvent enoughMergesWaiting, AtomicInt32 runningMergeCount, AtomicBoolean failed)
             {
                 this.OuterInstance = outerInstance;
                 this.maxMergeCount = maxMergeCount;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Tests/core/Index/TestDirectoryReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Index/TestDirectoryReader.cs b/src/Lucene.Net.Tests/core/Index/TestDirectoryReader.cs
index a0ccdce..62fd676 100644
--- a/src/Lucene.Net.Tests/core/Index/TestDirectoryReader.cs
+++ b/src/Lucene.Net.Tests/core/Index/TestDirectoryReader.cs
@@ -822,7 +822,7 @@ namespace Lucene.Net.Index
             // Open reader1
             DirectoryReader r = DirectoryReader.Open(dir);
             AtomicReader r1 = GetOnlySegmentReader(r);
-            FieldCache.Ints ints = FieldCache.DEFAULT.GetInt32s(r1, "number", false);
+            FieldCache.Int32s ints = FieldCache.DEFAULT.GetInt32s(r1, "number", false);
             Assert.AreEqual(17, ints.Get(0));
 
             // Add new segment
@@ -834,7 +834,7 @@ namespace Lucene.Net.Index
             Assert.IsNotNull(r2);
             r.Dispose();
             AtomicReader sub0 = (AtomicReader)r2.Leaves[0].Reader;
-            FieldCache.Ints ints2 = FieldCache.DEFAULT.GetInt32s(sub0, "number", false);
+            FieldCache.Int32s ints2 = FieldCache.DEFAULT.GetInt32s(sub0, "number", false);
             r2.Dispose();
             Assert.IsTrue(ints == ints2);
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Tests/core/Index/TestDocTermOrds.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Index/TestDocTermOrds.cs b/src/Lucene.Net.Tests/core/Index/TestDocTermOrds.cs
index 337c152..1ea4d2b 100644
--- a/src/Lucene.Net.Tests/core/Index/TestDocTermOrds.cs
+++ b/src/Lucene.Net.Tests/core/Index/TestDocTermOrds.cs
@@ -32,7 +32,7 @@ namespace Lucene.Net.Index
     using Directory = Lucene.Net.Store.Directory;
     using Document = Documents.Document;
     using Field = Field;
-    using IntField = IntField;
+    using Int32Field = Int32Field;
     using LuceneTestCase = Lucene.Net.Util.LuceneTestCase;
     using MockAnalyzer = Lucene.Net.Analysis.MockAnalyzer;
     using PostingsFormat = Lucene.Net.Codecs.PostingsFormat;
@@ -134,7 +134,7 @@ namespace Lucene.Net.Index
             {
                 Document doc = new Document();
 
-                doc.Add(new IntField("id", id, Field.Store.NO));
+                doc.Add(new Int32Field("id", id, Field.Store.NO));
 
                 int termCount = TestUtil.NextInt(Random(), 0, 20 * RANDOM_MULTIPLIER);
                 while (ordsForDocSet.Count < termCount)
@@ -251,7 +251,7 @@ namespace Lucene.Net.Index
             {
                 Document doc = new Document();
 
-                doc.Add(new IntField("id", id, Field.Store.NO));
+                doc.Add(new Int32Field("id", id, Field.Store.NO));
 
                 int termCount = TestUtil.NextInt(Random(), 0, 20 * RANDOM_MULTIPLIER);
                 while (ordsForDocSet.Count < termCount)
@@ -342,7 +342,7 @@ namespace Lucene.Net.Index
         {
             DocTermOrds dto = new DocTermOrds(r, r.LiveDocs, "field", prefixRef, int.MaxValue, TestUtil.NextInt(Random(), 2, 10));
 
-            FieldCache.Ints docIDToID = FieldCache.DEFAULT.GetInt32s(r, "id", false);
+            FieldCache.Int32s docIDToID = FieldCache.DEFAULT.GetInt32s(r, "id", false);
             /*
               for(int docID=0;docID<subR.MaxDoc;docID++) {
               System.out.println("  docID=" + docID + " id=" + docIDToID[docID]);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Tests/core/Index/TestDocValuesWithThreads.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Index/TestDocValuesWithThreads.cs b/src/Lucene.Net.Tests/core/Index/TestDocValuesWithThreads.cs
index 11fa190..40cc370 100644
--- a/src/Lucene.Net.Tests/core/Index/TestDocValuesWithThreads.cs
+++ b/src/Lucene.Net.Tests/core/Index/TestDocValuesWithThreads.cs
@@ -126,7 +126,7 @@ namespace Lucene.Net.Index
                 try
                 {
                     //NumericDocValues ndv = ar.GetNumericDocValues("number");
-                    FieldCache.Longs ndv = FieldCache.DEFAULT.GetInt64s(Ar, "number", false);
+                    FieldCache.Int64s ndv = FieldCache.DEFAULT.GetInt64s(Ar, "number", false);
                     //BinaryDocValues bdv = ar.GetBinaryDocValues("bytes");
                     BinaryDocValues bdv = FieldCache.DEFAULT.GetTerms(Ar, "bytes", false);
                     SortedDocValues sdv = FieldCache.DEFAULT.GetTermsIndex(Ar, "sorted");

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Tests/core/Index/TestDocumentsWriterDeleteQueue.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Index/TestDocumentsWriterDeleteQueue.cs b/src/Lucene.Net.Tests/core/Index/TestDocumentsWriterDeleteQueue.cs
index f1ba611..b238062 100644
--- a/src/Lucene.Net.Tests/core/Index/TestDocumentsWriterDeleteQueue.cs
+++ b/src/Lucene.Net.Tests/core/Index/TestDocumentsWriterDeleteQueue.cs
@@ -219,7 +219,7 @@ namespace Lucene.Net.Index
                 uniqueValues.Add(new Term("id", ids[i].ToString()));
             }
             CountdownEvent latch = new CountdownEvent(1);
-            AtomicInteger index = new AtomicInteger(0);
+            AtomicInt32 index = new AtomicInt32(0);
             int numThreads = 2 + Random().Next(5);
             UpdateThread[] threads = new UpdateThread[numThreads];
             for (int i = 0; i < threads.Length; i++)
@@ -257,13 +257,13 @@ namespace Lucene.Net.Index
         private class UpdateThread : ThreadClass
         {
             internal readonly DocumentsWriterDeleteQueue Queue;
-            internal readonly AtomicInteger Index;
+            internal readonly AtomicInt32 Index;
             internal readonly int?[] Ids;
             internal readonly DeleteSlice Slice;
             internal readonly BufferedUpdates Deletes;
             internal readonly CountdownEvent Latch;
 
-            protected internal UpdateThread(DocumentsWriterDeleteQueue queue, AtomicInteger index, int?[] ids, CountdownEvent latch)
+            protected internal UpdateThread(DocumentsWriterDeleteQueue queue, AtomicInt32 index, int?[] ids, CountdownEvent latch)
             {
                 this.Queue = queue;
                 this.Index = index;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Tests/core/Index/TestFlushByRamOrCountsPolicy.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Index/TestFlushByRamOrCountsPolicy.cs b/src/Lucene.Net.Tests/core/Index/TestFlushByRamOrCountsPolicy.cs
index 9450356..001f9e9 100644
--- a/src/Lucene.Net.Tests/core/Index/TestFlushByRamOrCountsPolicy.cs
+++ b/src/Lucene.Net.Tests/core/Index/TestFlushByRamOrCountsPolicy.cs
@@ -69,7 +69,7 @@ namespace Lucene.Net.Index
         protected internal virtual void RunFlushByRam(int numThreads, double maxRamMB, bool ensureNotStalled)
         {
             int numDocumentsToIndex = 10 + AtLeast(30);
-            AtomicInteger numDocs = new AtomicInteger(numDocumentsToIndex);
+            AtomicInt32 numDocs = new AtomicInt32(numDocumentsToIndex);
             Directory dir = NewDirectory();
             MockDefaultFlushPolicy flushPolicy = new MockDefaultFlushPolicy();
             MockAnalyzer analyzer = new MockAnalyzer(Random());
@@ -130,7 +130,7 @@ namespace Lucene.Net.Index
             {
 
                 int numDocumentsToIndex = 50 + AtLeast(30);
-                AtomicInteger numDocs = new AtomicInteger(numDocumentsToIndex);
+                AtomicInt32 numDocs = new AtomicInt32(numDocumentsToIndex);
                 Directory dir = NewDirectory();
                 MockDefaultFlushPolicy flushPolicy = new MockDefaultFlushPolicy();
                 IndexWriterConfig iwc = NewIndexWriterConfig(TEST_VERSION_CURRENT, new MockAnalyzer(Random())).SetFlushPolicy(flushPolicy);
@@ -179,7 +179,7 @@ namespace Lucene.Net.Index
         {
             int numThreads = 1 + Random().Next(8);
             int numDocumentsToIndex = 50 + AtLeast(70);
-            AtomicInteger numDocs = new AtomicInteger(numDocumentsToIndex);
+            AtomicInt32 numDocs = new AtomicInt32(numDocumentsToIndex);
             Directory dir = NewDirectory();
             IndexWriterConfig iwc = NewIndexWriterConfig(TEST_VERSION_CURRENT, new MockAnalyzer(Random()));
             MockDefaultFlushPolicy flushPolicy = new MockDefaultFlushPolicy();
@@ -244,7 +244,7 @@ namespace Lucene.Net.Index
             int numDocumentsToIndex = 50 + Random().Next(50);
             for (int i = 0; i < numThreads.Length; i++)
             {
-                AtomicInteger numDocs = new AtomicInteger(numDocumentsToIndex);
+                AtomicInt32 numDocs = new AtomicInt32(numDocumentsToIndex);
                 MockDirectoryWrapper dir = NewMockDirectory();
                 // mock a very slow harddisk sometimes here so that flushing is very slow
                 dir.Throttling = MockDirectoryWrapper.Throttling_e.SOMETIMES;
@@ -312,10 +312,10 @@ namespace Lucene.Net.Index
             internal IndexWriter Writer;
             internal LiveIndexWriterConfig Iwc;
             internal LineFileDocs Docs;
-            internal AtomicInteger PendingDocs;
+            internal AtomicInt32 PendingDocs;
             internal readonly bool DoRandomCommit;
 
-            public IndexThread(TestFlushByRamOrCountsPolicy outerInstance, AtomicInteger pendingDocs, int numThreads, IndexWriter writer, LineFileDocs docs, bool doRandomCommit)
+            public IndexThread(TestFlushByRamOrCountsPolicy outerInstance, AtomicInt32 pendingDocs, int numThreads, IndexWriter writer, LineFileDocs docs, bool doRandomCommit)
             {
                 this.OuterInstance = outerInstance;
                 this.PendingDocs = pendingDocs;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Tests/core/Index/TestForceMergeForever.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Index/TestForceMergeForever.cs b/src/Lucene.Net.Tests/core/Index/TestForceMergeForever.cs
index 720a6e1..12145b1 100644
--- a/src/Lucene.Net.Tests/core/Index/TestForceMergeForever.cs
+++ b/src/Lucene.Net.Tests/core/Index/TestForceMergeForever.cs
@@ -34,7 +34,7 @@ namespace Lucene.Net.Index
         // Just counts how many merges are done
         private class MyIndexWriter : IndexWriter
         {
-            internal AtomicInteger MergeCount = new AtomicInteger();
+            internal AtomicInt32 MergeCount = new AtomicInt32();
             internal bool First;
 
             public MyIndexWriter(Directory dir, IndexWriterConfig conf)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Tests/core/Index/TestIndexReaderClose.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Index/TestIndexReaderClose.cs b/src/Lucene.Net.Tests/core/Index/TestIndexReaderClose.cs
index 6767adf..9c96ced 100644
--- a/src/Lucene.Net.Tests/core/Index/TestIndexReaderClose.cs
+++ b/src/Lucene.Net.Tests/core/Index/TestIndexReaderClose.cs
@@ -49,7 +49,7 @@ namespace Lucene.Net.Index
                 FilterAtomicReader reader = new FilterAtomicReaderAnonymousInnerClassHelper(this, wrap, throwOnClose);
                 IList<IndexReader.IReaderClosedListener> listeners = new List<IndexReader.IReaderClosedListener>();
                 int listenerCount = Random().Next(20);
-                AtomicInteger count = new AtomicInteger();
+                AtomicInt32 count = new AtomicInt32();
                 bool faultySet = false;
                 for (int i = 0; i < listenerCount; i++)
                 {
@@ -131,9 +131,9 @@ namespace Lucene.Net.Index
 
         private sealed class CountListener : IndexReader.IReaderClosedListener
         {
-            internal readonly AtomicInteger Count;
+            internal readonly AtomicInt32 Count;
 
-            public CountListener(AtomicInteger count)
+            public CountListener(AtomicInt32 count)
             {
                 this.Count = count;
             }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Tests/core/Index/TestIndexWriter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Index/TestIndexWriter.cs b/src/Lucene.Net.Tests/core/Index/TestIndexWriter.cs
index b2d5535..de2d69c 100644
--- a/src/Lucene.Net.Tests/core/Index/TestIndexWriter.cs
+++ b/src/Lucene.Net.Tests/core/Index/TestIndexWriter.cs
@@ -61,7 +61,7 @@ namespace Lucene.Net.Index
     using MockDirectoryWrapper = Lucene.Net.Store.MockDirectoryWrapper;
     using NoLockFactory = Lucene.Net.Store.NoLockFactory;
     using NumericDocValuesField = NumericDocValuesField;
-    using PackedInts = Lucene.Net.Util.Packed.PackedInts;
+    using PackedInt32s = Lucene.Net.Util.Packed.PackedInt32s;
     using PhraseQuery = Lucene.Net.Search.PhraseQuery;
     using RAMDirectory = Lucene.Net.Store.RAMDirectory;
     using ScoreDoc = Lucene.Net.Search.ScoreDoc;
@@ -2024,7 +2024,7 @@ namespace Lucene.Net.Index
             w.Dispose();
             Assert.AreEqual(1, reader.DocFreq(new Term("content", bigTerm)));
 
-            SortedDocValues dti = FieldCache.DEFAULT.GetTermsIndex(SlowCompositeReaderWrapper.Wrap(reader), "content", (float)Random().NextDouble() * PackedInts.FAST);
+            SortedDocValues dti = FieldCache.DEFAULT.GetTermsIndex(SlowCompositeReaderWrapper.Wrap(reader), "content", (float)Random().NextDouble() * PackedInt32s.FAST);
             Assert.AreEqual(4, dti.ValueCount);
             BytesRef br = new BytesRef();
             dti.LookupOrd(2, br);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Tests/core/Index/TestIndexWriterDelete.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Index/TestIndexWriterDelete.cs b/src/Lucene.Net.Tests/core/Index/TestIndexWriterDelete.cs
index 1fb48ea..6ac040a 100644
--- a/src/Lucene.Net.Tests/core/Index/TestIndexWriterDelete.cs
+++ b/src/Lucene.Net.Tests/core/Index/TestIndexWriterDelete.cs
@@ -1304,7 +1304,7 @@ namespace Lucene.Net.Index
             Directory dir = NewDirectory();
             // Cannot use RandomIndexWriter because we don't want to
             // ever call commit() for this test:
-            AtomicInteger docsInSegment = new AtomicInteger();
+            AtomicInt32 docsInSegment = new AtomicInt32();
             AtomicBoolean closing = new AtomicBoolean();
             AtomicBoolean sawAfterFlush = new AtomicBoolean();
             IndexWriter w = new IndexWriterAnonymousInnerClassHelper(this, dir, NewIndexWriterConfig(TEST_VERSION_CURRENT, new MockAnalyzer(Random())).SetRAMBufferSizeMB(0.5).SetMaxBufferedDocs(-1).SetMergePolicy(NoMergePolicy.NO_COMPOUND_FILES).SetReaderPooling(false), docsInSegment, closing, sawAfterFlush);
@@ -1346,11 +1346,11 @@ namespace Lucene.Net.Index
         {
             private readonly TestIndexWriterDelete OuterInstance;
 
-            private AtomicInteger DocsInSegment;
+            private AtomicInt32 DocsInSegment;
             private AtomicBoolean Closing;
             private AtomicBoolean SawAfterFlush;
 
-            public IndexWriterAnonymousInnerClassHelper(TestIndexWriterDelete outerInstance, Directory dir, IndexWriterConfig setReaderPooling, AtomicInteger docsInSegment, AtomicBoolean closing, AtomicBoolean sawAfterFlush)
+            public IndexWriterAnonymousInnerClassHelper(TestIndexWriterDelete outerInstance, Directory dir, IndexWriterConfig setReaderPooling, AtomicInt32 docsInSegment, AtomicBoolean closing, AtomicBoolean sawAfterFlush)
                 : base(dir, setReaderPooling)
             {
                 this.OuterInstance = outerInstance;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Tests/core/Index/TestIndexWriterReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Index/TestIndexWriterReader.cs b/src/Lucene.Net.Tests/core/Index/TestIndexWriterReader.cs
index 4748ea0..9207b98 100644
--- a/src/Lucene.Net.Tests/core/Index/TestIndexWriterReader.cs
+++ b/src/Lucene.Net.Tests/core/Index/TestIndexWriterReader.cs
@@ -473,8 +473,8 @@ namespace Lucene.Net.Index
             internal readonly IList<Exception> Failures = new List<Exception>();
             internal IndexReader[] Readers;
             internal bool DidClose = false;
-            internal AtomicInteger Count = new AtomicInteger(0);
-            internal AtomicInteger NumaddIndexes = new AtomicInteger(0);
+            internal AtomicInt32 Count = new AtomicInt32(0);
+            internal AtomicInt32 NumaddIndexes = new AtomicInt32(0);
 
             public AddDirectoriesThreads(TestIndexWriterReader outerInstance, int numDirs, IndexWriter mainWriter)
             {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Tests/core/Index/TestIntBlockPool.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Index/TestIntBlockPool.cs b/src/Lucene.Net.Tests/core/Index/TestIntBlockPool.cs
index f81bfa2..b74d541 100644
--- a/src/Lucene.Net.Tests/core/Index/TestIntBlockPool.cs
+++ b/src/Lucene.Net.Tests/core/Index/TestIntBlockPool.cs
@@ -23,12 +23,12 @@ namespace Lucene.Net.Index
              */
 
     using Counter = Lucene.Net.Util.Counter;
-    using IntBlockPool = Lucene.Net.Util.IntBlockPool;
+    using Int32BlockPool = Lucene.Net.Util.Int32BlockPool;
     using LuceneTestCase = Lucene.Net.Util.LuceneTestCase;
     using RamUsageEstimator = Lucene.Net.Util.RamUsageEstimator;
 
     /// <summary>
-    /// tests basic <seealso cref="IntBlockPool"/> functionality
+    /// tests basic <seealso cref="Int32BlockPool"/> functionality
     /// </summary>
     [TestFixture]
     public class TestIntBlockPool : LuceneTestCase
@@ -37,11 +37,11 @@ namespace Lucene.Net.Index
         public virtual void TestSingleWriterReader()
         {
             Counter bytesUsed = Util.Counter.NewCounter();
-            IntBlockPool pool = new IntBlockPool(new ByteTrackingAllocator(bytesUsed));
+            Int32BlockPool pool = new Int32BlockPool(new ByteTrackingAllocator(bytesUsed));
 
             for (int j = 0; j < 2; j++)
             {
-                IntBlockPool.SliceWriter writer = new IntBlockPool.SliceWriter(pool);
+                Int32BlockPool.SliceWriter writer = new Int32BlockPool.SliceWriter(pool);
                 int start = writer.StartNewSlice();
                 int num = AtLeast(100);
                 for (int i = 0; i < num; i++)
@@ -50,7 +50,7 @@ namespace Lucene.Net.Index
                 }
 
                 int upto = writer.CurrentOffset;
-                IntBlockPool.SliceReader reader = new IntBlockPool.SliceReader(pool);
+                Int32BlockPool.SliceReader reader = new Int32BlockPool.SliceReader(pool);
                 reader.Reset(start, upto);
                 for (int i = 0; i < num; i++)
                 {
@@ -65,7 +65,7 @@ namespace Lucene.Net.Index
                 else
                 {
                     pool.Reset(true, true);
-                    Assert.AreEqual(IntBlockPool.INT_BLOCK_SIZE * RamUsageEstimator.NUM_BYTES_INT, bytesUsed.Get());
+                    Assert.AreEqual(Int32BlockPool.INT_BLOCK_SIZE * RamUsageEstimator.NUM_BYTES_INT, bytesUsed.Get());
                 }
             }
         }
@@ -74,7 +74,7 @@ namespace Lucene.Net.Index
         public virtual void TestMultipleWriterReader()
         {
             Counter bytesUsed = Util.Counter.NewCounter();
-            IntBlockPool pool = new IntBlockPool(new ByteTrackingAllocator(bytesUsed));
+            Int32BlockPool pool = new Int32BlockPool(new ByteTrackingAllocator(bytesUsed));
             for (int j = 0; j < 2; j++)
             {
                 IList<StartEndAndValues> holders = new List<StartEndAndValues>();
@@ -83,8 +83,8 @@ namespace Lucene.Net.Index
                 {
                     holders.Add(new StartEndAndValues(Random().Next(1000)));
                 }
-                IntBlockPool.SliceWriter writer = new IntBlockPool.SliceWriter(pool);
-                IntBlockPool.SliceReader reader = new IntBlockPool.SliceReader(pool);
+                Int32BlockPool.SliceWriter writer = new Int32BlockPool.SliceWriter(pool);
+                Int32BlockPool.SliceReader reader = new Int32BlockPool.SliceReader(pool);
 
                 int numValuesToWrite = AtLeast(10000);
                 for (int i = 0; i < numValuesToWrite; i++)
@@ -122,17 +122,17 @@ namespace Lucene.Net.Index
                 else
                 {
                     pool.Reset(true, true);
-                    Assert.AreEqual(IntBlockPool.INT_BLOCK_SIZE * RamUsageEstimator.NUM_BYTES_INT, bytesUsed.Get());
+                    Assert.AreEqual(Int32BlockPool.INT_BLOCK_SIZE * RamUsageEstimator.NUM_BYTES_INT, bytesUsed.Get());
                 }
             }
         }
 
-        private class ByteTrackingAllocator : IntBlockPool.Allocator
+        private class ByteTrackingAllocator : Int32BlockPool.Allocator
         {
             internal readonly Counter BytesUsed;
 
             public ByteTrackingAllocator(Counter bytesUsed)
-                : this(IntBlockPool.INT_BLOCK_SIZE, bytesUsed)
+                : this(Int32BlockPool.INT_BLOCK_SIZE, bytesUsed)
             {
             }
 
@@ -154,7 +154,7 @@ namespace Lucene.Net.Index
             }
         }
 
-        private void AssertReader(IntBlockPool.SliceReader reader, StartEndAndValues values)
+        private void AssertReader(Int32BlockPool.SliceReader reader, StartEndAndValues values)
         {
             reader.Reset(values.Start, values.End);
             for (int i = 0; i < values.ValueCount; i++)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Tests/core/Index/TestMixedDocValuesUpdates.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Index/TestMixedDocValuesUpdates.cs b/src/Lucene.Net.Tests/core/Index/TestMixedDocValuesUpdates.cs
index b02aa25..4a3741d 100644
--- a/src/Lucene.Net.Tests/core/Index/TestMixedDocValuesUpdates.cs
+++ b/src/Lucene.Net.Tests/core/Index/TestMixedDocValuesUpdates.cs
@@ -266,7 +266,7 @@ namespace Lucene.Net.Index
             }
 
             CountdownEvent done = new CountdownEvent(numThreads);
-            AtomicInteger numUpdates = new AtomicInteger(AtLeast(100));
+            AtomicInt32 numUpdates = new AtomicInt32(AtLeast(100));
 
             // same thread updates a field as well as reopens
             ThreadClass[] threads = new ThreadClass[numThreads];
@@ -326,11 +326,11 @@ namespace Lucene.Net.Index
             private IndexWriter Writer;
             private int NumDocs;
             private CountdownEvent Done;
-            private AtomicInteger NumUpdates;
+            private AtomicInt32 NumUpdates;
             private string f;
             private string Cf;
 
-            public ThreadAnonymousInnerClassHelper(TestMixedDocValuesUpdates outerInstance, string str, IndexWriter writer, int numDocs, CountdownEvent done, AtomicInteger numUpdates, string f, string cf)
+            public ThreadAnonymousInnerClassHelper(TestMixedDocValuesUpdates outerInstance, string str, IndexWriter writer, int numDocs, CountdownEvent done, AtomicInt32 numUpdates, string f, string cf)
                 : base(str)
             {
                 this.OuterInstance = outerInstance;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Tests/core/Index/TestMultiLevelSkipList.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Index/TestMultiLevelSkipList.cs b/src/Lucene.Net.Tests/core/Index/TestMultiLevelSkipList.cs
index 70a459e..49456ed 100644
--- a/src/Lucene.Net.Tests/core/Index/TestMultiLevelSkipList.cs
+++ b/src/Lucene.Net.Tests/core/Index/TestMultiLevelSkipList.cs
@@ -125,7 +125,7 @@ namespace Lucene.Net.Index
 
         private class PayloadAnalyzer : Analyzer
         {
-            internal readonly AtomicInteger PayloadCount = new AtomicInteger(-1);
+            internal readonly AtomicInt32 PayloadCount = new AtomicInt32(-1);
 
             protected internal override TokenStreamComponents CreateComponents(string fieldName, TextReader reader)
             {
@@ -137,9 +137,9 @@ namespace Lucene.Net.Index
         private class PayloadFilter : TokenFilter
         {
             internal IPayloadAttribute PayloadAtt;
-            internal AtomicInteger PayloadCount;
+            internal AtomicInt32 PayloadCount;
 
-            protected internal PayloadFilter(AtomicInteger payloadCount, TokenStream input)
+            protected internal PayloadFilter(AtomicInt32 payloadCount, TokenStream input)
                 : base(input)
             {
                 this.PayloadCount = payloadCount;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Tests/core/Index/TestNRTReaderWithThreads.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Index/TestNRTReaderWithThreads.cs b/src/Lucene.Net.Tests/core/Index/TestNRTReaderWithThreads.cs
index bcf2260..918b5b5 100644
--- a/src/Lucene.Net.Tests/core/Index/TestNRTReaderWithThreads.cs
+++ b/src/Lucene.Net.Tests/core/Index/TestNRTReaderWithThreads.cs
@@ -32,7 +32,7 @@ namespace Lucene.Net.Index
     [TestFixture]
     public class TestNRTReaderWithThreads : LuceneTestCase
     {
-        internal AtomicInteger Seq = new AtomicInteger(1);
+        internal AtomicInt32 Seq = new AtomicInt32(1);
         [Test]
         public virtual void TestIndexing()
         {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Tests/core/Index/TestNumericDocValuesUpdates.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Index/TestNumericDocValuesUpdates.cs b/src/Lucene.Net.Tests/core/Index/TestNumericDocValuesUpdates.cs
index 4bff40a..cdef49a 100644
--- a/src/Lucene.Net.Tests/core/Index/TestNumericDocValuesUpdates.cs
+++ b/src/Lucene.Net.Tests/core/Index/TestNumericDocValuesUpdates.cs
@@ -1149,7 +1149,7 @@ namespace Lucene.Net.Index
             }
 
             CountdownEvent done = new CountdownEvent(numThreads);
-            AtomicInteger numUpdates = new AtomicInteger(AtLeast(100));
+            AtomicInt32 numUpdates = new AtomicInt32(AtLeast(100));
 
             // same thread updates a field as well as reopens
             ThreadClass[] threads = new ThreadClass[numThreads];
@@ -1203,11 +1203,11 @@ namespace Lucene.Net.Index
             private IndexWriter Writer;
             private int NumDocs;
             private CountdownEvent Done;
-            private AtomicInteger NumUpdates;
+            private AtomicInt32 NumUpdates;
             private string f;
             private string Cf;
 
-            public ThreadAnonymousInnerClassHelper(TestNumericDocValuesUpdates outerInstance, string str, IndexWriter writer, int numDocs, CountdownEvent done, AtomicInteger numUpdates, string f, string cf)
+            public ThreadAnonymousInnerClassHelper(TestNumericDocValuesUpdates outerInstance, string str, IndexWriter writer, int numDocs, CountdownEvent done, AtomicInt32 numUpdates, string f, string cf)
                 : base(str)
             {
                 this.OuterInstance = outerInstance;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Tests/core/Index/TestPostingsOffsets.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Index/TestPostingsOffsets.cs b/src/Lucene.Net.Tests/core/Index/TestPostingsOffsets.cs
index ddbb79e..3d05e9a 100644
--- a/src/Lucene.Net.Tests/core/Index/TestPostingsOffsets.cs
+++ b/src/Lucene.Net.Tests/core/Index/TestPostingsOffsets.cs
@@ -36,7 +36,7 @@ namespace Lucene.Net.Index
     using English = Lucene.Net.Util.English;
     using Field = Field;
     using FieldType = FieldType;
-    using IntField = IntField;
+    using Int32Field = Int32Field;
     using IOUtils = Lucene.Net.Util.IOUtils;
     using LuceneTestCase = Lucene.Net.Util.LuceneTestCase;
     using MockAnalyzer = Lucene.Net.Analysis.MockAnalyzer;
@@ -262,7 +262,7 @@ namespace Lucene.Net.Index
             for (int docCount = 0; docCount < numDocs; docCount++)
             {
                 Document doc = new Document();
-                doc.Add(new IntField("id", docCount, Field.Store.NO));
+                doc.Add(new Int32Field("id", docCount, Field.Store.NO));
                 IList<Token> tokens = new List<Token>();
                 int numTokens = AtLeast(100);
                 //final int numTokens = AtLeast(20);
@@ -331,7 +331,7 @@ namespace Lucene.Net.Index
                 DocsEnum docs = null;
                 DocsAndPositionsEnum docsAndPositions = null;
                 DocsAndPositionsEnum docsAndPositionsAndOffsets = null;
-                FieldCache.Ints docIDToID = FieldCache.DEFAULT.GetInt32s(sub, "id", false);
+                FieldCache.Int32s docIDToID = FieldCache.DEFAULT.GetInt32s(sub, "id", false);
                 foreach (string term in terms)
                 {
                     //System.out.println("  term=" + term);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Tests/core/Index/TestStressNRT.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Index/TestStressNRT.cs b/src/Lucene.Net.Tests/core/Index/TestStressNRT.cs
index e3d4d7b..b9d52cb 100644
--- a/src/Lucene.Net.Tests/core/Index/TestStressNRT.cs
+++ b/src/Lucene.Net.Tests/core/Index/TestStressNRT.cs
@@ -84,7 +84,7 @@ namespace Lucene.Net.Index
             bool tombstones = Random().NextBoolean();
 
             // query variables
-            AtomicLong operations = new AtomicLong(AtLeast(10000)); // number of query operations to perform in total
+            AtomicInt64 operations = new AtomicInt64(AtLeast(10000)); // number of query operations to perform in total
 
             int nReadThreads = TestUtil.NextInt(Random(), 1, TEST_NIGHTLY ? 10 : 5);
             InitModel(ndocs);
@@ -108,7 +108,7 @@ namespace Lucene.Net.Index
                 Console.WriteLine("\n");
             }
 
-            AtomicInteger numCommitting = new AtomicInteger();
+            AtomicInt32 numCommitting = new AtomicInt32();
 
             IList<ThreadClass> threads = new List<ThreadClass>();
 
@@ -163,12 +163,12 @@ namespace Lucene.Net.Index
             private int Ndocs;
             private int MaxConcurrentCommits;
             private bool Tombstones;
-            private AtomicLong Operations;
+            private AtomicInt64 Operations;
             private FieldType StoredOnlyType;
-            private AtomicInteger NumCommitting;
+            private AtomicInt32 NumCommitting;
             private RandomIndexWriter Writer;
 
-            public ThreadAnonymousInnerClassHelper(TestStressNRT outerInstance, string str, int commitPercent, int softCommitPercent, int deletePercent, int deleteByQueryPercent, int ndocs, int maxConcurrentCommits, bool tombstones, AtomicLong operations, FieldType storedOnlyType, AtomicInteger numCommitting, RandomIndexWriter writer)
+            public ThreadAnonymousInnerClassHelper(TestStressNRT outerInstance, string str, int commitPercent, int softCommitPercent, int deletePercent, int deleteByQueryPercent, int ndocs, int maxConcurrentCommits, bool tombstones, AtomicInt64 operations, FieldType storedOnlyType, AtomicInt32 numCommitting, RandomIndexWriter writer)
                 : base(str)
             {
                 this.OuterInstance = outerInstance;
@@ -411,9 +411,9 @@ namespace Lucene.Net.Index
 
             private int Ndocs;
             private bool Tombstones;
-            private AtomicLong Operations;
+            private AtomicInt64 Operations;
 
-            public ThreadAnonymousInnerClassHelper2(TestStressNRT outerInstance, string str, int ndocs, bool tombstones, AtomicLong operations)
+            public ThreadAnonymousInnerClassHelper2(TestStressNRT outerInstance, string str, int ndocs, bool tombstones, AtomicInt64 operations)
                 : base(str)
             {
                 this.OuterInstance = outerInstance;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Tests/core/Index/TestTermsEnum.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Index/TestTermsEnum.cs b/src/Lucene.Net.Tests/core/Index/TestTermsEnum.cs
index edb37d0..54f2747 100644
--- a/src/Lucene.Net.Tests/core/Index/TestTermsEnum.cs
+++ b/src/Lucene.Net.Tests/core/Index/TestTermsEnum.cs
@@ -17,7 +17,7 @@ namespace Lucene.Net.Index
     using DocIdSetIterator = Lucene.Net.Search.DocIdSetIterator;
     using Document = Documents.Document;
     using Field = Field;
-    using IntField = IntField;
+    using Int32Field = Int32Field;
     using LineFileDocs = Lucene.Net.Util.LineFileDocs;
     using LuceneTestCase = Lucene.Net.Util.LuceneTestCase;
 
@@ -201,7 +201,7 @@ namespace Lucene.Net.Index
         private void AddDoc(RandomIndexWriter w, ICollection<string> terms, IDictionary<BytesRef, int?> termToID, int id)
         {
             Document doc = new Document();
-            doc.Add(new IntField("id", id, Field.Store.NO));
+            doc.Add(new Int32Field("id", id, Field.Store.NO));
             if (VERBOSE)
             {
                 Console.WriteLine("TEST: addDoc id:" + id + " terms=" + terms);
@@ -285,7 +285,7 @@ namespace Lucene.Net.Index
             w.Dispose();
 
             // NOTE: intentional insanity!!
-            FieldCache.Ints docIDToID = FieldCache.DEFAULT.GetInt32s(SlowCompositeReaderWrapper.Wrap(r), "id", false);
+            FieldCache.Int32s docIDToID = FieldCache.DEFAULT.GetInt32s(SlowCompositeReaderWrapper.Wrap(r), "id", false);
 
             for (int iter = 0; iter < 10 * RANDOM_MULTIPLIER; iter++)
             {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Tests/core/Search/JustCompileSearch.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Search/JustCompileSearch.cs b/src/Lucene.Net.Tests/core/Search/JustCompileSearch.cs
index d157b3e..272d338 100644
--- a/src/Lucene.Net.Tests/core/Search/JustCompileSearch.cs
+++ b/src/Lucene.Net.Tests/core/Search/JustCompileSearch.cs
@@ -94,7 +94,7 @@ namespace Lucene.Net.Search
             }
         }
 
-        internal sealed class JustCompileExtendedFieldCacheLongParser : FieldCache.ILongParser
+        internal sealed class JustCompileExtendedFieldCacheLongParser : FieldCache.IInt64Parser
         {
             /// <summary>
             /// NOTE: This was parseLong() in Lucene

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Tests/core/Search/TestBooleanOr.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Search/TestBooleanOr.cs b/src/Lucene.Net.Tests/core/Search/TestBooleanOr.cs
index c57666b..ba4f218 100644
--- a/src/Lucene.Net.Tests/core/Search/TestBooleanOr.cs
+++ b/src/Lucene.Net.Tests/core/Search/TestBooleanOr.cs
@@ -199,7 +199,7 @@ namespace Lucene.Net.Search
             BulkScorer scorer = w.GetBulkScorer(s.IndexReader.Leaves[0], false, null);
 
             FixedBitSet hits = new FixedBitSet(docCount);
-            AtomicInteger end = new AtomicInteger();
+            AtomicInt32 end = new AtomicInt32();
             ICollector c = new CollectorAnonymousInnerClassHelper(this, scorer, hits, end);
 
             while (end.Get() < docCount)
@@ -220,9 +220,9 @@ namespace Lucene.Net.Search
 
             private BulkScorer scorer;
             private FixedBitSet Hits;
-            private AtomicInteger End;
+            private AtomicInt32 End;
 
-            public CollectorAnonymousInnerClassHelper(TestBooleanOr outerInstance, BulkScorer scorer, FixedBitSet hits, AtomicInteger end)
+            public CollectorAnonymousInnerClassHelper(TestBooleanOr outerInstance, BulkScorer scorer, FixedBitSet hits, AtomicInt32 end)
             {
                 this.OuterInstance = outerInstance;
                 this.scorer = scorer;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Tests/core/Search/TestDocValuesScoring.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Search/TestDocValuesScoring.cs b/src/Lucene.Net.Tests/core/Search/TestDocValuesScoring.cs
index ab4dfcb..ebd3e72 100644
--- a/src/Lucene.Net.Tests/core/Search/TestDocValuesScoring.cs
+++ b/src/Lucene.Net.Tests/core/Search/TestDocValuesScoring.cs
@@ -28,7 +28,7 @@ namespace Lucene.Net.Search
     using Document = Documents.Document;
     using Field = Field;
     using FieldInvertState = Lucene.Net.Index.FieldInvertState;
-    using FloatDocValuesField = FloatDocValuesField;
+    using SingleDocValuesField = SingleDocValuesField;
     using IndexReader = Lucene.Net.Index.IndexReader;
     using LuceneTestCase = Lucene.Net.Util.LuceneTestCase;
     using PerFieldSimilarityWrapper = Lucene.Net.Search.Similarities.PerFieldSimilarityWrapper;
@@ -56,7 +56,7 @@ namespace Lucene.Net.Search
             Document doc = new Document();
             Field field = NewTextField("foo", "", Field.Store.NO);
             doc.Add(field);
-            Field dvField = new FloatDocValuesField("foo_boost", 0.0F);
+            Field dvField = new SingleDocValuesField("foo_boost", 0.0F);
             doc.Add(dvField);
             Field field2 = NewTextField("bar", "", Field.Store.NO);
             doc.Add(field2);
@@ -184,7 +184,7 @@ namespace Lucene.Net.Search
             public override SimScorer GetSimScorer(SimWeight stats, AtomicReaderContext context)
             {
                 SimScorer sub = Sim.GetSimScorer(stats, context);
-                FieldCache.Floats values = FieldCache.DEFAULT.GetSingles(context.AtomicReader, BoostField, false);
+                FieldCache.Singles values = FieldCache.DEFAULT.GetSingles(context.AtomicReader, BoostField, false);
 
                 return new SimScorerAnonymousInnerClassHelper(this, sub, values);
             }
@@ -194,9 +194,9 @@ namespace Lucene.Net.Search
                 private readonly BoostingSimilarity OuterInstance;
 
                 private SimScorer Sub;
-                private FieldCache.Floats Values;
+                private FieldCache.Singles Values;
 
-                public SimScorerAnonymousInnerClassHelper(BoostingSimilarity outerInstance, SimScorer sub, FieldCache.Floats values)
+                public SimScorerAnonymousInnerClassHelper(BoostingSimilarity outerInstance, SimScorer sub, FieldCache.Singles values)
                 {
                     this.OuterInstance = outerInstance;
                     this.Sub = sub;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Tests/core/Search/TestFieldCache.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Search/TestFieldCache.cs b/src/Lucene.Net.Tests/core/Search/TestFieldCache.cs
index a161aff..918a693 100644
--- a/src/Lucene.Net.Tests/core/Search/TestFieldCache.cs
+++ b/src/Lucene.Net.Tests/core/Search/TestFieldCache.cs
@@ -33,8 +33,8 @@ namespace Lucene.Net.Search
     using Document = Lucene.Net.Documents.Document;
     using Field = Lucene.Net.Documents.Field;
     using Store = Lucene.Net.Documents.Field.Store;
-    using IntField = Lucene.Net.Documents.IntField;
-    using LongField = Lucene.Net.Documents.LongField;
+    using Int32Field = Lucene.Net.Documents.Int32Field;
+    using Int64Field = Lucene.Net.Documents.Int64Field;
     using NumericDocValuesField = Lucene.Net.Documents.NumericDocValuesField;
     using SortedDocValuesField = Lucene.Net.Documents.SortedDocValuesField;
     using SortedSetDocValuesField = Lucene.Net.Documents.SortedSetDocValuesField;
@@ -53,10 +53,10 @@ namespace Lucene.Net.Search
     using TermsEnum = Lucene.Net.Index.TermsEnum;
     using Bytes = Lucene.Net.Search.FieldCache.Bytes;
     using Doubles = Lucene.Net.Search.FieldCache.Doubles;
-    using Floats = Lucene.Net.Search.FieldCache.Floats;
-    using Ints = Lucene.Net.Search.FieldCache.Ints;
-    using Longs = Lucene.Net.Search.FieldCache.Longs;
-    using Shorts = Lucene.Net.Search.FieldCache.Shorts;
+    using Singles = Lucene.Net.Search.FieldCache.Singles;
+    using Int32s = Lucene.Net.Search.FieldCache.Int32s;
+    using Int64s = Lucene.Net.Search.FieldCache.Int64s;
+    using Int16s = Lucene.Net.Search.FieldCache.Int16s;
     using Directory = Lucene.Net.Store.Directory;
     using IBits = Lucene.Net.Util.IBits;
     using BytesRef = Lucene.Net.Util.BytesRef;
@@ -137,7 +137,7 @@ namespace Lucene.Net.Search
 
                 if (i % 2 == 0)
                 {
-                    doc.Add(new IntField("numInt", i, Field.Store.NO));
+                    doc.Add(new Int32Field("numInt", i, Field.Store.NO));
                 }
 
                 // sometimes skip the field:
@@ -209,7 +209,7 @@ namespace Lucene.Net.Search
                 Assert.IsTrue(doubles.Get(i) == (double.MaxValue - i), doubles.Get(i) + " does not equal: " + (double.MaxValue - i));
             }
 
-            FieldCache.Longs longs = cache.GetInt64s(Reader, "theLong", Random().NextBoolean());
+            FieldCache.Int64s longs = cache.GetInt64s(Reader, "theLong", Random().NextBoolean());
             Assert.AreSame(longs, cache.GetInt64s(Reader, "theLong", Random().NextBoolean()), "Second request to cache return same array");
             Assert.AreSame(longs, cache.GetInt64s(Reader, "theLong", FieldCache.DEFAULT_LONG_PARSER, Random().NextBoolean()), "Second request with explicit parser return same array");
             for (int i = 0; i < NUM_DOCS; i++)
@@ -226,7 +226,7 @@ namespace Lucene.Net.Search
                 Assert.IsTrue(bytes.Get(i) == (sbyte)(sbyte.MaxValue - i), bytes.Get(i) + " does not equal: " + (sbyte.MaxValue - i));
             }
 
-            FieldCache.Shorts shorts = cache.GetInt16s(Reader, "theShort", Random().NextBoolean());
+            FieldCache.Int16s shorts = cache.GetInt16s(Reader, "theShort", Random().NextBoolean());
             Assert.AreSame(shorts, cache.GetInt16s(Reader, "theShort", Random().NextBoolean()), "Second request to cache return same array");
             Assert.AreSame(shorts, cache.GetInt16s(Reader, "theShort", FieldCache.DEFAULT_SHORT_PARSER, Random().NextBoolean()), "Second request with explicit parser return same array");
             for (int i = 0; i < NUM_DOCS; i++)
@@ -235,7 +235,7 @@ namespace Lucene.Net.Search
             }
 #pragma warning restore 612, 618
 
-            FieldCache.Ints ints = cache.GetInt32s(Reader, "theInt", Random().NextBoolean());
+            FieldCache.Int32s ints = cache.GetInt32s(Reader, "theInt", Random().NextBoolean());
             Assert.AreSame(ints, cache.GetInt32s(Reader, "theInt", Random().NextBoolean()), "Second request to cache return same array");
             Assert.AreSame(ints, cache.GetInt32s(Reader, "theInt", FieldCache.DEFAULT_INT_PARSER, Random().NextBoolean()), "Second request with explicit parser return same array");
             for (int i = 0; i < NUM_DOCS; i++)
@@ -243,7 +243,7 @@ namespace Lucene.Net.Search
                 Assert.IsTrue(ints.Get(i) == (int.MaxValue - i), ints.Get(i) + " does not equal: " + (int.MaxValue - i));
             }
 
-            FieldCache.Floats floats = cache.GetSingles(Reader, "theFloat", Random().NextBoolean());
+            FieldCache.Singles floats = cache.GetSingles(Reader, "theFloat", Random().NextBoolean());
             Assert.AreSame(floats, cache.GetSingles(Reader, "theFloat", Random().NextBoolean()), "Second request to cache return same array");
             Assert.AreSame(floats, cache.GetSingles(Reader, "theFloat", FieldCache.DEFAULT_FLOAT_PARSER, Random().NextBoolean()), "Second request with explicit parser return same array");
             for (int i = 0; i < NUM_DOCS; i++)
@@ -435,7 +435,7 @@ namespace Lucene.Net.Search
             Assert.AreEqual(3, cache.GetCacheEntries().Length);
             Assert.IsTrue(bits is Bits.MatchAllBits);
 
-            Ints ints = cache.GetInt32s(Reader, "sparse", true);
+            Int32s ints = cache.GetInt32s(Reader, "sparse", true);
             Assert.AreEqual(6, cache.GetCacheEntries().Length);
             IBits docsWithField = cache.GetDocsWithField(Reader, "sparse");
             Assert.AreEqual(6, cache.GetCacheEntries().Length);
@@ -452,7 +452,7 @@ namespace Lucene.Net.Search
                 }
             }
 
-            Ints numInts = cache.GetInt32s(Reader, "numInt", Random().NextBoolean());
+            Int32s numInts = cache.GetInt32s(Reader, "numInt", Random().NextBoolean());
             docsWithField = cache.GetDocsWithField(Reader, "numInt");
             for (int i = 0; i < docsWithField.Length; i++)
             {
@@ -477,7 +477,7 @@ namespace Lucene.Net.Search
             int NUM_THREADS = 3;
             ThreadClass[] threads = new ThreadClass[NUM_THREADS];
             AtomicBoolean failed = new AtomicBoolean();
-            AtomicInteger iters = new AtomicInteger();
+            AtomicInt32 iters = new AtomicInt32();
             int NUM_ITER = 200 * RANDOM_MULTIPLIER;
             Barrier restart = new Barrier(NUM_THREADS, (barrier) => new RunnableAnonymousInnerClassHelper(this, cache, iters).Run());
             for (int threadIDX = 0; threadIDX < NUM_THREADS; threadIDX++)
@@ -498,9 +498,9 @@ namespace Lucene.Net.Search
             private readonly TestFieldCache OuterInstance;
 
             private IFieldCache Cache;
-            private AtomicInteger Iters;
+            private AtomicInt32 Iters;
 
-            public RunnableAnonymousInnerClassHelper(TestFieldCache outerInstance, IFieldCache cache, AtomicInteger iters)
+            public RunnableAnonymousInnerClassHelper(TestFieldCache outerInstance, IFieldCache cache, AtomicInt32 iters)
             {
                 this.OuterInstance = outerInstance;
                 this.Cache = cache;
@@ -520,11 +520,11 @@ namespace Lucene.Net.Search
 
             private IFieldCache Cache;
             private AtomicBoolean Failed;
-            private AtomicInteger Iters;
+            private AtomicInt32 Iters;
             private int NUM_ITER;
             private Barrier Restart;
 
-            public ThreadAnonymousInnerClassHelper(TestFieldCache outerInstance, IFieldCache cache, AtomicBoolean failed, AtomicInteger iters, int NUM_ITER, Barrier restart)
+            public ThreadAnonymousInnerClassHelper(TestFieldCache outerInstance, IFieldCache cache, AtomicBoolean failed, AtomicInt32 iters, int NUM_ITER, Barrier restart)
             {
                 this.OuterInstance = outerInstance;
                 this.Cache = cache;
@@ -562,7 +562,7 @@ namespace Lucene.Net.Search
                         }
                         else
                         {
-                            Ints ints = Cache.GetInt32s(Reader, "sparse", true);
+                            Int32s ints = Cache.GetInt32s(Reader, "sparse", true);
                             IBits docsWithField = Cache.GetDocsWithField(Reader, "sparse");
                             for (int i = 0; i < docsWithField.Length; i++)
                             {
@@ -705,7 +705,7 @@ namespace Lucene.Net.Search
             Assert.IsTrue(bits.Get(0));
 
             // Numeric type: can be retrieved via getInts() and so on
-            Ints numeric = FieldCache.DEFAULT.GetInt32s(ar, "numeric", false);
+            Int32s numeric = FieldCache.DEFAULT.GetInt32s(ar, "numeric", false);
             Assert.AreEqual(42, numeric.Get(0));
 
             try
@@ -837,17 +837,17 @@ namespace Lucene.Net.Search
             Bytes bytes = cache.GetBytes(ar, "bogusbytes", true);
             Assert.AreEqual(0, bytes.Get(0));
 
-            Shorts shorts = cache.GetInt16s(ar, "bogusshorts", true);
+            Int16s shorts = cache.GetInt16s(ar, "bogusshorts", true);
             Assert.AreEqual(0, shorts.Get(0));
 #pragma warning restore 612, 618
 
-            Ints ints = cache.GetInt32s(ar, "bogusints", true);
+            Int32s ints = cache.GetInt32s(ar, "bogusints", true);
             Assert.AreEqual(0, ints.Get(0));
 
-            Longs longs = cache.GetInt64s(ar, "boguslongs", true);
+            Int64s longs = cache.GetInt64s(ar, "boguslongs", true);
             Assert.AreEqual(0, longs.Get(0));
 
-            Floats floats = cache.GetSingles(ar, "bogusfloats", true);
+            Singles floats = cache.GetSingles(ar, "bogusfloats", true);
             Assert.AreEqual(0, floats.Get(0), 0.0f);
 
             Doubles doubles = cache.GetDoubles(ar, "bogusdoubles", true);
@@ -906,17 +906,17 @@ namespace Lucene.Net.Search
             Bytes bytes = cache.GetBytes(ar, "bogusbytes", true);
             Assert.AreEqual(0, bytes.Get(0));
 
-            Shorts shorts = cache.GetInt16s(ar, "bogusshorts", true);
+            Int16s shorts = cache.GetInt16s(ar, "bogusshorts", true);
             Assert.AreEqual(0, shorts.Get(0));
 #pragma warning restore 612, 618
 
-            Ints ints = cache.GetInt32s(ar, "bogusints", true);
+            Int32s ints = cache.GetInt32s(ar, "bogusints", true);
             Assert.AreEqual(0, ints.Get(0));
 
-            Longs longs = cache.GetInt64s(ar, "boguslongs", true);
+            Int64s longs = cache.GetInt64s(ar, "boguslongs", true);
             Assert.AreEqual(0, longs.Get(0));
 
-            Floats floats = cache.GetSingles(ar, "bogusfloats", true);
+            Singles floats = cache.GetSingles(ar, "bogusfloats", true);
             Assert.AreEqual(0, floats.Get(0), 0.0f);
 
             Doubles doubles = cache.GetDoubles(ar, "bogusdoubles", true);
@@ -954,7 +954,7 @@ namespace Lucene.Net.Search
             cfg.SetMergePolicy(NewLogMergePolicy());
             RandomIndexWriter iw = new RandomIndexWriter(Random(), dir, cfg);
             Document doc = new Document();
-            LongField field = new LongField("f", 0L, Field.Store.YES);
+            Int64Field field = new Int64Field("f", 0L, Field.Store.YES);
             doc.Add(field);
             long[] values = new long[TestUtil.NextInt(Random(), 1, 10)];
             for (int i = 0; i < values.Length; ++i)
@@ -989,7 +989,7 @@ namespace Lucene.Net.Search
             }
             iw.ForceMerge(1);
             DirectoryReader reader = iw.Reader;
-            Longs longs = FieldCache.DEFAULT.GetInt64s(GetOnlySegmentReader(reader), "f", false);
+            Int64s longs = FieldCache.DEFAULT.GetInt64s(GetOnlySegmentReader(reader), "f", false);
             for (int i = 0; i < values.Length; ++i)
             {
                 Assert.AreEqual(values[i], longs.Get(i));
@@ -1008,7 +1008,7 @@ namespace Lucene.Net.Search
             cfg.SetMergePolicy(NewLogMergePolicy());
             RandomIndexWriter iw = new RandomIndexWriter(Random(), dir, cfg);
             Document doc = new Document();
-            IntField field = new IntField("f", 0, Field.Store.YES);
+            Int32Field field = new Int32Field("f", 0, Field.Store.YES);
             doc.Add(field);
             int[] values = new int[TestUtil.NextInt(Random(), 1, 10)];
             for (int i = 0; i < values.Length; ++i)
@@ -1043,7 +1043,7 @@ namespace Lucene.Net.Search
             }
             iw.ForceMerge(1);
             DirectoryReader reader = iw.Reader;
-            Ints ints = FieldCache.DEFAULT.GetInt32s(GetOnlySegmentReader(reader), "f", false);
+            Int32s ints = FieldCache.DEFAULT.GetInt32s(GetOnlySegmentReader(reader), "f", false);
             for (int i = 0; i < values.Length; ++i)
             {
                 Assert.AreEqual(values[i], ints.Get(i));

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Tests/core/Search/TestLiveFieldValues.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Search/TestLiveFieldValues.cs b/src/Lucene.Net.Tests/core/Search/TestLiveFieldValues.cs
index 5f2a627..9cd902c 100644
--- a/src/Lucene.Net.Tests/core/Search/TestLiveFieldValues.cs
+++ b/src/Lucene.Net.Tests/core/Search/TestLiveFieldValues.cs
@@ -15,7 +15,7 @@ namespace Lucene.Net.Search
     using IndexReader = Lucene.Net.Index.IndexReader;
     using IndexWriter = Lucene.Net.Index.IndexWriter;
     using IndexWriterConfig = Lucene.Net.Index.IndexWriterConfig;
-    using IntField = IntField;
+    using Int32Field = Int32Field;
     using LuceneTestCase = Lucene.Net.Util.LuceneTestCase;
 
     /*
@@ -181,7 +181,7 @@ namespace Lucene.Net.Search
                             string id = string.Format(CultureInfo.InvariantCulture, "{0}_{1:X4}", ThreadID, ThreadRandom.Next(IdCount));
                             int field = ThreadRandom.Next(int.MaxValue);
                             doc.Add(new StringField("id", id, Field.Store.YES));
-                            doc.Add(new IntField("field", (int)field, Field.Store.YES));
+                            doc.Add(new Int32Field("field", (int)field, Field.Store.YES));
                             w.UpdateDocument(new Term("id", id), doc);
                             Rt.Add(id, field);
                             if (!values.ContainsKey(id))//Key didn't exist before

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Tests/core/Search/TestMultiValuedNumericRangeQuery.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Search/TestMultiValuedNumericRangeQuery.cs b/src/Lucene.Net.Tests/core/Search/TestMultiValuedNumericRangeQuery.cs
index 8c5b83a..5c66182 100644
--- a/src/Lucene.Net.Tests/core/Search/TestMultiValuedNumericRangeQuery.cs
+++ b/src/Lucene.Net.Tests/core/Search/TestMultiValuedNumericRangeQuery.cs
@@ -8,7 +8,7 @@ namespace Lucene.Net.Search
     using Document = Documents.Document;
     using Field = Field;
     using IndexReader = Lucene.Net.Index.IndexReader;
-    using IntField = IntField;
+    using Int32Field = Int32Field;
     using LuceneTestCase = Lucene.Net.Util.LuceneTestCase;
 
     /*
@@ -56,7 +56,7 @@ namespace Lucene.Net.Search
                 {
                     int value = Random().Next(int.MaxValue);
                     doc.Add(NewStringField("asc", value.ToString(format), Field.Store.NO));
-                    doc.Add(new IntField("trie", value, Field.Store.NO));
+                    doc.Add(new Int32Field("trie", value, Field.Store.NO));
                 }
                 writer.AddDocument(doc);
             }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Tests/core/Search/TestNumericRangeQuery32.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Search/TestNumericRangeQuery32.cs b/src/Lucene.Net.Tests/core/Search/TestNumericRangeQuery32.cs
index cc0da97..5236870 100644
--- a/src/Lucene.Net.Tests/core/Search/TestNumericRangeQuery32.cs
+++ b/src/Lucene.Net.Tests/core/Search/TestNumericRangeQuery32.cs
@@ -13,9 +13,9 @@ namespace Lucene.Net.Search
     using Document = Documents.Document;
     using Field = Field;
     using FieldType = FieldType;
-    using FloatField = FloatField;
+    using SingleField = SingleField;
     using IndexReader = Lucene.Net.Index.IndexReader;
-    using IntField = IntField;
+    using Int32Field = Int32Field;
     using LuceneTestCase = Lucene.Net.Util.LuceneTestCase;
 
     /*
@@ -73,7 +73,7 @@ namespace Lucene.Net.Search
             Directory = NewDirectory();
             RandomIndexWriter writer = new RandomIndexWriter(Random(), Directory, NewIndexWriterConfig(TEST_VERSION_CURRENT, new MockAnalyzer(Random())).SetMaxBufferedDocs(TestUtil.NextInt(Random(), 100, 1000)).SetMergePolicy(NewLogMergePolicy()));
 
-            FieldType storedInt = new FieldType(IntField.TYPE_NOT_STORED);
+            FieldType storedInt = new FieldType(Int32Field.TYPE_NOT_STORED);
             storedInt.IsStored = true;
             storedInt.Freeze();
 
@@ -89,7 +89,7 @@ namespace Lucene.Net.Search
             FieldType storedIntNone = new FieldType(storedInt);
             storedIntNone.NumericPrecisionStep = int.MaxValue;
 
-            FieldType unstoredInt = IntField.TYPE_NOT_STORED;
+            FieldType unstoredInt = Int32Field.TYPE_NOT_STORED;
 
             FieldType unstoredInt8 = new FieldType(unstoredInt);
             unstoredInt8.NumericPrecisionStep = 8;
@@ -100,7 +100,7 @@ namespace Lucene.Net.Search
             FieldType unstoredInt2 = new FieldType(unstoredInt);
             unstoredInt2.NumericPrecisionStep = 2;
 
-            IntField field8 = new IntField("field8", 0, storedInt8), field4 = new IntField("field4", 0, storedInt4), field2 = new IntField("field2", 0, storedInt2), fieldNoTrie = new IntField("field" + int.MaxValue, 0, storedIntNone), ascfield8 = new IntField("ascfield8", 0, unstoredInt8), ascfield4 = new IntField("ascfield4", 0, unstoredInt4), ascfield2 = new IntField("ascfield2", 0, unstoredInt2);
+            Int32Field field8 = new Int32Field("field8", 0, storedInt8), field4 = new Int32Field("field4", 0, storedInt4), field2 = new Int32Field("field2", 0, storedInt2), fieldNoTrie = new Int32Field("field" + int.MaxValue, 0, storedIntNone), ascfield8 = new Int32Field("ascfield8", 0, unstoredInt8), ascfield4 = new Int32Field("ascfield4", 0, unstoredInt4), ascfield2 = new Int32Field("ascfield2", 0, unstoredInt2);
 
             Document doc = new Document();
             // add fields, that have a distance to test general functionality
@@ -332,24 +332,24 @@ namespace Lucene.Net.Search
             Directory dir = NewDirectory();
             RandomIndexWriter writer = new RandomIndexWriter(Random(), dir, NewIndexWriterConfig(TEST_VERSION_CURRENT, new MockAnalyzer(Random())));
             Document doc = new Document();
-            doc.Add(new FloatField("float", float.NegativeInfinity, Field.Store.NO));
-            doc.Add(new IntField("int", int.MinValue, Field.Store.NO));
+            doc.Add(new SingleField("float", float.NegativeInfinity, Field.Store.NO));
+            doc.Add(new Int32Field("int", int.MinValue, Field.Store.NO));
             writer.AddDocument(doc);
 
             doc = new Document();
-            doc.Add(new FloatField("float", float.PositiveInfinity, Field.Store.NO));
-            doc.Add(new IntField("int", int.MaxValue, Field.Store.NO));
+            doc.Add(new SingleField("float", float.PositiveInfinity, Field.Store.NO));
+            doc.Add(new Int32Field("int", int.MaxValue, Field.Store.NO));
             writer.AddDocument(doc);
 
             doc = new Document();
-            doc.Add(new FloatField("float", 0.0f, Field.Store.NO));
-            doc.Add(new IntField("int", 0, Field.Store.NO));
+            doc.Add(new SingleField("float", 0.0f, Field.Store.NO));
+            doc.Add(new Int32Field("int", 0, Field.Store.NO));
             writer.AddDocument(doc);
 
             foreach (float f in TestNumericUtils.FLOAT_NANs)
             {
                 doc = new Document();
-                doc.Add(new FloatField("float", f, Field.Store.NO));
+                doc.Add(new SingleField("float", f, Field.Store.NO));
                 writer.AddDocument(doc);
             }
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Tests/core/Search/TestNumericRangeQuery64.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Search/TestNumericRangeQuery64.cs b/src/Lucene.Net.Tests/core/Search/TestNumericRangeQuery64.cs
index a1525f7..97da973 100644
--- a/src/Lucene.Net.Tests/core/Search/TestNumericRangeQuery64.cs
+++ b/src/Lucene.Net.Tests/core/Search/TestNumericRangeQuery64.cs
@@ -15,7 +15,7 @@ namespace Lucene.Net.Search
     using Field = Field;
     using FieldType = FieldType;
     using IndexReader = Lucene.Net.Index.IndexReader;
-    using LongField = LongField;
+    using Int64Field = Int64Field;
     using LuceneTestCase = Lucene.Net.Util.LuceneTestCase;
 
     /*
@@ -73,7 +73,7 @@ namespace Lucene.Net.Search
             Directory = NewDirectory();
             RandomIndexWriter writer = new RandomIndexWriter(Random(), Directory, NewIndexWriterConfig(TEST_VERSION_CURRENT, new MockAnalyzer(Random())).SetMaxBufferedDocs(TestUtil.NextInt(Random(), 100, 1000)).SetMergePolicy(NewLogMergePolicy()));
 
-            FieldType storedLong = new FieldType(LongField.TYPE_NOT_STORED);
+            FieldType storedLong = new FieldType(Int64Field.TYPE_NOT_STORED);
             storedLong.IsStored = true;
             storedLong.Freeze();
 
@@ -92,7 +92,7 @@ namespace Lucene.Net.Search
             FieldType storedLongNone = new FieldType(storedLong);
             storedLongNone.NumericPrecisionStep = int.MaxValue;
 
-            FieldType unstoredLong = LongField.TYPE_NOT_STORED;
+            FieldType unstoredLong = Int64Field.TYPE_NOT_STORED;
 
             FieldType unstoredLong8 = new FieldType(unstoredLong);
             unstoredLong8.NumericPrecisionStep = 8;
@@ -106,7 +106,7 @@ namespace Lucene.Net.Search
             FieldType unstoredLong2 = new FieldType(unstoredLong);
             unstoredLong2.NumericPrecisionStep = 2;
 
-            LongField field8 = new LongField("field8", 0L, storedLong8), field6 = new LongField("field6", 0L, storedLong6), field4 = new LongField("field4", 0L, storedLong4), field2 = new LongField("field2", 0L, storedLong2), fieldNoTrie = new LongField("field" + int.MaxValue, 0L, storedLongNone), ascfield8 = new LongField("ascfield8", 0L, unstoredLong8), ascfield6 = new LongField("ascfield6", 0L, unstoredLong6), ascfield4 = new LongField("ascfield4", 0L, unstoredLong4), ascfield2 = new LongField("ascfield2", 0L, unstoredLong2);
+            Int64Field field8 = new Int64Field("field8", 0L, storedLong8), field6 = new Int64Field("field6", 0L, storedLong6), field4 = new Int64Field("field4", 0L, storedLong4), field2 = new Int64Field("field2", 0L, storedLong2), fieldNoTrie = new Int64Field("field" + int.MaxValue, 0L, storedLongNone), ascfield8 = new Int64Field("ascfield8", 0L, unstoredLong8), ascfield6 = new Int64Field("ascfield6", 0L, unstoredLong6), ascfield4 = new Int64Field("ascfield4", 0L, unstoredLong4), ascfield2 = new Int64Field("ascfield2", 0L, unstoredLong2);
 
             Document doc = new Document();
             // add fields, that have a distance to test general functionality
@@ -360,17 +360,17 @@ namespace Lucene.Net.Search
             RandomIndexWriter writer = new RandomIndexWriter(Random(), dir, NewIndexWriterConfig(TEST_VERSION_CURRENT, new MockAnalyzer(Random())));
             Document doc = new Document();
             doc.Add(new DoubleField("double", double.NegativeInfinity, Field.Store.NO));
-            doc.Add(new LongField("long", long.MinValue, Field.Store.NO));
+            doc.Add(new Int64Field("long", long.MinValue, Field.Store.NO));
             writer.AddDocument(doc);
 
             doc = new Document();
             doc.Add(new DoubleField("double", double.PositiveInfinity, Field.Store.NO));
-            doc.Add(new LongField("long", long.MaxValue, Field.Store.NO));
+            doc.Add(new Int64Field("long", long.MaxValue, Field.Store.NO));
             writer.AddDocument(doc);
 
             doc = new Document();
             doc.Add(new DoubleField("double", 0.0, Field.Store.NO));
-            doc.Add(new LongField("long", 0L, Field.Store.NO));
+            doc.Add(new Int64Field("long", 0L, Field.Store.NO));
             writer.AddDocument(doc);
 
             foreach (double d in TestNumericUtils.DOUBLE_NANs)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Tests/core/Search/TestSearchAfter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Search/TestSearchAfter.cs b/src/Lucene.Net.Tests/core/Search/TestSearchAfter.cs
index d460d91..c4635b1 100644
--- a/src/Lucene.Net.Tests/core/Search/TestSearchAfter.cs
+++ b/src/Lucene.Net.Tests/core/Search/TestSearchAfter.cs
@@ -35,11 +35,11 @@ namespace Lucene.Net.Search
     using DoubleField = DoubleField;
     using English = Lucene.Net.Util.English;
     using Field = Field;
-    using FloatDocValuesField = FloatDocValuesField;
-    using FloatField = FloatField;
+    using SingleDocValuesField = SingleDocValuesField;
+    using SingleField = SingleField;
     using IndexReader = Lucene.Net.Index.IndexReader;
-    using IntField = IntField;
-    using LongField = LongField;
+    using Int32Field = Int32Field;
+    using Int64Field = Int64Field;
     using LuceneTestCase = Lucene.Net.Util.LuceneTestCase;
     using NumericDocValuesField = NumericDocValuesField;
     using RandomIndexWriter = Lucene.Net.Index.RandomIndexWriter;
@@ -153,10 +153,10 @@ namespace Lucene.Net.Search
                 fields.Add(NewTextField("oddeven", (i % 2 == 0) ? "even" : "odd", Field.Store.NO));
                 fields.Add(NewStringField("byte", "" + ((sbyte)Random().Next()), Field.Store.NO));
                 fields.Add(NewStringField("short", "" + ((short)Random().Next()), Field.Store.NO));
-                fields.Add(new IntField("int", Random().Next(), Field.Store.NO));
-                fields.Add(new LongField("long", Random().NextLong(), Field.Store.NO));
+                fields.Add(new Int32Field("int", Random().Next(), Field.Store.NO));
+                fields.Add(new Int64Field("long", Random().NextLong(), Field.Store.NO));
 
-                fields.Add(new FloatField("float", (float)Random().NextDouble(), Field.Store.NO));
+                fields.Add(new SingleField("float", (float)Random().NextDouble(), Field.Store.NO));
                 fields.Add(new DoubleField("double", Random().NextDouble(), Field.Store.NO));
                 fields.Add(NewStringField("bytes", TestUtil.RandomRealisticUnicodeString(Random()), Field.Store.NO));
                 fields.Add(NewStringField("bytesval", TestUtil.RandomRealisticUnicodeString(Random()), Field.Store.NO));
@@ -165,7 +165,7 @@ namespace Lucene.Net.Search
                 if (SupportsDocValues)
                 {
                     fields.Add(new NumericDocValuesField("intdocvalues", Random().Next()));
-                    fields.Add(new FloatDocValuesField("floatdocvalues", (float)Random().NextDouble()));
+                    fields.Add(new SingleDocValuesField("floatdocvalues", (float)Random().NextDouble()));
                     fields.Add(new SortedDocValuesField("sortedbytesdocvalues", new BytesRef(TestUtil.RandomRealisticUnicodeString(Random()))));
                     fields.Add(new SortedDocValuesField("sortedbytesdocvaluesval", new BytesRef(TestUtil.RandomRealisticUnicodeString(Random()))));
                     fields.Add(new BinaryDocValuesField("straightbytesdocvalues", new BytesRef(TestUtil.RandomRealisticUnicodeString(Random()))));

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Tests/core/Search/TestSearchWithThreads.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Search/TestSearchWithThreads.cs b/src/Lucene.Net.Tests/core/Search/TestSearchWithThreads.cs
index ce1e5d9..1ce0552 100644
--- a/src/Lucene.Net.Tests/core/Search/TestSearchWithThreads.cs
+++ b/src/Lucene.Net.Tests/core/Search/TestSearchWithThreads.cs
@@ -87,7 +87,7 @@ namespace Lucene.Net.Search
             IndexSearcher s = NewSearcher(r);
 
             AtomicBoolean failed = new AtomicBoolean();
-            AtomicLong netSearch = new AtomicLong();
+            AtomicInt64 netSearch = new AtomicInt64();
 
             ThreadClass[] threads = new ThreadClass[NUM_SEARCH_THREADS];
             for (int threadID = 0; threadID < NUM_SEARCH_THREADS; threadID++)
@@ -121,9 +121,9 @@ namespace Lucene.Net.Search
 
             private IndexSearcher s;
             private AtomicBoolean Failed;
-            private AtomicLong NetSearch;
+            private AtomicInt64 NetSearch;
 
-            public ThreadAnonymousInnerClassHelper(TestSearchWithThreads outerInstance, IndexSearcher s, AtomicBoolean failed, AtomicLong netSearch)
+            public ThreadAnonymousInnerClassHelper(TestSearchWithThreads outerInstance, IndexSearcher s, AtomicBoolean failed, AtomicInt64 netSearch)
             {
                 this.OuterInstance = outerInstance;
                 this.s = s;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Tests/core/Search/TestSort.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Search/TestSort.cs b/src/Lucene.Net.Tests/core/Search/TestSort.cs
index 92253c2..9d09ed2 100644
--- a/src/Lucene.Net.Tests/core/Search/TestSort.cs
+++ b/src/Lucene.Net.Tests/core/Search/TestSort.cs
@@ -1547,7 +1547,7 @@ namespace Lucene.Net.Search
             dir.Dispose();
         }
 
-        private class IntParserAnonymousInnerClassHelper : FieldCache.IIntParser
+        private class IntParserAnonymousInnerClassHelper : FieldCache.IInt32Parser
         {
             private readonly TestSort OuterInstance;
 
@@ -1666,7 +1666,7 @@ namespace Lucene.Net.Search
             dir.Dispose();
         }
 
-        private class ShortParserAnonymousInnerClassHelper : FieldCache.IShortParser
+        private class ShortParserAnonymousInnerClassHelper : FieldCache.IInt16Parser
         {
             private readonly TestSort OuterInstance;
 
@@ -1727,7 +1727,7 @@ namespace Lucene.Net.Search
             dir.Dispose();
         }
 
-        private class LongParserAnonymousInnerClassHelper : FieldCache.ILongParser
+        private class LongParserAnonymousInnerClassHelper : FieldCache.IInt64Parser
         {
             private readonly TestSort OuterInstance;
 
@@ -1788,7 +1788,7 @@ namespace Lucene.Net.Search
             dir.Dispose();
         }
 
-        private class FloatParserAnonymousInnerClassHelper : FieldCache.IFloatParser
+        private class FloatParserAnonymousInnerClassHelper : FieldCache.ISingleParser
         {
             private readonly TestSort OuterInstance;
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Tests/core/Search/TestSortDocValues.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Search/TestSortDocValues.cs b/src/Lucene.Net.Tests/core/Search/TestSortDocValues.cs
index 04146e0..7f58afb 100644
--- a/src/Lucene.Net.Tests/core/Search/TestSortDocValues.cs
+++ b/src/Lucene.Net.Tests/core/Search/TestSortDocValues.cs
@@ -27,7 +27,7 @@ namespace Lucene.Net.Search
     using Document = Documents.Document;
     using DoubleDocValuesField = DoubleDocValuesField;
     using Field = Field;
-    using FloatDocValuesField = FloatDocValuesField;
+    using SingleDocValuesField = SingleDocValuesField;
     using IndexReader = Lucene.Net.Index.IndexReader;
     using LuceneTestCase = Lucene.Net.Util.LuceneTestCase;
     using NumericDocValuesField = NumericDocValuesField;
@@ -701,15 +701,15 @@ namespace Lucene.Net.Search
             Directory dir = NewDirectory();
             RandomIndexWriter writer = new RandomIndexWriter(Random(), dir, Similarity, TimeZone);
             Document doc = new Document();
-            doc.Add(new FloatDocValuesField("value", 30.1F));
+            doc.Add(new SingleDocValuesField("value", 30.1F));
             doc.Add(NewStringField("value", "30.1", Field.Store.YES));
             writer.AddDocument(doc);
             doc = new Document();
-            doc.Add(new FloatDocValuesField("value", -1.3F));
+            doc.Add(new SingleDocValuesField("value", -1.3F));
             doc.Add(NewStringField("value", "-1.3", Field.Store.YES));
             writer.AddDocument(doc);
             doc = new Document();
-            doc.Add(new FloatDocValuesField("value", 4.2F));
+            doc.Add(new SingleDocValuesField("value", 4.2F));
             doc.Add(NewStringField("value", "4.2", Field.Store.YES));
             writer.AddDocument(doc);
             IndexReader ir = writer.Reader;
@@ -738,15 +738,15 @@ namespace Lucene.Net.Search
             Directory dir = NewDirectory();
             RandomIndexWriter writer = new RandomIndexWriter(Random(), dir, Similarity, TimeZone);
             Document doc = new Document();
-            doc.Add(new FloatDocValuesField("value", 30.1F));
+            doc.Add(new SingleDocValuesField("value", 30.1F));
             doc.Add(NewStringField("value", "30.1", Field.Store.YES));
             writer.AddDocument(doc);
             doc = new Document();
-            doc.Add(new FloatDocValuesField("value", -1.3F));
+            doc.Add(new SingleDocValuesField("value", -1.3F));
             doc.Add(NewStringField("value", "-1.3", Field.Store.YES));
             writer.AddDocument(doc);
             doc = new Document();
-            doc.Add(new FloatDocValuesField("value", 4.2F));
+            doc.Add(new SingleDocValuesField("value", 4.2F));
             doc.Add(NewStringField("value", "4.2", Field.Store.YES));
             writer.AddDocument(doc);
             IndexReader ir = writer.Reader;
@@ -777,11 +777,11 @@ namespace Lucene.Net.Search
             Document doc = new Document();
             writer.AddDocument(doc);
             doc = new Document();
-            doc.Add(new FloatDocValuesField("value", -1.3F));
+            doc.Add(new SingleDocValuesField("value", -1.3F));
             doc.Add(NewStringField("value", "-1.3", Field.Store.YES));
             writer.AddDocument(doc);
             doc = new Document();
-            doc.Add(new FloatDocValuesField("value", 4.2F));
+            doc.Add(new SingleDocValuesField("value", 4.2F));
             doc.Add(NewStringField("value", "4.2", Field.Store.YES));
             writer.AddDocument(doc);
             IndexReader ir = writer.Reader;
@@ -811,11 +811,11 @@ namespace Lucene.Net.Search
             Document doc = new Document();
             writer.AddDocument(doc);
             doc = new Document();
-            doc.Add(new FloatDocValuesField("value", -1.3F));
+            doc.Add(new SingleDocValuesField("value", -1.3F));
             doc.Add(NewStringField("value", "-1.3", Field.Store.YES));
             writer.AddDocument(doc);
             doc = new Document();
-            doc.Add(new FloatDocValuesField("value", 4.2F));
+            doc.Add(new SingleDocValuesField("value", 4.2F));
             doc.Add(NewStringField("value", "4.2", Field.Store.YES));
             writer.AddDocument(doc);
             IndexReader ir = writer.Reader;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Tests/core/Search/TestSortRandom.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Search/TestSortRandom.cs b/src/Lucene.Net.Tests/core/Search/TestSortRandom.cs
index 5687659..03ad57a 100644
--- a/src/Lucene.Net.Tests/core/Search/TestSortRandom.cs
+++ b/src/Lucene.Net.Tests/core/Search/TestSortRandom.cs
@@ -345,7 +345,7 @@ namespace Lucene.Net.Search
             public override DocIdSet GetDocIdSet(AtomicReaderContext context, IBits acceptDocs)
             {
                 int maxDoc = context.Reader.MaxDoc;
-                FieldCache.Ints idSource = FieldCache.DEFAULT.GetInt32s(context.AtomicReader, "id", false);
+                FieldCache.Int32s idSource = FieldCache.DEFAULT.GetInt32s(context.AtomicReader, "id", false);
                 Assert.IsNotNull(idSource);
                 FixedBitSet bits = new FixedBitSet(maxDoc);
                 for (int docID = 0; docID < maxDoc; docID++)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Tests/core/Search/TestTopDocsMerge.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Search/TestTopDocsMerge.cs b/src/Lucene.Net.Tests/core/Search/TestTopDocsMerge.cs
index 8cc6507..b454cd2 100644
--- a/src/Lucene.Net.Tests/core/Search/TestTopDocsMerge.cs
+++ b/src/Lucene.Net.Tests/core/Search/TestTopDocsMerge.cs
@@ -31,10 +31,10 @@ namespace Lucene.Net.Search
 
     using Document = Documents.Document;
     using Field = Field;
-    using FloatField = FloatField;
+    using SingleField = SingleField;
     using IndexReader = Lucene.Net.Index.IndexReader;
     using IndexReaderContext = Lucene.Net.Index.IndexReaderContext;
-    using IntField = IntField;
+    using Int32Field = Int32Field;
     using LuceneTestCase = Lucene.Net.Util.LuceneTestCase;
     using RandomIndexWriter = Lucene.Net.Index.RandomIndexWriter;
     using ReaderUtil = Lucene.Net.Index.ReaderUtil;
@@ -122,7 +122,7 @@ namespace Lucene.Net.Search
                     Document doc = new Document();
                     doc.Add(NewStringField("string", TestUtil.RandomRealisticUnicodeString(Random()), Field.Store.NO));
                     doc.Add(NewTextField("text", content[Random().Next(content.Length)], Field.Store.NO));
-                    doc.Add(new FloatField("float", (float)Random().NextDouble(), Field.Store.NO));
+                    doc.Add(new SingleField("float", (float)Random().NextDouble(), Field.Store.NO));
                     int intValue;
                     if (Random().Next(100) == 17)
                     {
@@ -136,7 +136,7 @@ namespace Lucene.Net.Search
                     {
                         intValue = Random().Next();
                     }
-                    doc.Add(new IntField("int", intValue, Field.Store.NO));
+                    doc.Add(new Int32Field("int", intValue, Field.Store.NO));
                     if (VERBOSE)
                     {
                         Console.WriteLine("  doc=" + doc);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Tests/core/Support/TestByteBuffer.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Support/TestByteBuffer.cs b/src/Lucene.Net.Tests/core/Support/TestByteBuffer.cs
index b386f4d..0412025 100644
--- a/src/Lucene.Net.Tests/core/Support/TestByteBuffer.cs
+++ b/src/Lucene.Net.Tests/core/Support/TestByteBuffer.cs
@@ -181,7 +181,7 @@ namespace Lucene.Net.Support
             //checkBytes(b, new byte[] { 0, 0, 0, (byte)ic(0) });
             //checkInvalidMarkException(ib);
 
-            LongBuffer lb = b.AsInt64Buffer();
+            Int64Buffer lb = b.AsInt64Buffer();
             TestLongBuffer.test(level, lb, direct);
             checkBytes(b, new byte[] { 0, 0, 0, 0, 0, 0, 0, (byte)Ic(0) });
             checkInvalidMarkException(lb);


[28/53] [abbrv] lucenenet git commit: Lucene.Net.Core: Renamed all type-derived classes and interfaces from Short, Int, Long, and Float to match CLR types Int16, Int32, Int64, and Single, respectively.

Posted by ni...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Document/FloatField.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Document/FloatField.cs b/src/Lucene.Net.Core/Document/FloatField.cs
index 8d584bc..57aa6da 100644
--- a/src/Lucene.Net.Core/Document/FloatField.cs
+++ b/src/Lucene.Net.Core/Document/FloatField.cs
@@ -45,7 +45,7 @@ namespace Lucene.Net.Documents
     ///  }
     /// </pre>
     ///
-    /// See also <seealso cref="IntField"/>, <seealso cref="LongField"/>, {@link
+    /// See also <seealso cref="Int32Field"/>, <seealso cref="Int64Field"/>, {@link
     /// DoubleField}.</p>
     ///
     /// <p>To perform range querying or filtering against a
@@ -104,10 +104,12 @@ namespace Lucene.Net.Documents
     /// NumericTokenStream} directly, when indexing numbers. this
     /// class is a wrapper around this token stream type for
     /// easier, more intuitive usage.</p>
-    ///
+    /// <para>
+    /// NOTE: This was FloatField in Lucene
+    /// </para>
     /// @since 2.9
     /// </summary>
-    public sealed class FloatField : Field
+    public sealed class SingleField : Field
     {
         /// <summary>
         /// Type for a FloatField that is not stored:
@@ -115,7 +117,7 @@ namespace Lucene.Net.Documents
         /// </summary>
         public static readonly FieldType TYPE_NOT_STORED = new FieldType();
 
-        static FloatField()
+        static SingleField()
         {
             TYPE_NOT_STORED.IsIndexed = true;
             TYPE_NOT_STORED.IsTokenized = true;
@@ -147,7 +149,7 @@ namespace Lucene.Net.Documents
         ///  <param name="value"> 32-bit double value </param>
         ///  <param name="stored"> Store.YES if the content should also be stored </param>
         ///  <exception cref="IllegalArgumentException"> if the field name is null. </exception>
-        public FloatField(string name, float value, Store stored)
+        public SingleField(string name, float value, Store stored)
             : base(name, stored == Store.YES ? TYPE_STORED : TYPE_NOT_STORED)
         {
             m_fieldsData = Convert.ToSingle(value);
@@ -162,7 +164,7 @@ namespace Lucene.Net.Documents
         ///         of <seealso cref="NumericType#FLOAT"/>. </param>
         ///  <exception cref="IllegalArgumentException"> if the field name or type is null, or
         ///          if the field type does not have a FLOAT numericType() </exception>
-        public FloatField(string name, float value, FieldType type)
+        public SingleField(string name, float value, FieldType type)
             : base(name, type)
         {
             if (type.NumericType != NumericType.FLOAT)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Document/IntDocValuesField.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Document/IntDocValuesField.cs b/src/Lucene.Net.Core/Document/IntDocValuesField.cs
index afa39d1..9b1c57e 100644
--- a/src/Lucene.Net.Core/Document/IntDocValuesField.cs
+++ b/src/Lucene.Net.Core/Document/IntDocValuesField.cs
@@ -28,17 +28,20 @@ namespace Lucene.Net.Documents
     /// </pre>
     ///
     /// If you also need to store the value, you should add a
-    /// separate <seealso cref="StoredField"/> instance. </summary>
+    /// separate <seealso cref="StoredField"/> instance. 
+    /// <para/>
+    /// NOTE: This was IntDocValuesField in Lucene
+    /// </summary>
     /// <seealso cref="NumericDocValuesField"/>
     [Obsolete("Deprecated, use NumericDocValuesField instead")]
-    public class IntDocValuesField : NumericDocValuesField
+    public class Int32DocValuesField : NumericDocValuesField
     {
         /// <summary>
-        /// Creates a new DocValues field with the specified 32-bit integer value </summary>
+        /// Creates a new DocValues field with the specified 32-bit <see cref="int"/> value </summary>
         /// <param name="name"> field name </param>
-        /// <param name="value"> 32-bit integer value </param>
+        /// <param name="value"> 32-bit <see cref="int"/> value </param>
         /// <exception cref="ArgumentException"> if the field name is null </exception>
-        public IntDocValuesField(string name, int value)
+        public Int32DocValuesField(string name, int value)
             : base(name, value)
         {
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Document/IntField.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Document/IntField.cs b/src/Lucene.Net.Core/Document/IntField.cs
index 46ed541..b5f2f54 100644
--- a/src/Lucene.Net.Core/Document/IntField.cs
+++ b/src/Lucene.Net.Core/Document/IntField.cs
@@ -45,7 +45,7 @@ namespace Lucene.Net.Documents
     ///  }
     /// </pre>
     ///
-    /// See also <seealso cref="LongField"/>, <seealso cref="FloatField"/>, {@link
+    /// See also <seealso cref="Int64Field"/>, <seealso cref="SingleField"/>, {@link
     /// DoubleField}.</p>
     ///
     /// <p>To perform range querying or filtering against a
@@ -104,10 +104,12 @@ namespace Lucene.Net.Documents
     /// NumericTokenStream} directly, when indexing numbers. this
     /// class is a wrapper around this token stream type for
     /// easier, more intuitive usage.</p>
-    ///
+    /// <para>
+    /// NOTE: This was IntField in Lucene
+    /// </para>
     /// @since 2.9
     /// </summary>
-    public sealed class IntField : Field
+    public sealed class Int32Field : Field
     {
         /// <summary>
         /// Type for an IntField that is not stored:
@@ -115,7 +117,7 @@ namespace Lucene.Net.Documents
         /// </summary>
         public static readonly FieldType TYPE_NOT_STORED = new FieldType();
 
-        static IntField()
+        static Int32Field()
         {
             TYPE_NOT_STORED.IsIndexed = true;
             TYPE_NOT_STORED.IsTokenized = true;
@@ -147,7 +149,7 @@ namespace Lucene.Net.Documents
         ///  <param name="value"> 32-bit integer value </param>
         ///  <param name="stored"> Store.YES if the content should also be stored </param>
         ///  <exception cref="IllegalArgumentException"> if the field name is null. </exception>
-        public IntField(string name, int value, Store stored)
+        public Int32Field(string name, int value, Store stored)
             : base(name, stored == Store.YES ? TYPE_STORED : TYPE_NOT_STORED)
         {
             m_fieldsData = Convert.ToInt32(value);
@@ -162,7 +164,7 @@ namespace Lucene.Net.Documents
         ///         of <seealso cref="NumericType#INT"/>. </param>
         ///  <exception cref="IllegalArgumentException"> if the field name or type is null, or
         ///          if the field type does not have a INT numericType() </exception>
-        public IntField(string name, int value, FieldType type)
+        public Int32Field(string name, int value, FieldType type)
             : base(name, type)
         {
             if (type.NumericType != NumericType.INT)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Document/LongDocValuesField.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Document/LongDocValuesField.cs b/src/Lucene.Net.Core/Document/LongDocValuesField.cs
index fac0278..556d0af 100644
--- a/src/Lucene.Net.Core/Document/LongDocValuesField.cs
+++ b/src/Lucene.Net.Core/Document/LongDocValuesField.cs
@@ -31,17 +31,20 @@ namespace Lucene.Net.Documents
     /// <p>
     /// If you also need to store the value, you should add a
     /// separate <seealso cref="StoredField"/> instance.</p>
+    /// <para>
+    /// NOTE: This was LongDocValuesField in Lucene
+    /// </para>
     /// </summary>
     /// <seealso cref="NumericDocValues"/>
     [Obsolete("Use NumericDocValuesField instead")]
-    public class LongDocValuesField : NumericDocValuesField
+    public class Int64DocValuesField : NumericDocValuesField
     {
         /// <summary>
         /// Creates a new DocValues field with the specified 64-bit long value </summary>
         /// <param name="name"> field name </param>
         /// <param name="value"> 64-bit long value </param>
         /// <exception cref="ArgumentException"> if the field name is null </exception>
-        public LongDocValuesField(string name, long value)
+        public Int64DocValuesField(string name, long value)
             : base(name, value)
         {
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Document/LongField.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Document/LongField.cs b/src/Lucene.Net.Core/Document/LongField.cs
index 9289e89..8296269 100644
--- a/src/Lucene.Net.Core/Document/LongField.cs
+++ b/src/Lucene.Net.Core/Document/LongField.cs
@@ -45,7 +45,7 @@ namespace Lucene.Net.Documents
     ///  }
     /// </pre>
     ///
-    /// See also <seealso cref="IntField"/>, <seealso cref="FloatField"/>, {@link
+    /// See also <seealso cref="Int32Field"/>, <seealso cref="SingleField"/>, {@link
     /// DoubleField}.
     ///
     /// Any type that can be converted to long can also be
@@ -114,10 +114,12 @@ namespace Lucene.Net.Documents
     /// NumericTokenStream} directly, when indexing numbers. this
     /// class is a wrapper around this token stream type for
     /// easier, more intuitive usage.</p>
-    ///
+    /// <para>
+    /// NOTE: This was LongField in Lucene
+    /// </para>
     /// @since 2.9
     /// </summary>
-    public sealed class LongField : Field
+    public sealed class Int64Field : Field
     {
         /// <summary>
         /// Type for a LongField that is not stored:
@@ -125,7 +127,7 @@ namespace Lucene.Net.Documents
         /// </summary>
         public static readonly FieldType TYPE_NOT_STORED = new FieldType();
 
-        static LongField()
+        static Int64Field()
         {
             TYPE_NOT_STORED.IsIndexed = true;
             TYPE_NOT_STORED.IsTokenized = true;
@@ -157,7 +159,7 @@ namespace Lucene.Net.Documents
         ///  <param name="value"> 64-bit long value </param>
         ///  <param name="stored"> Store.YES if the content should also be stored </param>
         ///  <exception cref="IllegalArgumentException"> if the field name is null. </exception>
-        public LongField(string name, long value, Store stored)
+        public Int64Field(string name, long value, Store stored)
             : base(name, stored == Store.YES ? TYPE_STORED : TYPE_NOT_STORED)
         {
             m_fieldsData = Convert.ToInt64(value);
@@ -172,7 +174,7 @@ namespace Lucene.Net.Documents
         ///         of <seealso cref="NumericType#LONG"/>. </param>
         ///  <exception cref="IllegalArgumentException"> if the field name or type is null, or
         ///          if the field type does not have a LONG numericType() </exception>
-        public LongField(string name, long value, FieldType type)
+        public Int64Field(string name, long value, FieldType type)
             : base(name, type)
         {
             if (type.NumericType != NumericType.LONG)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Document/PackedLongDocValuesField.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Document/PackedLongDocValuesField.cs b/src/Lucene.Net.Core/Document/PackedLongDocValuesField.cs
index c1f8d63..5583920 100644
--- a/src/Lucene.Net.Core/Document/PackedLongDocValuesField.cs
+++ b/src/Lucene.Net.Core/Document/PackedLongDocValuesField.cs
@@ -31,18 +31,21 @@ namespace Lucene.Net.Documents
     /// <p>
     /// If you also need to store the value, you should add a
     /// separate <seealso cref="StoredField"/> instance.
+    /// <para>
+    /// NOTE: This was PackedLongDocValuesField in Lucene
+    /// </para>
     /// </summary>
     /// <seealso cref= NumericDocValues </seealso>
     /// @deprecated use <seealso cref="NumericDocValuesField"/> instead.
     [Obsolete("Use NumericDocValuesField instead.")]
-    public class PackedLongDocValuesField : NumericDocValuesField
+    public class PackedInt64DocValuesField : NumericDocValuesField
     {
         /// <summary>
-        /// Creates a new DocValues field with the specified long value </summary>
+        /// Creates a new DocValues field with the specified <see cref="long"/> value </summary>
         /// <param name="name"> field name </param>
-        /// <param name="value"> 64-bit long value </param>
+        /// <param name="value"> 64-bit <see cref="long"/> value </param>
         /// <exception cref="ArgumentException"> if the field name is null </exception>
-        public PackedLongDocValuesField(string name, long value)
+        public PackedInt64DocValuesField(string name, long value)
             : base(name, value)
         {
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Document/ShortDocValuesField.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Document/ShortDocValuesField.cs b/src/Lucene.Net.Core/Document/ShortDocValuesField.cs
index 92bbf57..fbb1d94 100644
--- a/src/Lucene.Net.Core/Document/ShortDocValuesField.cs
+++ b/src/Lucene.Net.Core/Document/ShortDocValuesField.cs
@@ -31,18 +31,21 @@ namespace Lucene.Net.Documents
     /// <p>
     /// If you also need to store the value, you should add a
     /// separate <seealso cref="StoredField"/> instance.
+    /// <para>
+    /// NOTE: This was ShortDocValuesField in Lucene
+    /// </para>
     /// </summary>
     /// <seealso cref= NumericDocValues </seealso>
     /// @deprecated use <seealso cref="NumericDocValuesField"/> instead.
     [Obsolete("Use NumericDocValuesField instead.")]
-    public class ShortDocValuesField : NumericDocValuesField
+    public class Int16DocValuesField : NumericDocValuesField
     {
         /// <summary>
-        /// Creates a new DocValues field with the specified 16-bit short value </summary>
+        /// Creates a new DocValues field with the specified 16-bit <see cref="short"/> value </summary>
         /// <param name="name"> field name </param>
-        /// <param name="value"> 16-bit short value </param>
+        /// <param name="value"> 16-bit <see cref="short"/> value </param>
         /// <exception cref="ArgumentException"> if the field name is null </exception>
-        public ShortDocValuesField(string name, short value)
+        public Int16DocValuesField(string name, short value)
             : base(name, value)
         {
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Index/AutomatonTermsEnum.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Index/AutomatonTermsEnum.cs b/src/Lucene.Net.Core/Index/AutomatonTermsEnum.cs
index d4f43f2..b6ba1b4 100644
--- a/src/Lucene.Net.Core/Index/AutomatonTermsEnum.cs
+++ b/src/Lucene.Net.Core/Index/AutomatonTermsEnum.cs
@@ -24,7 +24,7 @@ namespace Lucene.Net.Index
     using ByteRunAutomaton = Lucene.Net.Util.Automaton.ByteRunAutomaton;
     using BytesRef = Lucene.Net.Util.BytesRef;
     using CompiledAutomaton = Lucene.Net.Util.Automaton.CompiledAutomaton;
-    using IntsRef = Lucene.Net.Util.IntsRef;
+    using Int32sRef = Lucene.Net.Util.Int32sRef;
     using StringHelper = Lucene.Net.Util.StringHelper;
     using Transition = Lucene.Net.Util.Automaton.Transition;
 
@@ -192,7 +192,7 @@ namespace Lucene.Net.Index
             linear = true;
         }
 
-        private readonly IntsRef savedStates = new IntsRef(10);
+        private readonly Int32sRef savedStates = new Int32sRef(10);
 
         /// <summary>
         /// Increments the byte buffer to the next String in binary order after s that will not put

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Index/BinaryDocValuesFieldUpdates.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Index/BinaryDocValuesFieldUpdates.cs b/src/Lucene.Net.Core/Index/BinaryDocValuesFieldUpdates.cs
index 0e20728..082b25a 100644
--- a/src/Lucene.Net.Core/Index/BinaryDocValuesFieldUpdates.cs
+++ b/src/Lucene.Net.Core/Index/BinaryDocValuesFieldUpdates.cs
@@ -26,7 +26,7 @@ namespace Lucene.Net.Index
     using DocIdSetIterator = Lucene.Net.Search.DocIdSetIterator;
     using FixedBitSet = Lucene.Net.Util.FixedBitSet;
     using InPlaceMergeSorter = Lucene.Net.Util.InPlaceMergeSorter;
-    using PackedInts = Lucene.Net.Util.Packed.PackedInts;
+    using PackedInt32s = Lucene.Net.Util.Packed.PackedInt32s;
     using PagedGrowableWriter = Lucene.Net.Util.Packed.PagedGrowableWriter;
     using PagedMutable = Lucene.Net.Util.Packed.PagedMutable;
 
@@ -130,9 +130,9 @@ namespace Lucene.Net.Index
             : base(field, DocValuesFieldUpdates.Type.BINARY)
         {
             docsWithField = new FixedBitSet(64);
-            docs = new PagedMutable(1, 1024, PackedInts.BitsRequired(maxDoc - 1), PackedInts.COMPACT);
-            offsets = new PagedGrowableWriter(1, 1024, 1, PackedInts.FAST);
-            lengths = new PagedGrowableWriter(1, 1024, 1, PackedInts.FAST);
+            docs = new PagedMutable(1, 1024, PackedInt32s.BitsRequired(maxDoc - 1), PackedInt32s.COMPACT);
+            offsets = new PagedGrowableWriter(1, 1024, 1, PackedInt32s.FAST);
+            lengths = new PagedGrowableWriter(1, 1024, 1, PackedInt32s.FAST);
             values = new BytesRef(16); // start small
             size = 0;
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Index/BinaryDocValuesWriter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Index/BinaryDocValuesWriter.cs b/src/Lucene.Net.Core/Index/BinaryDocValuesWriter.cs
index 3b1833d..908c2af 100644
--- a/src/Lucene.Net.Core/Index/BinaryDocValuesWriter.cs
+++ b/src/Lucene.Net.Core/Index/BinaryDocValuesWriter.cs
@@ -20,7 +20,7 @@ namespace Lucene.Net.Index
      * limitations under the License.
      */
 
-    using AppendingDeltaPackedLongBuffer = Lucene.Net.Util.Packed.AppendingDeltaPackedLongBuffer;
+    using AppendingDeltaPackedInt64Buffer = Lucene.Net.Util.Packed.AppendingDeltaPackedInt64Buffer;
     using ArrayUtil = Lucene.Net.Util.ArrayUtil;
     using BytesRef = Lucene.Net.Util.BytesRef;
     using Counter = Lucene.Net.Util.Counter;
@@ -28,7 +28,7 @@ namespace Lucene.Net.Index
     using DataOutput = Lucene.Net.Store.DataOutput;
     using DocValuesConsumer = Lucene.Net.Codecs.DocValuesConsumer;
     using FixedBitSet = Lucene.Net.Util.FixedBitSet;
-    using PackedInts = Lucene.Net.Util.Packed.PackedInts;
+    using PackedInt32s = Lucene.Net.Util.Packed.PackedInt32s;
     using PagedBytes = Lucene.Net.Util.PagedBytes;
     using RamUsageEstimator = Lucene.Net.Util.RamUsageEstimator;
 
@@ -49,7 +49,7 @@ namespace Lucene.Net.Index
         private readonly DataOutput bytesOut;
 
         private readonly Counter iwBytesUsed;
-        private readonly AppendingDeltaPackedLongBuffer lengths;
+        private readonly AppendingDeltaPackedInt64Buffer lengths;
         private FixedBitSet docsWithField;
         private readonly FieldInfo fieldInfo;
         private int addedValues;
@@ -60,7 +60,7 @@ namespace Lucene.Net.Index
             this.fieldInfo = fieldInfo;
             this.bytes = new PagedBytes(BLOCK_BITS);
             this.bytesOut = bytes.GetDataOutput();
-            this.lengths = new AppendingDeltaPackedLongBuffer(PackedInts.COMPACT);
+            this.lengths = new AppendingDeltaPackedInt64Buffer(PackedInt32s.COMPACT);
             this.iwBytesUsed = iwBytesUsed;
             this.docsWithField = new FixedBitSet(64);
             this.bytesUsed = DocsWithFieldBytesUsed();
@@ -136,7 +136,7 @@ namespace Lucene.Net.Index
         {
             // Use yield return instead of ucsom IEnumerable
 
-            AppendingDeltaPackedLongBuffer.Iterator lengthsIterator = lengths.GetIterator();
+            AppendingDeltaPackedInt64Buffer.Iterator lengthsIterator = lengths.GetIterator();
             int size = (int)lengths.Count;
             DataInput bytesIterator = bytes.GetDataInput();
             int maxDoc = maxDocParam;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Index/BufferedUpdates.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Index/BufferedUpdates.cs b/src/Lucene.Net.Core/Index/BufferedUpdates.cs
index d03d298..3f66ed5 100644
--- a/src/Lucene.Net.Core/Index/BufferedUpdates.cs
+++ b/src/Lucene.Net.Core/Index/BufferedUpdates.cs
@@ -117,9 +117,9 @@ namespace Lucene.Net.Index
          */
         internal static readonly int BYTES_PER_BINARY_UPDATE_ENTRY = 7 * RamUsageEstimator.NUM_BYTES_OBJECT_REF + RamUsageEstimator.NUM_BYTES_OBJECT_HEADER + RamUsageEstimator.NUM_BYTES_INT;
 
-        internal readonly AtomicInteger numTermDeletes = new AtomicInteger();
-        internal readonly AtomicInteger numNumericUpdates = new AtomicInteger();
-        internal readonly AtomicInteger numBinaryUpdates = new AtomicInteger();
+        internal readonly AtomicInt32 numTermDeletes = new AtomicInt32();
+        internal readonly AtomicInt32 numNumericUpdates = new AtomicInt32();
+        internal readonly AtomicInt32 numBinaryUpdates = new AtomicInt32();
         internal readonly IDictionary<Term, int?> terms = new Dictionary<Term, int?>();
         internal readonly IDictionary<Query, int?> queries = new Dictionary<Query, int?>();
         internal readonly IList<int?> docIDs = new List<int?>();
@@ -145,7 +145,7 @@ namespace Lucene.Net.Index
 
         public static readonly int MAX_INT = Convert.ToInt32(int.MaxValue);
 
-        internal readonly AtomicLong bytesUsed;
+        internal readonly AtomicInt64 bytesUsed;
 
         private static bool VERBOSE_DELETES = false;
 
@@ -153,7 +153,7 @@ namespace Lucene.Net.Index
 
         internal BufferedUpdates() // LUCENENET NOTE: Made internal rather than public, since this class is intended to be internal but couldn't be because it is exposed through a public API
         {
-            this.bytesUsed = new AtomicLong();
+            this.bytesUsed = new AtomicInt64();
         }
 
         public override string ToString()

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Index/BufferedUpdatesStream.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Index/BufferedUpdatesStream.cs b/src/Lucene.Net.Core/Index/BufferedUpdatesStream.cs
index 5db21ca..4db8b0d 100644
--- a/src/Lucene.Net.Core/Index/BufferedUpdatesStream.cs
+++ b/src/Lucene.Net.Core/Index/BufferedUpdatesStream.cs
@@ -59,8 +59,8 @@ namespace Lucene.Net.Index
         private Term lastDeleteTerm;
 
         private readonly InfoStream infoStream;
-        private readonly AtomicLong bytesUsed = new AtomicLong();
-        private readonly AtomicInteger numTerms = new AtomicInteger();
+        private readonly AtomicInt64 bytesUsed = new AtomicInt64();
+        private readonly AtomicInt32 numTerms = new AtomicInt32();
 
         public BufferedUpdatesStream(InfoStream infoStream)
         {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Index/CheckIndex.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Index/CheckIndex.cs b/src/Lucene.Net.Core/Index/CheckIndex.cs
index b363b8d..a26eb30 100644
--- a/src/Lucene.Net.Core/Index/CheckIndex.cs
+++ b/src/Lucene.Net.Core/Index/CheckIndex.cs
@@ -35,7 +35,7 @@ namespace Lucene.Net.Index
     using FixedBitSet = Lucene.Net.Util.FixedBitSet;
     using IndexInput = Lucene.Net.Store.IndexInput;
     using IOContext = Lucene.Net.Store.IOContext;
-    using LongBitSet = Lucene.Net.Util.LongBitSet;
+    using Int64BitSet = Lucene.Net.Util.Int64BitSet;
     using Lucene3xSegmentInfoFormat = Lucene.Net.Codecs.Lucene3x.Lucene3xSegmentInfoFormat;
     using PostingsFormat = Lucene.Net.Codecs.PostingsFormat;
     using StringHelper = Lucene.Net.Util.StringHelper;
@@ -1874,7 +1874,7 @@ namespace Lucene.Net.Index
         private static void CheckSortedSetDocValues(string fieldName, AtomicReader reader, SortedSetDocValues dv, IBits docsWithField)
         {
             long maxOrd = dv.ValueCount - 1;
-            LongBitSet seenOrds = new LongBitSet(dv.ValueCount);
+            Int64BitSet seenOrds = new Int64BitSet(dv.ValueCount);
             long maxOrd2 = -1;
             for (int i = 0; i < reader.MaxDoc; i++)
             {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Index/DocumentsWriter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Index/DocumentsWriter.cs b/src/Lucene.Net.Core/Index/DocumentsWriter.cs
index 97c8aea..abbb2ad 100644
--- a/src/Lucene.Net.Core/Index/DocumentsWriter.cs
+++ b/src/Lucene.Net.Core/Index/DocumentsWriter.cs
@@ -110,7 +110,7 @@ namespace Lucene.Net.Index
 
         private readonly LiveIndexWriterConfig config;
 
-        private readonly AtomicInteger numDocsInRAM = new AtomicInteger(0);
+        private readonly AtomicInt32 numDocsInRAM = new AtomicInt32(0);
 
         // TODO: cut over to BytesRefHash in BufferedDeletes
         internal volatile DocumentsWriterDeleteQueue deleteQueue = new DocumentsWriterDeleteQueue();

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Index/DocumentsWriterFlushQueue.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Index/DocumentsWriterFlushQueue.cs b/src/Lucene.Net.Core/Index/DocumentsWriterFlushQueue.cs
index f488afb..d9cbe9d 100644
--- a/src/Lucene.Net.Core/Index/DocumentsWriterFlushQueue.cs
+++ b/src/Lucene.Net.Core/Index/DocumentsWriterFlushQueue.cs
@@ -32,7 +32,7 @@ namespace Lucene.Net.Index
 
         // we track tickets separately since count must be present even before the ticket is
         // constructed ie. queue.size would not reflect it.
-        private readonly AtomicInteger ticketCount = new AtomicInteger();
+        private readonly AtomicInt32 ticketCount = new AtomicInt32();
 
         private readonly ReentrantLock purgeLock = new ReentrantLock();
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Index/DocumentsWriterPerThread.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Index/DocumentsWriterPerThread.cs b/src/Lucene.Net.Core/Index/DocumentsWriterPerThread.cs
index 470e590..56e01ec 100644
--- a/src/Lucene.Net.Core/Index/DocumentsWriterPerThread.cs
+++ b/src/Lucene.Net.Core/Index/DocumentsWriterPerThread.cs
@@ -35,7 +35,7 @@ namespace Lucene.Net.Index
     using DirectTrackingAllocator = Lucene.Net.Util.ByteBlockPool.DirectTrackingAllocator;
     using FlushInfo = Lucene.Net.Store.FlushInfo;
     using InfoStream = Lucene.Net.Util.InfoStream;
-    using IntBlockPool = Lucene.Net.Util.IntBlockPool;
+    using Int32BlockPool = Lucene.Net.Util.Int32BlockPool;
     using IOContext = Lucene.Net.Store.IOContext;
     using IMutableBits = Lucene.Net.Util.IMutableBits;
     using RamUsageEstimator = Lucene.Net.Util.RamUsageEstimator;
@@ -218,7 +218,7 @@ namespace Lucene.Net.Index
         private readonly DeleteSlice deleteSlice;
         private readonly NumberFormatInfo nf = CultureInfo.InvariantCulture.NumberFormat;
         internal readonly Allocator byteBlockAllocator;
-        internal readonly IntBlockPool.Allocator intBlockAllocator;
+        internal readonly Int32BlockPool.Allocator intBlockAllocator;
         private readonly LiveIndexWriterConfig indexWriterConfig;
 
         public DocumentsWriterPerThread(string segmentName, Directory directory, LiveIndexWriterConfig indexWriterConfig, InfoStream infoStream, DocumentsWriterDeleteQueue deleteQueue, FieldInfos.Builder fieldInfos)
@@ -234,7 +234,7 @@ namespace Lucene.Net.Index
             bytesUsed = Counter.NewCounter();
             byteBlockAllocator = new DirectTrackingAllocator(bytesUsed);
             pendingUpdates = new BufferedUpdates();
-            intBlockAllocator = new IntBlockAllocator(bytesUsed);
+            intBlockAllocator = new Int32BlockAllocator(bytesUsed);
             this.deleteQueue = deleteQueue;
             Debug.Assert(numDocsInRAM == 0, "num docs " + numDocsInRAM);
             pendingUpdates.Clear();
@@ -705,12 +705,15 @@ namespace Lucene.Net.Index
          * getTerms/getTermsIndex requires <= 32768 */
         internal static readonly int MAX_TERM_LENGTH_UTF8 = ByteBlockPool.BYTE_BLOCK_SIZE - 2;
 
-        private class IntBlockAllocator : IntBlockPool.Allocator
+        /// <summary>
+        /// NOTE: This was IntBlockAllocator in Lucene
+        /// </summary>
+        private class Int32BlockAllocator : Int32BlockPool.Allocator
         {
             private readonly Counter bytesUsed;
 
-            public IntBlockAllocator(Counter bytesUsed)
-                : base(IntBlockPool.INT_BLOCK_SIZE)
+            public Int32BlockAllocator(Counter bytesUsed)
+                : base(Int32BlockPool.INT_BLOCK_SIZE)
             {
                 this.bytesUsed = bytesUsed;
             }
@@ -719,14 +722,14 @@ namespace Lucene.Net.Index
 
             public override int[] GetInt32Block()
             {
-                int[] b = new int[IntBlockPool.INT_BLOCK_SIZE];
-                bytesUsed.AddAndGet(IntBlockPool.INT_BLOCK_SIZE * RamUsageEstimator.NUM_BYTES_INT);
+                int[] b = new int[Int32BlockPool.INT_BLOCK_SIZE];
+                bytesUsed.AddAndGet(Int32BlockPool.INT_BLOCK_SIZE * RamUsageEstimator.NUM_BYTES_INT);
                 return b;
             }
 
             public override void RecycleInt32Blocks(int[][] blocks, int offset, int length)
             {
-                bytesUsed.AddAndGet(-(length * (IntBlockPool.INT_BLOCK_SIZE * RamUsageEstimator.NUM_BYTES_INT)));
+                bytesUsed.AddAndGet(-(length * (Int32BlockPool.INT_BLOCK_SIZE * RamUsageEstimator.NUM_BYTES_INT)));
             }
         }
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Index/IndexReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Index/IndexReader.cs b/src/Lucene.Net.Core/Index/IndexReader.cs
index 46886d4..f445715 100644
--- a/src/Lucene.Net.Core/Index/IndexReader.cs
+++ b/src/Lucene.Net.Core/Index/IndexReader.cs
@@ -72,7 +72,7 @@ namespace Lucene.Net.Index
     {
         private bool closed = false;
         private bool closedByChild = false;
-        private readonly AtomicInteger refCount = new AtomicInteger(1);
+        private readonly AtomicInt32 refCount = new AtomicInt32(1);
 
         internal IndexReader()
         {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Index/IndexWriter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Index/IndexWriter.cs b/src/Lucene.Net.Core/Index/IndexWriter.cs
index 99a9381..2155239 100644
--- a/src/Lucene.Net.Core/Index/IndexWriter.cs
+++ b/src/Lucene.Net.Core/Index/IndexWriter.cs
@@ -256,8 +256,8 @@ namespace Lucene.Net.Index
         private long mergeGen;
         private bool stopMerges;
 
-        internal readonly AtomicInteger flushCount = new AtomicInteger();
-        internal readonly AtomicInteger flushDeletesCount = new AtomicInteger();
+        internal readonly AtomicInt32 flushCount = new AtomicInt32();
+        internal readonly AtomicInt32 flushDeletesCount = new AtomicInt32();
 
         internal ReaderPool readerPool;
         internal readonly BufferedUpdatesStream bufferedUpdatesStream;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Index/MergeState.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Index/MergeState.cs b/src/Lucene.Net.Core/Index/MergeState.cs
index 971a771..5ffaee3 100644
--- a/src/Lucene.Net.Core/Index/MergeState.cs
+++ b/src/Lucene.Net.Core/Index/MergeState.cs
@@ -25,7 +25,7 @@ namespace Lucene.Net.Index
     using IBits = Lucene.Net.Util.IBits;
     using Directory = Lucene.Net.Store.Directory;
     using InfoStream = Lucene.Net.Util.InfoStream;
-    using MonotonicAppendingLongBuffer = Lucene.Net.Util.Packed.MonotonicAppendingLongBuffer;
+    using MonotonicAppendingInt64Buffer = Lucene.Net.Util.Packed.MonotonicAppendingInt64Buffer;
 
     /// <summary>
     /// Holds common state used during segment merging.
@@ -89,7 +89,7 @@ namespace Lucene.Net.Index
             internal static DocMap Build(int maxDoc, IBits liveDocs)
             {
                 Debug.Assert(liveDocs != null);
-                MonotonicAppendingLongBuffer docMap = new MonotonicAppendingLongBuffer();
+                MonotonicAppendingInt64Buffer docMap = new MonotonicAppendingInt64Buffer();
                 int del = 0;
                 for (int i = 0; i < maxDoc; ++i)
                 {
@@ -109,10 +109,10 @@ namespace Lucene.Net.Index
             {
                 private int maxDoc;
                 private IBits liveDocs;
-                private MonotonicAppendingLongBuffer docMap;
+                private MonotonicAppendingInt64Buffer docMap;
                 private int numDeletedDocs;
 
-                public DocMapAnonymousInnerClassHelper(int maxDoc, IBits liveDocs, MonotonicAppendingLongBuffer docMap, int numDeletedDocs)
+                public DocMapAnonymousInnerClassHelper(int maxDoc, IBits liveDocs, MonotonicAppendingInt64Buffer docMap, int numDeletedDocs)
                 {
                     this.maxDoc = maxDoc;
                     this.liveDocs = liveDocs;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Index/MultiDocValues.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Index/MultiDocValues.cs b/src/Lucene.Net.Core/Index/MultiDocValues.cs
index bcd6fbc..ae9e91a 100644
--- a/src/Lucene.Net.Core/Index/MultiDocValues.cs
+++ b/src/Lucene.Net.Core/Index/MultiDocValues.cs
@@ -22,11 +22,11 @@ namespace Lucene.Net.Index
      * limitations under the License.
      */
 
-    using AppendingPackedLongBuffer = Lucene.Net.Util.Packed.AppendingPackedLongBuffer;
+    using AppendingPackedInt64Buffer = Lucene.Net.Util.Packed.AppendingPackedInt64Buffer;
     using IBits = Lucene.Net.Util.IBits;
     using BytesRef = Lucene.Net.Util.BytesRef;
-    using MonotonicAppendingLongBuffer = Lucene.Net.Util.Packed.MonotonicAppendingLongBuffer;
-    using PackedInts = Lucene.Net.Util.Packed.PackedInts;
+    using MonotonicAppendingInt64Buffer = Lucene.Net.Util.Packed.MonotonicAppendingInt64Buffer;
+    using PackedInt32s = Lucene.Net.Util.Packed.PackedInt32s;
     using TermsEnumIndex = Lucene.Net.Index.MultiTermsEnum.TermsEnumIndex;
     using TermsEnumWithSlice = Lucene.Net.Index.MultiTermsEnum.TermsEnumWithSlice;
 
@@ -443,13 +443,13 @@ namespace Lucene.Net.Index
             internal readonly object owner;
 
             // globalOrd -> (globalOrd - segmentOrd) where segmentOrd is the the ordinal in the first segment that contains this term
-            internal readonly MonotonicAppendingLongBuffer globalOrdDeltas;
+            internal readonly MonotonicAppendingInt64Buffer globalOrdDeltas;
 
             // globalOrd -> first segment container
-            internal readonly AppendingPackedLongBuffer firstSegments;
+            internal readonly AppendingPackedInt64Buffer firstSegments;
 
             // for every segment, segmentOrd -> (globalOrd - segmentOrd)
-            internal readonly MonotonicAppendingLongBuffer[] ordDeltas;
+            internal readonly MonotonicAppendingInt64Buffer[] ordDeltas;
 
             /// <summary>
             /// Creates an ordinal map that allows mapping ords to/from a merged
@@ -463,12 +463,12 @@ namespace Lucene.Net.Index
                 // create the ordinal mappings by pulling a termsenum over each sub's
                 // unique terms, and walking a multitermsenum over those
                 this.owner = owner;
-                globalOrdDeltas = new MonotonicAppendingLongBuffer(PackedInts.COMPACT);
-                firstSegments = new AppendingPackedLongBuffer(PackedInts.COMPACT);
-                ordDeltas = new MonotonicAppendingLongBuffer[subs.Length];
+                globalOrdDeltas = new MonotonicAppendingInt64Buffer(PackedInt32s.COMPACT);
+                firstSegments = new AppendingPackedInt64Buffer(PackedInt32s.COMPACT);
+                ordDeltas = new MonotonicAppendingInt64Buffer[subs.Length];
                 for (int i = 0; i < ordDeltas.Length; i++)
                 {
-                    ordDeltas[i] = new MonotonicAppendingLongBuffer();
+                    ordDeltas[i] = new MonotonicAppendingInt64Buffer();
                 }
                 long[] segmentOrds = new long[subs.Length];
                 ReaderSlice[] slices = new ReaderSlice[subs.Length];

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Index/NumericDocValuesFieldUpdates.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Index/NumericDocValuesFieldUpdates.cs b/src/Lucene.Net.Core/Index/NumericDocValuesFieldUpdates.cs
index f9e041d..8d2dcc6 100644
--- a/src/Lucene.Net.Core/Index/NumericDocValuesFieldUpdates.cs
+++ b/src/Lucene.Net.Core/Index/NumericDocValuesFieldUpdates.cs
@@ -25,7 +25,7 @@ namespace Lucene.Net.Index
     using FixedBitSet = Lucene.Net.Util.FixedBitSet;
     using InPlaceMergeSorter = Lucene.Net.Util.InPlaceMergeSorter;
     using NumericDocValuesUpdate = Lucene.Net.Index.DocValuesUpdate.NumericDocValuesUpdate;
-    using PackedInts = Lucene.Net.Util.Packed.PackedInts;
+    using PackedInt32s = Lucene.Net.Util.Packed.PackedInt32s;
     using PagedGrowableWriter = Lucene.Net.Util.Packed.PagedGrowableWriter;
     using PagedMutable = Lucene.Net.Util.Packed.PagedMutable;
 
@@ -107,8 +107,8 @@ namespace Lucene.Net.Index
             : base(field, DocValuesFieldUpdates.Type.NUMERIC)
         {
             docsWithField = new FixedBitSet(64);
-            docs = new PagedMutable(1, 1024, PackedInts.BitsRequired(maxDoc - 1), PackedInts.COMPACT);
-            values = new PagedGrowableWriter(1, 1024, 1, PackedInts.FAST);
+            docs = new PagedMutable(1, 1024, PackedInt32s.BitsRequired(maxDoc - 1), PackedInt32s.COMPACT);
+            values = new PagedGrowableWriter(1, 1024, 1, PackedInt32s.FAST);
             size = 0;
         }
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Index/NumericDocValuesWriter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Index/NumericDocValuesWriter.cs b/src/Lucene.Net.Core/Index/NumericDocValuesWriter.cs
index d1a988a..88eb450 100644
--- a/src/Lucene.Net.Core/Index/NumericDocValuesWriter.cs
+++ b/src/Lucene.Net.Core/Index/NumericDocValuesWriter.cs
@@ -20,11 +20,11 @@ namespace Lucene.Net.Index
      * limitations under the License.
      */
 
-    using AppendingDeltaPackedLongBuffer = Lucene.Net.Util.Packed.AppendingDeltaPackedLongBuffer;
+    using AppendingDeltaPackedInt64Buffer = Lucene.Net.Util.Packed.AppendingDeltaPackedInt64Buffer;
     using Counter = Lucene.Net.Util.Counter;
     using DocValuesConsumer = Lucene.Net.Codecs.DocValuesConsumer;
     using FixedBitSet = Lucene.Net.Util.FixedBitSet;
-    using PackedInts = Lucene.Net.Util.Packed.PackedInts;
+    using PackedInt32s = Lucene.Net.Util.Packed.PackedInt32s;
     using RamUsageEstimator = Lucene.Net.Util.RamUsageEstimator;
 
     /// <summary>
@@ -35,7 +35,7 @@ namespace Lucene.Net.Index
     {
         private const long MISSING = 0L;
 
-        private AppendingDeltaPackedLongBuffer pending;
+        private AppendingDeltaPackedInt64Buffer pending;
         private readonly Counter iwBytesUsed;
         private long bytesUsed;
         private FixedBitSet docsWithField;
@@ -43,7 +43,7 @@ namespace Lucene.Net.Index
 
         public NumericDocValuesWriter(FieldInfo fieldInfo, Counter iwBytesUsed, bool trackDocsWithField)
         {
-            pending = new AppendingDeltaPackedLongBuffer(PackedInts.COMPACT);
+            pending = new AppendingDeltaPackedInt64Buffer(PackedInt32s.COMPACT);
             docsWithField = trackDocsWithField ? new FixedBitSet(64) : null;
             bytesUsed = pending.RamBytesUsed() + DocsWithFieldBytesUsed();
             this.fieldInfo = fieldInfo;
@@ -101,7 +101,7 @@ namespace Lucene.Net.Index
         private IEnumerable<long?> GetNumericIterator(int maxDoc)
         {
             // LUCENENET specific: using yield return instead of custom iterator type. Much less code.
-            AbstractAppendingLongBuffer.Iterator iter = pending.GetIterator();
+            AbstractAppendingInt64Buffer.Iterator iter = pending.GetIterator();
             int size = (int)pending.Count;
             int upto = 0;
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Index/ReadersAndUpdates.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Index/ReadersAndUpdates.cs b/src/Lucene.Net.Core/Index/ReadersAndUpdates.cs
index b9859c2..de07b6f 100644
--- a/src/Lucene.Net.Core/Index/ReadersAndUpdates.cs
+++ b/src/Lucene.Net.Core/Index/ReadersAndUpdates.cs
@@ -49,7 +49,7 @@ namespace Lucene.Net.Index
         public SegmentCommitInfo Info { get; private set; }
 
         // Tracks how many consumers are using this instance:
-        private readonly AtomicInteger refCount = new AtomicInteger(1);
+        private readonly AtomicInt32 refCount = new AtomicInt32(1);
 
         private readonly IndexWriter writer;
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Index/SegmentCoreReaders.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Index/SegmentCoreReaders.cs b/src/Lucene.Net.Core/Index/SegmentCoreReaders.cs
index dd55c47..c9f89ad 100644
--- a/src/Lucene.Net.Core/Index/SegmentCoreReaders.cs
+++ b/src/Lucene.Net.Core/Index/SegmentCoreReaders.cs
@@ -49,7 +49,7 @@ namespace Lucene.Net.Index
         // closed.  A given instance of SegmentReader may be
         // closed, even though it shares core objects with other
         // SegmentReaders:
-        private readonly AtomicInteger @ref = new AtomicInteger(1);
+        private readonly AtomicInt32 @ref = new AtomicInt32(1);
 
         internal readonly FieldsProducer fields;
         internal readonly DocValuesProducer normsProducer;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Index/SortedDocValuesWriter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Index/SortedDocValuesWriter.cs b/src/Lucene.Net.Core/Index/SortedDocValuesWriter.cs
index 74022f6..881de17 100644
--- a/src/Lucene.Net.Core/Index/SortedDocValuesWriter.cs
+++ b/src/Lucene.Net.Core/Index/SortedDocValuesWriter.cs
@@ -30,7 +30,7 @@ namespace Lucene.Net.Index
     internal class SortedDocValuesWriter : DocValuesWriter
     {
         internal readonly BytesRefHash hash;
-        private AppendingDeltaPackedLongBuffer pending;
+        private AppendingDeltaPackedInt64Buffer pending;
         private readonly Counter iwBytesUsed;
         private long bytesUsed; // this currently only tracks differences in 'pending'
         private readonly FieldInfo fieldInfo;
@@ -42,7 +42,7 @@ namespace Lucene.Net.Index
             this.fieldInfo = fieldInfo;
             this.iwBytesUsed = iwBytesUsed;
             hash = new BytesRefHash(new ByteBlockPool(new ByteBlockPool.DirectTrackingAllocator(iwBytesUsed)), BytesRefHash.DEFAULT_CAPACITY, new BytesRefHash.DirectBytesStartArray(BytesRefHash.DEFAULT_CAPACITY, iwBytesUsed));
-            pending = new AppendingDeltaPackedLongBuffer(PackedInts.COMPACT);
+            pending = new AppendingDeltaPackedInt64Buffer(PackedInt32s.COMPACT);
             bytesUsed = pending.RamBytesUsed();
             iwBytesUsed.AddAndGet(bytesUsed);
         }
@@ -142,7 +142,7 @@ namespace Lucene.Net.Index
 
         private IEnumerable<long?> GetOrdsEnumberable(int maxDoc, int[] ordMap)
         {
-            AppendingDeltaPackedLongBuffer.Iterator iter = pending.GetIterator();
+            AppendingDeltaPackedInt64Buffer.Iterator iter = pending.GetIterator();
 
             for (int i = 0; i < maxDoc; ++i)
             {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Index/SortedSetDocValuesWriter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Index/SortedSetDocValuesWriter.cs b/src/Lucene.Net.Core/Index/SortedSetDocValuesWriter.cs
index d20b2ff..a0515ec 100644
--- a/src/Lucene.Net.Core/Index/SortedSetDocValuesWriter.cs
+++ b/src/Lucene.Net.Core/Index/SortedSetDocValuesWriter.cs
@@ -21,8 +21,8 @@ namespace Lucene.Net.Index
      * limitations under the License.
      */
 
-    using AppendingDeltaPackedLongBuffer = Lucene.Net.Util.Packed.AppendingDeltaPackedLongBuffer;
-    using AppendingPackedLongBuffer = Lucene.Net.Util.Packed.AppendingPackedLongBuffer;
+    using AppendingDeltaPackedInt64Buffer = Lucene.Net.Util.Packed.AppendingDeltaPackedInt64Buffer;
+    using AppendingPackedInt64Buffer = Lucene.Net.Util.Packed.AppendingPackedInt64Buffer;
     using ArrayUtil = Lucene.Net.Util.ArrayUtil;
     using ByteBlockPool = Lucene.Net.Util.ByteBlockPool;
     using BytesRef = Lucene.Net.Util.BytesRef;
@@ -30,7 +30,7 @@ namespace Lucene.Net.Index
     using Counter = Lucene.Net.Util.Counter;
     using DirectBytesStartArray = Lucene.Net.Util.BytesRefHash.DirectBytesStartArray;
     using DocValuesConsumer = Lucene.Net.Codecs.DocValuesConsumer;
-    using PackedInts = Lucene.Net.Util.Packed.PackedInts;
+    using PackedInt32s = Lucene.Net.Util.Packed.PackedInt32s;
     using RamUsageEstimator = Lucene.Net.Util.RamUsageEstimator;
 
     /// <summary>
@@ -40,8 +40,8 @@ namespace Lucene.Net.Index
     internal class SortedSetDocValuesWriter : DocValuesWriter
     {
         internal readonly BytesRefHash hash;
-        private AppendingPackedLongBuffer pending; // stream of all termIDs
-        private AppendingDeltaPackedLongBuffer pendingCounts; // termIDs per doc
+        private AppendingPackedInt64Buffer pending; // stream of all termIDs
+        private AppendingDeltaPackedInt64Buffer pendingCounts; // termIDs per doc
         private readonly Counter iwBytesUsed;
         private long bytesUsed; // this only tracks differences in 'pending' and 'pendingCounts'
         private readonly FieldInfo fieldInfo;
@@ -55,8 +55,8 @@ namespace Lucene.Net.Index
             this.fieldInfo = fieldInfo;
             this.iwBytesUsed = iwBytesUsed;
             hash = new BytesRefHash(new ByteBlockPool(new ByteBlockPool.DirectTrackingAllocator(iwBytesUsed)), BytesRefHash.DEFAULT_CAPACITY, new DirectBytesStartArray(BytesRefHash.DEFAULT_CAPACITY, iwBytesUsed));
-            pending = new AppendingPackedLongBuffer(PackedInts.COMPACT);
-            pendingCounts = new AppendingDeltaPackedLongBuffer(PackedInts.COMPACT);
+            pending = new AppendingPackedInt64Buffer(PackedInt32s.COMPACT);
+            pendingCounts = new AppendingDeltaPackedInt64Buffer(PackedInt32s.COMPACT);
             bytesUsed = pending.RamBytesUsed() + pendingCounts.RamBytesUsed();
             iwBytesUsed.AddAndGet(bytesUsed);
         }
@@ -197,7 +197,7 @@ namespace Lucene.Net.Index
 
         private IEnumerable<long?> GetOrdsEnumberable(int maxDoc)
         {
-            AppendingDeltaPackedLongBuffer.Iterator iter = pendingCounts.GetIterator();
+            AppendingDeltaPackedInt64Buffer.Iterator iter = pendingCounts.GetIterator();
 
             Debug.Assert(maxDoc == pendingCounts.Count, "MaxDoc: " + maxDoc + ", pending.Count: " + pending.Count);
 
@@ -210,8 +210,8 @@ namespace Lucene.Net.Index
         private IEnumerable<long?> GetOrdCountEnumberable(int maxCountPerDoc, int[] ordMap)
         {
             int currentUpTo = 0, currentLength = 0;
-            AppendingPackedLongBuffer.Iterator iter = pending.GetIterator();
-            AppendingDeltaPackedLongBuffer.Iterator counts = pendingCounts.GetIterator();
+            AppendingPackedInt64Buffer.Iterator iter = pending.GetIterator();
+            AppendingDeltaPackedInt64Buffer.Iterator counts = pendingCounts.GetIterator();
             int[] currentDoc = new int[maxCountPerDoc];
 
             for (long i = 0; i < pending.Count; ++i)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Index/TermsHash.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Index/TermsHash.cs b/src/Lucene.Net.Core/Index/TermsHash.cs
index 51cdf1b..2a0a874 100644
--- a/src/Lucene.Net.Core/Index/TermsHash.cs
+++ b/src/Lucene.Net.Core/Index/TermsHash.cs
@@ -22,7 +22,7 @@ namespace Lucene.Net.Index
     using ByteBlockPool = Lucene.Net.Util.ByteBlockPool;
     using BytesRef = Lucene.Net.Util.BytesRef;
     using Counter = Lucene.Net.Util.Counter;
-    using IntBlockPool = Lucene.Net.Util.IntBlockPool;
+    using Int32BlockPool = Lucene.Net.Util.Int32BlockPool;
 
     /// <summary>
     /// this class implements <seealso cref="InvertedDocConsumer"/>, which
@@ -38,7 +38,7 @@ namespace Lucene.Net.Index
         internal readonly TermsHashConsumer consumer;
         internal readonly TermsHash nextTermsHash;
 
-        internal readonly IntBlockPool intPool;
+        internal readonly Int32BlockPool intPool;
         internal readonly ByteBlockPool bytePool;
         internal ByteBlockPool termBytePool;
         internal readonly Counter bytesUsed;
@@ -63,7 +63,7 @@ namespace Lucene.Net.Index
             this.trackAllocations = trackAllocations;
             this.nextTermsHash = nextTermsHash;
             this.bytesUsed = trackAllocations ? docWriter.bytesUsed : Counter.NewCounter();
-            intPool = new IntBlockPool(docWriter.intBlockAllocator);
+            intPool = new Int32BlockPool(docWriter.intBlockAllocator);
             bytePool = new ByteBlockPool(docWriter.byteBlockAllocator);
 
             if (nextTermsHash != null)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Index/TermsHashPerField.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Index/TermsHashPerField.cs b/src/Lucene.Net.Core/Index/TermsHashPerField.cs
index 3b451f6..649be47 100644
--- a/src/Lucene.Net.Core/Index/TermsHashPerField.cs
+++ b/src/Lucene.Net.Core/Index/TermsHashPerField.cs
@@ -26,7 +26,7 @@ namespace Lucene.Net.Index
     using BytesRef = Lucene.Net.Util.BytesRef;
     using BytesRefHash = Lucene.Net.Util.BytesRefHash;
     using Counter = Lucene.Net.Util.Counter;
-    using IntBlockPool = Lucene.Net.Util.IntBlockPool;
+    using Int32BlockPool = Lucene.Net.Util.Int32BlockPool;
 
     internal sealed class TermsHashPerField : InvertedDocConsumerPerField
     {
@@ -43,7 +43,7 @@ namespace Lucene.Net.Index
         internal BytesRef termBytesRef;
 
         // Copied from our perThread
-        internal readonly IntBlockPool intPool;
+        internal readonly Int32BlockPool intPool;
 
         internal readonly ByteBlockPool bytePool;
         internal readonly ByteBlockPool termBytePool;
@@ -112,8 +112,8 @@ namespace Lucene.Net.Index
         {
             Debug.Assert(stream < streamCount);
             int intStart = postingsArray.intStarts[termID];
-            int[] ints = intPool.Buffers[intStart >> IntBlockPool.INT_BLOCK_SHIFT];
-            int upto = intStart & IntBlockPool.INT_BLOCK_MASK;
+            int[] ints = intPool.Buffers[intStart >> Int32BlockPool.INT_BLOCK_SHIFT];
+            int upto = intStart & Int32BlockPool.INT_BLOCK_MASK;
             reader.Init(bytePool, postingsArray.byteStarts[termID] + stream * ByteBlockPool.FIRST_LEVEL_SIZE, ints[upto + stream]);
         }
 
@@ -160,7 +160,7 @@ namespace Lucene.Net.Index
                 // First time we are seeing this token since we last
                 // flushed the hash.
                 // Init stream slices
-                if (numPostingInt + intPool.Int32Upto > IntBlockPool.INT_BLOCK_SIZE)
+                if (numPostingInt + intPool.Int32Upto > Int32BlockPool.INT_BLOCK_SIZE)
                 {
                     intPool.NextBuffer();
                 }
@@ -189,8 +189,8 @@ namespace Lucene.Net.Index
             {
                 termID = (-termID) - 1;
                 int intStart = postingsArray.intStarts[termID];
-                intUptos = intPool.Buffers[intStart >> IntBlockPool.INT_BLOCK_SHIFT];
-                intUptoStart = intStart & IntBlockPool.INT_BLOCK_MASK;
+                intUptos = intPool.Buffers[intStart >> Int32BlockPool.INT_BLOCK_SHIFT];
+                intUptoStart = intStart & Int32BlockPool.INT_BLOCK_MASK;
                 consumer.AddTerm(termID);
             }
         }
@@ -235,7 +235,7 @@ namespace Lucene.Net.Index
             {
                 bytesHash.ByteStart(termID);
                 // Init stream slices
-                if (numPostingInt + intPool.Int32Upto > IntBlockPool.INT_BLOCK_SIZE)
+                if (numPostingInt + intPool.Int32Upto > Int32BlockPool.INT_BLOCK_SIZE)
                 {
                     intPool.NextBuffer();
                 }
@@ -264,8 +264,8 @@ namespace Lucene.Net.Index
             {
                 termID = (-termID) - 1;
                 int intStart = postingsArray.intStarts[termID];
-                intUptos = intPool.Buffers[intStart >> IntBlockPool.INT_BLOCK_SHIFT];
-                intUptoStart = intStart & IntBlockPool.INT_BLOCK_MASK;
+                intUptos = intPool.Buffers[intStart >> Int32BlockPool.INT_BLOCK_SHIFT];
+                intUptoStart = intStart & Int32BlockPool.INT_BLOCK_MASK;
                 consumer.AddTerm(termID);
             }
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Index/TrackingIndexWriter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Index/TrackingIndexWriter.cs b/src/Lucene.Net.Core/Index/TrackingIndexWriter.cs
index 9b0d8e5..679bc63 100644
--- a/src/Lucene.Net.Core/Index/TrackingIndexWriter.cs
+++ b/src/Lucene.Net.Core/Index/TrackingIndexWriter.cs
@@ -41,7 +41,7 @@ namespace Lucene.Net.Index
     public class TrackingIndexWriter
     {
         private readonly IndexWriter writer;
-        private readonly AtomicLong indexingGen = new AtomicLong(1);
+        private readonly AtomicInt64 indexingGen = new AtomicInt64(1);
 
         /// <summary>
         /// Create a {@code TrackingIndexWriter} wrapping the

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Search/DocTermOrdsRewriteMethod.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Search/DocTermOrdsRewriteMethod.cs b/src/Lucene.Net.Core/Search/DocTermOrdsRewriteMethod.cs
index 5392ea2..bd79c34 100644
--- a/src/Lucene.Net.Core/Search/DocTermOrdsRewriteMethod.cs
+++ b/src/Lucene.Net.Core/Search/DocTermOrdsRewriteMethod.cs
@@ -24,7 +24,7 @@ namespace Lucene.Net.Search
     using IBits = Lucene.Net.Util.IBits;
     using BytesRef = Lucene.Net.Util.BytesRef;
     using IndexReader = Lucene.Net.Index.IndexReader;
-    using LongBitSet = Lucene.Net.Util.LongBitSet;
+    using Int64BitSet = Lucene.Net.Util.Int64BitSet;
     using SortedSetDocValues = Lucene.Net.Index.SortedSetDocValues;
     using Terms = Lucene.Net.Index.Terms;
     using TermsEnum = Lucene.Net.Index.TermsEnum;
@@ -102,7 +102,7 @@ namespace Lucene.Net.Search
             {
                 SortedSetDocValues docTermOrds = FieldCache.DEFAULT.GetDocTermOrds((context.AtomicReader), m_query.m_field);
                 // Cannot use FixedBitSet because we require long index (ord):
-                LongBitSet termSet = new LongBitSet(docTermOrds.ValueCount);
+                Int64BitSet termSet = new Int64BitSet(docTermOrds.ValueCount);
                 TermsEnum termsEnum = m_query.GetTermsEnum(new TermsAnonymousInnerClassHelper(this, docTermOrds));
 
                 Debug.Assert(termsEnum != null);
@@ -202,9 +202,9 @@ namespace Lucene.Net.Search
                 private readonly MultiTermQueryDocTermOrdsWrapperFilter outerInstance;
 
                 private SortedSetDocValues docTermOrds;
-                private LongBitSet termSet;
+                private Int64BitSet termSet;
 
-                public FieldCacheDocIdSetAnonymousInnerClassHelper(MultiTermQueryDocTermOrdsWrapperFilter outerInstance, int maxDoc, IBits acceptDocs, SortedSetDocValues docTermOrds, LongBitSet termSet)
+                public FieldCacheDocIdSetAnonymousInnerClassHelper(MultiTermQueryDocTermOrdsWrapperFilter outerInstance, int maxDoc, IBits acceptDocs, SortedSetDocValues docTermOrds, Int64BitSet termSet)
                     : base(maxDoc, acceptDocs)
                 {
                     this.outerInstance = outerInstance;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Search/FieldCache.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Search/FieldCache.cs b/src/Lucene.Net.Core/Search/FieldCache.cs
index ea165c9..4e082ea 100644
--- a/src/Lucene.Net.Core/Search/FieldCache.cs
+++ b/src/Lucene.Net.Core/Search/FieldCache.cs
@@ -98,7 +98,7 @@ namespace Lucene.Net.Search
         /// <exception cref="IOException">  If any error occurs. </exception>
         /// @deprecated (4.4) Index as a numeric field using <seealso cref="IntField"/> and then use <seealso cref="#getInts(AtomicReader, String, boolean)"/> instead.
         [Obsolete("(4.4) Index as a numeric field using Int32Field and then use GetInt32s(AtomicReader, string, bool) instead.")]
-        FieldCache.Shorts GetInt16s(AtomicReader reader, string field, bool setDocsWithField);
+        FieldCache.Int16s GetInt16s(AtomicReader reader, string field, bool setDocsWithField);
 
         /// <summary>
         /// Checks the internal cache for an appropriate entry, and if none is found,
@@ -117,19 +117,19 @@ namespace Lucene.Net.Search
         /// <exception cref="IOException">  If any error occurs. </exception>
         /// @deprecated (4.4) Index as a numeric field using <seealso cref="IntField"/> and then use <seealso cref="#getInts(AtomicReader, String, boolean)"/> instead.
         [Obsolete("(4.4) Index as a numeric field using Int32Field and then use GetInt32s(AtomicReader, string, bool) instead.")]
-        FieldCache.Shorts GetInt16s(AtomicReader reader, string field, FieldCache.IShortParser parser, bool setDocsWithField);
+        FieldCache.Int16s GetInt16s(AtomicReader reader, string field, FieldCache.IInt16Parser parser, bool setDocsWithField);
 
         /// <summary>
-        /// Returns an <seealso cref="FieldCache.Ints"/> over the values found in documents in the given
+        /// Returns an <seealso cref="FieldCache.Int32s"/> over the values found in documents in the given
         /// field.
         /// <para/>
         /// NOTE: this was getInts() in Lucene
         /// </summary>
         /// <seealso cref= #getInts(AtomicReader, String, IntParser, boolean) </seealso>
-        FieldCache.Ints GetInt32s(AtomicReader reader, string field, bool setDocsWithField);
+        FieldCache.Int32s GetInt32s(AtomicReader reader, string field, bool setDocsWithField);
 
         /// <summary>
-        /// Returns an <seealso cref="FieldCache.Ints"/> over the values found in documents in the given
+        /// Returns an <seealso cref="FieldCache.Int32s"/> over the values found in documents in the given
         /// field. If the field was indexed as <seealso cref="NumericDocValuesField"/>, it simply
         /// uses <seealso cref="AtomicReader#getNumericDocValues(String)"/> to read the values.
         /// Otherwise, it checks the internal cache for an appropriate entry, and if
@@ -153,7 +153,7 @@ namespace Lucene.Net.Search
         /// <returns> The values in the given field for each document. </returns>
         /// <exception cref="IOException">
         ///           If any error occurs. </exception>
-        FieldCache.Ints GetInt32s(AtomicReader reader, string field, FieldCache.IIntParser parser, bool setDocsWithField);
+        FieldCache.Int32s GetInt32s(AtomicReader reader, string field, FieldCache.IInt32Parser parser, bool setDocsWithField);
 
         /// <summary>
         /// Returns a <seealso cref="Floats"/> over the values found in documents in the given
@@ -162,7 +162,7 @@ namespace Lucene.Net.Search
         /// NOTE: this was getFloats() in Lucene
         /// </summary>
         /// <seealso cref= #getFloats(AtomicReader, String, FloatParser, boolean) </seealso>
-        FieldCache.Floats GetSingles(AtomicReader reader, string field, bool setDocsWithField);
+        FieldCache.Singles GetSingles(AtomicReader reader, string field, bool setDocsWithField);
 
         /// <summary>
         /// Returns a <seealso cref="Floats"/> over the values found in documents in the given
@@ -189,7 +189,7 @@ namespace Lucene.Net.Search
         /// <returns> The values in the given field for each document. </returns>
         /// <exception cref="IOException">
         ///           If any error occurs. </exception>
-        FieldCache.Floats GetSingles(AtomicReader reader, string field, FieldCache.IFloatParser parser, bool setDocsWithField);
+        FieldCache.Singles GetSingles(AtomicReader reader, string field, FieldCache.ISingleParser parser, bool setDocsWithField);
 
         /// <summary>
         /// Returns a <seealso cref="Longs"/> over the values found in documents in the given
@@ -198,7 +198,7 @@ namespace Lucene.Net.Search
         /// NOTE: this was getLongs() in Lucene
         /// </summary>
         /// <seealso cref= #getLongs(AtomicReader, String, LongParser, boolean) </seealso>
-        FieldCache.Longs GetInt64s(AtomicReader reader, string field, bool setDocsWithField);
+        FieldCache.Int64s GetInt64s(AtomicReader reader, string field, bool setDocsWithField);
 
         /// <summary>
         /// Returns a <seealso cref="Longs"/> over the values found in documents in the given
@@ -225,7 +225,7 @@ namespace Lucene.Net.Search
         /// <returns> The values in the given field for each document. </returns>
         /// <exception cref="IOException">
         ///           If any error occurs. </exception>
-        FieldCache.Longs GetInt64s(AtomicReader reader, string field, FieldCache.ILongParser parser, bool setDocsWithField);
+        FieldCache.Int64s GetInt64s(AtomicReader reader, string field, FieldCache.IInt64Parser parser, bool setDocsWithField);
 
         /// <summary>
         /// Returns a <seealso cref="Doubles"/> over the values found in documents in the given
@@ -383,13 +383,19 @@ namespace Lucene.Net.Search
             }
         }
 
-        public abstract class Shorts // LUCENENET TODO: Rename Int16s
+        /// <summary>
+        /// NOTE: This was Shorts in Lucene
+        /// </summary>
+        public abstract class Int16s
         {
             public abstract short Get(int docID);
 
-            public static readonly Shorts EMPTY = new EmptyShorts();
+            public static readonly Int16s EMPTY = new EmptyInt16s();
 
-            public sealed class EmptyShorts : Shorts // LUCENENET TODO: Rename EmptyInt16s
+            /// <summary>
+            /// NOTE: This was EmptyShorts in Lucene
+            /// </summary>
+            public sealed class EmptyInt16s : Int16s
             {
                 public override short Get(int docID)
                 {
@@ -398,13 +404,19 @@ namespace Lucene.Net.Search
             }
         }
 
-        public abstract class Ints // LUCENENET TODO: Rename Int32s
+        /// <summary>
+        /// NOTE: This was Ints in Lucene
+        /// </summary>
+        public abstract class Int32s
         {
             public abstract int Get(int docID);
 
-            public static readonly Ints EMPTY = new EmptyInts();
+            public static readonly Int32s EMPTY = new EmptyInt32s();
 
-            public sealed class EmptyInts : Ints // LUCENENET TODO: Rename EmptyInt32s
+            /// <summary>
+            /// NOTE: This was EmptyInts in Lucene
+            /// </summary>
+            public sealed class EmptyInt32s : Int32s
             {
                 public override int Get(int docID)
                 {
@@ -413,13 +425,19 @@ namespace Lucene.Net.Search
             }
         }
 
-        public abstract class Longs // LUCENENET TODO: Rename Int64s
+        /// <summary>
+        /// NOTE: This was Longs in Lucene
+        /// </summary>
+        public abstract class Int64s
         {
             public abstract long Get(int docID);
 
-            public static readonly Longs EMPTY = new EmptyLongs();
+            public static readonly Int64s EMPTY = new EmptyInt64s();
 
-            public sealed class EmptyLongs : Longs // LUCENENET TODO: Rename EmptyInt64s
+            /// <summary>
+            /// NOTE: This was EmptyLongs in Lucene
+            /// </summary>
+            public sealed class EmptyInt64s : Int64s
             {
                 public override long Get(int docID)
                 {
@@ -428,13 +446,19 @@ namespace Lucene.Net.Search
             }
         }
 
-        public abstract class Floats // LUCENENET TODO: Rename Singles
+        /// <summary>
+        /// NOTE: This was Floats in Lucene
+        /// </summary>
+        public abstract class Singles
         {
             public abstract float Get(int docID);
 
-            public static readonly Floats EMPTY = new EmptyFloats();
+            public static readonly Singles EMPTY = new EmptySingles();
 
-            public sealed class EmptyFloats : Floats // LUCENENET TODO: Rename EmptySingles
+            /// <summary>
+            /// NOTE: This was EmptySingles in Lucene
+            /// </summary>
+            public sealed class EmptySingles : Singles
             {
                 public override float Get(int docID)
                 {
@@ -473,7 +497,10 @@ namespace Lucene.Net.Search
             sbyte ParseByte(BytesRef term); // LUCENENET TODO: can this be byte?
         }
 
-        public interface IShortParser : IParser // LUCENENET TODO: Rename IInt16Parser
+        /// <summary>
+        /// NOTE: This was ShortParser in Lucene
+        /// </summary>
+        public interface IInt16Parser : IParser
         {
             /// <summary>
             /// NOTE: This was parseShort() in Lucene
@@ -481,7 +508,10 @@ namespace Lucene.Net.Search
             short ParseInt16(BytesRef term);
         }
 
-        public interface IIntParser : IParser // LUCENENET TODO: Rename IInt32Parser
+        /// <summary>
+        /// NOTE: This was IntParser in Lucene
+        /// </summary>
+        public interface IInt32Parser : IParser
         {
             /// <summary>
             /// NOTE: This was parseInt() in Lucene
@@ -489,7 +519,10 @@ namespace Lucene.Net.Search
             int ParseInt32(BytesRef term);
         }
 
-        public interface IFloatParser : IParser // LUCENENET TODO: Rename ISingleParser
+        /// <summary>
+        /// NOTE: This was FloatParser in Lucene
+        /// </summary>
+        public interface ISingleParser : IParser
         {
             /// <summary>
             /// NOTE: This was parseFloat() in Lucene
@@ -497,7 +530,10 @@ namespace Lucene.Net.Search
             float ParseSingle(BytesRef term);
         }
 
-        public interface ILongParser : IParser // LUCENENET TODO: Rename IInt64Parser
+        /// <summary>
+        /// NOTE: This was LongParser in Lucene
+        /// </summary>
+        public interface IInt64Parser : IParser
         {
             /// <summary>
             /// NOTE: This was parseLong() in Lucene
@@ -536,9 +572,10 @@ namespace Lucene.Net.Search
             }
         }
 
-        public static readonly IShortParser DEFAULT_SHORT_PARSER = new AnonymousShortParser(); // LUCENENET TODO: Rename DEFAULT_INT16_PARSER
+        public static readonly IInt16Parser DEFAULT_SHORT_PARSER = new AnonymousInt16Parser(); // LUCENENET TODO: Rename DEFAULT_INT16_PARSER
+
 
-        private sealed class AnonymousShortParser : IShortParser
+        private sealed class AnonymousInt16Parser : IInt16Parser
         {
             /// <summary>
             /// NOTE: This was parseShort() in Lucene
@@ -563,9 +600,9 @@ namespace Lucene.Net.Search
             }
         }
 
-        public static readonly IIntParser DEFAULT_INT_PARSER = new AnonymousIntParser(); // LUCENENET TODO: Rename DEFAULT_INT32_PARSER
+        public static readonly IInt32Parser DEFAULT_INT_PARSER = new AnonymousInt32Parser(); // LUCENENET TODO: Rename DEFAULT_INT32_PARSER
 
-        private sealed class AnonymousIntParser : IIntParser
+        private sealed class AnonymousInt32Parser : IInt32Parser
         {
             /// <summary>
             /// NOTE: This was parseInt() in Lucene
@@ -590,9 +627,9 @@ namespace Lucene.Net.Search
             }
         }
 
-        public static readonly IFloatParser DEFAULT_FLOAT_PARSER = new AnonymousFloatParser();  // LUCENENET TODO: Rename DEFAULT_SINGLE_PARSER
+        public static readonly ISingleParser DEFAULT_FLOAT_PARSER = new AnonymousSingleParser();  // LUCENENET TODO: Rename DEFAULT_SINGLE_PARSER
 
-        private sealed class AnonymousFloatParser : IFloatParser
+        private sealed class AnonymousSingleParser : ISingleParser
         {
             /// <summary>
             /// NOTE: This was parseFloat() in Lucene
@@ -621,9 +658,9 @@ namespace Lucene.Net.Search
             }
         }
 
-        public static readonly ILongParser DEFAULT_LONG_PARSER = new AnonymousLongParser(); // LUCENENET TODO: Rename DEFAULT_INT64_PARSER
+        public static readonly IInt64Parser DEFAULT_LONG_PARSER = new AnonymousInt64Parser(); // LUCENENET TODO: Rename DEFAULT_INT64_PARSER
 
-        private sealed class AnonymousLongParser : ILongParser
+        private sealed class AnonymousInt64Parser : IInt64Parser
         {
             /// <summary>
             /// NOTE: This was parseLong() in Lucene
@@ -672,9 +709,9 @@ namespace Lucene.Net.Search
             }
         }
 
-        public static readonly IIntParser NUMERIC_UTILS_INT_PARSER = new AnonymousNumericUtilsIntParser();
+        public static readonly IInt32Parser NUMERIC_UTILS_INT_PARSER = new AnonymousNumericUtilsInt32Parser(); // LUCENENET TODO: Rename NUMERIC_UTILS_INT32_PARSER
 
-        private sealed class AnonymousNumericUtilsIntParser : IIntParser
+        private sealed class AnonymousNumericUtilsInt32Parser : IInt32Parser
         {
             /// <summary>
             /// NOTE: This was parseInt() in Lucene
@@ -695,9 +732,9 @@ namespace Lucene.Net.Search
             }
         }
 
-        public static readonly IFloatParser NUMERIC_UTILS_FLOAT_PARSER = new AnonymousNumericUtilsFloatParser();
+        public static readonly ISingleParser NUMERIC_UTILS_FLOAT_PARSER = new AnonymousNumericUtilsSingleParser(); // LUCENENET TODO: Rename NUMERIC_UTILS_SINGLE_PARSER
 
-        private sealed class AnonymousNumericUtilsFloatParser : IFloatParser
+        private sealed class AnonymousNumericUtilsSingleParser : ISingleParser
         {
             /// <summary>
             /// NOTE: This was parseFloat() in Lucene
@@ -718,9 +755,9 @@ namespace Lucene.Net.Search
             }
         }
 
-        public static readonly ILongParser NUMERIC_UTILS_LONG_PARSER = new AnonymousNumericUtilsLongParser();
+        public static readonly IInt64Parser NUMERIC_UTILS_LONG_PARSER = new AnonymousNumericUtilsInt64Parser(); // LUCENENET TODO: Rename NUMERIC_UTILS_INT64_PARSER
 
-        private sealed class AnonymousNumericUtilsLongParser : ILongParser
+        private sealed class AnonymousNumericUtilsInt64Parser : IInt64Parser
         {
             /// <summary>
             /// NOTE: This was parseLong() in Lucene


[31/53] [abbrv] lucenenet git commit: Lucene.Net.Analysis.Common: Renamed all type-derived classes and interfaces from Short, Int, Long, and Float to match CLR types Int16, Int32, Int64, and Single, respectively.

Posted by ni...@apache.org.
Lucene.Net.Analysis.Common: Renamed all type-derived classes and interfaces from Short, Int, Long, and Float to match CLR types Int16, Int32, Int64, and Single, respectively.


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

Branch: refs/heads/api-work
Commit: 0ff79884cb1d74ac48348ec2eb47c25e8444de5a
Parents: 8b7f418
Author: Shad Storhaug <sh...@shadstorhaug.com>
Authored: Wed Feb 8 02:22:33 2017 +0700
Committer: Shad Storhaug <sh...@shadstorhaug.com>
Committed: Wed Feb 8 21:08:22 2017 +0700

----------------------------------------------------------------------
 .../Analysis/Payloads/DelimitedPayloadTokenFilterFactory.cs      | 2 +-
 src/Lucene.Net.Analysis.Common/Analysis/Payloads/FloatEncoder.cs | 4 +++-
 .../Analysis/Payloads/DelimitedPayloadTokenFilterTest.cs         | 2 +-
 3 files changed, 5 insertions(+), 3 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/lucenenet/blob/0ff79884/src/Lucene.Net.Analysis.Common/Analysis/Payloads/DelimitedPayloadTokenFilterFactory.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Analysis.Common/Analysis/Payloads/DelimitedPayloadTokenFilterFactory.cs b/src/Lucene.Net.Analysis.Common/Analysis/Payloads/DelimitedPayloadTokenFilterFactory.cs
index 429e9a8..20a85ea 100644
--- a/src/Lucene.Net.Analysis.Common/Analysis/Payloads/DelimitedPayloadTokenFilterFactory.cs
+++ b/src/Lucene.Net.Analysis.Common/Analysis/Payloads/DelimitedPayloadTokenFilterFactory.cs
@@ -62,7 +62,7 @@ namespace Lucene.Net.Analysis.Payloads
         {
             if (encoderClass.Equals("float"))
             {
-                encoder = new FloatEncoder();
+                encoder = new SingleEncoder();
             }
             else if (encoderClass.Equals("integer"))
             {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/0ff79884/src/Lucene.Net.Analysis.Common/Analysis/Payloads/FloatEncoder.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Analysis.Common/Analysis/Payloads/FloatEncoder.cs b/src/Lucene.Net.Analysis.Common/Analysis/Payloads/FloatEncoder.cs
index 9e451e7..4810d9d 100644
--- a/src/Lucene.Net.Analysis.Common/Analysis/Payloads/FloatEncoder.cs
+++ b/src/Lucene.Net.Analysis.Common/Analysis/Payloads/FloatEncoder.cs
@@ -22,9 +22,11 @@ namespace Lucene.Net.Analysis.Payloads
 
     /// <summary>
     /// Encode a character array <see cref="float"/> as a <see cref="BytesRef"/>.
+    /// <para/>
+    /// NOTE: This was FloatEncoder in Lucene
     /// </summary>
     /// <seealso cref="PayloadHelper.EncodeSingle(float, byte[], int)"/>
-    public class FloatEncoder : AbstractEncoder, IPayloadEncoder
+    public class SingleEncoder : AbstractEncoder, IPayloadEncoder
     {
         public override BytesRef Encode(char[] buffer, int offset, int length)
         {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/0ff79884/src/Lucene.Net.Tests.Analysis.Common/Analysis/Payloads/DelimitedPayloadTokenFilterTest.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests.Analysis.Common/Analysis/Payloads/DelimitedPayloadTokenFilterTest.cs b/src/Lucene.Net.Tests.Analysis.Common/Analysis/Payloads/DelimitedPayloadTokenFilterTest.cs
index f5681f0..5a66ae9 100644
--- a/src/Lucene.Net.Tests.Analysis.Common/Analysis/Payloads/DelimitedPayloadTokenFilterTest.cs
+++ b/src/Lucene.Net.Tests.Analysis.Common/Analysis/Payloads/DelimitedPayloadTokenFilterTest.cs
@@ -76,7 +76,7 @@ namespace Lucene.Net.Analysis.Payloads
         public virtual void TestFloatEncoding()
         {
             string test = "The quick|1.0 red|2.0 fox|3.5 jumped|0.5 over the lazy|5 brown|99.3 dogs|83.7";
-            DelimitedPayloadTokenFilter filter = new DelimitedPayloadTokenFilter(new MockTokenizer(new StringReader(test), MockTokenizer.WHITESPACE, false), '|', new FloatEncoder());
+            DelimitedPayloadTokenFilter filter = new DelimitedPayloadTokenFilter(new MockTokenizer(new StringReader(test), MockTokenizer.WHITESPACE, false), '|', new SingleEncoder());
             ICharTermAttribute termAtt = filter.GetAttribute<ICharTermAttribute>();
             IPayloadAttribute payAtt = filter.GetAttribute<IPayloadAttribute>();
             filter.Reset();


[03/53] [abbrv] lucenenet git commit: Lucene.Net.Core: Renamed all type-derived properties and methods from Short, Int, Long, and Float to match CLR types Int16, Int32, Int64, and Single, respectively.

Posted by ni...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Tests.Facet/Range/TestRangeFacetCounts.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests.Facet/Range/TestRangeFacetCounts.cs b/src/Lucene.Net.Tests.Facet/Range/TestRangeFacetCounts.cs
index e602ed8..14060c2 100644
--- a/src/Lucene.Net.Tests.Facet/Range/TestRangeFacetCounts.cs
+++ b/src/Lucene.Net.Tests.Facet/Range/TestRangeFacetCounts.cs
@@ -274,7 +274,7 @@ namespace Lucene.Net.Facet.Range
 
             // Third search, drill down on "less than or equal to 10":
             ddq = new DrillDownQuery(config);
-            ddq.Add("field", NumericRangeQuery.NewLongRange("field", 0L, 10L, true, true));
+            ddq.Add("field", NumericRangeQuery.NewInt64Range("field", 0L, 10L, true, true));
             dsr = ds.Search(null, ddq, 10);
 
             Assert.AreEqual(11, dsr.Hits.TotalHits);
@@ -522,11 +522,11 @@ namespace Lucene.Net.Facet.Range
                 {
                     if (Random().NextBoolean())
                     {
-                        fastMatchFilter = NumericRangeFilter.NewLongRange("field", minValue, maxValue, true, true);
+                        fastMatchFilter = NumericRangeFilter.NewInt64Range("field", minValue, maxValue, true, true);
                     }
                     else
                     {
-                        fastMatchFilter = NumericRangeFilter.NewLongRange("field", minAcceptedValue, maxAcceptedValue, true, true);
+                        fastMatchFilter = NumericRangeFilter.NewInt64Range("field", minAcceptedValue, maxAcceptedValue, true, true);
                     }
                 }
                 else
@@ -555,11 +555,11 @@ namespace Lucene.Net.Facet.Range
                     {
                         if (Random().NextBoolean())
                         {
-                            ddq.Add("field", NumericRangeFilter.NewLongRange("field", range.Min, range.Max, range.MinInclusive, range.MaxInclusive));
+                            ddq.Add("field", NumericRangeFilter.NewInt64Range("field", range.Min, range.Max, range.MinInclusive, range.MaxInclusive));
                         }
                         else
                         {
-                            ddq.Add("field", NumericRangeQuery.NewLongRange("field", range.Min, range.Max, range.MinInclusive, range.MaxInclusive));
+                            ddq.Add("field", NumericRangeQuery.NewInt64Range("field", range.Min, range.Max, range.MinInclusive, range.MaxInclusive));
                         }
                     }
                     else
@@ -727,11 +727,11 @@ namespace Lucene.Net.Facet.Range
                 {
                     if (Random().NextBoolean())
                     {
-                        fastMatchFilter = NumericRangeFilter.NewFloatRange("field", minValue, maxValue, true, true);
+                        fastMatchFilter = NumericRangeFilter.NewSingleRange("field", minValue, maxValue, true, true);
                     }
                     else
                     {
-                        fastMatchFilter = NumericRangeFilter.NewFloatRange("field", minAcceptedValue, maxAcceptedValue, true, true);
+                        fastMatchFilter = NumericRangeFilter.NewSingleRange("field", minAcceptedValue, maxAcceptedValue, true, true);
                     }
                 }
                 else
@@ -760,11 +760,11 @@ namespace Lucene.Net.Facet.Range
                     {
                         if (Random().NextBoolean())
                         {
-                            ddq.Add("field", NumericRangeFilter.NewFloatRange("field", (float)range.Min, (float)range.Max, range.MinInclusive, range.MaxInclusive));
+                            ddq.Add("field", NumericRangeFilter.NewSingleRange("field", (float)range.Min, (float)range.Max, range.MinInclusive, range.MaxInclusive));
                         }
                         else
                         {
-                            ddq.Add("field", NumericRangeQuery.NewFloatRange("field", (float)range.Min, (float)range.Max, range.MinInclusive, range.MaxInclusive));
+                            ddq.Add("field", NumericRangeQuery.NewSingleRange("field", (float)range.Min, (float)range.Max, range.MinInclusive, range.MaxInclusive));
                         }
                     }
                     else

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Tests.Grouping/AllGroupHeadsCollectorTest.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests.Grouping/AllGroupHeadsCollectorTest.cs b/src/Lucene.Net.Tests.Grouping/AllGroupHeadsCollectorTest.cs
index 1b7bc7a..1835309 100644
--- a/src/Lucene.Net.Tests.Grouping/AllGroupHeadsCollectorTest.cs
+++ b/src/Lucene.Net.Tests.Grouping/AllGroupHeadsCollectorTest.cs
@@ -312,7 +312,7 @@ namespace Lucene.Net.Search.Grouping
                 w.Dispose();
 
                 // NOTE: intentional but temporary field cache insanity!
-                FieldCache.Ints docIdToFieldId = FieldCache.DEFAULT.GetInts(SlowCompositeReaderWrapper.Wrap(r), "id", false);
+                FieldCache.Ints docIdToFieldId = FieldCache.DEFAULT.GetInt32s(SlowCompositeReaderWrapper.Wrap(r), "id", false);
                 int[] fieldIdToDocID = new int[numDocs];
                 for (int i = 0; i < numDocs; i++)
                 {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Tests.Grouping/TestGrouping.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests.Grouping/TestGrouping.cs b/src/Lucene.Net.Tests.Grouping/TestGrouping.cs
index 8a77f2e..b22e46d 100644
--- a/src/Lucene.Net.Tests.Grouping/TestGrouping.cs
+++ b/src/Lucene.Net.Tests.Grouping/TestGrouping.cs
@@ -900,7 +900,7 @@ namespace Lucene.Net.Search.Grouping
                 w.Dispose();
 
                 // NOTE: intentional but temporary field cache insanity!
-                FieldCache.Ints docIDToID = FieldCache.DEFAULT.GetInts(SlowCompositeReaderWrapper.Wrap(r), "id", false);
+                FieldCache.Ints docIDToID = FieldCache.DEFAULT.GetInt32s(SlowCompositeReaderWrapper.Wrap(r), "id", false);
                 DirectoryReader rBlocks = null;
                 Directory dirBlocks = null;
 
@@ -944,7 +944,7 @@ namespace Lucene.Net.Search.Grouping
                     dirBlocks = NewDirectory();
                     rBlocks = GetDocBlockReader(dirBlocks, groupDocs);
                     Filter lastDocInBlock = new CachingWrapperFilter(new QueryWrapperFilter(new TermQuery(new Term("groupend", "x"))));
-                    FieldCache.Ints docIDToIDBlocks = FieldCache.DEFAULT.GetInts(SlowCompositeReaderWrapper.Wrap(rBlocks), "id", false);
+                    FieldCache.Ints docIDToIDBlocks = FieldCache.DEFAULT.GetInt32s(SlowCompositeReaderWrapper.Wrap(rBlocks), "id", false);
 
                     IndexSearcher sBlocks = NewSearcher(rBlocks);
                     ShardState shardsBlocks = new ShardState(sBlocks);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Tests.Highlighter/Highlight/HighlighterTest.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests.Highlighter/Highlight/HighlighterTest.cs b/src/Lucene.Net.Tests.Highlighter/Highlight/HighlighterTest.cs
index d9e7347..84d00a8 100644
--- a/src/Lucene.Net.Tests.Highlighter/Highlight/HighlighterTest.cs
+++ b/src/Lucene.Net.Tests.Highlighter/Highlight/HighlighterTest.cs
@@ -502,7 +502,7 @@ namespace Lucene.Net.Search.Highlight
         public void TestNumericRangeQuery()
         {
             // doesn't currently highlight, but make sure it doesn't cause exception either
-            query = NumericRangeQuery.NewIntRange(NUMERIC_FIELD_NAME, 2, 6, true, true);
+            query = NumericRangeQuery.NewInt32Range(NUMERIC_FIELD_NAME, 2, 6, true, true);
             searcher = NewSearcher(reader);
             hits = searcher.Search(query, 100);
             int maxNumFragmentsRequired = 2;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Tests.Join/TestBlockJoin.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests.Join/TestBlockJoin.cs b/src/Lucene.Net.Tests.Join/TestBlockJoin.cs
index ba0dfd2..a5f3ce2 100644
--- a/src/Lucene.Net.Tests.Join/TestBlockJoin.cs
+++ b/src/Lucene.Net.Tests.Join/TestBlockJoin.cs
@@ -103,7 +103,7 @@ namespace Lucene.Net.Tests.Join
 
             BooleanQuery childQuery = new BooleanQuery();
             childQuery.Add(new BooleanClause(new TermQuery(new Term("skill", "java")), Occur.MUST));
-            childQuery.Add(new BooleanClause(NumericRangeQuery.NewIntRange("year", 2006, 2011, true, true), Occur.MUST));
+            childQuery.Add(new BooleanClause(NumericRangeQuery.NewInt32Range("year", 2006, 2011, true, true), Occur.MUST));
 
             ToParentBlockJoinQuery childJoinQuery = new ToParentBlockJoinQuery(childQuery, parentsFilter, ScoreMode.Avg);
 
@@ -156,7 +156,7 @@ namespace Lucene.Net.Tests.Join
             // Define child document criteria (finds an example of relevant work experience)
             BooleanQuery childQuery = new BooleanQuery();
             childQuery.Add(new BooleanClause(new TermQuery(new Term("skill", "java")), Occur.MUST));
-            childQuery.Add(new BooleanClause(NumericRangeQuery.NewIntRange("year", 2006, 2011, true, true), Occur.MUST));
+            childQuery.Add(new BooleanClause(NumericRangeQuery.NewInt32Range("year", 2006, 2011, true, true), Occur.MUST));
 
             // Define parent document criteria (find a resident in the UK)
             Query parentQuery = new TermQuery(new Term("country", "United Kingdom"));
@@ -238,7 +238,7 @@ namespace Lucene.Net.Tests.Join
             w.Dispose();
             IndexSearcher s = NewSearcher(r);
 
-            MultiTermQuery qc = NumericRangeQuery.NewIntRange("year", 2007, 2007, true, true);
+            MultiTermQuery qc = NumericRangeQuery.NewInt32Range("year", 2007, 2007, true, true);
             // Hacky: this causes the query to need 2 rewrite
             // iterations: 
             qc.MultiTermRewriteMethod = MultiTermQuery.CONSTANT_SCORE_BOOLEAN_QUERY_REWRITE;
@@ -312,7 +312,7 @@ namespace Lucene.Net.Tests.Join
             // Define child document criteria (finds an example of relevant work experience)
             BooleanQuery childQuery = new BooleanQuery();
             childQuery.Add(new BooleanClause(new TermQuery(new Term("skill", "java")), Occur.MUST));
-            childQuery.Add(new BooleanClause(NumericRangeQuery.NewIntRange("year", 2006, 2011, true, true), Occur.MUST));
+            childQuery.Add(new BooleanClause(NumericRangeQuery.NewInt32Range("year", 2006, 2011, true, true), Occur.MUST));
 
             // Define parent document criteria (find a resident in the UK)
             Query parentQuery = new TermQuery(new Term("country", "United Kingdom"));
@@ -417,7 +417,7 @@ namespace Lucene.Net.Tests.Join
             w.Commit();
             IndexSearcher s = NewSearcher(DirectoryReader.Open(dir));
 
-            ToParentBlockJoinQuery q = new ToParentBlockJoinQuery(NumericRangeQuery.NewIntRange("year", 1990, 2010, true, true), new FixedBitSetCachingWrapperFilter(new QueryWrapperFilter(new TermQuery(new Term("docType", "resume")))), ScoreMode.Total);
+            ToParentBlockJoinQuery q = new ToParentBlockJoinQuery(NumericRangeQuery.NewInt32Range("year", 1990, 2010, true, true), new FixedBitSetCachingWrapperFilter(new QueryWrapperFilter(new TermQuery(new Term("docType", "resume")))), ScoreMode.Total);
 
             TopDocs topDocs = s.Search(q, 10);
             assertEquals(2, topDocs.TotalHits);
@@ -1145,11 +1145,11 @@ namespace Lucene.Net.Tests.Join
             // Define child document criteria (finds an example of relevant work experience)
             BooleanQuery childJobQuery = new BooleanQuery();
             childJobQuery.Add(new BooleanClause(new TermQuery(new Term("skill", "java")), Occur.MUST));
-            childJobQuery.Add(new BooleanClause(NumericRangeQuery.NewIntRange("year", 2006, 2011, true, true), Occur.MUST));
+            childJobQuery.Add(new BooleanClause(NumericRangeQuery.NewInt32Range("year", 2006, 2011, true, true), Occur.MUST));
 
             BooleanQuery childQualificationQuery = new BooleanQuery();
             childQualificationQuery.Add(new BooleanClause(new TermQuery(new Term("qualification", "maths")), Occur.MUST));
-            childQualificationQuery.Add(new BooleanClause(NumericRangeQuery.NewIntRange("year", 1980, 2000, true, true), Occur.MUST));
+            childQualificationQuery.Add(new BooleanClause(NumericRangeQuery.NewInt32Range("year", 1980, 2000, true, true), Occur.MUST));
 
 
             // Define parent document criteria (find a resident in the UK)
@@ -1295,7 +1295,7 @@ namespace Lucene.Net.Tests.Join
             // Define child document criteria (finds an example of relevant work experience)
             BooleanQuery childQuery = new BooleanQuery();
             childQuery.Add(new BooleanClause(new TermQuery(new Term("skill", "java")), Occur.MUST));
-            childQuery.Add(new BooleanClause(NumericRangeQuery.NewIntRange("year", 2006, 2011, true, true), Occur.MUST));
+            childQuery.Add(new BooleanClause(NumericRangeQuery.NewInt32Range("year", 2006, 2011, true, true), Occur.MUST));
 
             // Wrap the child document query to 'join' any matches
             // up to corresponding parent:

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Tests.Misc/Index/Sorter/SorterTestBase.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests.Misc/Index/Sorter/SorterTestBase.cs b/src/Lucene.Net.Tests.Misc/Index/Sorter/SorterTestBase.cs
index e1cbe65..a364e45 100644
--- a/src/Lucene.Net.Tests.Misc/Index/Sorter/SorterTestBase.cs
+++ b/src/Lucene.Net.Tests.Misc/Index/Sorter/SorterTestBase.cs
@@ -49,7 +49,7 @@ namespace Lucene.Net.Index.Sorter
             {
                 if (state.Name.Equals(NORMS_FIELD))
                 {
-                    return Number.FloatToIntBits(state.Boost);
+                    return Number.SingleToInt32Bits(state.Boost);
                 }
                 else
                 {
@@ -156,7 +156,7 @@ namespace Lucene.Net.Index.Sorter
             }
             doc.Add(new NumericDocValuesField(NUMERIC_DV_FIELD, id));
             TextField norms = new TextField(NORMS_FIELD, id.ToString(), Field.Store.NO);
-            norms.Boost = (Number.IntBitsToFloat(id));
+            norms.Boost = (Number.Int32BitsToSingle(id));
             doc.Add(norms);
             doc.Add(new BinaryDocValuesField(BINARY_DV_FIELD, new BytesRef(id.ToString())));
             doc.Add(new SortedDocValuesField(SORTED_DV_FIELD, new BytesRef(id.ToString())));

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Tests.Misc/Util/Fst/TestFSTsMisc.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests.Misc/Util/Fst/TestFSTsMisc.cs b/src/Lucene.Net.Tests.Misc/Util/Fst/TestFSTsMisc.cs
index 41752e0..228b91f 100644
--- a/src/Lucene.Net.Tests.Misc/Util/Fst/TestFSTsMisc.cs
+++ b/src/Lucene.Net.Tests.Misc/Util/Fst/TestFSTsMisc.cs
@@ -181,10 +181,10 @@ namespace Lucene.Net.Util.Fst
             IntsRef scratch = new IntsRef();
             // Add the same input more than once and the outputs
             // are merged:
-            builder.Add(Util.ToIntsRef(new BytesRef("a"), scratch), 1L);
-            builder.Add(Util.ToIntsRef(new BytesRef("a"), scratch), 3L);
-            builder.Add(Util.ToIntsRef(new BytesRef("a"), scratch), 0L);
-            builder.Add(Util.ToIntsRef(new BytesRef("b"), scratch), 17L);
+            builder.Add(Util.ToInt32sRef(new BytesRef("a"), scratch), 1L);
+            builder.Add(Util.ToInt32sRef(new BytesRef("a"), scratch), 3L);
+            builder.Add(Util.ToInt32sRef(new BytesRef("a"), scratch), 0L);
+            builder.Add(Util.ToInt32sRef(new BytesRef("b"), scratch), 17L);
             FST<object> fst = builder.Finish();
 
             object output = Util.Get(fst, new BytesRef("a"));
@@ -215,10 +215,10 @@ namespace Lucene.Net.Util.Fst
             builder.Add(scratch, 17L);
             builder.Add(scratch, 1L);
 
-            builder.Add(Util.ToIntsRef(new BytesRef("a"), scratch), 1L);
-            builder.Add(Util.ToIntsRef(new BytesRef("a"), scratch), 3L);
-            builder.Add(Util.ToIntsRef(new BytesRef("a"), scratch), 0L);
-            builder.Add(Util.ToIntsRef(new BytesRef("b"), scratch), 0L);
+            builder.Add(Util.ToInt32sRef(new BytesRef("a"), scratch), 1L);
+            builder.Add(Util.ToInt32sRef(new BytesRef("a"), scratch), 3L);
+            builder.Add(Util.ToInt32sRef(new BytesRef("a"), scratch), 0L);
+            builder.Add(Util.ToInt32sRef(new BytesRef("b"), scratch), 0L);
 
             FST<object> fst = builder.Finish();
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Tests.Queries/TestCustomScoreQuery.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests.Queries/TestCustomScoreQuery.cs b/src/Lucene.Net.Tests.Queries/TestCustomScoreQuery.cs
index b1d6b82..b188246 100644
--- a/src/Lucene.Net.Tests.Queries/TestCustomScoreQuery.cs
+++ b/src/Lucene.Net.Tests.Queries/TestCustomScoreQuery.cs
@@ -184,7 +184,7 @@ namespace Lucene.Net.Tests.Queries
 
             protected override CustomScoreProvider GetCustomScoreProvider(AtomicReaderContext context)
             {
-                FieldCache.Ints values = FieldCache.DEFAULT.GetInts(context.AtomicReader, INT_FIELD, false);
+                FieldCache.Ints values = FieldCache.DEFAULT.GetInt32s(context.AtomicReader, INT_FIELD, false);
                 return new CustomScoreProviderAnonymousInnerClassHelper(this, context, values);
             }
             

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Tests.Suggest/Suggest/Analyzing/FuzzySuggesterTest.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests.Suggest/Suggest/Analyzing/FuzzySuggesterTest.cs b/src/Lucene.Net.Tests.Suggest/Suggest/Analyzing/FuzzySuggesterTest.cs
index 9690713..d0796d8 100644
--- a/src/Lucene.Net.Tests.Suggest/Suggest/Analyzing/FuzzySuggesterTest.cs
+++ b/src/Lucene.Net.Tests.Suggest/Suggest/Analyzing/FuzzySuggesterTest.cs
@@ -1375,15 +1375,15 @@ namespace Lucene.Net.Search.Suggest.Analyzing
 
             for (j = 1; j <= m; j++)
             {
-                t_j = otherPoints.Ints[j - 1];
+                t_j = otherPoints.Int32s[j - 1];
 
                 for (i = 1; i <= n; i++)
                 {
-                    cost = targetPoints.Ints[i - 1] == t_j ? 0 : 1;
+                    cost = targetPoints.Int32s[i - 1] == t_j ? 0 : 1;
                     // minimum of cell to the left+1, to the top+1, diagonally left and up +cost
                     d[i][j] = Math.Min(Math.Min(d[i - 1][j] + 1, d[i][j - 1] + 1), d[i - 1][j - 1] + cost);
                     // transposition
-                    if (allowTransposition && i > 1 && j > 1 && targetPoints.Ints[i - 1] == otherPoints.Ints[j - 2] && targetPoints.Ints[i - 2] == otherPoints.Ints[j - 1])
+                    if (allowTransposition && i > 1 && j > 1 && targetPoints.Int32s[i - 1] == otherPoints.Int32s[j - 2] && targetPoints.Int32s[i - 2] == otherPoints.Int32s[j - 1])
                     {
                         d[i][j] = Math.Min(d[i][j], d[i - 2][j - 2] + cost);
                     }
@@ -1419,7 +1419,7 @@ namespace Lucene.Net.Search.Suggest.Analyzing
             int utf16Len = s.Length;
             for (int i = 0, cp = 0; i < utf16Len; i += Character.CharCount(cp))
             {
-                cp = @ref.Ints[@ref.Length++] = Character.CodePointAt(s, i);
+                cp = @ref.Int32s[@ref.Length++] = Character.CodePointAt(s, i);
             }
             return @ref;
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Tests/core/Analysis/TestNumericTokenStream.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Analysis/TestNumericTokenStream.cs b/src/Lucene.Net.Tests/core/Analysis/TestNumericTokenStream.cs
index 2e655e7..8c020e4 100644
--- a/src/Lucene.Net.Tests/core/Analysis/TestNumericTokenStream.cs
+++ b/src/Lucene.Net.Tests/core/Analysis/TestNumericTokenStream.cs
@@ -36,7 +36,7 @@ namespace Lucene.Net.Analysis
         [NUnit.Framework.Test]
         public virtual void TestLongStream()
         {
-            using (NumericTokenStream stream = (new NumericTokenStream()).SetLongValue(Lvalue)) {
+            using (NumericTokenStream stream = (new NumericTokenStream()).SetInt64Value(Lvalue)) {
                 // use getAttribute to test if attributes really exist, if not an IAE will be throwed
                 ITermToBytesRefAttribute bytesAtt = stream.GetAttribute<ITermToBytesRefAttribute>();
                 ITypeAttribute typeAtt = stream.GetAttribute<ITypeAttribute>();
@@ -49,7 +49,7 @@ namespace Lucene.Net.Analysis
                     Assert.IsTrue(stream.IncrementToken(), "New token is available");
                     Assert.AreEqual(shift, numericAtt.Shift, "Shift value wrong");
                     bytesAtt.FillBytesRef();
-                    Assert.AreEqual(Lvalue & ~((1L << shift) - 1L), NumericUtils.PrefixCodedToLong(bytes), "Term is incorrectly encoded");
+                    Assert.AreEqual(Lvalue & ~((1L << shift) - 1L), NumericUtils.PrefixCodedToInt64(bytes), "Term is incorrectly encoded");
                     Assert.AreEqual(Lvalue & ~((1L << shift) - 1L), numericAtt.RawValue, "Term raw value is incorrectly encoded");
                     Assert.AreEqual((shift == 0) ? NumericTokenStream.TOKEN_TYPE_FULL_PREC : NumericTokenStream.TOKEN_TYPE_LOWER_PREC, typeAtt.Type, "Type incorrect");
                 }
@@ -61,7 +61,7 @@ namespace Lucene.Net.Analysis
         [NUnit.Framework.Test]
         public virtual void TestIntStream()
         {
-            NumericTokenStream stream = (new NumericTokenStream()).SetIntValue(Ivalue);
+            NumericTokenStream stream = (new NumericTokenStream()).SetInt32Value(Ivalue);
             // use getAttribute to test if attributes really exist, if not an IAE will be throwed
             ITermToBytesRefAttribute bytesAtt = stream.GetAttribute<ITermToBytesRefAttribute>();
             ITypeAttribute typeAtt = stream.GetAttribute<ITypeAttribute>();
@@ -74,7 +74,7 @@ namespace Lucene.Net.Analysis
                 Assert.IsTrue(stream.IncrementToken(), "New token is available");
                 Assert.AreEqual(shift, numericAtt.Shift, "Shift value wrong");
                 bytesAtt.FillBytesRef();
-                Assert.AreEqual(Ivalue & ~((1 << shift) - 1), NumericUtils.PrefixCodedToInt(bytes), "Term is incorrectly encoded");
+                Assert.AreEqual(Ivalue & ~((1 << shift) - 1), NumericUtils.PrefixCodedToInt32(bytes), "Term is incorrectly encoded");
                 Assert.AreEqual(((long)Ivalue) & ~((1L << shift) - 1L), numericAtt.RawValue, "Term raw value is incorrectly encoded");
                 Assert.AreEqual((shift == 0) ? NumericTokenStream.TOKEN_TYPE_FULL_PREC : NumericTokenStream.TOKEN_TYPE_LOWER_PREC, typeAtt.Type, "Type incorrect");
             }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Tests/core/Document/TestField.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Document/TestField.cs b/src/Lucene.Net.Tests/core/Document/TestField.cs
index 105384c..c278fbf 100644
--- a/src/Lucene.Net.Tests/core/Document/TestField.cs
+++ b/src/Lucene.Net.Tests/core/Document/TestField.cs
@@ -95,7 +95,7 @@ namespace Lucene.Net.Documents
             TrySetStringValue(field);
             TrySetTokenStreamValue(field);
 
-            Assert.AreEqual(6f, Number.IntBitsToFloat(Convert.ToInt32(field.GetNumericValue())), 0.0f);
+            Assert.AreEqual(6f, Number.Int32BitsToSingle(Convert.ToInt32(field.GetNumericValue())), 0.0f);
         }
 
         [Test]

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Tests/core/Index/Test2BBinaryDocValues.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Index/Test2BBinaryDocValues.cs b/src/Lucene.Net.Tests/core/Index/Test2BBinaryDocValues.cs
index 10c1dd4..e7bc021 100644
--- a/src/Lucene.Net.Tests/core/Index/Test2BBinaryDocValues.cs
+++ b/src/Lucene.Net.Tests/core/Index/Test2BBinaryDocValues.cs
@@ -130,7 +130,7 @@ namespace Lucene.Net.Index
             for (int i = 0; i < int.MaxValue; i++)
             {
                 encoder.Reset(bytes);
-                encoder.WriteVInt(i % 65535); // 1, 2, or 3 bytes
+                encoder.WriteVInt32(i % 65535); // 1, 2, or 3 bytes
                 data.Length = encoder.Position;
                 w.AddDocument(doc);
                 if (i % 100000 == 0)
@@ -158,7 +158,7 @@ namespace Lucene.Net.Index
                 {
                     dv.Get(i, scratch);
                     input.Reset((byte[])(Array)scratch.Bytes, scratch.Offset, scratch.Length);
-                    Assert.AreEqual(expectedValue % 65535, input.ReadVInt());
+                    Assert.AreEqual(expectedValue % 65535, input.ReadVInt32());
                     Assert.IsTrue(input.Eof);
                     expectedValue++;
                 }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Tests/core/Index/TestAllFilesHaveCodecHeader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Index/TestAllFilesHaveCodecHeader.cs b/src/Lucene.Net.Tests/core/Index/TestAllFilesHaveCodecHeader.cs
index 9e52d00..2fbaa40 100644
--- a/src/Lucene.Net.Tests/core/Index/TestAllFilesHaveCodecHeader.cs
+++ b/src/Lucene.Net.Tests/core/Index/TestAllFilesHaveCodecHeader.cs
@@ -98,7 +98,7 @@ namespace Lucene.Net.Index
                 try
                 {
                     @in = dir.OpenInput(file, NewIOContext(Random()));
-                    int val = @in.ReadInt();
+                    int val = @in.ReadInt32();
                     Assert.AreEqual(CodecUtil.CODEC_MAGIC, val, file + " has no codec header, instead found: " + val);
                     success = true;
                 }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Tests/core/Index/TestBackwardsCompatibility.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Index/TestBackwardsCompatibility.cs b/src/Lucene.Net.Tests/core/Index/TestBackwardsCompatibility.cs
index 598782f..5183860 100644
--- a/src/Lucene.Net.Tests/core/Index/TestBackwardsCompatibility.cs
+++ b/src/Lucene.Net.Tests/core/Index/TestBackwardsCompatibility.cs
@@ -531,7 +531,7 @@ namespace Lucene.Net.Index
                     Assert.AreEqual(expectedRef, scratch);
 
                     Assert.AreEqual((double)id, BitConverter.Int64BitsToDouble(dvDouble.Get(i)), 0D);
-                    Assert.AreEqual((float)id, Number.IntBitsToFloat((int)dvFloat.Get(i)), 0F);
+                    Assert.AreEqual((float)id, Number.Int32BitsToSingle((int)dvFloat.Get(i)), 0F);
                     Assert.AreEqual(id, dvInt.Get(i));
                     Assert.AreEqual(id, dvLong.Get(i));
                     Assert.AreEqual(id, dvPacked.Get(i));
@@ -869,26 +869,26 @@ namespace Lucene.Net.Index
 
                 for (int id = 10; id < 15; id++)
                 {
-                    ScoreDoc[] hits = searcher.Search(NumericRangeQuery.NewIntRange("trieInt", 4, Convert.ToInt32(id), Convert.ToInt32(id), true, true), 100).ScoreDocs;
+                    ScoreDoc[] hits = searcher.Search(NumericRangeQuery.NewInt32Range("trieInt", 4, Convert.ToInt32(id), Convert.ToInt32(id), true, true), 100).ScoreDocs;
                     Assert.AreEqual(1, hits.Length, "wrong number of hits");
                     Document d = searcher.Doc(hits[0].Doc);
                     Assert.AreEqual(Convert.ToString(id), d.Get("id"));
 
-                    hits = searcher.Search(NumericRangeQuery.NewLongRange("trieLong", 4, Convert.ToInt64(id), Convert.ToInt64(id), true, true), 100).ScoreDocs;
+                    hits = searcher.Search(NumericRangeQuery.NewInt64Range("trieLong", 4, Convert.ToInt64(id), Convert.ToInt64(id), true, true), 100).ScoreDocs;
                     Assert.AreEqual(1, hits.Length, "wrong number of hits");
                     d = searcher.Doc(hits[0].Doc);
                     Assert.AreEqual(Convert.ToString(id), d.Get("id"));
                 }
 
                 // check that also lower-precision fields are ok
-                ScoreDoc[] hits_ = searcher.Search(NumericRangeQuery.NewIntRange("trieInt", 4, int.MinValue, int.MaxValue, false, false), 100).ScoreDocs;
+                ScoreDoc[] hits_ = searcher.Search(NumericRangeQuery.NewInt32Range("trieInt", 4, int.MinValue, int.MaxValue, false, false), 100).ScoreDocs;
                 Assert.AreEqual(34, hits_.Length, "wrong number of hits");
 
-                hits_ = searcher.Search(NumericRangeQuery.NewLongRange("trieLong", 4, long.MinValue, long.MaxValue, false, false), 100).ScoreDocs;
+                hits_ = searcher.Search(NumericRangeQuery.NewInt64Range("trieLong", 4, long.MinValue, long.MaxValue, false, false), 100).ScoreDocs;
                 Assert.AreEqual(34, hits_.Length, "wrong number of hits");
 
                 // check decoding into field cache
-                FieldCache.Ints fci = FieldCache.DEFAULT.GetInts(SlowCompositeReaderWrapper.Wrap(searcher.IndexReader), "trieInt", false);
+                FieldCache.Ints fci = FieldCache.DEFAULT.GetInt32s(SlowCompositeReaderWrapper.Wrap(searcher.IndexReader), "trieInt", false);
                 int maxDoc = searcher.IndexReader.MaxDoc;
                 for (int doc = 0; doc < maxDoc; doc++)
                 {
@@ -896,7 +896,7 @@ namespace Lucene.Net.Index
                     Assert.IsTrue(val >= 0 && val < 35, "value in id bounds");
                 }
 
-                FieldCache.Longs fcl = FieldCache.DEFAULT.GetLongs(SlowCompositeReaderWrapper.Wrap(searcher.IndexReader), "trieLong", false);
+                FieldCache.Longs fcl = FieldCache.DEFAULT.GetInt64s(SlowCompositeReaderWrapper.Wrap(searcher.IndexReader), "trieLong", false);
                 for (int doc = 0; doc < maxDoc; doc++)
                 {
                     long val = fcl.Get(doc);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Tests/core/Index/TestBackwardsCompatibility3x.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Index/TestBackwardsCompatibility3x.cs b/src/Lucene.Net.Tests/core/Index/TestBackwardsCompatibility3x.cs
index 711ea4d..ba5cd08 100644
--- a/src/Lucene.Net.Tests/core/Index/TestBackwardsCompatibility3x.cs
+++ b/src/Lucene.Net.Tests/core/Index/TestBackwardsCompatibility3x.cs
@@ -497,7 +497,7 @@ namespace Lucene.Net.Index
                     Assert.AreEqual(expectedRef, scratch);
 
                     Assert.AreEqual((double)id, BitConverter.Int64BitsToDouble(dvDouble.Get(i)), 0D);
-                    Assert.AreEqual((float)id, Number.IntBitsToFloat((int)dvFloat.Get(i)), 0F);
+                    Assert.AreEqual((float)id, Number.Int32BitsToSingle((int)dvFloat.Get(i)), 0F);
                     Assert.AreEqual(id, dvInt.Get(i));
                     Assert.AreEqual(id, dvLong.Get(i));
                     Assert.AreEqual(id, dvPacked.Get(i));
@@ -827,26 +827,26 @@ namespace Lucene.Net.Index
 
                 for (int id = 10; id < 15; id++)
                 {
-                    ScoreDoc[] hits = searcher.Search(NumericRangeQuery.NewIntRange("trieInt", 4, Convert.ToInt32(id), Convert.ToInt32(id), true, true), 100).ScoreDocs;
+                    ScoreDoc[] hits = searcher.Search(NumericRangeQuery.NewInt32Range("trieInt", 4, Convert.ToInt32(id), Convert.ToInt32(id), true, true), 100).ScoreDocs;
                     Assert.AreEqual(1, hits.Length, "wrong number of hits");
                     Document d = searcher.Doc(hits[0].Doc);
                     Assert.AreEqual(Convert.ToString(id), d.Get("id"));
 
-                    hits = searcher.Search(NumericRangeQuery.NewLongRange("trieLong", 4, Convert.ToInt64(id), Convert.ToInt64(id), true, true), 100).ScoreDocs;
+                    hits = searcher.Search(NumericRangeQuery.NewInt64Range("trieLong", 4, Convert.ToInt64(id), Convert.ToInt64(id), true, true), 100).ScoreDocs;
                     Assert.AreEqual(1, hits.Length, "wrong number of hits");
                     d = searcher.Doc(hits[0].Doc);
                     Assert.AreEqual(Convert.ToString(id), d.Get("id"));
                 }
 
                 // check that also lower-precision fields are ok
-                ScoreDoc[] hits_ = searcher.Search(NumericRangeQuery.NewIntRange("trieInt", 4, int.MinValue, int.MaxValue, false, false), 100).ScoreDocs;
+                ScoreDoc[] hits_ = searcher.Search(NumericRangeQuery.NewInt32Range("trieInt", 4, int.MinValue, int.MaxValue, false, false), 100).ScoreDocs;
                 Assert.AreEqual(34, hits_.Length, "wrong number of hits");
 
-                hits_ = searcher.Search(NumericRangeQuery.NewLongRange("trieLong", 4, long.MinValue, long.MaxValue, false, false), 100).ScoreDocs;
+                hits_ = searcher.Search(NumericRangeQuery.NewInt64Range("trieLong", 4, long.MinValue, long.MaxValue, false, false), 100).ScoreDocs;
                 Assert.AreEqual(34, hits_.Length, "wrong number of hits");
 
                 // check decoding into field cache
-                FieldCache.Ints fci = FieldCache.DEFAULT.GetInts(SlowCompositeReaderWrapper.Wrap(searcher.IndexReader), "trieInt", false);
+                FieldCache.Ints fci = FieldCache.DEFAULT.GetInt32s(SlowCompositeReaderWrapper.Wrap(searcher.IndexReader), "trieInt", false);
                 int maxDoc = searcher.IndexReader.MaxDoc;
                 for (int doc = 0; doc < maxDoc; doc++)
                 {
@@ -854,7 +854,7 @@ namespace Lucene.Net.Index
                     Assert.IsTrue(val >= 0 && val < 35, "value in id bounds");
                 }
 
-                FieldCache.Longs fcl = FieldCache.DEFAULT.GetLongs(SlowCompositeReaderWrapper.Wrap(searcher.IndexReader), "trieLong", false);
+                FieldCache.Longs fcl = FieldCache.DEFAULT.GetInt64s(SlowCompositeReaderWrapper.Wrap(searcher.IndexReader), "trieLong", false);
                 for (int doc = 0; doc < maxDoc; doc++)
                 {
                     long val = fcl.Get(doc);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Tests/core/Index/TestByteSlices.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Index/TestByteSlices.cs b/src/Lucene.Net.Tests/core/Index/TestByteSlices.cs
index db4c9e0..9869364 100644
--- a/src/Lucene.Net.Tests/core/Index/TestByteSlices.cs
+++ b/src/Lucene.Net.Tests/core/Index/TestByteSlices.cs
@@ -105,8 +105,8 @@ namespace Lucene.Net.Index
                             Console.WriteLine("    write " + (counters[stream] + j));
                         }
                         // write some large (incl. negative) ints:
-                        writer.WriteVInt(Random().Next());
-                        writer.WriteVInt(counters[stream] + j);
+                        writer.WriteVInt32(Random().Next());
+                        writer.WriteVInt32(counters[stream] + j);
                     }
                     counters[stream] += numValue;
                     uptos[stream] = writer.Address;
@@ -128,8 +128,8 @@ namespace Lucene.Net.Index
                         reader.Init(pool, starts[stream], uptos[stream]);
                         for (int j = 0; j < counters[stream]; j++)
                         {
-                            reader.ReadVInt();
-                            Assert.AreEqual(j, reader.ReadVInt());
+                            reader.ReadVInt32();
+                            Assert.AreEqual(j, reader.ReadVInt32());
                         }
                     }
                 }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Tests/core/Index/TestCompoundFile.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Index/TestCompoundFile.cs b/src/Lucene.Net.Tests/core/Index/TestCompoundFile.cs
index c291379..8452701 100644
--- a/src/Lucene.Net.Tests/core/Index/TestCompoundFile.cs
+++ b/src/Lucene.Net.Tests/core/Index/TestCompoundFile.cs
@@ -681,7 +681,7 @@ namespace Lucene.Net.Index
                 IndexOutput os = csw.CreateOutput("seg_" + j + "_foo.txt", NewIOContext(Random()));
                 for (int i = 0; i < size; i++)
                 {
-                    os.WriteInt(i * j);
+                    os.WriteInt32(i * j);
                 }
                 os.Dispose();
                 string[] listAll = newDir.ListAll();
@@ -701,7 +701,7 @@ namespace Lucene.Net.Index
                 Assert.AreEqual(size * 4, openInput.Length);
                 for (int i = 0; i < size; i++)
                 {
-                    Assert.AreEqual(i * j, openInput.ReadInt());
+                    Assert.AreEqual(i * j, openInput.ReadInt32());
                 }
 
                 openInput.Dispose();
@@ -723,7 +723,7 @@ namespace Lucene.Net.Index
             CompoundFileDirectory csw = new CompoundFileDirectory(newDir, "d.cfs", NewIOContext(Random()), true);
             CreateSequenceFile(newDir, "d1", (sbyte)0, 15);
             IndexOutput @out = csw.CreateOutput("d.xyz", NewIOContext(Random()));
-            @out.WriteInt(0);
+            @out.WriteInt32(0);
             @out.Dispose();
             Assert.AreEqual(1, csw.ListAll().Length);
             Assert.AreEqual("d.xyz", csw.ListAll()[0]);
@@ -759,8 +759,8 @@ namespace Lucene.Net.Index
             CompoundFileDirectory nested = new CompoundFileDirectory(newDir, "b.cfs", NewIOContext(Random()), true);
             IndexOutput @out = nested.CreateOutput("b.xyz", NewIOContext(Random()));
             IndexOutput out1 = nested.CreateOutput("b_1.xyz", NewIOContext(Random()));
-            @out.WriteInt(0);
-            out1.WriteInt(1);
+            @out.WriteInt32(0);
+            out1.WriteInt32(1);
             @out.Dispose();
             out1.Dispose();
             nested.Dispose();
@@ -778,10 +778,10 @@ namespace Lucene.Net.Index
 
             Assert.AreEqual(2, nested.ListAll().Length);
             IndexInput openInput = nested.OpenInput("b.xyz", NewIOContext(Random()));
-            Assert.AreEqual(0, openInput.ReadInt());
+            Assert.AreEqual(0, openInput.ReadInt32());
             openInput.Dispose();
             openInput = nested.OpenInput("b_1.xyz", NewIOContext(Random()));
-            Assert.AreEqual(1, openInput.ReadInt());
+            Assert.AreEqual(1, openInput.ReadInt32());
             openInput.Dispose();
             nested.Dispose();
             csw.Dispose();
@@ -794,7 +794,7 @@ namespace Lucene.Net.Index
             Directory newDir = NewDirectory();
             CompoundFileDirectory csw = new CompoundFileDirectory(newDir, "d.cfs", NewIOContext(Random()), true);
             IndexOutput @out = csw.CreateOutput("d.xyz", NewIOContext(Random()));
-            @out.WriteInt(0);
+            @out.WriteInt32(0);
             @out.Dispose();
 
             csw.Dispose();
@@ -803,7 +803,7 @@ namespace Lucene.Net.Index
 
             csw = new CompoundFileDirectory(newDir, "d.cfs", NewIOContext(Random()), false);
             IndexInput openInput = csw.OpenInput("d.xyz", NewIOContext(Random()));
-            Assert.AreEqual(0, openInput.ReadInt());
+            Assert.AreEqual(0, openInput.ReadInt32());
             openInput.Dispose();
             csw.Dispose();
             // close a second time - must have no effect according to IDisposable

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Tests/core/Index/TestCustomNorms.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Index/TestCustomNorms.cs b/src/Lucene.Net.Tests/core/Index/TestCustomNorms.cs
index 6865cdb..0db78f9 100644
--- a/src/Lucene.Net.Tests/core/Index/TestCustomNorms.cs
+++ b/src/Lucene.Net.Tests/core/Index/TestCustomNorms.cs
@@ -82,7 +82,7 @@ namespace Lucene.Net.Index
             {
                 Document document = open.Document(i);
                 float expected = Convert.ToSingle(document.Get(FloatTestField));
-                Assert.AreEqual(expected, Number.IntBitsToFloat((int)norms.Get(i)), 0.0f);
+                Assert.AreEqual(expected, Number.Int32BitsToSingle((int)norms.Get(i)), 0.0f);
             }
             open.Dispose();
             dir.Dispose();
@@ -127,7 +127,7 @@ namespace Lucene.Net.Index
         {
             public override long ComputeNorm(FieldInvertState state)
             {
-                return Number.FloatToIntBits(state.Boost);
+                return Number.SingleToInt32Bits(state.Boost);
             }
 
             public override SimWeight ComputeWeight(float queryBoost, CollectionStatistics collectionStats, params TermStatistics[] termStats)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Tests/core/Index/TestDirectoryReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Index/TestDirectoryReader.cs b/src/Lucene.Net.Tests/core/Index/TestDirectoryReader.cs
index ee4a8b6..a0ccdce 100644
--- a/src/Lucene.Net.Tests/core/Index/TestDirectoryReader.cs
+++ b/src/Lucene.Net.Tests/core/Index/TestDirectoryReader.cs
@@ -822,7 +822,7 @@ namespace Lucene.Net.Index
             // Open reader1
             DirectoryReader r = DirectoryReader.Open(dir);
             AtomicReader r1 = GetOnlySegmentReader(r);
-            FieldCache.Ints ints = FieldCache.DEFAULT.GetInts(r1, "number", false);
+            FieldCache.Ints ints = FieldCache.DEFAULT.GetInt32s(r1, "number", false);
             Assert.AreEqual(17, ints.Get(0));
 
             // Add new segment
@@ -834,7 +834,7 @@ namespace Lucene.Net.Index
             Assert.IsNotNull(r2);
             r.Dispose();
             AtomicReader sub0 = (AtomicReader)r2.Leaves[0].Reader;
-            FieldCache.Ints ints2 = FieldCache.DEFAULT.GetInts(sub0, "number", false);
+            FieldCache.Ints ints2 = FieldCache.DEFAULT.GetInt32s(sub0, "number", false);
             r2.Dispose();
             Assert.IsTrue(ints == ints2);
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Tests/core/Index/TestDocTermOrds.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Index/TestDocTermOrds.cs b/src/Lucene.Net.Tests/core/Index/TestDocTermOrds.cs
index 599402b..337c152 100644
--- a/src/Lucene.Net.Tests/core/Index/TestDocTermOrds.cs
+++ b/src/Lucene.Net.Tests/core/Index/TestDocTermOrds.cs
@@ -342,7 +342,7 @@ namespace Lucene.Net.Index
         {
             DocTermOrds dto = new DocTermOrds(r, r.LiveDocs, "field", prefixRef, int.MaxValue, TestUtil.NextInt(Random(), 2, 10));
 
-            FieldCache.Ints docIDToID = FieldCache.DEFAULT.GetInts(r, "id", false);
+            FieldCache.Ints docIDToID = FieldCache.DEFAULT.GetInt32s(r, "id", false);
             /*
               for(int docID=0;docID<subR.MaxDoc;docID++) {
               System.out.println("  docID=" + docID + " id=" + docIDToID[docID]);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Tests/core/Index/TestDocValuesIndexing.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Index/TestDocValuesIndexing.cs b/src/Lucene.Net.Tests/core/Index/TestDocValuesIndexing.cs
index 063aad9..f46110b 100644
--- a/src/Lucene.Net.Tests/core/Index/TestDocValuesIndexing.cs
+++ b/src/Lucene.Net.Tests/core/Index/TestDocValuesIndexing.cs
@@ -123,7 +123,7 @@ namespace Lucene.Net.Index
             w.ForceMerge(1);
             DirectoryReader r = w.Reader;
             w.Dispose();
-            Assert.AreEqual(17, FieldCache.DEFAULT.GetInts(GetOnlySegmentReader(r), "field", false).Get(0));
+            Assert.AreEqual(17, FieldCache.DEFAULT.GetInt32s(GetOnlySegmentReader(r), "field", false).Get(0));
             r.Dispose();
             d.Dispose();
         }
@@ -157,7 +157,7 @@ namespace Lucene.Net.Index
             w.ForceMerge(1);
             DirectoryReader r = w.Reader;
             w.Dispose();
-            Assert.AreEqual(17, FieldCache.DEFAULT.GetInts(GetOnlySegmentReader(r), "field", false).Get(0));
+            Assert.AreEqual(17, FieldCache.DEFAULT.GetInt32s(GetOnlySegmentReader(r), "field", false).Get(0));
             r.Dispose();
             d.Dispose();
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Tests/core/Index/TestDocValuesWithThreads.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Index/TestDocValuesWithThreads.cs b/src/Lucene.Net.Tests/core/Index/TestDocValuesWithThreads.cs
index 8d0ea97..11fa190 100644
--- a/src/Lucene.Net.Tests/core/Index/TestDocValuesWithThreads.cs
+++ b/src/Lucene.Net.Tests/core/Index/TestDocValuesWithThreads.cs
@@ -126,7 +126,7 @@ namespace Lucene.Net.Index
                 try
                 {
                     //NumericDocValues ndv = ar.GetNumericDocValues("number");
-                    FieldCache.Longs ndv = FieldCache.DEFAULT.GetLongs(Ar, "number", false);
+                    FieldCache.Longs ndv = FieldCache.DEFAULT.GetInt64s(Ar, "number", false);
                     //BinaryDocValues bdv = ar.GetBinaryDocValues("bytes");
                     BinaryDocValues bdv = FieldCache.DEFAULT.GetTerms(Ar, "bytes", false);
                     SortedDocValues sdv = FieldCache.DEFAULT.GetTermsIndex(Ar, "sorted");
@@ -145,20 +145,20 @@ namespace Lucene.Net.Index
                                 break;
 
                             case 1:
-                                Assert.AreEqual((long)(short)Numbers[docID], FieldCache.DEFAULT.GetShorts(Ar, "number", false).Get(docID));
+                                Assert.AreEqual((long)(short)Numbers[docID], FieldCache.DEFAULT.GetInt16s(Ar, "number", false).Get(docID));
                                 break;
 #pragma warning restore 612, 618
 
                             case 2:
-                                Assert.AreEqual((long)(int)Numbers[docID], FieldCache.DEFAULT.GetInts(Ar, "number", false).Get(docID));
+                                Assert.AreEqual((long)(int)Numbers[docID], FieldCache.DEFAULT.GetInt32s(Ar, "number", false).Get(docID));
                                 break;
 
                             case 3:
-                                Assert.AreEqual((long)Numbers[docID], FieldCache.DEFAULT.GetLongs(Ar, "number", false).Get(docID));
+                                Assert.AreEqual((long)Numbers[docID], FieldCache.DEFAULT.GetInt64s(Ar, "number", false).Get(docID));
                                 break;
 
                             case 4:
-                                Assert.AreEqual(Number.IntBitsToFloat((int)Numbers[docID]), FieldCache.DEFAULT.GetFloats(Ar, "number", false).Get(docID), 0.0f);
+                                Assert.AreEqual(Number.Int32BitsToSingle((int)Numbers[docID]), FieldCache.DEFAULT.GetSingles(Ar, "number", false).Get(docID), 0.0f);
                                 break;
 
                             case 5:

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Tests/core/Index/TestIndexInput.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Index/TestIndexInput.cs b/src/Lucene.Net.Tests/core/Index/TestIndexInput.cs
index 71357ac..32cd6a5 100644
--- a/src/Lucene.Net.Tests/core/Index/TestIndexInput.cs
+++ b/src/Lucene.Net.Tests/core/Index/TestIndexInput.cs
@@ -53,8 +53,8 @@ namespace Lucene.Net.Index
             for (int i = 0; i < COUNT; i++)
             {
                 int i1 = INTS[i] = random.Next();
-                bdo.WriteVInt(i1);
-                bdo.WriteInt(i1);
+                bdo.WriteVInt32(i1);
+                bdo.WriteInt32(i1);
 
                 long l1;
                 if (Rarely())
@@ -66,8 +66,8 @@ namespace Lucene.Net.Index
                 {
                     l1 = LONGS[i] = TestUtil.NextLong(random, 0, long.MaxValue);
                 }
-                bdo.WriteVLong(l1);
-                bdo.WriteLong(l1);
+                bdo.WriteVInt64(l1);
+                bdo.WriteInt64(l1);
             }
         }
 
@@ -81,14 +81,14 @@ namespace Lucene.Net.Index
 
         private void CheckReads(DataInput @is, Type expectedEx)
         {
-            Assert.AreEqual(128, @is.ReadVInt());
-            Assert.AreEqual(16383, @is.ReadVInt());
-            Assert.AreEqual(16384, @is.ReadVInt());
-            Assert.AreEqual(16385, @is.ReadVInt());
-            Assert.AreEqual(int.MaxValue, @is.ReadVInt());
-            Assert.AreEqual(-1, @is.ReadVInt());
-            Assert.AreEqual((long)int.MaxValue, @is.ReadVLong());
-            Assert.AreEqual(long.MaxValue, @is.ReadVLong());
+            Assert.AreEqual(128, @is.ReadVInt32());
+            Assert.AreEqual(16383, @is.ReadVInt32());
+            Assert.AreEqual(16384, @is.ReadVInt32());
+            Assert.AreEqual(16385, @is.ReadVInt32());
+            Assert.AreEqual(int.MaxValue, @is.ReadVInt32());
+            Assert.AreEqual(-1, @is.ReadVInt32());
+            Assert.AreEqual((long)int.MaxValue, @is.ReadVInt64());
+            Assert.AreEqual(long.MaxValue, @is.ReadVInt64());
             Assert.AreEqual("Lucene", @is.ReadString());
 
             Assert.AreEqual("\u00BF", @is.ReadString());
@@ -106,7 +106,7 @@ namespace Lucene.Net.Index
 
             try
             {
-                @is.ReadVInt();
+                @is.ReadVInt32();
                 Assert.Fail("Should throw " + expectedEx.Name);
             }
             catch (Exception e)
@@ -114,11 +114,11 @@ namespace Lucene.Net.Index
                 Assert.IsTrue(e.Message.StartsWith("Invalid vInt"));
                 Assert.IsTrue(expectedEx.IsInstanceOfType(e));
             }
-            Assert.AreEqual(1, @is.ReadVInt()); // guard value
+            Assert.AreEqual(1, @is.ReadVInt32()); // guard value
 
             try
             {
-                @is.ReadVLong();
+                @is.ReadVInt64();
                 Assert.Fail("Should throw " + expectedEx.Name);
             }
             catch (Exception e)
@@ -126,17 +126,17 @@ namespace Lucene.Net.Index
                 Assert.IsTrue(e.Message.StartsWith("Invalid vLong"));
                 Assert.IsTrue(expectedEx.IsInstanceOfType(e));
             }
-            Assert.AreEqual(1L, @is.ReadVLong()); // guard value
+            Assert.AreEqual(1L, @is.ReadVInt64()); // guard value
         }
 
         private void CheckRandomReads(DataInput @is)
         {
             for (int i = 0; i < COUNT; i++)
             {
-                Assert.AreEqual(INTS[i], @is.ReadVInt());
-                Assert.AreEqual(INTS[i], @is.ReadInt());
-                Assert.AreEqual(LONGS[i], @is.ReadVLong());
-                Assert.AreEqual(LONGS[i], @is.ReadLong());
+                Assert.AreEqual(INTS[i], @is.ReadVInt32());
+                Assert.AreEqual(INTS[i], @is.ReadInt32());
+                Assert.AreEqual(LONGS[i], @is.ReadVInt64());
+                Assert.AreEqual(LONGS[i], @is.ReadInt64());
             }
         }
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Tests/core/Index/TestIntBlockPool.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Index/TestIntBlockPool.cs b/src/Lucene.Net.Tests/core/Index/TestIntBlockPool.cs
index 7a996ca..f81bfa2 100644
--- a/src/Lucene.Net.Tests/core/Index/TestIntBlockPool.cs
+++ b/src/Lucene.Net.Tests/core/Index/TestIntBlockPool.cs
@@ -46,7 +46,7 @@ namespace Lucene.Net.Index
                 int num = AtLeast(100);
                 for (int i = 0; i < num; i++)
                 {
-                    writer.WriteInt(i);
+                    writer.WriteInt32(i);
                 }
 
                 int upto = writer.CurrentOffset;
@@ -54,7 +54,7 @@ namespace Lucene.Net.Index
                 reader.Reset(start, upto);
                 for (int i = 0; i < num; i++)
                 {
-                    Assert.AreEqual(i, reader.ReadInt());
+                    Assert.AreEqual(i, reader.ReadInt32());
                 }
                 Assert.IsTrue(reader.EndOfSlice());
                 if (Random().NextBoolean())
@@ -98,7 +98,7 @@ namespace Lucene.Net.Index
                     {
                         writer.Reset(values.End);
                     }
-                    writer.WriteInt(values.NextValue());
+                    writer.WriteInt32(values.NextValue());
                     values.End = writer.CurrentOffset;
                     if (Random().Next(5) == 0)
                     {
@@ -142,13 +142,13 @@ namespace Lucene.Net.Index
                 this.BytesUsed = bytesUsed;
             }
 
-            public override int[] GetIntBlock()
+            public override int[] GetInt32Block()
             {
                 BytesUsed.AddAndGet(m_blockSize * RamUsageEstimator.NUM_BYTES_INT);
                 return new int[m_blockSize];
             }
 
-            public override void RecycleIntBlocks(int[][] blocks, int start, int end)
+            public override void RecycleInt32Blocks(int[][] blocks, int start, int end)
             {
                 BytesUsed.AddAndGet(-((end - start) * m_blockSize * RamUsageEstimator.NUM_BYTES_INT));
             }
@@ -159,7 +159,7 @@ namespace Lucene.Net.Index
             reader.Reset(values.Start, values.End);
             for (int i = 0; i < values.ValueCount; i++)
             {
-                Assert.AreEqual(values.ValueOffset + i, reader.ReadInt());
+                Assert.AreEqual(values.ValueOffset + i, reader.ReadInt32());
             }
             Assert.IsTrue(reader.EndOfSlice());
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Tests/core/Index/TestPerSegmentDeletes.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Index/TestPerSegmentDeletes.cs b/src/Lucene.Net.Tests/core/Index/TestPerSegmentDeletes.cs
index a665696..b52811b 100644
--- a/src/Lucene.Net.Tests/core/Index/TestPerSegmentDeletes.cs
+++ b/src/Lucene.Net.Tests/core/Index/TestPerSegmentDeletes.cs
@@ -263,7 +263,7 @@ namespace Lucene.Net.Index
                 int docID = docsEnum.DocID;
                 docs.Add(docID);
             }
-            return ArrayUtil.ToIntArray(docs);
+            return ArrayUtil.ToInt32Array(docs);
         }
 
         public class RangeMergePolicy : MergePolicy

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Tests/core/Index/TestPostingsOffsets.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Index/TestPostingsOffsets.cs b/src/Lucene.Net.Tests/core/Index/TestPostingsOffsets.cs
index bcb30f3..ddbb79e 100644
--- a/src/Lucene.Net.Tests/core/Index/TestPostingsOffsets.cs
+++ b/src/Lucene.Net.Tests/core/Index/TestPostingsOffsets.cs
@@ -331,7 +331,7 @@ namespace Lucene.Net.Index
                 DocsEnum docs = null;
                 DocsAndPositionsEnum docsAndPositions = null;
                 DocsAndPositionsEnum docsAndPositionsAndOffsets = null;
-                FieldCache.Ints docIDToID = FieldCache.DEFAULT.GetInts(sub, "id", false);
+                FieldCache.Ints docIDToID = FieldCache.DEFAULT.GetInt32s(sub, "id", false);
                 foreach (string term in terms)
                 {
                     //System.out.println("  term=" + term);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Tests/core/Index/TestTermsEnum.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Index/TestTermsEnum.cs b/src/Lucene.Net.Tests/core/Index/TestTermsEnum.cs
index 608fee0..edb37d0 100644
--- a/src/Lucene.Net.Tests/core/Index/TestTermsEnum.cs
+++ b/src/Lucene.Net.Tests/core/Index/TestTermsEnum.cs
@@ -285,7 +285,7 @@ namespace Lucene.Net.Index
             w.Dispose();
 
             // NOTE: intentional insanity!!
-            FieldCache.Ints docIDToID = FieldCache.DEFAULT.GetInts(SlowCompositeReaderWrapper.Wrap(r), "id", false);
+            FieldCache.Ints docIDToID = FieldCache.DEFAULT.GetInt32s(SlowCompositeReaderWrapper.Wrap(r), "id", false);
 
             for (int iter = 0; iter < 10 * RANDOM_MULTIPLIER; iter++)
             {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Tests/core/Search/JustCompileSearch.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Search/JustCompileSearch.cs b/src/Lucene.Net.Tests/core/Search/JustCompileSearch.cs
index c610709..d157b3e 100644
--- a/src/Lucene.Net.Tests/core/Search/JustCompileSearch.cs
+++ b/src/Lucene.Net.Tests/core/Search/JustCompileSearch.cs
@@ -96,7 +96,10 @@ namespace Lucene.Net.Search
 
         internal sealed class JustCompileExtendedFieldCacheLongParser : FieldCache.ILongParser
         {
-            public long ParseLong(BytesRef @string)
+            /// <summary>
+            /// NOTE: This was parseLong() in Lucene
+            /// </summary>
+            public long ParseInt64(BytesRef @string)
             {
                 throw new System.NotSupportedException(UNSUPPORTED_MSG);
             }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Tests/core/Search/TestCachingWrapperFilter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Search/TestCachingWrapperFilter.cs b/src/Lucene.Net.Tests/core/Search/TestCachingWrapperFilter.cs
index dc46ed9..2bbb21c 100644
--- a/src/Lucene.Net.Tests/core/Search/TestCachingWrapperFilter.cs
+++ b/src/Lucene.Net.Tests/core/Search/TestCachingWrapperFilter.cs
@@ -333,9 +333,9 @@ namespace Lucene.Net.Search
             // not cacheable:
             AssertDocIdSetCacheable(reader, new QueryWrapperFilter(new TermQuery(new Term("test", "value"))), false);
             // returns default empty docidset, always cacheable:
-            AssertDocIdSetCacheable(reader, NumericRangeFilter.NewIntRange("test", Convert.ToInt32(10000), Convert.ToInt32(-10000), true, true), true);
+            AssertDocIdSetCacheable(reader, NumericRangeFilter.NewInt32Range("test", Convert.ToInt32(10000), Convert.ToInt32(-10000), true, true), true);
             // is cacheable:
-            AssertDocIdSetCacheable(reader, FieldCacheRangeFilter.NewIntRange("test", Convert.ToInt32(10), Convert.ToInt32(20), true, true), true);
+            AssertDocIdSetCacheable(reader, FieldCacheRangeFilter.NewInt32Range("test", Convert.ToInt32(10), Convert.ToInt32(20), true, true), true);
             // a fixedbitset filter is always cacheable
             AssertDocIdSetCacheable(reader, new FilterAnonymousInnerClassHelper3(this), true);
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Tests/core/Search/TestDocValuesScoring.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Search/TestDocValuesScoring.cs b/src/Lucene.Net.Tests/core/Search/TestDocValuesScoring.cs
index c8e9499..ab4dfcb 100644
--- a/src/Lucene.Net.Tests/core/Search/TestDocValuesScoring.cs
+++ b/src/Lucene.Net.Tests/core/Search/TestDocValuesScoring.cs
@@ -184,7 +184,7 @@ namespace Lucene.Net.Search
             public override SimScorer GetSimScorer(SimWeight stats, AtomicReaderContext context)
             {
                 SimScorer sub = Sim.GetSimScorer(stats, context);
-                FieldCache.Floats values = FieldCache.DEFAULT.GetFloats(context.AtomicReader, BoostField, false);
+                FieldCache.Floats values = FieldCache.DEFAULT.GetSingles(context.AtomicReader, BoostField, false);
 
                 return new SimScorerAnonymousInnerClassHelper(this, sub, values);
             }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Tests/core/Search/TestFieldCache.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Search/TestFieldCache.cs b/src/Lucene.Net.Tests/core/Search/TestFieldCache.cs
index ba63742..a161aff 100644
--- a/src/Lucene.Net.Tests/core/Search/TestFieldCache.cs
+++ b/src/Lucene.Net.Tests/core/Search/TestFieldCache.cs
@@ -187,7 +187,7 @@ namespace Lucene.Net.Search
                 {
                     cache.InfoStream = bos;
                     cache.GetDoubles(Reader, "theDouble", false);
-                    cache.GetFloats(Reader, "theDouble", false);
+                    cache.GetSingles(Reader, "theDouble", false);
                 }
                 Assert.IsTrue(sb.ToString(/*IOUtils.UTF_8*/).IndexOf("WARNING") != -1);
             }
@@ -209,9 +209,9 @@ namespace Lucene.Net.Search
                 Assert.IsTrue(doubles.Get(i) == (double.MaxValue - i), doubles.Get(i) + " does not equal: " + (double.MaxValue - i));
             }
 
-            FieldCache.Longs longs = cache.GetLongs(Reader, "theLong", Random().NextBoolean());
-            Assert.AreSame(longs, cache.GetLongs(Reader, "theLong", Random().NextBoolean()), "Second request to cache return same array");
-            Assert.AreSame(longs, cache.GetLongs(Reader, "theLong", FieldCache.DEFAULT_LONG_PARSER, Random().NextBoolean()), "Second request with explicit parser return same array");
+            FieldCache.Longs longs = cache.GetInt64s(Reader, "theLong", Random().NextBoolean());
+            Assert.AreSame(longs, cache.GetInt64s(Reader, "theLong", Random().NextBoolean()), "Second request to cache return same array");
+            Assert.AreSame(longs, cache.GetInt64s(Reader, "theLong", FieldCache.DEFAULT_LONG_PARSER, Random().NextBoolean()), "Second request with explicit parser return same array");
             for (int i = 0; i < NUM_DOCS; i++)
             {
                 Assert.IsTrue(longs.Get(i) == (long.MaxValue - i), longs.Get(i) + " does not equal: " + (long.MaxValue - i) + " i=" + i);
@@ -226,26 +226,26 @@ namespace Lucene.Net.Search
                 Assert.IsTrue(bytes.Get(i) == (sbyte)(sbyte.MaxValue - i), bytes.Get(i) + " does not equal: " + (sbyte.MaxValue - i));
             }
 
-            FieldCache.Shorts shorts = cache.GetShorts(Reader, "theShort", Random().NextBoolean());
-            Assert.AreSame(shorts, cache.GetShorts(Reader, "theShort", Random().NextBoolean()), "Second request to cache return same array");
-            Assert.AreSame(shorts, cache.GetShorts(Reader, "theShort", FieldCache.DEFAULT_SHORT_PARSER, Random().NextBoolean()), "Second request with explicit parser return same array");
+            FieldCache.Shorts shorts = cache.GetInt16s(Reader, "theShort", Random().NextBoolean());
+            Assert.AreSame(shorts, cache.GetInt16s(Reader, "theShort", Random().NextBoolean()), "Second request to cache return same array");
+            Assert.AreSame(shorts, cache.GetInt16s(Reader, "theShort", FieldCache.DEFAULT_SHORT_PARSER, Random().NextBoolean()), "Second request with explicit parser return same array");
             for (int i = 0; i < NUM_DOCS; i++)
             {
                 Assert.IsTrue(shorts.Get(i) == (short)(short.MaxValue - i), shorts.Get(i) + " does not equal: " + (short.MaxValue - i));
             }
 #pragma warning restore 612, 618
 
-            FieldCache.Ints ints = cache.GetInts(Reader, "theInt", Random().NextBoolean());
-            Assert.AreSame(ints, cache.GetInts(Reader, "theInt", Random().NextBoolean()), "Second request to cache return same array");
-            Assert.AreSame(ints, cache.GetInts(Reader, "theInt", FieldCache.DEFAULT_INT_PARSER, Random().NextBoolean()), "Second request with explicit parser return same array");
+            FieldCache.Ints ints = cache.GetInt32s(Reader, "theInt", Random().NextBoolean());
+            Assert.AreSame(ints, cache.GetInt32s(Reader, "theInt", Random().NextBoolean()), "Second request to cache return same array");
+            Assert.AreSame(ints, cache.GetInt32s(Reader, "theInt", FieldCache.DEFAULT_INT_PARSER, Random().NextBoolean()), "Second request with explicit parser return same array");
             for (int i = 0; i < NUM_DOCS; i++)
             {
                 Assert.IsTrue(ints.Get(i) == (int.MaxValue - i), ints.Get(i) + " does not equal: " + (int.MaxValue - i));
             }
 
-            FieldCache.Floats floats = cache.GetFloats(Reader, "theFloat", Random().NextBoolean());
-            Assert.AreSame(floats, cache.GetFloats(Reader, "theFloat", Random().NextBoolean()), "Second request to cache return same array");
-            Assert.AreSame(floats, cache.GetFloats(Reader, "theFloat", FieldCache.DEFAULT_FLOAT_PARSER, Random().NextBoolean()), "Second request with explicit parser return same array");
+            FieldCache.Floats floats = cache.GetSingles(Reader, "theFloat", Random().NextBoolean());
+            Assert.AreSame(floats, cache.GetSingles(Reader, "theFloat", Random().NextBoolean()), "Second request to cache return same array");
+            Assert.AreSame(floats, cache.GetSingles(Reader, "theFloat", FieldCache.DEFAULT_FLOAT_PARSER, Random().NextBoolean()), "Second request with explicit parser return same array");
             for (int i = 0; i < NUM_DOCS; i++)
             {
                 Assert.IsTrue(floats.Get(i) == (float.MaxValue - i), floats.Get(i) + " does not equal: " + (float.MaxValue - i));
@@ -435,7 +435,7 @@ namespace Lucene.Net.Search
             Assert.AreEqual(3, cache.GetCacheEntries().Length);
             Assert.IsTrue(bits is Bits.MatchAllBits);
 
-            Ints ints = cache.GetInts(Reader, "sparse", true);
+            Ints ints = cache.GetInt32s(Reader, "sparse", true);
             Assert.AreEqual(6, cache.GetCacheEntries().Length);
             IBits docsWithField = cache.GetDocsWithField(Reader, "sparse");
             Assert.AreEqual(6, cache.GetCacheEntries().Length);
@@ -452,7 +452,7 @@ namespace Lucene.Net.Search
                 }
             }
 
-            Ints numInts = cache.GetInts(Reader, "numInt", Random().NextBoolean());
+            Ints numInts = cache.GetInt32s(Reader, "numInt", Random().NextBoolean());
             docsWithField = cache.GetDocsWithField(Reader, "numInt");
             for (int i = 0; i < docsWithField.Length; i++)
             {
@@ -562,7 +562,7 @@ namespace Lucene.Net.Search
                         }
                         else
                         {
-                            Ints ints = Cache.GetInts(Reader, "sparse", true);
+                            Ints ints = Cache.GetInt32s(Reader, "sparse", true);
                             IBits docsWithField = Cache.GetDocsWithField(Reader, "sparse");
                             for (int i = 0; i < docsWithField.Length; i++)
                             {
@@ -613,7 +613,7 @@ namespace Lucene.Net.Search
             // Binary type: can be retrieved via getTerms()
             try
             {
-                FieldCache.DEFAULT.GetInts(ar, "binary", false);
+                FieldCache.DEFAULT.GetInt32s(ar, "binary", false);
                 Assert.Fail();
             }
 #pragma warning disable 168
@@ -665,7 +665,7 @@ namespace Lucene.Net.Search
             // Sorted type: can be retrieved via getTerms(), getTermsIndex(), getDocTermOrds()
             try
             {
-                FieldCache.DEFAULT.GetInts(ar, "sorted", false);
+                FieldCache.DEFAULT.GetInt32s(ar, "sorted", false);
                 Assert.Fail();
             }
 #pragma warning disable 168
@@ -705,7 +705,7 @@ namespace Lucene.Net.Search
             Assert.IsTrue(bits.Get(0));
 
             // Numeric type: can be retrieved via getInts() and so on
-            Ints numeric = FieldCache.DEFAULT.GetInts(ar, "numeric", false);
+            Ints numeric = FieldCache.DEFAULT.GetInt32s(ar, "numeric", false);
             Assert.AreEqual(42, numeric.Get(0));
 
             try
@@ -760,7 +760,7 @@ namespace Lucene.Net.Search
             {
                 try
                 {
-                    FieldCache.DEFAULT.GetInts(ar, "sortedset", false);
+                    FieldCache.DEFAULT.GetInt32s(ar, "sortedset", false);
                     Assert.Fail();
                 }
 #pragma warning disable 168
@@ -837,17 +837,17 @@ namespace Lucene.Net.Search
             Bytes bytes = cache.GetBytes(ar, "bogusbytes", true);
             Assert.AreEqual(0, bytes.Get(0));
 
-            Shorts shorts = cache.GetShorts(ar, "bogusshorts", true);
+            Shorts shorts = cache.GetInt16s(ar, "bogusshorts", true);
             Assert.AreEqual(0, shorts.Get(0));
 #pragma warning restore 612, 618
 
-            Ints ints = cache.GetInts(ar, "bogusints", true);
+            Ints ints = cache.GetInt32s(ar, "bogusints", true);
             Assert.AreEqual(0, ints.Get(0));
 
-            Longs longs = cache.GetLongs(ar, "boguslongs", true);
+            Longs longs = cache.GetInt64s(ar, "boguslongs", true);
             Assert.AreEqual(0, longs.Get(0));
 
-            Floats floats = cache.GetFloats(ar, "bogusfloats", true);
+            Floats floats = cache.GetSingles(ar, "bogusfloats", true);
             Assert.AreEqual(0, floats.Get(0), 0.0f);
 
             Doubles doubles = cache.GetDoubles(ar, "bogusdoubles", true);
@@ -906,17 +906,17 @@ namespace Lucene.Net.Search
             Bytes bytes = cache.GetBytes(ar, "bogusbytes", true);
             Assert.AreEqual(0, bytes.Get(0));
 
-            Shorts shorts = cache.GetShorts(ar, "bogusshorts", true);
+            Shorts shorts = cache.GetInt16s(ar, "bogusshorts", true);
             Assert.AreEqual(0, shorts.Get(0));
 #pragma warning restore 612, 618
 
-            Ints ints = cache.GetInts(ar, "bogusints", true);
+            Ints ints = cache.GetInt32s(ar, "bogusints", true);
             Assert.AreEqual(0, ints.Get(0));
 
-            Longs longs = cache.GetLongs(ar, "boguslongs", true);
+            Longs longs = cache.GetInt64s(ar, "boguslongs", true);
             Assert.AreEqual(0, longs.Get(0));
 
-            Floats floats = cache.GetFloats(ar, "bogusfloats", true);
+            Floats floats = cache.GetSingles(ar, "bogusfloats", true);
             Assert.AreEqual(0, floats.Get(0), 0.0f);
 
             Doubles doubles = cache.GetDoubles(ar, "bogusdoubles", true);
@@ -989,7 +989,7 @@ namespace Lucene.Net.Search
             }
             iw.ForceMerge(1);
             DirectoryReader reader = iw.Reader;
-            Longs longs = FieldCache.DEFAULT.GetLongs(GetOnlySegmentReader(reader), "f", false);
+            Longs longs = FieldCache.DEFAULT.GetInt64s(GetOnlySegmentReader(reader), "f", false);
             for (int i = 0; i < values.Length; ++i)
             {
                 Assert.AreEqual(values[i], longs.Get(i));
@@ -1043,7 +1043,7 @@ namespace Lucene.Net.Search
             }
             iw.ForceMerge(1);
             DirectoryReader reader = iw.Reader;
-            Ints ints = FieldCache.DEFAULT.GetInts(GetOnlySegmentReader(reader), "f", false);
+            Ints ints = FieldCache.DEFAULT.GetInt32s(GetOnlySegmentReader(reader), "f", false);
             for (int i = 0; i < values.Length; ++i)
             {
                 Assert.AreEqual(values[i], ints.Get(i));


[17/53] [abbrv] lucenenet git commit: Lucene.Net.Queries: Renamed all type-derived properties and methods from Short, Int, Long, and Float to match CLR types Int16, Int32, Int64, and Single, respectively.

Posted by ni...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/ec70857f/src/Lucene.Net.Suggest/Suggest/DocumentValueSourceDictionary.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Suggest/Suggest/DocumentValueSourceDictionary.cs b/src/Lucene.Net.Suggest/Suggest/DocumentValueSourceDictionary.cs
index ae45105..987ab46 100644
--- a/src/Lucene.Net.Suggest/Suggest/DocumentValueSourceDictionary.cs
+++ b/src/Lucene.Net.Suggest/Suggest/DocumentValueSourceDictionary.cs
@@ -158,7 +158,7 @@ namespace Lucene.Net.Search.Suggest
                         throw new Exception();
                     }
                 }
-                return currentWeightValues.LongVal(docId - starts[subIndex]);
+                return currentWeightValues.Int64Val(docId - starts[subIndex]);
             }
         }
     }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/ec70857f/src/Lucene.Net.Tests.Expressions/TestExpressionValueSource.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests.Expressions/TestExpressionValueSource.cs b/src/Lucene.Net.Tests.Expressions/TestExpressionValueSource.cs
index 7df6dd5..a088eae 100644
--- a/src/Lucene.Net.Tests.Expressions/TestExpressionValueSource.cs
+++ b/src/Lucene.Net.Tests.Expressions/TestExpressionValueSource.cs
@@ -72,26 +72,26 @@ namespace Lucene.Net.Tests.Expressions
 			AtomicReaderContext leaf = reader.Leaves[0];
 			FunctionValues values = vs.GetValues(new Dictionary<string, object>(), leaf);
 			AreEqual(10, values.DoubleVal(0), 0);
-			AreEqual(10, values.FloatVal(0), 0);
-			AreEqual(10, values.LongVal(0));
-			AreEqual(10, values.IntVal(0));
-			AreEqual(10, values.ShortVal(0));
+			AreEqual(10, values.SingleVal(0), 0);
+			AreEqual(10, values.Int64Val(0));
+			AreEqual(10, values.Int32Val(0));
+			AreEqual(10, values.Int16Val(0));
 			AreEqual(10, values.ByteVal(0));
 			AreEqual("10", values.StrVal(0));
 			AreEqual(System.Convert.ToDouble(10), values.ObjectVal(0));
 			AreEqual(40, values.DoubleVal(1), 0);
-			AreEqual(40, values.FloatVal(1), 0);
-			AreEqual(40, values.LongVal(1));
-			AreEqual(40, values.IntVal(1));
-			AreEqual(40, values.ShortVal(1));
+			AreEqual(40, values.SingleVal(1), 0);
+			AreEqual(40, values.Int64Val(1));
+			AreEqual(40, values.Int32Val(1));
+			AreEqual(40, values.Int16Val(1));
 			AreEqual(40, values.ByteVal(1));
 			AreEqual("40", values.StrVal(1));
 			AreEqual(System.Convert.ToDouble(40), values.ObjectVal(1));
 			AreEqual(4, values.DoubleVal(2), 0);
-			AreEqual(4, values.FloatVal(2), 0);
-			AreEqual(4, values.LongVal(2));
-			AreEqual(4, values.IntVal(2));
-			AreEqual(4, values.ShortVal(2));
+			AreEqual(4, values.SingleVal(2), 0);
+			AreEqual(4, values.Int64Val(2));
+			AreEqual(4, values.Int32Val(2));
+			AreEqual(4, values.Int16Val(2));
 			AreEqual(4, values.ByteVal(2));
 			AreEqual("4", values.StrVal(2));
 			AreEqual(System.Convert.ToDouble(4), values.ObjectVal(2));

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/ec70857f/src/Lucene.Net.Tests.Queries/Function/TestDocValuesFieldSources.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests.Queries/Function/TestDocValuesFieldSources.cs b/src/Lucene.Net.Tests.Queries/Function/TestDocValuesFieldSources.cs
index b8afb3f..1692996 100644
--- a/src/Lucene.Net.Tests.Queries/Function/TestDocValuesFieldSources.cs
+++ b/src/Lucene.Net.Tests.Queries/Function/TestDocValuesFieldSources.cs
@@ -108,7 +108,7 @@ namespace Lucene.Net.Tests.Queries.Function
                         throw new InvalidOperationException();
                     }
 
-                    object expected = vals[ids.IntVal(i)];
+                    object expected = vals[ids.Int32Val(i)];
                     switch (type)
                     {
                         case DocValuesType.SORTED:
@@ -124,7 +124,7 @@ namespace Lucene.Net.Tests.Queries.Function
                             assertEquals(new BytesRef((string)expected), bytes);
                             break;
                         case DocValuesType.NUMERIC:
-                            assertEquals(Convert.ToInt64(expected, CultureInfo.InvariantCulture), values.LongVal(i));
+                            assertEquals(Convert.ToInt64(expected, CultureInfo.InvariantCulture), values.Int64Val(i));
                             break;
                     }
                 }


[30/53] [abbrv] lucenenet git commit: Lucene.Net.Core: Renamed all type-derived classes and interfaces from Short, Int, Long, and Float to match CLR types Int16, Int32, Int64, and Single, respectively.

Posted by ni...@apache.org.
Lucene.Net.Core: Renamed all type-derived classes and interfaces from Short, Int, Long, and Float to match CLR types Int16, Int32, Int64, and Single, respectively.


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

Branch: refs/heads/api-work
Commit: 8b7f4185cf3ae4bd5fe9ca43ce11e21017df14cd
Parents: f0cd424
Author: Shad Storhaug <sh...@shadstorhaug.com>
Authored: Wed Feb 8 02:19:45 2017 +0700
Committer: Shad Storhaug <sh...@shadstorhaug.com>
Committed: Wed Feb 8 21:08:22 2017 +0700

----------------------------------------------------------------------
 .../Analysis/CharFilter/NormalizeCharMap.cs     |   2 +-
 .../Analysis/Hunspell/Dictionary.cs             |  44 ++--
 .../Analysis/Hunspell/Stemmer.cs                |   8 +-
 .../Miscellaneous/StemmerOverrideFilter.cs      |   2 +-
 .../Analysis/Synonym/SynonymMap.cs              |   2 +-
 .../BlockTerms/FixedGapTermsIndexReader.cs      |  24 +-
 .../BlockTerms/FixedGapTermsIndexWriter.cs      |  10 +-
 .../BlockTerms/VariableGapTermsIndexReader.cs   |   6 +-
 .../BlockTerms/VariableGapTermsIndexWriter.cs   |   6 +-
 .../Memory/DirectDocValuesProducer.cs           |   4 +-
 .../Memory/FSTOrdTermsReader.cs                 |   2 +-
 .../Memory/FSTOrdTermsWriter.cs                 |  10 +-
 src/Lucene.Net.Codecs/Memory/FSTTermsWriter.cs  |   4 +-
 .../Memory/MemoryDocValuesConsumer.cs           |  28 +--
 .../Memory/MemoryDocValuesFormat.cs             |   2 +-
 .../Memory/MemoryDocValuesProducer.cs           |  34 +--
 .../Memory/MemoryPostingsFormat.cs              |   8 +-
 .../SimpleText/SimpleTextFieldsReader.cs        |   8 +-
 .../Codecs/BlockTreeTermsWriter.cs              |  18 +-
 .../CompressingStoredFieldsIndexReader.cs       |  18 +-
 .../CompressingStoredFieldsIndexWriter.cs       |  22 +-
 .../CompressingStoredFieldsReader.cs            |  12 +-
 .../CompressingStoredFieldsWriter.cs            |  10 +-
 .../Compressing/CompressingTermVectorsReader.cs |  30 +--
 .../Compressing/CompressingTermVectorsWriter.cs |  22 +-
 src/Lucene.Net.Core/Codecs/Compressing/LZ4.cs   |  12 +-
 src/Lucene.Net.Core/Codecs/DocValuesConsumer.cs |  10 +-
 .../Codecs/Lucene3x/Lucene3xNormsProducer.cs    |   4 +-
 .../Codecs/Lucene3x/TermInfosReaderIndex.cs     |   6 +-
 .../Codecs/Lucene40/Lucene40DocValuesReader.cs  |  46 ++--
 src/Lucene.Net.Core/Codecs/Lucene41/ForUtil.cs  |  46 ++--
 .../Codecs/Lucene41/Lucene41PostingsReader.cs   |  18 +-
 .../Codecs/Lucene41/Lucene41PostingsWriter.cs   |  23 +-
 .../Codecs/Lucene42/Lucene42DocValuesFormat.cs  |   6 +-
 .../Lucene42/Lucene42DocValuesProducer.cs       |  40 ++--
 .../Codecs/Lucene42/Lucene42NormsConsumer.cs    |  16 +-
 .../Codecs/Lucene42/Lucene42NormsFormat.cs      |   6 +-
 .../Lucene45/Lucene45DocValuesConsumer.cs       |  16 +-
 .../Lucene45/Lucene45DocValuesProducer.cs       |  57 ++---
 src/Lucene.Net.Core/Document/DateTools.cs       |   2 +-
 src/Lucene.Net.Core/Document/Document.cs        |   4 +-
 src/Lucene.Net.Core/Document/DoubleField.cs     |   2 +-
 src/Lucene.Net.Core/Document/Field.cs           |   2 +-
 .../Document/FloatDocValuesField.cs             |  20 +-
 src/Lucene.Net.Core/Document/FloatField.cs      |  14 +-
 .../Document/IntDocValuesField.cs               |  13 +-
 src/Lucene.Net.Core/Document/IntField.cs        |  14 +-
 .../Document/LongDocValuesField.cs              |   7 +-
 src/Lucene.Net.Core/Document/LongField.cs       |  14 +-
 .../Document/PackedLongDocValuesField.cs        |  11 +-
 .../Document/ShortDocValuesField.cs             |  11 +-
 src/Lucene.Net.Core/Index/AutomatonTermsEnum.cs |   4 +-
 .../Index/BinaryDocValuesFieldUpdates.cs        |   8 +-
 .../Index/BinaryDocValuesWriter.cs              |  10 +-
 src/Lucene.Net.Core/Index/BufferedUpdates.cs    |  10 +-
 .../Index/BufferedUpdatesStream.cs              |   4 +-
 src/Lucene.Net.Core/Index/CheckIndex.cs         |   4 +-
 src/Lucene.Net.Core/Index/DocumentsWriter.cs    |   2 +-
 .../Index/DocumentsWriterFlushQueue.cs          |   2 +-
 .../Index/DocumentsWriterPerThread.cs           |  21 +-
 src/Lucene.Net.Core/Index/IndexReader.cs        |   2 +-
 src/Lucene.Net.Core/Index/IndexWriter.cs        |   4 +-
 src/Lucene.Net.Core/Index/MergeState.cs         |   8 +-
 src/Lucene.Net.Core/Index/MultiDocValues.cs     |  20 +-
 .../Index/NumericDocValuesFieldUpdates.cs       |   6 +-
 .../Index/NumericDocValuesWriter.cs             |  10 +-
 src/Lucene.Net.Core/Index/ReadersAndUpdates.cs  |   2 +-
 src/Lucene.Net.Core/Index/SegmentCoreReaders.cs |   2 +-
 .../Index/SortedDocValuesWriter.cs              |   6 +-
 .../Index/SortedSetDocValuesWriter.cs           |  20 +-
 src/Lucene.Net.Core/Index/TermsHash.cs          |   6 +-
 src/Lucene.Net.Core/Index/TermsHashPerField.cs  |  20 +-
 .../Index/TrackingIndexWriter.cs                |   2 +-
 .../Search/DocTermOrdsRewriteMethod.cs          |   8 +-
 src/Lucene.Net.Core/Search/FieldCache.cs        | 117 ++++++----
 src/Lucene.Net.Core/Search/FieldCacheImpl.cs    | 218 ++++++++++---------
 .../Search/FieldCacheRangeFilter.cs             |  56 ++---
 .../Search/FieldCacheRewriteMethod.cs           |   8 +-
 src/Lucene.Net.Core/Search/FieldComparator.cs   |  58 ++---
 src/Lucene.Net.Core/Search/MultiPhraseQuery.cs  |  11 +-
 src/Lucene.Net.Core/Search/NumericRangeQuery.cs |  20 +-
 .../Search/Similarities/BM25Similarity.cs       |  10 +-
 .../Search/Similarities/DefaultSimilarity.cs    |   8 +-
 .../Search/Similarities/SimilarityBase.cs       |   6 +-
 src/Lucene.Net.Core/Search/SortField.cs         |  16 +-
 src/Lucene.Net.Core/Store/RAMDirectory.cs       |   2 +-
 src/Lucene.Net.Core/Support/AtomicInteger.cs    |   9 +-
 src/Lucene.Net.Core/Support/AtomicLong.cs       |   9 +-
 src/Lucene.Net.Core/Support/Buffer.cs           |   2 +-
 src/Lucene.Net.Core/Support/ByteBuffer.cs       |  34 +--
 src/Lucene.Net.Core/Support/LongBuffer.cs       |  81 +++----
 .../Support/MemoryMappedFileByteBuffer.cs       |   2 +-
 .../Util/Automaton/BasicOperations.cs           |  12 +-
 .../Util/Automaton/MinimizationOperations.cs    |  17 +-
 .../Util/Automaton/SortedIntSet.cs              |  51 +++--
 .../Util/Automaton/SpecialOperations.cs         |  12 +-
 src/Lucene.Net.Core/Util/BytesRefHash.cs        |   2 +-
 src/Lucene.Net.Core/Util/FixedBitSet.cs         |   2 +-
 src/Lucene.Net.Core/Util/Fst/Builder.cs         |  12 +-
 src/Lucene.Net.Core/Util/Fst/FST.cs             |  18 +-
 .../Util/Fst/IntSequenceOutputs.cs              |  36 +--
 src/Lucene.Net.Core/Util/Fst/IntsRefFSTEnum.cs  |  36 +--
 src/Lucene.Net.Core/Util/Fst/NodeHash.cs        |   6 +-
 .../Util/Fst/PositiveIntOutputs.cs              |  12 +-
 src/Lucene.Net.Core/Util/Fst/Util.cs            |  34 +--
 src/Lucene.Net.Core/Util/IntBlockPool.cs        |  40 ++--
 src/Lucene.Net.Core/Util/IntsRef.cs             |  32 +--
 src/Lucene.Net.Core/Util/LongBitSet.cs          |  34 +--
 src/Lucene.Net.Core/Util/LongValues.cs          |   9 +-
 src/Lucene.Net.Core/Util/LongsRef.cs            |  26 ++-
 .../Util/Mutable/MutableValueDate.cs            |   2 +-
 .../Util/Mutable/MutableValueFloat.cs           |  15 +-
 .../Util/Mutable/MutableValueInt.cs             |  15 +-
 .../Util/Mutable/MutableValueLong.cs            |  15 +-
 src/Lucene.Net.Core/Util/NumericUtils.cs        |  22 +-
 src/Lucene.Net.Core/Util/PForDeltaDocIdSet.cs   |  38 ++--
 .../Util/Packed/AbstractAppendingLongBuffer.cs  |  21 +-
 .../Util/Packed/AbstractBlockPackedWriter.cs    |   6 +-
 .../Util/Packed/AbstractPagedMutable.cs         |  18 +-
 .../Packed/AppendingDeltaPackedLongBuffer.cs    |  26 ++-
 .../Util/Packed/AppendingPackedLongBuffer.cs    |  26 ++-
 .../Util/Packed/BlockPackedReader.cs            |  20 +-
 .../Util/Packed/BlockPackedReaderIterator.cs    |  14 +-
 .../Util/Packed/BlockPackedWriter.cs            |   6 +-
 .../Util/Packed/BulkOperation.cs                |   8 +-
 .../Util/Packed/BulkOperationPacked.cs          |   6 +-
 .../Packed/BulkOperationPackedSingleBlock.cs    |   2 +-
 src/Lucene.Net.Core/Util/Packed/Direct16.cs     |   4 +-
 src/Lucene.Net.Core/Util/Packed/Direct32.cs     |   4 +-
 src/Lucene.Net.Core/Util/Packed/Direct64.cs     |   2 +-
 src/Lucene.Net.Core/Util/Packed/Direct8.cs      |   4 +-
 .../Packed/DirectPacked64SingleBlockReader.cs   |   2 +-
 .../Util/Packed/DirectPackedReader.cs           |   2 +-
 .../Util/Packed/GrowableWriter.cs               |  20 +-
 .../Util/Packed/MonotonicAppendingLongBuffer.cs |  26 ++-
 .../Util/Packed/MonotonicBlockPackedReader.cs   |  20 +-
 .../Util/Packed/MonotonicBlockPackedWriter.cs   |   4 +-
 .../Util/Packed/Packed16ThreeBlocks.cs          |   4 +-
 src/Lucene.Net.Core/Util/Packed/Packed64.cs     |  16 +-
 .../Util/Packed/Packed64SingleBlock.cs          |  12 +-
 .../Util/Packed/Packed8ThreeBlocks.cs           |   4 +-
 .../Util/Packed/PackedDataInput.cs              |   2 +-
 .../Util/Packed/PackedDataOutput.cs             |   2 +-
 src/Lucene.Net.Core/Util/Packed/PackedInts.cs   |  54 ++---
 .../Util/Packed/PackedReaderIterator.cs         |  14 +-
 src/Lucene.Net.Core/Util/Packed/PackedWriter.cs |  12 +-
 .../Util/Packed/PagedGrowableWriter.cs          |   4 +-
 src/Lucene.Net.Core/Util/Packed/PagedMutable.cs |  14 +-
 .../Util/RecyclingIntBlockAllocator.cs          |  27 ++-
 src/Lucene.Net.Core/Util/SentinelIntSet.cs      |  12 +-
 src/Lucene.Net.Core/Util/SmallFloat.cs          |   6 +-
 src/Lucene.Net.Core/Util/UnicodeUtil.cs         |   2 +-
 src/Lucene.Net.Core/Util/WAH8DocIdSet.cs        |  20 +-
 src/Lucene.Net.Expressions/SimpleBindings.cs    |   6 +-
 src/Lucene.Net.Facet/FacetsConfig.cs            |   6 +-
 .../Range/DoubleRangeFacetCounts.cs             |   2 +-
 .../Taxonomy/CachedOrdinalsReader.cs            |   6 +-
 .../Directory/DirectoryTaxonomyWriter.cs        |   2 +-
 .../Taxonomy/DocValuesOrdinalsReader.cs         |   6 +-
 src/Lucene.Net.Facet/Taxonomy/OrdinalsReader.cs |   6 +-
 .../Taxonomy/TaxonomyFacetCounts.cs             |   4 +-
 .../Taxonomy/TaxonomyFacetSumValueSource.cs     |   4 +-
 src/Lucene.Net.Facet/Taxonomy/TaxonomyReader.cs |   2 +-
 .../Term/TermAllGroupHeadsCollector.cs          |  12 +-
 .../Term/TermAllGroupsCollector.cs              |   4 +-
 .../Term/TermDistinctValuesCollector.cs         |   4 +-
 .../Term/TermGroupFacetCollector.cs             |   4 +-
 .../Term/TermSecondPassGroupingCollector.cs     |   4 +-
 .../MemoryIndex.MemoryIndexReader.cs            |   4 +-
 src/Lucene.Net.Memory/MemoryIndex.cs            |  14 +-
 src/Lucene.Net.Misc/Index/Sorter/Sorter.cs      |  10 +-
 .../Index/Sorter/SortingMergePolicy.cs          |  10 +-
 src/Lucene.Net.Misc/Util/Fst/ListOfOutputs.cs   |   4 +-
 .../Util/Fst/UpToTwoPositiveIntOutputs.cs       |   2 +-
 .../Function/DocValues/FloatDocValues.cs        |   4 +-
 .../Function/DocValues/IntDocValues.cs          |   4 +-
 .../Function/DocValues/LongDocValues.cs         |   4 +-
 .../Function/FunctionValues.cs                  |   4 +-
 .../Function/ValueSources/EnumFieldSource.cs    |  16 +-
 .../Function/ValueSources/FloatFieldSource.cs   |  12 +-
 .../Function/ValueSources/IntFieldSource.cs     |  18 +-
 .../ValueSources/JoinDocFreqValueSource.cs      |   2 +-
 .../Function/ValueSources/LongFieldSource.cs    |  14 +-
 .../Function/ValueSources/OrdFieldSource.cs     |   4 +-
 .../Function/ValueSources/QueryValueSource.cs   |   4 +-
 .../Function/ValueSources/ShortFieldSource.cs   |   8 +-
 .../Queries/SlowFuzzyTermsEnum.cs               |   2 +-
 .../Prefix/ContainsPrefixTreeFilter.cs          |   4 +-
 .../Spell/LuceneLevenshteinDistance.cs          |   8 +-
 .../Suggest/Analyzing/AnalyzingSuggester.cs     |  14 +-
 .../Suggest/Analyzing/FSTUtil.cs                |  12 +-
 .../Suggest/Analyzing/FreeTextSuggester.cs      |  12 +-
 .../Suggest/Analyzing/FuzzySuggester.cs         |   2 +-
 .../Suggest/Fst/FSTCompletionBuilder.cs         |   4 +-
 .../Suggest/Fst/WFSTCompletionLookup.cs         |   6 +-
 .../asserting/AssertingDocValuesFormat.cs       |   4 +-
 .../Codecs/compressing/FastCompressingCodec.cs  |   4 +-
 .../FastDecompressionCompressingCodec.cs        |   4 +-
 .../HighCompressionCompressingCodec.cs          |   4 +-
 .../Codecs/lucene40/Lucene40DocValuesWriter.cs  |  22 +-
 .../lucene42/Lucene42DocValuesConsumer.cs       |  26 +--
 .../Codecs/ramonly/RAMOnlyPostingsFormat.cs     |   2 +-
 .../BaseCompressingDocValuesFormatTestCase.cs   |   4 +-
 .../Index/BaseDocValuesFormatTestCase.cs        |   4 +-
 .../Index/BaseStoredFieldsFormatTestCase.cs     |  22 +-
 .../ThreadedIndexingAndSearchingTestCase.cs     |  16 +-
 .../Store/MockDirectoryWrapper.cs               |   2 +-
 .../Util/LineFileDocs.cs                        |   2 +-
 src/Lucene.Net.TestFramework/Util/TestUtil.cs   |  12 +-
 .../Util/fst/FSTTester.cs                       |  72 +++---
 .../Analysis/Hunspell/TestDictionary.cs         |  10 +-
 .../TestExpressionSorts.cs                      |   8 +-
 .../Range/TestRangeFacetCounts.cs               |  16 +-
 .../Taxonomy/Directory/TestAddTaxonomy.cs       |   6 +-
 .../Directory/TestConcurrentFacetedIndexing.cs  |   6 +-
 .../Directory/TestDirectoryTaxonomyWriter.cs    |   6 +-
 .../Taxonomy/TestTaxonomyFacetSumValueSource.cs |  24 +-
 .../AllGroupHeadsCollectorTest.cs               |   4 +-
 src/Lucene.Net.Tests.Grouping/TestGrouping.cs   |  10 +-
 .../Highlight/HighlighterTest.cs                |   8 +-
 src/Lucene.Net.Tests.Join/TestBlockJoin.cs      |   4 +-
 .../Util/Fst/TestFSTsMisc.cs                    |  16 +-
 .../Function/TestDocValuesFieldSources.cs       |   2 +-
 .../TestCustomScoreQuery.cs                     |   6 +-
 .../Flexible/Standard/TestNumericQueryParser.cs |  12 +-
 .../Xml/TestParser.cs                           |   2 +-
 src/Lucene.Net.Tests.Spatial/SpatialExample.cs  |   2 +-
 .../Suggest/Analyzing/FuzzySuggesterTest.cs     |  12 +-
 .../TestCompressingStoredFieldsFormat.cs        |   4 +-
 .../core/Codecs/Lucene41/TestForUtil.cs         |   4 +-
 .../core/Document/TestDocument.cs               |   4 +-
 src/Lucene.Net.Tests/core/Document/TestField.cs |   8 +-
 .../core/Index/TestBackwardsCompatibility.cs    |  16 +-
 .../core/Index/TestBackwardsCompatibility3x.cs  |  16 +-
 .../core/Index/TestBinaryDocValuesUpdates.cs    |   6 +-
 .../core/Index/TestConcurrentMergeScheduler.cs  |   6 +-
 .../core/Index/TestDirectoryReader.cs           |   4 +-
 .../core/Index/TestDocTermOrds.cs               |   8 +-
 .../core/Index/TestDocValuesWithThreads.cs      |   2 +-
 .../Index/TestDocumentsWriterDeleteQueue.cs     |   6 +-
 .../core/Index/TestFlushByRamOrCountsPolicy.cs  |  12 +-
 .../core/Index/TestForceMergeForever.cs         |   2 +-
 .../core/Index/TestIndexReaderClose.cs          |   6 +-
 .../core/Index/TestIndexWriter.cs               |   4 +-
 .../core/Index/TestIndexWriterDelete.cs         |   6 +-
 .../core/Index/TestIndexWriterReader.cs         |   4 +-
 .../core/Index/TestIntBlockPool.cs              |  26 +--
 .../core/Index/TestMixedDocValuesUpdates.cs     |   6 +-
 .../core/Index/TestMultiLevelSkipList.cs        |   6 +-
 .../core/Index/TestNRTReaderWithThreads.cs      |   2 +-
 .../core/Index/TestNumericDocValuesUpdates.cs   |   6 +-
 .../core/Index/TestPostingsOffsets.cs           |   6 +-
 .../core/Index/TestStressNRT.cs                 |  14 +-
 .../core/Index/TestTermsEnum.cs                 |   6 +-
 .../core/Search/JustCompileSearch.cs            |   2 +-
 .../core/Search/TestBooleanOr.cs                |   6 +-
 .../core/Search/TestDocValuesScoring.cs         |  10 +-
 .../core/Search/TestFieldCache.cs               |  64 +++---
 .../core/Search/TestLiveFieldValues.cs          |   4 +-
 .../Search/TestMultiValuedNumericRangeQuery.cs  |   4 +-
 .../core/Search/TestNumericRangeQuery32.cs      |  24 +-
 .../core/Search/TestNumericRangeQuery64.cs      |  14 +-
 .../core/Search/TestSearchAfter.cs              |  16 +-
 .../core/Search/TestSearchWithThreads.cs        |   6 +-
 src/Lucene.Net.Tests/core/Search/TestSort.cs    |   8 +-
 .../core/Search/TestSortDocValues.cs            |  22 +-
 .../core/Search/TestSortRandom.cs               |   2 +-
 .../core/Search/TestTopDocsMerge.cs             |   8 +-
 .../core/Support/TestByteBuffer.cs              |   2 +-
 .../core/Support/TestLongBuffer.cs              |  68 +++---
 .../Util/Automaton/TestSpecialOperations.cs     |   6 +-
 src/Lucene.Net.Tests/core/Util/Fst/Test2BFST.cs |  26 +--
 src/Lucene.Net.Tests/core/Util/Fst/TestFSTs.cs  | 150 ++++++-------
 .../core/Util/Packed/TestPackedInts.cs          | 186 ++++++++--------
 src/Lucene.Net.Tests/core/Util/TestIntsRef.cs   |  10 +-
 .../core/Util/TestLongBitSet.cs                 |  62 +++---
 .../core/Util/TestNumericUtils.cs               |  10 +-
 .../core/Util/TestRecyclingIntBlockAllocator.cs |  12 +-
 .../core/Util/TestSentinelIntSet.cs             |   4 +-
 .../core/Util/TestSmallFloat.cs                 |  32 +--
 .../core/Util/TestUnicodeUtil.cs                |   2 +-
 281 files changed, 2146 insertions(+), 1980 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Analysis.Common/Analysis/CharFilter/NormalizeCharMap.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Analysis.Common/Analysis/CharFilter/NormalizeCharMap.cs b/src/Lucene.Net.Analysis.Common/Analysis/CharFilter/NormalizeCharMap.cs
index 6678922..c4113a4 100644
--- a/src/Lucene.Net.Analysis.Common/Analysis/CharFilter/NormalizeCharMap.cs
+++ b/src/Lucene.Net.Analysis.Common/Analysis/CharFilter/NormalizeCharMap.cs
@@ -118,7 +118,7 @@ namespace Lucene.Net.Analysis.CharFilters
                 {
                     Outputs<CharsRef> outputs = CharSequenceOutputs.Singleton;
                     Builder<CharsRef> builder = new Builder<CharsRef>(FST.INPUT_TYPE.BYTE2, outputs);
-                    IntsRef scratch = new IntsRef();
+                    Int32sRef scratch = new Int32sRef();
                     foreach (var ent in pendingPairs)
                     {
                         builder.Add(Lucene.Net.Util.Fst.Util.ToUTF16(ent.Key, scratch), new CharsRef(ent.Value));

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Analysis.Common/Analysis/Hunspell/Dictionary.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Analysis.Common/Analysis/Hunspell/Dictionary.cs b/src/Lucene.Net.Analysis.Common/Analysis/Hunspell/Dictionary.cs
index 0fa0f34..8cf3503 100644
--- a/src/Lucene.Net.Analysis.Common/Analysis/Hunspell/Dictionary.cs
+++ b/src/Lucene.Net.Analysis.Common/Analysis/Hunspell/Dictionary.cs
@@ -56,8 +56,8 @@ namespace Lucene.Net.Analysis.Hunspell
         private const string PREFIX_CONDITION_REGEX_PATTERN = "{0}.*";
         private const string SUFFIX_CONDITION_REGEX_PATTERN = ".*{0}";
 
-        internal FST<IntsRef> prefixes;
-        internal FST<IntsRef> suffixes;
+        internal FST<Int32sRef> prefixes;
+        internal FST<Int32sRef> suffixes;
 
         // all condition checks used by prefixes and suffixes. these are typically re-used across
         // many affix stripping rules. so these are deduplicated, to save RAM.
@@ -65,7 +65,7 @@ namespace Lucene.Net.Analysis.Hunspell
 
         // the entries in the .dic file, mapping to their set of flags.
         // the fst output is the ordinal list for flagLookup
-        internal FST<IntsRef> words;
+        internal FST<Int32sRef> words;
         // the list of unique flagsets (wordforms). theoretically huge, but practically
         // small (e.g. for polish this is 756), otherwise humans wouldn't be able to deal with it either.
         internal BytesRefHash flagLookup = new BytesRefHash();
@@ -157,8 +157,8 @@ namespace Lucene.Net.Analysis.Hunspell
             }
 
             // read dictionary entries
-            IntSequenceOutputs o = IntSequenceOutputs.Singleton;
-            Builder<IntsRef> b = new Builder<IntsRef>(FST.INPUT_TYPE.BYTE4, o);
+            Int32SequenceOutputs o = Int32SequenceOutputs.Singleton;
+            Builder<Int32sRef> b = new Builder<Int32sRef>(FST.INPUT_TYPE.BYTE4, o);
             ReadDictionaryFiles(dictionaries, decoder, b);
             words = b.Finish();
             aliases = null; // no longer needed
@@ -176,7 +176,7 @@ namespace Lucene.Net.Analysis.Hunspell
         /// <summary>
         /// Looks up Hunspell word forms from the dictionary
         /// </summary>
-        internal virtual IntsRef LookupWord(char[] word, int offset, int length)
+        internal virtual Int32sRef LookupWord(char[] word, int offset, int length)
         {
             return Lookup(words, word, offset, length);
         }
@@ -188,7 +188,7 @@ namespace Lucene.Net.Analysis.Hunspell
         /// <param name="offset"> Offset in the <see cref="char"/> array that the <see cref="string"/> starts at </param>
         /// <param name="length"> Length from the offset that the <see cref="string"/> is </param>
         /// <returns> List of HunspellAffix prefixes with an append that matches the <see cref="string"/>, or <c>null</c> if none are found </returns>
-        internal virtual IntsRef LookupPrefix(char[] word, int offset, int length)
+        internal virtual Int32sRef LookupPrefix(char[] word, int offset, int length)
         {
             return Lookup(prefixes, word, offset, length);
         }
@@ -200,24 +200,24 @@ namespace Lucene.Net.Analysis.Hunspell
         /// <param name="offset"> Offset in the char array that the <see cref="string"/> starts at </param>
         /// <param name="length"> Length from the offset that the <see cref="string"/> is </param>
         /// <returns> List of HunspellAffix suffixes with an append that matches the <see cref="string"/>, or <c>null</c> if none are found </returns>
-        internal virtual IntsRef LookupSuffix(char[] word, int offset, int length)
+        internal virtual Int32sRef LookupSuffix(char[] word, int offset, int length)
         {
             return Lookup(suffixes, word, offset, length);
         }
 
         // TODO: this is pretty stupid, considering how the stemming algorithm works
         // we can speed it up to be significantly faster!
-        internal virtual IntsRef Lookup(FST<IntsRef> fst, char[] word, int offset, int length)
+        internal virtual Int32sRef Lookup(FST<Int32sRef> fst, char[] word, int offset, int length)
         {
             if (fst == null)
             {
                 return null;
             }
             FST.BytesReader bytesReader = fst.GetBytesReader();
-            FST.Arc<IntsRef> arc = fst.GetFirstArc(new FST.Arc<IntsRef>());
+            FST.Arc<Int32sRef> arc = fst.GetFirstArc(new FST.Arc<Int32sRef>());
             // Accumulate output as we go
-            IntsRef NO_OUTPUT = fst.Outputs.NoOutput;
-            IntsRef output = NO_OUTPUT;
+            Int32sRef NO_OUTPUT = fst.Outputs.NoOutput;
+            Int32sRef output = NO_OUTPUT;
 
             int l = offset + length;
             try
@@ -371,17 +371,17 @@ namespace Lucene.Net.Analysis.Hunspell
             stripOffsets[currentIndex] = currentOffset;
         }
 
-        private FST<IntsRef> AffixFST(SortedDictionary<string, IList<char?>> affixes)
+        private FST<Int32sRef> AffixFST(SortedDictionary<string, IList<char?>> affixes)
         {
-            IntSequenceOutputs outputs = IntSequenceOutputs.Singleton;
-            Builder<IntsRef> builder = new Builder<IntsRef>(FST.INPUT_TYPE.BYTE4, outputs);
+            Int32SequenceOutputs outputs = Int32SequenceOutputs.Singleton;
+            Builder<Int32sRef> builder = new Builder<Int32sRef>(FST.INPUT_TYPE.BYTE4, outputs);
 
-            IntsRef scratch = new IntsRef();
+            Int32sRef scratch = new Int32sRef();
             foreach (KeyValuePair<string, IList<char?>> entry in affixes)
             {
                 Lucene.Net.Util.Fst.Util.ToUTF32(entry.Key, scratch);
                 IList<char?> entries = entry.Value;
-                IntsRef output = new IntsRef(entries.Count);
+                Int32sRef output = new Int32sRef(entries.Count);
                 foreach (char? c in entries)
                 {
                     output.Int32s[output.Length++] = c.HasValue ? c.Value : 0;
@@ -566,7 +566,7 @@ namespace Lucene.Net.Analysis.Hunspell
 
             Outputs<CharsRef> outputs = CharSequenceOutputs.Singleton;
             Builder<CharsRef> builder = new Builder<CharsRef>(FST.INPUT_TYPE.BYTE2, outputs);
-            IntsRef scratchInts = new IntsRef();
+            Int32sRef scratchInts = new Int32sRef();
             foreach (KeyValuePair<string, string> entry in mappings)
             {
                 Lucene.Net.Util.Fst.Util.ToUTF16(entry.Key, scratchInts);
@@ -737,10 +737,10 @@ namespace Lucene.Net.Analysis.Hunspell
         /// <param name="decoder"> <see cref="Encoding"/> used to decode the contents of the file </param>
         /// <param name="words"></param>
         /// <exception cref="IOException"> Can be thrown while reading from the file </exception>
-        private void ReadDictionaryFiles(IList<Stream> dictionaries, Encoding decoder, Builder<IntsRef> words)
+        private void ReadDictionaryFiles(IList<Stream> dictionaries, Encoding decoder, Builder<Int32sRef> words)
         {
             BytesRef flagsScratch = new BytesRef();
-            IntsRef scratchInts = new IntsRef();
+            Int32sRef scratchInts = new Int32sRef();
 
             StringBuilder sb = new StringBuilder();
 
@@ -805,7 +805,7 @@ namespace Lucene.Net.Analysis.Hunspell
                 // either way the trick is to encode them as char... but they must be parsed differently
 
                 string currentEntry = null;
-                IntsRef currentOrds = new IntsRef();
+                Int32sRef currentOrds = new Int32sRef();
 
                 string line2;
                 while (reader.Read(scratchLine))
@@ -872,7 +872,7 @@ namespace Lucene.Net.Analysis.Hunspell
                         if (cmp > 0 || currentEntry == null)
                         {
                             currentEntry = entry;
-                            currentOrds = new IntsRef(); // must be this way
+                            currentOrds = new Int32sRef(); // must be this way
                         }
                         currentOrds.Grow(currentOrds.Length + 1);
                         currentOrds.Int32s[currentOrds.Length++] = ord;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Analysis.Common/Analysis/Hunspell/Stemmer.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Analysis.Common/Analysis/Hunspell/Stemmer.cs b/src/Lucene.Net.Analysis.Common/Analysis/Hunspell/Stemmer.cs
index 2c0d0d7..5feb587 100644
--- a/src/Lucene.Net.Analysis.Common/Analysis/Hunspell/Stemmer.cs
+++ b/src/Lucene.Net.Analysis.Common/Analysis/Hunspell/Stemmer.cs
@@ -83,7 +83,7 @@ namespace Lucene.Net.Analysis.Hunspell
             }
 
             List<CharsRef> stems = new List<CharsRef>();
-            IntsRef forms = dictionary.LookupWord(word, 0, length);
+            Int32sRef forms = dictionary.LookupWord(word, 0, length);
             if (forms != null)
             {
                 // TODO: some forms should not be added, e.g. ONLYINCOMPOUND
@@ -179,7 +179,7 @@ namespace Lucene.Net.Analysis.Hunspell
             {
                 for (int i = length - 1; i >= 0; i--)
                 {
-                    IntsRef prefixes = dictionary.LookupPrefix(word, 0, i);
+                    Int32sRef prefixes = dictionary.LookupPrefix(word, 0, i);
                     if (prefixes == null)
                     {
                         continue;
@@ -248,7 +248,7 @@ namespace Lucene.Net.Analysis.Hunspell
             {
                 for (int i = 0; i < length; i++)
                 {
-                    IntsRef suffixes = dictionary.LookupSuffix(word, i, length - i);
+                    Int32sRef suffixes = dictionary.LookupSuffix(word, i, length - i);
                     if (suffixes == null)
                     {
                         continue;
@@ -373,7 +373,7 @@ namespace Lucene.Net.Analysis.Hunspell
 
             List<CharsRef> stems = new List<CharsRef>();
 
-            IntsRef forms = dictionary.LookupWord(strippedWord, 0, length);
+            Int32sRef forms = dictionary.LookupWord(strippedWord, 0, length);
             if (forms != null)
             {
                 for (int i = 0; i < forms.Length; i++)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Analysis.Common/Analysis/Miscellaneous/StemmerOverrideFilter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Analysis.Common/Analysis/Miscellaneous/StemmerOverrideFilter.cs b/src/Lucene.Net.Analysis.Common/Analysis/Miscellaneous/StemmerOverrideFilter.cs
index 2eec23f..10139ea 100644
--- a/src/Lucene.Net.Analysis.Common/Analysis/Miscellaneous/StemmerOverrideFilter.cs
+++ b/src/Lucene.Net.Analysis.Common/Analysis/Miscellaneous/StemmerOverrideFilter.cs
@@ -216,7 +216,7 @@ namespace Lucene.Net.Analysis.Miscellaneous
                 ByteSequenceOutputs outputs = ByteSequenceOutputs.Singleton;
                 Builder<BytesRef> builder = new Builder<BytesRef>(FST.INPUT_TYPE.BYTE4, outputs);
                 int[] sort = hash.Sort(BytesRef.UTF8SortedAsUnicodeComparer);
-                IntsRef intsSpare = new IntsRef();
+                Int32sRef intsSpare = new Int32sRef();
                 int size = hash.Count;
                 for (int i = 0; i < size; i++)
                 {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Analysis.Common/Analysis/Synonym/SynonymMap.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Analysis.Common/Analysis/Synonym/SynonymMap.cs b/src/Lucene.Net.Analysis.Common/Analysis/Synonym/SynonymMap.cs
index ac487cd..8fd98ce 100644
--- a/src/Lucene.Net.Analysis.Common/Analysis/Synonym/SynonymMap.cs
+++ b/src/Lucene.Net.Analysis.Common/Analysis/Synonym/SynonymMap.cs
@@ -273,7 +273,7 @@ namespace Lucene.Net.Analysis.Synonym
 #pragma warning restore 612, 618
 
 
-                IntsRef scratchIntsRef = new IntsRef();
+                Int32sRef scratchIntsRef = new Int32sRef();
 
                 //System.out.println("fmap.build");
                 for (int keyIdx = 0; keyIdx < sortedKeys.Length; keyIdx++)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/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
index 4fdb5fe..3254635 100644
--- a/src/Lucene.Net.Codecs/BlockTerms/FixedGapTermsIndexReader.cs
+++ b/src/Lucene.Net.Codecs/BlockTerms/FixedGapTermsIndexReader.cs
@@ -341,12 +341,12 @@ namespace Lucene.Net.Codecs.BlockTerms
                 /// <summary>
                 /// Offset into index TermBytes
                 /// </summary>
-                internal PackedInts.Reader TermOffsets { get; private set; }
+                internal PackedInt32s.Reader TermOffsets { get; private set; }
 
                 /// <summary>
                 /// Index pointers into main terms dict
                 /// </summary>
-                internal PackedInts.Reader TermsDictOffsets { get; private set; }
+                internal PackedInt32s.Reader TermsDictOffsets { get; private set; }
 
                 internal int NumIndexTerms { get; private set; }
                 internal long TermsStart { get; private set; }
@@ -380,11 +380,11 @@ namespace Lucene.Net.Codecs.BlockTerms
                             fgtir._termBytes.Copy(clone, numTermBytes);
 
                             // records offsets into main terms dict file
-                            TermsDictOffsets = PackedInts.GetReader(clone);
+                            TermsDictOffsets = PackedInt32s.GetReader(clone);
                             Debug.Assert(TermsDictOffsets.Count == numIndexTerms);
 
                             // records offsets into byte[] term data
-                            TermOffsets = PackedInts.GetReader(clone);
+                            TermOffsets = PackedInt32s.GetReader(clone);
                             Debug.Assert(TermOffsets.Count == 1 + numIndexTerms);
                         }
                         finally
@@ -403,23 +403,23 @@ namespace Lucene.Net.Codecs.BlockTerms
                             // Subsample the index terms
                             clone1.Seek(packedIndexStart);
                             
-                            PackedInts.IReaderIterator termsDictOffsetsIter = PackedInts.GetReaderIterator(clone1,
-                                PackedInts.DEFAULT_BUFFER_SIZE);
+                            PackedInt32s.IReaderIterator termsDictOffsetsIter = PackedInt32s.GetReaderIterator(clone1,
+                                PackedInt32s.DEFAULT_BUFFER_SIZE);
 
                             clone2.Seek(packedOffsetsStart);
                             
-                            PackedInts.IReaderIterator termOffsetsIter = PackedInts.GetReaderIterator(clone2,
-                                PackedInts.DEFAULT_BUFFER_SIZE);
+                            PackedInt32s.IReaderIterator termOffsetsIter = PackedInt32s.GetReaderIterator(clone2,
+                                PackedInt32s.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(NumIndexTerms,
-                                termsDictOffsetsIter.BitsPerValue, PackedInts.DEFAULT);
-                            PackedInts.Mutable termOffsetsM = PackedInts.GetMutable(NumIndexTerms + 1,
-                                termOffsetsIter.BitsPerValue, PackedInts.DEFAULT);
+                            PackedInt32s.Mutable termsDictOffsetsM = PackedInt32s.GetMutable(NumIndexTerms,
+                                termsDictOffsetsIter.BitsPerValue, PackedInt32s.DEFAULT);
+                            PackedInt32s.Mutable termOffsetsM = PackedInt32s.GetMutable(NumIndexTerms + 1,
+                                termOffsetsIter.BitsPerValue, PackedInt32s.DEFAULT);
 
                             TermsDictOffsets = termsDictOffsetsM;
                             TermOffsets = termOffsetsM;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/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
index 39d3209..1e8fefb 100644
--- a/src/Lucene.Net.Codecs/BlockTerms/FixedGapTermsIndexWriter.cs
+++ b/src/Lucene.Net.Codecs/BlockTerms/FixedGapTermsIndexWriter.cs
@@ -192,9 +192,9 @@ namespace Lucene.Net.Codecs.BlockTerms
                 // write primary terms dict offsets
                 packedIndexStart = outerInstance.m_output.FilePointer;
 
-                PackedInts.Writer w = PackedInts.GetWriter(outerInstance.m_output, numIndexTerms,
-                    PackedInts.BitsRequired(termsFilePointer),
-                    PackedInts.DEFAULT);
+                PackedInt32s.Writer w = PackedInt32s.GetWriter(outerInstance.m_output, numIndexTerms,
+                    PackedInt32s.BitsRequired(termsFilePointer),
+                    PackedInt32s.DEFAULT);
 
                 // relative to our indexStart
                 long upto = 0;
@@ -208,8 +208,8 @@ namespace Lucene.Net.Codecs.BlockTerms
                 packedOffsetsStart = outerInstance.m_output.FilePointer;
 
                 // write offsets into the byte[] terms
-                w = PackedInts.GetWriter(outerInstance.m_output, 1 + numIndexTerms, PackedInts.BitsRequired(totTermLength),
-                    PackedInts.DEFAULT);
+                w = PackedInt32s.GetWriter(outerInstance.m_output, 1 + numIndexTerms, PackedInt32s.BitsRequired(totTermLength),
+                    PackedInt32s.DEFAULT);
                 upto = 0;
                 for (int i = 0; i < numIndexTerms; i++)
                 {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/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
index fb75734..b90c689 100644
--- a/src/Lucene.Net.Codecs/BlockTerms/VariableGapTermsIndexReader.cs
+++ b/src/Lucene.Net.Codecs/BlockTerms/VariableGapTermsIndexReader.cs
@@ -33,7 +33,7 @@ namespace Lucene.Net.Codecs.BlockTerms
     /// </summary>
     public class VariableGapTermsIndexReader : TermsIndexReaderBase
     {
-        private readonly PositiveIntOutputs _fstOutputs = PositiveIntOutputs.Singleton;
+        private readonly PositiveInt32Outputs _fstOutputs = PositiveInt32Outputs.Singleton;
         private readonly int _indexDivisor;
 
         private readonly IndexInput _input;       // Closed if indexLoaded is true:
@@ -207,8 +207,8 @@ namespace Lucene.Net.Codecs.BlockTerms
                 if (outerInstance._indexDivisor > 1)
                 {
                     // subsample
-                    var scratchIntsRef = new IntsRef();
-                    var outputs = PositiveIntOutputs.Singleton;
+                    var scratchIntsRef = new Int32sRef();
+                    var outputs = PositiveInt32Outputs.Singleton;
                     var builder = new Builder<long?>(FST.INPUT_TYPE.BYTE1, outputs);
                     var fstEnum = new BytesRefFSTEnum<long?>(fst);
                     var count = outerInstance._indexDivisor;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/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
index 1089fa8..fae7620 100644
--- a/src/Lucene.Net.Codecs/BlockTerms/VariableGapTermsIndexWriter.cs
+++ b/src/Lucene.Net.Codecs/BlockTerms/VariableGapTermsIndexWriter.cs
@@ -247,12 +247,12 @@ namespace Lucene.Net.Codecs.BlockTerms
             {
                 this.outerInstance = outerInstance;
                 FieldInfo = fieldInfo;
-                PositiveIntOutputs fstOutputs = PositiveIntOutputs.Singleton;
+                PositiveInt32Outputs fstOutputs = PositiveInt32Outputs.Singleton;
                 _fstBuilder = new Builder<long?>(FST.INPUT_TYPE.BYTE1, fstOutputs);
                 IndexStart = this.outerInstance.m_output.FilePointer;
 
                 // Always put empty string in
-                _fstBuilder.Add(new IntsRef(), termsFilePointer);
+                _fstBuilder.Add(new Int32sRef(), termsFilePointer);
                 _startTermsFilePointer = termsFilePointer;
             }
 
@@ -270,7 +270,7 @@ namespace Lucene.Net.Codecs.BlockTerms
                 return false;
             }
 
-            private readonly IntsRef _scratchIntsRef = new IntsRef();
+            private readonly Int32sRef _scratchIntsRef = new Int32sRef();
 
             public override void Add(BytesRef text, TermStats stats, long termsFilePointer)
             {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/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
index fa1c9b2..a216109 100644
--- a/src/Lucene.Net.Codecs/Memory/DirectDocValuesProducer.cs
+++ b/src/Lucene.Net.Codecs/Memory/DirectDocValuesProducer.cs
@@ -45,7 +45,7 @@ namespace Lucene.Net.Codecs.Memory
         private readonly IDictionary<int?, IBits> docsWithFieldInstances = new Dictionary<int?, IBits>();
 
         private readonly int maxDoc;
-        private readonly AtomicLong ramBytesUsed;
+        private readonly AtomicInt64 ramBytesUsed;
         private readonly int version;
 
         internal const sbyte NUMBER = 0;
@@ -63,7 +63,7 @@ namespace Lucene.Net.Codecs.Memory
             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(this.GetType()));
+            ramBytesUsed = new AtomicInt64(RamUsageEstimator.ShallowSizeOfInstance(this.GetType()));
             bool success = false;
             try
             {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/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
index 6ceb94c..f57f31f 100644
--- a/src/Lucene.Net.Codecs/Memory/FSTOrdTermsReader.cs
+++ b/src/Lucene.Net.Codecs/Memory/FSTOrdTermsReader.cs
@@ -79,7 +79,7 @@ namespace Lucene.Net.Codecs.Memory
                     long sumDocFreq = blockIn.ReadVInt64();
                     int docCount = blockIn.ReadVInt32();
                     int longsSize = blockIn.ReadVInt32();
-                    var index = new FST<long?>(indexIn, PositiveIntOutputs.Singleton);
+                    var index = new FST<long?>(indexIn, PositiveInt32Outputs.Singleton);
 
                     var current = new TermsReader(this, fieldInfo, blockIn, numTerms, sumTotalTermFreq, sumDocFreq, docCount, longsSize, index);
                     TermsReader previous;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/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
index c3ecb3d..d313348 100644
--- a/src/Lucene.Net.Codecs/Memory/FSTOrdTermsWriter.cs
+++ b/src/Lucene.Net.Codecs/Memory/FSTOrdTermsWriter.cs
@@ -29,9 +29,9 @@ namespace Lucene.Net.Codecs.Memory
     using IndexFileNames = Index.IndexFileNames;
     using IndexOptions = Index.IndexOptions;
     using IndexOutput = Store.IndexOutput;
-    using IntsRef = Util.IntsRef;
+    using Int32sRef = Util.Int32sRef;
     using IOUtils = Util.IOUtils;
-    using PositiveIntOutputs = Util.Fst.PositiveIntOutputs;
+    using PositiveInt32Outputs = Util.Fst.PositiveInt32Outputs;
     using RAMOutputStream = Store.RAMOutputStream;
     using SegmentWriteState = Index.SegmentWriteState;
     using Util = Util.Fst.Util;
@@ -275,12 +275,12 @@ namespace Lucene.Net.Codecs.Memory
             private readonly FSTOrdTermsWriter _outerInstance;
 
             private readonly Builder<long?> _builder;
-            private readonly PositiveIntOutputs _outputs;
+            private readonly PositiveInt32Outputs _outputs;
             private readonly FieldInfo _fieldInfo;
             private readonly int _longsSize;
             private long _numTerms;
 
-            private readonly IntsRef _scratchTerm = new IntsRef();
+            private readonly Int32sRef _scratchTerm = new Int32sRef();
             private readonly RAMOutputStream _statsOut = new RAMOutputStream();
             private readonly RAMOutputStream _metaLongsOut = new RAMOutputStream();
             private readonly RAMOutputStream _metaBytesOut = new RAMOutputStream();
@@ -300,7 +300,7 @@ namespace Lucene.Net.Codecs.Memory
                 _numTerms = 0;
                 _fieldInfo = fieldInfo;
                 _longsSize = outerInstance.postingsWriter.SetField(fieldInfo);
-                _outputs = PositiveIntOutputs.Singleton;
+                _outputs = PositiveInt32Outputs.Singleton;
                 _builder = new Builder<long?>(FST.INPUT_TYPE.BYTE1, _outputs);
 
                 _lastBlockStatsFp = 0;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/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
index 29cadfb..7f13d8c 100644
--- a/src/Lucene.Net.Codecs/Memory/FSTTermsWriter.cs
+++ b/src/Lucene.Net.Codecs/Memory/FSTTermsWriter.cs
@@ -28,7 +28,7 @@ namespace Lucene.Net.Codecs.Memory
     using IndexFileNames = Index.IndexFileNames;
     using IndexOptions = Index.IndexOptions;
     using IndexOutput = Store.IndexOutput;
-    using IntsRef = Util.IntsRef;
+    using Int32sRef = Util.Int32sRef;
     using IOUtils = Util.IOUtils;
     using RAMOutputStream = Store.RAMOutputStream;
     using SegmentWriteState = Index.SegmentWriteState;
@@ -238,7 +238,7 @@ namespace Lucene.Net.Codecs.Memory
             private readonly int _longsSize;
             private long _numTerms;
 
-            private readonly IntsRef _scratchTerm = new IntsRef();
+            private readonly Int32sRef _scratchTerm = new Int32sRef();
             private readonly RAMOutputStream _statsWriter = new RAMOutputStream();
             private readonly RAMOutputStream _metaWriter = new RAMOutputStream();
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/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
index 94224fc..aeb0237 100644
--- a/src/Lucene.Net.Codecs/Memory/MemoryDocValuesConsumer.cs
+++ b/src/Lucene.Net.Codecs/Memory/MemoryDocValuesConsumer.cs
@@ -29,16 +29,16 @@ namespace Lucene.Net.Codecs.Memory
     using ByteArrayDataOutput = Store.ByteArrayDataOutput;
     using BytesRef = Util.BytesRef;
     using FieldInfo = Index.FieldInfo;
-    using FormatAndBits = Util.Packed.PackedInts.FormatAndBits;
+    using FormatAndBits = Util.Packed.PackedInt32s.FormatAndBits;
     using IndexFileNames = Index.IndexFileNames;
     using IndexOutput = Store.IndexOutput;
     using INPUT_TYPE = Util.Fst.FST.INPUT_TYPE;
-    using IntsRef = Util.IntsRef;
+    using Int32sRef = Util.Int32sRef;
     using IOUtils = Util.IOUtils;
     using MathUtil = Util.MathUtil;
     using MonotonicBlockPackedWriter = Util.Packed.MonotonicBlockPackedWriter;
-    using PackedInts = Util.Packed.PackedInts;
-    using PositiveIntOutputs = Util.Fst.PositiveIntOutputs;
+    using PackedInt32s = Util.Packed.PackedInt32s;
+    using PositiveInt32Outputs = Util.Fst.PositiveInt32Outputs;
     using SegmentWriteState = Index.SegmentWriteState;
     using Util = Util.Fst.Util;
 
@@ -161,8 +161,8 @@ namespace Lucene.Net.Codecs.Memory
             {
                 // small number of unique values
 
-                int bitsPerValue = PackedInts.BitsRequired(uniqueValues.Count - 1);
-                FormatAndBits formatAndBits = PackedInts.FastestFormatAndBits(maxDoc, bitsPerValue,
+                int bitsPerValue = PackedInt32s.BitsRequired(uniqueValues.Count - 1);
+                FormatAndBits formatAndBits = PackedInt32s.FastestFormatAndBits(maxDoc, bitsPerValue,
                     acceptableOverheadRatio);
                 if (formatAndBits.BitsPerValue == 8 && minValue >= sbyte.MinValue && maxValue <= sbyte.MaxValue)
                 {
@@ -185,12 +185,12 @@ namespace Lucene.Net.Codecs.Memory
                         encode[decode[i]] = i;
                     }
 
-                    meta.WriteVInt32(PackedInts.VERSION_CURRENT);
+                    meta.WriteVInt32(PackedInt32s.VERSION_CURRENT);
                     data.WriteVInt32(formatAndBits.Format.Id);
                     data.WriteVInt32(formatAndBits.BitsPerValue);
 
-                    PackedInts.Writer writer = PackedInts.GetWriterNoHeader(data, formatAndBits.Format, maxDoc,
-                        formatAndBits.BitsPerValue, PackedInts.DEFAULT_BUFFER_SIZE);
+                    PackedInt32s.Writer writer = PackedInt32s.GetWriterNoHeader(data, formatAndBits.Format, maxDoc,
+                        formatAndBits.BitsPerValue, PackedInt32s.DEFAULT_BUFFER_SIZE);
                     foreach (var nv in values)
                     {
                         var v = encode[nv.HasValue ? nv.Value : 0];
@@ -203,7 +203,7 @@ namespace Lucene.Net.Codecs.Memory
             else if (gcd != 0 && gcd != 1)
             {
                 meta.WriteByte(MemoryDocValuesProducer.GCD_COMPRESSED);
-                meta.WriteVInt32(PackedInts.VERSION_CURRENT);
+                meta.WriteVInt32(PackedInt32s.VERSION_CURRENT);
                 data.WriteInt64(minValue);
                 data.WriteInt64(gcd);
                 data.WriteVInt32(MemoryDocValuesProducer.BLOCK_SIZE);
@@ -219,7 +219,7 @@ namespace Lucene.Net.Codecs.Memory
             {
                 meta.WriteByte(MemoryDocValuesProducer.DELTA_COMPRESSED); // delta-compressed
 
-                meta.WriteVInt32(PackedInts.VERSION_CURRENT);
+                meta.WriteVInt32(PackedInt32s.VERSION_CURRENT);
                 data.WriteVInt32(MemoryDocValuesProducer.BLOCK_SIZE);
 
                 var writer = new BlockPackedWriter(data, MemoryDocValuesProducer.BLOCK_SIZE);
@@ -317,7 +317,7 @@ namespace Lucene.Net.Codecs.Memory
             // otherwise, we need to record the length fields...
             if (minLength != maxLength)
             {
-                meta.WriteVInt32(PackedInts.VERSION_CURRENT);
+                meta.WriteVInt32(PackedInt32s.VERSION_CURRENT);
                 meta.WriteVInt32(MemoryDocValuesProducer.BLOCK_SIZE);
 
 
@@ -340,9 +340,9 @@ namespace Lucene.Net.Codecs.Memory
             meta.WriteVInt32(field.Number);
             meta.WriteByte(MemoryDocValuesProducer.FST);
             meta.WriteInt64(data.FilePointer);
-            PositiveIntOutputs outputs = PositiveIntOutputs.Singleton;
+            PositiveInt32Outputs outputs = PositiveInt32Outputs.Singleton;
             var builder = new Builder<long?>(INPUT_TYPE.BYTE1, outputs);
-            var scratch = new IntsRef();
+            var scratch = new Int32sRef();
             long ord = 0;
             foreach (BytesRef v in values)
             {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/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
index 80a8b34..9393198 100644
--- a/src/Lucene.Net.Codecs/Memory/MemoryDocValuesFormat.cs
+++ b/src/Lucene.Net.Codecs/Memory/MemoryDocValuesFormat.cs
@@ -34,7 +34,7 @@ namespace Lucene.Net.Codecs.Memory
         /// MemoryDocValuesFormat(PackedInts.DEFAULT)} 
         /// </summary>
         public MemoryDocValuesFormat() 
-            : this(PackedInts.DEFAULT)
+            : this(PackedInt32s.DEFAULT)
         {
         }
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/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
index cab8547..7fd6ca2 100644
--- a/src/Lucene.Net.Codecs/Memory/MemoryDocValuesProducer.cs
+++ b/src/Lucene.Net.Codecs/Memory/MemoryDocValuesProducer.cs
@@ -48,7 +48,7 @@ namespace Lucene.Net.Codecs.Memory
         private readonly IDictionary<int?, IBits> docsWithFieldInstances = new Dictionary<int?, IBits>();
 
         private readonly int maxDoc;
-        private readonly AtomicLong ramBytesUsed;
+        private readonly AtomicInt64 ramBytesUsed;
         private readonly int version;
 
         internal const byte NUMBER = 0;
@@ -93,7 +93,7 @@ namespace Lucene.Net.Codecs.Memory
                     CodecUtil.CheckEOF(@in);
 #pragma warning restore 612, 618
                 }
-                ramBytesUsed = new AtomicLong(RamUsageEstimator.ShallowSizeOfInstance(this.GetType()));
+                ramBytesUsed = new AtomicInt64(RamUsageEstimator.ShallowSizeOfInstance(this.GetType()));
                 success = true;
             }
             finally
@@ -251,7 +251,7 @@ namespace Lucene.Net.Codecs.Memory
                     }
                     int formatID = data.ReadVInt32();
                     int bitsPerValue = data.ReadVInt32();
-                    var ordsReader = PackedInts.GetReaderNoHeader(data, PackedInts.Format.ById(formatID),
+                    var ordsReader = PackedInt32s.GetReaderNoHeader(data, PackedInt32s.Format.ById(formatID),
                         entry.packedIntsVersion, maxDoc, bitsPerValue);
                     ramBytesUsed.AddAndGet(RamUsageEstimator.SizeOf(decode) + ordsReader.RamBytesUsed());
                     return new NumericDocValuesAnonymousInnerClassHelper(this, decode, ordsReader);
@@ -285,10 +285,10 @@ namespace Lucene.Net.Codecs.Memory
             private readonly MemoryDocValuesProducer outerInstance;
 
             private readonly long[] decode;
-            private readonly PackedInts.Reader ordsReader;
+            private readonly PackedInt32s.Reader ordsReader;
 
             public NumericDocValuesAnonymousInnerClassHelper(MemoryDocValuesProducer outerInstance, long[] decode,
-                PackedInts.Reader ordsReader)
+                PackedInt32s.Reader ordsReader)
             {
                 this.outerInstance = outerInstance;
                 this.decode = decode;
@@ -429,7 +429,7 @@ namespace Lucene.Net.Codecs.Memory
                 if (!fstInstances.TryGetValue(field.Number, out instance))
                 {
                     data.Seek(entry.offset);
-                    instance = new FST<long?>(data, PositiveIntOutputs.Singleton);
+                    instance = new FST<long?>(data, PositiveInt32Outputs.Singleton);
                     ramBytesUsed.AddAndGet(instance.SizeInBytes());
                     fstInstances[field.Number] = instance;
                 }
@@ -441,7 +441,7 @@ namespace Lucene.Net.Codecs.Memory
             var @in = fst.GetBytesReader();
             var firstArc = new FST.Arc<long?>();
             var scratchArc = new FST.Arc<long?>();
-            var scratchInts = new IntsRef();
+            var scratchInts = new Int32sRef();
             var fstEnum = new BytesRefFSTEnum<long?>(fst);
 
             return new SortedDocValuesAnonymousInnerClassHelper(entry, docToOrd, fst, @in, firstArc, scratchArc,
@@ -456,12 +456,12 @@ namespace Lucene.Net.Codecs.Memory
             private readonly FST.BytesReader @in;
             private readonly FST.Arc<long?> firstArc;
             private readonly FST.Arc<long?> scratchArc;
-            private readonly IntsRef scratchInts;
+            private readonly Int32sRef scratchInts;
             private readonly BytesRefFSTEnum<long?> fstEnum;
 
             public SortedDocValuesAnonymousInnerClassHelper(FSTEntry fstEntry,
                 NumericDocValues numericDocValues, FST<long?> fst1, FST.BytesReader @in, FST.Arc<long?> arc, FST.Arc<long?> scratchArc1,
-                IntsRef intsRef, BytesRefFSTEnum<long?> bytesRefFstEnum)
+                Int32sRef intsRef, BytesRefFSTEnum<long?> bytesRefFstEnum)
             {
                 entry = fstEntry;
                 docToOrd = numericDocValues;
@@ -484,7 +484,7 @@ namespace Lucene.Net.Codecs.Memory
                 {
                     @in.Position = 0;
                     fst.GetFirstArc(firstArc);
-                    IntsRef output = Util.GetByOutput(fst, ord, @in, firstArc, scratchArc, scratchInts);
+                    Int32sRef output = Util.GetByOutput(fst, ord, @in, firstArc, scratchArc, scratchInts);
                     result.Bytes = new byte[output.Length];
                     result.Offset = 0;
                     result.Length = 0;
@@ -544,7 +544,7 @@ namespace Lucene.Net.Codecs.Memory
                 if (!fstInstances.TryGetValue(field.Number, out instance))
                 {
                     data.Seek(entry.offset);
-                    instance = new FST<long?>(data, PositiveIntOutputs.Singleton);
+                    instance = new FST<long?>(data, PositiveInt32Outputs.Singleton);
                     ramBytesUsed.AddAndGet(instance.SizeInBytes());
                     fstInstances[field.Number] = instance;
                 }
@@ -556,7 +556,7 @@ namespace Lucene.Net.Codecs.Memory
             var @in = fst.GetBytesReader();
             var firstArc = new FST.Arc<long?>();
             var scratchArc = new FST.Arc<long?>();
-            var scratchInts = new IntsRef();
+            var scratchInts = new Int32sRef();
             var fstEnum = new BytesRefFSTEnum<long?>(fst);
             var @ref = new BytesRef();
             var input = new ByteArrayDataInput();
@@ -572,7 +572,7 @@ namespace Lucene.Net.Codecs.Memory
             private readonly FST.BytesReader @in;
             private readonly FST.Arc<long?> firstArc;
             private readonly FST.Arc<long?> scratchArc;
-            private readonly IntsRef scratchInts;
+            private readonly Int32sRef scratchInts;
             private readonly BytesRefFSTEnum<long?> fstEnum;
             private readonly BytesRef @ref;
             private readonly ByteArrayDataInput input;
@@ -580,7 +580,7 @@ namespace Lucene.Net.Codecs.Memory
             private long currentOrd;
 
             public SortedSetDocValuesAnonymousInnerClassHelper(FSTEntry fstEntry, BinaryDocValues binaryDocValues, FST<long?> fst1,
-                FST.BytesReader @in, FST.Arc<long?> arc, FST.Arc<long?> scratchArc1, IntsRef intsRef, BytesRefFSTEnum<long?> bytesRefFstEnum,
+                FST.BytesReader @in, FST.Arc<long?> arc, FST.Arc<long?> scratchArc1, Int32sRef intsRef, BytesRefFSTEnum<long?> bytesRefFstEnum,
                 BytesRef @ref, ByteArrayDataInput byteArrayDataInput)
             {
                 entry = fstEntry;
@@ -621,7 +621,7 @@ namespace Lucene.Net.Codecs.Memory
                 {
                     @in.Position = 0;
                     fst.GetFirstArc(firstArc);
-                    IntsRef output = Util.GetByOutput(fst, ord, @in, firstArc, scratchArc, scratchInts);
+                    Int32sRef output = Util.GetByOutput(fst, ord, @in, firstArc, scratchArc, scratchInts);
                     result.Bytes = new byte[output.Length];
                     result.Offset = 0;
                     result.Length = 0;
@@ -762,7 +762,7 @@ namespace Lucene.Net.Codecs.Memory
             private readonly FST.BytesReader bytesReader;
             private readonly FST.Arc<long?> firstArc = new FST.Arc<long?>();
             private readonly FST.Arc<long?> scratchArc = new FST.Arc<long?>();
-            private readonly IntsRef scratchInts = new IntsRef();
+            private readonly Int32sRef scratchInts = new Int32sRef();
             private readonly BytesRef scratchBytes = new BytesRef();
 
             internal FSTTermsEnum(FST<long?> fst)
@@ -812,7 +812,7 @@ namespace Lucene.Net.Codecs.Memory
                 // but we dont want to introduce a bug that corrupts our enum state!
                 bytesReader.Position = 0;
                 fst.GetFirstArc(firstArc);
-                IntsRef output = Util.GetByOutput(fst, ord, bytesReader, firstArc, scratchArc, scratchInts);
+                Int32sRef output = Util.GetByOutput(fst, ord, bytesReader, firstArc, scratchArc, scratchInts);
                 scratchBytes.Bytes = new byte[output.Length];
                 scratchBytes.Offset = 0;
                 scratchBytes.Length = 0;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/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
index 50e1116..9ed0949 100644
--- a/src/Lucene.Net.Codecs/Memory/MemoryPostingsFormat.cs
+++ b/src/Lucene.Net.Codecs/Memory/MemoryPostingsFormat.cs
@@ -37,10 +37,10 @@ namespace Lucene.Net.Codecs.Memory
     using IndexInput = Store.IndexInput;
     using IndexOptions = Index.IndexOptions;
     using IndexOutput = Store.IndexOutput;
-    using IntsRef = Util.IntsRef;
+    using Int32sRef = Util.Int32sRef;
     using IOContext = Store.IOContext;
     using IOUtils = Util.IOUtils;
-    using PackedInts = Util.Packed.PackedInts;
+    using PackedInt32s = Util.Packed.PackedInt32s;
     using RAMOutputStream = Store.RAMOutputStream;
     using RamUsageEstimator = Util.RamUsageEstimator;
     using SegmentReadState = Index.SegmentReadState;
@@ -77,7 +77,7 @@ namespace Lucene.Net.Codecs.Memory
         private readonly float acceptableOverheadRatio;
 
         public MemoryPostingsFormat() 
-            : this(false, PackedInts.DEFAULT)
+            : this(false, PackedInt32s.DEFAULT)
         {
         }
 
@@ -248,7 +248,7 @@ namespace Lucene.Net.Codecs.Memory
             private readonly BytesRef spare = new BytesRef();
             private byte[] finalBuffer = new byte[128];
 
-            private readonly IntsRef scratchIntsRef = new IntsRef();
+            private readonly Int32sRef scratchIntsRef = new Int32sRef();
 
             public override void FinishTerm(BytesRef text, TermStats stats)
             {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/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
index fbe26ba..09bde88 100644
--- a/src/Lucene.Net.Codecs/SimpleText/SimpleTextFieldsReader.cs
+++ b/src/Lucene.Net.Codecs/SimpleText/SimpleTextFieldsReader.cs
@@ -38,9 +38,9 @@ namespace Lucene.Net.Codecs.SimpleText
     using IBits = Util.IBits;
     using IndexInput = Store.IndexInput;
     using IndexOptions = Index.IndexOptions;
-    using IntsRef = Util.IntsRef;
+    using Int32sRef = Util.Int32sRef;
     using IOUtils = Util.IOUtils;
-    using PositiveIntOutputs = Util.Fst.PositiveIntOutputs;
+    using PositiveInt32Outputs = Util.Fst.PositiveInt32Outputs;
     using SegmentReadState = Index.SegmentReadState;
     using StringHelper = Util.StringHelper;
     using Terms = Index.Terms;
@@ -596,7 +596,7 @@ namespace Lucene.Net.Codecs.SimpleText
 
             private void LoadTerms()
             {
-                var posIntOutputs = PositiveIntOutputs.Singleton;
+                var posIntOutputs = PositiveInt32Outputs.Singleton;
                 var outputsInner = new PairOutputs<long?, long?>(posIntOutputs, posIntOutputs);
                 var outputs = new PairOutputs<long?, PairOutputs<long?,long?>.Pair>(posIntOutputs, outputsInner);
                 
@@ -611,7 +611,7 @@ namespace Lucene.Net.Codecs.SimpleText
                 long totalTermFreq = 0;
                 var visitedDocs = new FixedBitSet(_maxDoc);
 
-                var scratchIntsRef = new IntsRef();
+                var scratchIntsRef = new Int32sRef();
                 while (true)
                 {
                     SimpleTextUtil.ReadLine(input, _scratch);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Codecs/BlockTreeTermsWriter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/BlockTreeTermsWriter.cs b/src/Lucene.Net.Core/Codecs/BlockTreeTermsWriter.cs
index 4541d1d..b026cbf 100644
--- a/src/Lucene.Net.Core/Codecs/BlockTreeTermsWriter.cs
+++ b/src/Lucene.Net.Core/Codecs/BlockTreeTermsWriter.cs
@@ -31,10 +31,10 @@ namespace Lucene.Net.Codecs
     using IndexFileNames = Lucene.Net.Index.IndexFileNames;
     using IndexOptions = Lucene.Net.Index.IndexOptions;
     using IndexOutput = Lucene.Net.Store.IndexOutput;
-    using IntsRef = Lucene.Net.Util.IntsRef;
+    using Int32sRef = Lucene.Net.Util.Int32sRef;
     using IOUtils = Lucene.Net.Util.IOUtils;
     using NoOutputs = Lucene.Net.Util.Fst.NoOutputs;
-    using PackedInts = Lucene.Net.Util.Packed.PackedInts;
+    using PackedInt32s = Lucene.Net.Util.Packed.PackedInt32s;
     using RAMOutputStream = Lucene.Net.Store.RAMOutputStream;
     using SegmentWriteState = Lucene.Net.Index.SegmentWriteState;
     using Util = Lucene.Net.Util.Fst.Util;
@@ -413,7 +413,7 @@ namespace Lucene.Net.Codecs
             public bool HasTerms { get; private set; }
             public bool IsFloor { get; private set; }
             public int FloorLeadByte { get; private set; }
-            private readonly IntsRef scratchIntsRef = new IntsRef();
+            private readonly Int32sRef scratchIntsRef = new Int32sRef();
 
             public PendingBlock(BytesRef prefix, long fp, bool hasTerms, bool isFloor, int floorLeadByte, IList<FST<BytesRef>> subIndices)
                 : base(false)
@@ -457,7 +457,7 @@ namespace Lucene.Net.Codecs
                 }
 
                 ByteSequenceOutputs outputs = ByteSequenceOutputs.Singleton;
-                Builder<BytesRef> indexBuilder = new Builder<BytesRef>(FST.INPUT_TYPE.BYTE1, 0, 0, true, false, int.MaxValue, outputs, null, false, PackedInts.COMPACT, true, 15);
+                Builder<BytesRef> indexBuilder = new Builder<BytesRef>(FST.INPUT_TYPE.BYTE1, 0, 0, true, false, int.MaxValue, outputs, null, false, PackedInt32s.COMPACT, true, 15);
                 var bytes = new byte[(int)scratchBytes.FilePointer];
                 Debug.Assert(bytes.Length > 0);
                 scratchBytes.WriteTo(bytes, 0);
@@ -562,7 +562,7 @@ namespace Lucene.Net.Codecs
                     this.outerInstance = outerInstance;
                 }
 
-                public override void Freeze(Builder.UnCompiledNode<object>[] frontier, int prefixLenPlus1, IntsRef lastInput)
+                public override void Freeze(Builder.UnCompiledNode<object>[] frontier, int prefixLenPlus1, Int32sRef lastInput)
                 {
                     //if (DEBUG) System.out.println("  freeze prefixLenPlus1=" + prefixLenPlus1);
 
@@ -617,7 +617,7 @@ namespace Lucene.Net.Codecs
             // primary (initial) block and then one or more
             // following floor blocks:
 
-            internal virtual void WriteBlocks(IntsRef prevTerm, int prefixLength, int count)
+            internal virtual void WriteBlocks(Int32sRef prevTerm, int prefixLength, int count)
             {
                 if (prefixLength == 0 || count <= outerInstance.maxItemsInBlock)
                 {
@@ -874,7 +874,7 @@ namespace Lucene.Net.Codecs
 
             // Writes all entries in the pending slice as a single
             // block:
-            private PendingBlock WriteBlock(IntsRef prevTerm, int prefixLength, int indexPrefixLength, int startBackwards, int length, int futureTermCount, bool isFloor, int floorLeadByte, bool isLastInFloor)
+            private PendingBlock WriteBlock(Int32sRef prevTerm, int prefixLength, int indexPrefixLength, int startBackwards, int length, int futureTermCount, bool isFloor, int floorLeadByte, bool isLastInFloor)
             {
                 Debug.Assert(length > 0);
 
@@ -1104,7 +1104,7 @@ namespace Lucene.Net.Codecs
                 // this Builder is just used transiently to fragment
                 // terms into "good" blocks; we don't save the
                 // resulting FST:
-                blockBuilder = new Builder<object>(FST.INPUT_TYPE.BYTE1, 0, 0, true, true, int.MaxValue, noOutputs, new FindBlocks(this), false, PackedInts.COMPACT, true, 15);
+                blockBuilder = new Builder<object>(FST.INPUT_TYPE.BYTE1, 0, 0, true, true, int.MaxValue, noOutputs, new FindBlocks(this), false, PackedInt32s.COMPACT, true, 15);
 
                 this.longsSize = outerInstance.postingsWriter.SetField(fieldInfo);
             }
@@ -1131,7 +1131,7 @@ namespace Lucene.Net.Codecs
                 return outerInstance.postingsWriter;
             }
 
-            private readonly IntsRef scratchIntsRef = new IntsRef();
+            private readonly Int32sRef scratchIntsRef = new Int32sRef();
 
             public override void FinishTerm(BytesRef text, TermStats stats)
             {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Codecs/Compressing/CompressingStoredFieldsIndexReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/Compressing/CompressingStoredFieldsIndexReader.cs b/src/Lucene.Net.Core/Codecs/Compressing/CompressingStoredFieldsIndexReader.cs
index 7a07078..a27fc40 100644
--- a/src/Lucene.Net.Core/Codecs/Compressing/CompressingStoredFieldsIndexReader.cs
+++ b/src/Lucene.Net.Core/Codecs/Compressing/CompressingStoredFieldsIndexReader.cs
@@ -22,7 +22,7 @@ namespace Lucene.Net.Codecs.Compressing
 
     using CorruptIndexException = Lucene.Net.Index.CorruptIndexException;
     using IndexInput = Lucene.Net.Store.IndexInput;
-    using PackedInts = Lucene.Net.Util.Packed.PackedInts;
+    using PackedInt32s = Lucene.Net.Util.Packed.PackedInt32s;
     using RamUsageEstimator = Lucene.Net.Util.RamUsageEstimator;
     using SegmentInfo = Lucene.Net.Index.SegmentInfo;
 
@@ -42,8 +42,8 @@ namespace Lucene.Net.Codecs.Compressing
         internal readonly long[] startPointers;
         internal readonly int[] avgChunkDocs;
         internal readonly long[] avgChunkSizes;
-        internal readonly PackedInts.Reader[] docBasesDeltas; // delta from the avg
-        internal readonly PackedInts.Reader[] startPointersDeltas; // delta from the avg
+        internal readonly PackedInt32s.Reader[] docBasesDeltas; // delta from the avg
+        internal readonly PackedInt32s.Reader[] startPointersDeltas; // delta from the avg
 
         // It is the responsibility of the caller to close fieldsIndexIn after this constructor
         // has been called
@@ -54,8 +54,8 @@ namespace Lucene.Net.Codecs.Compressing
             long[] startPointers = new long[16];
             int[] avgChunkDocs = new int[16];
             long[] avgChunkSizes = new long[16];
-            PackedInts.Reader[] docBasesDeltas = new PackedInts.Reader[16];
-            PackedInts.Reader[] startPointersDeltas = new PackedInts.Reader[16];
+            PackedInt32s.Reader[] docBasesDeltas = new PackedInt32s.Reader[16];
+            PackedInt32s.Reader[] startPointersDeltas = new PackedInt32s.Reader[16];
 
             int packedIntsVersion = fieldsIndexIn.ReadVInt32();
 
@@ -87,7 +87,7 @@ namespace Lucene.Net.Codecs.Compressing
                 {
                     throw new CorruptIndexException("Corrupted bitsPerDocBase (resource=" + fieldsIndexIn + ")");
                 }
-                docBasesDeltas[blockCount] = PackedInts.GetReaderNoHeader(fieldsIndexIn, PackedInts.Format.PACKED, packedIntsVersion, numChunks, bitsPerDocBase);
+                docBasesDeltas[blockCount] = PackedInt32s.GetReaderNoHeader(fieldsIndexIn, PackedInt32s.Format.PACKED, packedIntsVersion, numChunks, bitsPerDocBase);
 
                 // start pointers
                 startPointers[blockCount] = fieldsIndexIn.ReadVInt64();
@@ -97,7 +97,7 @@ namespace Lucene.Net.Codecs.Compressing
                 {
                     throw new CorruptIndexException("Corrupted bitsPerStartPointer (resource=" + fieldsIndexIn + ")");
                 }
-                startPointersDeltas[blockCount] = PackedInts.GetReaderNoHeader(fieldsIndexIn, PackedInts.Format.PACKED, packedIntsVersion, numChunks, bitsPerStartPointer);
+                startPointersDeltas[blockCount] = PackedInt32s.GetReaderNoHeader(fieldsIndexIn, PackedInt32s.Format.PACKED, packedIntsVersion, numChunks, bitsPerStartPointer);
 
                 ++blockCount;
             }
@@ -190,11 +190,11 @@ namespace Lucene.Net.Codecs.Compressing
         {
             long res = 0;
 
-            foreach (PackedInts.Reader r in docBasesDeltas)
+            foreach (PackedInt32s.Reader r in docBasesDeltas)
             {
                 res += r.RamBytesUsed();
             }
-            foreach (PackedInts.Reader r in startPointersDeltas)
+            foreach (PackedInt32s.Reader r in startPointersDeltas)
             {
                 res += r.RamBytesUsed();
             }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Codecs/Compressing/CompressingStoredFieldsIndexWriter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/Compressing/CompressingStoredFieldsIndexWriter.cs b/src/Lucene.Net.Core/Codecs/Compressing/CompressingStoredFieldsIndexWriter.cs
index 6d7ce28..981e476 100644
--- a/src/Lucene.Net.Core/Codecs/Compressing/CompressingStoredFieldsIndexWriter.cs
+++ b/src/Lucene.Net.Core/Codecs/Compressing/CompressingStoredFieldsIndexWriter.cs
@@ -21,7 +21,7 @@ namespace Lucene.Net.Codecs.Compressing
      */
 
     using IndexOutput = Lucene.Net.Store.IndexOutput;
-    using PackedInts = Lucene.Net.Util.Packed.PackedInts;
+    using PackedInt32s = Lucene.Net.Util.Packed.PackedInt32s;
 
     /// <summary>
     /// Efficient index format for block-based <seealso cref="Codec"/>s.
@@ -36,7 +36,7 @@ namespace Lucene.Net.Codecs.Compressing
     /// <p>Data is written as follows:</p>
     /// <ul>
     /// <li>PackedIntsVersion, &lt;Block&gt;<sup>BlockCount</sup>, BlocksEndMarker</li>
-    /// <li>PackedIntsVersion --&gt; <seealso cref="PackedInts#VERSION_CURRENT"/> as a <seealso cref="DataOutput#writeVInt VInt"/></li>
+    /// <li>PackedIntsVersion --&gt; <seealso cref="PackedInt32s#VERSION_CURRENT"/> as a <seealso cref="DataOutput#writeVInt VInt"/></li>
     /// <li>BlocksEndMarker --&gt; <tt>0</tt> as a <seealso cref="DataOutput#writeVInt VInt"/>, this marks the end of blocks since blocks are not allowed to start with <tt>0</tt></li>
     /// <li>Block --&gt; BlockChunks, &lt;DocBases&gt;, &lt;StartPointers&gt;</li>
     /// <li>BlockChunks --&gt; a <seealso cref="DataOutput#writeVInt VInt"/> which is the number of chunks encoded in the block</li>
@@ -44,12 +44,12 @@ namespace Lucene.Net.Codecs.Compressing
     /// <li>DocBase --&gt; first document ID of the block of chunks, as a <seealso cref="DataOutput#writeVInt VInt"/></li>
     /// <li>AvgChunkDocs --&gt; average number of documents in a single chunk, as a <seealso cref="DataOutput#writeVInt VInt"/></li>
     /// <li>BitsPerDocBaseDelta --&gt; number of bits required to represent a delta from the average using <a href="https://developers.google.com/protocol-buffers/docs/encoding#types">ZigZag encoding</a></li>
-    /// <li>DocBaseDeltas --&gt; <seealso cref="PackedInts packed"/> array of BlockChunks elements of BitsPerDocBaseDelta bits each, representing the deltas from the average doc base using <a href="https://developers.google.com/protocol-buffers/docs/encoding#types">ZigZag encoding</a>.</li>
+    /// <li>DocBaseDeltas --&gt; <seealso cref="PackedInt32s packed"/> array of BlockChunks elements of BitsPerDocBaseDelta bits each, representing the deltas from the average doc base using <a href="https://developers.google.com/protocol-buffers/docs/encoding#types">ZigZag encoding</a>.</li>
     /// <li>StartPointers --&gt; StartPointerBase, AvgChunkSize, BitsPerStartPointerDelta, StartPointerDeltas</li>
     /// <li>StartPointerBase --&gt; the first start pointer of the block, as a <seealso cref="DataOutput#writeVLong VLong"/></li>
     /// <li>AvgChunkSize --&gt; the average size of a chunk of compressed documents, as a <seealso cref="DataOutput#writeVLong VLong"/></li>
     /// <li>BitsPerStartPointerDelta --&gt; number of bits required to represent a delta from the average using <a href="https://developers.google.com/protocol-buffers/docs/encoding#types">ZigZag encoding</a></li>
-    /// <li>StartPointerDeltas --&gt; <seealso cref="PackedInts packed"/> array of BlockChunks elements of BitsPerStartPointerDelta bits each, representing the deltas from the average start pointer using <a href="https://developers.google.com/protocol-buffers/docs/encoding#types">ZigZag encoding</a></li>
+    /// <li>StartPointerDeltas --&gt; <seealso cref="PackedInt32s packed"/> array of BlockChunks elements of BitsPerStartPointerDelta bits each, representing the deltas from the average start pointer using <a href="https://developers.google.com/protocol-buffers/docs/encoding#types">ZigZag encoding</a></li>
     /// <li>Footer --&gt; <seealso cref="CodecUtil#writeFooter CodecFooter"/></li>
     /// </ul>
     /// <p>Notes</p>
@@ -90,7 +90,7 @@ namespace Lucene.Net.Codecs.Compressing
             totalDocs = 0;
             docBaseDeltas = new int[BLOCK_SIZE];
             startPointerDeltas = new long[BLOCK_SIZE];
-            fieldsIndexOut.WriteVInt32(PackedInts.VERSION_CURRENT);
+            fieldsIndexOut.WriteVInt32(PackedInt32s.VERSION_CURRENT);
         }
 
         private void Reset()
@@ -133,14 +133,14 @@ namespace Lucene.Net.Codecs.Compressing
                 docBase += docBaseDeltas[i];
             }
 
-            int bitsPerDocBase = PackedInts.BitsRequired(maxDelta);
+            int bitsPerDocBase = PackedInt32s.BitsRequired(maxDelta);
             fieldsIndexOut.WriteVInt32(bitsPerDocBase);
-            PackedInts.Writer writer = PackedInts.GetWriterNoHeader(fieldsIndexOut, PackedInts.Format.PACKED, blockChunks, bitsPerDocBase, 1);
+            PackedInt32s.Writer writer = PackedInt32s.GetWriterNoHeader(fieldsIndexOut, PackedInt32s.Format.PACKED, blockChunks, bitsPerDocBase, 1);
             docBase = 0;
             for (int i = 0; i < blockChunks; ++i)
             {
                 long delta = docBase - avgChunkDocs * i;
-                Debug.Assert(PackedInts.BitsRequired(MoveSignToLowOrderBit(delta)) <= writer.BitsPerValue);
+                Debug.Assert(PackedInt32s.BitsRequired(MoveSignToLowOrderBit(delta)) <= writer.BitsPerValue);
                 writer.Add(MoveSignToLowOrderBit(delta));
                 docBase += docBaseDeltas[i];
             }
@@ -167,15 +167,15 @@ namespace Lucene.Net.Codecs.Compressing
                 maxDelta |= MoveSignToLowOrderBit(delta);
             }
 
-            int bitsPerStartPointer = PackedInts.BitsRequired(maxDelta);
+            int bitsPerStartPointer = PackedInt32s.BitsRequired(maxDelta);
             fieldsIndexOut.WriteVInt32(bitsPerStartPointer);
-            writer = PackedInts.GetWriterNoHeader(fieldsIndexOut, PackedInts.Format.PACKED, blockChunks, bitsPerStartPointer, 1);
+            writer = PackedInt32s.GetWriterNoHeader(fieldsIndexOut, PackedInt32s.Format.PACKED, blockChunks, bitsPerStartPointer, 1);
             startPointer = 0;
             for (int i = 0; i < blockChunks; ++i)
             {
                 startPointer += startPointerDeltas[i];
                 long delta = startPointer - avgChunkSize * i;
-                Debug.Assert(PackedInts.BitsRequired(MoveSignToLowOrderBit(delta)) <= writer.BitsPerValue);
+                Debug.Assert(PackedInt32s.BitsRequired(MoveSignToLowOrderBit(delta)) <= writer.BitsPerValue);
                 writer.Add(MoveSignToLowOrderBit(delta));
             }
             writer.Finish();

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Codecs/Compressing/CompressingStoredFieldsReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/Compressing/CompressingStoredFieldsReader.cs b/src/Lucene.Net.Core/Codecs/Compressing/CompressingStoredFieldsReader.cs
index 7d82d35..6fcb5e9 100644
--- a/src/Lucene.Net.Core/Codecs/Compressing/CompressingStoredFieldsReader.cs
+++ b/src/Lucene.Net.Core/Codecs/Compressing/CompressingStoredFieldsReader.cs
@@ -37,7 +37,7 @@ namespace Lucene.Net.Codecs.Compressing
     using IndexInput = Lucene.Net.Store.IndexInput;
     using IOContext = Lucene.Net.Store.IOContext;
     using IOUtils = Lucene.Net.Util.IOUtils;
-    using PackedInts = Lucene.Net.Util.Packed.PackedInts;
+    using PackedInt32s = Lucene.Net.Util.Packed.PackedInt32s;
     using SegmentInfo = Lucene.Net.Index.SegmentInfo;
     using StoredFieldVisitor = Lucene.Net.Index.StoredFieldVisitor;
 
@@ -282,9 +282,9 @@ namespace Lucene.Net.Codecs.Compressing
                 else
                 {
                     long filePointer = fieldsStream.FilePointer;
-                    PackedInts.Reader reader = PackedInts.GetDirectReaderNoHeader(fieldsStream, PackedInts.Format.PACKED, packedIntsVersion, chunkDocs, bitsPerStoredFields);
+                    PackedInt32s.Reader reader = PackedInt32s.GetDirectReaderNoHeader(fieldsStream, PackedInt32s.Format.PACKED, packedIntsVersion, chunkDocs, bitsPerStoredFields);
                     numStoredFields = (int)(reader.Get(docID - docBase));
-                    fieldsStream.Seek(filePointer + PackedInts.Format.PACKED.ByteCount(packedIntsVersion, chunkDocs, bitsPerStoredFields));
+                    fieldsStream.Seek(filePointer + PackedInt32s.Format.PACKED.ByteCount(packedIntsVersion, chunkDocs, bitsPerStoredFields));
                 }
 
                 int bitsPerLength = fieldsStream.ReadVInt32();
@@ -300,7 +300,7 @@ namespace Lucene.Net.Codecs.Compressing
                 }
                 else
                 {
-                    PackedInts.IReaderIterator it = PackedInts.GetReaderIteratorNoHeader(fieldsStream, PackedInts.Format.PACKED, packedIntsVersion, chunkDocs, bitsPerLength, 1);
+                    PackedInt32s.IReaderIterator it = PackedInt32s.GetReaderIteratorNoHeader(fieldsStream, PackedInt32s.Format.PACKED, packedIntsVersion, chunkDocs, bitsPerLength, 1);
                     int off = 0;
                     for (int i = 0; i < docID - docBase; ++i)
                     {
@@ -541,7 +541,7 @@ namespace Lucene.Net.Codecs.Compressing
                     }
                     else
                     {
-                        PackedInts.IReaderIterator it = PackedInts.GetReaderIteratorNoHeader(fieldsStream, PackedInts.Format.PACKED, outerInstance.packedIntsVersion, chunkDocs, bitsPerStoredFields, 1);
+                        PackedInt32s.IReaderIterator it = PackedInt32s.GetReaderIteratorNoHeader(fieldsStream, PackedInt32s.Format.PACKED, outerInstance.packedIntsVersion, chunkDocs, bitsPerStoredFields, 1);
                         for (int i = 0; i < chunkDocs; ++i)
                         {
                             numStoredFields[i] = (int)it.Next();
@@ -559,7 +559,7 @@ namespace Lucene.Net.Codecs.Compressing
                     }
                     else
                     {
-                        PackedInts.IReaderIterator it = PackedInts.GetReaderIteratorNoHeader(fieldsStream, PackedInts.Format.PACKED, outerInstance.packedIntsVersion, chunkDocs, bitsPerLength, 1);
+                        PackedInt32s.IReaderIterator it = PackedInt32s.GetReaderIteratorNoHeader(fieldsStream, PackedInt32s.Format.PACKED, outerInstance.packedIntsVersion, chunkDocs, bitsPerLength, 1);
                         for (int i = 0; i < chunkDocs; ++i)
                         {
                             lengths[i] = (int)it.Next();

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Codecs/Compressing/CompressingStoredFieldsWriter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/Compressing/CompressingStoredFieldsWriter.cs b/src/Lucene.Net.Core/Codecs/Compressing/CompressingStoredFieldsWriter.cs
index b1f722e..1097cb2 100644
--- a/src/Lucene.Net.Core/Codecs/Compressing/CompressingStoredFieldsWriter.cs
+++ b/src/Lucene.Net.Core/Codecs/Compressing/CompressingStoredFieldsWriter.cs
@@ -43,8 +43,8 @@ namespace Lucene.Net.Codecs.Compressing
         internal const int NUMERIC_LONG = 0x04;
         internal const int NUMERIC_DOUBLE = 0x05;
 
-        internal static readonly int TYPE_BITS = PackedInts.BitsRequired(NUMERIC_DOUBLE);
-        internal static readonly int TYPE_MASK = (int)PackedInts.MaxValue(TYPE_BITS);
+        internal static readonly int TYPE_BITS = PackedInt32s.BitsRequired(NUMERIC_DOUBLE);
+        internal static readonly int TYPE_MASK = (int)PackedInt32s.MaxValue(TYPE_BITS);
 
         internal const string CODEC_SFX_IDX = "Index";
         internal const string CODEC_SFX_DAT = "Data";
@@ -103,7 +103,7 @@ namespace Lucene.Net.Codecs.Compressing
                 indexStream = null;
 
                 fieldsStream.WriteVInt32(chunkSize);
-                fieldsStream.WriteVInt32(PackedInts.VERSION_CURRENT);
+                fieldsStream.WriteVInt32(PackedInt32s.VERSION_CURRENT);
 
                 success = true;
             }
@@ -187,9 +187,9 @@ namespace Lucene.Net.Codecs.Compressing
                     {
                         max |= (uint)values[i];
                     }
-                    int bitsRequired = PackedInts.BitsRequired(max);
+                    int bitsRequired = PackedInt32s.BitsRequired(max);
                     @out.WriteVInt32(bitsRequired);
-                    PackedInts.Writer w = PackedInts.GetWriterNoHeader(@out, PackedInts.Format.PACKED, length, bitsRequired, 1);
+                    PackedInt32s.Writer w = PackedInt32s.GetWriterNoHeader(@out, PackedInt32s.Format.PACKED, length, bitsRequired, 1);
                     for (int i = 0; i < length; ++i)
                     {
                         w.Add(values[i]);


[09/53] [abbrv] lucenenet git commit: Lucene.Net.Core: Renamed all type-derived properties and methods from Short, Int, Long, and Float to match CLR types Int16, Int32, Int64, and Single, respectively.

Posted by ni...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Codecs/Lucene41/Lucene41PostingsReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/Lucene41/Lucene41PostingsReader.cs b/src/Lucene.Net.Core/Codecs/Lucene41/Lucene41PostingsReader.cs
index c2f137b..d32ec16 100644
--- a/src/Lucene.Net.Core/Codecs/Lucene41/Lucene41PostingsReader.cs
+++ b/src/Lucene.Net.Core/Codecs/Lucene41/Lucene41PostingsReader.cs
@@ -85,7 +85,7 @@ namespace Lucene.Net.Codecs.Lucene41
         {
             // Make sure we are talking to the matching postings writer
             CodecUtil.CheckHeader(termsIn, Lucene41PostingsWriter.TERMS_CODEC, Lucene41PostingsWriter.VERSION_START, Lucene41PostingsWriter.VERSION_CURRENT);
-            int indexBlockSize = termsIn.ReadVInt();
+            int indexBlockSize = termsIn.ReadVInt32();
             if (indexBlockSize != Lucene41PostingsFormat.BLOCK_SIZE)
             {
                 throw new InvalidOperationException("index-time BLOCK_SIZE (" + indexBlockSize + ") != read-time BLOCK_SIZE (" + Lucene41PostingsFormat.BLOCK_SIZE + ")");
@@ -94,14 +94,16 @@ namespace Lucene.Net.Codecs.Lucene41
 
         /// <summary>
         /// Read values that have been written using variable-length encoding instead of bit-packing.
+        /// <para/>
+        /// NOTE: This was readVIntBlock() in Lucene
         /// </summary>
-        internal static void ReadVIntBlock(IndexInput docIn, int[] docBuffer, int[] freqBuffer, int num, bool indexHasFreq)
+        internal static void ReadVInt32Block(IndexInput docIn, int[] docBuffer, int[] freqBuffer, int num, bool indexHasFreq)
         {
             if (indexHasFreq)
             {
                 for (int i = 0; i < num; i++)
                 {
-                    int code = docIn.ReadVInt();
+                    int code = docIn.ReadVInt32();
                     docBuffer[i] = (int)((uint)code >> 1);
                     if ((code & 1) != 0)
                     {
@@ -109,7 +111,7 @@ namespace Lucene.Net.Codecs.Lucene41
                     }
                     else
                     {
-                        freqBuffer[i] = docIn.ReadVInt();
+                        freqBuffer[i] = docIn.ReadVInt32();
                     }
                 }
             }
@@ -117,7 +119,7 @@ namespace Lucene.Net.Codecs.Lucene41
             {
                 for (int i = 0; i < num; i++)
                 {
-                    docBuffer[i] = docIn.ReadVInt();
+                    docBuffer[i] = docIn.ReadVInt32();
                 }
             }
         }
@@ -162,7 +164,7 @@ namespace Lucene.Net.Codecs.Lucene41
             }
             if (termState2.DocFreq == 1)
             {
-                termState2.singletonDocID = @in.ReadVInt();
+                termState2.singletonDocID = @in.ReadVInt32();
             }
             else
             {
@@ -172,7 +174,7 @@ namespace Lucene.Net.Codecs.Lucene41
             {
                 if (termState2.TotalTermFreq > Lucene41PostingsFormat.BLOCK_SIZE)
                 {
-                    termState2.lastPosBlockOffset = @in.ReadVLong();
+                    termState2.lastPosBlockOffset = @in.ReadVInt64();
                 }
                 else
                 {
@@ -181,7 +183,7 @@ namespace Lucene.Net.Codecs.Lucene41
             }
             if (termState2.DocFreq > Lucene41PostingsFormat.BLOCK_SIZE)
             {
-                termState2.skipOffset = @in.ReadVLong();
+                termState2.skipOffset = @in.ReadVInt64();
             }
             else
             {
@@ -196,19 +198,19 @@ namespace Lucene.Net.Codecs.Lucene41
             bool fieldHasPayloads = fieldInfo.HasPayloads;
             if (termState.DocFreq == 1)
             {
-                termState.singletonDocID = @in.ReadVInt();
+                termState.singletonDocID = @in.ReadVInt32();
             }
             else
             {
                 termState.singletonDocID = -1;
-                termState.docStartFP += @in.ReadVLong();
+                termState.docStartFP += @in.ReadVInt64();
             }
             if (fieldHasPositions)
             {
-                termState.posStartFP += @in.ReadVLong();
+                termState.posStartFP += @in.ReadVInt64();
                 if (termState.TotalTermFreq > Lucene41PostingsFormat.BLOCK_SIZE)
                 {
-                    termState.lastPosBlockOffset = @in.ReadVLong();
+                    termState.lastPosBlockOffset = @in.ReadVInt64();
                 }
                 else
                 {
@@ -216,12 +218,12 @@ namespace Lucene.Net.Codecs.Lucene41
                 }
                 if ((fieldHasPayloads || fieldHasOffsets) && termState.TotalTermFreq >= Lucene41PostingsFormat.BLOCK_SIZE)
                 {
-                    termState.payStartFP += @in.ReadVLong();
+                    termState.payStartFP += @in.ReadVInt64();
                 }
             }
             if (termState.DocFreq > Lucene41PostingsFormat.BLOCK_SIZE)
             {
-                termState.skipOffset = @in.ReadVLong();
+                termState.skipOffset = @in.ReadVInt64();
             }
             else
             {
@@ -436,7 +438,7 @@ namespace Lucene.Net.Codecs.Lucene41
                     // if (DEBUG) {
                     //   System.out.println("    fill last vInt block from fp=" + docIn.getFilePointer());
                     // }
-                    ReadVIntBlock(docIn, docDeltaBuffer, freqBuffer, left, indexHasFreq);
+                    ReadVInt32Block(docIn, docDeltaBuffer, freqBuffer, left, indexHasFreq);
                 }
                 docBufferUpto = 0;
             }
@@ -758,7 +760,7 @@ namespace Lucene.Net.Codecs.Lucene41
                     // if (DEBUG) {
                     //   System.out.println("    fill last vInt doc block from fp=" + docIn.getFilePointer());
                     // }
-                    ReadVIntBlock(docIn, docDeltaBuffer, freqBuffer, left, true);
+                    ReadVInt32Block(docIn, docDeltaBuffer, freqBuffer, left, true);
                 }
                 docBufferUpto = 0;
             }
@@ -777,12 +779,12 @@ namespace Lucene.Net.Codecs.Lucene41
                     int payloadLength = 0;
                     for (int i = 0; i < count; i++)
                     {
-                        int code = posIn.ReadVInt();
+                        int code = posIn.ReadVInt32();
                         if (indexHasPayloads)
                         {
                             if ((code & 1) != 0)
                             {
-                                payloadLength = posIn.ReadVInt();
+                                payloadLength = posIn.ReadVInt32();
                             }
                             posDeltaBuffer[i] = (int)((uint)code >> 1);
                             if (payloadLength != 0)
@@ -796,10 +798,10 @@ namespace Lucene.Net.Codecs.Lucene41
                         }
                         if (indexHasOffsets)
                         {
-                            if ((posIn.ReadVInt() & 1) != 0)
+                            if ((posIn.ReadVInt32() & 1) != 0)
                             {
                                 // offset length changed
-                                posIn.ReadVInt();
+                                posIn.ReadVInt32();
                             }
                         }
                     }
@@ -1272,7 +1274,7 @@ namespace Lucene.Net.Codecs.Lucene41
                     // if (DEBUG) {
                     //   System.out.println("    fill last vInt doc block from fp=" + docIn.getFilePointer());
                     // }
-                    ReadVIntBlock(docIn, docDeltaBuffer, freqBuffer, left, true);
+                    ReadVInt32Block(docIn, docDeltaBuffer, freqBuffer, left, true);
                 }
                 docBufferUpto = 0;
             }
@@ -1293,12 +1295,12 @@ namespace Lucene.Net.Codecs.Lucene41
                     payloadByteUpto = 0;
                     for (int i = 0; i < count; i++)
                     {
-                        int code = posIn.ReadVInt();
+                        int code = posIn.ReadVInt32();
                         if (indexHasPayloads)
                         {
                             if ((code & 1) != 0)
                             {
-                                payloadLength = posIn.ReadVInt();
+                                payloadLength = posIn.ReadVInt32();
                             }
                             // if (DEBUG) {
                             //   System.out.println("        i=" + i + " payloadLen=" + payloadLength);
@@ -1326,10 +1328,10 @@ namespace Lucene.Net.Codecs.Lucene41
                             // if (DEBUG) {
                             //   System.out.println("        i=" + i + " read offsets from posIn.fp=" + posIn.getFilePointer());
                             // }
-                            int deltaCode = posIn.ReadVInt();
+                            int deltaCode = posIn.ReadVInt32();
                             if ((deltaCode & 1) != 0)
                             {
-                                offsetLength = posIn.ReadVInt();
+                                offsetLength = posIn.ReadVInt32();
                             }
                             offsetStartDeltaBuffer[i] = (int)((uint)deltaCode >> 1);
                             offsetLengthBuffer[i] = offsetLength;
@@ -1355,7 +1357,7 @@ namespace Lucene.Net.Codecs.Lucene41
                         if (needsPayloads)
                         {
                             outerInstance.forUtil.ReadBlock(payIn, encoded, payloadLengthBuffer);
-                            int numBytes = payIn.ReadVInt();
+                            int numBytes = payIn.ReadVInt32();
                             // if (DEBUG) {
                             //   System.out.println("        " + numBytes + " payload bytes @ pay.fp=" + payIn.getFilePointer());
                             // }
@@ -1369,7 +1371,7 @@ namespace Lucene.Net.Codecs.Lucene41
                         {
                             // this works, because when writing a vint block we always force the first length to be written
                             outerInstance.forUtil.SkipBlock(payIn); // skip over lengths
-                            int numBytes = payIn.ReadVInt(); // read length of payloadBytes
+                            int numBytes = payIn.ReadVInt32(); // read length of payloadBytes
                             payIn.Seek(payIn.FilePointer + numBytes); // skip over payloadBytes
                         }
                         payloadByteUpto = 0;
@@ -1590,7 +1592,7 @@ namespace Lucene.Net.Codecs.Lucene41
                             outerInstance.forUtil.SkipBlock(payIn);
 
                             // Skip payloadBytes block:
-                            int numBytes = payIn.ReadVInt();
+                            int numBytes = payIn.ReadVInt32();
                             payIn.Seek(payIn.FilePointer + numBytes);
                         }
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Codecs/Lucene41/Lucene41PostingsWriter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/Lucene41/Lucene41PostingsWriter.cs b/src/Lucene.Net.Core/Codecs/Lucene41/Lucene41PostingsWriter.cs
index af77eb9..68abbed 100644
--- a/src/Lucene.Net.Core/Codecs/Lucene41/Lucene41PostingsWriter.cs
+++ b/src/Lucene.Net.Core/Codecs/Lucene41/Lucene41PostingsWriter.cs
@@ -238,7 +238,7 @@ namespace Lucene.Net.Codecs.Lucene41
         public override void Init(IndexOutput termsOut)
         {
             CodecUtil.WriteHeader(termsOut, TERMS_CODEC, VERSION_CURRENT);
-            termsOut.WriteVInt(Lucene41PostingsFormat.BLOCK_SIZE);
+            termsOut.WriteVInt32(Lucene41PostingsFormat.BLOCK_SIZE);
         }
 
         public override int SetField(FieldInfo fieldInfo)
@@ -391,7 +391,7 @@ namespace Lucene.Net.Codecs.Lucene41
                 if (fieldHasPayloads)
                 {
                     forUtil.WriteBlock(payloadLengthBuffer, encoded, payOut);
-                    payOut.WriteVInt(payloadByteUpto);
+                    payOut.WriteVInt32(payloadByteUpto);
                     payOut.WriteBytes(payloadBytes, 0, payloadByteUpto);
                     payloadByteUpto = 0;
                 }
@@ -467,16 +467,16 @@ namespace Lucene.Net.Codecs.Lucene41
                     int freq = freqBuffer[i];
                     if (!fieldHasFreqs)
                     {
-                        docOut.WriteVInt(docDelta);
+                        docOut.WriteVInt32(docDelta);
                     }
                     else if (freqBuffer[i] == 1)
                     {
-                        docOut.WriteVInt((docDelta << 1) | 1);
+                        docOut.WriteVInt32((docDelta << 1) | 1);
                     }
                     else
                     {
-                        docOut.WriteVInt(docDelta << 1);
-                        docOut.WriteVInt(freq);
+                        docOut.WriteVInt32(docDelta << 1);
+                        docOut.WriteVInt32(freq);
                     }
                 }
             }
@@ -523,12 +523,12 @@ namespace Lucene.Net.Codecs.Lucene41
                             if (payloadLength != lastPayloadLength)
                             {
                                 lastPayloadLength = payloadLength;
-                                posOut.WriteVInt((posDelta << 1) | 1);
-                                posOut.WriteVInt(payloadLength);
+                                posOut.WriteVInt32((posDelta << 1) | 1);
+                                posOut.WriteVInt32(payloadLength);
                             }
                             else
                             {
-                                posOut.WriteVInt(posDelta << 1);
+                                posOut.WriteVInt32(posDelta << 1);
                             }
 
                             // if (DEBUG) {
@@ -546,7 +546,7 @@ namespace Lucene.Net.Codecs.Lucene41
                         }
                         else
                         {
-                            posOut.WriteVInt(posDelta);
+                            posOut.WriteVInt32(posDelta);
                         }
 
                         if (fieldHasOffsets)
@@ -558,12 +558,12 @@ namespace Lucene.Net.Codecs.Lucene41
                             int length = offsetLengthBuffer[i];
                             if (length == lastOffsetLength)
                             {
-                                posOut.WriteVInt(delta << 1);
+                                posOut.WriteVInt32(delta << 1);
                             }
                             else
                             {
-                                posOut.WriteVInt(delta << 1 | 1);
-                                posOut.WriteVInt(length);
+                                posOut.WriteVInt32(delta << 1 | 1);
+                                posOut.WriteVInt32(length);
                                 lastOffsetLength = length;
                             }
                         }
@@ -633,18 +633,18 @@ namespace Lucene.Net.Codecs.Lucene41
             }
             if (state2.singletonDocID != -1)
             {
-                @out.WriteVInt(state2.singletonDocID);
+                @out.WriteVInt32(state2.singletonDocID);
             }
             if (fieldHasPositions)
             {
                 if (state2.lastPosBlockOffset != -1)
                 {
-                    @out.WriteVLong(state2.lastPosBlockOffset);
+                    @out.WriteVInt64(state2.lastPosBlockOffset);
                 }
             }
             if (state2.skipOffset != -1)
             {
-                @out.WriteVLong(state2.skipOffset);
+                @out.WriteVInt64(state2.skipOffset);
             }
             lastState = state2;
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Codecs/Lucene41/Lucene41SkipReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/Lucene41/Lucene41SkipReader.cs b/src/Lucene.Net.Core/Codecs/Lucene41/Lucene41SkipReader.cs
index 264f746..675777e 100644
--- a/src/Lucene.Net.Core/Codecs/Lucene41/Lucene41SkipReader.cs
+++ b/src/Lucene.Net.Core/Codecs/Lucene41/Lucene41SkipReader.cs
@@ -239,34 +239,34 @@ namespace Lucene.Net.Codecs.Lucene41
             // if (DEBUG) {
             //   System.out.println("readSkipData level=" + level);
             // }
-            int delta = skipStream.ReadVInt();
+            int delta = skipStream.ReadVInt32();
             // if (DEBUG) {
             //   System.out.println("  delta=" + delta);
             // }
-            docPointer[level] += skipStream.ReadVInt();
+            docPointer[level] += skipStream.ReadVInt32();
             // if (DEBUG) {
             //   System.out.println("  docFP=" + docPointer[level]);
             // }
 
             if (posPointer != null)
             {
-                posPointer[level] += skipStream.ReadVInt();
+                posPointer[level] += skipStream.ReadVInt32();
                 // if (DEBUG) {
                 //   System.out.println("  posFP=" + posPointer[level]);
                 // }
-                posBufferUpto[level] = skipStream.ReadVInt();
+                posBufferUpto[level] = skipStream.ReadVInt32();
                 // if (DEBUG) {
                 //   System.out.println("  posBufferUpto=" + posBufferUpto[level]);
                 // }
 
                 if (payloadByteUpto != null)
                 {
-                    payloadByteUpto[level] = skipStream.ReadVInt();
+                    payloadByteUpto[level] = skipStream.ReadVInt32();
                 }
 
                 if (payPointer != null)
                 {
-                    payPointer[level] += skipStream.ReadVInt();
+                    payPointer[level] += skipStream.ReadVInt32();
                 }
             }
             return delta;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Codecs/Lucene41/Lucene41SkipWriter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/Lucene41/Lucene41SkipWriter.cs b/src/Lucene.Net.Core/Codecs/Lucene41/Lucene41SkipWriter.cs
index ae9eafe..c8bebc6 100644
--- a/src/Lucene.Net.Core/Codecs/Lucene41/Lucene41SkipWriter.cs
+++ b/src/Lucene.Net.Core/Codecs/Lucene41/Lucene41SkipWriter.cs
@@ -131,10 +131,10 @@ namespace Lucene.Net.Codecs.Lucene41
             // if (DEBUG) {
             //   System.out.println("writeSkipData level=" + level + " lastDoc=" + curDoc + " delta=" + delta + " curDocPointer=" + curDocPointer);
             // }
-            skipBuffer.WriteVInt(delta);
+            skipBuffer.WriteVInt32(delta);
             lastSkipDoc[level] = curDoc;
 
-            skipBuffer.WriteVInt((int)(curDocPointer - lastSkipDocPointer[level]));
+            skipBuffer.WriteVInt32((int)(curDocPointer - lastSkipDocPointer[level]));
             lastSkipDocPointer[level] = curDocPointer;
 
             if (fieldHasPositions)
@@ -142,18 +142,18 @@ namespace Lucene.Net.Codecs.Lucene41
                 // if (DEBUG) {
                 //   System.out.println("  curPosPointer=" + curPosPointer + " curPosBufferUpto=" + curPosBufferUpto);
                 // }
-                skipBuffer.WriteVInt((int)(curPosPointer - lastSkipPosPointer[level]));
+                skipBuffer.WriteVInt32((int)(curPosPointer - lastSkipPosPointer[level]));
                 lastSkipPosPointer[level] = curPosPointer;
-                skipBuffer.WriteVInt(curPosBufferUpto);
+                skipBuffer.WriteVInt32(curPosBufferUpto);
 
                 if (fieldHasPayloads)
                 {
-                    skipBuffer.WriteVInt(curPayloadByteUpto);
+                    skipBuffer.WriteVInt32(curPayloadByteUpto);
                 }
 
                 if (fieldHasOffsets || fieldHasPayloads)
                 {
-                    skipBuffer.WriteVInt((int)(curPayPointer - lastSkipPayPointer[level]));
+                    skipBuffer.WriteVInt32((int)(curPayPointer - lastSkipPayPointer[level]));
                     lastSkipPayPointer[level] = curPayPointer;
                 }
             }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Codecs/Lucene42/Lucene42DocValuesProducer.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/Lucene42/Lucene42DocValuesProducer.cs b/src/Lucene.Net.Core/Codecs/Lucene42/Lucene42DocValuesProducer.cs
index 0f81a18..a6b1ed0 100644
--- a/src/Lucene.Net.Core/Codecs/Lucene42/Lucene42DocValuesProducer.cs
+++ b/src/Lucene.Net.Core/Codecs/Lucene42/Lucene42DocValuesProducer.cs
@@ -155,7 +155,7 @@ namespace Lucene.Net.Codecs.Lucene42
 
         private void ReadFields(IndexInput meta, FieldInfos infos)
         {
-            int fieldNumber = meta.ReadVInt();
+            int fieldNumber = meta.ReadVInt32();
             while (fieldNumber != -1)
             {
                 // check should be: infos.fieldInfo(fieldNumber) != null, which incorporates negative check
@@ -169,7 +169,7 @@ namespace Lucene.Net.Codecs.Lucene42
                 int fieldType = meta.ReadByte();
                 if (fieldType == NUMBER)
                 {
-                    var entry = new NumericEntry {Offset = meta.ReadLong(), Format = (sbyte)meta.ReadByte()};
+                    var entry = new NumericEntry {Offset = meta.ReadInt64(), Format = (sbyte)meta.ReadByte()};
                     switch (entry.Format)
                     {
                         case DELTA_COMPRESSED:
@@ -183,36 +183,36 @@ namespace Lucene.Net.Codecs.Lucene42
                     }
                     if (entry.Format != UNCOMPRESSED)
                     {
-                        entry.PackedIntsVersion = meta.ReadVInt();
+                        entry.PackedInt32sVersion = meta.ReadVInt32();
                     }
                     numerics[fieldNumber] = entry;
                 }
                 else if (fieldType == BYTES)
                 {
                     BinaryEntry entry = new BinaryEntry();
-                    entry.Offset = meta.ReadLong();
-                    entry.NumBytes = meta.ReadLong();
-                    entry.MinLength = meta.ReadVInt();
-                    entry.MaxLength = meta.ReadVInt();
+                    entry.Offset = meta.ReadInt64();
+                    entry.NumBytes = meta.ReadInt64();
+                    entry.MinLength = meta.ReadVInt32();
+                    entry.MaxLength = meta.ReadVInt32();
                     if (entry.MinLength != entry.MaxLength)
                     {
-                        entry.PackedIntsVersion = meta.ReadVInt();
-                        entry.BlockSize = meta.ReadVInt();
+                        entry.PackedInt32sVersion = meta.ReadVInt32();
+                        entry.BlockSize = meta.ReadVInt32();
                     }
                     binaries[fieldNumber] = entry;
                 }
                 else if (fieldType == FST)
                 {
                     FSTEntry entry = new FSTEntry();
-                    entry.Offset = meta.ReadLong();
-                    entry.NumOrds = meta.ReadVLong();
+                    entry.Offset = meta.ReadInt64();
+                    entry.NumOrds = meta.ReadVInt64();
                     fsts[fieldNumber] = entry;
                 }
                 else
                 {
                     throw new CorruptIndexException("invalid entry type: " + fieldType + ", input=" + meta);
                 }
-                fieldNumber = meta.ReadVInt();
+                fieldNumber = meta.ReadVInt32();
             }
         }
 
@@ -251,7 +251,7 @@ namespace Lucene.Net.Codecs.Lucene42
             switch (entry.Format)
             {
                 case TABLE_COMPRESSED:
-                    int size = data.ReadVInt();
+                    int size = data.ReadVInt32();
                     if (size > 256)
                     {
                         throw new CorruptIndexException("TABLE_COMPRESSED cannot have more than 256 distinct values, input=" + data);
@@ -259,17 +259,17 @@ namespace Lucene.Net.Codecs.Lucene42
                     var decode = new long[size];
                     for (int i = 0; i < decode.Length; i++)
                     {
-                        decode[i] = data.ReadLong();
+                        decode[i] = data.ReadInt64();
                     }
-                    int formatID = data.ReadVInt();
-                    int bitsPerValue = data.ReadVInt();
-                    PackedInts.Reader ordsReader = PackedInts.GetReaderNoHeader(data, PackedInts.Format.ById(formatID), entry.PackedIntsVersion, maxDoc, bitsPerValue);
+                    int formatID = data.ReadVInt32();
+                    int bitsPerValue = data.ReadVInt32();
+                    PackedInts.Reader ordsReader = PackedInts.GetReaderNoHeader(data, PackedInts.Format.ById(formatID), entry.PackedInt32sVersion, maxDoc, bitsPerValue);
                     ramBytesUsed.AddAndGet(RamUsageEstimator.SizeOf(decode) + ordsReader.RamBytesUsed());
                     return new NumericDocValuesAnonymousInnerClassHelper(decode, ordsReader);
 
                 case DELTA_COMPRESSED:
-                    int blockSize = data.ReadVInt();
-                    var reader = new BlockPackedReader(data, entry.PackedIntsVersion, blockSize, maxDoc, false);
+                    int blockSize = data.ReadVInt32();
+                    var reader = new BlockPackedReader(data, entry.PackedInt32sVersion, blockSize, maxDoc, false);
                     ramBytesUsed.AddAndGet(reader.RamBytesUsed());
                     return reader;
 
@@ -280,10 +280,10 @@ namespace Lucene.Net.Codecs.Lucene42
                     return new NumericDocValuesAnonymousInnerClassHelper2(this, bytes);
 
                 case GCD_COMPRESSED:
-                    long min = data.ReadLong();
-                    long mult = data.ReadLong();
-                    int quotientBlockSize = data.ReadVInt();
-                    BlockPackedReader quotientReader = new BlockPackedReader(data, entry.PackedIntsVersion, quotientBlockSize, maxDoc, false);
+                    long min = data.ReadInt64();
+                    long mult = data.ReadInt64();
+                    int quotientBlockSize = data.ReadVInt32();
+                    BlockPackedReader quotientReader = new BlockPackedReader(data, entry.PackedInt32sVersion, quotientBlockSize, maxDoc, false);
                     ramBytesUsed.AddAndGet(quotientReader.RamBytesUsed());
                     return new NumericDocValuesAnonymousInnerClassHelper3(min, mult, quotientReader);
 
@@ -372,7 +372,7 @@ namespace Lucene.Net.Codecs.Lucene42
             }
             else
             {
-                MonotonicBlockPackedReader addresses = new MonotonicBlockPackedReader(data, entry.PackedIntsVersion, entry.BlockSize, maxDoc, false);
+                MonotonicBlockPackedReader addresses = new MonotonicBlockPackedReader(data, entry.PackedInt32sVersion, entry.BlockSize, maxDoc, false);
                 ramBytesUsed.AddAndGet(bytes.RamBytesUsed() + addresses.RamBytesUsed());
                 return new BinaryDocValuesAnonymousInnerClassHelper2(bytesReader, addresses);
             }
@@ -594,7 +594,7 @@ namespace Lucene.Net.Codecs.Lucene42
                 }
                 else
                 {
-                    currentOrd += input.ReadVLong();
+                    currentOrd += input.ReadVInt64();
                     return currentOrd;
                 }
             }
@@ -686,7 +686,11 @@ namespace Lucene.Net.Codecs.Lucene42
         {
             internal long Offset { get; set; }
             internal sbyte Format { get; set; }
-            internal int PackedIntsVersion { get; set; }
+
+            /// <summary>
+            /// NOTE: This was packedIntsVersion (field) in Lucene
+            /// </summary>
+            internal int PackedInt32sVersion { get; set; }
         }
 
         internal class BinaryEntry
@@ -695,7 +699,11 @@ namespace Lucene.Net.Codecs.Lucene42
             internal long NumBytes { get; set; }
             internal int MinLength { get; set; }
             internal int MaxLength { get; set; }
-            internal int PackedIntsVersion { get; set; }
+
+            /// <summary>
+            /// NOTE: This was packedIntsVersion (field) in Lucene
+            /// </summary>
+            internal int PackedInt32sVersion { get; set; }
             internal int BlockSize { get; set; }
         }
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Codecs/Lucene42/Lucene42FieldInfosReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/Lucene42/Lucene42FieldInfosReader.cs b/src/Lucene.Net.Core/Codecs/Lucene42/Lucene42FieldInfosReader.cs
index 2b5e14a..b663a87 100644
--- a/src/Lucene.Net.Core/Codecs/Lucene42/Lucene42FieldInfosReader.cs
+++ b/src/Lucene.Net.Core/Codecs/Lucene42/Lucene42FieldInfosReader.cs
@@ -57,13 +57,13 @@ namespace Lucene.Net.Codecs.Lucene42
             {
                 CodecUtil.CheckHeader(input, Lucene42FieldInfosFormat.CODEC_NAME, Lucene42FieldInfosFormat.FORMAT_START, Lucene42FieldInfosFormat.FORMAT_CURRENT);
 
-                int size = input.ReadVInt(); //read in the size
+                int size = input.ReadVInt32(); //read in the size
                 FieldInfo[] infos = new FieldInfo[size];
 
                 for (int i = 0; i < size; i++)
                 {
                     string name = input.ReadString();
-                    int fieldNumber = input.ReadVInt();
+                    int fieldNumber = input.ReadVInt32();
                     byte bits = input.ReadByte();
                     bool isIndexed = (bits & Lucene42FieldInfosFormat.IS_INDEXED) != 0;
                     bool storeTermVector = (bits & Lucene42FieldInfosFormat.STORE_TERMVECTOR) != 0;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Codecs/Lucene42/Lucene42NormsConsumer.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/Lucene42/Lucene42NormsConsumer.cs b/src/Lucene.Net.Core/Codecs/Lucene42/Lucene42NormsConsumer.cs
index 531ecbc..55697a3 100644
--- a/src/Lucene.Net.Core/Codecs/Lucene42/Lucene42NormsConsumer.cs
+++ b/src/Lucene.Net.Core/Codecs/Lucene42/Lucene42NormsConsumer.cs
@@ -77,9 +77,9 @@ namespace Lucene.Net.Codecs.Lucene42
 
         public override void AddNumericField(FieldInfo field, IEnumerable<long?> values)
         {
-            meta.WriteVInt(field.Number);
+            meta.WriteVInt32(field.Number);
             meta.WriteByte((byte)NUMBER);
-            meta.WriteLong(data.FilePointer);
+            meta.WriteInt64(data.FilePointer);
             long minValue = long.MaxValue;
             long maxValue = long.MinValue;
             long gcd = 0;
@@ -147,16 +147,16 @@ namespace Lucene.Net.Codecs.Lucene42
                     meta.WriteByte((byte)TABLE_COMPRESSED); // table-compressed
                     var decode = uniqueValues.ToArray();
                     var encode = new Dictionary<long, int>();
-                    data.WriteVInt(decode.Length);
+                    data.WriteVInt32(decode.Length);
                     for (int i = 0; i < decode.Length; i++)
                     {
-                        data.WriteLong(decode[i]);
+                        data.WriteInt64(decode[i]);
                         encode[decode[i]] = i;
                     }
 
-                    meta.WriteVInt(PackedInts.VERSION_CURRENT);
-                    data.WriteVInt(formatAndBits.Format.Id);
-                    data.WriteVInt(formatAndBits.BitsPerValue);
+                    meta.WriteVInt32(PackedInts.VERSION_CURRENT);
+                    data.WriteVInt32(formatAndBits.Format.Id);
+                    data.WriteVInt32(formatAndBits.BitsPerValue);
 
                     PackedInts.Writer writer = PackedInts.GetWriterNoHeader(data, formatAndBits.Format, maxDoc, formatAndBits.BitsPerValue, PackedInts.DEFAULT_BUFFER_SIZE);
                     foreach (long? nv in values)
@@ -169,10 +169,10 @@ namespace Lucene.Net.Codecs.Lucene42
             else if (gcd != 0 && gcd != 1)
             {
                 meta.WriteByte((byte)GCD_COMPRESSED);
-                meta.WriteVInt(PackedInts.VERSION_CURRENT);
-                data.WriteLong(minValue);
-                data.WriteLong(gcd);
-                data.WriteVInt(BLOCK_SIZE);
+                meta.WriteVInt32(PackedInts.VERSION_CURRENT);
+                data.WriteInt64(minValue);
+                data.WriteInt64(gcd);
+                data.WriteVInt32(BLOCK_SIZE);
 
                 var writer = new BlockPackedWriter(data, BLOCK_SIZE);
                 foreach (long? nv in values)
@@ -186,8 +186,8 @@ namespace Lucene.Net.Codecs.Lucene42
             {
                 meta.WriteByte((byte)DELTA_COMPRESSED); // delta-compressed
 
-                meta.WriteVInt(PackedInts.VERSION_CURRENT);
-                data.WriteVInt(BLOCK_SIZE);
+                meta.WriteVInt32(PackedInts.VERSION_CURRENT);
+                data.WriteVInt32(BLOCK_SIZE);
 
                 var writer = new BlockPackedWriter(data, BLOCK_SIZE);
                 foreach (long? nv in values)
@@ -207,7 +207,7 @@ namespace Lucene.Net.Codecs.Lucene42
                 {
                     if (meta != null)
                     {
-                        meta.WriteVInt(-1); // write EOF marker
+                        meta.WriteVInt32(-1); // write EOF marker
                         CodecUtil.WriteFooter(meta); // write checksum
                     }
                     if (data != null)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Codecs/Lucene45/Lucene45DocValuesConsumer.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/Lucene45/Lucene45DocValuesConsumer.cs b/src/Lucene.Net.Core/Codecs/Lucene45/Lucene45DocValuesConsumer.cs
index 5ae2379..ef643b8 100644
--- a/src/Lucene.Net.Core/Codecs/Lucene45/Lucene45DocValuesConsumer.cs
+++ b/src/Lucene.Net.Core/Codecs/Lucene45/Lucene45DocValuesConsumer.cs
@@ -195,28 +195,28 @@ namespace Lucene.Net.Codecs.Lucene45
             {
                 format = DELTA_COMPRESSED;
             }
-            meta.WriteVInt(field.Number);
+            meta.WriteVInt32(field.Number);
             meta.WriteByte((byte)Lucene45DocValuesFormat.NUMERIC);
-            meta.WriteVInt(format);
+            meta.WriteVInt32(format);
             if (missing)
             {
-                meta.WriteLong(data.FilePointer);
+                meta.WriteInt64(data.FilePointer);
                 WriteMissingBitset(values);
             }
             else
             {
-                meta.WriteLong(-1L);
+                meta.WriteInt64(-1L);
             }
-            meta.WriteVInt(PackedInts.VERSION_CURRENT);
-            meta.WriteLong(data.FilePointer);
-            meta.WriteVLong(count);
-            meta.WriteVInt(BLOCK_SIZE);
+            meta.WriteVInt32(PackedInts.VERSION_CURRENT);
+            meta.WriteInt64(data.FilePointer);
+            meta.WriteVInt64(count);
+            meta.WriteVInt32(BLOCK_SIZE);
 
             switch (format)
             {
                 case GCD_COMPRESSED:
-                    meta.WriteLong(minValue);
-                    meta.WriteLong(gcd);
+                    meta.WriteInt64(minValue);
+                    meta.WriteInt64(gcd);
                     BlockPackedWriter quotientWriter = new BlockPackedWriter(data, BLOCK_SIZE);
                     foreach (long? nv in values)
                     {
@@ -240,10 +240,10 @@ namespace Lucene.Net.Codecs.Lucene45
                     long[] decode = new long[uniqueValues.Count];
                     uniqueValues.CopyTo(decode, 0);
                     Dictionary<long, int> encode = new Dictionary<long, int>();
-                    meta.WriteVInt(decode.Length);
+                    meta.WriteVInt32(decode.Length);
                     for (int i = 0; i < decode.Length; i++)
                     {
-                        meta.WriteLong(decode[i]);
+                        meta.WriteInt64(decode[i]);
                         encode[decode[i]] = i;
                     }
                     int bitsRequired = PackedInts.BitsRequired(uniqueValues.Count - 1);
@@ -289,7 +289,7 @@ namespace Lucene.Net.Codecs.Lucene45
         public override void AddBinaryField(FieldInfo field, IEnumerable<BytesRef> values)
         {
             // write the byte[] data
-            meta.WriteVInt(field.Number);
+            meta.WriteVInt32(field.Number);
             meta.WriteByte((byte)Lucene45DocValuesFormat.BINARY);
             int minLength = int.MaxValue;
             int maxLength = int.MinValue;
@@ -316,28 +316,28 @@ namespace Lucene.Net.Codecs.Lucene45
                 }
                 count++;
             }
-            meta.WriteVInt(minLength == maxLength ? BINARY_FIXED_UNCOMPRESSED : BINARY_VARIABLE_UNCOMPRESSED);
+            meta.WriteVInt32(minLength == maxLength ? BINARY_FIXED_UNCOMPRESSED : BINARY_VARIABLE_UNCOMPRESSED);
             if (missing)
             {
-                meta.WriteLong(data.FilePointer);
+                meta.WriteInt64(data.FilePointer);
                 WriteMissingBitset(values);
             }
             else
             {
-                meta.WriteLong(-1L);
+                meta.WriteInt64(-1L);
             }
-            meta.WriteVInt(minLength);
-            meta.WriteVInt(maxLength);
-            meta.WriteVLong(count);
-            meta.WriteLong(startFP);
+            meta.WriteVInt32(minLength);
+            meta.WriteVInt32(maxLength);
+            meta.WriteVInt64(count);
+            meta.WriteInt64(startFP);
 
             // 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.WriteLong(data.FilePointer);
-                meta.WriteVInt(PackedInts.VERSION_CURRENT);
-                meta.WriteVInt(BLOCK_SIZE);
+                meta.WriteInt64(data.FilePointer);
+                meta.WriteVInt32(PackedInts.VERSION_CURRENT);
+                meta.WriteVInt32(BLOCK_SIZE);
 
                 MonotonicBlockPackedWriter writer = new MonotonicBlockPackedWriter(data, BLOCK_SIZE);
                 long addr = 0;
@@ -373,10 +373,10 @@ namespace Lucene.Net.Codecs.Lucene45
             else
             {
                 // header
-                meta.WriteVInt(field.Number);
+                meta.WriteVInt32(field.Number);
                 meta.WriteByte((byte)Lucene45DocValuesFormat.BINARY);
-                meta.WriteVInt(BINARY_PREFIX_COMPRESSED);
-                meta.WriteLong(-1L);
+                meta.WriteVInt32(BINARY_PREFIX_COMPRESSED);
+                meta.WriteInt64(-1L);
                 // now write the bytes: sharing prefixes within a block
                 long startFP = data.FilePointer;
                 // currently, we have to store the delta from expected for every 1/nth term
@@ -396,8 +396,8 @@ namespace Lucene.Net.Codecs.Lucene45
 
                     // prefix-code
                     int sharedPrefix = StringHelper.BytesDifference(lastTerm, v);
-                    data.WriteVInt(sharedPrefix);
-                    data.WriteVInt(v.Length - sharedPrefix);
+                    data.WriteVInt32(sharedPrefix);
+                    data.WriteVInt32(v.Length - sharedPrefix);
                     data.WriteBytes(v.Bytes, v.Offset + sharedPrefix, v.Length - sharedPrefix);
                     lastTerm.CopyBytes(v);
                     count++;
@@ -408,20 +408,20 @@ namespace Lucene.Net.Codecs.Lucene45
                 addressBuffer.WriteTo(data);
                 addressBuffer = null;
                 termAddresses = null;
-                meta.WriteVInt(minLength);
-                meta.WriteVInt(maxLength);
-                meta.WriteVLong(count);
-                meta.WriteLong(startFP);
-                meta.WriteVInt(ADDRESS_INTERVAL);
-                meta.WriteLong(indexStartFP);
-                meta.WriteVInt(PackedInts.VERSION_CURRENT);
-                meta.WriteVInt(BLOCK_SIZE);
+                meta.WriteVInt32(minLength);
+                meta.WriteVInt32(maxLength);
+                meta.WriteVInt64(count);
+                meta.WriteInt64(startFP);
+                meta.WriteVInt32(ADDRESS_INTERVAL);
+                meta.WriteInt64(indexStartFP);
+                meta.WriteVInt32(PackedInts.VERSION_CURRENT);
+                meta.WriteVInt32(BLOCK_SIZE);
             }
         }
 
         public override void AddSortedField(FieldInfo field, IEnumerable<BytesRef> values, IEnumerable<long?> docToOrd)
         {
-            meta.WriteVInt(field.Number);
+            meta.WriteVInt32(field.Number);
             meta.WriteByte((byte)Lucene45DocValuesFormat.SORTED);
             AddTermsDict(field, values);
             AddNumericField(field, docToOrd, false);
@@ -434,18 +434,18 @@ namespace Lucene.Net.Codecs.Lucene45
 
         public override void AddSortedSetField(FieldInfo field, IEnumerable<BytesRef> values, IEnumerable<long?> docToOrdCount, IEnumerable<long?> ords)
         {
-            meta.WriteVInt(field.Number);
+            meta.WriteVInt32(field.Number);
             meta.WriteByte((byte)Lucene45DocValuesFormat.SORTED_SET);
 
             if (IsSingleValued(docToOrdCount))
             {
-                meta.WriteVInt(SORTED_SET_SINGLE_VALUED_SORTED);
+                meta.WriteVInt32(SORTED_SET_SINGLE_VALUED_SORTED);
                 // The field is single-valued, we can encode it as SORTED
                 AddSortedField(field, values, GetSortedSetEnumerable(docToOrdCount, ords));
                 return;
             }
 
-            meta.WriteVInt(SORTED_SET_WITH_ADDRESSES);
+            meta.WriteVInt32(SORTED_SET_WITH_ADDRESSES);
 
             // write the ord -> byte[] as a binary field
             AddTermsDict(field, values);
@@ -455,14 +455,14 @@ namespace Lucene.Net.Codecs.Lucene45
             AddNumericField(field, ords, false);
 
             // write the doc -> ord count as a absolute index to the stream
-            meta.WriteVInt(field.Number);
+            meta.WriteVInt32(field.Number);
             meta.WriteByte((byte)Lucene45DocValuesFormat.NUMERIC);
-            meta.WriteVInt(DELTA_COMPRESSED);
-            meta.WriteLong(-1L);
-            meta.WriteVInt(PackedInts.VERSION_CURRENT);
-            meta.WriteLong(data.FilePointer);
-            meta.WriteVLong(maxDoc);
-            meta.WriteVInt(BLOCK_SIZE);
+            meta.WriteVInt32(DELTA_COMPRESSED);
+            meta.WriteInt64(-1L);
+            meta.WriteVInt32(PackedInts.VERSION_CURRENT);
+            meta.WriteInt64(data.FilePointer);
+            meta.WriteVInt64(maxDoc);
+            meta.WriteVInt32(BLOCK_SIZE);
 
             var writer = new MonotonicBlockPackedWriter(data, BLOCK_SIZE);
             long addr = 0;
@@ -658,7 +658,7 @@ throw new NotImplementedException();
                 {
                     if (meta != null)
                     {
-                        meta.WriteVInt(-1); // write EOF marker
+                        meta.WriteVInt32(-1); // write EOF marker
                         CodecUtil.WriteFooter(meta); // write checksum
                     }
                     if (data != null)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Codecs/Lucene45/Lucene45DocValuesProducer.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/Lucene45/Lucene45DocValuesProducer.cs b/src/Lucene.Net.Core/Codecs/Lucene45/Lucene45DocValuesProducer.cs
index d4558a7..e6ccc17 100644
--- a/src/Lucene.Net.Core/Codecs/Lucene45/Lucene45DocValuesProducer.cs
+++ b/src/Lucene.Net.Core/Codecs/Lucene45/Lucene45DocValuesProducer.cs
@@ -137,7 +137,7 @@ namespace Lucene.Net.Codecs.Lucene45
         private void ReadSortedField(int fieldNumber, IndexInput meta, FieldInfos infos)
         {
             // sorted = binary + numeric
-            if (meta.ReadVInt() != fieldNumber)
+            if (meta.ReadVInt32() != fieldNumber)
             {
                 throw new Exception("sorted entry for field: " + fieldNumber + " is corrupt (resource=" + meta + ")");
             }
@@ -148,7 +148,7 @@ namespace Lucene.Net.Codecs.Lucene45
             BinaryEntry b = ReadBinaryEntry(meta);
             binaries[fieldNumber] = b;
 
-            if (meta.ReadVInt() != fieldNumber)
+            if (meta.ReadVInt32() != fieldNumber)
             {
                 throw new Exception("sorted entry for field: " + fieldNumber + " is corrupt (resource=" + meta + ")");
             }
@@ -163,7 +163,7 @@ namespace Lucene.Net.Codecs.Lucene45
         private void ReadSortedSetFieldWithAddresses(int fieldNumber, IndexInput meta, FieldInfos infos)
         {
             // sortedset = binary + numeric (addresses) + ordIndex
-            if (meta.ReadVInt() != fieldNumber)
+            if (meta.ReadVInt32() != fieldNumber)
             {
                 throw new Exception("sortedset entry for field: " + fieldNumber + " is corrupt (resource=" + meta + ")");
             }
@@ -174,7 +174,7 @@ namespace Lucene.Net.Codecs.Lucene45
             BinaryEntry b = ReadBinaryEntry(meta);
             binaries[fieldNumber] = b;
 
-            if (meta.ReadVInt() != fieldNumber)
+            if (meta.ReadVInt32() != fieldNumber)
             {
                 throw new Exception("sortedset entry for field: " + fieldNumber + " is corrupt (resource=" + meta + ")");
             }
@@ -185,7 +185,7 @@ namespace Lucene.Net.Codecs.Lucene45
             NumericEntry n1 = ReadNumericEntry(meta);
             ords[fieldNumber] = n1;
 
-            if (meta.ReadVInt() != fieldNumber)
+            if (meta.ReadVInt32() != fieldNumber)
             {
                 throw new Exception("sortedset entry for field: " + fieldNumber + " is corrupt (resource=" + meta + ")");
             }
@@ -199,7 +199,7 @@ namespace Lucene.Net.Codecs.Lucene45
 
         private void ReadFields(IndexInput meta, FieldInfos infos)
         {
-            int fieldNumber = meta.ReadVInt();
+            int fieldNumber = meta.ReadVInt32();
             while (fieldNumber != -1)
             {
                 // check should be: infos.fieldInfo(fieldNumber) != null, which incorporates negative check
@@ -234,7 +234,7 @@ namespace Lucene.Net.Codecs.Lucene45
                     }
                     else if (ss.Format == Lucene45DocValuesConsumer.SORTED_SET_SINGLE_VALUED_SORTED)
                     {
-                        if (meta.ReadVInt() != fieldNumber)
+                        if (meta.ReadVInt32() != fieldNumber)
                         {
                             throw new Exception("sortedset entry for field: " + fieldNumber + " is corrupt (resource=" + meta + ")");
                         }
@@ -253,24 +253,24 @@ namespace Lucene.Net.Codecs.Lucene45
                 {
                     throw new Exception("invalid type: " + type + ", resource=" + meta);
                 }
-                fieldNumber = meta.ReadVInt();
+                fieldNumber = meta.ReadVInt32();
             }
         }
 
         internal static NumericEntry ReadNumericEntry(IndexInput meta)
         {
             NumericEntry entry = new NumericEntry();
-            entry.format = meta.ReadVInt();
-            entry.missingOffset = meta.ReadLong();
-            entry.PackedIntsVersion = meta.ReadVInt();
-            entry.Offset = meta.ReadLong();
-            entry.Count = meta.ReadVLong();
-            entry.BlockSize = meta.ReadVInt();
+            entry.format = meta.ReadVInt32();
+            entry.missingOffset = meta.ReadInt64();
+            entry.PackedInt32sVersion = meta.ReadVInt32();
+            entry.Offset = meta.ReadInt64();
+            entry.Count = meta.ReadVInt64();
+            entry.BlockSize = meta.ReadVInt32();
             switch (entry.format)
             {
                 case Lucene45DocValuesConsumer.GCD_COMPRESSED:
-                    entry.minValue = meta.ReadLong();
-                    entry.gcd = meta.ReadLong();
+                    entry.minValue = meta.ReadInt64();
+                    entry.gcd = meta.ReadInt64();
                     break;
 
                 case Lucene45DocValuesConsumer.TABLE_COMPRESSED:
@@ -278,7 +278,7 @@ namespace Lucene.Net.Codecs.Lucene45
                     {
                         throw new Exception("Cannot use TABLE_COMPRESSED with more than MAX_VALUE values, input=" + meta);
                     }
-                    int uniqueValues = meta.ReadVInt();
+                    int uniqueValues = meta.ReadVInt32();
                     if (uniqueValues > 256)
                     {
                         throw new Exception("TABLE_COMPRESSED cannot have more than 256 distinct values, input=" + meta);
@@ -286,7 +286,7 @@ namespace Lucene.Net.Codecs.Lucene45
                     entry.table = new long[uniqueValues];
                     for (int i = 0; i < uniqueValues; ++i)
                     {
-                        entry.table[i] = meta.ReadLong();
+                        entry.table[i] = meta.ReadInt64();
                     }
                     break;
 
@@ -302,28 +302,28 @@ namespace Lucene.Net.Codecs.Lucene45
         internal static BinaryEntry ReadBinaryEntry(IndexInput meta)
         {
             BinaryEntry entry = new BinaryEntry();
-            entry.format = meta.ReadVInt();
-            entry.missingOffset = meta.ReadLong();
-            entry.minLength = meta.ReadVInt();
-            entry.maxLength = meta.ReadVInt();
-            entry.Count = meta.ReadVLong();
-            entry.offset = meta.ReadLong();
+            entry.format = meta.ReadVInt32();
+            entry.missingOffset = meta.ReadInt64();
+            entry.minLength = meta.ReadVInt32();
+            entry.maxLength = meta.ReadVInt32();
+            entry.Count = meta.ReadVInt64();
+            entry.offset = meta.ReadInt64();
             switch (entry.format)
             {
                 case Lucene45DocValuesConsumer.BINARY_FIXED_UNCOMPRESSED:
                     break;
 
                 case Lucene45DocValuesConsumer.BINARY_PREFIX_COMPRESSED:
-                    entry.AddressInterval = meta.ReadVInt();
-                    entry.AddressesOffset = meta.ReadLong();
-                    entry.PackedIntsVersion = meta.ReadVInt();
-                    entry.BlockSize = meta.ReadVInt();
+                    entry.AddressInterval = meta.ReadVInt32();
+                    entry.AddressesOffset = meta.ReadInt64();
+                    entry.PackedInt32sVersion = meta.ReadVInt32();
+                    entry.BlockSize = meta.ReadVInt32();
                     break;
 
                 case Lucene45DocValuesConsumer.BINARY_VARIABLE_UNCOMPRESSED:
-                    entry.AddressesOffset = meta.ReadLong();
-                    entry.PackedIntsVersion = meta.ReadVInt();
-                    entry.BlockSize = meta.ReadVInt();
+                    entry.AddressesOffset = meta.ReadInt64();
+                    entry.PackedInt32sVersion = meta.ReadVInt32();
+                    entry.BlockSize = meta.ReadVInt32();
                     break;
 
                 default:
@@ -337,7 +337,7 @@ namespace Lucene.Net.Codecs.Lucene45
             SortedSetEntry entry = new SortedSetEntry();
             if (version >= Lucene45DocValuesFormat.VERSION_SORTED_SET_SINGLE_VALUE_OPTIMIZED)
             {
-                entry.Format = meta.ReadVInt();
+                entry.Format = meta.ReadVInt32();
             }
             else
             {
@@ -377,19 +377,19 @@ namespace Lucene.Net.Codecs.Lucene45
             switch (entry.format)
             {
                 case Lucene45DocValuesConsumer.DELTA_COMPRESSED:
-                    BlockPackedReader reader = new BlockPackedReader(data, entry.PackedIntsVersion, entry.BlockSize, entry.Count, true);
+                    BlockPackedReader reader = new BlockPackedReader(data, entry.PackedInt32sVersion, entry.BlockSize, entry.Count, true);
                     return reader;
 
                 case Lucene45DocValuesConsumer.GCD_COMPRESSED:
                     long min = entry.minValue;
                     long mult = entry.gcd;
-                    BlockPackedReader quotientReader = new BlockPackedReader(data, entry.PackedIntsVersion, entry.BlockSize, entry.Count, true);
+                    BlockPackedReader quotientReader = new BlockPackedReader(data, entry.PackedInt32sVersion, entry.BlockSize, entry.Count, true);
                     return new LongValuesAnonymousInnerClassHelper(this, min, mult, quotientReader);
 
                 case Lucene45DocValuesConsumer.TABLE_COMPRESSED:
                     long[] table = entry.table;
                     int bitsRequired = PackedInts.BitsRequired(table.Length - 1);
-                    PackedInts.Reader ords = PackedInts.GetDirectReaderNoHeader(data, PackedInts.Format.PACKED, entry.PackedIntsVersion, (int)entry.Count, bitsRequired);
+                    PackedInts.Reader ords = PackedInts.GetDirectReaderNoHeader(data, PackedInts.Format.PACKED, entry.PackedInt32sVersion, (int)entry.Count, bitsRequired);
                     return new LongValuesAnonymousInnerClassHelper2(this, table, ords);
 
                 default:
@@ -513,7 +513,7 @@ namespace Lucene.Net.Codecs.Lucene45
                 if (!addressInstances.TryGetValue(field.Number, out addrInstance))
                 {
                     data.Seek(bytes.AddressesOffset);
-                    addrInstance = new MonotonicBlockPackedReader(data, bytes.PackedIntsVersion, bytes.BlockSize, bytes.Count, false);
+                    addrInstance = new MonotonicBlockPackedReader(data, bytes.PackedInt32sVersion, bytes.BlockSize, bytes.Count, false);
                     addressInstances[field.Number] = addrInstance;
                     ramBytesUsed.AddAndGet(addrInstance.RamBytesUsed() + RamUsageEstimator.NUM_BYTES_INT);
                 }
@@ -593,7 +593,7 @@ namespace Lucene.Net.Codecs.Lucene45
                     {
                         size = 1L + bytes.Count / interval;
                     }
-                    addrInstance = new MonotonicBlockPackedReader(data, bytes.PackedIntsVersion, bytes.BlockSize, size, false);
+                    addrInstance = new MonotonicBlockPackedReader(data, bytes.PackedInt32sVersion, bytes.BlockSize, size, false);
                     addressInstances[field.Number] = addrInstance;
                     ramBytesUsed.AddAndGet(addrInstance.RamBytesUsed() + RamUsageEstimator.NUM_BYTES_INT);
                 }
@@ -618,7 +618,7 @@ namespace Lucene.Net.Codecs.Lucene45
             NumericEntry entry = ords[field.Number];
             IndexInput data = (IndexInput)this.data.Clone();
             data.Seek(entry.Offset);
-            BlockPackedReader ordinals = new BlockPackedReader(data, entry.PackedIntsVersion, entry.BlockSize, entry.Count, true);
+            BlockPackedReader ordinals = new BlockPackedReader(data, entry.PackedInt32sVersion, entry.BlockSize, entry.Count, true);
 
             return new SortedDocValuesAnonymousInnerClassHelper(this, valueCount, binary, ordinals);
         }
@@ -695,7 +695,7 @@ namespace Lucene.Net.Codecs.Lucene45
                 if (!ordIndexInstances.TryGetValue(field.Number, out ordIndexInstance))
                 {
                     data.Seek(entry.Offset);
-                    ordIndexInstance = new MonotonicBlockPackedReader(data, entry.PackedIntsVersion, entry.BlockSize, entry.Count, false);
+                    ordIndexInstance = new MonotonicBlockPackedReader(data, entry.PackedInt32sVersion, entry.BlockSize, entry.Count, false);
                     ordIndexInstances[field.Number] = ordIndexInstance;
                     ramBytesUsed.AddAndGet(ordIndexInstance.RamBytesUsed() + RamUsageEstimator.NUM_BYTES_INT);
                 }
@@ -914,8 +914,11 @@ namespace Lucene.Net.Codecs.Lucene45
             internal int format;
 
             /// <summary>
-            /// packed ints version used to encode these numerics </summary>
-            public int PackedIntsVersion { get; set; }
+            /// packed ints version used to encode these numerics 
+            /// <para/>
+            /// NOTE: This was packedIntsVersion (field) in Lucene
+            /// </summary>
+            public int PackedInt32sVersion { get; set; }
 
             /// <summary>
             /// count of values written </summary>
@@ -964,8 +967,11 @@ namespace Lucene.Net.Codecs.Lucene45
             public long AddressInterval { get; set; }
 
             /// <summary>
-            /// packed ints version used to encode addressing information </summary>
-            public int PackedIntsVersion { get; set; }
+            /// packed ints version used to encode addressing information 
+            /// <para/>
+            /// NOTE: This was packedIntsVersion (field) in Lucene
+            /// </summary>
+            public int PackedInt32sVersion { get; set; }
 
             /// <summary>
             /// packed ints blocksize </summary>
@@ -1121,8 +1127,8 @@ namespace Lucene.Net.Codecs.Lucene45
                     }
                     else
                     {
-                        int start = input.ReadVInt();
-                        int suffix = input.ReadVInt();
+                        int start = input.ReadVInt32();
+                        int suffix = input.ReadVInt32();
                         input.ReadBytes(termBuffer.Bytes, start, suffix);
                         termBuffer.Length = start + suffix;
                         return termBuffer;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Codecs/Lucene46/Lucene46FieldInfosReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/Lucene46/Lucene46FieldInfosReader.cs b/src/Lucene.Net.Core/Codecs/Lucene46/Lucene46FieldInfosReader.cs
index 131ca65..63f4c94 100644
--- a/src/Lucene.Net.Core/Codecs/Lucene46/Lucene46FieldInfosReader.cs
+++ b/src/Lucene.Net.Core/Codecs/Lucene46/Lucene46FieldInfosReader.cs
@@ -55,13 +55,13 @@ namespace Lucene.Net.Codecs.Lucene46
             {
                 int codecVersion = CodecUtil.CheckHeader(input, Lucene46FieldInfosFormat.CODEC_NAME, Lucene46FieldInfosFormat.FORMAT_START, Lucene46FieldInfosFormat.FORMAT_CURRENT);
 
-                int size = input.ReadVInt(); //read in the size
+                int size = input.ReadVInt32(); //read in the size
                 FieldInfo[] infos = new FieldInfo[size];
 
                 for (int i = 0; i < size; i++)
                 {
                     string name = input.ReadString();
-                    int fieldNumber = input.ReadVInt();
+                    int fieldNumber = input.ReadVInt32();
                     byte bits = input.ReadByte();
                     bool isIndexed = (bits & Lucene46FieldInfosFormat.IS_INDEXED) != 0;
                     bool storeTermVector = (bits & Lucene46FieldInfosFormat.STORE_TERMVECTOR) != 0;
@@ -93,7 +93,7 @@ namespace Lucene.Net.Codecs.Lucene46
                     byte val = input.ReadByte();
                     DocValuesType? docValuesType = GetDocValuesType(input, (sbyte)(val & 0x0F));
                     DocValuesType? normsType = GetDocValuesType(input, (sbyte)(((int)((uint)val >> 4)) & 0x0F));
-                    long dvGen = input.ReadLong();
+                    long dvGen = input.ReadInt64();
                     IDictionary<string, string> attributes = input.ReadStringStringMap();
                     infos[i] = new FieldInfo(name, isIndexed, fieldNumber, storeTermVector, omitNorms, storePayloads, indexOptions, docValuesType, normsType, Collections.UnmodifiableMap(attributes));
                     infos[i].DocValuesGen = dvGen;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Codecs/Lucene46/Lucene46FieldInfosWriter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/Lucene46/Lucene46FieldInfosWriter.cs b/src/Lucene.Net.Core/Codecs/Lucene46/Lucene46FieldInfosWriter.cs
index 3c94d71..df803b1 100644
--- a/src/Lucene.Net.Core/Codecs/Lucene46/Lucene46FieldInfosWriter.cs
+++ b/src/Lucene.Net.Core/Codecs/Lucene46/Lucene46FieldInfosWriter.cs
@@ -51,7 +51,7 @@ namespace Lucene.Net.Codecs.Lucene46
             try
             {
                 CodecUtil.WriteHeader(output, Lucene46FieldInfosFormat.CODEC_NAME, Lucene46FieldInfosFormat.FORMAT_CURRENT);
-                output.WriteVInt(infos.Count);
+                output.WriteVInt32(infos.Count);
                 foreach (FieldInfo fi in infos)
                 {
                     IndexOptions? indexOptions = fi.IndexOptions;
@@ -86,7 +86,7 @@ namespace Lucene.Net.Codecs.Lucene46
                         }
                     }
                     output.WriteString(fi.Name);
-                    output.WriteVInt(fi.Number);
+                    output.WriteVInt32(fi.Number);
                     output.WriteByte((byte)bits);
 
                     // pack the DV types in one byte
@@ -95,7 +95,7 @@ namespace Lucene.Net.Codecs.Lucene46
                     Debug.Assert((dv & (~0xF)) == 0 && (nrm & (~0x0F)) == 0);
                     var val = unchecked((sbyte)(0xff & ((nrm << 4) | dv)));
                     output.WriteByte((byte)val);
-                    output.WriteLong(fi.DocValuesGen);
+                    output.WriteInt64(fi.DocValuesGen);
                     output.WriteStringStringMap(fi.Attributes);
                 }
                 CodecUtil.WriteFooter(output);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Codecs/Lucene46/Lucene46SegmentInfoReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/Lucene46/Lucene46SegmentInfoReader.cs b/src/Lucene.Net.Core/Codecs/Lucene46/Lucene46SegmentInfoReader.cs
index 9d037b9..6cb374e 100644
--- a/src/Lucene.Net.Core/Codecs/Lucene46/Lucene46SegmentInfoReader.cs
+++ b/src/Lucene.Net.Core/Codecs/Lucene46/Lucene46SegmentInfoReader.cs
@@ -49,7 +49,7 @@ namespace Lucene.Net.Codecs.Lucene46
             {
                 int codecVersion = CodecUtil.CheckHeader(input, Lucene46SegmentInfoFormat.CODEC_NAME, Lucene46SegmentInfoFormat.VERSION_START, Lucene46SegmentInfoFormat.VERSION_CURRENT);
                 string version = input.ReadString();
-                int docCount = input.ReadInt();
+                int docCount = input.ReadInt32();
                 if (docCount < 0)
                 {
                     throw new CorruptIndexException("invalid docCount: " + docCount + " (resource=" + input + ")");

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Codecs/Lucene46/Lucene46SegmentInfoWriter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/Lucene46/Lucene46SegmentInfoWriter.cs b/src/Lucene.Net.Core/Codecs/Lucene46/Lucene46SegmentInfoWriter.cs
index 5d59e5c..9cf8da9 100644
--- a/src/Lucene.Net.Core/Codecs/Lucene46/Lucene46SegmentInfoWriter.cs
+++ b/src/Lucene.Net.Core/Codecs/Lucene46/Lucene46SegmentInfoWriter.cs
@@ -53,7 +53,7 @@ namespace Lucene.Net.Codecs.Lucene46
                 CodecUtil.WriteHeader(output, Lucene46SegmentInfoFormat.CODEC_NAME, Lucene46SegmentInfoFormat.VERSION_CURRENT);
                 // Write the Lucene version that created this segment, since 3.1
                 output.WriteString(si.Version);
-                output.WriteInt(si.DocCount);
+                output.WriteInt32(si.DocCount);
 
                 output.WriteByte((byte)(sbyte)(si.UseCompoundFile ? SegmentInfo.YES : SegmentInfo.NO));
                 output.WriteStringStringMap(si.Diagnostics);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Codecs/MultiLevelSkipListReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/MultiLevelSkipListReader.cs b/src/Lucene.Net.Core/Codecs/MultiLevelSkipListReader.cs
index 2cb474f..5d0f568 100644
--- a/src/Lucene.Net.Core/Codecs/MultiLevelSkipListReader.cs
+++ b/src/Lucene.Net.Core/Codecs/MultiLevelSkipListReader.cs
@@ -206,7 +206,7 @@ namespace Lucene.Net.Codecs
             if (level != 0)
             {
                 // read the child pointer if we are not on the leaf level
-                childPointer[level] = skipStream[level].ReadVLong() + skipPointer[level - 1];
+                childPointer[level] = skipStream[level].ReadVInt64() + skipPointer[level - 1];
             }
 
             return true;
@@ -221,7 +221,7 @@ namespace Lucene.Net.Codecs
             m_skipDoc[level] = lastDoc;
             if (level > 0)
             {
-                childPointer[level] = skipStream[level].ReadVLong() + skipPointer[level - 1];
+                childPointer[level] = skipStream[level].ReadVInt64() + skipPointer[level - 1];
             }
         }
 
@@ -279,7 +279,7 @@ namespace Lucene.Net.Codecs
             for (int i = numberOfSkipLevels - 1; i > 0; i--)
             {
                 // the length of the current level
-                long length = skipStream[0].ReadVLong();
+                long length = skipStream[0].ReadVInt64();
 
                 // the start pointer of the current level
                 skipPointer[i] = skipStream[0].FilePointer;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Codecs/MultiLevelSkipListWriter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/MultiLevelSkipListWriter.cs b/src/Lucene.Net.Core/Codecs/MultiLevelSkipListWriter.cs
index 03c414a..802548d 100644
--- a/src/Lucene.Net.Core/Codecs/MultiLevelSkipListWriter.cs
+++ b/src/Lucene.Net.Core/Codecs/MultiLevelSkipListWriter.cs
@@ -168,7 +168,7 @@ namespace Lucene.Net.Codecs
                 if (level != 0)
                 {
                     // store child pointers for all levels except the lowest
-                    skipBuffer[level].WriteVLong(childPointer);
+                    skipBuffer[level].WriteVInt64(childPointer);
                 }
 
                 //remember the childPointer for the next level
@@ -195,7 +195,7 @@ namespace Lucene.Net.Codecs
                 long length = skipBuffer[level].FilePointer;
                 if (length > 0)
                 {
-                    output.WriteVLong(length);
+                    output.WriteVInt64(length);
                     skipBuffer[level].WriteTo(output);
                 }
             }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Codecs/TermVectorsWriter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Codecs/TermVectorsWriter.cs b/src/Lucene.Net.Core/Codecs/TermVectorsWriter.cs
index e8cade2..39563ec 100644
--- a/src/Lucene.Net.Core/Codecs/TermVectorsWriter.cs
+++ b/src/Lucene.Net.Core/Codecs/TermVectorsWriter.cs
@@ -162,12 +162,12 @@ namespace Lucene.Net.Codecs
                 }
                 else
                 {
-                    int code = positions.ReadVInt();
+                    int code = positions.ReadVInt32();
                     position += (int)((uint)code >> 1);
                     if ((code & 1) != 0)
                     {
                         // this position has a payload
-                        int payloadLength = positions.ReadVInt();
+                        int payloadLength = positions.ReadVInt32();
 
                         if (payload == null)
                         {
@@ -195,8 +195,8 @@ namespace Lucene.Net.Codecs
                 }
                 else
                 {
-                    startOffset = lastOffset + offsets.ReadVInt();
-                    endOffset = startOffset + offsets.ReadVInt();
+                    startOffset = lastOffset + offsets.ReadVInt32();
+                    endOffset = startOffset + offsets.ReadVInt32();
                     lastOffset = endOffset;
                 }
                 AddPosition(position, startOffset, endOffset, thisPayload);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Document/Field.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Document/Field.cs b/src/Lucene.Net.Core/Document/Field.cs
index c1dfd6d..dfffb9e 100644
--- a/src/Lucene.Net.Core/Document/Field.cs
+++ b/src/Lucene.Net.Core/Document/Field.cs
@@ -577,15 +577,15 @@ namespace Lucene.Net.Documents
                 switch (numericType)
                 {
                     case NumericType.INT:
-                        nts.SetIntValue(Convert.ToInt32(val));
+                        nts.SetInt32Value(Convert.ToInt32(val));
                         break;
 
                     case NumericType.LONG:
-                        nts.SetLongValue(Convert.ToInt64(val));
+                        nts.SetInt64Value(Convert.ToInt64(val));
                         break;
 
                     case NumericType.FLOAT:
-                        nts.SetFloatValue(Convert.ToSingle(val));
+                        nts.SetSingleValue(Convert.ToSingle(val));
                         break;
 
                     case NumericType.DOUBLE:

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Document/FloatDocValuesField.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Document/FloatDocValuesField.cs b/src/Lucene.Net.Core/Document/FloatDocValuesField.cs
index d702042..8c02eca 100644
--- a/src/Lucene.Net.Core/Document/FloatDocValuesField.cs
+++ b/src/Lucene.Net.Core/Document/FloatDocValuesField.cs
@@ -36,13 +36,13 @@ namespace Lucene.Net.Documents
         /// <param name="value"> 32-bit float value </param>
         /// <exception cref="ArgumentException"> if the field name is null </exception>
         public FloatDocValuesField(string name, float value)
-            : base(name, Support.Number.FloatToIntBits(value))
+            : base(name, Support.Number.SingleToInt32Bits(value))
         {
         }
 
         public override void SetSingleValue(float value)
         {
-            base.SetInt64Value(Support.Number.FloatToIntBits(value));
+            base.SetInt64Value(Support.Number.SingleToInt32Bits(value));
         }
 
         public override void SetInt64Value(long value)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Index/AutomatonTermsEnum.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Index/AutomatonTermsEnum.cs b/src/Lucene.Net.Core/Index/AutomatonTermsEnum.cs
index 4b36cad..d4f43f2 100644
--- a/src/Lucene.Net.Core/Index/AutomatonTermsEnum.cs
+++ b/src/Lucene.Net.Core/Index/AutomatonTermsEnum.cs
@@ -208,7 +208,7 @@ namespace Lucene.Net.Index
             int state;
             int pos = 0;
             savedStates.Grow(seekBytesRef.Length + 1);
-            int[] states = savedStates.Ints;
+            int[] states = savedStates.Int32s;
             states[0] = runAutomaton.InitialState;
 
             while (true)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Index/CheckIndex.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Index/CheckIndex.cs b/src/Lucene.Net.Core/Index/CheckIndex.cs
index fd84f7d..b363b8d 100644
--- a/src/Lucene.Net.Core/Index/CheckIndex.cs
+++ b/src/Lucene.Net.Core/Index/CheckIndex.cs
@@ -588,7 +588,7 @@ namespace Lucene.Net.Index
             int format = 0;
             try
             {
-                format = input.ReadInt();
+                format = input.ReadInt32();
             }
             catch (Exception t)
             {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Index/DocTermOrds.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Index/DocTermOrds.cs b/src/Lucene.Net.Core/Index/DocTermOrds.cs
index ecea4bf..6e2e076 100644
--- a/src/Lucene.Net.Core/Index/DocTermOrds.cs
+++ b/src/Lucene.Net.Core/Index/DocTermOrds.cs
@@ -467,7 +467,7 @@ namespace Lucene.Net.Index
                             // index into byte array (actually the end of
                             // the doc-specific byte[] when building)
                             int pos = (int)((uint)val >> 8);
-                            int ilen = VIntSize(delta);
+                            int ilen = VInt32Size(delta);
                             var arr = bytes[doc];
                             int newend = pos + ilen;
                             if (newend > arr.Length)
@@ -484,7 +484,7 @@ namespace Lucene.Net.Index
                                 arr = newarr;
                                 bytes[doc] = newarr;
                             }
-                            pos = WriteInt(delta, arr, pos);
+                            pos = WriteInt32(delta, arr, pos);
                             index[doc] = (pos << 8) | 1; // update pointer to end index in byte[]
                         }
                         else
@@ -515,7 +515,7 @@ namespace Lucene.Net.Index
 
                             //System.out.println("      ipos=" + ipos);
 
-                            int endPos = WriteInt(delta, tempArr, ipos);
+                            int endPos = WriteInt32(delta, tempArr, ipos);
                             //System.out.println("      endpos=" + endPos);
                             if (endPos <= 4)
                             {
@@ -671,8 +671,11 @@ namespace Lucene.Net.Index
         }
 
         /// <summary>
-        /// Number of bytes to represent an unsigned int as a vint. </summary>
-        private static int VIntSize(int x)
+        /// Number of bytes to represent an unsigned int as a vint. 
+        /// <para/>
+        /// NOTE: This was vIntSize() in Lucene
+        /// </summary>
+        private static int VInt32Size(int x)
         {
             if ((x & (0xffffffff << (7 * 1))) == 0)
             {
@@ -695,7 +698,10 @@ namespace Lucene.Net.Index
 
         // todo: if we know the size of the vInt already, we could do
         // a single switch on the size
-        private static int WriteInt(int x, sbyte[] arr, int pos)
+        /// <summary>
+        /// NOTE: This was writeInt() in Lucene
+        /// </summary>
+        private static int WriteInt32(int x, sbyte[] arr, int pos)
         {
             var a = ((int)((uint)x >> (7 * 4)));
             if (a != 0)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Index/DocumentsWriterPerThread.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Index/DocumentsWriterPerThread.cs b/src/Lucene.Net.Core/Index/DocumentsWriterPerThread.cs
index 5de3e86..470e590 100644
--- a/src/Lucene.Net.Core/Index/DocumentsWriterPerThread.cs
+++ b/src/Lucene.Net.Core/Index/DocumentsWriterPerThread.cs
@@ -717,14 +717,14 @@ namespace Lucene.Net.Index
 
             /* Allocate another int[] from the shared pool */
 
-            public override int[] GetIntBlock()
+            public override int[] GetInt32Block()
             {
                 int[] b = new int[IntBlockPool.INT_BLOCK_SIZE];
                 bytesUsed.AddAndGet(IntBlockPool.INT_BLOCK_SIZE * RamUsageEstimator.NUM_BYTES_INT);
                 return b;
             }
 
-            public override void RecycleIntBlocks(int[][] blocks, int offset, int length)
+            public override void RecycleInt32Blocks(int[][] blocks, int offset, int length)
             {
                 bytesUsed.AddAndGet(-(length * (IntBlockPool.INT_BLOCK_SIZE * RamUsageEstimator.NUM_BYTES_INT)));
             }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Index/FreqProxTermsWriterPerField.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Index/FreqProxTermsWriterPerField.cs b/src/Lucene.Net.Core/Index/FreqProxTermsWriterPerField.cs
index 0f5ea98..1ab3f51 100644
--- a/src/Lucene.Net.Core/Index/FreqProxTermsWriterPerField.cs
+++ b/src/Lucene.Net.Core/Index/FreqProxTermsWriterPerField.cs
@@ -164,14 +164,14 @@ namespace Lucene.Net.Index
 
             if (payload != null && payload.Length > 0)
             {
-                termsHashPerField.WriteVInt(1, (proxCode << 1) | 1);
-                termsHashPerField.WriteVInt(1, payload.Length);
+                termsHashPerField.WriteVInt32(1, (proxCode << 1) | 1);
+                termsHashPerField.WriteVInt32(1, payload.Length);
                 termsHashPerField.WriteBytes(1, payload.Bytes, payload.Offset, payload.Length);
                 hasPayloads = true;
             }
             else
             {
-                termsHashPerField.WriteVInt(1, proxCode << 1);
+                termsHashPerField.WriteVInt32(1, proxCode << 1);
             }
 
             FreqProxPostingsArray postings = (FreqProxPostingsArray)termsHashPerField.postingsArray;
@@ -185,8 +185,8 @@ namespace Lucene.Net.Index
             int endOffset = offsetAccum + offsetAttribute.EndOffset;
             FreqProxPostingsArray postings = (FreqProxPostingsArray)termsHashPerField.postingsArray;
             Debug.Assert(startOffset - postings.lastOffsets[termID] >= 0);
-            termsHashPerField.WriteVInt(1, startOffset - postings.lastOffsets[termID]);
-            termsHashPerField.WriteVInt(1, endOffset - startOffset);
+            termsHashPerField.WriteVInt32(1, startOffset - postings.lastOffsets[termID]);
+            termsHashPerField.WriteVInt32(1, endOffset - startOffset);
 
             postings.lastOffsets[termID] = startOffset;
         }
@@ -238,7 +238,7 @@ namespace Lucene.Net.Index
                 if (docState.docID != postings.lastDocIDs[termID])
                 {
                     Debug.Assert(docState.docID > postings.lastDocIDs[termID]);
-                    termsHashPerField.WriteVInt(0, postings.lastDocCodes[termID]);
+                    termsHashPerField.WriteVInt32(0, postings.lastDocCodes[termID]);
                     postings.lastDocCodes[termID] = docState.docID - postings.lastDocIDs[termID];
                     postings.lastDocIDs[termID] = docState.docID;
                     fieldState.UniqueTermCount++;
@@ -254,12 +254,12 @@ namespace Lucene.Net.Index
                 // write it & lastDocCode
                 if (1 == postings.termFreqs[termID])
                 {
-                    termsHashPerField.WriteVInt(0, postings.lastDocCodes[termID] | 1);
+                    termsHashPerField.WriteVInt32(0, postings.lastDocCodes[termID] | 1);
                 }
                 else
                 {
-                    termsHashPerField.WriteVInt(0, postings.lastDocCodes[termID]);
-                    termsHashPerField.WriteVInt(0, postings.termFreqs[termID]);
+                    termsHashPerField.WriteVInt32(0, postings.lastDocCodes[termID]);
+                    termsHashPerField.WriteVInt32(0, postings.termFreqs[termID]);
                 }
                 postings.termFreqs[termID] = 1;
                 fieldState.MaxTermFrequency = Math.Max(1, fieldState.MaxTermFrequency);
@@ -528,7 +528,7 @@ namespace Lucene.Net.Index
                     }
                     else
                     {
-                        int code = freq.ReadVInt();
+                        int code = freq.ReadVInt32();
                         if (!readTermFreq)
                         {
                             docID += code;
@@ -543,7 +543,7 @@ namespace Lucene.Net.Index
                             }
                             else
                             {
-                                termFreq = freq.ReadVInt();
+                                termFreq = freq.ReadVInt32();
                             }
                         }
 
@@ -601,13 +601,13 @@ namespace Lucene.Net.Index
 
                             if (readPositions)
                             {
-                                int code = prox.ReadVInt();
+                                int code = prox.ReadVInt32();
                                 position += (int)((uint)code >> 1);
 
                                 if ((code & 1) != 0)
                                 {
                                     // this position has a payload
-                                    int payloadLength = prox.ReadVInt();
+                                    int payloadLength = prox.ReadVInt32();
 
                                     if (payload == null)
                                     {
@@ -630,8 +630,8 @@ namespace Lucene.Net.Index
 
                                 if (readOffsets)
                                 {
-                                    int startOffset = offset + prox.ReadVInt();
-                                    int endOffset = startOffset + prox.ReadVInt();
+                                    int startOffset = offset + prox.ReadVInt32();
+                                    int endOffset = startOffset + prox.ReadVInt32();
                                     if (writePositions)
                                     {
                                         if (writeOffsets)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Index/PersistentSnapshotDeletionPolicy.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Index/PersistentSnapshotDeletionPolicy.cs b/src/Lucene.Net.Core/Index/PersistentSnapshotDeletionPolicy.cs
index 2143968..2b21a4c 100644
--- a/src/Lucene.Net.Core/Index/PersistentSnapshotDeletionPolicy.cs
+++ b/src/Lucene.Net.Core/Index/PersistentSnapshotDeletionPolicy.cs
@@ -209,11 +209,11 @@ namespace Lucene.Net.Index
                 try
                 {
                     CodecUtil.WriteHeader(@out, CODEC_NAME, VERSION_CURRENT);
-                    @out.WriteVInt(m_refCounts.Count);
+                    @out.WriteVInt32(m_refCounts.Count);
                     foreach (KeyValuePair<long, int> ent in m_refCounts)
                     {
-                        @out.WriteVLong(ent.Key);
-                        @out.WriteVInt(ent.Value);
+                        @out.WriteVInt64(ent.Key);
+                        @out.WriteVInt32(ent.Value);
                     }
                     success = true;
                 }
@@ -319,11 +319,11 @@ namespace Lucene.Net.Index
                             try
                             {
                                 CodecUtil.CheckHeader(@in, CODEC_NAME, VERSION_START, VERSION_START);
-                                int count = @in.ReadVInt();
+                                int count = @in.ReadVInt32();
                                 for (int i = 0; i < count; i++)
                                 {
-                                    long commitGen = @in.ReadVLong();
-                                    int refCount = @in.ReadVInt();
+                                    long commitGen = @in.ReadVInt64();
+                                    int refCount = @in.ReadVInt32();
                                     m[commitGen] = refCount;
                                 }
                             }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Index/PrefixCodedTerms.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Index/PrefixCodedTerms.cs b/src/Lucene.Net.Core/Index/PrefixCodedTerms.cs
index 1cfdd6e..f965cc2 100644
--- a/src/Lucene.Net.Core/Index/PrefixCodedTerms.cs
+++ b/src/Lucene.Net.Core/Index/PrefixCodedTerms.cs
@@ -102,13 +102,13 @@ namespace Lucene.Net.Index
             {
                 if (input.FilePointer < input.Length)
                 {
-                    int code = input.ReadVInt();
+                    int code = input.ReadVInt32();
                     if ((code & 1) != 0)
                     {
                         field = input.ReadString();
                     }
                     int prefix = Number.URShift(code, 1);
-                    int suffix = input.ReadVInt();
+                    int suffix = input.ReadVInt32();
                     bytes.Grow(prefix + suffix);
                     input.ReadBytes(bytes.Bytes, prefix, suffix);
                     bytes.Length = prefix + suffix;
@@ -154,14 +154,14 @@ namespace Lucene.Net.Index
                     int suffix = term.Bytes.Length - prefix;
                     if (term.Field.Equals(lastTerm.Field))
                     {
-                        output.WriteVInt(prefix << 1);
+                        output.WriteVInt32(prefix << 1);
                     }
                     else
                     {
-                        output.WriteVInt(prefix << 1 | 1);
+                        output.WriteVInt32(prefix << 1 | 1);
                         output.WriteString(term.Field);
                     }
-                    output.WriteVInt(suffix);
+                    output.WriteVInt32(suffix);
                     output.WriteBytes(term.Bytes.Bytes, term.Bytes.Offset + prefix, suffix);
                     lastTerm.Bytes.CopyBytes(term.Bytes);
                     lastTerm.Field = term.Field;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Index/ReadersAndUpdates.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Index/ReadersAndUpdates.cs b/src/Lucene.Net.Core/Index/ReadersAndUpdates.cs
index 6158e4e..b9859c2 100644
--- a/src/Lucene.Net.Core/Index/ReadersAndUpdates.cs
+++ b/src/Lucene.Net.Core/Index/ReadersAndUpdates.cs
@@ -521,7 +521,7 @@ namespace Lucene.Net.Index
 
                                 fieldInfo.DocValuesGen = nextFieldInfosGen;
                                 // write the numeric updates to a new gen'd docvalues file
-                                fieldsConsumer.AddNumericField(fieldInfo, GetLongEnumerable(reader, field, fieldUpdates));
+                                fieldsConsumer.AddNumericField(fieldInfo, GetInt64Enumerable(reader, field, fieldUpdates));
                             }
 
                             //        System.out.println("[" + Thread.currentThread().getName() + "] RAU.writeFieldUpdates: applying binary updates; seg=" + info + " updates=" + dvUpdates.binaryDVUpdates);
@@ -665,7 +665,10 @@ namespace Lucene.Net.Index
             }
         }
 
-        private IEnumerable<long?> GetLongEnumerable(SegmentReader reader, string field, NumericDocValuesFieldUpdates fieldUpdates)
+        /// <summary>
+        /// NOTE: This was getLongEnumerable() in Lucene
+        /// </summary>
+        private IEnumerable<long?> GetInt64Enumerable(SegmentReader reader, string field, NumericDocValuesFieldUpdates fieldUpdates)
         {
             int maxDoc = reader.MaxDoc;
             IBits DocsWithField = reader.GetDocsWithField(field);


[02/53] [abbrv] lucenenet git commit: Lucene.Net.Core: Renamed all type-derived properties and methods from Short, Int, Long, and Float to match CLR types Int16, Int32, Int64, and Single, respectively.

Posted by ni...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Tests/core/Search/TestFieldCacheRangeFilter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Search/TestFieldCacheRangeFilter.cs b/src/Lucene.Net.Tests/core/Search/TestFieldCacheRangeFilter.cs
index a1d1e50..63f77d9 100644
--- a/src/Lucene.Net.Tests/core/Search/TestFieldCacheRangeFilter.cs
+++ b/src/Lucene.Net.Tests/core/Search/TestFieldCacheRangeFilter.cs
@@ -234,75 +234,75 @@ namespace Lucene.Net.Search
 
 #pragma warning disable 612, 618
             // test id, bounded on both ends
-            result = search.Search(q, FieldCacheRangeFilter.NewShortRange("id", minIdO, maxIdO, T, T), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewInt16Range("id", minIdO, maxIdO, T, T), numDocs).ScoreDocs;
             Assert.AreEqual(numDocs, result.Length, "find all");
 
-            result = search.Search(q, FieldCacheRangeFilter.NewShortRange("id", minIdO, maxIdO, T, F), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewInt16Range("id", minIdO, maxIdO, T, F), numDocs).ScoreDocs;
             Assert.AreEqual(numDocs - 1, result.Length, "all but last");
 
-            result = search.Search(q, FieldCacheRangeFilter.NewShortRange("id", minIdO, maxIdO, F, T), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewInt16Range("id", minIdO, maxIdO, F, T), numDocs).ScoreDocs;
             Assert.AreEqual(numDocs - 1, result.Length, "all but first");
 
-            result = search.Search(q, FieldCacheRangeFilter.NewShortRange("id", minIdO, maxIdO, F, F), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewInt16Range("id", minIdO, maxIdO, F, F), numDocs).ScoreDocs;
             Assert.AreEqual(numDocs - 2, result.Length, "all but ends");
 
-            result = search.Search(q, FieldCacheRangeFilter.NewShortRange("id", medIdO, maxIdO, T, T), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewInt16Range("id", medIdO, maxIdO, T, T), numDocs).ScoreDocs;
             Assert.AreEqual(1 + MaxId - medId, result.Length, "med and up");
 
-            result = search.Search(q, FieldCacheRangeFilter.NewShortRange("id", minIdO, medIdO, T, T), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewInt16Range("id", minIdO, medIdO, T, T), numDocs).ScoreDocs;
             Assert.AreEqual(1 + medId - MinId, result.Length, "up to med");
 
             // unbounded id
 
-            result = search.Search(q, FieldCacheRangeFilter.NewShortRange("id", null, null, T, T), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewInt16Range("id", null, null, T, T), numDocs).ScoreDocs;
             Assert.AreEqual(numDocs, result.Length, "find all");
 
-            result = search.Search(q, FieldCacheRangeFilter.NewShortRange("id", minIdO, null, T, F), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewInt16Range("id", minIdO, null, T, F), numDocs).ScoreDocs;
             Assert.AreEqual(numDocs, result.Length, "min and up");
 
-            result = search.Search(q, FieldCacheRangeFilter.NewShortRange("id", null, maxIdO, F, T), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewInt16Range("id", null, maxIdO, F, T), numDocs).ScoreDocs;
             Assert.AreEqual(numDocs, result.Length, "max and down");
 
-            result = search.Search(q, FieldCacheRangeFilter.NewShortRange("id", minIdO, null, F, F), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewInt16Range("id", minIdO, null, F, F), numDocs).ScoreDocs;
             Assert.AreEqual(numDocs - 1, result.Length, "not min, but up");
 
-            result = search.Search(q, FieldCacheRangeFilter.NewShortRange("id", null, maxIdO, F, F), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewInt16Range("id", null, maxIdO, F, F), numDocs).ScoreDocs;
             Assert.AreEqual(numDocs - 1, result.Length, "not max, but down");
 
-            result = search.Search(q, FieldCacheRangeFilter.NewShortRange("id", medIdO, maxIdO, T, F), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewInt16Range("id", medIdO, maxIdO, T, F), numDocs).ScoreDocs;
             Assert.AreEqual(MaxId - medId, result.Length, "med and up, not max");
 
-            result = search.Search(q, FieldCacheRangeFilter.NewShortRange("id", minIdO, medIdO, F, T), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewInt16Range("id", minIdO, medIdO, F, T), numDocs).ScoreDocs;
             Assert.AreEqual(medId - MinId, result.Length, "not min, up to med");
 
             // very small sets
 
-            result = search.Search(q, FieldCacheRangeFilter.NewShortRange("id", minIdO, minIdO, F, F), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewInt16Range("id", minIdO, minIdO, F, F), numDocs).ScoreDocs;
             Assert.AreEqual(0, result.Length, "min,min,F,F");
-            result = search.Search(q, FieldCacheRangeFilter.NewShortRange("id", medIdO, medIdO, F, F), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewInt16Range("id", medIdO, medIdO, F, F), numDocs).ScoreDocs;
             Assert.AreEqual(0, result.Length, "med,med,F,F");
-            result = search.Search(q, FieldCacheRangeFilter.NewShortRange("id", maxIdO, maxIdO, F, F), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewInt16Range("id", maxIdO, maxIdO, F, F), numDocs).ScoreDocs;
             Assert.AreEqual(0, result.Length, "max,max,F,F");
 
-            result = search.Search(q, FieldCacheRangeFilter.NewShortRange("id", minIdO, minIdO, T, T), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewInt16Range("id", minIdO, minIdO, T, T), numDocs).ScoreDocs;
             Assert.AreEqual(1, result.Length, "min,min,T,T");
-            result = search.Search(q, FieldCacheRangeFilter.NewShortRange("id", null, minIdO, F, T), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewInt16Range("id", null, minIdO, F, T), numDocs).ScoreDocs;
             Assert.AreEqual(1, result.Length, "nul,min,F,T");
 
-            result = search.Search(q, FieldCacheRangeFilter.NewShortRange("id", maxIdO, maxIdO, T, T), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewInt16Range("id", maxIdO, maxIdO, T, T), numDocs).ScoreDocs;
             Assert.AreEqual(1, result.Length, "max,max,T,T");
-            result = search.Search(q, FieldCacheRangeFilter.NewShortRange("id", maxIdO, null, T, F), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewInt16Range("id", maxIdO, null, T, F), numDocs).ScoreDocs;
             Assert.AreEqual(1, result.Length, "max,nul,T,T");
 
-            result = search.Search(q, FieldCacheRangeFilter.NewShortRange("id", medIdO, medIdO, T, T), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewInt16Range("id", medIdO, medIdO, T, T), numDocs).ScoreDocs;
             Assert.AreEqual(1, result.Length, "med,med,T,T");
 
             // special cases
-            result = search.Search(q, FieldCacheRangeFilter.NewShortRange("id", Convert.ToInt16(short.MaxValue), null, F, F), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewInt16Range("id", Convert.ToInt16(short.MaxValue), null, F, F), numDocs).ScoreDocs;
             Assert.AreEqual(0, result.Length, "overflow special case");
-            result = search.Search(q, FieldCacheRangeFilter.NewShortRange("id", null, Convert.ToInt16(short.MinValue), F, F), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewInt16Range("id", null, Convert.ToInt16(short.MinValue), F, F), numDocs).ScoreDocs;
             Assert.AreEqual(0, result.Length, "overflow special case");
-            result = search.Search(q, FieldCacheRangeFilter.NewShortRange("id", maxIdO, minIdO, T, T), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewInt16Range("id", maxIdO, minIdO, T, T), numDocs).ScoreDocs;
             Assert.AreEqual(0, result.Length, "inverse range");
 #pragma warning restore 612, 618
         }
@@ -326,75 +326,75 @@ namespace Lucene.Net.Search
 
             // test id, bounded on both ends
 
-            result = search.Search(q, FieldCacheRangeFilter.NewIntRange("id", minIdO, maxIdO, T, T), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewInt32Range("id", minIdO, maxIdO, T, T), numDocs).ScoreDocs;
             Assert.AreEqual(numDocs, result.Length, "find all");
 
-            result = search.Search(q, FieldCacheRangeFilter.NewIntRange("id", minIdO, maxIdO, T, F), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewInt32Range("id", minIdO, maxIdO, T, F), numDocs).ScoreDocs;
             Assert.AreEqual(numDocs - 1, result.Length, "all but last");
 
-            result = search.Search(q, FieldCacheRangeFilter.NewIntRange("id", minIdO, maxIdO, F, T), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewInt32Range("id", minIdO, maxIdO, F, T), numDocs).ScoreDocs;
             Assert.AreEqual(numDocs - 1, result.Length, "all but first");
 
-            result = search.Search(q, FieldCacheRangeFilter.NewIntRange("id", minIdO, maxIdO, F, F), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewInt32Range("id", minIdO, maxIdO, F, F), numDocs).ScoreDocs;
             Assert.AreEqual(numDocs - 2, result.Length, "all but ends");
 
-            result = search.Search(q, FieldCacheRangeFilter.NewIntRange("id", medIdO, maxIdO, T, T), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewInt32Range("id", medIdO, maxIdO, T, T), numDocs).ScoreDocs;
             Assert.AreEqual(1 + MaxId - medId, result.Length, "med and up");
 
-            result = search.Search(q, FieldCacheRangeFilter.NewIntRange("id", minIdO, medIdO, T, T), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewInt32Range("id", minIdO, medIdO, T, T), numDocs).ScoreDocs;
             Assert.AreEqual(1 + medId - MinId, result.Length, "up to med");
 
             // unbounded id
 
-            result = search.Search(q, FieldCacheRangeFilter.NewIntRange("id", null, null, T, T), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewInt32Range("id", null, null, T, T), numDocs).ScoreDocs;
             Assert.AreEqual(numDocs, result.Length, "find all");
 
-            result = search.Search(q, FieldCacheRangeFilter.NewIntRange("id", minIdO, null, T, F), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewInt32Range("id", minIdO, null, T, F), numDocs).ScoreDocs;
             Assert.AreEqual(numDocs, result.Length, "min and up");
 
-            result = search.Search(q, FieldCacheRangeFilter.NewIntRange("id", null, maxIdO, F, T), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewInt32Range("id", null, maxIdO, F, T), numDocs).ScoreDocs;
             Assert.AreEqual(numDocs, result.Length, "max and down");
 
-            result = search.Search(q, FieldCacheRangeFilter.NewIntRange("id", minIdO, null, F, F), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewInt32Range("id", minIdO, null, F, F), numDocs).ScoreDocs;
             Assert.AreEqual(numDocs - 1, result.Length, "not min, but up");
 
-            result = search.Search(q, FieldCacheRangeFilter.NewIntRange("id", null, maxIdO, F, F), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewInt32Range("id", null, maxIdO, F, F), numDocs).ScoreDocs;
             Assert.AreEqual(numDocs - 1, result.Length, "not max, but down");
 
-            result = search.Search(q, FieldCacheRangeFilter.NewIntRange("id", medIdO, maxIdO, T, F), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewInt32Range("id", medIdO, maxIdO, T, F), numDocs).ScoreDocs;
             Assert.AreEqual(MaxId - medId, result.Length, "med and up, not max");
 
-            result = search.Search(q, FieldCacheRangeFilter.NewIntRange("id", minIdO, medIdO, F, T), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewInt32Range("id", minIdO, medIdO, F, T), numDocs).ScoreDocs;
             Assert.AreEqual(medId - MinId, result.Length, "not min, up to med");
 
             // very small sets
 
-            result = search.Search(q, FieldCacheRangeFilter.NewIntRange("id", minIdO, minIdO, F, F), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewInt32Range("id", minIdO, minIdO, F, F), numDocs).ScoreDocs;
             Assert.AreEqual(0, result.Length, "min,min,F,F");
-            result = search.Search(q, FieldCacheRangeFilter.NewIntRange("id", medIdO, medIdO, F, F), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewInt32Range("id", medIdO, medIdO, F, F), numDocs).ScoreDocs;
             Assert.AreEqual(0, result.Length, "med,med,F,F");
-            result = search.Search(q, FieldCacheRangeFilter.NewIntRange("id", maxIdO, maxIdO, F, F), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewInt32Range("id", maxIdO, maxIdO, F, F), numDocs).ScoreDocs;
             Assert.AreEqual(0, result.Length, "max,max,F,F");
 
-            result = search.Search(q, FieldCacheRangeFilter.NewIntRange("id", minIdO, minIdO, T, T), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewInt32Range("id", minIdO, minIdO, T, T), numDocs).ScoreDocs;
             Assert.AreEqual(1, result.Length, "min,min,T,T");
-            result = search.Search(q, FieldCacheRangeFilter.NewIntRange("id", null, minIdO, F, T), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewInt32Range("id", null, minIdO, F, T), numDocs).ScoreDocs;
             Assert.AreEqual(1, result.Length, "nul,min,F,T");
 
-            result = search.Search(q, FieldCacheRangeFilter.NewIntRange("id", maxIdO, maxIdO, T, T), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewInt32Range("id", maxIdO, maxIdO, T, T), numDocs).ScoreDocs;
             Assert.AreEqual(1, result.Length, "max,max,T,T");
-            result = search.Search(q, FieldCacheRangeFilter.NewIntRange("id", maxIdO, null, T, F), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewInt32Range("id", maxIdO, null, T, F), numDocs).ScoreDocs;
             Assert.AreEqual(1, result.Length, "max,nul,T,T");
 
-            result = search.Search(q, FieldCacheRangeFilter.NewIntRange("id", medIdO, medIdO, T, T), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewInt32Range("id", medIdO, medIdO, T, T), numDocs).ScoreDocs;
             Assert.AreEqual(1, result.Length, "med,med,T,T");
 
             // special cases
-            result = search.Search(q, FieldCacheRangeFilter.NewIntRange("id", Convert.ToInt32(int.MaxValue), null, F, F), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewInt32Range("id", Convert.ToInt32(int.MaxValue), null, F, F), numDocs).ScoreDocs;
             Assert.AreEqual(0, result.Length, "overflow special case");
-            result = search.Search(q, FieldCacheRangeFilter.NewIntRange("id", null, Convert.ToInt32(int.MinValue), F, F), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewInt32Range("id", null, Convert.ToInt32(int.MinValue), F, F), numDocs).ScoreDocs;
             Assert.AreEqual(0, result.Length, "overflow special case");
-            result = search.Search(q, FieldCacheRangeFilter.NewIntRange("id", maxIdO, minIdO, T, T), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewInt32Range("id", maxIdO, minIdO, T, T), numDocs).ScoreDocs;
             Assert.AreEqual(0, result.Length, "inverse range");
         }
 
@@ -417,75 +417,75 @@ namespace Lucene.Net.Search
 
             // test id, bounded on both ends
 
-            result = search.Search(q, FieldCacheRangeFilter.NewLongRange("id", minIdO, maxIdO, T, T), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewInt64Range("id", minIdO, maxIdO, T, T), numDocs).ScoreDocs;
             Assert.AreEqual(numDocs, result.Length, "find all");
 
-            result = search.Search(q, FieldCacheRangeFilter.NewLongRange("id", minIdO, maxIdO, T, F), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewInt64Range("id", minIdO, maxIdO, T, F), numDocs).ScoreDocs;
             Assert.AreEqual(numDocs - 1, result.Length, "all but last");
 
-            result = search.Search(q, FieldCacheRangeFilter.NewLongRange("id", minIdO, maxIdO, F, T), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewInt64Range("id", minIdO, maxIdO, F, T), numDocs).ScoreDocs;
             Assert.AreEqual(numDocs - 1, result.Length, "all but first");
 
-            result = search.Search(q, FieldCacheRangeFilter.NewLongRange("id", minIdO, maxIdO, F, F), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewInt64Range("id", minIdO, maxIdO, F, F), numDocs).ScoreDocs;
             Assert.AreEqual(numDocs - 2, result.Length, "all but ends");
 
-            result = search.Search(q, FieldCacheRangeFilter.NewLongRange("id", medIdO, maxIdO, T, T), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewInt64Range("id", medIdO, maxIdO, T, T), numDocs).ScoreDocs;
             Assert.AreEqual(1 + MaxId - medId, result.Length, "med and up");
 
-            result = search.Search(q, FieldCacheRangeFilter.NewLongRange("id", minIdO, medIdO, T, T), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewInt64Range("id", minIdO, medIdO, T, T), numDocs).ScoreDocs;
             Assert.AreEqual(1 + medId - MinId, result.Length, "up to med");
 
             // unbounded id
 
-            result = search.Search(q, FieldCacheRangeFilter.NewLongRange("id", null, null, T, T), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewInt64Range("id", null, null, T, T), numDocs).ScoreDocs;
             Assert.AreEqual(numDocs, result.Length, "find all");
 
-            result = search.Search(q, FieldCacheRangeFilter.NewLongRange("id", minIdO, null, T, F), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewInt64Range("id", minIdO, null, T, F), numDocs).ScoreDocs;
             Assert.AreEqual(numDocs, result.Length, "min and up");
 
-            result = search.Search(q, FieldCacheRangeFilter.NewLongRange("id", null, maxIdO, F, T), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewInt64Range("id", null, maxIdO, F, T), numDocs).ScoreDocs;
             Assert.AreEqual(numDocs, result.Length, "max and down");
 
-            result = search.Search(q, FieldCacheRangeFilter.NewLongRange("id", minIdO, null, F, F), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewInt64Range("id", minIdO, null, F, F), numDocs).ScoreDocs;
             Assert.AreEqual(numDocs - 1, result.Length, "not min, but up");
 
-            result = search.Search(q, FieldCacheRangeFilter.NewLongRange("id", null, maxIdO, F, F), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewInt64Range("id", null, maxIdO, F, F), numDocs).ScoreDocs;
             Assert.AreEqual(numDocs - 1, result.Length, "not max, but down");
 
-            result = search.Search(q, FieldCacheRangeFilter.NewLongRange("id", medIdO, maxIdO, T, F), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewInt64Range("id", medIdO, maxIdO, T, F), numDocs).ScoreDocs;
             Assert.AreEqual(MaxId - medId, result.Length, "med and up, not max");
 
-            result = search.Search(q, FieldCacheRangeFilter.NewLongRange("id", minIdO, medIdO, F, T), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewInt64Range("id", minIdO, medIdO, F, T), numDocs).ScoreDocs;
             Assert.AreEqual(medId - MinId, result.Length, "not min, up to med");
 
             // very small sets
 
-            result = search.Search(q, FieldCacheRangeFilter.NewLongRange("id", minIdO, minIdO, F, F), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewInt64Range("id", minIdO, minIdO, F, F), numDocs).ScoreDocs;
             Assert.AreEqual(0, result.Length, "min,min,F,F");
-            result = search.Search(q, FieldCacheRangeFilter.NewLongRange("id", medIdO, medIdO, F, F), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewInt64Range("id", medIdO, medIdO, F, F), numDocs).ScoreDocs;
             Assert.AreEqual(0, result.Length, "med,med,F,F");
-            result = search.Search(q, FieldCacheRangeFilter.NewLongRange("id", maxIdO, maxIdO, F, F), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewInt64Range("id", maxIdO, maxIdO, F, F), numDocs).ScoreDocs;
             Assert.AreEqual(0, result.Length, "max,max,F,F");
 
-            result = search.Search(q, FieldCacheRangeFilter.NewLongRange("id", minIdO, minIdO, T, T), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewInt64Range("id", minIdO, minIdO, T, T), numDocs).ScoreDocs;
             Assert.AreEqual(1, result.Length, "min,min,T,T");
-            result = search.Search(q, FieldCacheRangeFilter.NewLongRange("id", null, minIdO, F, T), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewInt64Range("id", null, minIdO, F, T), numDocs).ScoreDocs;
             Assert.AreEqual(1, result.Length, "nul,min,F,T");
 
-            result = search.Search(q, FieldCacheRangeFilter.NewLongRange("id", maxIdO, maxIdO, T, T), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewInt64Range("id", maxIdO, maxIdO, T, T), numDocs).ScoreDocs;
             Assert.AreEqual(1, result.Length, "max,max,T,T");
-            result = search.Search(q, FieldCacheRangeFilter.NewLongRange("id", maxIdO, null, T, F), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewInt64Range("id", maxIdO, null, T, F), numDocs).ScoreDocs;
             Assert.AreEqual(1, result.Length, "max,nul,T,T");
 
-            result = search.Search(q, FieldCacheRangeFilter.NewLongRange("id", medIdO, medIdO, T, T), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewInt64Range("id", medIdO, medIdO, T, T), numDocs).ScoreDocs;
             Assert.AreEqual(1, result.Length, "med,med,T,T");
 
             // special cases
-            result = search.Search(q, FieldCacheRangeFilter.NewLongRange("id", Convert.ToInt64(long.MaxValue), null, F, F), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewInt64Range("id", Convert.ToInt64(long.MaxValue), null, F, F), numDocs).ScoreDocs;
             Assert.AreEqual(0, result.Length, "overflow special case");
-            result = search.Search(q, FieldCacheRangeFilter.NewLongRange("id", null, Convert.ToInt64(long.MinValue), F, F), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewInt64Range("id", null, Convert.ToInt64(long.MinValue), F, F), numDocs).ScoreDocs;
             Assert.AreEqual(0, result.Length, "overflow special case");
-            result = search.Search(q, FieldCacheRangeFilter.NewLongRange("id", maxIdO, minIdO, T, T), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewInt64Range("id", maxIdO, minIdO, T, T), numDocs).ScoreDocs;
             Assert.AreEqual(0, result.Length, "inverse range");
         }
 
@@ -504,19 +504,19 @@ namespace Lucene.Net.Search
             ScoreDoc[] result;
             Query q = new TermQuery(new Term("body", "body"));
 
-            result = search.Search(q, FieldCacheRangeFilter.NewFloatRange("id", minIdO, medIdO, T, T), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewSingleRange("id", minIdO, medIdO, T, T), numDocs).ScoreDocs;
             Assert.AreEqual(numDocs / 2, result.Length, "find all");
             int count = 0;
-            result = search.Search(q, FieldCacheRangeFilter.NewFloatRange("id", null, medIdO, F, T), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewSingleRange("id", null, medIdO, F, T), numDocs).ScoreDocs;
             count += result.Length;
-            result = search.Search(q, FieldCacheRangeFilter.NewFloatRange("id", medIdO, null, F, F), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewSingleRange("id", medIdO, null, F, F), numDocs).ScoreDocs;
             count += result.Length;
             Assert.AreEqual(numDocs, count, "sum of two concenatted ranges");
-            result = search.Search(q, FieldCacheRangeFilter.NewFloatRange("id", null, null, T, T), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewSingleRange("id", null, null, T, T), numDocs).ScoreDocs;
             Assert.AreEqual(numDocs, result.Length, "find all");
-            result = search.Search(q, FieldCacheRangeFilter.NewFloatRange("id", Convert.ToSingle(float.PositiveInfinity), null, F, F), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewSingleRange("id", Convert.ToSingle(float.PositiveInfinity), null, F, F), numDocs).ScoreDocs;
             Assert.AreEqual(0, result.Length, "infinity special case");
-            result = search.Search(q, FieldCacheRangeFilter.NewFloatRange("id", null, Convert.ToSingle(float.NegativeInfinity), F, F), numDocs).ScoreDocs;
+            result = search.Search(q, FieldCacheRangeFilter.NewSingleRange("id", null, Convert.ToSingle(float.NegativeInfinity), F, F), numDocs).ScoreDocs;
             Assert.AreEqual(0, result.Length, "infinity special case");
         }
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Tests/core/Search/TestMultiValuedNumericRangeQuery.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Search/TestMultiValuedNumericRangeQuery.cs b/src/Lucene.Net.Tests/core/Search/TestMultiValuedNumericRangeQuery.cs
index c473302..8c5b83a 100644
--- a/src/Lucene.Net.Tests/core/Search/TestMultiValuedNumericRangeQuery.cs
+++ b/src/Lucene.Net.Tests/core/Search/TestMultiValuedNumericRangeQuery.cs
@@ -76,7 +76,7 @@ namespace Lucene.Net.Search
                     upper = a;
                 }
                 TermRangeQuery cq = TermRangeQuery.NewStringRange("asc", lower.ToString(format), upper.ToString(format), true, true);
-                NumericRangeQuery<int> tq = NumericRangeQuery.NewIntRange("trie", lower, upper, true, true);
+                NumericRangeQuery<int> tq = NumericRangeQuery.NewInt32Range("trie", lower, upper, true, true);
                 TopDocs trTopDocs = searcher.Search(cq, 1);
                 TopDocs nrTopDocs = searcher.Search(tq, 1);
                 Assert.AreEqual(trTopDocs.TotalHits, nrTopDocs.TotalHits, "Returned count for NumericRangeQuery and TermRangeQuery must be equal");

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Tests/core/Search/TestNumericRangeQuery32.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Search/TestNumericRangeQuery32.cs b/src/Lucene.Net.Tests/core/Search/TestNumericRangeQuery32.cs
index ce5741d..cc0da97 100644
--- a/src/Lucene.Net.Tests/core/Search/TestNumericRangeQuery32.cs
+++ b/src/Lucene.Net.Tests/core/Search/TestNumericRangeQuery32.cs
@@ -160,8 +160,8 @@ namespace Lucene.Net.Search
             string field = "field" + precisionStep;
             int count = 3000;
             int lower = (Distance * 3 / 2) + StartOffset, upper = lower + count * Distance + (Distance / 3);
-            NumericRangeQuery<int> q = NumericRangeQuery.NewIntRange(field, precisionStep, lower, upper, true, true);
-            NumericRangeFilter<int> f = NumericRangeFilter.NewIntRange(field, precisionStep, lower, upper, true, true);
+            NumericRangeQuery<int> q = NumericRangeQuery.NewInt32Range(field, precisionStep, lower, upper, true, true);
+            NumericRangeFilter<int> f = NumericRangeFilter.NewInt32Range(field, precisionStep, lower, upper, true, true);
             for (sbyte i = 0; i < 3; i++)
             {
                 TopDocs topDocs;
@@ -220,18 +220,18 @@ namespace Lucene.Net.Search
         public virtual void TestInverseRange()
         {
             AtomicReaderContext context = (AtomicReaderContext)SlowCompositeReaderWrapper.Wrap(Reader).Context;
-            NumericRangeFilter<int> f = NumericRangeFilter.NewIntRange("field8", 8, 1000, -1000, true, true);
+            NumericRangeFilter<int> f = NumericRangeFilter.NewInt32Range("field8", 8, 1000, -1000, true, true);
             Assert.IsNull(f.GetDocIdSet(context, (context.AtomicReader).LiveDocs), "A inverse range should return the null instance");
-            f = NumericRangeFilter.NewIntRange("field8", 8, int.MaxValue, null, false, false);
+            f = NumericRangeFilter.NewInt32Range("field8", 8, int.MaxValue, null, false, false);
             Assert.IsNull(f.GetDocIdSet(context, (context.AtomicReader).LiveDocs), "A exclusive range starting with Integer.MAX_VALUE should return the null instance");
-            f = NumericRangeFilter.NewIntRange("field8", 8, null, int.MinValue, false, false);
+            f = NumericRangeFilter.NewInt32Range("field8", 8, null, int.MinValue, false, false);
             Assert.IsNull(f.GetDocIdSet(context, (context.AtomicReader).LiveDocs), "A exclusive range ending with Integer.MIN_VALUE should return the null instance");
         }
 
         [Test]
         public virtual void TestOneMatchQuery()
         {
-            NumericRangeQuery<int> q = NumericRangeQuery.NewIntRange("ascfield8", 8, 1000, 1000, true, true);
+            NumericRangeQuery<int> q = NumericRangeQuery.NewInt32Range("ascfield8", 8, 1000, 1000, true, true);
             TopDocs topDocs = Searcher.Search(q, NoDocs);
             ScoreDoc[] sd = topDocs.ScoreDocs;
             Assert.IsNotNull(sd);
@@ -243,7 +243,7 @@ namespace Lucene.Net.Search
             string field = "field" + precisionStep;
             int count = 3000;
             int upper = (count - 1) * Distance + (Distance / 3) + StartOffset;
-            NumericRangeQuery<int> q = NumericRangeQuery.NewIntRange(field, precisionStep, null, upper, true, true);
+            NumericRangeQuery<int> q = NumericRangeQuery.NewInt32Range(field, precisionStep, null, upper, true, true);
             TopDocs topDocs = Searcher.Search(q, null, NoDocs, Sort.INDEXORDER);
             ScoreDoc[] sd = topDocs.ScoreDocs;
             Assert.IsNotNull(sd);
@@ -253,7 +253,7 @@ namespace Lucene.Net.Search
             doc = Searcher.Doc(sd[sd.Length - 1].Doc);
             Assert.AreEqual((count - 1) * Distance + StartOffset, (int)doc.GetField(field).GetNumericValue(), "Last doc");
 
-            q = NumericRangeQuery.NewIntRange(field, precisionStep, null, upper, false, true);
+            q = NumericRangeQuery.NewInt32Range(field, precisionStep, null, upper, false, true);
             topDocs = Searcher.Search(q, null, NoDocs, Sort.INDEXORDER);
             sd = topDocs.ScoreDocs;
             Assert.IsNotNull(sd);
@@ -287,7 +287,7 @@ namespace Lucene.Net.Search
             string field = "field" + precisionStep;
             int count = 3000;
             int lower = (count - 1) * Distance + (Distance / 3) + StartOffset;
-            NumericRangeQuery<int> q = NumericRangeQuery.NewIntRange(field, precisionStep, lower, null, true, true);
+            NumericRangeQuery<int> q = NumericRangeQuery.NewInt32Range(field, precisionStep, lower, null, true, true);
             TopDocs topDocs = Searcher.Search(q, null, NoDocs, Sort.INDEXORDER);
             ScoreDoc[] sd = topDocs.ScoreDocs;
             Assert.IsNotNull(sd);
@@ -297,7 +297,7 @@ namespace Lucene.Net.Search
             doc = Searcher.Doc(sd[sd.Length - 1].Doc);
             Assert.AreEqual((NoDocs - 1) * Distance + StartOffset, (int)doc.GetField(field).GetNumericValue(), "Last doc");
 
-            q = NumericRangeQuery.NewIntRange(field, precisionStep, lower, null, true, false);
+            q = NumericRangeQuery.NewInt32Range(field, precisionStep, lower, null, true, false);
             topDocs = Searcher.Search(q, null, NoDocs, Sort.INDEXORDER);
             sd = topDocs.ScoreDocs;
             Assert.IsNotNull(sd);
@@ -358,39 +358,39 @@ namespace Lucene.Net.Search
             IndexReader r = DirectoryReader.Open(dir);
             IndexSearcher s = NewSearcher(r);
 
-            Query q = NumericRangeQuery.NewIntRange("int", null, null, true, true);
+            Query q = NumericRangeQuery.NewInt32Range("int", null, null, true, true);
             TopDocs topDocs = s.Search(q, 10);
             Assert.AreEqual(3, topDocs.ScoreDocs.Length, "Score doc count");
 
-            q = NumericRangeQuery.NewIntRange("int", null, null, false, false);
+            q = NumericRangeQuery.NewInt32Range("int", null, null, false, false);
             topDocs = s.Search(q, 10);
             Assert.AreEqual(3, topDocs.ScoreDocs.Length, "Score doc count");
 
-            q = NumericRangeQuery.NewIntRange("int", int.MinValue, int.MaxValue, true, true);
+            q = NumericRangeQuery.NewInt32Range("int", int.MinValue, int.MaxValue, true, true);
             topDocs = s.Search(q, 10);
             Assert.AreEqual(3, topDocs.ScoreDocs.Length, "Score doc count");
 
-            q = NumericRangeQuery.NewIntRange("int", int.MinValue, int.MaxValue, false, false);
+            q = NumericRangeQuery.NewInt32Range("int", int.MinValue, int.MaxValue, false, false);
             topDocs = s.Search(q, 10);
             Assert.AreEqual(1, topDocs.ScoreDocs.Length, "Score doc count");
 
-            q = NumericRangeQuery.NewFloatRange("float", null, null, true, true);
+            q = NumericRangeQuery.NewSingleRange("float", null, null, true, true);
             topDocs = s.Search(q, 10);
             Assert.AreEqual(3, topDocs.ScoreDocs.Length, "Score doc count");
 
-            q = NumericRangeQuery.NewFloatRange("float", null, null, false, false);
+            q = NumericRangeQuery.NewSingleRange("float", null, null, false, false);
             topDocs = s.Search(q, 10);
             Assert.AreEqual(3, topDocs.ScoreDocs.Length, "Score doc count");
 
-            q = NumericRangeQuery.NewFloatRange("float", float.NegativeInfinity, float.PositiveInfinity, true, true);
+            q = NumericRangeQuery.NewSingleRange("float", float.NegativeInfinity, float.PositiveInfinity, true, true);
             topDocs = s.Search(q, 10);
             Assert.AreEqual(3, topDocs.ScoreDocs.Length, "Score doc count");
 
-            q = NumericRangeQuery.NewFloatRange("float", float.NegativeInfinity, float.PositiveInfinity, false, false);
+            q = NumericRangeQuery.NewSingleRange("float", float.NegativeInfinity, float.PositiveInfinity, false, false);
             topDocs = s.Search(q, 10);
             Assert.AreEqual(1, topDocs.ScoreDocs.Length, "Score doc count");
 
-            q = NumericRangeQuery.NewFloatRange("float", float.NaN, float.NaN, true, true);
+            q = NumericRangeQuery.NewSingleRange("float", float.NaN, float.NaN, true, true);
             topDocs = s.Search(q, 10);
             Assert.AreEqual(TestNumericUtils.FLOAT_NANs.Length, topDocs.ScoreDocs.Length, "Score doc count");
 
@@ -414,11 +414,11 @@ namespace Lucene.Net.Search
                     upper = a;
                 }
                 BytesRef lowerBytes = new BytesRef(NumericUtils.BUF_SIZE_INT), upperBytes = new BytesRef(NumericUtils.BUF_SIZE_INT);
-                NumericUtils.IntToPrefixCodedBytes(lower, 0, lowerBytes);
-                NumericUtils.IntToPrefixCodedBytes(upper, 0, upperBytes);
+                NumericUtils.Int32ToPrefixCodedBytes(lower, 0, lowerBytes);
+                NumericUtils.Int32ToPrefixCodedBytes(upper, 0, upperBytes);
 
                 // test inclusive range
-                NumericRangeQuery<int> tq = NumericRangeQuery.NewIntRange(field, precisionStep, lower, upper, true, true);
+                NumericRangeQuery<int> tq = NumericRangeQuery.NewInt32Range(field, precisionStep, lower, upper, true, true);
                 TermRangeQuery cq = new TermRangeQuery(field, lowerBytes, upperBytes, true, true);
                 TopDocs tTopDocs = Searcher.Search(tq, 1);
                 TopDocs cTopDocs = Searcher.Search(cq, 1);
@@ -427,7 +427,7 @@ namespace Lucene.Net.Search
                 totalTermCountC += termCountC = CountTerms(cq);
                 CheckTermCounts(precisionStep, termCountT, termCountC);
                 // test exclusive range
-                tq = NumericRangeQuery.NewIntRange(field, precisionStep, lower, upper, false, false);
+                tq = NumericRangeQuery.NewInt32Range(field, precisionStep, lower, upper, false, false);
                 cq = new TermRangeQuery(field, lowerBytes, upperBytes, false, false);
                 tTopDocs = Searcher.Search(tq, 1);
                 cTopDocs = Searcher.Search(cq, 1);
@@ -436,7 +436,7 @@ namespace Lucene.Net.Search
                 totalTermCountC += termCountC = CountTerms(cq);
                 CheckTermCounts(precisionStep, termCountT, termCountC);
                 // test left exclusive range
-                tq = NumericRangeQuery.NewIntRange(field, precisionStep, lower, upper, false, true);
+                tq = NumericRangeQuery.NewInt32Range(field, precisionStep, lower, upper, false, true);
                 cq = new TermRangeQuery(field, lowerBytes, upperBytes, false, true);
                 tTopDocs = Searcher.Search(tq, 1);
                 cTopDocs = Searcher.Search(cq, 1);
@@ -445,7 +445,7 @@ namespace Lucene.Net.Search
                 totalTermCountC += termCountC = CountTerms(cq);
                 CheckTermCounts(precisionStep, termCountT, termCountC);
                 // test right exclusive range
-                tq = NumericRangeQuery.NewIntRange(field, precisionStep, lower, upper, true, false);
+                tq = NumericRangeQuery.NewInt32Range(field, precisionStep, lower, upper, true, false);
                 cq = new TermRangeQuery(field, lowerBytes, upperBytes, true, false);
                 tTopDocs = Searcher.Search(tq, 1);
                 cTopDocs = Searcher.Search(cq, 1);
@@ -471,13 +471,13 @@ namespace Lucene.Net.Search
             int lower = (Distance * 3 / 2) + StartOffset, upper = lower + count * Distance + (Distance / 3);
             // test empty enum
             Debug.Assert(lower < upper);
-            Assert.IsTrue(0 < CountTerms(NumericRangeQuery.NewIntRange("field4", 4, lower, upper, true, true)));
-            Assert.AreEqual(0, CountTerms(NumericRangeQuery.NewIntRange("field4", 4, upper, lower, true, true)));
+            Assert.IsTrue(0 < CountTerms(NumericRangeQuery.NewInt32Range("field4", 4, lower, upper, true, true)));
+            Assert.AreEqual(0, CountTerms(NumericRangeQuery.NewInt32Range("field4", 4, upper, lower, true, true)));
             // test empty enum outside of bounds
             lower = Distance * NoDocs + StartOffset;
             upper = 2 * lower;
             Debug.Assert(lower < upper);
-            Assert.AreEqual(0, CountTerms(NumericRangeQuery.NewIntRange("field4", 4, lower, upper, true, true)));
+            Assert.AreEqual(0, CountTerms(NumericRangeQuery.NewInt32Range("field4", 4, lower, upper, true, true)));
         }
 
         private int CountTerms(MultiTermQuery q)
@@ -557,19 +557,19 @@ namespace Lucene.Net.Search
                     upper = a;
                 }
                 // test inclusive range
-                Query tq = NumericRangeQuery.NewIntRange(field, precisionStep, lower, upper, true, true);
+                Query tq = NumericRangeQuery.NewInt32Range(field, precisionStep, lower, upper, true, true);
                 TopDocs tTopDocs = Searcher.Search(tq, 1);
                 Assert.AreEqual(upper - lower + 1, tTopDocs.TotalHits, "Returned count of range query must be equal to inclusive range length");
                 // test exclusive range
-                tq = NumericRangeQuery.NewIntRange(field, precisionStep, lower, upper, false, false);
+                tq = NumericRangeQuery.NewInt32Range(field, precisionStep, lower, upper, false, false);
                 tTopDocs = Searcher.Search(tq, 1);
                 Assert.AreEqual(Math.Max(upper - lower - 1, 0), tTopDocs.TotalHits, "Returned count of range query must be equal to exclusive range length");
                 // test left exclusive range
-                tq = NumericRangeQuery.NewIntRange(field, precisionStep, lower, upper, false, true);
+                tq = NumericRangeQuery.NewInt32Range(field, precisionStep, lower, upper, false, true);
                 tTopDocs = Searcher.Search(tq, 1);
                 Assert.AreEqual(upper - lower, tTopDocs.TotalHits, "Returned count of range query must be equal to half exclusive range length");
                 // test right exclusive range
-                tq = NumericRangeQuery.NewIntRange(field, precisionStep, lower, upper, true, false);
+                tq = NumericRangeQuery.NewInt32Range(field, precisionStep, lower, upper, true, false);
                 tTopDocs = Searcher.Search(tq, 1);
                 Assert.AreEqual(upper - lower, tTopDocs.TotalHits, "Returned count of range query must be equal to half exclusive range length");
             }
@@ -600,11 +600,11 @@ namespace Lucene.Net.Search
             string field = "ascfield" + precisionStep;
             const int lower = -1000, upper = +2000;
 
-            Query tq = NumericRangeQuery.NewFloatRange(field, precisionStep, NumericUtils.SortableIntToFloat(lower), NumericUtils.SortableIntToFloat(upper), true, true);
+            Query tq = NumericRangeQuery.NewSingleRange(field, precisionStep, NumericUtils.SortableInt32ToSingle(lower), NumericUtils.SortableInt32ToSingle(upper), true, true);
             TopDocs tTopDocs = Searcher.Search(tq, 1);
             Assert.AreEqual(upper - lower + 1, tTopDocs.TotalHits, "Returned count of range query must be equal to inclusive range length");
 
-            Filter tf = NumericRangeFilter.NewFloatRange(field, precisionStep, NumericUtils.SortableIntToFloat(lower), NumericUtils.SortableIntToFloat(upper), true, true);
+            Filter tf = NumericRangeFilter.NewSingleRange(field, precisionStep, NumericUtils.SortableInt32ToSingle(lower), NumericUtils.SortableInt32ToSingle(upper), true, true);
             tTopDocs = Searcher.Search(new MatchAllDocsQuery(), tf, 1);
             Assert.AreEqual(upper - lower + 1, tTopDocs.TotalHits, "Returned count of range filter must be equal to inclusive range length");
         }
@@ -643,7 +643,7 @@ namespace Lucene.Net.Search
                     lower = upper;
                     upper = a;
                 }
-                Query tq = NumericRangeQuery.NewIntRange(field, precisionStep, lower, upper, true, true);
+                Query tq = NumericRangeQuery.NewInt32Range(field, precisionStep, lower, upper, true, true);
                 TopDocs topDocs = Searcher.Search(tq, null, NoDocs, new Sort(new SortField(field, SortFieldType.INT, true)));
                 if (topDocs.TotalHits == 0)
                 {
@@ -682,22 +682,22 @@ namespace Lucene.Net.Search
         [Test]
         public virtual void TestEqualsAndHash()
         {
-            QueryUtils.CheckHashEquals(NumericRangeQuery.NewIntRange("test1", 4, 10, 20, true, true));
-            QueryUtils.CheckHashEquals(NumericRangeQuery.NewIntRange("test2", 4, 10, 20, false, true));
-            QueryUtils.CheckHashEquals(NumericRangeQuery.NewIntRange("test3", 4, 10, 20, true, false));
-            QueryUtils.CheckHashEquals(NumericRangeQuery.NewIntRange("test4", 4, 10, 20, false, false));
-            QueryUtils.CheckHashEquals(NumericRangeQuery.NewIntRange("test5", 4, 10, null, true, true));
-            QueryUtils.CheckHashEquals(NumericRangeQuery.NewIntRange("test6", 4, null, 20, true, true));
-            QueryUtils.CheckHashEquals(NumericRangeQuery.NewIntRange("test7", 4, null, null, true, true));
-            QueryUtils.CheckEqual(NumericRangeQuery.NewIntRange("test8", 4, 10, 20, true, true), NumericRangeQuery.NewIntRange("test8", 4, 10, 20, true, true));
-            QueryUtils.CheckUnequal(NumericRangeQuery.NewIntRange("test9", 4, 10, 20, true, true), NumericRangeQuery.NewIntRange("test9", 8, 10, 20, true, true));
-            QueryUtils.CheckUnequal(NumericRangeQuery.NewIntRange("test10a", 4, 10, 20, true, true), NumericRangeQuery.NewIntRange("test10b", 4, 10, 20, true, true));
-            QueryUtils.CheckUnequal(NumericRangeQuery.NewIntRange("test11", 4, 10, 20, true, true), NumericRangeQuery.NewIntRange("test11", 4, 20, 10, true, true));
-            QueryUtils.CheckUnequal(NumericRangeQuery.NewIntRange("test12", 4, 10, 20, true, true), NumericRangeQuery.NewIntRange("test12", 4, 10, 20, false, true));
-            QueryUtils.CheckUnequal(NumericRangeQuery.NewIntRange("test13", 4, 10, 20, true, true), NumericRangeQuery.NewFloatRange("test13", 4, 10f, 20f, true, true));
+            QueryUtils.CheckHashEquals(NumericRangeQuery.NewInt32Range("test1", 4, 10, 20, true, true));
+            QueryUtils.CheckHashEquals(NumericRangeQuery.NewInt32Range("test2", 4, 10, 20, false, true));
+            QueryUtils.CheckHashEquals(NumericRangeQuery.NewInt32Range("test3", 4, 10, 20, true, false));
+            QueryUtils.CheckHashEquals(NumericRangeQuery.NewInt32Range("test4", 4, 10, 20, false, false));
+            QueryUtils.CheckHashEquals(NumericRangeQuery.NewInt32Range("test5", 4, 10, null, true, true));
+            QueryUtils.CheckHashEquals(NumericRangeQuery.NewInt32Range("test6", 4, null, 20, true, true));
+            QueryUtils.CheckHashEquals(NumericRangeQuery.NewInt32Range("test7", 4, null, null, true, true));
+            QueryUtils.CheckEqual(NumericRangeQuery.NewInt32Range("test8", 4, 10, 20, true, true), NumericRangeQuery.NewInt32Range("test8", 4, 10, 20, true, true));
+            QueryUtils.CheckUnequal(NumericRangeQuery.NewInt32Range("test9", 4, 10, 20, true, true), NumericRangeQuery.NewInt32Range("test9", 8, 10, 20, true, true));
+            QueryUtils.CheckUnequal(NumericRangeQuery.NewInt32Range("test10a", 4, 10, 20, true, true), NumericRangeQuery.NewInt32Range("test10b", 4, 10, 20, true, true));
+            QueryUtils.CheckUnequal(NumericRangeQuery.NewInt32Range("test11", 4, 10, 20, true, true), NumericRangeQuery.NewInt32Range("test11", 4, 20, 10, true, true));
+            QueryUtils.CheckUnequal(NumericRangeQuery.NewInt32Range("test12", 4, 10, 20, true, true), NumericRangeQuery.NewInt32Range("test12", 4, 10, 20, false, true));
+            QueryUtils.CheckUnequal(NumericRangeQuery.NewInt32Range("test13", 4, 10, 20, true, true), NumericRangeQuery.NewSingleRange("test13", 4, 10f, 20f, true, true));
             // the following produces a hash collision, because Long and Integer have the same hashcode, so only test equality:
-            Query q1 = NumericRangeQuery.NewIntRange("test14", 4, 10, 20, true, true);
-            Query q2 = NumericRangeQuery.NewLongRange("test14", 4, 10L, 20L, true, true);
+            Query q1 = NumericRangeQuery.NewInt32Range("test14", 4, 10, 20, true, true);
+            Query q2 = NumericRangeQuery.NewInt64Range("test14", 4, 10L, 20L, true, true);
             Assert.IsFalse(q1.Equals(q2));
             Assert.IsFalse(q2.Equals(q1));
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Tests/core/Search/TestNumericRangeQuery64.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Search/TestNumericRangeQuery64.cs b/src/Lucene.Net.Tests/core/Search/TestNumericRangeQuery64.cs
index 861f3cd..a1525f7 100644
--- a/src/Lucene.Net.Tests/core/Search/TestNumericRangeQuery64.cs
+++ b/src/Lucene.Net.Tests/core/Search/TestNumericRangeQuery64.cs
@@ -169,8 +169,8 @@ namespace Lucene.Net.Search
             string field = "field" + precisionStep;
             int count = 3000;
             long lower = (Distance * 3 / 2) + StartOffset, upper = lower + count * Distance + (Distance / 3);
-            NumericRangeQuery<long> q = NumericRangeQuery.NewLongRange(field, precisionStep, lower, upper, true, true);
-            NumericRangeFilter<long> f = NumericRangeFilter.NewLongRange(field, precisionStep, lower, upper, true, true);
+            NumericRangeQuery<long> q = NumericRangeQuery.NewInt64Range(field, precisionStep, lower, upper, true, true);
+            NumericRangeFilter<long> f = NumericRangeFilter.NewInt64Range(field, precisionStep, lower, upper, true, true);
             for (sbyte i = 0; i < 3; i++)
             {
                 TopDocs topDocs;
@@ -235,18 +235,18 @@ namespace Lucene.Net.Search
         public virtual void TestInverseRange()
         {
             AtomicReaderContext context = (AtomicReaderContext)SlowCompositeReaderWrapper.Wrap(Searcher.IndexReader).Context;
-            NumericRangeFilter<long> f = NumericRangeFilter.NewLongRange("field8", 8, 1000L, -1000L, true, true);
+            NumericRangeFilter<long> f = NumericRangeFilter.NewInt64Range("field8", 8, 1000L, -1000L, true, true);
             Assert.IsNull(f.GetDocIdSet(context, (context.AtomicReader).LiveDocs), "A inverse range should return the null instance");
-            f = NumericRangeFilter.NewLongRange("field8", 8, long.MaxValue, null, false, false);
+            f = NumericRangeFilter.NewInt64Range("field8", 8, long.MaxValue, null, false, false);
             Assert.IsNull(f.GetDocIdSet(context, (context.AtomicReader).LiveDocs), "A exclusive range starting with Long.MAX_VALUE should return the null instance");
-            f = NumericRangeFilter.NewLongRange("field8", 8, null, long.MinValue, false, false);
+            f = NumericRangeFilter.NewInt64Range("field8", 8, null, long.MinValue, false, false);
             Assert.IsNull(f.GetDocIdSet(context, (context.AtomicReader).LiveDocs), "A exclusive range ending with Long.MIN_VALUE should return the null instance");
         }
 
         [Test]
         public virtual void TestOneMatchQuery()
         {
-            NumericRangeQuery<long> q = NumericRangeQuery.NewLongRange("ascfield8", 8, 1000L, 1000L, true, true);
+            NumericRangeQuery<long> q = NumericRangeQuery.NewInt64Range("ascfield8", 8, 1000L, 1000L, true, true);
             TopDocs topDocs = Searcher.Search(q, NoDocs);
             ScoreDoc[] sd = topDocs.ScoreDocs;
             Assert.IsNotNull(sd);
@@ -258,7 +258,7 @@ namespace Lucene.Net.Search
             string field = "field" + precisionStep;
             int count = 3000;
             long upper = (count - 1) * Distance + (Distance / 3) + StartOffset;
-            NumericRangeQuery<long> q = NumericRangeQuery.NewLongRange(field, precisionStep, null, upper, true, true);
+            NumericRangeQuery<long> q = NumericRangeQuery.NewInt64Range(field, precisionStep, null, upper, true, true);
             TopDocs topDocs = Searcher.Search(q, null, NoDocs, Sort.INDEXORDER);
             ScoreDoc[] sd = topDocs.ScoreDocs;
             Assert.IsNotNull(sd);
@@ -268,7 +268,7 @@ namespace Lucene.Net.Search
             doc = Searcher.Doc(sd[sd.Length - 1].Doc);
             Assert.AreEqual((count - 1) * Distance + StartOffset, (long)doc.GetField(field).GetNumericValue(), "Last doc");
 
-            q = NumericRangeQuery.NewLongRange(field, precisionStep, null, upper, false, true);
+            q = NumericRangeQuery.NewInt64Range(field, precisionStep, null, upper, false, true);
             topDocs = Searcher.Search(q, null, NoDocs, Sort.INDEXORDER);
             sd = topDocs.ScoreDocs;
             Assert.IsNotNull(sd);
@@ -308,7 +308,7 @@ namespace Lucene.Net.Search
             string field = "field" + precisionStep;
             int count = 3000;
             long lower = (count - 1) * Distance + (Distance / 3) + StartOffset;
-            NumericRangeQuery<long> q = NumericRangeQuery.NewLongRange(field, precisionStep, lower, null, true, true);
+            NumericRangeQuery<long> q = NumericRangeQuery.NewInt64Range(field, precisionStep, lower, null, true, true);
             TopDocs topDocs = Searcher.Search(q, null, NoDocs, Sort.INDEXORDER);
             ScoreDoc[] sd = topDocs.ScoreDocs;
             Assert.IsNotNull(sd);
@@ -318,7 +318,7 @@ namespace Lucene.Net.Search
             doc = Searcher.Doc(sd[sd.Length - 1].Doc);
             Assert.AreEqual((NoDocs - 1) * Distance + StartOffset, (long)doc.GetField(field).GetNumericValue(), "Last doc");
 
-            q = NumericRangeQuery.NewLongRange(field, precisionStep, lower, null, true, false);
+            q = NumericRangeQuery.NewInt64Range(field, precisionStep, lower, null, true, false);
             topDocs = Searcher.Search(q, null, NoDocs, Sort.INDEXORDER);
             sd = topDocs.ScoreDocs;
             Assert.IsNotNull(sd);
@@ -385,19 +385,19 @@ namespace Lucene.Net.Search
             IndexReader r = DirectoryReader.Open(dir);
             IndexSearcher s = NewSearcher(r);
 
-            Query q = NumericRangeQuery.NewLongRange("long", null, null, true, true);
+            Query q = NumericRangeQuery.NewInt64Range("long", null, null, true, true);
             TopDocs topDocs = s.Search(q, 10);
             Assert.AreEqual(3, topDocs.ScoreDocs.Length, "Score doc count");
 
-            q = NumericRangeQuery.NewLongRange("long", null, null, false, false);
+            q = NumericRangeQuery.NewInt64Range("long", null, null, false, false);
             topDocs = s.Search(q, 10);
             Assert.AreEqual(3, topDocs.ScoreDocs.Length, "Score doc count");
 
-            q = NumericRangeQuery.NewLongRange("long", long.MinValue, long.MaxValue, true, true);
+            q = NumericRangeQuery.NewInt64Range("long", long.MinValue, long.MaxValue, true, true);
             topDocs = s.Search(q, 10);
             Assert.AreEqual(3, topDocs.ScoreDocs.Length, "Score doc count");
 
-            q = NumericRangeQuery.NewLongRange("long", long.MinValue, long.MaxValue, false, false);
+            q = NumericRangeQuery.NewInt64Range("long", long.MinValue, long.MaxValue, false, false);
             topDocs = s.Search(q, 10);
             Assert.AreEqual(1, topDocs.ScoreDocs.Length, "Score doc count");
 
@@ -441,11 +441,11 @@ namespace Lucene.Net.Search
                     upper = a;
                 }
                 BytesRef lowerBytes = new BytesRef(NumericUtils.BUF_SIZE_LONG), upperBytes = new BytesRef(NumericUtils.BUF_SIZE_LONG);
-                NumericUtils.LongToPrefixCodedBytes(lower, 0, lowerBytes);
-                NumericUtils.LongToPrefixCodedBytes(upper, 0, upperBytes);
+                NumericUtils.Int64ToPrefixCodedBytes(lower, 0, lowerBytes);
+                NumericUtils.Int64ToPrefixCodedBytes(upper, 0, upperBytes);
 
                 // test inclusive range
-                NumericRangeQuery<long> tq = NumericRangeQuery.NewLongRange(field, precisionStep, lower, upper, true, true);
+                NumericRangeQuery<long> tq = NumericRangeQuery.NewInt64Range(field, precisionStep, lower, upper, true, true);
                 TermRangeQuery cq = new TermRangeQuery(field, lowerBytes, upperBytes, true, true);
                 TopDocs tTopDocs = Searcher.Search(tq, 1);
                 TopDocs cTopDocs = Searcher.Search(cq, 1);
@@ -454,7 +454,7 @@ namespace Lucene.Net.Search
                 totalTermCountC += termCountC = CountTerms(cq);
                 CheckTermCounts(precisionStep, termCountT, termCountC);
                 // test exclusive range
-                tq = NumericRangeQuery.NewLongRange(field, precisionStep, lower, upper, false, false);
+                tq = NumericRangeQuery.NewInt64Range(field, precisionStep, lower, upper, false, false);
                 cq = new TermRangeQuery(field, lowerBytes, upperBytes, false, false);
                 tTopDocs = Searcher.Search(tq, 1);
                 cTopDocs = Searcher.Search(cq, 1);
@@ -463,7 +463,7 @@ namespace Lucene.Net.Search
                 totalTermCountC += termCountC = CountTerms(cq);
                 CheckTermCounts(precisionStep, termCountT, termCountC);
                 // test left exclusive range
-                tq = NumericRangeQuery.NewLongRange(field, precisionStep, lower, upper, false, true);
+                tq = NumericRangeQuery.NewInt64Range(field, precisionStep, lower, upper, false, true);
                 cq = new TermRangeQuery(field, lowerBytes, upperBytes, false, true);
                 tTopDocs = Searcher.Search(tq, 1);
                 cTopDocs = Searcher.Search(cq, 1);
@@ -472,7 +472,7 @@ namespace Lucene.Net.Search
                 totalTermCountC += termCountC = CountTerms(cq);
                 CheckTermCounts(precisionStep, termCountT, termCountC);
                 // test right exclusive range
-                tq = NumericRangeQuery.NewLongRange(field, precisionStep, lower, upper, true, false);
+                tq = NumericRangeQuery.NewInt64Range(field, precisionStep, lower, upper, true, false);
                 cq = new TermRangeQuery(field, lowerBytes, upperBytes, true, false);
                 tTopDocs = Searcher.Search(tq, 1);
                 cTopDocs = Searcher.Search(cq, 1);
@@ -498,13 +498,13 @@ namespace Lucene.Net.Search
             long lower = (Distance * 3 / 2) + StartOffset, upper = lower + count * Distance + (Distance / 3);
             // test empty enum
             Debug.Assert(lower < upper);
-            Assert.IsTrue(0 < CountTerms(NumericRangeQuery.NewLongRange("field4", 4, lower, upper, true, true)));
-            Assert.AreEqual(0, CountTerms(NumericRangeQuery.NewLongRange("field4", 4, upper, lower, true, true)));
+            Assert.IsTrue(0 < CountTerms(NumericRangeQuery.NewInt64Range("field4", 4, lower, upper, true, true)));
+            Assert.AreEqual(0, CountTerms(NumericRangeQuery.NewInt64Range("field4", 4, upper, lower, true, true)));
             // test empty enum outside of bounds
             lower = Distance * NoDocs + StartOffset;
             upper = 2L * lower;
             Debug.Assert(lower < upper);
-            Assert.AreEqual(0, CountTerms(NumericRangeQuery.NewLongRange("field4", 4, lower, upper, true, true)));
+            Assert.AreEqual(0, CountTerms(NumericRangeQuery.NewInt64Range("field4", 4, lower, upper, true, true)));
         }
 
         private int CountTerms(MultiTermQuery q)
@@ -590,19 +590,19 @@ namespace Lucene.Net.Search
                     upper = a;
                 }
                 // test inclusive range
-                Query tq = NumericRangeQuery.NewLongRange(field, precisionStep, lower, upper, true, true);
+                Query tq = NumericRangeQuery.NewInt64Range(field, precisionStep, lower, upper, true, true);
                 TopDocs tTopDocs = Searcher.Search(tq, 1);
                 Assert.AreEqual(upper - lower + 1, tTopDocs.TotalHits, "Returned count of range query must be equal to inclusive range length");
                 // test exclusive range
-                tq = NumericRangeQuery.NewLongRange(field, precisionStep, lower, upper, false, false);
+                tq = NumericRangeQuery.NewInt64Range(field, precisionStep, lower, upper, false, false);
                 tTopDocs = Searcher.Search(tq, 1);
                 Assert.AreEqual(Math.Max(upper - lower - 1, 0), tTopDocs.TotalHits, "Returned count of range query must be equal to exclusive range length");
                 // test left exclusive range
-                tq = NumericRangeQuery.NewLongRange(field, precisionStep, lower, upper, false, true);
+                tq = NumericRangeQuery.NewInt64Range(field, precisionStep, lower, upper, false, true);
                 tTopDocs = Searcher.Search(tq, 1);
                 Assert.AreEqual(upper - lower, tTopDocs.TotalHits, "Returned count of range query must be equal to half exclusive range length");
                 // test right exclusive range
-                tq = NumericRangeQuery.NewLongRange(field, precisionStep, lower, upper, true, false);
+                tq = NumericRangeQuery.NewInt64Range(field, precisionStep, lower, upper, true, false);
                 tTopDocs = Searcher.Search(tq, 1);
                 Assert.AreEqual(upper - lower, tTopDocs.TotalHits, "Returned count of range query must be equal to half exclusive range length");
             }
@@ -639,11 +639,11 @@ namespace Lucene.Net.Search
             string field = "ascfield" + precisionStep;
             const long lower = -1000L, upper = +2000L;
 
-            Query tq = NumericRangeQuery.NewDoubleRange(field, precisionStep, NumericUtils.SortableLongToDouble(lower), NumericUtils.SortableLongToDouble(upper), true, true);
+            Query tq = NumericRangeQuery.NewDoubleRange(field, precisionStep, NumericUtils.SortableInt64ToDouble(lower), NumericUtils.SortableInt64ToDouble(upper), true, true);
             TopDocs tTopDocs = Searcher.Search(tq, 1);
             Assert.AreEqual(upper - lower + 1, tTopDocs.TotalHits, "Returned count of range query must be equal to inclusive range length");
 
-            Filter tf = NumericRangeFilter.NewDoubleRange(field, precisionStep, NumericUtils.SortableLongToDouble(lower), NumericUtils.SortableLongToDouble(upper), true, true);
+            Filter tf = NumericRangeFilter.NewDoubleRange(field, precisionStep, NumericUtils.SortableInt64ToDouble(lower), NumericUtils.SortableInt64ToDouble(upper), true, true);
             tTopDocs = Searcher.Search(new MatchAllDocsQuery(), tf, 1);
             Assert.AreEqual(upper - lower + 1, tTopDocs.TotalHits, "Returned count of range filter must be equal to inclusive range length");
         }
@@ -688,7 +688,7 @@ namespace Lucene.Net.Search
                     lower = upper;
                     upper = a;
                 }
-                Query tq = NumericRangeQuery.NewLongRange(field, precisionStep, lower, upper, true, true);
+                Query tq = NumericRangeQuery.NewInt64Range(field, precisionStep, lower, upper, true, true);
                 TopDocs topDocs = Searcher.Search(tq, null, NoDocs, new Sort(new SortField(field, SortFieldType.LONG, true)));
                 if (topDocs.TotalHits == 0)
                 {
@@ -733,19 +733,19 @@ namespace Lucene.Net.Search
         [Test]
         public virtual void TestEqualsAndHash()
         {
-            QueryUtils.CheckHashEquals(NumericRangeQuery.NewLongRange("test1", 4, 10L, 20L, true, true));
-            QueryUtils.CheckHashEquals(NumericRangeQuery.NewLongRange("test2", 4, 10L, 20L, false, true));
-            QueryUtils.CheckHashEquals(NumericRangeQuery.NewLongRange("test3", 4, 10L, 20L, true, false));
-            QueryUtils.CheckHashEquals(NumericRangeQuery.NewLongRange("test4", 4, 10L, 20L, false, false));
-            QueryUtils.CheckHashEquals(NumericRangeQuery.NewLongRange("test5", 4, 10L, null, true, true));
-            QueryUtils.CheckHashEquals(NumericRangeQuery.NewLongRange("test6", 4, null, 20L, true, true));
-            QueryUtils.CheckHashEquals(NumericRangeQuery.NewLongRange("test7", 4, null, null, true, true));
-            QueryUtils.CheckEqual(NumericRangeQuery.NewLongRange("test8", 4, 10L, 20L, true, true), NumericRangeQuery.NewLongRange("test8", 4, 10L, 20L, true, true));
-            QueryUtils.CheckUnequal(NumericRangeQuery.NewLongRange("test9", 4, 10L, 20L, true, true), NumericRangeQuery.NewLongRange("test9", 8, 10L, 20L, true, true));
-            QueryUtils.CheckUnequal(NumericRangeQuery.NewLongRange("test10a", 4, 10L, 20L, true, true), NumericRangeQuery.NewLongRange("test10b", 4, 10L, 20L, true, true));
-            QueryUtils.CheckUnequal(NumericRangeQuery.NewLongRange("test11", 4, 10L, 20L, true, true), NumericRangeQuery.NewLongRange("test11", 4, 20L, 10L, true, true));
-            QueryUtils.CheckUnequal(NumericRangeQuery.NewLongRange("test12", 4, 10L, 20L, true, true), NumericRangeQuery.NewLongRange("test12", 4, 10L, 20L, false, true));
-            QueryUtils.CheckUnequal(NumericRangeQuery.NewLongRange("test13", 4, 10L, 20L, true, true), NumericRangeQuery.NewFloatRange("test13", 4, 10f, 20f, true, true));
+            QueryUtils.CheckHashEquals(NumericRangeQuery.NewInt64Range("test1", 4, 10L, 20L, true, true));
+            QueryUtils.CheckHashEquals(NumericRangeQuery.NewInt64Range("test2", 4, 10L, 20L, false, true));
+            QueryUtils.CheckHashEquals(NumericRangeQuery.NewInt64Range("test3", 4, 10L, 20L, true, false));
+            QueryUtils.CheckHashEquals(NumericRangeQuery.NewInt64Range("test4", 4, 10L, 20L, false, false));
+            QueryUtils.CheckHashEquals(NumericRangeQuery.NewInt64Range("test5", 4, 10L, null, true, true));
+            QueryUtils.CheckHashEquals(NumericRangeQuery.NewInt64Range("test6", 4, null, 20L, true, true));
+            QueryUtils.CheckHashEquals(NumericRangeQuery.NewInt64Range("test7", 4, null, null, true, true));
+            QueryUtils.CheckEqual(NumericRangeQuery.NewInt64Range("test8", 4, 10L, 20L, true, true), NumericRangeQuery.NewInt64Range("test8", 4, 10L, 20L, true, true));
+            QueryUtils.CheckUnequal(NumericRangeQuery.NewInt64Range("test9", 4, 10L, 20L, true, true), NumericRangeQuery.NewInt64Range("test9", 8, 10L, 20L, true, true));
+            QueryUtils.CheckUnequal(NumericRangeQuery.NewInt64Range("test10a", 4, 10L, 20L, true, true), NumericRangeQuery.NewInt64Range("test10b", 4, 10L, 20L, true, true));
+            QueryUtils.CheckUnequal(NumericRangeQuery.NewInt64Range("test11", 4, 10L, 20L, true, true), NumericRangeQuery.NewInt64Range("test11", 4, 20L, 10L, true, true));
+            QueryUtils.CheckUnequal(NumericRangeQuery.NewInt64Range("test12", 4, 10L, 20L, true, true), NumericRangeQuery.NewInt64Range("test12", 4, 10L, 20L, false, true));
+            QueryUtils.CheckUnequal(NumericRangeQuery.NewInt64Range("test13", 4, 10L, 20L, true, true), NumericRangeQuery.NewSingleRange("test13", 4, 10f, 20f, true, true));
             // difference to int range is tested in TestNumericRangeQuery32
         }
     }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Tests/core/Search/TestQueryRescorer.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Search/TestQueryRescorer.cs b/src/Lucene.Net.Tests/core/Search/TestQueryRescorer.cs
index 1d3cab5..aa585fc 100644
--- a/src/Lucene.Net.Tests/core/Search/TestQueryRescorer.cs
+++ b/src/Lucene.Net.Tests/core/Search/TestQueryRescorer.cs
@@ -586,7 +586,7 @@ namespace Lucene.Net.Search
                     return false;
                 }
                 FixedScoreQuery other = (FixedScoreQuery)o;
-                return Number.FloatToIntBits(Boost) == Number.FloatToIntBits(other.Boost) && Reverse == other.Reverse && Arrays.Equals(IdToNum, other.IdToNum);
+                return Number.SingleToInt32Bits(Boost) == Number.SingleToInt32Bits(other.Boost) && Reverse == other.Reverse && Arrays.Equals(IdToNum, other.IdToNum);
             }
 
             public override object Clone()

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Tests/core/Search/TestSort.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Search/TestSort.cs b/src/Lucene.Net.Tests/core/Search/TestSort.cs
index 2a31834..92253c2 100644
--- a/src/Lucene.Net.Tests/core/Search/TestSort.cs
+++ b/src/Lucene.Net.Tests/core/Search/TestSort.cs
@@ -1556,7 +1556,10 @@ namespace Lucene.Net.Search
                 this.OuterInstance = outerInstance;
             }
 
-            public int ParseInt(BytesRef term)
+            /// <summary>
+            /// NOTE: This was parseInt() in Lucene
+            /// </summary>
+            public int ParseInt32(BytesRef term)
             {
                 return (term.Bytes[term.Offset] - 'A') * 123456;
             }
@@ -1672,7 +1675,10 @@ namespace Lucene.Net.Search
                 this.OuterInstance = outerInstance;
             }
 
-            public short ParseShort(BytesRef term)
+            /// <summary>
+            /// NOTE: This was parseShort() in Lucene
+            /// </summary>
+            public short ParseInt16(BytesRef term)
             {
                 return (short)(term.Bytes[term.Offset] - 'A');
             }
@@ -1730,7 +1736,10 @@ namespace Lucene.Net.Search
                 this.OuterInstance = outerInstance;
             }
 
-            public long ParseLong(BytesRef term)
+            /// <summary>
+            /// NOTE: This was parseLong() in Lucene
+            /// </summary>
+            public long ParseInt64(BytesRef term)
             {
                 return (term.Bytes[term.Offset] - 'A') * 1234567890L;
             }
@@ -1788,7 +1797,10 @@ namespace Lucene.Net.Search
                 this.OuterInstance = outerInstance;
             }
 
-            public float ParseFloat(BytesRef term)
+            /// <summary>
+            /// NOTE: This was parseFloat() in Lucene
+            /// </summary>
+            public float ParseSingle(BytesRef term)
             {
                 return (float)Math.Sqrt(term.Bytes[term.Offset]);
             }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Tests/core/Search/TestSortRandom.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Search/TestSortRandom.cs b/src/Lucene.Net.Tests/core/Search/TestSortRandom.cs
index 7973806..5687659 100644
--- a/src/Lucene.Net.Tests/core/Search/TestSortRandom.cs
+++ b/src/Lucene.Net.Tests/core/Search/TestSortRandom.cs
@@ -345,7 +345,7 @@ namespace Lucene.Net.Search
             public override DocIdSet GetDocIdSet(AtomicReaderContext context, IBits acceptDocs)
             {
                 int maxDoc = context.Reader.MaxDoc;
-                FieldCache.Ints idSource = FieldCache.DEFAULT.GetInts(context.AtomicReader, "id", false);
+                FieldCache.Ints idSource = FieldCache.DEFAULT.GetInt32s(context.AtomicReader, "id", false);
                 Assert.IsNotNull(idSource);
                 FixedBitSet bits = new FixedBitSet(maxDoc);
                 for (int docID = 0; docID < maxDoc; docID++)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Tests/core/Store/TestFileSwitchDirectory.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Store/TestFileSwitchDirectory.cs b/src/Lucene.Net.Tests/core/Store/TestFileSwitchDirectory.cs
index 8228e10..3eb0de7 100644
--- a/src/Lucene.Net.Tests/core/Store/TestFileSwitchDirectory.cs
+++ b/src/Lucene.Net.Tests/core/Store/TestFileSwitchDirectory.cs
@@ -153,7 +153,7 @@ namespace Lucene.Net.Store
             var csw = new CompoundFileDirectory(newDir, "d.cfs", NewIOContext(Random()), true);
             CreateSequenceFile(newDir, "d1", (sbyte)0, 15);
             IndexOutput @out = csw.CreateOutput("d.xyz", NewIOContext(Random()));
-            @out.WriteInt(0);
+            @out.WriteInt32(0);
             @out.Dispose();
             Assert.AreEqual(1, csw.ListAll().Length);
             Assert.AreEqual("d.xyz", csw.ListAll()[0]);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Tests/core/Store/TestMultiMMap.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Store/TestMultiMMap.cs b/src/Lucene.Net.Tests/core/Store/TestMultiMMap.cs
index 6e609c3..8341b1a 100644
--- a/src/Lucene.Net.Tests/core/Store/TestMultiMMap.cs
+++ b/src/Lucene.Net.Tests/core/Store/TestMultiMMap.cs
@@ -64,7 +64,7 @@ namespace Lucene.Net.Store
         {
             MMapDirectory mmapDir = new MMapDirectory(CreateTempDir("testCloneSafety"));
             IndexOutput io = mmapDir.CreateOutput("bytes", NewIOContext(Random()));
-            io.WriteVInt(5);
+            io.WriteVInt32(5);
             io.Dispose();
             IndexInput one = mmapDir.OpenInput("bytes", IOContext.DEFAULT);
             IndexInput two = (IndexInput)one.Clone();
@@ -72,7 +72,7 @@ namespace Lucene.Net.Store
             one.Dispose();
             try
             {
-                one.ReadVInt();
+                one.ReadVInt32();
                 Assert.Fail("Must throw AlreadyClosedException");
             }
 #pragma warning disable 168
@@ -83,7 +83,7 @@ namespace Lucene.Net.Store
             }
             try
             {
-                two.ReadVInt();
+                two.ReadVInt32();
                 Assert.Fail("Must throw AlreadyClosedException");
             }
 #pragma warning disable 168
@@ -94,7 +94,7 @@ namespace Lucene.Net.Store
             }
             try
             {
-                three.ReadVInt();
+                three.ReadVInt32();
                 Assert.Fail("Must throw AlreadyClosedException");
             }
 #pragma warning disable 168
@@ -115,16 +115,16 @@ namespace Lucene.Net.Store
         {
             MMapDirectory mmapDir = new MMapDirectory(CreateTempDir("testCloneClose"));
             IndexOutput io = mmapDir.CreateOutput("bytes", NewIOContext(Random()));
-            io.WriteVInt(5);
+            io.WriteVInt32(5);
             io.Dispose();
             IndexInput one = mmapDir.OpenInput("bytes", IOContext.DEFAULT);
             IndexInput two = (IndexInput)one.Clone();
             IndexInput three = (IndexInput)two.Clone(); // clone of clone
             two.Dispose();
-            Assert.AreEqual(5, one.ReadVInt());
+            Assert.AreEqual(5, one.ReadVInt32());
             try
             {
-                two.ReadVInt();
+                two.ReadVInt32();
                 Assert.Fail("Must throw AlreadyClosedException");
             }
 #pragma warning disable 168
@@ -133,7 +133,7 @@ namespace Lucene.Net.Store
             {
                 // pass
             }
-            Assert.AreEqual(5, three.ReadVInt());
+            Assert.AreEqual(5, three.ReadVInt32());
             one.Dispose();
             three.Dispose();
             mmapDir.Dispose();
@@ -144,8 +144,8 @@ namespace Lucene.Net.Store
         {
             MMapDirectory mmapDir = new MMapDirectory(CreateTempDir("testCloneSliceSafety"));
             IndexOutput io = mmapDir.CreateOutput("bytes", NewIOContext(Random()));
-            io.WriteInt(1);
-            io.WriteInt(2);
+            io.WriteInt32(1);
+            io.WriteInt32(2);
             io.Dispose();
             IndexInputSlicer slicer = mmapDir.CreateSlicer("bytes", NewIOContext(Random()));
             IndexInput one = slicer.OpenSlice("first int", 0, 4);
@@ -155,7 +155,7 @@ namespace Lucene.Net.Store
             slicer.Dispose();
             try
             {
-                one.ReadInt();
+                one.ReadInt32();
                 Assert.Fail("Must throw AlreadyClosedException");
             }
 #pragma warning disable 168
@@ -166,7 +166,7 @@ namespace Lucene.Net.Store
             }
             try
             {
-                two.ReadInt();
+                two.ReadInt32();
                 Assert.Fail("Must throw AlreadyClosedException");
             }
 #pragma warning disable 168
@@ -177,7 +177,7 @@ namespace Lucene.Net.Store
             }
             try
             {
-                three.ReadInt();
+                three.ReadInt32();
                 Assert.Fail("Must throw AlreadyClosedException");
             }
 #pragma warning disable 168
@@ -188,7 +188,7 @@ namespace Lucene.Net.Store
             }
             try
             {
-                four.ReadInt();
+                four.ReadInt32();
                 Assert.Fail("Must throw AlreadyClosedException");
             }
 #pragma warning disable 168
@@ -211,8 +211,8 @@ namespace Lucene.Net.Store
         {
             MMapDirectory mmapDir = new MMapDirectory(CreateTempDir("testCloneSliceClose"));
             IndexOutput io = mmapDir.CreateOutput("bytes", NewIOContext(Random()));
-            io.WriteInt(1);
-            io.WriteInt(2);
+            io.WriteInt32(1);
+            io.WriteInt32(2);
             io.Dispose();
             IndexInputSlicer slicer = mmapDir.CreateSlicer("bytes", NewIOContext(Random()));
             IndexInput one = slicer.OpenSlice("first int", 0, 4);
@@ -220,7 +220,7 @@ namespace Lucene.Net.Store
             one.Dispose();
             try
             {
-                one.ReadInt();
+                one.ReadInt32();
                 Assert.Fail("Must throw AlreadyClosedException");
             }
 #pragma warning disable 168
@@ -229,10 +229,10 @@ namespace Lucene.Net.Store
             {
                 // pass
             }
-            Assert.AreEqual(2, two.ReadInt());
+            Assert.AreEqual(2, two.ReadInt32());
             // reopen a new slice "one":
             one = slicer.OpenSlice("first int", 0, 4);
-            Assert.AreEqual(1, one.ReadInt());
+            Assert.AreEqual(1, one.ReadInt32());
             one.Dispose();
             two.Dispose();
             slicer.Dispose();

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Tests/core/Store/TestNRTCachingDirectory.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Store/TestNRTCachingDirectory.cs b/src/Lucene.Net.Tests/core/Store/TestNRTCachingDirectory.cs
index 0fa65e3..806295b 100644
--- a/src/Lucene.Net.Tests/core/Store/TestNRTCachingDirectory.cs
+++ b/src/Lucene.Net.Tests/core/Store/TestNRTCachingDirectory.cs
@@ -184,7 +184,7 @@ namespace Lucene.Net.Store
             CompoundFileDirectory csw = new CompoundFileDirectory(newDir, "d.cfs", NewIOContext(Random()), true);
             CreateSequenceFile(newDir, "d1", (sbyte)0, 15);
             IndexOutput @out = csw.CreateOutput("d.xyz", NewIOContext(Random()));
-            @out.WriteInt(0);
+            @out.WriteInt32(0);
             @out.Dispose();
             Assert.AreEqual(1, csw.ListAll().Length);
             Assert.AreEqual("d.xyz", csw.ListAll()[0]);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Tests/core/Support/TestByteBuffer.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Support/TestByteBuffer.cs b/src/Lucene.Net.Tests/core/Support/TestByteBuffer.cs
index 322645a..b386f4d 100644
--- a/src/Lucene.Net.Tests/core/Support/TestByteBuffer.cs
+++ b/src/Lucene.Net.Tests/core/Support/TestByteBuffer.cs
@@ -181,7 +181,7 @@ namespace Lucene.Net.Support
             //checkBytes(b, new byte[] { 0, 0, 0, (byte)ic(0) });
             //checkInvalidMarkException(ib);
 
-            LongBuffer lb = b.AsLongBuffer();
+            LongBuffer lb = b.AsInt64Buffer();
             TestLongBuffer.test(level, lb, direct);
             checkBytes(b, new byte[] { 0, 0, 0, 0, 0, 0, 0, (byte)Ic(0) });
             checkInvalidMarkException(lb);
@@ -209,21 +209,21 @@ namespace Lucene.Net.Support
             b.PutChar((char)char.MaxValue);
             output.Write(" char");
 
-            b.PutShort((short)1);
-            b.PutShort((short)short.MaxValue);
+            b.PutInt16((short)1);
+            b.PutInt16((short)short.MaxValue);
             output.Write(" short");
 
-            b.PutInt(1);
-            b.PutInt(int.MaxValue);
+            b.PutInt32(1);
+            b.PutInt32(int.MaxValue);
             output.Write(" int");
 
-            b.PutLong((long)1);
-            b.PutLong((long)long.MaxValue);
+            b.PutInt64((long)1);
+            b.PutInt64((long)long.MaxValue);
             output.Write(" long");
 
-            b.PutFloat((float)1);
-            b.PutFloat((float)float.MinValue);
-            b.PutFloat((float)float.MaxValue);
+            b.PutSingle((float)1);
+            b.PutSingle((float)float.MinValue);
+            b.PutSingle((float)float.MaxValue);
             output.Write(" float");
 
             b.PutDouble((double)1);
@@ -241,21 +241,21 @@ namespace Lucene.Net.Support
             ck(b, b.GetChar(), char.MaxValue);
             output.Write(" char");
 
-            ck(b, b.GetShort(), 1);
-            ck(b, b.GetShort(), short.MaxValue);
+            ck(b, b.GetInt16(), 1);
+            ck(b, b.GetInt16(), short.MaxValue);
             output.Write(" short");
 
-            ck(b, b.GetInt(), 1);
-            ck(b, b.GetInt(), int.MaxValue);
+            ck(b, b.GetInt32(), 1);
+            ck(b, b.GetInt32(), int.MaxValue);
             output.Write(" int");
 
-            ck(b, b.GetLong(), 1);
-            ck(b, b.GetLong(), long.MaxValue);
+            ck(b, b.GetInt64(), 1);
+            ck(b, b.GetInt64(), long.MaxValue);
             output.Write(" long");
 
-            ck(b, (long)b.GetFloat(), 1);
-            ck(b, (long)b.GetFloat(), unchecked((long)float.MinValue));
-            ck(b, (long)b.GetFloat(), unchecked((long)float.MaxValue));
+            ck(b, (long)b.GetSingle(), 1);
+            ck(b, (long)b.GetSingle(), unchecked((long)float.MinValue));
+            ck(b, (long)b.GetSingle(), unchecked((long)float.MaxValue));
             output.Write(" float");
 
             ck(b, (long)b.GetDouble(), 1);
@@ -575,38 +575,38 @@ namespace Lucene.Net.Support
 
             tryCatch(b, typeof(ReadOnlyBufferException), () =>
             {
-                rb.PutShort((short)1);
+                rb.PutInt16((short)1);
             });
             tryCatch(b, typeof(ReadOnlyBufferException), () =>
             {
-                rb.PutShort(0, (short)1);
+                rb.PutInt16(0, (short)1);
             });
 
             tryCatch(b, typeof(ReadOnlyBufferException), () =>
             {
-                rb.PutInt(1);
+                rb.PutInt32(1);
             });
             tryCatch(b, typeof(ReadOnlyBufferException), () =>
             {
-                rb.PutInt(0, 1);
+                rb.PutInt32(0, 1);
             });
 
             tryCatch(b, typeof(ReadOnlyBufferException), () =>
             {
-                rb.PutLong((long)1);
+                rb.PutInt64((long)1);
             });
             tryCatch(b, typeof(ReadOnlyBufferException), () =>
             {
-                rb.PutLong(0, (long)1);
+                rb.PutInt64(0, (long)1);
             });
 
             tryCatch(b, typeof(ReadOnlyBufferException), () =>
             {
-                rb.PutFloat((float)1);
+                rb.PutSingle((float)1);
             });
             tryCatch(b, typeof(ReadOnlyBufferException), () =>
             {
-                rb.PutFloat(0, (float)1);
+                rb.PutSingle(0, (float)1);
             });
 
             tryCatch(b, typeof(ReadOnlyBufferException), () =>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Tests/core/Support/TestLongBuffer.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Support/TestLongBuffer.cs b/src/Lucene.Net.Tests/core/Support/TestLongBuffer.cs
index 7055211..c4f0947 100644
--- a/src/Lucene.Net.Tests/core/Support/TestLongBuffer.cs
+++ b/src/Lucene.Net.Tests/core/Support/TestLongBuffer.cs
@@ -122,19 +122,19 @@ namespace Lucene.Net.Support
             // LUCENENET: AllocateDirect not implemented
 
             //LongBuffer direct1 = ByteBuffer.AllocateDirect(cap).AsLongBuffer();
-            LongBuffer nondirect1 = ByteBuffer.Allocate(cap).AsLongBuffer();
+            LongBuffer nondirect1 = ByteBuffer.Allocate(cap).AsInt64Buffer();
             //direct1.Put(nondirect1);
 
             //LongBuffer direct2 = ByteBuffer.AllocateDirect(cap).AsLongBuffer();
-            LongBuffer nondirect2 = ByteBuffer.Allocate(cap).AsLongBuffer();
+            LongBuffer nondirect2 = ByteBuffer.Allocate(cap).AsInt64Buffer();
             //nondirect2.Put(direct2);
 
             //LongBuffer direct3 = ByteBuffer.AllocateDirect(cap).AsLongBuffer();
             //LongBuffer direct4 = ByteBuffer.AllocateDirect(cap).AsLongBuffer();
             //direct3.Put(direct4);
 
-            LongBuffer nondirect3 = ByteBuffer.Allocate(cap).AsLongBuffer();
-            LongBuffer nondirect4 = ByteBuffer.Allocate(cap).AsLongBuffer();
+            LongBuffer nondirect3 = ByteBuffer.Allocate(cap).AsInt64Buffer();
+            LongBuffer nondirect4 = ByteBuffer.Allocate(cap).AsInt64Buffer();
             nondirect3.Put(nondirect4);
         }
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Tests/core/Util/Automaton/TestSpecialOperations.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Util/Automaton/TestSpecialOperations.cs b/src/Lucene.Net.Tests/core/Util/Automaton/TestSpecialOperations.cs
index 5f0dac7..5eb06cc 100644
--- a/src/Lucene.Net.Tests/core/Util/Automaton/TestSpecialOperations.cs
+++ b/src/Lucene.Net.Tests/core/Util/Automaton/TestSpecialOperations.cs
@@ -51,10 +51,10 @@ namespace Lucene.Net.Util.Automaton
             ISet<IntsRef> strings = SpecialOperations.GetFiniteStrings(a, -1);
             Assert.AreEqual(2, strings.Count);
             IntsRef dog = new IntsRef();
-            Util.ToIntsRef(new BytesRef("dog"), dog);
+            Util.ToInt32sRef(new BytesRef("dog"), dog);
             Assert.IsTrue(strings.Contains(dog));
             IntsRef duck = new IntsRef();
-            Util.ToIntsRef(new BytesRef("duck"), duck);
+            Util.ToInt32sRef(new BytesRef("duck"), duck);
             Assert.IsTrue(strings.Contains(duck));
         }
     }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Tests/core/Util/Fst/TestBytesStore.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Util/Fst/TestBytesStore.cs b/src/Lucene.Net.Tests/core/Util/Fst/TestBytesStore.cs
index b2b6379..beb674d 100644
--- a/src/Lucene.Net.Tests/core/Util/Fst/TestBytesStore.cs
+++ b/src/Lucene.Net.Tests/core/Util/Fst/TestBytesStore.cs
@@ -104,7 +104,7 @@ namespace Lucene.Net.Util.Fst
                                     {
                                         Console.WriteLine("    abs writeInt pos=" + randomPos + " x=" + x);
                                     }
-                                    bytes.WriteInt(randomPos, x);
+                                    bytes.WriteInt32(randomPos, x);
                                     expected[randomPos++] = (byte)(x >> 24);
                                     expected[randomPos++] = (byte)(x >> 16);
                                     expected[randomPos++] = (byte)(x >> 8);
@@ -424,7 +424,7 @@ namespace Lucene.Net.Util.Fst
                         }
 
                         r.SkipBytes(skipBytes);
-                        Assert.AreEqual(expectedInt, r.ReadInt());
+                        Assert.AreEqual(expectedInt, r.ReadInt32());
                     }
                 }
             }


[51/53] [abbrv] lucenenet git commit: Lucene.Net.Core.Index.Fields refactor: Renamed Terms() > GetTerms()

Posted by ni...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.Tests/core/Index/TestStressIndexing2.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Index/TestStressIndexing2.cs b/src/Lucene.Net.Tests/core/Index/TestStressIndexing2.cs
index 0135b61..f073cb4 100644
--- a/src/Lucene.Net.Tests/core/Index/TestStressIndexing2.cs
+++ b/src/Lucene.Net.Tests/core/Index/TestStressIndexing2.cs
@@ -366,10 +366,10 @@ namespace Lucene.Net.Index
                 Assert.IsNull(MultiFields.GetFields(r2));
                 return;
             }
-            Terms terms1 = f1.Terms(idField);
+            Terms terms1 = f1.GetTerms(idField);
             if (terms1 == null)
             {
-                Assert.IsTrue(MultiFields.GetFields(r2) == null || MultiFields.GetFields(r2).Terms(idField) == null);
+                Assert.IsTrue(MultiFields.GetFields(r2) == null || MultiFields.GetFields(r2).GetTerms(idField) == null);
                 return;
             }
             TermsEnum termsEnum = terms1.GetIterator(null);
@@ -394,7 +394,7 @@ namespace Lucene.Net.Index
                 }
                 return;
             }
-            Terms terms2 = fields.Terms(idField);
+            Terms terms2 = fields.GetTerms(idField);
             TermsEnum termsEnum2 = terms2.GetIterator(null);
 
             DocsEnum termDocs1 = null;
@@ -465,7 +465,7 @@ namespace Lucene.Net.Index
                         foreach (string field in tv1)
                         {
                             Console.WriteLine("    " + field + ":");
-                            Terms terms3 = tv1.Terms(field);
+                            Terms terms3 = tv1.GetTerms(field);
                             Assert.IsNotNull(terms3);
                             TermsEnum termsEnum3 = terms3.GetIterator(null);
                             BytesRef term2;
@@ -504,7 +504,7 @@ namespace Lucene.Net.Index
                         foreach (string field in tv2)
                         {
                             Console.WriteLine("    " + field + ":");
-                            Terms terms3 = tv2.Terms(field);
+                            Terms terms3 = tv2.GetTerms(field);
                             Assert.IsNotNull(terms3);
                             TermsEnum termsEnum3 = terms3.GetIterator(null);
                             BytesRef term2;
@@ -572,7 +572,7 @@ namespace Lucene.Net.Index
                             break;
                         }
                         field1 = fields1Enum.Current;
-                        Terms terms = fields1.Terms(field1);
+                        Terms terms = fields1.GetTerms(field1);
                         if (terms == null)
                         {
                             continue;
@@ -614,7 +614,7 @@ namespace Lucene.Net.Index
                             break;
                         }
                         field2 = fields2Enum.Current;
-                        Terms terms = fields2.Terms(field2);
+                        Terms terms = fields2.GetTerms(field2);
                         if (terms == null)
                         {
                             continue;
@@ -715,11 +715,11 @@ namespace Lucene.Net.Index
                 string field2 = fieldsEnum2.Current;
                 Assert.AreEqual(field1, field2);
 
-                Terms terms1 = d1.Terms(field1);
+                Terms terms1 = d1.GetTerms(field1);
                 Assert.IsNotNull(terms1);
                 TermsEnum termsEnum1 = terms1.GetIterator(null);
 
-                Terms terms2 = d2.Terms(field2);
+                Terms terms2 = d2.GetTerms(field2);
                 Assert.IsNotNull(terms2);
                 TermsEnum termsEnum2 = terms2.GetIterator(null);
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.Tests/core/Index/TestSumDocFreq.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Index/TestSumDocFreq.cs b/src/Lucene.Net.Tests/core/Index/TestSumDocFreq.cs
index c18ef01..66f88c2 100644
--- a/src/Lucene.Net.Tests/core/Index/TestSumDocFreq.cs
+++ b/src/Lucene.Net.Tests/core/Index/TestSumDocFreq.cs
@@ -88,7 +88,7 @@ namespace Lucene.Net.Index
 
             foreach (string f in fields)
             {
-                Terms terms = fields.Terms(f);
+                Terms terms = fields.GetTerms(f);
                 long sumDocFreq = terms.SumDocFreq;
                 if (sumDocFreq == -1)
                 {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.Tests/core/Index/TestTermVectorsReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Index/TestTermVectorsReader.cs b/src/Lucene.Net.Tests/core/Index/TestTermVectorsReader.cs
index 694005c..8426151 100644
--- a/src/Lucene.Net.Tests/core/Index/TestTermVectorsReader.cs
+++ b/src/Lucene.Net.Tests/core/Index/TestTermVectorsReader.cs
@@ -247,7 +247,7 @@ namespace Lucene.Net.Index
             TermVectorsReader reader = Codec.Default.TermVectorsFormat.VectorsReader(Dir, Seg.Info, FieldInfos, NewIOContext(Random()));
             for (int j = 0; j < 5; j++)
             {
-                Terms vector = reader.Get(j).Terms(TestFields[0]);
+                Terms vector = reader.Get(j).GetTerms(TestFields[0]);
                 Assert.IsNotNull(vector);
                 Assert.AreEqual(TestTerms.Length, vector.Count);
                 TermsEnum termsEnum = vector.GetIterator(null);
@@ -270,7 +270,7 @@ namespace Lucene.Net.Index
             TermVectorsReader reader = Codec.Default.TermVectorsFormat.VectorsReader(Dir, Seg.Info, FieldInfos, NewIOContext(Random()));
             for (int j = 0; j < 5; j++)
             {
-                Terms vector = reader.Get(j).Terms(TestFields[0]);
+                Terms vector = reader.Get(j).GetTerms(TestFields[0]);
                 Assert.IsNotNull(vector);
                 Assert.AreEqual(TestTerms.Length, vector.Count);
                 TermsEnum termsEnum = vector.GetIterator(null);
@@ -300,7 +300,7 @@ namespace Lucene.Net.Index
         {
             TermVectorsReader reader = Codec.Default.TermVectorsFormat.VectorsReader(Dir, Seg.Info, FieldInfos, NewIOContext(Random()));
             //BytesRef[] terms; // LUCENENET NOTE: Not used in Lucene
-            Terms vector = reader.Get(0).Terms(TestFields[0]);
+            Terms vector = reader.Get(0).GetTerms(TestFields[0]);
             Assert.IsNotNull(vector);
             Assert.AreEqual(TestTerms.Length, vector.Count);
             TermsEnum termsEnum = vector.GetIterator(null);
@@ -340,7 +340,7 @@ namespace Lucene.Net.Index
                 Assert.AreEqual(DocIdSetIterator.NO_MORE_DOCS, dpEnum.NextDoc());
             }
 
-            Terms freqVector = reader.Get(0).Terms(TestFields[1]); //no pos, no offset
+            Terms freqVector = reader.Get(0).GetTerms(TestFields[1]); //no pos, no offset
             Assert.IsNotNull(freqVector);
             Assert.AreEqual(TestTerms.Length, freqVector.Count);
             termsEnum = freqVector.GetIterator(null);
@@ -362,7 +362,7 @@ namespace Lucene.Net.Index
         public virtual void TestOffsetReader()
         {
             TermVectorsReader reader = Codec.Default.TermVectorsFormat.VectorsReader(Dir, Seg.Info, FieldInfos, NewIOContext(Random()));
-            Terms vector = reader.Get(0).Terms(TestFields[0]);
+            Terms vector = reader.Get(0).GetTerms(TestFields[0]);
             Assert.IsNotNull(vector);
             TermsEnum termsEnum = vector.GetIterator(null);
             Assert.IsNotNull(termsEnum);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.Tests/core/Index/TestTermVectorsWriter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Index/TestTermVectorsWriter.cs b/src/Lucene.Net.Tests/core/Index/TestTermVectorsWriter.cs
index 9cd1989..355249e 100644
--- a/src/Lucene.Net.Tests/core/Index/TestTermVectorsWriter.cs
+++ b/src/Lucene.Net.Tests/core/Index/TestTermVectorsWriter.cs
@@ -67,7 +67,7 @@ namespace Lucene.Net.Index
             w.Dispose();
 
             IndexReader r = DirectoryReader.Open(dir);
-            Terms vector = r.GetTermVectors(0).Terms("field");
+            Terms vector = r.GetTermVectors(0).GetTerms("field");
             Assert.IsNotNull(vector);
             TermsEnum termsEnum = vector.GetIterator(null);
             Assert.IsNotNull(termsEnum.Next());
@@ -125,7 +125,7 @@ namespace Lucene.Net.Index
             w.Dispose();
 
             IndexReader r = DirectoryReader.Open(dir);
-            TermsEnum termsEnum = r.GetTermVectors(0).Terms("field").GetIterator(null);
+            TermsEnum termsEnum = r.GetTermVectors(0).GetTerms("field").GetIterator(null);
             Assert.IsNotNull(termsEnum.Next());
             DocsAndPositionsEnum dpEnum = termsEnum.DocsAndPositions(null, null);
             Assert.AreEqual(2, termsEnum.TotalTermFreq);
@@ -162,7 +162,7 @@ namespace Lucene.Net.Index
             w.Dispose();
 
             IndexReader r = DirectoryReader.Open(dir);
-            TermsEnum termsEnum = r.GetTermVectors(0).Terms("field").GetIterator(null);
+            TermsEnum termsEnum = r.GetTermVectors(0).GetTerms("field").GetIterator(null);
             Assert.IsNotNull(termsEnum.Next());
             DocsAndPositionsEnum dpEnum = termsEnum.DocsAndPositions(null, null);
             Assert.AreEqual(2, termsEnum.TotalTermFreq);
@@ -215,7 +215,7 @@ namespace Lucene.Net.Index
             w.Dispose();
 
             IndexReader r = DirectoryReader.Open(dir);
-            TermsEnum termsEnum = r.GetTermVectors(0).Terms("field").GetIterator(null);
+            TermsEnum termsEnum = r.GetTermVectors(0).GetTerms("field").GetIterator(null);
             Assert.IsNotNull(termsEnum.Next());
             DocsAndPositionsEnum dpEnum = termsEnum.DocsAndPositions(null, null);
             Assert.AreEqual(2, termsEnum.TotalTermFreq);
@@ -252,7 +252,7 @@ namespace Lucene.Net.Index
             w.Dispose();
 
             IndexReader r = DirectoryReader.Open(dir);
-            TermsEnum termsEnum = r.GetTermVectors(0).Terms("field").GetIterator(null);
+            TermsEnum termsEnum = r.GetTermVectors(0).GetTerms("field").GetIterator(null);
             Assert.IsNotNull(termsEnum.Next());
             DocsAndPositionsEnum dpEnum = termsEnum.DocsAndPositions(null, null);
             Assert.AreEqual(2, termsEnum.TotalTermFreq);
@@ -290,7 +290,7 @@ namespace Lucene.Net.Index
             w.Dispose();
 
             IndexReader r = DirectoryReader.Open(dir);
-            TermsEnum termsEnum = r.GetTermVectors(0).Terms("field").GetIterator(null);
+            TermsEnum termsEnum = r.GetTermVectors(0).GetTerms("field").GetIterator(null);
             Assert.IsNotNull(termsEnum.Next());
             DocsAndPositionsEnum dpEnum = termsEnum.DocsAndPositions(null, null);
 
@@ -336,7 +336,7 @@ namespace Lucene.Net.Index
             w.Dispose();
 
             IndexReader r = DirectoryReader.Open(dir);
-            TermsEnum termsEnum = r.GetTermVectors(0).Terms("field").GetIterator(null);
+            TermsEnum termsEnum = r.GetTermVectors(0).GetTerms("field").GetIterator(null);
             Assert.IsNotNull(termsEnum.Next());
             DocsAndPositionsEnum dpEnum = termsEnum.DocsAndPositions(null, null);
 
@@ -380,7 +380,7 @@ namespace Lucene.Net.Index
             w.Dispose();
 
             IndexReader r = DirectoryReader.Open(dir);
-            TermsEnum termsEnum = r.GetTermVectors(0).Terms("field").GetIterator(null);
+            TermsEnum termsEnum = r.GetTermVectors(0).GetTerms("field").GetIterator(null);
             Assert.IsNotNull(termsEnum.Next());
             DocsAndPositionsEnum dpEnum = termsEnum.DocsAndPositions(null, null);
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.Tests/core/Index/TestTermsEnum.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Index/TestTermsEnum.cs b/src/Lucene.Net.Tests/core/Index/TestTermsEnum.cs
index 54f2747..ed848b3 100644
--- a/src/Lucene.Net.Tests/core/Index/TestTermsEnum.cs
+++ b/src/Lucene.Net.Tests/core/Index/TestTermsEnum.cs
@@ -899,7 +899,7 @@ namespace Lucene.Net.Index
             DirectoryReader r = w.Reader;
             w.Dispose();
             AtomicReader sub = GetOnlySegmentReader(r);
-            Terms terms = sub.Fields.Terms("field");
+            Terms terms = sub.Fields.GetTerms("field");
             Automaton automaton = (new RegExp(".*", RegExp.NONE)).ToAutomaton();
             CompiledAutomaton ca = new CompiledAutomaton(automaton, false, false);
             TermsEnum te = terms.Intersect(ca, null);
@@ -957,7 +957,7 @@ namespace Lucene.Net.Index
             DirectoryReader r = w.Reader;
             w.Dispose();
             AtomicReader sub = GetOnlySegmentReader(r);
-            Terms terms = sub.Fields.Terms("field");
+            Terms terms = sub.Fields.GetTerms("field");
 
             Automaton automaton = (new RegExp(".*d", RegExp.NONE)).ToAutomaton();
             CompiledAutomaton ca = new CompiledAutomaton(automaton, false, false);
@@ -1013,7 +1013,7 @@ namespace Lucene.Net.Index
             DirectoryReader r = w.Reader;
             w.Dispose();
             AtomicReader sub = GetOnlySegmentReader(r);
-            Terms terms = sub.Fields.Terms("field");
+            Terms terms = sub.Fields.GetTerms("field");
 
             Automaton automaton = (new RegExp(".*", RegExp.NONE)).ToAutomaton(); // accept ALL
             CompiledAutomaton ca = new CompiledAutomaton(automaton, false, false);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.Tests/core/Search/TestMultiPhraseQuery.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Search/TestMultiPhraseQuery.cs b/src/Lucene.Net.Tests/core/Search/TestMultiPhraseQuery.cs
index a27562a..0995c13 100644
--- a/src/Lucene.Net.Tests/core/Search/TestMultiPhraseQuery.cs
+++ b/src/Lucene.Net.Tests/core/Search/TestMultiPhraseQuery.cs
@@ -78,7 +78,7 @@ namespace Lucene.Net.Search
 
             // this TermEnum gives "piccadilly", "pie" and "pizza".
             string prefix = "pi";
-            TermsEnum te = MultiFields.GetFields(reader).Terms("body").GetIterator(null);
+            TermsEnum te = MultiFields.GetFields(reader).GetTerms("body").GetIterator(null);
             te.SeekCeil(new BytesRef(prefix));
             do
             {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.Tests/core/Search/TestMultiThreadTermVectors.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Search/TestMultiThreadTermVectors.cs b/src/Lucene.Net.Tests/core/Search/TestMultiThreadTermVectors.cs
index 501a84c..89607cf 100644
--- a/src/Lucene.Net.Tests/core/Search/TestMultiThreadTermVectors.cs
+++ b/src/Lucene.Net.Tests/core/Search/TestMultiThreadTermVectors.cs
@@ -211,7 +211,7 @@ namespace Lucene.Net.Search
                 VerifyVectors(vectors, docId);
 
                 start = Environment.TickCount;
-                Terms vector = Reader.GetTermVectors(docId).Terms("field");
+                Terms vector = Reader.GetTermVectors(docId).GetTerms("field");
                 TimeElapsed += Environment.TickCount - start;
 
                 VerifyVector(vector.GetIterator(null), docId);
@@ -222,7 +222,7 @@ namespace Lucene.Net.Search
         {
             foreach (string field in vectors)
             {
-                Terms terms = vectors.Terms(field);
+                Terms terms = vectors.GetTerms(field);
                 Debug.Assert(terms != null);
                 VerifyVector(terms.GetIterator(null), num);
             }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.Tests/core/Search/TestPhrasePrefixQuery.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Search/TestPhrasePrefixQuery.cs b/src/Lucene.Net.Tests/core/Search/TestPhrasePrefixQuery.cs
index 9a0864e..d143f18 100644
--- a/src/Lucene.Net.Tests/core/Search/TestPhrasePrefixQuery.cs
+++ b/src/Lucene.Net.Tests/core/Search/TestPhrasePrefixQuery.cs
@@ -77,7 +77,7 @@ namespace Lucene.Net.Search
 
             // this TermEnum gives "piccadilly", "pie" and "pizza".
             string prefix = "pi";
-            TermsEnum te = MultiFields.GetFields(reader).Terms("body").GetIterator(null);
+            TermsEnum te = MultiFields.GetFields(reader).GetTerms("body").GetIterator(null);
             te.SeekCeil(new BytesRef(prefix));
             do
             {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.Tests/core/Search/TestSameScoresWithThreads.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Search/TestSameScoresWithThreads.cs b/src/Lucene.Net.Tests/core/Search/TestSameScoresWithThreads.cs
index f3dcf52..361e17e 100644
--- a/src/Lucene.Net.Tests/core/Search/TestSameScoresWithThreads.cs
+++ b/src/Lucene.Net.Tests/core/Search/TestSameScoresWithThreads.cs
@@ -65,7 +65,7 @@ namespace Lucene.Net.Search
             w.Dispose();
 
             IndexSearcher s = NewSearcher(r);
-            Terms terms = MultiFields.GetFields(r).Terms("body");
+            Terms terms = MultiFields.GetFields(r).GetTerms("body");
             int termCount = 0;
             TermsEnum termsEnum = terms.GetIterator(null);
             while (termsEnum.Next() != null)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/52da783d/src/Lucene.Net.Tests/core/Search/TestTermVectors.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Search/TestTermVectors.cs b/src/Lucene.Net.Tests/core/Search/TestTermVectors.cs
index 0170ab4..ff49de1 100644
--- a/src/Lucene.Net.Tests/core/Search/TestTermVectors.cs
+++ b/src/Lucene.Net.Tests/core/Search/TestTermVectors.cs
@@ -144,7 +144,7 @@ namespace Lucene.Net.Search
             Fields vectors = searcher.IndexReader.GetTermVectors(hits[0].Doc);
             Assert.IsNotNull(vectors);
             Assert.AreEqual(1, vectors.Count);
-            Terms vector = vectors.Terms("field");
+            Terms vector = vectors.GetTerms("field");
             Assert.IsNotNull(vector);
             Assert.AreEqual(1, vector.Count);
             TermsEnum termsEnum = vector.GetIterator(null);
@@ -202,7 +202,7 @@ namespace Lucene.Net.Search
             int numDocs = r.NumDocs;
             for (int i = 0; i < numDocs; i++)
             {
-                Assert.IsNotNull(r.GetTermVectors(i).Terms("c"), "term vectors should not have been null for document " + i);
+                Assert.IsNotNull(r.GetTermVectors(i).GetTerms("c"), "term vectors should not have been null for document " + i);
             }
             r.Dispose();
         }


[32/53] [abbrv] lucenenet git commit: Lucene.Net.Suggest: Renamed all type-derived properties and methods from Short, Int, Long, and Float to match CLR types Int16, Int32, Int64, and Single, respectively.

Posted by ni...@apache.org.
Lucene.Net.Suggest: Renamed all type-derived properties and methods from Short, Int, Long, and Float to match CLR types Int16, Int32, Int64, and Single, respectively.


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

Branch: refs/heads/api-work
Commit: f0cd4246db710502cc696a22dfc60dec080f0dfe
Parents: 76f687c
Author: Shad Storhaug <sh...@shadstorhaug.com>
Authored: Wed Feb 8 00:38:18 2017 +0700
Committer: Shad Storhaug <sh...@shadstorhaug.com>
Committed: Wed Feb 8 21:08:22 2017 +0700

----------------------------------------------------------------------
 .../Spell/LuceneLevenshteinDistance.cs                | 14 +++++++++-----
 1 file changed, 9 insertions(+), 5 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f0cd4246/src/Lucene.Net.Suggest/Spell/LuceneLevenshteinDistance.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Suggest/Spell/LuceneLevenshteinDistance.cs b/src/Lucene.Net.Suggest/Spell/LuceneLevenshteinDistance.cs
index ab0c9b7..3ced995 100644
--- a/src/Lucene.Net.Suggest/Spell/LuceneLevenshteinDistance.cs
+++ b/src/Lucene.Net.Suggest/Spell/LuceneLevenshteinDistance.cs
@@ -64,12 +64,12 @@ namespace Lucene.Net.Search.Spell
             // in "distributed spellcheck", and its inefficient in other ways too...
 
             // cheaper to do this up front once
-            targetPoints = ToIntsRef(target);
-            otherPoints = ToIntsRef(other);
+            targetPoints = ToInt32sRef(target);
+            otherPoints = ToInt32sRef(other);
             n = targetPoints.Length;
             int m = otherPoints.Length;
 
-            d = ReturnRectangularIntArray(n + 1, m + 1);
+            d = ReturnRectangularInt32Array(n + 1, m + 1);
 
             if (n == 0 || m == 0)
             {
@@ -121,7 +121,10 @@ namespace Lucene.Net.Search.Spell
             return 1.0f - ((float)d[n][m] / Math.Min(m, n));
         }
 
-        private static IntsRef ToIntsRef(string s)
+        /// <summary>
+        /// NOTE: This was toIntsRef() in Lucene
+        /// </summary>
+        private static IntsRef ToInt32sRef(string s)
         {
             var @ref = new IntsRef(s.Length); // worst case
             int utf16Len = s.Length;
@@ -132,7 +135,8 @@ namespace Lucene.Net.Search.Spell
             return @ref;
         }
 
-        private static int[][] ReturnRectangularIntArray(int size1, int size2)
+        // LUCENENET TODO: Move to Support ?
+        private static int[][] ReturnRectangularInt32Array(int size1, int size2)
         {
             int[][] array;
             if (size1 > -1)


[39/53] [abbrv] lucenenet git commit: Lucene.Net.Tests.Expressions: added exceptions for naming of fields in JavascriptLexer

Posted by ni...@apache.org.
Lucene.Net.Tests.Expressions: added exceptions for naming of fields in JavascriptLexer


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

Branch: refs/heads/api-work
Commit: 546dfe408d93720bc64be018796556819031faf4
Parents: 8ca0267
Author: Shad Storhaug <sh...@shadstorhaug.com>
Authored: Wed Feb 8 17:17:24 2017 +0700
Committer: Shad Storhaug <sh...@shadstorhaug.com>
Committed: Wed Feb 8 21:08:24 2017 +0700

----------------------------------------------------------------------
 src/Lucene.Net.Tests.Expressions/TestApiConsistency.cs | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/lucenenet/blob/546dfe40/src/Lucene.Net.Tests.Expressions/TestApiConsistency.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests.Expressions/TestApiConsistency.cs b/src/Lucene.Net.Tests.Expressions/TestApiConsistency.cs
index bdb7ae8..1d0c034 100644
--- a/src/Lucene.Net.Tests.Expressions/TestApiConsistency.cs
+++ b/src/Lucene.Net.Tests.Expressions/TestApiConsistency.cs
@@ -21,7 +21,7 @@ namespace Lucene.Net.Tests.Expressions
         [TestCase(typeof(Lucene.Net.Expressions.Bindings))]
         public override void TestPrivateFieldNames(Type typeFromTargetAssembly)
         {
-            base.TestPrivateFieldNames(typeFromTargetAssembly);
+            base.TestPrivateFieldNames(typeFromTargetAssembly, @"JS\.JavascriptLexer\.DFA9_");
         }
 
         [Test, LuceneNetSpecific]


[26/53] [abbrv] lucenenet git commit: Lucene.Net.Core: Renamed all type-derived classes and interfaces from Short, Int, Long, and Float to match CLR types Int16, Int32, Int64, and Single, respectively.

Posted by ni...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Util/Automaton/BasicOperations.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Automaton/BasicOperations.cs b/src/Lucene.Net.Core/Util/Automaton/BasicOperations.cs
index 1e6ee2c..4c02d4e 100644
--- a/src/Lucene.Net.Core/Util/Automaton/BasicOperations.cs
+++ b/src/Lucene.Net.Core/Util/Automaton/BasicOperations.cs
@@ -796,10 +796,10 @@ namespace Lucene.Net.Util.Automaton
             bool initAccept = a.initial.accept;
             int initNumber = a.initial.number;
             a.initial = new State();
-            SortedIntSet.FrozenIntSet initialset = new SortedIntSet.FrozenIntSet(initNumber, a.initial);
+            SortedInt32Set.FrozenInt32Set initialset = new SortedInt32Set.FrozenInt32Set(initNumber, a.initial);
 
-            LinkedList<SortedIntSet.FrozenIntSet> worklist = new LinkedList<SortedIntSet.FrozenIntSet>();
-            IDictionary<SortedIntSet.FrozenIntSet, State> newstate = new Dictionary<SortedIntSet.FrozenIntSet, State>();
+            LinkedList<SortedInt32Set.FrozenInt32Set> worklist = new LinkedList<SortedInt32Set.FrozenInt32Set>();
+            IDictionary<SortedInt32Set.FrozenInt32Set, State> newstate = new Dictionary<SortedInt32Set.FrozenInt32Set, State>();
 
             worklist.AddLast(initialset);
 
@@ -816,7 +816,7 @@ namespace Lucene.Net.Util.Automaton
             PointTransitionSet points = new PointTransitionSet();
 
             // like SortedMap<Integer,Integer>
-            SortedIntSet statesSet = new SortedIntSet(5);
+            SortedInt32Set statesSet = new SortedInt32Set(5);
 
             // LUCENENET TODO: THIS IS INFINITE LOOPING
 
@@ -825,7 +825,7 @@ namespace Lucene.Net.Util.Automaton
             // differing equality checking.
             while (worklist.Count > 0)
             {
-                SortedIntSet.FrozenIntSet s = worklist.First.Value;
+                SortedInt32Set.FrozenInt32Set s = worklist.First.Value;
                 worklist.Remove(s);
 
                 // Collate all outgoing transitions by min/1+max:
@@ -866,7 +866,7 @@ namespace Lucene.Net.Util.Automaton
                         {
                             q = new State();
 
-                            SortedIntSet.FrozenIntSet p = statesSet.Freeze(q);
+                            SortedInt32Set.FrozenInt32Set p = statesSet.Freeze(q);
                             worklist.AddLast(p);
                             if (newStateUpto == newStatesArray.Length)
                             {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Util/Automaton/MinimizationOperations.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Automaton/MinimizationOperations.cs b/src/Lucene.Net.Core/Util/Automaton/MinimizationOperations.cs
index 3a1d413..1350478 100644
--- a/src/Lucene.Net.Core/Util/Automaton/MinimizationOperations.cs
+++ b/src/Lucene.Net.Core/Util/Automaton/MinimizationOperations.cs
@@ -86,7 +86,7 @@ namespace Lucene.Net.Util.Automaton
             int[] block = new int[statesLen];
             StateList[,] active = new StateList[statesLen, sigmaLen];
             StateListNode[,] active2 = new StateListNode[statesLen, sigmaLen];
-            LinkedList<IntPair> pending = new LinkedList<IntPair>();
+            LinkedList<Int32Pair> pending = new LinkedList<Int32Pair>();
             BitArray pending2 = new BitArray(sigmaLen * statesLen);
             BitArray split = new BitArray(statesLen), refine = new BitArray(statesLen), refine2 = new BitArray(statesLen);
             for (int q = 0; q < statesLen; q++)
@@ -134,14 +134,14 @@ namespace Lucene.Net.Util.Automaton
             for (int x = 0; x < sigmaLen; x++)
             {
                 int j = (active[0, x].Count <= active[1, x].Count) ? 0 : 1;
-                pending.AddLast(new IntPair(j, x));
+                pending.AddLast(new Int32Pair(j, x));
                 pending2.SafeSet(x * statesLen + j, true);
             }
             // process pending until fixed point
             int k = 2;
             while (pending.Count > 0)
             {
-                IntPair ip = pending.First.Value;
+                Int32Pair ip = pending.First.Value;
                 pending.Remove(ip);
                 int p = ip.N1;
                 int x = ip.N2;
@@ -199,12 +199,12 @@ namespace Lucene.Net.Util.Automaton
                             if (!pending2.SafeGet(ofs + j) && 0 < aj && aj <= ak)
                             {
                                 pending2.SafeSet(ofs + j, true);
-                                pending.AddLast(new IntPair(j, c));
+                                pending.AddLast(new Int32Pair(j, c));
                             }
                             else
                             {
                                 pending2.SafeSet(ofs + k, true);
-                                pending.AddLast(new IntPair(k, c));
+                                pending.AddLast(new Int32Pair(k, c));
                             }
                         }
                         k++;
@@ -249,11 +249,14 @@ namespace Lucene.Net.Util.Automaton
             a.RemoveDeadTransitions();
         }
 
-        internal sealed class IntPair
+        /// <summary>
+        /// NOTE: This was IntPair in Lucene
+        /// </summary>
+        internal sealed class Int32Pair
         {
             internal int N1 { get; private set; }
             internal int N2 { get; private set; }
-            internal IntPair(int n1, int n2)
+            internal Int32Pair(int n1, int n2)
             {
                 this.N1 = n1;
                 this.N2 = n2;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Util/Automaton/SortedIntSet.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Automaton/SortedIntSet.cs b/src/Lucene.Net.Core/Util/Automaton/SortedIntSet.cs
index 44b9a8a..1ce3b7f 100644
--- a/src/Lucene.Net.Core/Util/Automaton/SortedIntSet.cs
+++ b/src/Lucene.Net.Core/Util/Automaton/SortedIntSet.cs
@@ -22,10 +22,14 @@ namespace Lucene.Net.Util.Automaton
      * limitations under the License.
      */
 
-    // Just holds a set of int[] states, plus a corresponding
-    // int[] count per state.  Used by
-    // BasicOperations.determinize
-    internal sealed class SortedIntSet : IEquatable<SortedIntSet>, IEquatable<SortedIntSet.FrozenIntSet> // LUCENENET TODO: Rename SortedInt32Set
+    /// <summary>
+    /// Just holds a set of int[] states, plus a corresponding
+    /// int[] count per state.  Used by
+    /// BasicOperations.determinize
+    /// <para/>
+    /// NOTE: This was SortedIntSet in Lucene
+    /// </summary>
+    internal sealed class SortedInt32Set : IEquatable<SortedInt32Set>, IEquatable<SortedInt32Set.FrozenInt32Set>
     {
         internal int[] values;
         internal int[] counts;
@@ -42,7 +46,7 @@ namespace Lucene.Net.Util.Automaton
 
         internal State state;
 
-        public SortedIntSet(int capacity)
+        public SortedInt32Set(int capacity)
         {
             values = new int[capacity];
             counts = new int[capacity];
@@ -184,18 +188,18 @@ namespace Lucene.Net.Util.Automaton
             }
         }
 
-        public FrozenIntSet ToFrozenInt32Set() // LUCENENET TODO: This didn't exist in the original
+        public FrozenInt32Set ToFrozenInt32Set() // LUCENENET TODO: This didn't exist in the original
         {
             int[] c = new int[upto];
             Array.Copy(values, 0, c, 0, upto);
-            return new FrozenIntSet(c, this.hashCode, this.state);
+            return new FrozenInt32Set(c, this.hashCode, this.state);
         }
 
-        public FrozenIntSet Freeze(State state)
+        public FrozenInt32Set Freeze(State state)
         {
             int[] c = new int[upto];
             Array.Copy(values, 0, c, 0, upto);
-            return new FrozenIntSet(c, hashCode, state);
+            return new FrozenInt32Set(c, hashCode, state);
         }
 
         public override int GetHashCode()
@@ -209,11 +213,11 @@ namespace Lucene.Net.Util.Automaton
             {
                 return false;
             }
-            if (!(other is FrozenIntSet))
+            if (!(other is FrozenInt32Set))
             {
                 return false;
             }
-            FrozenIntSet other2 = (FrozenIntSet)other;
+            FrozenInt32Set other2 = (FrozenInt32Set)other;
             if (hashCode != other2.hashCode)
             {
                 return false;
@@ -233,12 +237,12 @@ namespace Lucene.Net.Util.Automaton
             return true;
         }
 
-        public bool Equals(SortedIntSet other) // LUCENENET TODO: This didn't exist in the original
+        public bool Equals(SortedInt32Set other) // LUCENENET TODO: This didn't exist in the original
         {
             throw new NotImplementedException("SortedIntSet Equals");
         }
 
-        public bool Equals(FrozenIntSet other) // LUCENENET TODO: This didn't exist in the original
+        public bool Equals(FrozenInt32Set other) // LUCENENET TODO: This didn't exist in the original
         {
             if (other == null)
             {
@@ -280,20 +284,23 @@ namespace Lucene.Net.Util.Automaton
             return sb.ToString();
         }
 
-        public sealed class FrozenIntSet : IEquatable<SortedIntSet>, IEquatable<FrozenIntSet> // LUCENENET TODO: Rename FrozenInt32Set
+        /// <summary>
+        /// NOTE: This was FrozenIntSet in Lucene
+        /// </summary>
+        public sealed class FrozenInt32Set : IEquatable<SortedInt32Set>, IEquatable<FrozenInt32Set> 
         {
             internal readonly int[] values;
             internal readonly int hashCode;
             internal readonly State state;
 
-            public FrozenIntSet(int[] values, int hashCode, State state)
+            public FrozenInt32Set(int[] values, int hashCode, State state)
             {
                 this.values = values;
                 this.hashCode = hashCode;
                 this.state = state;
             }
 
-            public FrozenIntSet(int num, State state)
+            public FrozenInt32Set(int num, State state)
             {
                 this.values = new int[] { num };
                 this.state = state;
@@ -311,9 +318,9 @@ namespace Lucene.Net.Util.Automaton
                 {
                     return false;
                 }
-                if (other is FrozenIntSet)
+                if (other is FrozenInt32Set)
                 {
-                    FrozenIntSet other2 = (FrozenIntSet)other;
+                    FrozenInt32Set other2 = (FrozenInt32Set)other;
                     if (hashCode != other2.hashCode)
                     {
                         return false;
@@ -331,9 +338,9 @@ namespace Lucene.Net.Util.Automaton
                     }
                     return true;
                 }
-                else if (other is SortedIntSet)
+                else if (other is SortedInt32Set)
                 {
-                    SortedIntSet other3 = (SortedIntSet)other;
+                    SortedInt32Set other3 = (SortedInt32Set)other;
                     if (hashCode != other3.hashCode)
                     {
                         return false;
@@ -355,7 +362,7 @@ namespace Lucene.Net.Util.Automaton
                 return false;
             }
 
-            public bool Equals(SortedIntSet other) // LUCENENET TODO: This didn't exist in the original
+            public bool Equals(SortedInt32Set other) // LUCENENET TODO: This didn't exist in the original
             {
                 if (other == null)
                 {
@@ -380,7 +387,7 @@ namespace Lucene.Net.Util.Automaton
                 return true;
             }
 
-            public bool Equals(FrozenIntSet other) // LUCENENET TODO: This didn't exist in the original
+            public bool Equals(FrozenInt32Set other) // LUCENENET TODO: This didn't exist in the original
             {
                 if (other == null)
                 {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Util/Automaton/SpecialOperations.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Automaton/SpecialOperations.cs b/src/Lucene.Net.Core/Util/Automaton/SpecialOperations.cs
index 609a3a5..ac83546 100644
--- a/src/Lucene.Net.Core/Util/Automaton/SpecialOperations.cs
+++ b/src/Lucene.Net.Core/Util/Automaton/SpecialOperations.cs
@@ -285,17 +285,17 @@ namespace Lucene.Net.Util.Automaton
         /// strings are accepted, the first limit strings found are returned. If <code>limit</code>&lt;0, then
         /// the limit is infinite.
         /// </summary>
-        public static ISet<IntsRef> GetFiniteStrings(Automaton a, int limit)
+        public static ISet<Int32sRef> GetFiniteStrings(Automaton a, int limit)
         {
-            HashSet<IntsRef> strings = new HashSet<IntsRef>();
+            HashSet<Int32sRef> strings = new HashSet<Int32sRef>();
             if (a.IsSingleton)
             {
                 if (limit > 0)
                 {
-                    strings.Add(Util.ToUTF32(a.Singleton, new IntsRef()));
+                    strings.Add(Util.ToUTF32(a.Singleton, new Int32sRef()));
                 }
             }
-            else if (!GetFiniteStrings(a.initial, new HashSet<State>(), strings, new IntsRef(), limit))
+            else if (!GetFiniteStrings(a.initial, new HashSet<State>(), strings, new Int32sRef(), limit))
             {
                 return strings;
             }
@@ -307,7 +307,7 @@ namespace Lucene.Net.Util.Automaton
         /// false if more than <code>limit</code> strings are found.
         /// <code>limit</code>&lt;0 means "infinite".
         /// </summary>
-        private static bool GetFiniteStrings(State s, HashSet<State> pathstates, HashSet<IntsRef> strings, IntsRef path, int limit)
+        private static bool GetFiniteStrings(State s, HashSet<State> pathstates, HashSet<Int32sRef> strings, Int32sRef path, int limit)
         {
             pathstates.Add(s);
             foreach (Transition t in s.GetTransitions())
@@ -323,7 +323,7 @@ namespace Lucene.Net.Util.Automaton
                     path.Length++;
                     if (t.to.accept)
                     {
-                        strings.Add(IntsRef.DeepCopyOf(path));
+                        strings.Add(Int32sRef.DeepCopyOf(path));
                         if (limit >= 0 && strings.Count > limit)
                         {
                             return false;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Util/BytesRefHash.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/BytesRefHash.cs b/src/Lucene.Net.Core/Util/BytesRefHash.cs
index 1916ef1..b134712 100644
--- a/src/Lucene.Net.Core/Util/BytesRefHash.cs
+++ b/src/Lucene.Net.Core/Util/BytesRefHash.cs
@@ -593,7 +593,7 @@ namespace Lucene.Net.Util
             /// <seealso cref="BytesStartArray"/>. The <seealso cref="BytesRefHash"/> uses this reference to
             /// track it memory usage
             /// </summary>
-            /// <returns> a <seealso cref="AtomicLong"/> reference holding the number of bytes used
+            /// <returns> a <seealso cref="AtomicInt64"/> reference holding the number of bytes used
             ///         by this <seealso cref="BytesStartArray"/>. </returns>
             public abstract Counter BytesUsed();
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Util/FixedBitSet.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/FixedBitSet.cs b/src/Lucene.Net.Core/Util/FixedBitSet.cs
index f375819..0f4aa34 100644
--- a/src/Lucene.Net.Core/Util/FixedBitSet.cs
+++ b/src/Lucene.Net.Core/Util/FixedBitSet.cs
@@ -28,7 +28,7 @@ namespace Lucene.Net.Util
     /// BitSet of fixed length (numBits), backed by accessible (<seealso cref="#getBits"/>)
     /// long[], accessed with an int index, implementing <seealso cref="GetBits"/> and
     /// <seealso cref="DocIdSet"/>. If you need to manage more than 2.1B bits, use
-    /// <seealso cref="LongBitSet"/>.
+    /// <seealso cref="Int64BitSet"/>.
     ///
     /// @lucene.internal
     /// </summary>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Util/Fst/Builder.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Fst/Builder.cs b/src/Lucene.Net.Core/Util/Fst/Builder.cs
index b147f4d..7195193 100644
--- a/src/Lucene.Net.Core/Util/Fst/Builder.cs
+++ b/src/Lucene.Net.Core/Util/Fst/Builder.cs
@@ -23,7 +23,7 @@ namespace Lucene.Net.Util.Fst
      */
 
     //using INPUT_TYPE = Lucene.Net.Util.Fst.FST.INPUT_TYPE; // javadoc
-    using PackedInts = Lucene.Net.Util.Packed.PackedInts;
+    using PackedInt32s = Lucene.Net.Util.Packed.PackedInt32s;
 
     // TODO: could we somehow stream an FST to disk while we
     // build it?
@@ -68,7 +68,7 @@ namespace Lucene.Net.Util.Fst
         private readonly bool doShareNonSingletonNodes;
         private readonly int shareMaxTailLength;
 
-        private readonly IntsRef lastInput = new IntsRef();
+        private readonly Int32sRef lastInput = new Int32sRef();
 
         // for packing
         private readonly bool doPackFST;
@@ -104,7 +104,7 @@ namespace Lucene.Net.Util.Fst
         /// boolean, int)} with pruning options turned off.
         /// </summary>
         public Builder(FST.INPUT_TYPE inputType, Outputs<T> outputs)
-            : this(inputType, 0, 0, true, true, int.MaxValue, outputs, null, false, PackedInts.COMPACT, true, 15)
+            : this(inputType, 0, 0, true, true, int.MaxValue, outputs, null, false, PackedInt32s.COMPACT, true, 15)
         {
             var x = new System.Text.StringBuilder();
         }
@@ -149,7 +149,7 @@ namespace Lucene.Net.Util.Fst
         /// <param name="doPackFST"> Pass true to create a packed FST.
         /// </param>
         /// <param name="acceptableOverheadRatio"> How to trade speed for space when building the FST. this option </param>
-        ///    is only relevant when doPackFST is true. <seealso cref= PackedInts#getMutable(int, int, float)
+        ///    is only relevant when doPackFST is true. <seealso cref= PackedInt32s#getMutable(int, int, float)
         /// </seealso>
         /// <param name="allowArrayArcs"> Pass false to disable the array arc optimization
         ///    while building the FST; this will make the resulting
@@ -375,7 +375,7 @@ namespace Lucene.Net.Util.Fst
         ///  IntSequenceOutputs}) then you cannot reuse across
         ///  calls.
         /// </summary>
-        public virtual void Add(IntsRef input, T output)
+        public virtual void Add(Int32sRef input, T output)
         {
             /*
             if (DEBUG) {
@@ -609,7 +609,7 @@ namespace Lucene.Net.Util.Fst
         /// </summary>
         public abstract class FreezeTail<S>
         {
-            public abstract void Freeze(UnCompiledNode<S>[] frontier, int prefixLenPlus1, IntsRef prevInput);
+            public abstract void Freeze(UnCompiledNode<S>[] frontier, int prefixLenPlus1, Int32sRef prevInput);
         }
 
         public interface INode // LUCENENET NOTE: made public rather than internal because it is returned in public types

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Util/Fst/FST.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Fst/FST.cs b/src/Lucene.Net.Core/Util/Fst/FST.cs
index 8cc840d..0c53847 100644
--- a/src/Lucene.Net.Core/Util/Fst/FST.cs
+++ b/src/Lucene.Net.Core/Util/Fst/FST.cs
@@ -32,7 +32,7 @@ namespace Lucene.Net.Util.Fst
     using GrowableWriter = Lucene.Net.Util.Packed.GrowableWriter;
     using InputStreamDataInput = Lucene.Net.Store.InputStreamDataInput;
     using OutputStreamDataOutput = Lucene.Net.Store.OutputStreamDataOutput;
-    using PackedInts = Lucene.Net.Util.Packed.PackedInts;
+    using PackedInt32s = Lucene.Net.Util.Packed.PackedInt32s;
     using RAMOutputStream = Lucene.Net.Store.RAMOutputStream;
 
     // TODO: break this into WritableFST and ReadOnlyFST.. then
@@ -164,7 +164,7 @@ namespace Lucene.Net.Util.Fst
         private long arcWithOutputCount;
 
         private readonly bool packed;
-        private PackedInts.Reader nodeRefToAddress;
+        private PackedInt32s.Reader nodeRefToAddress;
 
         ///// <summary>
         ///// If arc has this label then that arc is final/accepted </summary>
@@ -297,7 +297,7 @@ namespace Lucene.Net.Util.Fst
             }
             if (packed)
             {
-                nodeRefToAddress = PackedInts.GetReader(@in);
+                nodeRefToAddress = PackedInt32s.GetReader(@in);
             }
             else
             {
@@ -493,7 +493,7 @@ namespace Lucene.Net.Util.Fst
             {
                 throw new InvalidOperationException("cannot save an FST pre-packed FST; it must first be packed");
             }
-            if (packed && !(nodeRefToAddress is PackedInts.Mutable))
+            if (packed && !(nodeRefToAddress is PackedInt32s.Mutable))
             {
                 throw new InvalidOperationException("cannot save a FST which has been loaded from disk ");
             }
@@ -556,7 +556,7 @@ namespace Lucene.Net.Util.Fst
             @out.WriteByte((byte)t);
             if (packed)
             {
-                ((PackedInts.Mutable)nodeRefToAddress).Save(@out);
+                ((PackedInt32s.Mutable)nodeRefToAddress).Save(@out);
             }
             @out.WriteVInt64(startNode);
             @out.WriteVInt64(nodeCount);
@@ -1727,7 +1727,7 @@ namespace Lucene.Net.Util.Fst
             }
 
             // +1 because node ords start at 1 (0 is reserved as stop node):
-            GrowableWriter newNodeAddress = new GrowableWriter(PackedInts.BitsRequired(this.bytes.Position), (int)(1 + nodeCount), acceptableOverheadRatio);
+            GrowableWriter newNodeAddress = new GrowableWriter(PackedInt32s.BitsRequired(this.bytes.Position), (int)(1 + nodeCount), acceptableOverheadRatio);
 
             // Fill initial coarse guess:
             for (int node = 1; node <= nodeCount; node++)
@@ -2035,7 +2035,7 @@ namespace Lucene.Net.Util.Fst
                 maxAddress = Math.Max(maxAddress, newNodeAddress.Get((int)key));
             }
 
-            PackedInts.Mutable nodeRefToAddressIn = PackedInts.GetMutable(topNodeMap.Count, PackedInts.BitsRequired(maxAddress), acceptableOverheadRatio);
+            PackedInt32s.Mutable nodeRefToAddressIn = PackedInt32s.GetMutable(topNodeMap.Count, PackedInt32s.BitsRequired(maxAddress), acceptableOverheadRatio);
             foreach (KeyValuePair<int, int> ent in topNodeMap)
             {
                 nodeRefToAddressIn.Set(ent.Value, newNodeAddress.Get(ent.Key));
@@ -2307,9 +2307,9 @@ namespace Lucene.Net.Util.Fst
         internal class ArcAndState<T>
         {
             internal Arc<T> Arc { get; private set; }
-            internal IntsRef Chain { get; private set; }
+            internal Int32sRef Chain { get; private set; }
 
-            public ArcAndState(Arc<T> arc, IntsRef chain)
+            public ArcAndState(Arc<T> arc, Int32sRef chain)
             {
                 this.Arc = arc;
                 this.Chain = chain;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Util/Fst/IntSequenceOutputs.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Fst/IntSequenceOutputs.cs b/src/Lucene.Net.Core/Util/Fst/IntSequenceOutputs.cs
index 0db64a6..1f586ba 100644
--- a/src/Lucene.Net.Core/Util/Fst/IntSequenceOutputs.cs
+++ b/src/Lucene.Net.Core/Util/Fst/IntSequenceOutputs.cs
@@ -24,21 +24,23 @@ namespace Lucene.Net.Util.Fst
     using DataOutput = Lucene.Net.Store.DataOutput;
 
     /// <summary>
-    /// An FST <seealso cref="Outputs"/> implementation where each output
+    /// An FST <see cref="Outputs{T}"/> implementation where each output
     /// is a sequence of ints.
+    /// <para/>
+    /// NOTE: This was IntSequenceOutputs in Lucene
     ///
     /// @lucene.experimental
     /// </summary>
-    public sealed class IntSequenceOutputs : Outputs<IntsRef>
+    public sealed class Int32SequenceOutputs : Outputs<Int32sRef>
     {
-        private static readonly IntsRef NO_OUTPUT = new IntsRef();
-        private static readonly IntSequenceOutputs singleton = new IntSequenceOutputs();
+        private static readonly Int32sRef NO_OUTPUT = new Int32sRef();
+        private static readonly Int32SequenceOutputs singleton = new Int32SequenceOutputs();
 
-        private IntSequenceOutputs()
+        private Int32SequenceOutputs()
         {
         }
 
-        public static IntSequenceOutputs Singleton
+        public static Int32SequenceOutputs Singleton
         {
             get
             {
@@ -46,7 +48,7 @@ namespace Lucene.Net.Util.Fst
             }
         }
 
-        public override IntsRef Common(IntsRef output1, IntsRef output2)
+        public override Int32sRef Common(Int32sRef output1, Int32sRef output2)
         {
             Debug.Assert(output1 != null);
             Debug.Assert(output2 != null);
@@ -81,11 +83,11 @@ namespace Lucene.Net.Util.Fst
             }
             else
             {
-                return new IntsRef(output1.Int32s, output1.Offset, pos1 - output1.Offset);
+                return new Int32sRef(output1.Int32s, output1.Offset, pos1 - output1.Offset);
             }
         }
 
-        public override IntsRef Subtract(IntsRef output, IntsRef inc)
+        public override Int32sRef Subtract(Int32sRef output, Int32sRef inc)
         {
             Debug.Assert(output != null);
             Debug.Assert(inc != null);
@@ -103,11 +105,11 @@ namespace Lucene.Net.Util.Fst
             {
                 Debug.Assert(inc.Length < output.Length, "inc.length=" + inc.Length + " vs output.length=" + output.Length);
                 Debug.Assert(inc.Length > 0);
-                return new IntsRef(output.Int32s, output.Offset + inc.Length, output.Length - inc.Length);
+                return new Int32sRef(output.Int32s, output.Offset + inc.Length, output.Length - inc.Length);
             }
         }
 
-        public override IntsRef Add(IntsRef prefix, IntsRef output)
+        public override Int32sRef Add(Int32sRef prefix, Int32sRef output)
         {
             Debug.Assert(prefix != null);
             Debug.Assert(output != null);
@@ -123,7 +125,7 @@ namespace Lucene.Net.Util.Fst
             {
                 Debug.Assert(prefix.Length > 0);
                 Debug.Assert(output.Length > 0);
-                IntsRef result = new IntsRef(prefix.Length + output.Length);
+                Int32sRef result = new Int32sRef(prefix.Length + output.Length);
                 Array.Copy(prefix.Int32s, prefix.Offset, result.Int32s, 0, prefix.Length);
                 Array.Copy(output.Int32s, output.Offset, result.Int32s, prefix.Length, output.Length);
                 result.Length = prefix.Length + output.Length;
@@ -131,7 +133,7 @@ namespace Lucene.Net.Util.Fst
             }
         }
 
-        public override void Write(IntsRef prefix, DataOutput @out)
+        public override void Write(Int32sRef prefix, DataOutput @out)
         {
             Debug.Assert(prefix != null);
             @out.WriteVInt32(prefix.Length);
@@ -141,7 +143,7 @@ namespace Lucene.Net.Util.Fst
             }
         }
 
-        public override IntsRef Read(DataInput @in)
+        public override Int32sRef Read(DataInput @in)
         {
             int len = @in.ReadVInt32();
             if (len == 0)
@@ -150,7 +152,7 @@ namespace Lucene.Net.Util.Fst
             }
             else
             {
-                IntsRef output = new IntsRef(len);
+                Int32sRef output = new Int32sRef(len);
                 for (int idx = 0; idx < len; idx++)
                 {
                     output.Int32s[idx] = @in.ReadVInt32();
@@ -160,7 +162,7 @@ namespace Lucene.Net.Util.Fst
             }
         }
 
-        public override IntsRef NoOutput
+        public override Int32sRef NoOutput
         {
             get
             {
@@ -168,7 +170,7 @@ namespace Lucene.Net.Util.Fst
             }
         }
 
-        public override string OutputToString(IntsRef output)
+        public override string OutputToString(Int32sRef output)
         {
             return output.ToString();
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Util/Fst/IntsRefFSTEnum.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Fst/IntsRefFSTEnum.cs b/src/Lucene.Net.Core/Util/Fst/IntsRefFSTEnum.cs
index fba0afb..9fea57c 100644
--- a/src/Lucene.Net.Core/Util/Fst/IntsRefFSTEnum.cs
+++ b/src/Lucene.Net.Core/Util/Fst/IntsRefFSTEnum.cs
@@ -21,15 +21,17 @@ namespace Lucene.Net.Util.Fst
 
     /// <summary>
     /// Enumerates all input (IntsRef) + output pairs in an
-    ///  FST.
+    /// FST.
+    /// <para/>
+    /// NOTE: This was IntsRefFSTEnum{T} in Lucene
     ///
     /// @lucene.experimental
     /// </summary>
-    public sealed class IntsRefFSTEnum<T> : FSTEnum<T>
+    public sealed class Int32sRefFSTEnum<T> : FSTEnum<T>
     {
-        private readonly IntsRef current = new IntsRef(10);
-        private readonly IntsRefFSTEnum.InputOutput<T> result = new IntsRefFSTEnum.InputOutput<T>();
-        private IntsRef target;
+        private readonly Int32sRef current = new Int32sRef(10);
+        private readonly Int32sRefFSTEnum.InputOutput<T> result = new Int32sRefFSTEnum.InputOutput<T>();
+        private Int32sRef target;
 
         // LUCENENET NOTE: The InputOutput<T> class was moved into the IntsRefFSTEnum class
 
@@ -38,19 +40,19 @@ namespace Lucene.Net.Util.Fst
         ///  doFloor is true, advance positions to the biggest
         ///  term before target.
         /// </summary>
-        public IntsRefFSTEnum(FST<T> fst)
+        public Int32sRefFSTEnum(FST<T> fst)
             : base(fst)
         {
             result.Input = current;
             current.Offset = 1;
         }
 
-        public IntsRefFSTEnum.InputOutput<T> Current
+        public Int32sRefFSTEnum.InputOutput<T> Current
         {
             get { return result; }
         }
 
-        public IntsRefFSTEnum.InputOutput<T> Next()
+        public Int32sRefFSTEnum.InputOutput<T> Next()
         {
             //System.out.println("  enum.next");
             DoNext();
@@ -59,7 +61,7 @@ namespace Lucene.Net.Util.Fst
 
         /// <summary>
         /// Seeks to smallest term that's >= target. </summary>
-        public IntsRefFSTEnum.InputOutput<T> SeekCeil(IntsRef target)
+        public Int32sRefFSTEnum.InputOutput<T> SeekCeil(Int32sRef target)
         {
             this.target = target;
             m_targetLength = target.Length;
@@ -69,7 +71,7 @@ namespace Lucene.Net.Util.Fst
 
         /// <summary>
         /// Seeks to biggest term that's <= target. </summary>
-        public IntsRefFSTEnum.InputOutput<T> SeekFloor(IntsRef target)
+        public Int32sRefFSTEnum.InputOutput<T> SeekFloor(Int32sRef target)
         {
             this.target = target;
             m_targetLength = target.Length;
@@ -83,7 +85,7 @@ namespace Lucene.Net.Util.Fst
         ///  #seekFloor} or <seealso cref="#seekCeil"/> because it
         ///  short-circuits as soon the match is not found.
         /// </summary>
-        public IntsRefFSTEnum.InputOutput<T> SeekExact(IntsRef target)
+        public Int32sRefFSTEnum.InputOutput<T> SeekExact(Int32sRef target)
         {
             this.target = target;
             m_targetLength = target.Length;
@@ -131,7 +133,7 @@ namespace Lucene.Net.Util.Fst
             current.Int32s = ArrayUtil.Grow(current.Int32s, m_upto + 1);
         }
 
-        private IntsRefFSTEnum.InputOutput<T> SetResult()
+        private Int32sRefFSTEnum.InputOutput<T> SetResult()
         {
             if (m_upto == 0)
             {
@@ -149,18 +151,20 @@ namespace Lucene.Net.Util.Fst
     /// <summary>
     /// LUCENENET specific. This class is to mimic Java's ability to specify
     /// nested classes of Generics without having to specify the generic type
-    /// (i.e. IntsRefFSTEnum.InputOutput{T} rather than IntsRefFSTEnum{T}.InputOutput{T})
+    /// (i.e. <c>Int32sRefFSTEnum.InputOutput{T}</c> rather than <c>Int32sRefFSTEnum{T}.InputOutput{T}</c>)
+    /// <para/>
+    /// NOTE: This was Int32sRefFSTEnum{T} in Lucene
     /// </summary>
-    public sealed class IntsRefFSTEnum
+    public sealed class Int32sRefFSTEnum
     {
-        private IntsRefFSTEnum()
+        private Int32sRefFSTEnum()
         { }
 
         /// <summary>
         /// Holds a single input (IntsRef) + output pair. </summary>
         public class InputOutput<T>
         {
-            public IntsRef Input { get; set; }
+            public Int32sRef Input { get; set; }
             public T Output { get; set; }
         }
     }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Util/Fst/NodeHash.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Fst/NodeHash.cs b/src/Lucene.Net.Core/Util/Fst/NodeHash.cs
index ee61491..67dc54e 100644
--- a/src/Lucene.Net.Core/Util/Fst/NodeHash.cs
+++ b/src/Lucene.Net.Core/Util/Fst/NodeHash.cs
@@ -20,7 +20,7 @@ namespace Lucene.Net.Util.Fst
      * limitations under the License.
      */
 
-    using PackedInts = Lucene.Net.Util.Packed.PackedInts;
+    using PackedInt32s = Lucene.Net.Util.Packed.PackedInt32s;
     using PagedGrowableWriter = Lucene.Net.Util.Packed.PagedGrowableWriter;
 
     // Used to dedup states (lookup already-frozen states)
@@ -35,7 +35,7 @@ namespace Lucene.Net.Util.Fst
 
         public NodeHash(FST<T> fst, FST.BytesReader input)
         {
-            table = new PagedGrowableWriter(16, 1 << 30, 8, PackedInts.COMPACT);
+            table = new PagedGrowableWriter(16, 1 << 30, 8, PackedInt32s.COMPACT);
             mask = 15;
             this.fst = fst;
             this.input = input;
@@ -184,7 +184,7 @@ namespace Lucene.Net.Util.Fst
         {
             PagedGrowableWriter oldTable = table;
 
-            table = new PagedGrowableWriter(2 * oldTable.Count, 1 << 30, PackedInts.BitsRequired(count), PackedInts.COMPACT);
+            table = new PagedGrowableWriter(2 * oldTable.Count, 1 << 30, PackedInt32s.BitsRequired(count), PackedInt32s.COMPACT);
             mask = table.Count - 1;
             for (long idx = 0; idx < oldTable.Count; idx++)
             {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Util/Fst/PositiveIntOutputs.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Fst/PositiveIntOutputs.cs b/src/Lucene.Net.Core/Util/Fst/PositiveIntOutputs.cs
index 3713f83..4350dc9 100644
--- a/src/Lucene.Net.Core/Util/Fst/PositiveIntOutputs.cs
+++ b/src/Lucene.Net.Core/Util/Fst/PositiveIntOutputs.cs
@@ -24,22 +24,24 @@ namespace Lucene.Net.Util.Fst
     using DataOutput = Lucene.Net.Store.DataOutput;
 
     /// <summary>
-    /// An FST <seealso cref="Outputs"/> implementation where each output
+    /// An FST <seealso cref="Outputs{T}"/> implementation where each output
     /// is a non-negative long value.
+    /// <para/>
+    /// NOTE: This was PositiveIntOutputs in Lucene
     ///
     /// @lucene.experimental
     /// </summary>
-    public sealed class PositiveIntOutputs : Outputs<long?>
+    public sealed class PositiveInt32Outputs : Outputs<long?>
     {
         private static readonly long NO_OUTPUT = new long();
 
-        private static readonly PositiveIntOutputs singleton = new PositiveIntOutputs();
+        private static readonly PositiveInt32Outputs singleton = new PositiveInt32Outputs();
 
-        private PositiveIntOutputs()
+        private PositiveInt32Outputs()
         {
         }
 
-        public static PositiveIntOutputs Singleton
+        public static PositiveInt32Outputs Singleton
         {
             get
             {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Util/Fst/Util.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Fst/Util.cs b/src/Lucene.Net.Core/Util/Fst/Util.cs
index e3329c2..44bd4bc 100644
--- a/src/Lucene.Net.Core/Util/Fst/Util.cs
+++ b/src/Lucene.Net.Core/Util/Fst/Util.cs
@@ -39,7 +39,7 @@ namespace Lucene.Net.Util.Fst
         /// Looks up the output for this input, or null if the
         ///  input is not accepted.
         /// </summary>
-        public static T Get<T>(FST<T> fst, IntsRef input)
+        public static T Get<T>(FST<T> fst, Int32sRef input)
         {
             // TODO: would be nice not to alloc this on every lookup
             var arc = fst.GetFirstArc(new FST.Arc<T>());
@@ -117,7 +117,7 @@ namespace Lucene.Net.Util.Fst
         ///  2, ...), or file offets (when appending to a file)
         ///  fit this.
         /// </summary>
-        public static IntsRef GetByOutput(FST<long?> fst, long targetOutput)
+        public static Int32sRef GetByOutput(FST<long?> fst, long targetOutput)
         {
             var @in = fst.GetBytesReader();
 
@@ -126,7 +126,7 @@ namespace Lucene.Net.Util.Fst
 
             FST.Arc<long?> scratchArc = new FST.Arc<long?>();
 
-            IntsRef result = new IntsRef();
+            Int32sRef result = new Int32sRef();
 
             return GetByOutput(fst, targetOutput, @in, arc, scratchArc, result);
         }
@@ -135,7 +135,7 @@ namespace Lucene.Net.Util.Fst
         /// Expert: like <seealso cref="Util#getByOutput(FST, long)"/> except reusing
         /// BytesReader, initial and scratch Arc, and result.
         /// </summary>
-        public static IntsRef GetByOutput(FST<long?> fst, long targetOutput, FST.BytesReader @in, FST.Arc<long?> arc, FST.Arc<long?> scratchArc, IntsRef result)
+        public static Int32sRef GetByOutput(FST<long?> fst, long targetOutput, FST.BytesReader @in, FST.Arc<long?> arc, FST.Arc<long?> scratchArc, Int32sRef result)
         {
             long output = arc.Output.Value;
             int upto = 0;
@@ -301,11 +301,11 @@ namespace Lucene.Net.Util.Fst
         {
             public FST.Arc<T> Arc { get; set; }
             public T Cost { get; set; }
-            public IntsRef Input { get; private set; }
+            public Int32sRef Input { get; private set; }
 
             /// <summary>
             /// Sole constructor </summary>
-            public FSTPath(T cost, FST.Arc<T> arc, IntsRef input)
+            public FSTPath(T cost, FST.Arc<T> arc, Int32sRef input)
             {
                 this.Arc = (new FST.Arc<T>()).CopyFrom(arc);
                 this.Cost = cost;
@@ -424,7 +424,7 @@ namespace Lucene.Net.Util.Fst
 
                 // copy over the current input to the new input
                 // and add the arc.label to the end
-                IntsRef newInput = new IntsRef(path.Input.Length + 1);
+                Int32sRef newInput = new Int32sRef(path.Input.Length + 1);
                 Array.Copy(path.Input.Int32s, 0, newInput.Int32s, 0, path.Input.Length);
                 newInput.Int32s[path.Input.Length] = path.Arc.Label;
                 newInput.Length = path.Input.Length + 1;
@@ -449,7 +449,7 @@ namespace Lucene.Net.Util.Fst
             /// Adds all leaving arcs, including 'finished' arc, if
             ///  the node is final, from this node into the queue.
             /// </summary>
-            public virtual void AddStartPaths(FST.Arc<T> node, T startOutput, bool allowEmptyString, IntsRef input)
+            public virtual void AddStartPaths(FST.Arc<T> node, T startOutput, bool allowEmptyString, Int32sRef input)
             {
                 // De-dup NO_OUTPUT since it must be a singleton:
                 if (startOutput.Equals(fst.Outputs.NoOutput))
@@ -634,7 +634,7 @@ namespace Lucene.Net.Util.Fst
                 return new TopResults<T>(rejectCount + topN <= maxQueueDepth, results);
             }
 
-            protected virtual bool AcceptResult(IntsRef input, T output)
+            protected virtual bool AcceptResult(Int32sRef input, T output)
             {
                 return true;
             }
@@ -646,10 +646,10 @@ namespace Lucene.Net.Util.Fst
         /// </summary>
         public sealed class Result<T>
         {
-            public IntsRef Input { get; private set; }
+            public Int32sRef Input { get; private set; }
             public T Output { get; private set; }
 
-            public Result(IntsRef input, T output)
+            public Result(Int32sRef input, T output)
             {
                 this.Input = input;
                 this.Output = output;
@@ -702,7 +702,7 @@ namespace Lucene.Net.Util.Fst
 
             // since this search is initialized with a single start node
             // it is okay to start with an empty input path here
-            searcher.AddStartPaths(fromNode, startOutput, allowEmptyString, new IntsRef());
+            searcher.AddStartPaths(fromNode, startOutput, allowEmptyString, new Int32sRef());
             return searcher.Search();
         }
 
@@ -978,7 +978,7 @@ namespace Lucene.Net.Util.Fst
         /// Just maps each UTF16 unit (char) to the ints in an
         ///  IntsRef.
         /// </summary>
-        public static IntsRef ToUTF16(string s, IntsRef scratch)
+        public static Int32sRef ToUTF16(string s, Int32sRef scratch)
         {
             int charLimit = s.Length;
             scratch.Offset = 0;
@@ -996,7 +996,7 @@ namespace Lucene.Net.Util.Fst
         ///  CharSequence and places them in the provided scratch
         ///  IntsRef, which must not be null, returning it.
         /// </summary>
-        public static IntsRef ToUTF32(string s, IntsRef scratch)
+        public static Int32sRef ToUTF32(string s, Int32sRef scratch)
         {
             int charIdx = 0;
             int intIdx = 0;
@@ -1018,7 +1018,7 @@ namespace Lucene.Net.Util.Fst
         ///  char[] and places them in the provided scratch
         ///  IntsRef, which must not be null, returning it.
         /// </summary>
-        public static IntsRef ToUTF32(char[] s, int offset, int length, IntsRef scratch)
+        public static Int32sRef ToUTF32(char[] s, int offset, int length, Int32sRef scratch)
         {
             int charIdx = offset;
             int intIdx = 0;
@@ -1041,7 +1041,7 @@ namespace Lucene.Net.Util.Fst
         /// <para/>
         /// NOTE: This was toIntsRef() in Lucene
         /// </summary>
-        public static IntsRef ToInt32sRef(BytesRef input, IntsRef scratch)
+        public static Int32sRef ToInt32sRef(BytesRef input, Int32sRef scratch)
         {
             scratch.Grow(input.Length);
             for (int i = 0; i < input.Length; i++)
@@ -1056,7 +1056,7 @@ namespace Lucene.Net.Util.Fst
         /// Just converts IntsRef to BytesRef; you must ensure the
         ///  int values fit into a byte.
         /// </summary>
-        public static BytesRef ToBytesRef(IntsRef input, BytesRef scratch)
+        public static BytesRef ToBytesRef(Int32sRef input, BytesRef scratch)
         {
             scratch.Grow(input.Length);
             for (int i = 0; i < input.Length; i++)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Util/IntBlockPool.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/IntBlockPool.cs b/src/Lucene.Net.Core/Util/IntBlockPool.cs
index 0216498..300a5f6 100644
--- a/src/Lucene.Net.Core/Util/IntBlockPool.cs
+++ b/src/Lucene.Net.Core/Util/IntBlockPool.cs
@@ -23,10 +23,12 @@ namespace Lucene.Net.Util
      */
 
     /// <summary>
-    /// A pool for int blocks similar to <seealso cref="ByteBlockPool"/>
+    /// A pool for int blocks similar to <seealso cref="ByteBlockPool"/>.
+    /// <para/>
+    /// NOTE: This was IntBlockPool in Lucene
     /// @lucene.internal
     /// </summary>
-    public sealed class IntBlockPool
+    public sealed class Int32BlockPool
     {
         public static readonly int INT_BLOCK_SHIFT = 13;
         public static readonly int INT_BLOCK_SIZE = 1 << INT_BLOCK_SHIFT;
@@ -122,17 +124,17 @@ namespace Lucene.Net.Util
         private readonly Allocator allocator;
 
         /// <summary>
-        /// Creates a new <seealso cref="IntBlockPool"/> with a default <seealso cref="Allocator"/>. </summary>
-        /// <seealso cref= IntBlockPool#nextBuffer() </seealso>
-        public IntBlockPool()
+        /// Creates a new <seealso cref="Int32BlockPool"/> with a default <seealso cref="Allocator"/>. </summary>
+        /// <seealso cref= Int32BlockPool#nextBuffer() </seealso>
+        public Int32BlockPool()
             : this(new DirectAllocator())
         {
         }
 
         /// <summary>
-        /// Creates a new <seealso cref="IntBlockPool"/> with the given <seealso cref="Allocator"/>. </summary>
-        /// <seealso cref= IntBlockPool#nextBuffer() </seealso>
-        public IntBlockPool(Allocator allocator)
+        /// Creates a new <seealso cref="Int32BlockPool"/> with the given <seealso cref="Allocator"/>. </summary>
+        /// <seealso cref= Int32BlockPool#nextBuffer() </seealso>
+        public Int32BlockPool(Allocator allocator)
         {
             // set defaults
             Int32Upto = INT_BLOCK_SIZE;
@@ -143,7 +145,7 @@ namespace Lucene.Net.Util
 
         /// <summary>
         /// Resets the pool to its initial state reusing the first buffer. Calling
-        /// <seealso cref="IntBlockPool#nextBuffer()"/> is not needed after reset.
+        /// <seealso cref="Int32BlockPool#nextBuffer()"/> is not needed after reset.
         /// </summary>
         public void Reset()
         {
@@ -156,8 +158,8 @@ namespace Lucene.Net.Util
         ///        this should be set to <code>true</code> if this pool is used with
         ///        <seealso cref="SliceWriter"/>. </param>
         /// <param name="reuseFirst"> if <code>true</code> the first buffer will be reused and calling
-        ///        <seealso cref="IntBlockPool#nextBuffer()"/> is not needed after reset iff the
-        ///        block pool was used before ie. <seealso cref="IntBlockPool#nextBuffer()"/> was called before. </param>
+        ///        <seealso cref="Int32BlockPool#nextBuffer()"/> is not needed after reset iff the
+        ///        block pool was used before ie. <seealso cref="Int32BlockPool#nextBuffer()"/> was called before. </param>
         public void Reset(bool zeroFillBuffers, bool reuseFirst)
         {
             if (bufferUpto != -1)
@@ -203,7 +205,7 @@ namespace Lucene.Net.Util
         /// <summary>
         /// Advances the pool to its next buffer. this method should be called once
         /// after the constructor to initialize the pool. In contrast to the
-        /// constructor a <seealso cref="IntBlockPool#reset()"/> call will advance the pool to
+        /// constructor a <seealso cref="Int32BlockPool#reset()"/> call will advance the pool to
         /// its first buffer immediately.
         /// </summary>
         public void NextBuffer()
@@ -251,7 +253,7 @@ namespace Lucene.Net.Util
         // no need to make this public unless we support different sizes
         // TODO make the levels and the sizes configurable
         /// <summary>
-        /// An array holding the offset into the <seealso cref="IntBlockPool#LEVEL_SIZE_ARRAY"/>
+        /// An array holding the offset into the <seealso cref="Int32BlockPool#LEVEL_SIZE_ARRAY"/>
         /// to quickly navigate to the next slice level.
         /// </summary>
         private static readonly int[] NEXT_LEVEL_ARRAY = new int[] { 1, 2, 3, 4, 5, 6, 7, 8, 9, 9 };
@@ -294,16 +296,16 @@ namespace Lucene.Net.Util
         }
 
         /// <summary>
-        /// A <seealso cref="SliceWriter"/> that allows to write multiple integer slices into a given <seealso cref="IntBlockPool"/>.
+        /// A <seealso cref="SliceWriter"/> that allows to write multiple integer slices into a given <seealso cref="Int32BlockPool"/>.
         /// </summary>
         ///  <seealso cref= SliceReader
         ///  @lucene.internal </seealso>
         public class SliceWriter
         {
             private int offset;
-            private readonly IntBlockPool pool;
+            private readonly Int32BlockPool pool;
 
-            public SliceWriter(IntBlockPool pool)
+            public SliceWriter(Int32BlockPool pool)
             {
                 this.pool = pool;
             }
@@ -365,7 +367,7 @@ namespace Lucene.Net.Util
         /// </summary>
         public sealed class SliceReader
         {
-            private readonly IntBlockPool pool;
+            private readonly Int32BlockPool pool;
             private int upto;
             private int bufferUpto;
             private int bufferOffset;
@@ -377,7 +379,7 @@ namespace Lucene.Net.Util
             /// <summary>
             /// Creates a new <seealso cref="SliceReader"/> on the given pool
             /// </summary>
-            public SliceReader(IntBlockPool pool)
+            public SliceReader(Int32BlockPool pool)
             {
                 this.pool = pool;
             }
@@ -396,7 +398,7 @@ namespace Lucene.Net.Util
                 buffer = pool.buffers[bufferUpto];
                 upto = startOffset & INT_BLOCK_MASK;
 
-                int firstSize = IntBlockPool.LEVEL_SIZE_ARRAY[0];
+                int firstSize = Int32BlockPool.LEVEL_SIZE_ARRAY[0];
                 if (startOffset + firstSize >= endOffset)
                 {
                     // There is only this one slice to read

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Util/IntsRef.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/IntsRef.cs b/src/Lucene.Net.Core/Util/IntsRef.cs
index 26dd154..c39aceb 100644
--- a/src/Lucene.Net.Core/Util/IntsRef.cs
+++ b/src/Lucene.Net.Core/Util/IntsRef.cs
@@ -25,12 +25,14 @@ namespace Lucene.Net.Util
 
     /// <summary>
     /// Represents int[], as a slice (offset + length) into an
-    ///  existing int[].  The <seealso cref="#ints"/> member should never be null; use
-    ///  <seealso cref="#EMPTY_INTS"/> if necessary.
-    ///
+    /// existing int[].  The <seealso cref="#ints"/> member should never be null; use
+    /// <seealso cref="#EMPTY_INTS"/> if necessary.
+    /// <para/>
+    /// NOTE: This was IntsRef in Lucene
+    /// 
     ///  @lucene.internal
     /// </summary>
-    public sealed class IntsRef : IComparable<IntsRef> // LUCENENET TODO: Rename Int32sRef ?
+    public sealed class Int32sRef : IComparable<Int32sRef>
     {
         /// <summary>
         /// An empty integer array for convenience </summary>
@@ -67,7 +69,7 @@ namespace Lucene.Net.Util
 
         /// <summary>
         /// Create a IntsRef with <seealso cref="#EMPTY_INTS"/> </summary>
-        public IntsRef()
+        public Int32sRef()
         {
             ints = EMPTY_INTS;
         }
@@ -76,7 +78,7 @@ namespace Lucene.Net.Util
         /// Create a IntsRef pointing to a new array of size <code>capacity</code>.
         /// Offset and length will both be zero.
         /// </summary>
-        public IntsRef(int capacity)
+        public Int32sRef(int capacity)
         {
             ints = new int[capacity];
         }
@@ -85,7 +87,7 @@ namespace Lucene.Net.Util
         /// this instance will directly reference ints w/o making a copy.
         /// ints should not be null.
         /// </summary>
-        public IntsRef(int[] ints, int offset, int length)
+        public Int32sRef(int[] ints, int offset, int length)
         {
             this.ints = ints;
             this.Offset = offset;
@@ -101,7 +103,7 @@ namespace Lucene.Net.Util
         /// <seealso cref= #deepCopyOf </seealso>
         public object Clone()
         {
-            return new IntsRef(ints, Offset, Length);
+            return new Int32sRef(ints, Offset, Length);
         }
 
         public override int GetHashCode()
@@ -122,9 +124,9 @@ namespace Lucene.Net.Util
             {
                 return false;
             }
-            if (other is IntsRef)
+            if (other is Int32sRef)
             {
-                return this.Int32sEquals((IntsRef)other);
+                return this.Int32sEquals((Int32sRef)other);
             }
             return false;
         }
@@ -132,7 +134,7 @@ namespace Lucene.Net.Util
         /// <summary>
         /// NOTE: This was intsEquals() in Lucene
         /// </summary>
-        public bool Int32sEquals(IntsRef other)
+        public bool Int32sEquals(Int32sRef other)
         {
             if (Length == other.Length)
             {
@@ -156,7 +158,7 @@ namespace Lucene.Net.Util
 
         /// <summary>
         /// Signed int order comparison </summary>
-        public int CompareTo(IntsRef other)
+        public int CompareTo(Int32sRef other)
         {
             if (this == other)
             {
@@ -191,7 +193,7 @@ namespace Lucene.Net.Util
         /// <summary>
         /// NOTE: This was copyInts() in Lucene
         /// </summary>
-        public void CopyInt32s(IntsRef other)
+        public void CopyInt32s(Int32sRef other)
         {
             if (ints.Length - Offset < other.Length)
             {
@@ -241,9 +243,9 @@ namespace Lucene.Net.Util
         /// The returned IntsRef will have a length of other.length
         /// and an offset of zero.
         /// </summary>
-        public static IntsRef DeepCopyOf(IntsRef other)
+        public static Int32sRef DeepCopyOf(Int32sRef other)
         {
-            IntsRef clone = new IntsRef();
+            Int32sRef clone = new Int32sRef();
             clone.CopyInt32s(other);
             return clone;
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Util/LongBitSet.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/LongBitSet.cs b/src/Lucene.Net.Core/Util/LongBitSet.cs
index 02a73b8..fe46132 100644
--- a/src/Lucene.Net.Core/Util/LongBitSet.cs
+++ b/src/Lucene.Net.Core/Util/LongBitSet.cs
@@ -25,26 +25,28 @@ namespace Lucene.Net.Util
     /// BitSet of fixed length (numBits), backed by accessible (<seealso cref="#getBits"/>)
     /// long[], accessed with a long index. Use it only if you intend to store more
     /// than 2.1B bits, otherwise you should use <seealso cref="FixedBitSet"/>.
+    /// <para/>
+    /// NOTE: This was LongBitSet in Lucene
     ///
     /// @lucene.internal
     /// </summary>
-    public sealed class LongBitSet // LUCENENET TODO: Rename Int64BitSet ?
+    public sealed class Int64BitSet
     {
         private readonly long[] bits;
         private readonly long numBits;
         private readonly int numWords;
 
         /// <summary>
-        /// If the given <seealso cref="LongBitSet"/> is large enough to hold
+        /// If the given <seealso cref="Int64BitSet"/> is large enough to hold
         /// {@code numBits}, returns the given bits, otherwise returns a new
-        /// <seealso cref="LongBitSet"/> which can hold the requested number of bits.
+        /// <seealso cref="Int64BitSet"/> which can hold the requested number of bits.
         ///
         /// <p>
         /// <b>NOTE:</b> the returned bitset reuses the underlying {@code long[]} of
         /// the given {@code bits} if possible. Also, calling <seealso cref="#length()"/> on the
         /// returned bits may return a value greater than {@code numBits}.
         /// </summary>
-        public static LongBitSet EnsureCapacity(LongBitSet bits, long numBits)
+        public static Int64BitSet EnsureCapacity(Int64BitSet bits, long numBits)
         {
             if (numBits < bits.Length)
             {
@@ -58,7 +60,7 @@ namespace Lucene.Net.Util
                 {
                     arr = ArrayUtil.Grow(arr, numWords + 1);
                 }
-                return new LongBitSet(arr, arr.Length << 6);
+                return new Int64BitSet(arr, arr.Length << 6);
             }
         }
 
@@ -74,14 +76,14 @@ namespace Lucene.Net.Util
             return numLong;
         }
 
-        public LongBitSet(long numBits)
+        public Int64BitSet(long numBits)
         {
             this.numBits = numBits;
             bits = new long[Bits2words(numBits)];
             numWords = bits.Length;
         }
 
-        public LongBitSet(long[] storedBits, long numBits)
+        public Int64BitSet(long[] storedBits, long numBits)
         {
             this.numWords = Bits2words(numBits);
             if (numWords > storedBits.Length)
@@ -226,7 +228,7 @@ namespace Lucene.Net.Util
 
         /// <summary>
         /// this = this OR other </summary>
-        public void Or(LongBitSet other)
+        public void Or(Int64BitSet other)
         {
             Debug.Assert(other.numWords <= numWords, "numWords=" + numWords + ", other.numWords=" + other.numWords);
             int pos = Math.Min(numWords, other.numWords);
@@ -238,7 +240,7 @@ namespace Lucene.Net.Util
 
         /// <summary>
         /// this = this XOR other </summary>
-        public void Xor(LongBitSet other)
+        public void Xor(Int64BitSet other)
         {
             Debug.Assert(other.numWords <= numWords, "numWords=" + numWords + ", other.numWords=" + other.numWords);
             int pos = Math.Min(numWords, other.numWords);
@@ -250,7 +252,7 @@ namespace Lucene.Net.Util
 
         /// <summary>
         /// returns true if the sets have any elements in common </summary>
-        public bool Intersects(LongBitSet other)
+        public bool Intersects(Int64BitSet other)
         {
             int pos = Math.Min(numWords, other.numWords);
             while (--pos >= 0)
@@ -265,7 +267,7 @@ namespace Lucene.Net.Util
 
         /// <summary>
         /// this = this AND other </summary>
-        public void And(LongBitSet other)
+        public void And(Int64BitSet other)
         {
             int pos = Math.Min(numWords, other.numWords);
             while (--pos >= 0)
@@ -280,7 +282,7 @@ namespace Lucene.Net.Util
 
         /// <summary>
         /// this = this AND NOT other </summary>
-        public void AndNot(LongBitSet other)
+        public void AndNot(Int64BitSet other)
         {
             int pos = Math.Min(numWords, other.bits.Length);
             while (--pos >= 0)
@@ -409,11 +411,11 @@ namespace Lucene.Net.Util
             bits[endWord] &= endmask;
         }
 
-        public LongBitSet Clone()
+        public Int64BitSet Clone()
         {
             long[] bits = new long[this.bits.Length];
             Array.Copy(this.bits, 0, bits, 0, bits.Length);
-            return new LongBitSet(bits, numBits);
+            return new Int64BitSet(bits, numBits);
         }
 
         /// <summary>
@@ -424,11 +426,11 @@ namespace Lucene.Net.Util
             {
                 return true;
             }
-            if (!(o is LongBitSet))
+            if (!(o is Int64BitSet))
             {
                 return false;
             }
-            LongBitSet other = (LongBitSet)o;
+            Int64BitSet other = (Int64BitSet)o;
             if (numBits != other.Length)
             {
                 return false;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Util/LongValues.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/LongValues.cs b/src/Lucene.Net.Core/Util/LongValues.cs
index 625a842..ce1335f 100644
--- a/src/Lucene.Net.Core/Util/LongValues.cs
+++ b/src/Lucene.Net.Core/Util/LongValues.cs
@@ -18,16 +18,19 @@ namespace Lucene.Net.Util
      */
 
     using NumericDocValues = Lucene.Net.Index.NumericDocValues;
-    using PackedInts = Lucene.Net.Util.Packed.PackedInts;
+    using PackedInt32s = Lucene.Net.Util.Packed.PackedInt32s;
 
     /// <summary>
     /// Abstraction over an array of longs.
     ///  this class extends NumericDocValues so that we don't need to add another
-    ///  level of abstraction every time we want eg. to use the <seealso cref="PackedInts"/>
+    ///  level of abstraction every time we want eg. to use the <seealso cref="PackedInt32s"/>
     ///  utility classes to represent a <seealso cref="NumericDocValues"/> instance.
+    /// <para/>
+    /// NOTE: This was LongValues in Lucene
+    /// 
     ///  @lucene.internal
     /// </summary>
-    public abstract class LongValues : NumericDocValues
+    public abstract class Int64Values : NumericDocValues
     {
         /// <summary>
         /// Get value at <code>index</code>. </summary>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Util/LongsRef.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/LongsRef.cs b/src/Lucene.Net.Core/Util/LongsRef.cs
index 6bfd5f1..4274922 100644
--- a/src/Lucene.Net.Core/Util/LongsRef.cs
+++ b/src/Lucene.Net.Core/Util/LongsRef.cs
@@ -27,10 +27,12 @@ namespace Lucene.Net.Util
     /// Represents long[], as a slice (offset + length) into an
     ///  existing long[].  The <seealso cref="#longs"/> member should never be null; use
     ///  <seealso cref="#EMPTY_LONGS"/> if necessary.
+    ///  <para/>
+    /// NOTE: This was LongsRef in Lucene
     ///
     ///  @lucene.internal
     /// </summary>
-    public sealed class LongsRef : IComparable<LongsRef> // LUCENENET TODO: Rename Int64sRef ?
+    public sealed class Int64sRef : IComparable<Int64sRef>
     {
         /// <summary>
         /// An empty long array for convenience </summary>
@@ -67,7 +69,7 @@ namespace Lucene.Net.Util
 
         /// <summary>
         /// Create a LongsRef with <seealso cref="#EMPTY_LONGS"/> </summary>
-        public LongsRef()
+        public Int64sRef()
         {
             longs = EMPTY_LONGS;
         }
@@ -76,7 +78,7 @@ namespace Lucene.Net.Util
         /// Create a LongsRef pointing to a new array of size <code>capacity</code>.
         /// Offset and length will both be zero.
         /// </summary>
-        public LongsRef(int capacity)
+        public Int64sRef(int capacity)
         {
             longs = new long[capacity];
         }
@@ -85,7 +87,7 @@ namespace Lucene.Net.Util
         /// this instance will directly reference longs w/o making a copy.
         /// longs should not be null
         /// </summary>
-        public LongsRef(long[] longs, int offset, int length)
+        public Int64sRef(long[] longs, int offset, int length)
         {
             this.longs = longs;
             this.Offset = offset;
@@ -101,7 +103,7 @@ namespace Lucene.Net.Util
         /// <seealso cref= #deepCopyOf </seealso>
         public object Clone()
         {
-            return new LongsRef(longs, Offset, Length);
+            return new Int64sRef(longs, Offset, Length);
         }
 
         public override int GetHashCode()
@@ -122,9 +124,9 @@ namespace Lucene.Net.Util
             {
                 return false;
             }
-            if (other is LongsRef)
+            if (other is Int64sRef)
             {
-                return this.Int64sEquals((LongsRef)other);
+                return this.Int64sEquals((Int64sRef)other);
             }
             return false;
         }
@@ -132,7 +134,7 @@ namespace Lucene.Net.Util
         /// <summary>
         /// NOTE: This was longsEquals() in Lucene
         /// </summary>
-        public bool Int64sEquals(LongsRef other)
+        public bool Int64sEquals(Int64sRef other)
         {
             if (Length == other.Length)
             {
@@ -156,7 +158,7 @@ namespace Lucene.Net.Util
 
         /// <summary>
         /// Signed int order comparison </summary>
-        public int CompareTo(LongsRef other)
+        public int CompareTo(Int64sRef other)
         {
             if (this == other)
             {
@@ -191,7 +193,7 @@ namespace Lucene.Net.Util
         /// <summary>
         /// NOTE: This was copyLongs() in Lucene
         /// </summary>
-        public void CopyInt64s(LongsRef other)
+        public void CopyInt64s(Int64sRef other)
         {
             if (longs.Length - Offset < other.Length)
             {
@@ -241,9 +243,9 @@ namespace Lucene.Net.Util
         /// The returned IntsRef will have a length of other.length
         /// and an offset of zero.
         /// </summary>
-        public static LongsRef DeepCopyOf(LongsRef other)
+        public static Int64sRef DeepCopyOf(Int64sRef other)
         {
-            LongsRef clone = new LongsRef();
+            Int64sRef clone = new Int64sRef();
             clone.CopyInt64s(other);
             return clone;
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Util/Mutable/MutableValueDate.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Mutable/MutableValueDate.cs b/src/Lucene.Net.Core/Util/Mutable/MutableValueDate.cs
index f4fc8e1..bddab21 100644
--- a/src/Lucene.Net.Core/Util/Mutable/MutableValueDate.cs
+++ b/src/Lucene.Net.Core/Util/Mutable/MutableValueDate.cs
@@ -23,7 +23,7 @@ namespace Lucene.Net.Util.Mutable
     /// <seealso cref="MutableValue"/> implementation of type
     /// <seealso cref="Date"/>.
     /// </summary>
-    public class MutableValueDate : MutableValueLong
+    public class MutableValueDate : MutableValueInt64
     {
         public override object ToObject()
         {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Util/Mutable/MutableValueFloat.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Mutable/MutableValueFloat.cs b/src/Lucene.Net.Core/Util/Mutable/MutableValueFloat.cs
index a71386b..6cd335a 100644
--- a/src/Lucene.Net.Core/Util/Mutable/MutableValueFloat.cs
+++ b/src/Lucene.Net.Core/Util/Mutable/MutableValueFloat.cs
@@ -20,10 +20,11 @@ namespace Lucene.Net.Util.Mutable
      */
 
     /// <summary>
-    /// <seealso cref="MutableValue"/> implementation of type
-    /// <code>float</code>.
+    /// <see cref="MutableValue"/> implementation of type <see cref="float"/>.
+    /// <para/>
+    /// NOTE: This was MutableValueFloat in Lucene
     /// </summary>
-    public class MutableValueFloat : MutableValue
+    public class MutableValueSingle : MutableValue
     {
         public float Value { get; set; }
 
@@ -34,14 +35,14 @@ namespace Lucene.Net.Util.Mutable
 
         public override void Copy(MutableValue source)
         {
-            MutableValueFloat s = (MutableValueFloat)source;
+            MutableValueSingle s = (MutableValueSingle)source;
             Value = s.Value;
             Exists = s.Exists;
         }
 
         public override MutableValue Duplicate()
         {
-            MutableValueFloat v = new MutableValueFloat();
+            MutableValueSingle v = new MutableValueSingle();
             v.Value = this.Value;
             v.Exists = this.Exists;
             return v;
@@ -49,13 +50,13 @@ namespace Lucene.Net.Util.Mutable
 
         public override bool EqualsSameType(object other)
         {
-            MutableValueFloat b = (MutableValueFloat)other;
+            MutableValueSingle b = (MutableValueSingle)other;
             return Value == b.Value && Exists == b.Exists;
         }
 
         public override int CompareSameType(object other)
         {
-            MutableValueFloat b = (MutableValueFloat)other;
+            MutableValueSingle b = (MutableValueSingle)other;
             int c = Value.CompareTo(b.Value);
             if (c != 0)
             {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Util/Mutable/MutableValueInt.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Mutable/MutableValueInt.cs b/src/Lucene.Net.Core/Util/Mutable/MutableValueInt.cs
index fe70f58..91eb769 100644
--- a/src/Lucene.Net.Core/Util/Mutable/MutableValueInt.cs
+++ b/src/Lucene.Net.Core/Util/Mutable/MutableValueInt.cs
@@ -18,10 +18,11 @@ namespace Lucene.Net.Util.Mutable
      */
 
     /// <summary>
-    /// <seealso cref="MutableValue"/> implementation of type
-    /// <code>int</code>.
+    /// <see cref="MutableValue"/> implementation of type <see cref="int"/>.
+    /// <para/>
+    /// NOTE: This was MutableValueInt in Lucene
     /// </summary>
-    public class MutableValueInt : MutableValue
+    public class MutableValueInt32 : MutableValue
     {
         public int Value { get; set; }
 
@@ -32,14 +33,14 @@ namespace Lucene.Net.Util.Mutable
 
         public override void Copy(MutableValue source)
         {
-            MutableValueInt s = (MutableValueInt)source;
+            MutableValueInt32 s = (MutableValueInt32)source;
             Value = s.Value;
             Exists = s.Exists;
         }
 
         public override MutableValue Duplicate()
         {
-            MutableValueInt v = new MutableValueInt();
+            MutableValueInt32 v = new MutableValueInt32();
             v.Value = this.Value;
             v.Exists = this.Exists;
             return v;
@@ -47,13 +48,13 @@ namespace Lucene.Net.Util.Mutable
 
         public override bool EqualsSameType(object other)
         {
-            MutableValueInt b = (MutableValueInt)other;
+            MutableValueInt32 b = (MutableValueInt32)other;
             return Value == b.Value && Exists == b.Exists;
         }
 
         public override int CompareSameType(object other)
         {
-            MutableValueInt b = (MutableValueInt)other;
+            MutableValueInt32 b = (MutableValueInt32)other;
             int ai = Value;
             int bi = b.Value;
             if (ai < bi)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Util/Mutable/MutableValueLong.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Mutable/MutableValueLong.cs b/src/Lucene.Net.Core/Util/Mutable/MutableValueLong.cs
index f6162ad..77fba90 100644
--- a/src/Lucene.Net.Core/Util/Mutable/MutableValueLong.cs
+++ b/src/Lucene.Net.Core/Util/Mutable/MutableValueLong.cs
@@ -18,10 +18,11 @@ namespace Lucene.Net.Util.Mutable
      */
 
     /// <summary>
-    /// <seealso cref="MutableValue"/> implementation of type
-    /// <code>long</code>.
+    /// <see cref="MutableValue"/> implementation of type <see cref="long"/>.
+    /// <para/>
+    /// NOTE: This was MutableValueLong in Lucene
     /// </summary>
-    public class MutableValueLong : MutableValue
+    public class MutableValueInt64 : MutableValue
     {
         public long Value { get; set; }
 
@@ -32,14 +33,14 @@ namespace Lucene.Net.Util.Mutable
 
         public override void Copy(MutableValue source)
         {
-            MutableValueLong s = (MutableValueLong)source;
+            MutableValueInt64 s = (MutableValueInt64)source;
             Exists = s.Exists;
             Value = s.Value;
         }
 
         public override MutableValue Duplicate()
         {
-            MutableValueLong v = new MutableValueLong();
+            MutableValueInt64 v = new MutableValueInt64();
             v.Value = this.Value;
             v.Exists = this.Exists;
             return v;
@@ -47,13 +48,13 @@ namespace Lucene.Net.Util.Mutable
 
         public override bool EqualsSameType(object other)
         {
-            MutableValueLong b = (MutableValueLong)other;
+            MutableValueInt64 b = (MutableValueInt64)other;
             return Value == b.Value && Exists == b.Exists;
         }
 
         public override int CompareSameType(object other)
         {
-            MutableValueLong b = (MutableValueLong)other;
+            MutableValueInt64 b = (MutableValueInt64)other;
             long bv = b.Value;
             if (Value < bv)
             {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Util/NumericUtils.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/NumericUtils.cs b/src/Lucene.Net.Core/Util/NumericUtils.cs
index b66a134..4478e44 100644
--- a/src/Lucene.Net.Core/Util/NumericUtils.cs
+++ b/src/Lucene.Net.Core/Util/NumericUtils.cs
@@ -359,14 +359,14 @@ namespace Lucene.Net.Util
         /// Splits a long range recursively.
         /// You may implement a builder that adds clauses to a
         /// <seealso cref="Lucene.Net.Search.BooleanQuery"/> for each call to its
-        /// <seealso cref="LongRangeBuilder#addRange(BytesRef,BytesRef)"/>
+        /// <seealso cref="Int64RangeBuilder#addRange(BytesRef,BytesRef)"/>
         /// method.
         /// <para/>
         /// this method is used by <seealso cref="NumericRangeQuery"/>.
         /// <para/>
         /// NOTE: This was splitLongRange() in Lucene
         /// </summary>
-        public static void SplitInt64Range(LongRangeBuilder builder, int precisionStep, long minBound, long maxBound)
+        public static void SplitInt64Range(Int64RangeBuilder builder, int precisionStep, long minBound, long maxBound)
         {
             SplitRange(builder, 64, precisionStep, minBound, maxBound);
         }
@@ -375,14 +375,14 @@ namespace Lucene.Net.Util
         /// Splits an int range recursively.
         /// You may implement a builder that adds clauses to a
         /// <seealso cref="Lucene.Net.Search.BooleanQuery"/> for each call to its
-        /// <seealso cref="IntRangeBuilder#addRange(BytesRef,BytesRef)"/>
+        /// <seealso cref="Int32RangeBuilder#addRange(BytesRef,BytesRef)"/>
         /// method.
         /// <para/>
         /// this method is used by <seealso cref="NumericRangeQuery"/>.
         /// <para/>
         /// NOTE: This was splitIntRange() in Lucene
         /// </summary>
-        public static void SplitInt32Range(IntRangeBuilder builder, int precisionStep, int minBound, int maxBound)
+        public static void SplitInt32Range(Int32RangeBuilder builder, int precisionStep, int minBound, int maxBound)
         {
             SplitRange(builder, 32, precisionStep, minBound, maxBound);
         }
@@ -443,11 +443,11 @@ namespace Lucene.Net.Util
             switch (valSize)
             {
                 case 64:
-                    ((LongRangeBuilder)builder).AddRange(minBound, maxBound, shift);
+                    ((Int64RangeBuilder)builder).AddRange(minBound, maxBound, shift);
                     break;
 
                 case 32:
-                    ((IntRangeBuilder)builder).AddRange((int)minBound, (int)maxBound, shift);
+                    ((Int32RangeBuilder)builder).AddRange((int)minBound, (int)maxBound, shift);
                     break;
 
                 default:
@@ -459,10 +459,13 @@ namespace Lucene.Net.Util
         /// <summary>
         /// Callback for <seealso cref="#splitLongRange"/>.
         /// You need to overwrite only one of the methods.
+        /// <para/>
+        /// NOTE: This was LongRangeBuilder in Lucene
+        /// 
         /// @lucene.internal
         /// @since 2.9, API changed non backwards-compliant in 4.0
         /// </summary>
-        public abstract class LongRangeBuilder // LUCENENET TODO: Rename Int64RangeBuilder ?
+        public abstract class Int64RangeBuilder
         {
             /// <summary>
             /// Overwrite this method, if you like to receive the already prefix encoded range bounds.
@@ -489,10 +492,13 @@ namespace Lucene.Net.Util
         /// <summary>
         /// Callback for <seealso cref="#splitIntRange"/>.
         /// You need to overwrite only one of the methods.
+        /// <para/>
+        /// NOTE: This was IntRangeBuilder in Lucene
+        /// 
         /// @lucene.internal
         /// @since 2.9, API changed non backwards-compliant in 4.0
         /// </summary>
-        public abstract class IntRangeBuilder // LUCENENET TODO: Rename Int32RangeBuilder ?
+        public abstract class Int32RangeBuilder
         {
             /// <summary>
             /// Overwrite this method, if you like to receive the already prefix encoded range bounds.

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Util/PForDeltaDocIdSet.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/PForDeltaDocIdSet.cs b/src/Lucene.Net.Core/Util/PForDeltaDocIdSet.cs
index 331e020..d0d08a9 100644
--- a/src/Lucene.Net.Core/Util/PForDeltaDocIdSet.cs
+++ b/src/Lucene.Net.Core/Util/PForDeltaDocIdSet.cs
@@ -23,8 +23,8 @@ namespace Lucene.Net.Util
 
     using DocIdSet = Lucene.Net.Search.DocIdSet;
     using DocIdSetIterator = Lucene.Net.Search.DocIdSetIterator;
-    using MonotonicAppendingLongBuffer = Lucene.Net.Util.Packed.MonotonicAppendingLongBuffer;
-    using PackedInts = Lucene.Net.Util.Packed.PackedInts;
+    using MonotonicAppendingInt64Buffer = Lucene.Net.Util.Packed.MonotonicAppendingInt64Buffer;
+    using PackedInt32s = Lucene.Net.Util.Packed.PackedInt32s;
 
     /// <summary>
     /// <seealso cref="DocIdSet"/> implementation based on pfor-delta encoding.
@@ -38,11 +38,11 @@ namespace Lucene.Net.Util
     {
         internal const int BLOCK_SIZE = 128;
         internal const int MAX_EXCEPTIONS = 24; // no more than 24 exceptions per block
-        internal static readonly PackedInts.IDecoder[] DECODERS = new PackedInts.IDecoder[32];
+        internal static readonly PackedInt32s.IDecoder[] DECODERS = new PackedInt32s.IDecoder[32];
         internal static readonly int[] ITERATIONS = new int[32];
         internal static readonly int[] BYTE_BLOCK_COUNTS = new int[32];
         internal static readonly int MAX_BYTE_BLOCK_COUNT;
-        internal static readonly MonotonicAppendingLongBuffer SINGLE_ZERO_BUFFER = new MonotonicAppendingLongBuffer(0, 64, PackedInts.COMPACT);
+        internal static readonly MonotonicAppendingInt64Buffer SINGLE_ZERO_BUFFER = new MonotonicAppendingInt64Buffer(0, 64, PackedInt32s.COMPACT);
         internal static readonly PForDeltaDocIdSet EMPTY = new PForDeltaDocIdSet(null, 0, int.MaxValue, SINGLE_ZERO_BUFFER, SINGLE_ZERO_BUFFER);
         internal static readonly int LAST_BLOCK = 1 << 5; // flag to indicate the last block
         internal static readonly int HAS_EXCEPTIONS = 1 << 6;
@@ -55,7 +55,7 @@ namespace Lucene.Net.Util
             int maxByteBLockCount = 0;
             for (int i = 1; i < ITERATIONS.Length; ++i)
             {
-                DECODERS[i] = PackedInts.GetDecoder(PackedInts.Format.PACKED, PackedInts.VERSION_CURRENT, i);
+                DECODERS[i] = PackedInt32s.GetDecoder(PackedInt32s.Format.PACKED, PackedInt32s.VERSION_CURRENT, i);
                 Debug.Assert(BLOCK_SIZE % DECODERS[i].ByteValueCount == 0);
                 ITERATIONS[i] = BLOCK_SIZE / DECODERS[i].ByteValueCount;
                 BYTE_BLOCK_COUNTS[i] = ITERATIONS[i] * DECODERS[i].ByteBlockCount;
@@ -152,11 +152,11 @@ namespace Lucene.Net.Util
 
             internal virtual int PforBlockSize(int bitsPerValue, int numExceptions, int bitsPerException)
             {
-                PackedInts.Format format = PackedInts.Format.PACKED;
-                long blockSize = 1 + format.ByteCount(PackedInts.VERSION_CURRENT, BLOCK_SIZE, bitsPerValue); // header: number of bits per value
+                PackedInt32s.Format format = PackedInt32s.Format.PACKED;
+                long blockSize = 1 + format.ByteCount(PackedInt32s.VERSION_CURRENT, BLOCK_SIZE, bitsPerValue); // header: number of bits per value
                 if (numExceptions > 0)
                 {
-                    blockSize += 2 + numExceptions + format.ByteCount(PackedInts.VERSION_CURRENT, numExceptions, bitsPerException); // indices of the exceptions -  2 additional bytes in case of exceptions: numExceptions and bitsPerException
+                    blockSize += 2 + numExceptions + format.ByteCount(PackedInt32s.VERSION_CURRENT, numExceptions, bitsPerException); // indices of the exceptions -  2 additional bytes in case of exceptions: numExceptions and bitsPerException
                 }
                 if (bufferSize < BLOCK_SIZE)
                 {
@@ -230,7 +230,7 @@ namespace Lucene.Net.Util
 
                 if (bitsPerValue > 0)
                 {
-                    PackedInts.IEncoder encoder = PackedInts.GetEncoder(PackedInts.Format.PACKED, PackedInts.VERSION_CURRENT, bitsPerValue);
+                    PackedInt32s.IEncoder encoder = PackedInt32s.GetEncoder(PackedInt32s.Format.PACKED, PackedInt32s.VERSION_CURRENT, bitsPerValue);
                     int numIterations = ITERATIONS[bitsPerValue];
                     encoder.Encode(buffer, 0, data.Bytes, data.Length, numIterations);
                     data.Length += encoder.ByteBlockCount * numIterations;
@@ -241,10 +241,10 @@ namespace Lucene.Net.Util
                     Debug.Assert(bitsPerException > 0);
                     data.WriteByte((byte)(sbyte)numExceptions);
                     data.WriteByte((byte)(sbyte)bitsPerException);
-                    PackedInts.IEncoder encoder = PackedInts.GetEncoder(PackedInts.Format.PACKED, PackedInts.VERSION_CURRENT, bitsPerException);
+                    PackedInt32s.IEncoder encoder = PackedInt32s.GetEncoder(PackedInt32s.Format.PACKED, PackedInt32s.VERSION_CURRENT, bitsPerException);
                     int numIterations = (numExceptions + encoder.ByteValueCount - 1) / encoder.ByteValueCount;
                     encoder.Encode(exceptions, 0, data.Bytes, data.Length, numIterations);
-                    data.Length += (int)PackedInts.Format.PACKED.ByteCount(PackedInts.VERSION_CURRENT, numExceptions, bitsPerException);
+                    data.Length += (int)PackedInt32s.Format.PACKED.ByteCount(PackedInt32s.VERSION_CURRENT, numExceptions, bitsPerException);
                     for (int i = 0; i < numExceptions; ++i)
                     {
                         data.WriteByte((byte)(sbyte)exceptionIndices[i]);
@@ -328,7 +328,7 @@ namespace Lucene.Net.Util
                 var dataArr = Arrays.CopyOf(data.Bytes, data.Length + MAX_BYTE_BLOCK_COUNT);
 
                 int indexSize = (numBlocks - 1) / indexInterval + 1;
-                MonotonicAppendingLongBuffer docIDs, offsets;
+                MonotonicAppendingInt64Buffer docIDs, offsets;
                 if (indexSize <= 1)
                 {
                     docIDs = offsets = SINGLE_ZERO_BUFFER;
@@ -337,8 +337,8 @@ namespace Lucene.Net.Util
                 {
                     const int pageSize = 128;
                     int initialPageCount = (indexSize + pageSize - 1) / pageSize;
-                    docIDs = new MonotonicAppendingLongBuffer(initialPageCount, pageSize, PackedInts.COMPACT);
-                    offsets = new MonotonicAppendingLongBuffer(initialPageCount, pageSize, PackedInts.COMPACT);
+                    docIDs = new MonotonicAppendingInt64Buffer(initialPageCount, pageSize, PackedInt32s.COMPACT);
+                    offsets = new MonotonicAppendingInt64Buffer(initialPageCount, pageSize, PackedInt32s.COMPACT);
                     // Now build the index
                     Iterator it = new Iterator(dataArr, cardinality, int.MaxValue, SINGLE_ZERO_BUFFER, SINGLE_ZERO_BUFFER);
                     for (int k = 0; k < indexSize; ++k)
@@ -365,10 +365,10 @@ namespace Lucene.Net.Util
         }
 
         internal readonly byte[] data;
-        internal readonly MonotonicAppendingLongBuffer docIDs, offsets; // for the index
+        internal readonly MonotonicAppendingInt64Buffer docIDs, offsets; // for the index
         internal readonly int cardinality, indexInterval;
 
-        internal PForDeltaDocIdSet(byte[] data, int cardinality, int indexInterval, MonotonicAppendingLongBuffer docIDs, MonotonicAppendingLongBuffer offsets)
+        internal PForDeltaDocIdSet(byte[] data, int cardinality, int indexInterval, MonotonicAppendingInt64Buffer docIDs, MonotonicAppendingInt64Buffer offsets)
         {
             this.data = data;
             this.cardinality = cardinality;
@@ -402,7 +402,7 @@ namespace Lucene.Net.Util
             // index
             internal readonly int indexInterval;
 
-            internal readonly MonotonicAppendingLongBuffer docIDs, offsets;
+            internal readonly MonotonicAppendingInt64Buffer docIDs, offsets;
 
             internal readonly int cardinality;
             internal readonly byte[] data;
@@ -416,7 +416,7 @@ namespace Lucene.Net.Util
             internal int blockIdx;
             internal int docID;
 
-            internal Iterator(byte[] data, int cardinality, int indexInterval, MonotonicAppendingLongBuffer docIDs, MonotonicAppendingLongBuffer offsets)
+            internal Iterator(byte[] data, int cardinality, int indexInterval, MonotonicAppendingInt64Buffer docIDs, MonotonicAppendingInt64Buffer offsets)
             {
                 this.data = data;
                 this.cardinality = cardinality;
@@ -456,7 +456,7 @@ namespace Lucene.Net.Util
                     int bitsPerException = data[offset++];
                     int numIterations = (numExceptions + DECODERS[bitsPerException].ByteValueCount - 1) / DECODERS[bitsPerException].ByteValueCount;
                     DECODERS[bitsPerException].Decode(data, offset, nextExceptions, 0, numIterations);
-                    offset += (int)PackedInts.Format.PACKED.ByteCount(PackedInts.VERSION_CURRENT, numExceptions, bitsPerException);
+                    offset += (int)PackedInt32s.Format.PACKED.ByteCount(PackedInt32s.VERSION_CURRENT, numExceptions, bitsPerException);
                     for (int i = 0; i < numExceptions; ++i)
                     {
                         nextDocs[data[offset++]] |= nextExceptions[i] << bitsPerValue;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Util/Packed/AbstractAppendingLongBuffer.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Packed/AbstractAppendingLongBuffer.cs b/src/Lucene.Net.Core/Util/Packed/AbstractAppendingLongBuffer.cs
index 0ea749c..1916751 100644
--- a/src/Lucene.Net.Core/Util/Packed/AbstractAppendingLongBuffer.cs
+++ b/src/Lucene.Net.Core/Util/Packed/AbstractAppendingLongBuffer.cs
@@ -21,8 +21,11 @@ namespace Lucene.Net.Util.Packed
      */
 
     /// <summary>
-    /// Common functionality shared by <seealso cref="AppendingDeltaPackedLongBuffer"/> and <seealso cref="MonotonicAppendingLongBuffer"/>. </summary>
-    public abstract class AbstractAppendingLongBuffer : LongValues // LUCENENET NOTE: made public rather than internal because has public subclasses
+    /// Common functionality shared by <seealso cref="AppendingDeltaPackedInt64Buffer"/> and <seealso cref="MonotonicAppendingInt64Buffer"/>. 
+    /// <para/>
+    /// NOTE: This was AbstractAppendingLongBuffer in Lucene
+    /// </summary>
+    public abstract class AbstractAppendingInt64Buffer : Int64Values // LUCENENET NOTE: made public rather than internal because has public subclasses
     {
         internal const int MIN_PAGE_SIZE = 64;
 
@@ -31,18 +34,18 @@ namespace Lucene.Net.Util.Packed
         internal static readonly int MAX_PAGE_SIZE = 1 << 20;
 
         internal readonly int pageShift, pageMask;
-        internal PackedInts.Reader[] values;
+        internal PackedInt32s.Reader[] values;
         private long valuesBytes;
         internal int valuesOff;
         internal long[] pending;
         internal int pendingOff;
         internal float acceptableOverheadRatio;
 
-        internal AbstractAppendingLongBuffer(int initialBlockCount, int pageSize, float acceptableOverheadRatio)
+        internal AbstractAppendingInt64Buffer(int initialBlockCount, int pageSize, float acceptableOverheadRatio)
         {
-            values = new PackedInts.Reader[initialBlockCount];
+            values = new PackedInt32s.Reader[initialBlockCount];
             pending = new long[pageSize];
-            pageShift = PackedInts.CheckBlockSize(pageSize, MIN_PAGE_SIZE, MAX_PAGE_SIZE);
+            pageShift = PackedInt32s.CheckBlockSize(pageSize, MIN_PAGE_SIZE, MAX_PAGE_SIZE);
             pageMask = pageSize - 1;
             valuesOff = 0;
             pendingOff = 0;
@@ -102,7 +105,7 @@ namespace Lucene.Net.Util.Packed
 
         internal virtual void Grow(int newBlockCount)
         {
-            Array.Resize<PackedInts.Reader>(ref values, newBlockCount);
+            Array.Resize<PackedInt32s.Reader>(ref values, newBlockCount);
         }
 
         internal abstract void PackPendingValues();
@@ -145,13 +148,13 @@ namespace Lucene.Net.Util.Packed
 
         public sealed class Iterator
         {
-            private readonly AbstractAppendingLongBuffer outerInstance;
+            private readonly AbstractAppendingInt64Buffer outerInstance;
 
             internal long[] currentValues;
             internal int vOff, pOff;
             internal int currentCount; // number of entries of the current page
 
-            internal Iterator(AbstractAppendingLongBuffer outerInstance)
+            internal Iterator(AbstractAppendingInt64Buffer outerInstance)
             {
                 this.outerInstance = outerInstance;
                 vOff = pOff = 0;


[13/53] [abbrv] lucenenet git commit: Lucene.Net.Core: Renamed all type-derived properties and methods from Short, Int, Long, and Float to match CLR types Int16, Int32, Int64, and Single, respectively.

Posted by ni...@apache.org.
Lucene.Net.Core: Renamed all type-derived properties and methods from Short, Int, Long, and Float to match CLR types Int16, Int32, Int64, and Single, respectively.


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

Branch: refs/heads/api-work
Commit: f7432173e9255f67d1aea4597c13713d4ac43a15
Parents: a3e54be
Author: Shad Storhaug <sh...@shadstorhaug.com>
Authored: Tue Feb 7 13:07:03 2017 +0700
Committer: Shad Storhaug <sh...@shadstorhaug.com>
Committed: Wed Feb 8 21:08:20 2017 +0700

----------------------------------------------------------------------
 .../Analysis/Hunspell/Dictionary.cs             |  12 +-
 .../Analysis/Hunspell/Stemmer.cs                |  28 +--
 .../Analysis/Payloads/IntegerEncoder.cs         |   2 +-
 .../Analysis/Payloads/PayloadHelper.cs          |   4 +-
 .../Analysis/Synonym/SynonymFilter.cs           |   4 +-
 .../Analysis/Synonym/SynonymMap.cs              |   4 +-
 .../Egothor.Stemmer/MultiTrie.cs                |   8 +-
 .../Egothor.Stemmer/Row.cs                      |  20 +-
 .../Egothor.Stemmer/Trie.cs                     |  12 +-
 .../Appending/AppendingTermsReader.cs           |   2 +-
 .../BlockTerms/BlockTermsReader.cs              |  48 ++--
 .../BlockTerms/BlockTermsWriter.cs              |  38 ++--
 .../BlockTerms/FixedGapTermsIndexReader.cs      |  22 +-
 .../BlockTerms/FixedGapTermsIndexWriter.cs      |  18 +-
 .../BlockTerms/VariableGapTermsIndexReader.cs   |  14 +-
 .../BlockTerms/VariableGapTermsIndexWriter.cs   |  10 +-
 .../Bloom/BloomFilteringPostingsFormat.cs       |   8 +-
 src/Lucene.Net.Codecs/Bloom/FuzzySet.cs         |  16 +-
 .../DiskDV/DiskDocValuesProducer.cs             |   4 +-
 .../IntBlock/FixedIntBlockIndexInput.cs         |  10 +-
 .../IntBlock/FixedIntBlockIndexOutput.cs        |  12 +-
 .../IntBlock/VariableIntBlockIndexInput.cs      |  10 +-
 .../IntBlock/VariableIntBlockIndexOutput.cs     |  12 +-
 .../Memory/DirectDocValuesConsumer.cs           |  46 ++--
 .../Memory/DirectDocValuesProducer.cs           |  30 +--
 .../Memory/FSTOrdTermsReader.cs                 |  36 +--
 .../Memory/FSTOrdTermsWriter.cs                 |  44 ++--
 src/Lucene.Net.Codecs/Memory/FSTTermOutputs.cs  |  20 +-
 src/Lucene.Net.Codecs/Memory/FSTTermsReader.cs  |  16 +-
 src/Lucene.Net.Codecs/Memory/FSTTermsWriter.cs  |  18 +-
 .../Memory/MemoryDocValuesConsumer.cs           |  68 +++---
 .../Memory/MemoryDocValuesProducer.cs           |  48 ++--
 .../Memory/MemoryPostingsFormat.cs              |  98 ++++-----
 .../Pulsing/PulsingPostingsReader.cs            |  44 ++--
 .../Pulsing/PulsingPostingsWriter.cs            |  40 ++--
 src/Lucene.Net.Codecs/Sep/SepPostingsReader.cs  |  14 +-
 src/Lucene.Net.Codecs/Sep/SepPostingsWriter.cs  |  14 +-
 src/Lucene.Net.Codecs/Sep/SepSkipListReader.cs  |   8 +-
 src/Lucene.Net.Codecs/Sep/SepSkipListWriter.cs  |  10 +-
 .../SimpleText/SimpleTextFieldsReader.cs        |  22 +-
 .../SimpleText/SimpleTextLiveDocsFormat.cs      |   2 +-
 .../SimpleText/SimpleTextStoredFieldsReader.cs  |   2 +-
 .../SimpleText/SimpleTextTermVectorsReader.cs   |   2 +-
 .../Analysis/NumericTokenStream.cs              |  29 ++-
 .../Codecs/BlockTreeTermsReader.cs              | 104 ++++-----
 .../Codecs/BlockTreeTermsWriter.cs              |  80 +++----
 src/Lucene.Net.Core/Codecs/CodecUtil.cs         |  22 +-
 .../CompressingStoredFieldsIndexReader.cs       |  16 +-
 .../CompressingStoredFieldsIndexWriter.cs       |  20 +-
 .../CompressingStoredFieldsReader.cs            |  58 ++---
 .../CompressingStoredFieldsWriter.cs            |  37 ++--
 .../Compressing/CompressingTermVectorsReader.cs |  33 +--
 .../Compressing/CompressingTermVectorsWriter.cs |  40 ++--
 .../Codecs/Compressing/CompressionMode.cs       |   6 +-
 src/Lucene.Net.Core/Codecs/Compressing/LZ4.cs   |  28 ++-
 .../Codecs/Lucene3x/Lucene3xFieldInfosReader.cs |   4 +-
 .../Lucene3x/Lucene3xSegmentInfoReader.cs       |  20 +-
 .../Codecs/Lucene3x/Lucene3xSkipListReader.cs   |  10 +-
 .../Lucene3x/Lucene3xStoredFieldsReader.cs      |  26 +--
 .../Lucene3x/Lucene3xTermVectorsReader.cs       |  26 +--
 .../Codecs/Lucene3x/SegmentTermDocs.cs          |  10 +-
 .../Codecs/Lucene3x/SegmentTermEnum.cs          |  20 +-
 .../Codecs/Lucene3x/SegmentTermPositions.cs     |   4 +-
 .../Codecs/Lucene3x/TermBuffer.cs               |   6 +-
 .../Codecs/Lucene3x/TermInfosReaderIndex.cs     |  30 +--
 .../Codecs/Lucene40/BitVector.cs                |  32 +--
 .../Codecs/Lucene40/Lucene40DocValuesReader.cs  |  79 ++++---
 .../Codecs/Lucene40/Lucene40FieldInfosReader.cs |   4 +-
 .../Codecs/Lucene40/Lucene40PostingsReader.cs   |  52 ++---
 .../Lucene40/Lucene40SegmentInfoReader.cs       |   2 +-
 .../Lucene40/Lucene40SegmentInfoWriter.cs       |   2 +-
 .../Codecs/Lucene40/Lucene40SkipListReader.cs   |  12 +-
 .../Lucene40/Lucene40StoredFieldsReader.cs      |  26 +--
 .../Lucene40/Lucene40StoredFieldsWriter.cs      |  18 +-
 .../Lucene40/Lucene40TermVectorsReader.cs       |  36 +--
 .../Lucene40/Lucene40TermVectorsWriter.cs       |  48 ++--
 src/Lucene.Net.Core/Codecs/Lucene41/ForUtil.cs  |  14 +-
 .../Codecs/Lucene41/Lucene41PostingsReader.cs   |  58 ++---
 .../Codecs/Lucene41/Lucene41PostingsWriter.cs   |  32 +--
 .../Codecs/Lucene41/Lucene41SkipReader.cs       |  12 +-
 .../Codecs/Lucene41/Lucene41SkipWriter.cs       |  12 +-
 .../Lucene42/Lucene42DocValuesProducer.cs       |  62 +++---
 .../Codecs/Lucene42/Lucene42FieldInfosReader.cs |   4 +-
 .../Codecs/Lucene42/Lucene42NormsConsumer.cs    |  28 +--
 .../Lucene45/Lucene45DocValuesConsumer.cs       |  96 ++++----
 .../Lucene45/Lucene45DocValuesProducer.cs       |  96 ++++----
 .../Codecs/Lucene46/Lucene46FieldInfosReader.cs |   6 +-
 .../Codecs/Lucene46/Lucene46FieldInfosWriter.cs |   6 +-
 .../Lucene46/Lucene46SegmentInfoReader.cs       |   2 +-
 .../Lucene46/Lucene46SegmentInfoWriter.cs       |   2 +-
 .../Codecs/MultiLevelSkipListReader.cs          |   6 +-
 .../Codecs/MultiLevelSkipListWriter.cs          |   4 +-
 src/Lucene.Net.Core/Codecs/TermVectorsWriter.cs |   8 +-
 src/Lucene.Net.Core/Document/Field.cs           |   6 +-
 .../Document/FloatDocValuesField.cs             |   4 +-
 src/Lucene.Net.Core/Index/AutomatonTermsEnum.cs |   2 +-
 src/Lucene.Net.Core/Index/CheckIndex.cs         |   2 +-
 src/Lucene.Net.Core/Index/DocTermOrds.cs        |  18 +-
 .../Index/DocumentsWriterPerThread.cs           |   4 +-
 .../Index/FreqProxTermsWriterPerField.cs        |  30 +--
 .../Index/PersistentSnapshotDeletionPolicy.cs   |  12 +-
 src/Lucene.Net.Core/Index/PrefixCodedTerms.cs   |  10 +-
 src/Lucene.Net.Core/Index/ReadersAndUpdates.cs  |   7 +-
 src/Lucene.Net.Core/Index/SegmentInfos.cs       |  50 ++---
 .../Index/TermVectorsConsumerPerField.cs        |  10 +-
 src/Lucene.Net.Core/Index/TermsHashPerField.cs  |  21 +-
 src/Lucene.Net.Core/Search/BooleanQuery.cs      |   2 +-
 .../Search/DisjunctionMaxQuery.cs               |   4 +-
 src/Lucene.Net.Core/Search/FieldCache.cs        | 155 ++++++++-----
 src/Lucene.Net.Core/Search/FieldCacheImpl.cs    |  72 ++++--
 .../Search/FieldCacheRangeFilter.cs             |  69 +++---
 src/Lucene.Net.Core/Search/FieldComparator.cs   |   8 +-
 src/Lucene.Net.Core/Search/FuzzyQuery.cs        |   4 +-
 src/Lucene.Net.Core/Search/MatchAllDocsQuery.cs |   2 +-
 src/Lucene.Net.Core/Search/MultiPhraseQuery.cs  |   2 +-
 src/Lucene.Net.Core/Search/MultiTermQuery.cs    |   4 +-
 src/Lucene.Net.Core/Search/NGramPhraseQuery.cs  |   2 +-
 .../Search/NumericRangeFilter.cs                |  42 ++--
 src/Lucene.Net.Core/Search/NumericRangeQuery.cs |  50 +++--
 src/Lucene.Net.Core/Search/PhraseQuery.cs       |   2 +-
 src/Lucene.Net.Core/Search/Query.cs             |   4 +-
 .../Search/Similarities/BM25Similarity.cs       |   4 +-
 .../Search/Similarities/DefaultSimilarity.cs    |   4 +-
 .../Search/Similarities/SimilarityBase.cs       |   4 +-
 .../Search/Spans/FieldMaskingSpanQuery.cs       |   2 +-
 .../Search/Spans/SpanFirstQuery.cs              |   2 +-
 .../Search/Spans/SpanNearPayloadCheckQuery.cs   |   2 +-
 .../Search/Spans/SpanNearQuery.cs               |   2 +-
 src/Lucene.Net.Core/Search/Spans/SpanOrQuery.cs |   2 +-
 .../Search/Spans/SpanPayloadCheckQuery.cs       |   2 +-
 .../Search/Spans/SpanPositionRangeQuery.cs      |   2 +-
 src/Lucene.Net.Core/Search/TermQuery.cs         |   2 +-
 src/Lucene.Net.Core/Store/BufferedIndexInput.cs |  23 +-
 src/Lucene.Net.Core/Store/ByteArrayDataInput.cs |  24 +-
 .../Store/ByteBufferIndexInput.cs               |  27 ++-
 .../Store/CompoundFileDirectory.cs              |  12 +-
 src/Lucene.Net.Core/Store/CompoundFileWriter.cs |   6 +-
 src/Lucene.Net.Core/Store/DataInput.cs          |  42 ++--
 src/Lucene.Net.Core/Store/DataOutput.cs         |  46 ++--
 src/Lucene.Net.Core/Support/ByteBuffer.cs       | 218 +++++++++++++++----
 src/Lucene.Net.Core/Support/DataInputStream.cs  |  33 ++-
 src/Lucene.Net.Core/Support/DataOutputStream.cs |  24 +-
 src/Lucene.Net.Core/Support/IDataInput.cs       |  26 ++-
 src/Lucene.Net.Core/Support/IDataOutput.cs      |  24 +-
 src/Lucene.Net.Core/Support/LongBuffer.cs       |   2 +-
 .../Support/MemoryMappedFileByteBuffer.cs       |  86 ++++++--
 src/Lucene.Net.Core/Support/Number.cs           |  34 ++-
 src/Lucene.Net.Core/Util/ArrayUtil.cs           |  24 +-
 .../Util/Automaton/BasicOperations.cs           |   2 +-
 .../Util/Automaton/SortedIntSet.cs              |   6 +-
 .../Util/Automaton/SpecialOperations.cs         |   2 +-
 src/Lucene.Net.Core/Util/Fst/Builder.cs         |  18 +-
 .../Util/Fst/ByteSequenceOutputs.cs             |   4 +-
 src/Lucene.Net.Core/Util/Fst/BytesStore.cs      |   6 +-
 .../Util/Fst/CharSequenceOutputs.cs             |   8 +-
 src/Lucene.Net.Core/Util/Fst/FST.cs             |  80 +++----
 .../Util/Fst/IntSequenceOutputs.cs              |  18 +-
 src/Lucene.Net.Core/Util/Fst/IntsRefFSTEnum.cs  |   8 +-
 .../Util/Fst/PositiveIntOutputs.cs              |   4 +-
 src/Lucene.Net.Core/Util/Fst/Util.cs            |  36 +--
 src/Lucene.Net.Core/Util/IntBlockPool.cs        |  84 ++++---
 src/Lucene.Net.Core/Util/IntsRef.cs             |  29 ++-
 src/Lucene.Net.Core/Util/LongsRef.cs            |  21 +-
 .../Util/Mutable/MutableValueFloat.cs           |   2 +-
 src/Lucene.Net.Core/Util/NumericUtils.cs        | 134 ++++++++----
 src/Lucene.Net.Core/Util/OfflineSorter.cs       |   6 +-
 .../Util/Packed/AbstractBlockPackedWriter.cs    |   7 +-
 .../Util/Packed/BlockPackedReader.cs            |   2 +-
 .../Util/Packed/BlockPackedReaderIterator.cs    |  11 +-
 .../Util/Packed/BlockPackedWriter.cs            |   2 +-
 .../Util/Packed/BulkOperation.cs                |  15 +-
 .../Util/Packed/BulkOperationPacked.cs          |  10 +-
 .../Packed/BulkOperationPackedSingleBlock.cs    |  23 +-
 src/Lucene.Net.Core/Util/Packed/Direct16.cs     |   2 +-
 src/Lucene.Net.Core/Util/Packed/Direct32.cs     |   2 +-
 src/Lucene.Net.Core/Util/Packed/Direct64.cs     |   2 +-
 .../Packed/DirectPacked64SingleBlockReader.cs   |   2 +-
 .../Util/Packed/DirectPackedReader.cs           |  16 +-
 .../Util/Packed/EliasFanoDecoder.cs             |  20 +-
 .../Util/Packed/EliasFanoEncoder.cs             |  17 +-
 .../Util/Packed/MonotonicBlockPackedReader.cs   |   6 +-
 .../Util/Packed/MonotonicBlockPackedWriter.cs   |   8 +-
 .../Util/Packed/Packed16ThreeBlocks.cs          |   2 +-
 src/Lucene.Net.Core/Util/Packed/Packed64.cs     |  26 +--
 .../Util/Packed/Packed64SingleBlock.cs          |  10 +-
 .../Util/Packed/PackedDataInput.cs              |   4 +-
 .../Util/Packed/PackedDataOutput.cs             |   4 +-
 src/Lucene.Net.Core/Util/Packed/PackedInts.cs   |  60 +++--
 .../Util/Packed/PackedReaderIterator.cs         |  10 +-
 .../Util/RecyclingIntBlockAllocator.cs          |  10 +-
 src/Lucene.Net.Core/Util/SmallFloat.cs          |  35 ++-
 src/Lucene.Net.Core/Util/ToStringUtils.cs       |   5 +-
 src/Lucene.Net.Core/Util/UnicodeUtil.cs         |   6 +-
 src/Lucene.Net.Core/Util/WAH8DocIdSet.cs        |   8 +-
 src/Lucene.Net.Facet/FacetsConfig.cs            |  12 +-
 src/Lucene.Net.Facet/Range/DoubleRange.cs       |   2 +-
 .../Range/DoubleRangeFacetCounts.cs             |   4 +-
 .../Taxonomy/CachedOrdinalsReader.cs            |   4 +-
 .../Directory/DirectoryTaxonomyWriter.cs        |  12 +-
 .../Taxonomy/DocValuesOrdinalsReader.cs         |   8 +-
 .../Taxonomy/FloatAssociationFacetField.cs      |   4 +-
 .../Taxonomy/TaxonomyFacetCounts.cs             |   2 +-
 .../TaxonomyFacetSumFloatAssociations.cs        |   2 +-
 .../Taxonomy/TaxonomyFacetSumValueSource.cs     |   2 +-
 .../VectorHighlight/FieldPhraseList.cs          |   2 +-
 .../MemoryIndex.MemoryIndexReader.cs            |   8 +-
 src/Lucene.Net.Memory/MemoryIndex.cs            |  10 +-
 .../Index/Sorter/SortingAtomicReader.cs         |  20 +-
 src/Lucene.Net.Misc/Util/Fst/ListOfOutputs.cs   |   6 +-
 .../Util/Fst/UpToTwoPositiveIntOutputs.cs       |  10 +-
 src/Lucene.Net.Queries/BoostingQuery.cs         |   4 +-
 src/Lucene.Net.Queries/CommonTermsQuery.cs      |  16 +-
 src/Lucene.Net.Queries/CustomScoreQuery.cs      |   2 +-
 src/Lucene.Net.Queries/Function/BoostedQuery.cs |   2 +-
 .../Function/FunctionQuery.cs                   |   2 +-
 .../Function/ValueSources/ByteFieldSource.cs    |   2 +-
 .../Function/ValueSources/ConstValueSource.cs   |   2 +-
 .../ValueSources/DoubleConstValueSource.cs      |   2 +-
 .../Function/ValueSources/EnumFieldSource.cs    |   4 +-
 .../Function/ValueSources/FloatFieldSource.cs   |   2 +-
 .../Function/ValueSources/IntFieldSource.cs     |   4 +-
 .../ValueSources/LinearFloatFunction.cs         |   4 +-
 .../Function/ValueSources/LongFieldSource.cs    |   4 +-
 .../ValueSources/RangeMapFloatFunction.cs       |   4 +-
 .../ValueSources/ReciprocalFloatFunction.cs     |   4 +-
 .../Function/ValueSources/ScaleFloatFunction.cs |   6 +-
 .../Function/ValueSources/ShortFieldSource.cs   |   2 +-
 src/Lucene.Net.Queries/Mlt/MoreLikeThisQuery.cs |   4 +-
 .../Classic/QueryParserBase.cs                  |   2 +-
 .../Standard/Builders/FuzzyQueryNodeBuilder.cs  |   2 +-
 .../Builders/NumericRangeQueryNodeBuilder.cs    |   6 +-
 .../Xml/Builders/NumericRangeFilterBuilder.cs   |   6 +-
 .../Xml/Builders/NumericRangeQueryBuilder.cs    |   6 +-
 .../Queries/FuzzyLikeThisQuery.cs               |   6 +-
 .../Queries/SlowFuzzyQuery.cs                   |   6 +-
 .../Queries/SlowFuzzyTermsEnum.cs               |   2 +-
 .../Util/DistanceToShapeValueSource.cs          |   2 +-
 .../Spell/JaroWinklerDistance.cs                |   4 +-
 .../Spell/LuceneLevenshteinDistance.cs          |   8 +-
 .../Suggest/Analyzing/AnalyzingSuggester.cs     |  34 +--
 .../Suggest/Analyzing/FSTUtil.cs                |   8 +-
 .../Suggest/Analyzing/FreeTextSuggester.cs      |  20 +-
 .../Suggest/Analyzing/FuzzySuggester.cs         |   6 +-
 .../Suggest/Fst/FSTCompletionBuilder.cs         |   2 +-
 .../Suggest/Fst/FSTCompletionLookup.cs          |   8 +-
 .../Suggest/Fst/WFSTCompletionLookup.cs         |  10 +-
 .../Suggest/Jaspell/JaspellLookup.cs            |   8 +-
 .../Suggest/SortedInputIterator.cs              |  16 +-
 .../Suggest/SortedTermFreqIteratorWrapper.cs    |   4 +-
 src/Lucene.Net.Suggest/Suggest/Tst/TSTLookup.cs |   8 +-
 .../MockFixedIntBlockPostingsFormat.cs          |   4 +-
 .../MockVariableIntBlockPostingsFormat.cs       |  10 +-
 .../Codecs/MockSep/MockSingleIntIndexInput.cs   |   6 +-
 .../Codecs/MockSep/MockSingleIntIndexOutput.cs  |   6 +-
 .../lucene3x/PreFlexRWFieldInfosReader.cs       |   6 +-
 .../lucene3x/PreFlexRWFieldInfosWriter.cs       |   6 +-
 .../Codecs/lucene3x/PreFlexRWFieldsWriter.cs    |  16 +-
 .../Codecs/lucene3x/PreFlexRWSkipListWriter.cs  |  12 +-
 .../lucene3x/PreFlexRWStoredFieldsWriter.cs     |  20 +-
 .../lucene3x/PreFlexRWTermVectorsWriter.cs      |  36 +--
 .../Codecs/lucene3x/TermInfosWriter.cs          |  28 +--
 .../Codecs/lucene40/Lucene40DocValuesWriter.cs  |  32 +--
 .../Codecs/lucene40/Lucene40FieldInfosWriter.cs |   4 +-
 .../Codecs/lucene40/Lucene40PostingsWriter.cs   |  34 +--
 .../Codecs/lucene40/Lucene40SkipListWriter.cs   |  14 +-
 .../lucene42/Lucene42DocValuesConsumer.cs       |  52 ++---
 .../Codecs/lucene42/Lucene42FieldInfosWriter.cs |   4 +-
 .../Codecs/ramonly/RAMOnlyPostingsFormat.cs     |   4 +-
 .../Index/BaseDocValuesFormatTestCase.cs        |   2 +-
 .../Index/BaseStoredFieldsFormatTestCase.cs     |   4 +-
 .../Store/MockIndexInputWrapper.cs              |  35 ++-
 .../Util/automaton/AutomatonTestUtil.cs         |   2 +-
 .../Util/fst/FSTTester.cs                       |  24 +-
 .../Analysis/Core/TestTypeTokenFilterFactory.cs |   4 +-
 .../Analysis/Hunspell/TestDictionary.cs         |  10 +-
 .../Range/TestRangeFacetCounts.cs               |  18 +-
 .../AllGroupHeadsCollectorTest.cs               |   2 +-
 src/Lucene.Net.Tests.Grouping/TestGrouping.cs   |   4 +-
 .../Highlight/HighlighterTest.cs                |   2 +-
 src/Lucene.Net.Tests.Join/TestBlockJoin.cs      |  16 +-
 .../Index/Sorter/SorterTestBase.cs              |   4 +-
 .../Util/Fst/TestFSTsMisc.cs                    |  16 +-
 .../TestCustomScoreQuery.cs                     |   2 +-
 .../Suggest/Analyzing/FuzzySuggesterTest.cs     |   8 +-
 .../core/Analysis/TestNumericTokenStream.cs     |   8 +-
 src/Lucene.Net.Tests/core/Document/TestField.cs |   2 +-
 .../core/Index/Test2BBinaryDocValues.cs         |   4 +-
 .../core/Index/TestAllFilesHaveCodecHeader.cs   |   2 +-
 .../core/Index/TestBackwardsCompatibility.cs    |  14 +-
 .../core/Index/TestBackwardsCompatibility3x.cs  |  14 +-
 .../core/Index/TestByteSlices.cs                |   8 +-
 .../core/Index/TestCompoundFile.cs              |  18 +-
 .../core/Index/TestCustomNorms.cs               |   4 +-
 .../core/Index/TestDirectoryReader.cs           |   4 +-
 .../core/Index/TestDocTermOrds.cs               |   2 +-
 .../core/Index/TestDocValuesIndexing.cs         |   4 +-
 .../core/Index/TestDocValuesWithThreads.cs      |  10 +-
 .../core/Index/TestIndexInput.cs                |  40 ++--
 .../core/Index/TestIntBlockPool.cs              |  12 +-
 .../core/Index/TestPerSegmentDeletes.cs         |   2 +-
 .../core/Index/TestPostingsOffsets.cs           |   2 +-
 .../core/Index/TestTermsEnum.cs                 |   2 +-
 .../core/Search/JustCompileSearch.cs            |   5 +-
 .../core/Search/TestCachingWrapperFilter.cs     |   4 +-
 .../core/Search/TestDocValuesScoring.cs         |   2 +-
 .../core/Search/TestFieldCache.cs               |  60 ++---
 .../core/Search/TestFieldCacheRangeFilter.cs    | 156 ++++++-------
 .../Search/TestMultiValuedNumericRangeQuery.cs  |   2 +-
 .../core/Search/TestNumericRangeQuery32.cs      | 100 ++++-----
 .../core/Search/TestNumericRangeQuery64.cs      |  86 ++++----
 .../core/Search/TestQueryRescorer.cs            |   2 +-
 src/Lucene.Net.Tests/core/Search/TestSort.cs    |  20 +-
 .../core/Search/TestSortRandom.cs               |   2 +-
 .../core/Store/TestFileSwitchDirectory.cs       |   2 +-
 .../core/Store/TestMultiMMap.cs                 |  38 ++--
 .../core/Store/TestNRTCachingDirectory.cs       |   2 +-
 .../core/Support/TestByteBuffer.cs              |  54 ++---
 .../core/Support/TestLongBuffer.cs              |   8 +-
 .../Util/Automaton/TestSpecialOperations.cs     |   4 +-
 .../core/Util/Fst/TestBytesStore.cs             |   4 +-
 src/Lucene.Net.Tests/core/Util/Fst/TestFSTs.cs  |  74 +++----
 .../core/Util/Packed/TestPackedInts.cs          |  28 +--
 src/Lucene.Net.Tests/core/Util/TestArrayUtil.cs |  18 +-
 src/Lucene.Net.Tests/core/Util/TestBroadWord.cs |   6 +-
 .../core/Util/TestFieldCacheSanityChecker.cs    |   6 +-
 src/Lucene.Net.Tests/core/Util/TestIntsRef.cs   |   4 +-
 .../core/Util/TestNumericUtils.cs               |  50 ++---
 .../core/Util/TestRecyclingIntBlockAllocator.cs |  16 +-
 .../core/Util/TestSmallFloat.cs                 |  40 ++--
 .../core/Util/TestUnicodeUtil.cs                |   4 +-
 330 files changed, 3393 insertions(+), 2713 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Analysis.Common/Analysis/Hunspell/Dictionary.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Analysis.Common/Analysis/Hunspell/Dictionary.cs b/src/Lucene.Net.Analysis.Common/Analysis/Hunspell/Dictionary.cs
index a5276f7..0fa0f34 100644
--- a/src/Lucene.Net.Analysis.Common/Analysis/Hunspell/Dictionary.cs
+++ b/src/Lucene.Net.Analysis.Common/Analysis/Hunspell/Dictionary.cs
@@ -384,7 +384,7 @@ namespace Lucene.Net.Analysis.Hunspell
                 IntsRef output = new IntsRef(entries.Count);
                 foreach (char? c in entries)
                 {
-                    output.Ints[output.Length++] = c.HasValue ? c.Value : 0;
+                    output.Int32s[output.Length++] = c.HasValue ? c.Value : 0;
                 }
                 builder.Add(scratch, output);
             }
@@ -521,12 +521,12 @@ namespace Lucene.Net.Analysis.Hunspell
                     throw new System.NotSupportedException("Too many unique append flags, please report this to dev@lucene.apache.org");
                 }
 
-                affixWriter.WriteShort((short)flag);
-                affixWriter.WriteShort((short)stripOrd);
+                affixWriter.WriteInt16((short)flag);
+                affixWriter.WriteInt16((short)stripOrd);
                 // encode crossProduct into patternIndex
                 int patternOrd = (int)patternIndex << 1 | (crossProduct ? 1 : 0);
-                affixWriter.WriteShort((short)patternOrd);
-                affixWriter.WriteShort((short)appendFlagsOrd);
+                affixWriter.WriteInt16((short)patternOrd);
+                affixWriter.WriteInt16((short)appendFlagsOrd);
 
                 if (needsInputCleaning)
                 {
@@ -875,7 +875,7 @@ namespace Lucene.Net.Analysis.Hunspell
                             currentOrds = new IntsRef(); // must be this way
                         }
                         currentOrds.Grow(currentOrds.Length + 1);
-                        currentOrds.Ints[currentOrds.Length++] = ord;
+                        currentOrds.Int32s[currentOrds.Length++] = ord;
                     }
                 }
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Analysis.Common/Analysis/Hunspell/Stemmer.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Analysis.Common/Analysis/Hunspell/Stemmer.cs b/src/Lucene.Net.Analysis.Common/Analysis/Hunspell/Stemmer.cs
index 3b2d0d4..2c0d0d7 100644
--- a/src/Lucene.Net.Analysis.Common/Analysis/Hunspell/Stemmer.cs
+++ b/src/Lucene.Net.Analysis.Common/Analysis/Hunspell/Stemmer.cs
@@ -187,18 +187,18 @@ namespace Lucene.Net.Analysis.Hunspell
 
                     for (int j = 0; j < prefixes.Length; j++)
                     {
-                        int prefix = prefixes.Ints[prefixes.Offset + j];
+                        int prefix = prefixes.Int32s[prefixes.Offset + j];
                         if (prefix == previous)
                         {
                             continue;
                         }
                         affixReader.Position = 8 * prefix;
-                        char flag = (char)(affixReader.ReadShort() & 0xffff);
-                        char stripOrd = (char)(affixReader.ReadShort() & 0xffff);
-                        int condition = (char)(affixReader.ReadShort() & 0xffff);
+                        char flag = (char)(affixReader.ReadInt16() & 0xffff);
+                        char stripOrd = (char)(affixReader.ReadInt16() & 0xffff);
+                        int condition = (char)(affixReader.ReadInt16() & 0xffff);
                         bool crossProduct = (condition & 1) == 1;
                         condition = (int)((uint)condition >> 1);
-                        char append = (char)(affixReader.ReadShort() & 0xffff);
+                        char append = (char)(affixReader.ReadInt16() & 0xffff);
 
                         bool compatible;
                         if (recursionDepth == 0)
@@ -256,18 +256,18 @@ namespace Lucene.Net.Analysis.Hunspell
 
                     for (int j = 0; j < suffixes.Length; j++)
                     {
-                        int suffix = suffixes.Ints[suffixes.Offset + j];
+                        int suffix = suffixes.Int32s[suffixes.Offset + j];
                         if (suffix == previous)
                         {
                             continue;
                         }
                         affixReader.Position = 8 * suffix;
-                        char flag = (char)(affixReader.ReadShort() & 0xffff);
-                        char stripOrd = (char)(affixReader.ReadShort() & 0xffff);
-                        int condition = (char)(affixReader.ReadShort() & 0xffff);
+                        char flag = (char)(affixReader.ReadInt16() & 0xffff);
+                        char stripOrd = (char)(affixReader.ReadInt16() & 0xffff);
+                        int condition = (char)(affixReader.ReadInt16() & 0xffff);
                         bool crossProduct = (condition & 1) == 1;
                         condition = (int)((uint)condition >> 1);
-                        char append = (char)(affixReader.ReadShort() & 0xffff);
+                        char append = (char)(affixReader.ReadInt16() & 0xffff);
 
                         bool compatible;
                         if (recursionDepth == 0)
@@ -364,12 +364,12 @@ namespace Lucene.Net.Analysis.Hunspell
         {
             // TODO: just pass this in from before, no need to decode it twice
             affixReader.Position = 8 * affix;
-            char flag = (char)(affixReader.ReadShort() & 0xffff);
+            char flag = (char)(affixReader.ReadInt16() & 0xffff);
             affixReader.SkipBytes(2); // strip
-            int condition = (char)(affixReader.ReadShort() & 0xffff);
+            int condition = (char)(affixReader.ReadInt16() & 0xffff);
             bool crossProduct = (condition & 1) == 1;
             condition = (int)((uint)condition >> 1);
-            char append = (char)(affixReader.ReadShort() & 0xffff);
+            char append = (char)(affixReader.ReadInt16() & 0xffff);
 
             List<CharsRef> stems = new List<CharsRef>();
 
@@ -378,7 +378,7 @@ namespace Lucene.Net.Analysis.Hunspell
             {
                 for (int i = 0; i < forms.Length; i++)
                 {
-                    dictionary.flagLookup.Get(forms.Ints[forms.Offset + i], scratch);
+                    dictionary.flagLookup.Get(forms.Int32s[forms.Offset + i], scratch);
                     char[] wordFlags = Dictionary.DecodeFlags(scratch);
                     if (Dictionary.HasFlag(wordFlags, flag))
                     {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Analysis.Common/Analysis/Payloads/IntegerEncoder.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Analysis.Common/Analysis/Payloads/IntegerEncoder.cs b/src/Lucene.Net.Analysis.Common/Analysis/Payloads/IntegerEncoder.cs
index bb264a3..0a1b731 100644
--- a/src/Lucene.Net.Analysis.Common/Analysis/Payloads/IntegerEncoder.cs
+++ b/src/Lucene.Net.Analysis.Common/Analysis/Payloads/IntegerEncoder.cs
@@ -29,7 +29,7 @@ namespace Lucene.Net.Analysis.Payloads
     {
         public override BytesRef Encode(char[] buffer, int offset, int length)
         {
-            int payload = ArrayUtil.ParseInt(buffer, offset, length); //TODO: improve this so that we don't have to new Strings
+            int payload = ArrayUtil.ParseInt32(buffer, offset, length); //TODO: improve this so that we don't have to new Strings
             byte[] bytes = PayloadHelper.EncodeInt(payload);
             BytesRef result = new BytesRef(bytes);
             return result;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Analysis.Common/Analysis/Payloads/PayloadHelper.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Analysis.Common/Analysis/Payloads/PayloadHelper.cs b/src/Lucene.Net.Analysis.Common/Analysis/Payloads/PayloadHelper.cs
index 1045489..e0dca16 100644
--- a/src/Lucene.Net.Analysis.Common/Analysis/Payloads/PayloadHelper.cs
+++ b/src/Lucene.Net.Analysis.Common/Analysis/Payloads/PayloadHelper.cs
@@ -31,7 +31,7 @@ namespace Lucene.Net.Analysis.Payloads
 
         public static byte[] EncodeFloat(float payload, byte[] data, int offset)
         {
-            return EncodeInt(Number.FloatToIntBits(payload), data, offset);
+            return EncodeInt(Number.SingleToInt32Bits(payload), data, offset);
         }
 
         public static byte[] EncodeInt(int payload)
@@ -67,7 +67,7 @@ namespace Lucene.Net.Analysis.Payloads
         public static float DecodeFloat(byte[] bytes, int offset)
         {
 
-            return Number.IntBitsToFloat(DecodeInt(bytes, offset));
+            return Number.Int32BitsToSingle(DecodeInt(bytes, offset));
         }
 
         public static int DecodeInt(byte[] bytes, int offset)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Analysis.Common/Analysis/Synonym/SynonymFilter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Analysis.Common/Analysis/Synonym/SynonymFilter.cs b/src/Lucene.Net.Analysis.Common/Analysis/Synonym/SynonymFilter.cs
index 52bb61d..647d8ff 100644
--- a/src/Lucene.Net.Analysis.Common/Analysis/Synonym/SynonymFilter.cs
+++ b/src/Lucene.Net.Analysis.Common/Analysis/Synonym/SynonymFilter.cs
@@ -501,13 +501,13 @@ namespace Lucene.Net.Analysis.Synonym
         {
             bytesReader.Reset(bytes.Bytes, bytes.Offset, bytes.Length);
 
-            int code = bytesReader.ReadVInt();
+            int code = bytesReader.ReadVInt32();
             bool keepOrig = (code & 0x1) == 0;
             int count = (int)((uint)code >> 1);
             //System.out.println("  addOutput count=" + count + " keepOrig=" + keepOrig);
             for (int outputIDX = 0; outputIDX < count; outputIDX++)
             {
-                synonyms.Words.Get(bytesReader.ReadVInt(), scratchBytes);
+                synonyms.Words.Get(bytesReader.ReadVInt32(), scratchBytes);
                 //System.out.println("    outIDX=" + outputIDX + " bytes=" + scratchBytes.length);
                 UnicodeUtil.UTF8toUTF16(scratchBytes, scratchChars);
                 int lastStart = scratchChars.Offset;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Analysis.Common/Analysis/Synonym/SynonymMap.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Analysis.Common/Analysis/Synonym/SynonymMap.cs b/src/Lucene.Net.Analysis.Common/Analysis/Synonym/SynonymMap.cs
index 1c37c85..ac487cd 100644
--- a/src/Lucene.Net.Analysis.Common/Analysis/Synonym/SynonymMap.cs
+++ b/src/Lucene.Net.Analysis.Common/Analysis/Synonym/SynonymMap.cs
@@ -303,12 +303,12 @@ namespace Lucene.Net.Analysis.Synonym
                             }
                             dedupSet.Add(ent);
                         }
-                        scratchOutput.WriteVInt(output.ords[i]);
+                        scratchOutput.WriteVInt32(output.ords[i]);
                         count++;
                     }
 
                     int pos = scratchOutput.Position;
-                    scratchOutput.WriteVInt(count << 1 | (output.includeOrig ? 0 : 1));
+                    scratchOutput.WriteVInt32(count << 1 | (output.includeOrig ? 0 : 1));
                     int pos2 = scratchOutput.Position;
                     int vIntLen = pos2 - pos;
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Analysis.Stempel/Egothor.Stemmer/MultiTrie.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Analysis.Stempel/Egothor.Stemmer/MultiTrie.cs b/src/Lucene.Net.Analysis.Stempel/Egothor.Stemmer/MultiTrie.cs
index d8a3282..373bac5 100644
--- a/src/Lucene.Net.Analysis.Stempel/Egothor.Stemmer/MultiTrie.cs
+++ b/src/Lucene.Net.Analysis.Stempel/Egothor.Stemmer/MultiTrie.cs
@@ -83,8 +83,8 @@ namespace Egothor.Stemmer
             : base(false)
         {
             forward = @is.ReadBoolean();
-            BY = @is.ReadInt();
-            for (int i = @is.ReadInt(); i > 0; i--)
+            BY = @is.ReadInt32();
+            for (int i = @is.ReadInt32(); i > 0; i--)
             {
                 m_tries.Add(new Trie(@is));
             }
@@ -148,8 +148,8 @@ namespace Egothor.Stemmer
         public override void Store(IDataOutput os)
         {
             os.WriteBoolean(forward);
-            os.WriteInt(BY);
-            os.WriteInt(m_tries.Count);
+            os.WriteInt32(BY);
+            os.WriteInt32(m_tries.Count);
             foreach (Trie trie in m_tries)
                 trie.Store(os);
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Analysis.Stempel/Egothor.Stemmer/Row.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Analysis.Stempel/Egothor.Stemmer/Row.cs b/src/Lucene.Net.Analysis.Stempel/Egothor.Stemmer/Row.cs
index b2ee5fa..a11dc52 100644
--- a/src/Lucene.Net.Analysis.Stempel/Egothor.Stemmer/Row.cs
+++ b/src/Lucene.Net.Analysis.Stempel/Egothor.Stemmer/Row.cs
@@ -77,14 +77,14 @@ namespace Egothor.Stemmer
         /// <exception cref="IOException">if an I/O error occurs</exception>
         public Row(IDataInput @is)
         {
-            for (int i = @is.ReadInt(); i > 0; i--)
+            for (int i = @is.ReadInt32(); i > 0; i--)
             {
                 char ch = @is.ReadChar();
                 Cell c = new Cell();
-                c.cmd = @is.ReadInt();
-                c.cnt = @is.ReadInt();
-                c.@ref = @is.ReadInt();
-                c.skip = @is.ReadInt();
+                c.cmd = @is.ReadInt32();
+                c.cnt = @is.ReadInt32();
+                c.@ref = @is.ReadInt32();
+                c.skip = @is.ReadInt32();
                 cells[ch] = c;
             }
         }
@@ -247,7 +247,7 @@ namespace Egothor.Stemmer
         /// <exception cref="IOException">if an I/O error occurs</exception>
         public virtual void Store(IDataOutput os)
         {
-            os.WriteInt(cells.Count);
+            os.WriteInt32(cells.Count);
             IEnumerator<char> i = cells.Keys.GetEnumerator();
             for (; i.MoveNext();)
             {
@@ -259,10 +259,10 @@ namespace Egothor.Stemmer
                 }
 
                 os.WriteChar(c);
-                os.WriteInt(e.cmd);
-                os.WriteInt(e.cnt);
-                os.WriteInt(e.@ref);
-                os.WriteInt(e.skip);
+                os.WriteInt32(e.cmd);
+                os.WriteInt32(e.cnt);
+                os.WriteInt32(e.@ref);
+                os.WriteInt32(e.skip);
             }
         }
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Analysis.Stempel/Egothor.Stemmer/Trie.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Analysis.Stempel/Egothor.Stemmer/Trie.cs b/src/Lucene.Net.Analysis.Stempel/Egothor.Stemmer/Trie.cs
index 905f213..da9818f 100644
--- a/src/Lucene.Net.Analysis.Stempel/Egothor.Stemmer/Trie.cs
+++ b/src/Lucene.Net.Analysis.Stempel/Egothor.Stemmer/Trie.cs
@@ -84,12 +84,12 @@ namespace Egothor.Stemmer
         public Trie(IDataInput @is)
         {
             forward = @is.ReadBoolean();
-            root = @is.ReadInt();
-            for (int i = @is.ReadInt(); i > 0; i--)
+            root = @is.ReadInt32();
+            for (int i = @is.ReadInt32(); i > 0; i--)
             {
                 cmds.Add(@is.ReadUTF());
             }
-            for (int i = @is.ReadInt(); i > 0; i--)
+            for (int i = @is.ReadInt32(); i > 0; i--)
             {
                 rows.Add(new Row(@is));
             }
@@ -346,12 +346,12 @@ namespace Egothor.Stemmer
         public virtual void Store(IDataOutput os)
         {
             os.WriteBoolean(forward);
-            os.WriteInt(root);
-            os.WriteInt(cmds.Count);
+            os.WriteInt32(root);
+            os.WriteInt32(cmds.Count);
             foreach (string cmd in cmds)
                 os.WriteUTF(cmd);
 
-            os.WriteInt(rows.Count);
+            os.WriteInt32(rows.Count);
             foreach (Row row in rows)
                 row.Store(os);
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/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
index 1b01fea..ae95ef3 100644
--- a/src/Lucene.Net.Codecs/Appending/AppendingTermsReader.cs
+++ b/src/Lucene.Net.Codecs/Appending/AppendingTermsReader.cs
@@ -56,7 +56,7 @@ namespace Lucene.Net.Codecs.Appending
         protected override void SeekDir(IndexInput input, long dirOffset)
         {
             input.Seek(input.Length - sizeof(long)/8);
-            long offset = input.ReadLong();
+            long offset = input.ReadInt64();
             input.Seek(offset);
         }
     }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/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
index 8a0bf2b..707bef3 100644
--- a/src/Lucene.Net.Codecs/BlockTerms/BlockTermsReader.cs
+++ b/src/Lucene.Net.Codecs/BlockTerms/BlockTermsReader.cs
@@ -116,7 +116,7 @@ namespace Lucene.Net.Codecs.BlockTerms
                 // Read per-field details
                 SeekDir(_input, _dirOffset);
 
-                int numFields = _input.ReadVInt();
+                int numFields = _input.ReadVInt32();
                 if (numFields < 0)
                 {
                     throw new CorruptIndexException(string.Format("Invalid number of fields: {0}, Resource: {1}",
@@ -125,19 +125,19 @@ namespace Lucene.Net.Codecs.BlockTerms
 
                 for (var i = 0; i < numFields; i++)
                 {
-                    var field = _input.ReadVInt();
-                    var numTerms = _input.ReadVLong();
+                    var field = _input.ReadVInt32();
+                    var numTerms = _input.ReadVInt64();
 
                     Debug.Assert(numTerms >= 0);
 
-                    var termsStartPointer = _input.ReadVLong();
+                    var termsStartPointer = _input.ReadVInt64();
                     var fieldInfo = fieldInfos.FieldInfo(field);
                     var sumTotalTermFreq = fieldInfo.IndexOptions == IndexOptions.DOCS_ONLY
                         ? -1
-                        : _input.ReadVLong();
-                    var sumDocFreq = _input.ReadVLong();
-                    var docCount = _input.ReadVInt();
-                    var longsSize = _version >= BlockTermsWriter.VERSION_META_ARRAY ? _input.ReadVInt() : 0;
+                        : _input.ReadVInt64();
+                    var sumDocFreq = _input.ReadVInt64();
+                    var docCount = _input.ReadVInt32();
+                    var longsSize = _version >= BlockTermsWriter.VERSION_META_ARRAY ? _input.ReadVInt32() : 0;
 
                     if (docCount < 0 || docCount > info.DocCount)
                     {
@@ -197,7 +197,7 @@ namespace Lucene.Net.Codecs.BlockTerms
                 BlockTermsWriter.VERSION_CURRENT);
 
             if (version < BlockTermsWriter.VERSION_APPEND_ONLY)
-                _dirOffset = input.ReadLong();
+                _dirOffset = input.ReadInt64();
 
             return version;
         }
@@ -207,12 +207,12 @@ namespace Lucene.Net.Codecs.BlockTerms
             if (_version >= BlockTermsWriter.VERSION_CHECKSUM)
             {
                 input.Seek(input.Length - CodecUtil.FooterLength() - 8);
-                dirOffset = input.ReadLong();
+                dirOffset = input.ReadInt64();
             }
             else if (_version >= BlockTermsWriter.VERSION_APPEND_ONLY)
             {
                 input.Seek(input.Length - 8);
-                dirOffset = input.ReadLong();
+                dirOffset = input.ReadInt64();
             }
             input.Seek(dirOffset);
         }
@@ -531,9 +531,9 @@ namespace Lucene.Net.Codecs.BlockTerms
                                     {
                                         _state.TermBlockOrd++;
                                         _state.Ord++;
-                                        _termSuffixesReader.SkipBytes(_termSuffixesReader.ReadVInt());
+                                        _termSuffixesReader.SkipBytes(_termSuffixesReader.ReadVInt32());
                                     }
-                                    var suffix = _termSuffixesReader.ReadVInt();
+                                    var suffix = _termSuffixesReader.ReadVInt32();
                                     _term.Length = _termBlockPrefix + suffix;
                                     if (_term.Bytes.Length < _term.Length)
                                     {
@@ -558,7 +558,7 @@ namespace Lucene.Net.Codecs.BlockTerms
                                 // block and return NOT_FOUND:
                                 Debug.Assert(_state.TermBlockOrd == 0);
 
-                                var suffix = _termSuffixesReader.ReadVInt();
+                                var suffix = _termSuffixesReader.ReadVInt32();
                                 _term.Length = _termBlockPrefix + suffix;
                                 if (_term.Bytes.Length < _term.Length)
                                 {
@@ -581,7 +581,7 @@ namespace Lucene.Net.Codecs.BlockTerms
                             _state.TermBlockOrd++;
                             _state.Ord++;
 
-                            var suffix = _termSuffixesReader.ReadVInt();
+                            var suffix = _termSuffixesReader.ReadVInt32();
 
                             // We know the prefix matches, so just compare the new suffix:
 
@@ -710,7 +710,7 @@ namespace Lucene.Net.Codecs.BlockTerms
 
                     // TODO: cutover to something better for these ints!  simple64?
 
-                    var suffix = _termSuffixesReader.ReadVInt();
+                    var suffix = _termSuffixesReader.ReadVInt32();
                     //System.out.println("  suffix=" + suffix);
 
                     _term.Length = _termBlockPrefix + suffix;
@@ -852,15 +852,15 @@ namespace Lucene.Net.Codecs.BlockTerms
                     // bsearch w/in the block...
 
                     _state.BlockFilePointer = _input.FilePointer;
-                    _blockTermCount = _input.ReadVInt();
+                    _blockTermCount = _input.ReadVInt32();
 
                     if (_blockTermCount == 0)
                         return false;
 
-                    _termBlockPrefix = _input.ReadVInt();
+                    _termBlockPrefix = _input.ReadVInt32();
 
                     // term suffixes:
-                    int len = _input.ReadVInt();
+                    int len = _input.ReadVInt32();
                     if (_termSuffixes.Length < len)
                     {
                         _termSuffixes = new byte[ArrayUtil.Oversize(len, 1)];
@@ -871,7 +871,7 @@ namespace Lucene.Net.Codecs.BlockTerms
                     _termSuffixesReader.Reset(_termSuffixes, 0, len);
 
                     // docFreq, totalTermFreq
-                    len = _input.ReadVInt();
+                    len = _input.ReadVInt32();
                     if (_docFreqBytes.Length < len)
                         _docFreqBytes = new byte[ArrayUtil.Oversize(len, 1)];
 
@@ -879,7 +879,7 @@ namespace Lucene.Net.Codecs.BlockTerms
                     _freqReader.Reset(_docFreqBytes, 0, len);
 
                     // metadata
-                    len = _input.ReadVInt();
+                    len = _input.ReadVInt32();
                     if (_bytes == null)
                     {
                         _bytes = new byte[ArrayUtil.Oversize(len, 1)];
@@ -929,15 +929,15 @@ namespace Lucene.Net.Codecs.BlockTerms
                             // TODO: if docFreq were bulk decoded we could
                             // just skipN here:
 
-                            _state.DocFreq = _freqReader.ReadVInt();
+                            _state.DocFreq = _freqReader.ReadVInt32();
                             if (_fieldReader._fieldInfo.IndexOptions != IndexOptions.DOCS_ONLY)
                             {
-                                _state.TotalTermFreq = _state.DocFreq + _freqReader.ReadVLong();
+                                _state.TotalTermFreq = _state.DocFreq + _freqReader.ReadVInt64();
                             }
                             // metadata
                             for (int i = 0; i < _longs.Length; i++)
                             {
-                                _longs[i] = _bytesReader.ReadVLong();
+                                _longs[i] = _bytesReader.ReadVInt64();
                             }
                             _blockTermsReader._postingsReader.DecodeTerm(_longs, _bytesReader, _fieldReader._fieldInfo, _state, absolute);
                             _metaDataUpto++;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/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
index d95aa57..fd70f40 100644
--- a/src/Lucene.Net.Codecs/BlockTerms/BlockTermsWriter.cs
+++ b/src/Lucene.Net.Codecs/BlockTerms/BlockTermsWriter.cs
@@ -131,22 +131,22 @@ namespace Lucene.Net.Codecs.BlockTerms
             {
                 var dirStart = m_output.FilePointer;
 
-                m_output.WriteVInt(_fields.Count);
+                m_output.WriteVInt32(_fields.Count);
 
                 foreach (var field in _fields)
                 {
-                    m_output.WriteVInt(field.FieldInfo.Number);
-                    m_output.WriteVLong(field.NumTerms);
-                    m_output.WriteVLong(field.TermsStartPointer);
+                    m_output.WriteVInt32(field.FieldInfo.Number);
+                    m_output.WriteVInt64(field.NumTerms);
+                    m_output.WriteVInt64(field.TermsStartPointer);
                     if (field.FieldInfo.IndexOptions != IndexOptions.DOCS_ONLY)
                     {
-                        m_output.WriteVLong(field.SumTotalTermFreq);
+                        m_output.WriteVInt64(field.SumTotalTermFreq);
                     }
-                    m_output.WriteVLong(field.SumDocFreq);
-                    m_output.WriteVInt(field.DocCount);
+                    m_output.WriteVInt64(field.SumDocFreq);
+                    m_output.WriteVInt32(field.DocCount);
                     if (VERSION_CURRENT >= VERSION_META_ARRAY)
                     {
-                        m_output.WriteVInt(field.LongsSize);
+                        m_output.WriteVInt32(field.LongsSize);
                     }
 
                 }
@@ -162,7 +162,7 @@ namespace Lucene.Net.Codecs.BlockTerms
 
         private void WriteTrailer(long dirStart)
         {
-            m_output.WriteLong(dirStart);
+            m_output.WriteInt64(dirStart);
         }
 
         private class TermEntry
@@ -276,7 +276,7 @@ namespace Lucene.Net.Codecs.BlockTerms
                 }
 
                 // EOF marker:
-                outerInstance.m_output.WriteVInt(0);
+                outerInstance.m_output.WriteVInt32(0);
 
                 _sumTotalTermFreq = sumTotalTermFreq;
                 _sumDocFreq = sumDocFreq;
@@ -334,8 +334,8 @@ namespace Lucene.Net.Codecs.BlockTerms
                             _pendingTerms[termCount].Term));
                 }
 
-                outerInstance.m_output.WriteVInt(_pendingCount);
-                outerInstance.m_output.WriteVInt(commonPrefix);
+                outerInstance.m_output.WriteVInt32(_pendingCount);
+                outerInstance.m_output.WriteVInt32(commonPrefix);
 
                 // 2nd pass: write suffixes, as separate byte[] blob
                 for (var termCount = 0; termCount < _pendingCount; termCount++)
@@ -343,10 +343,10 @@ namespace Lucene.Net.Codecs.BlockTerms
                     var suffix = _pendingTerms[termCount].Term.Length - commonPrefix;
                     // TODO: cutover to better intblock codec, instead
                     // of interleaving here:
-                    _bytesWriter.WriteVInt(suffix);
+                    _bytesWriter.WriteVInt32(suffix);
                     _bytesWriter.WriteBytes(_pendingTerms[termCount].Term.Bytes, commonPrefix, suffix);
                 }
-                outerInstance.m_output.WriteVInt((int)_bytesWriter.FilePointer);
+                outerInstance.m_output.WriteVInt32((int)_bytesWriter.FilePointer);
                 _bytesWriter.WriteTo(outerInstance.m_output);
                 _bytesWriter.Reset();
 
@@ -359,13 +359,13 @@ namespace Lucene.Net.Codecs.BlockTerms
 
                     Debug.Assert(state != null);
 
-                    _bytesWriter.WriteVInt(state.DocFreq);
+                    _bytesWriter.WriteVInt32(state.DocFreq);
                     if (_fieldInfo.IndexOptions != IndexOptions.DOCS_ONLY)
                     {
-                        _bytesWriter.WriteVLong(state.TotalTermFreq - state.DocFreq);
+                        _bytesWriter.WriteVInt64(state.TotalTermFreq - state.DocFreq);
                     }
                 }
-                outerInstance.m_output.WriteVInt((int)_bytesWriter.FilePointer);
+                outerInstance.m_output.WriteVInt32((int)_bytesWriter.FilePointer);
                 _bytesWriter.WriteTo(outerInstance.m_output);
                 _bytesWriter.Reset();
 
@@ -378,13 +378,13 @@ namespace Lucene.Net.Codecs.BlockTerms
                     _postingsWriter.EncodeTerm(longs, _bufferWriter, _fieldInfo, state, absolute);
                     for (int i = 0; i < _longsSize; i++)
                     {
-                        _bytesWriter.WriteVLong(longs[i]);
+                        _bytesWriter.WriteVInt64(longs[i]);
                     }
                     _bufferWriter.WriteTo(_bytesWriter);
                     _bufferWriter.Reset();
                     absolute = false;
                 }
-                outerInstance.m_output.WriteVInt((int)_bytesWriter.FilePointer);
+                outerInstance.m_output.WriteVInt32((int)_bytesWriter.FilePointer);
                 _bytesWriter.WriteTo(outerInstance.m_output);
                 _bytesWriter.Reset();
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/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
index 534c9d0..4fdb5fe 100644
--- a/src/Lucene.Net.Codecs/BlockTerms/FixedGapTermsIndexReader.cs
+++ b/src/Lucene.Net.Codecs/BlockTerms/FixedGapTermsIndexReader.cs
@@ -86,7 +86,7 @@ namespace Lucene.Net.Codecs.BlockTerms
                 if (_version >= FixedGapTermsIndexWriter.VERSION_CHECKSUM)
                     CodecUtil.ChecksumEntireFile(_input);
                 
-                indexInterval = _input.ReadInt();
+                indexInterval = _input.ReadInt32();
                 
                 if (indexInterval < 1)
                 {
@@ -111,7 +111,7 @@ namespace Lucene.Net.Codecs.BlockTerms
                 SeekDir(_input, _dirOffset);
 
                 // Read directory
-                int numFields = _input.ReadVInt();
+                int numFields = _input.ReadVInt32();
 
                 if (numFields < 0)
                     throw new CorruptIndexException(String.Format("Invalid numFields: {0}, Resource: {1}", numFields,
@@ -119,17 +119,17 @@ namespace Lucene.Net.Codecs.BlockTerms
 
                 for (int i = 0; i < numFields; i++)
                 {
-                    int field = _input.ReadVInt();
-                    int numIndexTerms = _input.ReadVInt();
+                    int field = _input.ReadVInt32();
+                    int numIndexTerms = _input.ReadVInt32();
                     if (numIndexTerms < 0)
                         throw new CorruptIndexException(String.Format("Invalid numIndexTerms: {0}, Resource: {1}",
                             numIndexTerms,
                             _input));
 
-                    long termsStart = _input.ReadVLong();
-                    long indexStart = _input.ReadVLong();
-                    long packedIndexStart = _input.ReadVLong();
-                    long packedOffsetsStart = _input.ReadVLong();
+                    long termsStart = _input.ReadVInt64();
+                    long indexStart = _input.ReadVInt64();
+                    long packedIndexStart = _input.ReadVInt64();
+                    long packedOffsetsStart = _input.ReadVInt64();
 
                     if (packedIndexStart < indexStart)
                         throw new CorruptIndexException(
@@ -186,7 +186,7 @@ namespace Lucene.Net.Codecs.BlockTerms
                 FixedGapTermsIndexWriter.VERSION_START, FixedGapTermsIndexWriter.VERSION_CURRENT);
             
             if (version < FixedGapTermsIndexWriter.VERSION_APPEND_ONLY)
-                _dirOffset = input.ReadLong();
+                _dirOffset = input.ReadInt64();
 
             return version;
         }
@@ -501,13 +501,13 @@ namespace Lucene.Net.Codecs.BlockTerms
             if (_version >= FixedGapTermsIndexWriter.VERSION_CHECKSUM)
             {
                 input.Seek(input.Length - CodecUtil.FooterLength() - 8);
-                dirOffset = input.ReadLong();
+                dirOffset = input.ReadInt64();
 
             }
             else if (_version >= FixedGapTermsIndexWriter.VERSION_APPEND_ONLY)
             {
                 input.Seek(input.Length - 8);
-                dirOffset = input.ReadLong();
+                dirOffset = input.ReadInt64();
             }
 
             input.Seek(dirOffset);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/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
index 4339316..39d3209 100644
--- a/src/Lucene.Net.Codecs/BlockTerms/FixedGapTermsIndexWriter.cs
+++ b/src/Lucene.Net.Codecs/BlockTerms/FixedGapTermsIndexWriter.cs
@@ -63,7 +63,7 @@ namespace Lucene.Net.Codecs.BlockTerms
             {
                 _fieldInfos = state.FieldInfos;
                 WriteHeader(m_output);
-                m_output.WriteInt(_termIndexInterval);
+                m_output.WriteInt32(_termIndexInterval);
                 success = true;
             }
             finally
@@ -246,18 +246,18 @@ namespace Lucene.Net.Codecs.BlockTerms
                         }
                     }
 
-                    m_output.WriteVInt(nonNullFieldCount);
+                    m_output.WriteVInt32(nonNullFieldCount);
                     for (int i = 0; i < fieldCount; i++)
                     {
                         SimpleFieldWriter field = _fields[i];
                         if (field.numIndexTerms > 0)
                         {
-                            m_output.WriteVInt(field.fieldInfo.Number);
-                            m_output.WriteVInt(field.numIndexTerms);
-                            m_output.WriteVLong(field.termsStart);
-                            m_output.WriteVLong(field.indexStart);
-                            m_output.WriteVLong(field.packedIndexStart);
-                            m_output.WriteVLong(field.packedOffsetsStart);
+                            m_output.WriteVInt32(field.fieldInfo.Number);
+                            m_output.WriteVInt32(field.numIndexTerms);
+                            m_output.WriteVInt64(field.termsStart);
+                            m_output.WriteVInt64(field.indexStart);
+                            m_output.WriteVInt64(field.packedIndexStart);
+                            m_output.WriteVInt64(field.packedOffsetsStart);
                         }
                     }
                     WriteTrailer(dirStart);
@@ -281,7 +281,7 @@ namespace Lucene.Net.Codecs.BlockTerms
 
         private void WriteTrailer(long dirStart)
         {
-            m_output.WriteLong(dirStart);
+            m_output.WriteInt64(dirStart);
         }
     }
 }
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/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
index bbcaac5..fb75734 100644
--- a/src/Lucene.Net.Codecs/BlockTerms/VariableGapTermsIndexReader.cs
+++ b/src/Lucene.Net.Codecs/BlockTerms/VariableGapTermsIndexReader.cs
@@ -70,7 +70,7 @@ namespace Lucene.Net.Codecs.BlockTerms
                 SeekDir(_input, _dirOffset);
 
                 // Read directory
-                var numFields = _input.ReadVInt();
+                var numFields = _input.ReadVInt32();
                 if (numFields < 0)
                 {
                     throw new CorruptIndexException("invalid numFields: " + numFields + " (resource=" + _input + ")");
@@ -78,8 +78,8 @@ namespace Lucene.Net.Codecs.BlockTerms
 
                 for (var i = 0; i < numFields; i++)
                 {
-                    var field = _input.ReadVInt();
-                    var indexStart = _input.ReadVLong();
+                    var field = _input.ReadVInt32();
+                    var indexStart = _input.ReadVInt64();
                     var fieldInfo = fieldInfos.FieldInfo(field);
                     
                     try
@@ -119,7 +119,7 @@ namespace Lucene.Net.Codecs.BlockTerms
                 VariableGapTermsIndexWriter.VERSION_START, VariableGapTermsIndexWriter.VERSION_CURRENT);
             if (version < VariableGapTermsIndexWriter.VERSION_APPEND_ONLY)
             {
-                _dirOffset = input.ReadLong();
+                _dirOffset = input.ReadInt64();
             }
             return version;
         }
@@ -218,7 +218,7 @@ namespace Lucene.Net.Codecs.BlockTerms
                     {
                         if (count == outerInstance._indexDivisor)
                         {
-                            builder.Add(Util.Fst.Util.ToIntsRef(result.Input, scratchIntsRef), result.Output);
+                            builder.Add(Util.Fst.Util.ToInt32sRef(result.Input, scratchIntsRef), result.Output);
                             count = 0;
                         }
                         count++;
@@ -252,12 +252,12 @@ namespace Lucene.Net.Codecs.BlockTerms
             if (_version >= VariableGapTermsIndexWriter.VERSION_CHECKSUM)
             {
                 input.Seek(input.Length - CodecUtil.FooterLength() - 8);
-                dirOffset = input.ReadLong();
+                dirOffset = input.ReadInt64();
             }
             else if (_version >= VariableGapTermsIndexWriter.VERSION_APPEND_ONLY)
             {
                 input.Seek(input.Length - 8);
-                dirOffset = input.ReadLong();
+                dirOffset = input.ReadInt64();
             }
             input.Seek(dirOffset);
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/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
index be3f35c..1089fa8 100644
--- a/src/Lucene.Net.Codecs/BlockTerms/VariableGapTermsIndexWriter.cs
+++ b/src/Lucene.Net.Codecs/BlockTerms/VariableGapTermsIndexWriter.cs
@@ -284,7 +284,7 @@ namespace Lucene.Net.Codecs.BlockTerms
                 text.Length = outerInstance.IndexedTermPrefixLength(_lastTerm, text);
                 try
                 {
-                    _fstBuilder.Add(Util.Fst.Util.ToIntsRef(text, _scratchIntsRef), termsFilePointer);
+                    _fstBuilder.Add(Util.Fst.Util.ToInt32sRef(text, _scratchIntsRef), termsFilePointer);
                 }
                 finally
                 {
@@ -320,14 +320,14 @@ namespace Lucene.Net.Codecs.BlockTerms
                     }
                 }
 
-                m_output.WriteVInt(nonNullFieldCount);
+                m_output.WriteVInt32(nonNullFieldCount);
                 for (int i = 0; i < fieldCount; i++)
                 {
                     FstFieldWriter field = _fields[i];
                     if (field.Fst != null)
                     {
-                        m_output.WriteVInt(field.FieldInfo.Number);
-                        m_output.WriteVLong(field.IndexStart);
+                        m_output.WriteVInt32(field.FieldInfo.Number);
+                        m_output.WriteVInt64(field.IndexStart);
                     }
                 }
                 WriteTrailer(dirStart);
@@ -342,7 +342,7 @@ namespace Lucene.Net.Codecs.BlockTerms
 
         private void WriteTrailer(long dirStart)
         {
-            m_output.WriteLong(dirStart);
+            m_output.WriteInt64(dirStart);
         }
     }
 }
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/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
index cfdcb6b..cb68c0f 100644
--- a/src/Lucene.Net.Codecs/Bloom/BloomFilteringPostingsFormat.cs
+++ b/src/Lucene.Net.Codecs/Bloom/BloomFilteringPostingsFormat.cs
@@ -144,10 +144,10 @@ namespace Lucene.Net.Codecs.Bloom
 
                     _delegateFieldsProducer = delegatePostingsFormat
                         .FieldsProducer(state);
-                    var numBlooms = bloomIn.ReadInt();
+                    var numBlooms = bloomIn.ReadInt32();
                     for (var i = 0; i < numBlooms; i++)
                     {
-                        var fieldNum = bloomIn.ReadInt();
+                        var fieldNum = bloomIn.ReadInt32();
                         var bloom = FuzzySet.Deserialize(bloomIn);
                         var fieldInfo = state.FieldInfos.FieldInfo(fieldNum);
                         _bloomsByFieldName.Add(fieldInfo.Name, bloom);
@@ -456,12 +456,12 @@ namespace Lucene.Net.Codecs.Bloom
                     bloomOutput.WriteString(outerInstance._delegatePostingsFormat.Name);
 
                     // First field in the output file is the number of fields+blooms saved
-                    bloomOutput.WriteInt(nonSaturatedBlooms.Count);
+                    bloomOutput.WriteInt32(nonSaturatedBlooms.Count);
                     foreach (var entry in nonSaturatedBlooms)
                     {
                         var fieldInfo = entry.Key;
                         var bloomFilter = entry.Value;
-                        bloomOutput.WriteInt(fieldInfo.Number);
+                        bloomOutput.WriteInt32(fieldInfo.Number);
                         SaveAppropriatelySizedBloomFilter(bloomOutput, bloomFilter, fieldInfo);
                     }
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/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
index df87f20..282c790 100644
--- a/src/Lucene.Net.Codecs/Bloom/FuzzySet.cs
+++ b/src/Lucene.Net.Codecs/Bloom/FuzzySet.cs
@@ -189,31 +189,31 @@ namespace Lucene.Net.Codecs.Bloom
         /// </summary>
         public virtual void Serialize(DataOutput output)
         {
-            output.WriteInt(VERSION_CURRENT);
-            output.WriteInt(_bloomSize);
+            output.WriteInt32(VERSION_CURRENT);
+            output.WriteInt32(_bloomSize);
             var bits = _filter.GetBits();
-            output.WriteInt(bits.Length);
+            output.WriteInt32(bits.Length);
             foreach (var t in bits)
             {
                 // Can't used VLong encoding because cant cope with negative numbers
                 // output by FixedBitSet
-                output.WriteLong(t);
+                output.WriteInt64(t);
             }
         }
 
         public static FuzzySet Deserialize(DataInput input)
         {
-            var version = input.ReadInt();
+            var version = input.ReadInt32();
             if (version == VERSION_SPI)
                 input.ReadString();
            
             var hashFunction = HashFunctionForVersion(version);
-            var bloomSize = input.ReadInt();
-            var numLongs = input.ReadInt();
+            var bloomSize = input.ReadInt32();
+            var numLongs = input.ReadInt32();
             var longs = new long[numLongs];
             for (var i = 0; i < numLongs; i++)
             {
-                longs[i] = input.ReadLong();
+                longs[i] = input.ReadInt64();
             }
             var bits = new FixedBitSet(longs, bloomSize + 1);
             return new FuzzySet(bits, bloomSize, hashFunction);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/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
index 6fc81d1..8412a76 100644
--- a/src/Lucene.Net.Codecs/DiskDV/DiskDocValuesProducer.cs
+++ b/src/Lucene.Net.Codecs/DiskDV/DiskDocValuesProducer.cs
@@ -35,7 +35,7 @@ namespace Lucene.Net.Codecs.DiskDV
             BinaryEntry bytes)
         {
             data.Seek(bytes.AddressesOffset);
-            return new MonotonicBlockPackedReader((IndexInput)data.Clone(), bytes.PackedIntsVersion, bytes.BlockSize, bytes.Count,
+            return new MonotonicBlockPackedReader((IndexInput)data.Clone(), bytes.PackedInt32sVersion, bytes.BlockSize, bytes.Count,
                 true);
         }
 
@@ -49,7 +49,7 @@ namespace Lucene.Net.Codecs.DiskDV
             NumericEntry entry)
         {
             data.Seek(entry.Offset);
-            return new MonotonicBlockPackedReader((IndexInput)data.Clone(), entry.PackedIntsVersion, entry.BlockSize, entry.Count,
+            return new MonotonicBlockPackedReader((IndexInput)data.Clone(), entry.PackedInt32sVersion, entry.BlockSize, entry.Count,
                 true);
         }
     }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/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
index 991b5f0..23cbd4c 100644
--- a/src/Lucene.Net.Codecs/IntBlock/FixedIntBlockIndexInput.cs
+++ b/src/Lucene.Net.Codecs/IntBlock/FixedIntBlockIndexInput.cs
@@ -42,7 +42,7 @@ namespace Lucene.Net.Codecs.IntBlock
         public FixedIntBlockIndexInput(IndexInput @in)
         {
             input = @in;
-            m_blockSize = @in.ReadVInt();
+            m_blockSize = @in.ReadVInt32();
         }
 
         public override AbstractReader GetReader()
@@ -146,12 +146,12 @@ namespace Lucene.Net.Codecs.IntBlock
             {
                 if (absolute)
                 {
-                    upto = indexIn.ReadVInt();
-                    fp = indexIn.ReadVLong();
+                    upto = indexIn.ReadVInt32();
+                    fp = indexIn.ReadVInt64();
                 }
                 else
                 {
-                    int uptoDelta = indexIn.ReadVInt();
+                    int uptoDelta = indexIn.ReadVInt32();
                     if ((uptoDelta & 1) == 1)
                     {
                         // same block
@@ -161,7 +161,7 @@ namespace Lucene.Net.Codecs.IntBlock
                     {
                         // new block
                         upto = (int)((uint)uptoDelta >> 1);
-                        fp += indexIn.ReadVLong();
+                        fp += indexIn.ReadVInt64();
                     }
                 }
                 Debug.Assert(upto < outerInstance.m_blockSize);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/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
index 544b644..90672d5 100644
--- a/src/Lucene.Net.Codecs/IntBlock/FixedIntBlockIndexOutput.cs
+++ b/src/Lucene.Net.Codecs/IntBlock/FixedIntBlockIndexOutput.cs
@@ -48,7 +48,7 @@ namespace Lucene.Net.Codecs.IntBlock
         {
             blockSize = fixedBlockSize;
             this.m_output = output;
-            output.WriteVInt(blockSize);
+            output.WriteVInt32(blockSize);
             m_buffer = new int[blockSize];
         }
 
@@ -95,21 +95,21 @@ namespace Lucene.Net.Codecs.IntBlock
             {
                 if (absolute)
                 {
-                    indexOut.WriteVInt(upto);
-                    indexOut.WriteVLong(fp);
+                    indexOut.WriteVInt32(upto);
+                    indexOut.WriteVInt64(fp);
                 }
                 else if (fp == lastFP)
                 {
                     // same block
                     Debug.Assert(upto >= lastUpto);
                     int uptoDelta = upto - lastUpto;
-                    indexOut.WriteVInt(uptoDelta << 1 | 1);
+                    indexOut.WriteVInt32(uptoDelta << 1 | 1);
                 }
                 else
                 {
                     // new block
-                    indexOut.WriteVInt(upto << 1);
-                    indexOut.WriteVLong(fp - lastFP);
+                    indexOut.WriteVInt32(upto << 1);
+                    indexOut.WriteVInt64(fp - lastFP);
                 }
                 lastUpto = upto;
                 lastFP = fp;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/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
index b4cf3b8..e388124 100644
--- a/src/Lucene.Net.Codecs/IntBlock/VariableIntBlockIndexInput.cs
+++ b/src/Lucene.Net.Codecs/IntBlock/VariableIntBlockIndexInput.cs
@@ -46,7 +46,7 @@ namespace Lucene.Net.Codecs.IntBlock
         protected internal VariableIntBlockIndexInput(IndexInput input)
         {
             this.input = input;
-            m_maxBlockSize = input.ReadInt();
+            m_maxBlockSize = input.ReadInt32();
         }
 
         public override AbstractReader GetReader()
@@ -179,12 +179,12 @@ namespace Lucene.Net.Codecs.IntBlock
             {
                 if (absolute)
                 {
-                    upto = indexIn.ReadVInt();
-                    fp = indexIn.ReadVLong();
+                    upto = indexIn.ReadVInt32();
+                    fp = indexIn.ReadVInt64();
                 }
                 else
                 {
-                    int uptoDelta = indexIn.ReadVInt();
+                    int uptoDelta = indexIn.ReadVInt32();
                     if ((uptoDelta & 1) == 1)
                     {
                         // same block
@@ -194,7 +194,7 @@ namespace Lucene.Net.Codecs.IntBlock
                     {
                         // new block
                         upto = (int)((uint)uptoDelta >> 1);
-                        fp += indexIn.ReadVLong();
+                        fp += indexIn.ReadVInt64();
                     }
                 }
                 // TODO: we can't do this assert because non-causal

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/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
index f756777..b52ae38 100644
--- a/src/Lucene.Net.Codecs/IntBlock/VariableIntBlockIndexOutput.cs
+++ b/src/Lucene.Net.Codecs/IntBlock/VariableIntBlockIndexOutput.cs
@@ -58,7 +58,7 @@ namespace Lucene.Net.Codecs.IntBlock
         protected VariableIntBlockIndexOutput(IndexOutput output, int maxBlockSize)
         {
             this.m_output = output;
-            this.m_output.WriteInt(maxBlockSize);
+            this.m_output.WriteInt32(maxBlockSize);
         }
 
         /// <summary>
@@ -109,21 +109,21 @@ namespace Lucene.Net.Codecs.IntBlock
                 Debug.Assert(upto >= 0);
                 if (absolute)
                 {
-                    indexOut.WriteVInt(upto);
-                    indexOut.WriteVLong(fp);
+                    indexOut.WriteVInt32(upto);
+                    indexOut.WriteVInt64(fp);
                 }
                 else if (fp == lastFP)
                 {
                     // same block
                     Debug.Assert(upto >= lastUpto);
                     int uptoDelta = upto - lastUpto;
-                    indexOut.WriteVInt(uptoDelta << 1 | 1);
+                    indexOut.WriteVInt32(uptoDelta << 1 | 1);
                 }
                 else
                 {
                     // new block
-                    indexOut.WriteVInt(upto << 1);
-                    indexOut.WriteVLong(fp - lastFP);
+                    indexOut.WriteVInt32(upto << 1);
+                    indexOut.WriteVInt64(fp - lastFP);
                 }
                 lastUpto = upto;
                 lastFP = fp;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/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
index a6addd3..6181139 100644
--- a/src/Lucene.Net.Codecs/Memory/DirectDocValuesConsumer.cs
+++ b/src/Lucene.Net.Codecs/Memory/DirectDocValuesConsumer.cs
@@ -65,14 +65,14 @@ namespace Lucene.Net.Codecs.Memory
 
         public override void AddNumericField(FieldInfo field, IEnumerable<long?> values)
         {
-            meta.WriteVInt(field.Number);
+            meta.WriteVInt32(field.Number);
             meta.WriteByte(MemoryDocValuesProducer.NUMBER);
             AddNumericFieldValues(field, values);
         }
 
         private void AddNumericFieldValues(FieldInfo field, IEnumerable<long?> values)
         {
-            meta.WriteLong(data.FilePointer);
+            meta.WriteInt64(data.FilePointer);
             long minValue = long.MaxValue;
             long maxValue = long.MinValue;
             bool missing = false;
@@ -97,18 +97,18 @@ namespace Lucene.Net.Codecs.Memory
                                                        DirectDocValuesFormat.MAX_SORTED_SET_ORDS + " values/total ords");
                 }
             }
-            meta.WriteInt((int) count);
+            meta.WriteInt32((int) count);
 
             if (missing)
             {
                 long start = data.FilePointer;
                 WriteMissingBitset(values);
-                meta.WriteLong(start);
-                meta.WriteLong(data.FilePointer - start);
+                meta.WriteInt64(start);
+                meta.WriteInt64(data.FilePointer - start);
             }
             else
             {
-                meta.WriteLong(-1L);
+                meta.WriteInt64(-1L);
             }
 
             byte byteWidth;
@@ -148,13 +148,13 @@ namespace Lucene.Net.Codecs.Memory
                         data.WriteByte((byte)(sbyte) v);
                         break;
                     case 2:
-                        data.WriteShort((short) v);
+                        data.WriteInt16((short) v);
                         break;
                     case 4:
-                        data.WriteInt((int) v);
+                        data.WriteInt32((int) v);
                         break;
                     case 8:
-                        data.WriteLong(v);
+                        data.WriteInt64(v);
                         break;
                 }
             }
@@ -169,7 +169,7 @@ namespace Lucene.Net.Codecs.Memory
             {
                 if (meta != null)
                 {
-                    meta.WriteVInt(-1); // write EOF marker
+                    meta.WriteVInt32(-1); // write EOF marker
                     CodecUtil.WriteFooter(meta); // write checksum
                 }
                 if (data != null)
@@ -194,7 +194,7 @@ namespace Lucene.Net.Codecs.Memory
 
         public override void AddBinaryField(FieldInfo field, IEnumerable<BytesRef> values)
         {
-            meta.WriteVInt(field.Number);
+            meta.WriteVInt32(field.Number);
             meta.WriteByte(MemoryDocValuesProducer.BYTES);
             AddBinaryFieldValues(field, values);
         }
@@ -226,31 +226,31 @@ namespace Lucene.Net.Codecs.Memory
                 count++;
             }
 
-            meta.WriteLong(startFP);
-            meta.WriteInt((int) totalBytes);
-            meta.WriteInt(count);
+            meta.WriteInt64(startFP);
+            meta.WriteInt32((int) totalBytes);
+            meta.WriteInt32(count);
             if (missing)
             {
                 long start = data.FilePointer;
                 WriteMissingBitset(values);
-                meta.WriteLong(start);
-                meta.WriteLong(data.FilePointer - start);
+                meta.WriteInt64(start);
+                meta.WriteInt64(data.FilePointer - start);
             }
             else
             {
-                meta.WriteLong(-1L);
+                meta.WriteInt64(-1L);
             }
 
             int addr = 0;
             foreach (BytesRef v in values)
             {
-                data.WriteInt(addr);
+                data.WriteInt32(addr);
                 if (v != null)
                 {
                     addr += v.Length;
                 }
             }
-            data.WriteInt(addr);
+            data.WriteInt32(addr);
         }
 
         // TODO: in some cases representing missing with minValue-1 wouldn't take up additional space and so on,
@@ -263,7 +263,7 @@ namespace Lucene.Net.Codecs.Memory
             {
                 if (count == 64)
                 {
-                    data.WriteLong(bits);
+                    data.WriteInt64(bits);
                     count = 0;
                     bits = 0;
                 }
@@ -275,13 +275,13 @@ namespace Lucene.Net.Codecs.Memory
             }
             if (count > 0)
             {
-                data.WriteLong(bits);
+                data.WriteInt64(bits);
             }
         }
 
         public override void AddSortedField(FieldInfo field, IEnumerable<BytesRef> values, IEnumerable<long?> docToOrd)
         {
-            meta.WriteVInt(field.Number);
+            meta.WriteVInt32(field.Number);
             meta.WriteByte((byte)DirectDocValuesProducer.SORTED);
 
             // write the ordinals as numerics
@@ -295,7 +295,7 @@ namespace Lucene.Net.Codecs.Memory
         public override void AddSortedSetField(FieldInfo field, IEnumerable<BytesRef> values,
             IEnumerable<long?> docToOrdCount, IEnumerable<long?> ords)
         {
-            meta.WriteVInt(field.Number);
+            meta.WriteVInt32(field.Number);
             meta.WriteByte((byte)DirectDocValuesProducer.SORTED_SET);
 
             // First write docToOrdCounts, except we "aggregate" the

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/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
index 1fdb2ee..fa1c9b2 100644
--- a/src/Lucene.Net.Codecs/Memory/DirectDocValuesProducer.cs
+++ b/src/Lucene.Net.Codecs/Memory/DirectDocValuesProducer.cs
@@ -118,10 +118,10 @@ namespace Lucene.Net.Codecs.Memory
 
         private NumericEntry ReadNumericEntry(IndexInput meta)
         {
-            var entry = new NumericEntry { offset = meta.ReadLong(), count = meta.ReadInt(), missingOffset = meta.ReadLong() };
+            var entry = new NumericEntry { offset = meta.ReadInt64(), count = meta.ReadInt32(), missingOffset = meta.ReadInt64() };
             if (entry.missingOffset != -1)
             {
-                entry.missingBytes = meta.ReadLong();
+                entry.missingBytes = meta.ReadInt64();
             }
             else
             {
@@ -135,13 +135,13 @@ namespace Lucene.Net.Codecs.Memory
         private BinaryEntry ReadBinaryEntry(IndexInput meta)
         {
             var entry = new BinaryEntry();
-            entry.offset = meta.ReadLong();
-            entry.numBytes = meta.ReadInt();
-            entry.count = meta.ReadInt();
-            entry.missingOffset = meta.ReadLong();
+            entry.offset = meta.ReadInt64();
+            entry.numBytes = meta.ReadInt32();
+            entry.count = meta.ReadInt32();
+            entry.missingOffset = meta.ReadInt64();
             if (entry.missingOffset != -1)
             {
-                entry.missingBytes = meta.ReadLong();
+                entry.missingBytes = meta.ReadInt64();
             }
             else
             {
@@ -170,7 +170,7 @@ namespace Lucene.Net.Codecs.Memory
 
         private void ReadFields(IndexInput meta)
         {
-            int fieldNumber = meta.ReadVInt();
+            int fieldNumber = meta.ReadVInt32();
             while (fieldNumber != -1)
             {
                 int fieldType = meta.ReadByte();
@@ -194,7 +194,7 @@ namespace Lucene.Net.Codecs.Memory
                 {
                     throw new CorruptIndexException("invalid entry type: " + fieldType + ", input=" + meta);
                 }
-                fieldNumber = meta.ReadVInt();
+                fieldNumber = meta.ReadVInt32();
             }
         }
 
@@ -245,7 +245,7 @@ namespace Lucene.Net.Codecs.Memory
                         var values = new short[entry.count];
                         for (int i = 0; i < entry.count; i++)
                         {
-                            values[i] = data.ReadShort();
+                            values[i] = data.ReadInt16();
                         }
                         ramBytesUsed.AddAndGet(RamUsageEstimator.SizeOf(values));
                         return new NumericDocValuesAnonymousInnerClassHelper2(this, values);
@@ -256,7 +256,7 @@ namespace Lucene.Net.Codecs.Memory
                         var values = new int[entry.count];
                         for (var i = 0; i < entry.count; i++)
                         {
-                            values[i] = data.ReadInt();
+                            values[i] = data.ReadInt32();
                         }
                         ramBytesUsed.AddAndGet(RamUsageEstimator.SizeOf(values));
                         return new NumericDocValuesAnonymousInnerClassHelper3(values);
@@ -267,7 +267,7 @@ namespace Lucene.Net.Codecs.Memory
                         var values = new long[entry.count];
                         for (int i = 0; i < entry.count; i++)
                         {
-                            values[i] = data.ReadLong();
+                            values[i] = data.ReadInt64();
                         }
                         ramBytesUsed.AddAndGet(RamUsageEstimator.SizeOf(values));
                         return new NumericDocValuesAnonymousInnerClassHelper4(values);
@@ -363,9 +363,9 @@ namespace Lucene.Net.Codecs.Memory
             var address = new int[entry.count + 1];
             for (int i = 0; i < entry.count; i++)
             {
-                address[i] = data.ReadInt();
+                address[i] = data.ReadInt32();
             }
-            address[entry.count] = data.ReadInt();
+            address[entry.count] = data.ReadInt32();
 
             ramBytesUsed.AddAndGet(RamUsageEstimator.SizeOf(bytes) + RamUsageEstimator.SizeOf(address));
 
@@ -570,7 +570,7 @@ namespace Lucene.Net.Codecs.Memory
                         var bits = new long[(int)length >> 3];
                         for (var i = 0; i < bits.Length; i++)
                         {
-                            bits[i] = data.ReadLong();
+                            bits[i] = data.ReadInt64();
                         }
                         instance = new FixedBitSet(bits, maxDoc);
                         docsWithFieldInstances[fieldNumber] = instance;


[21/53] [abbrv] lucenenet git commit: Lucene.Net.Core: Renamed all type-derived classes and interfaces from Short, Int, Long, and Float to match CLR types Int16, Int32, Int64, and Single, respectively.

Posted by ni...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Tests/core/Support/TestLongBuffer.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Support/TestLongBuffer.cs b/src/Lucene.Net.Tests/core/Support/TestLongBuffer.cs
index c4f0947..f83ffcc 100644
--- a/src/Lucene.Net.Tests/core/Support/TestLongBuffer.cs
+++ b/src/Lucene.Net.Tests/core/Support/TestLongBuffer.cs
@@ -19,7 +19,7 @@ namespace Lucene.Net.Support
         };
 
 
-        private static void relGet(LongBuffer b)
+        private static void relGet(Int64Buffer b)
         {
             int n = b.Capacity;
             //long v; // LUCENENET: Not used
@@ -28,7 +28,7 @@ namespace Lucene.Net.Support
             b.Rewind();
         }
 
-        private static void relGet(LongBuffer b, int start)
+        private static void relGet(Int64Buffer b, int start)
         {
             int n = b.Remaining;
             //long v; // LUCENENET: Not used
@@ -37,7 +37,7 @@ namespace Lucene.Net.Support
             b.Rewind();
         }
 
-        private static void absGet(LongBuffer b)
+        private static void absGet(Int64Buffer b)
         {
             int n = b.Capacity;
             //long v; // LUCENENET: Not used
@@ -46,7 +46,7 @@ namespace Lucene.Net.Support
             b.Rewind();
         }
 
-        private static void bulkGet(LongBuffer b)
+        private static void bulkGet(Int64Buffer b)
         {
             int n = b.Capacity;
             long[] a = new long[n + 7];
@@ -55,7 +55,7 @@ namespace Lucene.Net.Support
                 ck(b, (long)a[i + 7], (long)((long)Ic(i)));
         }
 
-        private static void relPut(LongBuffer b)
+        private static void relPut(Int64Buffer b)
         {
             int n = b.Capacity;
             b.Clear();
@@ -64,7 +64,7 @@ namespace Lucene.Net.Support
             b.Flip();
         }
 
-        private static void absPut(LongBuffer b)
+        private static void absPut(Int64Buffer b)
         {
             int n = b.Capacity;
             b.Clear();
@@ -74,7 +74,7 @@ namespace Lucene.Net.Support
             b.Position = (0);
         }
 
-        private static void bulkPutArray(LongBuffer b)
+        private static void bulkPutArray(Int64Buffer b)
         {
             int n = b.Capacity;
             b.Clear();
@@ -85,11 +85,11 @@ namespace Lucene.Net.Support
             b.Flip();
         }
 
-        private static void bulkPutBuffer(LongBuffer b)
+        private static void bulkPutBuffer(Int64Buffer b)
         {
             int n = b.Capacity;
             b.Clear();
-            LongBuffer c = LongBuffer.Allocate(n + 7);
+            Int64Buffer c = Int64Buffer.Allocate(n + 7);
             c.Position = (7);
             for (int i = 0; i < n; i++)
                 c.Put((long)Ic(i));
@@ -100,7 +100,7 @@ namespace Lucene.Net.Support
         }
 
         //6231529
-        private static void callReset(LongBuffer b)
+        private static void callReset(Int64Buffer b)
         {
             b.Position = (0);
             b.Mark();
@@ -122,23 +122,23 @@ namespace Lucene.Net.Support
             // LUCENENET: AllocateDirect not implemented
 
             //LongBuffer direct1 = ByteBuffer.AllocateDirect(cap).AsLongBuffer();
-            LongBuffer nondirect1 = ByteBuffer.Allocate(cap).AsInt64Buffer();
+            Int64Buffer nondirect1 = ByteBuffer.Allocate(cap).AsInt64Buffer();
             //direct1.Put(nondirect1);
 
             //LongBuffer direct2 = ByteBuffer.AllocateDirect(cap).AsLongBuffer();
-            LongBuffer nondirect2 = ByteBuffer.Allocate(cap).AsInt64Buffer();
+            Int64Buffer nondirect2 = ByteBuffer.Allocate(cap).AsInt64Buffer();
             //nondirect2.Put(direct2);
 
             //LongBuffer direct3 = ByteBuffer.AllocateDirect(cap).AsLongBuffer();
             //LongBuffer direct4 = ByteBuffer.AllocateDirect(cap).AsLongBuffer();
             //direct3.Put(direct4);
 
-            LongBuffer nondirect3 = ByteBuffer.Allocate(cap).AsInt64Buffer();
-            LongBuffer nondirect4 = ByteBuffer.Allocate(cap).AsInt64Buffer();
+            Int64Buffer nondirect3 = ByteBuffer.Allocate(cap).AsInt64Buffer();
+            Int64Buffer nondirect4 = ByteBuffer.Allocate(cap).AsInt64Buffer();
             nondirect3.Put(nondirect4);
         }
 
-        private static void checkSlice(LongBuffer b, LongBuffer slice)
+        private static void checkSlice(Int64Buffer b, Int64Buffer slice)
         {
             ck(slice, 0, slice.Position);
             ck(slice, b.Remaining, slice.Limit);
@@ -150,7 +150,7 @@ namespace Lucene.Net.Support
         }
 
         private static void fail(string problem,
-                                 LongBuffer xb, LongBuffer yb,
+                                 Int64Buffer xb, Int64Buffer yb,
                                  long x, long y)
         {
             fail(problem + string.Format(": x={0} y={1}", x, y), xb, yb);
@@ -180,10 +180,10 @@ namespace Lucene.Net.Support
 
         private static void tryCatch(long[] t, Type ex, Action thunk)
         {
-            tryCatch(LongBuffer.Wrap(t), ex, thunk);
+            tryCatch(Int64Buffer.Wrap(t), ex, thunk);
         }
 
-        public static void test(int level, LongBuffer b, bool direct)
+        public static void test(int level, Int64Buffer b, bool direct)
         {
 
             Show(level, b);
@@ -276,7 +276,7 @@ namespace Lucene.Net.Support
 
             // Comparison
             b.Rewind();
-            LongBuffer b2 = Lucene.Net.Support.LongBuffer.Allocate(b.Capacity);
+            Int64Buffer b2 = Lucene.Net.Support.Int64Buffer.Allocate(b.Capacity);
             b2.Put(b);
             b2.Flip();
             b.Position = (2);
@@ -315,7 +315,7 @@ namespace Lucene.Net.Support
             // Check equals and compareTo with interesting values
             foreach (long x in VALUES)
             {
-                LongBuffer xb = Lucene.Net.Support.LongBuffer.Wrap(new long[] { x });
+                Int64Buffer xb = Lucene.Net.Support.Int64Buffer.Wrap(new long[] { x });
                 if (xb.CompareTo(xb) != 0)
                 {
                     fail("compareTo not reflexive", xb, xb, x, x);
@@ -326,7 +326,7 @@ namespace Lucene.Net.Support
                 }
                 foreach (long y in VALUES)
                 {
-                    LongBuffer yb = Lucene.Net.Support.LongBuffer.Wrap(new long[] { y });
+                    Int64Buffer yb = Lucene.Net.Support.Int64Buffer.Wrap(new long[] { y });
                     if (xb.CompareTo(yb) != -yb.CompareTo(xb))
                     {
                         fail("compareTo not anti-symmetric",
@@ -365,10 +365,10 @@ namespace Lucene.Net.Support
             // Slice
 
             b.Position = (5);
-            LongBuffer sb = b.Slice();
+            Int64Buffer sb = b.Slice();
             checkSlice(b, sb);
             b.Position = (0);
-            LongBuffer sb2 = sb.Slice();
+            Int64Buffer sb2 = sb.Slice();
             checkSlice(sb, sb2);
 
             if (!sb.equals(sb2))
@@ -462,7 +462,7 @@ namespace Lucene.Net.Support
         {
             int offset = 47;
             int length = 900;
-            LongBuffer b = LongBuffer.Wrap(ba, offset, length);
+            Int64Buffer b = Int64Buffer.Wrap(ba, offset, length);
             Show(0, b);
             ck(b, b.Capacity, ba.Length);
             ck(b, b.Position, offset);
@@ -471,29 +471,29 @@ namespace Lucene.Net.Support
             // The offset must be non-negative and no larger than <array.length>.
             tryCatch(ba, typeof(ArgumentOutOfRangeException), () =>
             {
-                LongBuffer.Wrap(ba, -1, ba.Length);
+                Int64Buffer.Wrap(ba, -1, ba.Length);
             });
             tryCatch(ba, typeof(ArgumentOutOfRangeException), () =>
             {
-                LongBuffer.Wrap(ba, ba.Length + 1, ba.Length);
+                Int64Buffer.Wrap(ba, ba.Length + 1, ba.Length);
             });
             tryCatch(ba, typeof(ArgumentOutOfRangeException), () =>
             {
-                LongBuffer.Wrap(ba, 0, -1);
+                Int64Buffer.Wrap(ba, 0, -1);
             });
             tryCatch(ba, typeof(ArgumentOutOfRangeException), () =>
             {
-                LongBuffer.Wrap(ba, 0, ba.Length + 1);
+                Int64Buffer.Wrap(ba, 0, ba.Length + 1);
             });
 
             // A NullPointerException will be thrown if the array is null.
             tryCatch(ba, typeof(NullReferenceException), () =>
             {
-                LongBuffer.Wrap((long[])null, 0, 5);
+                Int64Buffer.Wrap((long[])null, 0, 5);
             });
             tryCatch(ba, typeof(NullReferenceException), () =>
             {
-                LongBuffer.Wrap((long[])null);
+                Int64Buffer.Wrap((long[])null);
             });
         }
 
@@ -503,7 +503,7 @@ namespace Lucene.Net.Support
             // An IllegalArgumentException will be thrown for negative capacities.
             tryCatch((Buffer)null, typeof(ArgumentException), () =>
             {
-                LongBuffer.Allocate(-1);
+                Int64Buffer.Allocate(-1);
             });
         }
 
@@ -511,11 +511,11 @@ namespace Lucene.Net.Support
         public static void Test()
         {
             TestAllocate();
-            test(0, LongBuffer.Allocate(7 * 1024), false);
-            test(0, LongBuffer.Wrap(new long[7 * 1024], 0, 7 * 1024), false);
+            test(0, Int64Buffer.Allocate(7 * 1024), false);
+            test(0, Int64Buffer.Wrap(new long[7 * 1024], 0, 7 * 1024), false);
             test(new long[1024]);
 
-            callReset(LongBuffer.Allocate(10));
+            callReset(Int64Buffer.Allocate(10));
             putBuffer();
 
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Tests/core/Util/Automaton/TestSpecialOperations.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Util/Automaton/TestSpecialOperations.cs b/src/Lucene.Net.Tests/core/Util/Automaton/TestSpecialOperations.cs
index 5eb06cc..106983b 100644
--- a/src/Lucene.Net.Tests/core/Util/Automaton/TestSpecialOperations.cs
+++ b/src/Lucene.Net.Tests/core/Util/Automaton/TestSpecialOperations.cs
@@ -48,12 +48,12 @@ namespace Lucene.Net.Util.Automaton
         {
             Automaton a = BasicOperations.Union(BasicAutomata.MakeString("dog"), BasicAutomata.MakeString("duck"));
             MinimizationOperations.Minimize(a);
-            ISet<IntsRef> strings = SpecialOperations.GetFiniteStrings(a, -1);
+            ISet<Int32sRef> strings = SpecialOperations.GetFiniteStrings(a, -1);
             Assert.AreEqual(2, strings.Count);
-            IntsRef dog = new IntsRef();
+            Int32sRef dog = new Int32sRef();
             Util.ToInt32sRef(new BytesRef("dog"), dog);
             Assert.IsTrue(strings.Contains(dog));
-            IntsRef duck = new IntsRef();
+            Int32sRef duck = new Int32sRef();
             Util.ToInt32sRef(new BytesRef("duck"), duck);
             Assert.IsTrue(strings.Contains(duck));
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Tests/core/Util/Fst/Test2BFST.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Util/Fst/Test2BFST.cs b/src/Lucene.Net.Tests/core/Util/Fst/Test2BFST.cs
index 7127487..4a22f6d 100644
--- a/src/Lucene.Net.Tests/core/Util/Fst/Test2BFST.cs
+++ b/src/Lucene.Net.Tests/core/Util/Fst/Test2BFST.cs
@@ -26,7 +26,7 @@ namespace Lucene.Net.Util.Fst
     using IndexOutput = Lucene.Net.Store.IndexOutput;
     using IOContext = Lucene.Net.Store.IOContext;
     using MMapDirectory = Lucene.Net.Store.MMapDirectory;
-    using PackedInts = Lucene.Net.Util.Packed.PackedInts;
+    using PackedInt32s = Lucene.Net.Util.Packed.PackedInt32s;
 
     //ORIGINAL LINE: @TimeoutSuite(millis = 100 * TimeUnits.HOUR) public class Test2BFST extends Lucene.Net.Util.LuceneTestCase
     [Ignore("Requires tons of heap to run (420G works)")]
@@ -39,7 +39,7 @@ namespace Lucene.Net.Util.Fst
         public virtual void Test()
         {
             int[] ints = new int[7];
-            IntsRef input = new IntsRef(ints, 0, ints.Length);
+            Int32sRef input = new Int32sRef(ints, 0, ints.Length);
             int seed = Random().Next();
 
             Directory dir = new MMapDirectory(CreateTempDir("2BFST"));
@@ -54,12 +54,12 @@ namespace Lucene.Net.Util.Fst
                     Console.WriteLine("\nTEST: 3B nodes; doPack=false output=NO_OUTPUTS");
                     Outputs<object> outputs = NoOutputs.Singleton;
                     object NO_OUTPUT = outputs.NoOutput;
-                    Builder<object> b = new Builder<object>(FST.INPUT_TYPE.BYTE1, 0, 0, true, true, int.MaxValue, outputs, null, doPack, PackedInts.COMPACT, true, 15);
+                    Builder<object> b = new Builder<object>(FST.INPUT_TYPE.BYTE1, 0, 0, true, true, int.MaxValue, outputs, null, doPack, PackedInt32s.COMPACT, true, 15);
 
                     int count = 0;
                     Random r = new Random(seed);
                     int[] ints2 = new int[200];
-                    IntsRef input2 = new IntsRef(ints2, 0, ints2.Length);
+                    Int32sRef input2 = new Int32sRef(ints2, 0, ints2.Length);
                     while (true)
                     {
                         //System.out.println("add: " + input + " -> " + output);
@@ -104,14 +104,14 @@ namespace Lucene.Net.Util.Fst
                         }
 
                         Console.WriteLine("\nTEST: enum all input/outputs");
-                        IntsRefFSTEnum<object> fstEnum = new IntsRefFSTEnum<object>(fst);
+                        Int32sRefFSTEnum<object> fstEnum = new Int32sRefFSTEnum<object>(fst);
 
                         Arrays.Fill(ints2, 0);
                         r = new Random(seed);
                         int upto = 0;
                         while (true)
                         {
-                            IntsRefFSTEnum.InputOutput<object> pair = fstEnum.Next();
+                            Int32sRefFSTEnum.InputOutput<object> pair = fstEnum.Next();
                             if (pair == null)
                             {
                                 break;
@@ -149,7 +149,7 @@ namespace Lucene.Net.Util.Fst
                 {
                     Console.WriteLine("\nTEST: 3 GB size; doPack=" + doPack + " outputs=bytes");
                     Outputs<BytesRef> outputs = ByteSequenceOutputs.Singleton;
-                    Builder<BytesRef> b = new Builder<BytesRef>(FST.INPUT_TYPE.BYTE1, 0, 0, true, true, int.MaxValue, outputs, null, doPack, PackedInts.COMPACT, true, 15);
+                    Builder<BytesRef> b = new Builder<BytesRef>(FST.INPUT_TYPE.BYTE1, 0, 0, true, true, int.MaxValue, outputs, null, doPack, PackedInt32s.COMPACT, true, 15);
 
                     var outputBytes = new byte[20];
                     BytesRef output = new BytesRef(outputBytes);
@@ -193,14 +193,14 @@ namespace Lucene.Net.Util.Fst
                         }
 
                         Console.WriteLine("\nTEST: enum all input/outputs");
-                        IntsRefFSTEnum<BytesRef> fstEnum = new IntsRefFSTEnum<BytesRef>(fst);
+                        Int32sRefFSTEnum<BytesRef> fstEnum = new Int32sRefFSTEnum<BytesRef>(fst);
 
                         Arrays.Fill(ints, 0);
                         r = new Random(seed);
                         int upto = 0;
                         while (true)
                         {
-                            IntsRefFSTEnum.InputOutput<BytesRef> pair = fstEnum.Next();
+                            Int32sRefFSTEnum.InputOutput<BytesRef> pair = fstEnum.Next();
                             if (pair == null)
                             {
                                 break;
@@ -234,8 +234,8 @@ namespace Lucene.Net.Util.Fst
                 // size = 3GB
                 {
                     Console.WriteLine("\nTEST: 3 GB size; doPack=" + doPack + " outputs=long");
-                    Outputs<long?> outputs = PositiveIntOutputs.Singleton;
-                    Builder<long?> b = new Builder<long?>(FST.INPUT_TYPE.BYTE1, 0, 0, true, true, int.MaxValue, outputs, null, doPack, PackedInts.COMPACT, true, 15);
+                    Outputs<long?> outputs = PositiveInt32Outputs.Singleton;
+                    Builder<long?> b = new Builder<long?>(FST.INPUT_TYPE.BYTE1, 0, 0, true, true, int.MaxValue, outputs, null, doPack, PackedInt32s.COMPACT, true, 15);
 
                     long output = 1;
 
@@ -285,7 +285,7 @@ namespace Lucene.Net.Util.Fst
                         }
 
                         Console.WriteLine("\nTEST: enum all input/outputs");
-                        IntsRefFSTEnum<long?> fstEnum = new IntsRefFSTEnum<long?>(fst);
+                        Int32sRefFSTEnum<long?> fstEnum = new Int32sRefFSTEnum<long?>(fst);
 
                         Arrays.Fill(ints, 0);
                         r = new Random(seed);
@@ -293,7 +293,7 @@ namespace Lucene.Net.Util.Fst
                         output = 1;
                         while (true)
                         {
-                            IntsRefFSTEnum.InputOutput<long?> pair = fstEnum.Next();
+                            Int32sRefFSTEnum.InputOutput<long?> pair = fstEnum.Next();
                             if (pair == null)
                             {
                                 break;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Tests/core/Util/Fst/TestFSTs.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Util/Fst/TestFSTs.cs b/src/Lucene.Net.Tests/core/Util/Fst/TestFSTs.cs
index 83b3f07..a69292c 100644
--- a/src/Lucene.Net.Tests/core/Util/Fst/TestFSTs.cs
+++ b/src/Lucene.Net.Tests/core/Util/Fst/TestFSTs.cs
@@ -53,7 +53,7 @@ namespace Lucene.Net.Util.Fst
     //using ResultLong = Lucene.Net.Util.Fst.Util.Result<long?>;
     //using ResultPair = Lucene.Net.Util.Fst.Util.Result<long?>;
     using OpenMode = Lucene.Net.Index.OpenMode;
-    using PackedInts = Lucene.Net.Util.Packed.PackedInts;
+    using PackedInt32s = Lucene.Net.Util.Packed.PackedInt32s;
     using Pair = Lucene.Net.Util.Fst.PairOutputs<long?, long?>.Pair;
     using RandomIndexWriter = Lucene.Net.Index.RandomIndexWriter;
     using RegExp = Lucene.Net.Util.Automaton.RegExp;
@@ -93,8 +93,8 @@ namespace Lucene.Net.Util.Fst
         {
             string[] strings = new string[] { "station", "commotion", "elation", "elastic", "plastic", "stop", "ftop", "ftation", "stat" };
             string[] strings2 = new string[] { "station", "commotion", "elation", "elastic", "plastic", "stop", "ftop", "ftation" };
-            IntsRef[] terms = new IntsRef[strings.Length];
-            IntsRef[] terms2 = new IntsRef[strings2.Length];
+            Int32sRef[] terms = new Int32sRef[strings.Length];
+            Int32sRef[] terms2 = new Int32sRef[strings2.Length];
             for (int inputMode = 0; inputMode < 2; inputMode++)
             {
                 if (VERBOSE)
@@ -121,7 +121,7 @@ namespace Lucene.Net.Util.Fst
                     Outputs<object> outputs = NoOutputs.Singleton;
                     object NO_OUTPUT = outputs.NoOutput;
                     List<FSTTester<object>.InputOutput<object>> pairs = new List<FSTTester<object>.InputOutput<object>>(terms2.Length);
-                    foreach (IntsRef term in terms2)
+                    foreach (Int32sRef term in terms2)
                     {
                         pairs.Add(new FSTTester<object>.InputOutput<object>(term, NO_OUTPUT));
                     }
@@ -133,7 +133,7 @@ namespace Lucene.Net.Util.Fst
 
                 // FST ord pos int
                 {
-                    PositiveIntOutputs outputs = PositiveIntOutputs.Singleton;
+                    PositiveInt32Outputs outputs = PositiveInt32Outputs.Singleton;
                     List<FSTTester<long?>.InputOutput<long?>> pairs = new List<FSTTester<long?>.InputOutput<long?>>(terms2.Length);
                     for (int idx = 0; idx < terms2.Length; idx++)
                     {
@@ -164,7 +164,7 @@ namespace Lucene.Net.Util.Fst
         }
 
         // given set of terms, test the different outputs for them
-        private void DoTest(int inputMode, IntsRef[] terms)
+        private void DoTest(int inputMode, Int32sRef[] terms)
         {
             Array.Sort(terms);
 
@@ -173,7 +173,7 @@ namespace Lucene.Net.Util.Fst
                 Outputs<object> outputs = NoOutputs.Singleton;
                 object NO_OUTPUT = outputs.NoOutput;
                 List<FSTTester<object>.InputOutput<object>> pairs = new List<FSTTester<object>.InputOutput<object>>(terms.Length);
-                foreach (IntsRef term in terms)
+                foreach (Int32sRef term in terms)
                 {
                     pairs.Add(new FSTTester<object>.InputOutput<object>(term, NO_OUTPUT));
                 }
@@ -182,7 +182,7 @@ namespace Lucene.Net.Util.Fst
 
             // PositiveIntOutput (ord)
             {
-                PositiveIntOutputs outputs = PositiveIntOutputs.Singleton;
+                PositiveInt32Outputs outputs = PositiveInt32Outputs.Singleton;
                 List<FSTTester<long?>.InputOutput<long?>> pairs = new List<FSTTester<long?>.InputOutput<long?>>(terms.Length);
                 for (int idx = 0; idx < terms.Length; idx++)
                 {
@@ -193,7 +193,7 @@ namespace Lucene.Net.Util.Fst
 
             // PositiveIntOutput (random monotonically increasing positive number)
             {
-                PositiveIntOutputs outputs = PositiveIntOutputs.Singleton;
+                PositiveInt32Outputs outputs = PositiveInt32Outputs.Singleton;
                 List<FSTTester<long?>.InputOutput<long?>> pairs = new List<FSTTester<long?>.InputOutput<long?>>(terms.Length);
                 long lastOutput = 0;
                 for (int idx = 0; idx < terms.Length; idx++)
@@ -207,7 +207,7 @@ namespace Lucene.Net.Util.Fst
 
             // PositiveIntOutput (random positive number)
             {
-                PositiveIntOutputs outputs = PositiveIntOutputs.Singleton;
+                PositiveInt32Outputs outputs = PositiveInt32Outputs.Singleton;
                 List<FSTTester<long?>.InputOutput<long?>> pairs = new List<FSTTester<long?>.InputOutput<long?>>(terms.Length);
                 for (int idx = 0; idx < terms.Length; idx++)
                 {
@@ -218,8 +218,8 @@ namespace Lucene.Net.Util.Fst
 
             // Pair<ord, (random monotonically increasing positive number>
             {
-                PositiveIntOutputs o1 = PositiveIntOutputs.Singleton;
-                PositiveIntOutputs o2 = PositiveIntOutputs.Singleton;
+                PositiveInt32Outputs o1 = PositiveInt32Outputs.Singleton;
+                PositiveInt32Outputs o2 = PositiveInt32Outputs.Singleton;
                 PairOutputs<long?, long?> outputs = new PairOutputs<long?, long?>(o1, o2);
                 List<FSTTester<Pair>.InputOutput<Pair>> pairs = new List<FSTTester<Pair>.InputOutput<Pair>>(terms.Length);
                 long lastOutput = 0;
@@ -247,20 +247,20 @@ namespace Lucene.Net.Util.Fst
 
             // Sequence-of-ints
             {
-                IntSequenceOutputs outputs = IntSequenceOutputs.Singleton;
-                List<FSTTester<IntsRef>.InputOutput<IntsRef>> pairs = new List<FSTTester<IntsRef>.InputOutput<IntsRef>>(terms.Length);
+                Int32SequenceOutputs outputs = Int32SequenceOutputs.Singleton;
+                List<FSTTester<Int32sRef>.InputOutput<Int32sRef>> pairs = new List<FSTTester<Int32sRef>.InputOutput<Int32sRef>>(terms.Length);
                 for (int idx = 0; idx < terms.Length; idx++)
                 {
                     string s = Convert.ToString(idx);
-                    IntsRef output = new IntsRef(s.Length);
+                    Int32sRef output = new Int32sRef(s.Length);
                     output.Length = s.Length;
                     for (int idx2 = 0; idx2 < output.Length; idx2++)
                     {
                         output.Int32s[idx2] = s[idx2];
                     }
-                    pairs.Add(new FSTTester<IntsRef>.InputOutput<IntsRef>(terms[idx], output));
+                    pairs.Add(new FSTTester<Int32sRef>.InputOutput<Int32sRef>(terms[idx], output));
                 }
-                (new FSTTester<IntsRef>(Random(), Dir, inputMode, pairs, outputs, false)).DoTest(true);
+                (new FSTTester<Int32sRef>(Random(), Dir, inputMode, pairs, outputs, false)).DoTest(true);
             }
 
         }
@@ -302,8 +302,8 @@ namespace Lucene.Net.Util.Fst
                 for (int inputMode = 0; inputMode < 2; inputMode++)
                 {
                     int numWords = random.Next(maxNumWords + 1);
-                    HashSet<IntsRef> termsSet = new HashSet<IntsRef>();
-                    IntsRef[] terms = new IntsRef[numWords];
+                    HashSet<Int32sRef> termsSet = new HashSet<Int32sRef>();
+                    Int32sRef[] terms = new Int32sRef[numWords];
                     while (termsSet.Count < numWords)
                     {
                         string term = FSTTester<object>.GetRandomString(random);
@@ -346,11 +346,11 @@ namespace Lucene.Net.Util.Fst
             }
             IndexReader r = DirectoryReader.Open(writer, true);
             writer.Dispose();
-            PositiveIntOutputs outputs = PositiveIntOutputs.Singleton;
+            PositiveInt32Outputs outputs = PositiveInt32Outputs.Singleton;
 
             bool doRewrite = Random().NextBoolean();
 
-            Builder<long?> builder = new Builder<long?>(FST.INPUT_TYPE.BYTE1, 0, 0, true, true, int.MaxValue, outputs, null, doRewrite, PackedInts.DEFAULT, true, 15);
+            Builder<long?> builder = new Builder<long?>(FST.INPUT_TYPE.BYTE1, 0, 0, true, true, int.MaxValue, outputs, null, doRewrite, PackedInt32s.DEFAULT, true, 15);
 
             bool storeOrd = Random().NextBoolean();
             if (VERBOSE)
@@ -367,7 +367,7 @@ namespace Lucene.Net.Util.Fst
             Terms terms = MultiFields.GetTerms(r, "body");
             if (terms != null)
             {
-                IntsRef scratchIntsRef = new IntsRef();
+                Int32sRef scratchIntsRef = new Int32sRef();
                 TermsEnum termsEnum = terms.GetIterator(null);
                 if (VERBOSE)
                 {
@@ -536,17 +536,17 @@ namespace Lucene.Net.Util.Fst
                 this.Outputs = outputs;
                 this.DoPack = doPack;
 
-                Builder = new Builder<T>(inputMode == 0 ? FST.INPUT_TYPE.BYTE1 : FST.INPUT_TYPE.BYTE4, 0, prune, prune == 0, true, int.MaxValue, outputs, null, doPack, PackedInts.DEFAULT, !noArcArrays, 15);
+                Builder = new Builder<T>(inputMode == 0 ? FST.INPUT_TYPE.BYTE1 : FST.INPUT_TYPE.BYTE4, 0, prune, prune == 0, true, int.MaxValue, outputs, null, doPack, PackedInt32s.DEFAULT, !noArcArrays, 15);
             }
 
-            protected internal abstract T GetOutput(IntsRef input, int ord);
+            protected internal abstract T GetOutput(Int32sRef input, int ord);
 
             public virtual void Run(int limit, bool verify, bool verifyByOutput)
             {
                 TextReader @is = new StreamReader(new FileStream(WordsFileIn, FileMode.Open), Encoding.UTF8);
                 try
                 {
-                    IntsRef intsRef = new IntsRef(10);
+                    Int32sRef intsRef = new Int32sRef(10);
                     long tStart = Environment.TickCount;
                     int ord = 0;
                     while (true)
@@ -650,7 +650,7 @@ namespace Lucene.Net.Util.Fst
                                 {
                                     // Get by output
                                     long? output = GetOutput(intsRef, ord) as long?;
-                                    IntsRef actual = Util.GetByOutput(fst as FST<long?>, output.GetValueOrDefault());
+                                    Int32sRef actual = Util.GetByOutput(fst as FST<long?>, output.GetValueOrDefault());
                                     if (actual == null)
                                     {
                                         throw new Exception("unexpected null input from output=" + output);
@@ -826,7 +826,7 @@ namespace Lucene.Net.Util.Fst
             }
 
             internal Random rand;
-            protected internal override Pair GetOutput(IntsRef input, int ord)
+            protected internal override Pair GetOutput(Int32sRef input, int ord)
             {
                 if (ord == 0)
                 {
@@ -838,12 +838,12 @@ namespace Lucene.Net.Util.Fst
 
         private class VisitTermsAnonymousInnerClassHelper2 : VisitTerms<long?>
         {
-            public VisitTermsAnonymousInnerClassHelper2(string dirOut, string wordsFileIn, int inputMode, int prune, PositiveIntOutputs outputs, bool doPack, bool noArcArrays)
+            public VisitTermsAnonymousInnerClassHelper2(string dirOut, string wordsFileIn, int inputMode, int prune, PositiveInt32Outputs outputs, bool doPack, bool noArcArrays)
                 : base(dirOut, wordsFileIn, inputMode, prune, outputs, doPack, noArcArrays)
             {
             }
 
-            protected internal override long? GetOutput(IntsRef input, int ord)
+            protected internal override long? GetOutput(Int32sRef input, int ord)
             {
                 return ord;
             }
@@ -851,13 +851,13 @@ namespace Lucene.Net.Util.Fst
 
         private class VisitTermsAnonymousInnerClassHelper3 : VisitTerms<long?>
         {
-            public VisitTermsAnonymousInnerClassHelper3(string dirOut, string wordsFileIn, int inputMode, int prune, PositiveIntOutputs outputs, bool doPack, bool noArcArrays)
+            public VisitTermsAnonymousInnerClassHelper3(string dirOut, string wordsFileIn, int inputMode, int prune, PositiveInt32Outputs outputs, bool doPack, bool noArcArrays)
                 : base(dirOut, wordsFileIn, inputMode, prune, outputs, doPack, noArcArrays)
             {
             }
 
             internal Random rand;
-            protected internal override long? GetOutput(IntsRef input, int ord)
+            protected internal override long? GetOutput(Int32sRef input, int ord)
             {
                 if (ord == 0)
                 {
@@ -877,7 +877,7 @@ namespace Lucene.Net.Util.Fst
                 this.NO_OUTPUT = NO_OUTPUT;
             }
 
-            protected internal override object GetOutput(IntsRef input, int ord)
+            protected internal override object GetOutput(Int32sRef input, int ord)
             {
                 return NO_OUTPUT;
             }
@@ -888,7 +888,7 @@ namespace Lucene.Net.Util.Fst
         {
             Outputs<object> outputs = NoOutputs.Singleton;
             Builder<object> b = new Builder<object>(FST.INPUT_TYPE.BYTE1, outputs);
-            b.Add(Util.ToInt32sRef(new BytesRef("foobar"), new IntsRef()), outputs.NoOutput);
+            b.Add(Util.ToInt32sRef(new BytesRef("foobar"), new Int32sRef()), outputs.NoOutput);
             BytesRefFSTEnum<object> fstEnum = new BytesRefFSTEnum<object>(b.Finish());
             Assert.IsNull(fstEnum.SeekFloor(new BytesRef("foo")));
             Assert.IsNull(fstEnum.SeekCeil(new BytesRef("foobaz")));
@@ -901,7 +901,7 @@ namespace Lucene.Net.Util.Fst
             string str = "foobar";
             Outputs<object> outputs = NoOutputs.Singleton;
             Builder<object> b = new Builder<object>(FST.INPUT_TYPE.BYTE1, outputs);
-            IntsRef ints = new IntsRef();
+            Int32sRef ints = new Int32sRef();
             for (int i = 0; i < 10; i++)
             {
                 b.Add(Util.ToInt32sRef(new BytesRef(str), ints), outputs.NoOutput);
@@ -970,7 +970,7 @@ namespace Lucene.Net.Util.Fst
             // smaller FST if the outputs grow monotonically.  But
             // if numbers are "random", false should give smaller
             // final size:
-            PositiveIntOutputs outputs = PositiveIntOutputs.Singleton;
+            PositiveInt32Outputs outputs = PositiveInt32Outputs.Singleton;
 
             // Build an FST mapping BytesRef -> Long
             Builder<long?> builder = new Builder<long?>(FST.INPUT_TYPE.BYTE1, outputs);
@@ -979,9 +979,9 @@ namespace Lucene.Net.Util.Fst
             BytesRef b = new BytesRef("b");
             BytesRef c = new BytesRef("c");
 
-            builder.Add(Util.ToInt32sRef(a, new IntsRef()), 17L);
-            builder.Add(Util.ToInt32sRef(b, new IntsRef()), 42L);
-            builder.Add(Util.ToInt32sRef(c, new IntsRef()), 13824324872317238L);
+            builder.Add(Util.ToInt32sRef(a, new Int32sRef()), 17L);
+            builder.Add(Util.ToInt32sRef(b, new Int32sRef()), 42L);
+            builder.Add(Util.ToInt32sRef(c, new Int32sRef()), 13824324872317238L);
 
             FST<long?> fst = builder.Finish();
 
@@ -1006,10 +1006,10 @@ namespace Lucene.Net.Util.Fst
             Assert.AreEqual(b, seekResult.Input);
             Assert.AreEqual(42, seekResult.Output);
 
-            Assert.AreEqual(Util.ToInt32sRef(new BytesRef("c"), new IntsRef()), Util.GetByOutput(fst, 13824324872317238L));
+            Assert.AreEqual(Util.ToInt32sRef(new BytesRef("c"), new Int32sRef()), Util.GetByOutput(fst, 13824324872317238L));
             Assert.IsNull(Util.GetByOutput(fst, 47));
-            Assert.AreEqual(Util.ToInt32sRef(new BytesRef("b"), new IntsRef()), Util.GetByOutput(fst, 42));
-            Assert.AreEqual(Util.ToInt32sRef(new BytesRef("a"), new IntsRef()), Util.GetByOutput(fst, 17));
+            Assert.AreEqual(Util.ToInt32sRef(new BytesRef("b"), new Int32sRef()), Util.GetByOutput(fst, 42));
+            Assert.AreEqual(Util.ToInt32sRef(new BytesRef("a"), new Int32sRef()), Util.GetByOutput(fst, 17));
         }
 
         [Test]
@@ -1277,7 +1277,7 @@ namespace Lucene.Net.Util.Fst
 
                 int line = 0;
                 BytesRef term = new BytesRef();
-                IntsRef scratchIntsRef = new IntsRef();
+                Int32sRef scratchIntsRef = new Int32sRef();
 
                 while (line < lines.Length)
                 {
@@ -1338,11 +1338,11 @@ namespace Lucene.Net.Util.Fst
         [Test]
         public virtual void TestFinalOutputOnEndState()
         {
-            PositiveIntOutputs outputs = PositiveIntOutputs.Singleton;
+            PositiveInt32Outputs outputs = PositiveInt32Outputs.Singleton;
 
-            Builder<long?> builder = new Builder<long?>(FST.INPUT_TYPE.BYTE4, 2, 0, true, true, int.MaxValue, outputs, null, Random().NextBoolean(), PackedInts.DEFAULT, true, 15);
-            builder.Add(Util.ToUTF32("stat", new IntsRef()), 17L);
-            builder.Add(Util.ToUTF32("station", new IntsRef()), 10L);
+            Builder<long?> builder = new Builder<long?>(FST.INPUT_TYPE.BYTE4, 2, 0, true, true, int.MaxValue, outputs, null, Random().NextBoolean(), PackedInt32s.DEFAULT, true, 15);
+            builder.Add(Util.ToUTF32("stat", new Int32sRef()), 17L);
+            builder.Add(Util.ToUTF32("station", new Int32sRef()), 10L);
             FST<long?> fst = builder.Finish();
             //Writer w = new OutputStreamWriter(new FileOutputStream("/x/tmp3/out.dot"));
             StringWriter w = new StringWriter();
@@ -1355,11 +1355,11 @@ namespace Lucene.Net.Util.Fst
         [Test]
         public virtual void TestInternalFinalState()
         {
-            PositiveIntOutputs outputs = PositiveIntOutputs.Singleton;
+            PositiveInt32Outputs outputs = PositiveInt32Outputs.Singleton;
             bool willRewrite = Random().NextBoolean();
-            Builder<long?> builder = new Builder<long?>(FST.INPUT_TYPE.BYTE1, 0, 0, true, true, int.MaxValue, outputs, null, willRewrite, PackedInts.DEFAULT, true, 15);
-            builder.Add(Util.ToInt32sRef(new BytesRef("stat"), new IntsRef()), outputs.NoOutput);
-            builder.Add(Util.ToInt32sRef(new BytesRef("station"), new IntsRef()), outputs.NoOutput);
+            Builder<long?> builder = new Builder<long?>(FST.INPUT_TYPE.BYTE1, 0, 0, true, true, int.MaxValue, outputs, null, willRewrite, PackedInt32s.DEFAULT, true, 15);
+            builder.Add(Util.ToInt32sRef(new BytesRef("stat"), new Int32sRef()), outputs.NoOutput);
+            builder.Add(Util.ToInt32sRef(new BytesRef("station"), new Int32sRef()), outputs.NoOutput);
             FST<long?> fst = builder.Finish();
             StringWriter w = new StringWriter();
             //Writer w = new OutputStreamWriter(new FileOutputStream("/x/tmp/out.dot"));
@@ -1378,11 +1378,11 @@ namespace Lucene.Net.Util.Fst
         [Test]
         public virtual void TestNonFinalStopNode()
         {
-            PositiveIntOutputs outputs = PositiveIntOutputs.Singleton;
+            PositiveInt32Outputs outputs = PositiveInt32Outputs.Singleton;
             long? nothing = outputs.NoOutput;
             Builder<long?> b = new Builder<long?>(FST.INPUT_TYPE.BYTE1, outputs);
 
-            FST<long?> fst = new FST<long?>(FST.INPUT_TYPE.BYTE1, outputs, false, PackedInts.COMPACT, true, 15);
+            FST<long?> fst = new FST<long?>(FST.INPUT_TYPE.BYTE1, outputs, false, PackedInt32s.COMPACT, true, 15);
 
             Builder.UnCompiledNode<long?> rootNode = new Builder.UnCompiledNode<long?>(b, 0);
 
@@ -1432,7 +1432,7 @@ namespace Lucene.Net.Util.Fst
             dir.Dispose();
         }
 
-        private void CheckStopNodes(FST<long?> fst, PositiveIntOutputs outputs)
+        private void CheckStopNodes(FST<long?> fst, PositiveInt32Outputs outputs)
         {
             long? nothing = outputs.NoOutput;
             FST.Arc<long?> startArc = fst.GetFirstArc(new FST.Arc<long?>());
@@ -1467,10 +1467,10 @@ namespace Lucene.Net.Util.Fst
         [Test]
         public virtual void TestShortestPaths()
         {
-            PositiveIntOutputs outputs = PositiveIntOutputs.Singleton;
+            PositiveInt32Outputs outputs = PositiveInt32Outputs.Singleton;
             Builder<long?> builder = new Builder<long?>(FST.INPUT_TYPE.BYTE1, outputs);
 
-            IntsRef scratch = new IntsRef();
+            Int32sRef scratch = new Int32sRef();
             builder.Add(Util.ToInt32sRef(new BytesRef("aab"), scratch), 22L);
             builder.Add(Util.ToInt32sRef(new BytesRef("aac"), scratch), 7L);
             builder.Add(Util.ToInt32sRef(new BytesRef("ax"), scratch), 17L);
@@ -1495,10 +1495,10 @@ namespace Lucene.Net.Util.Fst
         [Test]
         public virtual void TestRejectNoLimits()
         {
-            PositiveIntOutputs outputs = PositiveIntOutputs.Singleton;
+            PositiveInt32Outputs outputs = PositiveInt32Outputs.Singleton;
             Builder<long?> builder = new Builder<long?>(FST.INPUT_TYPE.BYTE1, outputs);
 
-            IntsRef scratch = new IntsRef();
+            Int32sRef scratch = new Int32sRef();
             builder.Add(Util.ToInt32sRef(new BytesRef("aab"), scratch), 22L);
             builder.Add(Util.ToInt32sRef(new BytesRef("aac"), scratch), 7L);
             builder.Add(Util.ToInt32sRef(new BytesRef("adcd"), scratch), 17L);
@@ -1506,10 +1506,10 @@ namespace Lucene.Net.Util.Fst
 
             builder.Add(Util.ToInt32sRef(new BytesRef("ax"), scratch), 17L);
             FST<long?> fst = builder.Finish();
-            AtomicInteger rejectCount = new AtomicInteger();
+            AtomicInt32 rejectCount = new AtomicInt32();
             Util.TopNSearcher<long?> searcher = new TopNSearcherAnonymousInnerClassHelper(this, fst, minLongComparer, rejectCount);
 
-            searcher.AddStartPaths(fst.GetFirstArc(new FST.Arc<long?>()), outputs.NoOutput, true, new IntsRef());
+            searcher.AddStartPaths(fst.GetFirstArc(new FST.Arc<long?>()), outputs.NoOutput, true, new Int32sRef());
             Util.TopResults<long?> res = searcher.Search();
             Assert.AreEqual(rejectCount.Get(), 4);
             Assert.IsTrue(res.IsComplete); // rejected(4) + topN(2) <= maxQueueSize(6)
@@ -1520,7 +1520,7 @@ namespace Lucene.Net.Util.Fst
             rejectCount.Set(0);
             searcher = new TopNSearcherAnonymousInnerClassHelper2(this, fst, minLongComparer, rejectCount);
 
-            searcher.AddStartPaths(fst.GetFirstArc(new FST.Arc<long?>()), outputs.NoOutput, true, new IntsRef());
+            searcher.AddStartPaths(fst.GetFirstArc(new FST.Arc<long?>()), outputs.NoOutput, true, new Int32sRef());
             res = searcher.Search();
             Assert.AreEqual(rejectCount.Get(), 4);
             Assert.IsFalse(res.IsComplete); // rejected(4) + topN(2) > maxQueueSize(5)
@@ -1530,16 +1530,16 @@ namespace Lucene.Net.Util.Fst
         {
             private readonly TestFSTs OuterInstance;
 
-            private AtomicInteger RejectCount;
+            private AtomicInt32 RejectCount;
 
-            public TopNSearcherAnonymousInnerClassHelper(TestFSTs outerInstance, FST<long?> fst, IComparer<long?> minLongComparer, AtomicInteger rejectCount)
+            public TopNSearcherAnonymousInnerClassHelper(TestFSTs outerInstance, FST<long?> fst, IComparer<long?> minLongComparer, AtomicInt32 rejectCount)
                 : base(fst, 2, 6, minLongComparer)
             {
                 this.OuterInstance = outerInstance;
                 this.RejectCount = rejectCount;
             }
 
-            protected override bool AcceptResult(IntsRef input, long? output)
+            protected override bool AcceptResult(Int32sRef input, long? output)
             {
                 bool accept = (int)output == 7;
                 if (!accept)
@@ -1554,16 +1554,16 @@ namespace Lucene.Net.Util.Fst
         {
             private readonly TestFSTs OuterInstance;
 
-            private AtomicInteger RejectCount;
+            private AtomicInt32 RejectCount;
 
-            public TopNSearcherAnonymousInnerClassHelper2(TestFSTs outerInstance, FST<long?> fst, IComparer<long?> minLongComparer, AtomicInteger rejectCount)
+            public TopNSearcherAnonymousInnerClassHelper2(TestFSTs outerInstance, FST<long?> fst, IComparer<long?> minLongComparer, AtomicInt32 rejectCount)
                 : base(fst, 2, 5, minLongComparer)
             {
                 this.OuterInstance = outerInstance;
                 this.RejectCount = rejectCount;
             }
 
-            protected override bool AcceptResult(IntsRef input, long? output)
+            protected override bool AcceptResult(Int32sRef input, long? output)
             {
                 bool accept = (int)output == 7;
                 if (!accept)
@@ -1595,11 +1595,11 @@ namespace Lucene.Net.Util.Fst
         public virtual void TestShortestPathsWFST()
         {
 
-            PairOutputs<long?, long?> outputs = new PairOutputs<long?, long?>(PositiveIntOutputs.Singleton, PositiveIntOutputs.Singleton); // output -  weight
+            PairOutputs<long?, long?> outputs = new PairOutputs<long?, long?>(PositiveInt32Outputs.Singleton, PositiveInt32Outputs.Singleton); // output -  weight
 
             Builder<Pair> builder = new Builder<Pair>(FST.INPUT_TYPE.BYTE1, outputs);
 
-            IntsRef scratch = new IntsRef();
+            Int32sRef scratch = new Int32sRef();
             builder.Add(Util.ToInt32sRef(new BytesRef("aab"), scratch), outputs.NewPair(22L, 57L));
             builder.Add(Util.ToInt32sRef(new BytesRef("aac"), scratch), outputs.NewPair(7L, 36L));
             builder.Add(Util.ToInt32sRef(new BytesRef("ax"), scratch), outputs.NewPair(17L, 85L));
@@ -1634,9 +1634,9 @@ namespace Lucene.Net.Util.Fst
             SortedDictionary<string, long> slowCompletor = new SortedDictionary<string, long>();
             SortedSet<string> allPrefixes = new SortedSet<string>();
 
-            PositiveIntOutputs outputs = PositiveIntOutputs.Singleton;
+            PositiveInt32Outputs outputs = PositiveInt32Outputs.Singleton;
             Builder<long?> builder = new Builder<long?>(FST.INPUT_TYPE.BYTE1, outputs);
-            IntsRef scratch = new IntsRef();
+            Int32sRef scratch = new Int32sRef();
 
             for (int i = 0; i < numWords; i++)
             {
@@ -1703,7 +1703,7 @@ namespace Lucene.Net.Util.Fst
                     if (e.Key.StartsWith(prefix))
                     {
                         //System.out.println("  consider " + e.getKey());
-                        matches.Add(new Util.Result<long?>(Util.ToInt32sRef(new BytesRef(e.Key.Substring(prefix.Length)), new IntsRef()), e.Value - prefixOutput));
+                        matches.Add(new Util.Result<long?>(Util.ToInt32sRef(new BytesRef(e.Key.Substring(prefix.Length)), new Int32sRef()), e.Value - prefixOutput));
                     }
                 }
 
@@ -1773,9 +1773,9 @@ namespace Lucene.Net.Util.Fst
             SortedDictionary<string, TwoLongs> slowCompletor = new SortedDictionary<string, TwoLongs>();
             SortedSet<string> allPrefixes = new SortedSet<string>();
 
-            PairOutputs<long?, long?> outputs = new PairOutputs<long?, long?>(PositiveIntOutputs.Singleton, PositiveIntOutputs.Singleton); // output -  weight
+            PairOutputs<long?, long?> outputs = new PairOutputs<long?, long?>(PositiveInt32Outputs.Singleton, PositiveInt32Outputs.Singleton); // output -  weight
             Builder<Pair> builder = new Builder<Pair>(FST.INPUT_TYPE.BYTE1, outputs);
-            IntsRef scratch = new IntsRef();
+            Int32sRef scratch = new Int32sRef();
 
             Random random = Random();
             for (int i = 0; i < numWords; i++)
@@ -1845,7 +1845,7 @@ namespace Lucene.Net.Util.Fst
                     if (e.Key.StartsWith(prefix))
                     {
                         //System.out.println("  consider " + e.getKey());
-                        matches.Add(new Util.Result<Pair>(Util.ToInt32sRef(new BytesRef(e.Key.Substring(prefix.Length)), new IntsRef()),
+                        matches.Add(new Util.Result<Pair>(Util.ToInt32sRef(new BytesRef(e.Key.Substring(prefix.Length)), new Int32sRef()),
                             outputs.NewPair(e.Value.a - prefixOutput.Output1, e.Value.b - prefixOutput.Output2)));
                     }
                 }
@@ -1875,7 +1875,7 @@ namespace Lucene.Net.Util.Fst
             Builder<BytesRef> builder = new Builder<BytesRef>(FST.INPUT_TYPE.BYTE1, outputs);
 
             byte[] bytes = new byte[300];
-            IntsRef input = new IntsRef();
+            Int32sRef input = new Int32sRef();
             input.Grow(1);
             input.Length = 1;
             BytesRef output = new BytesRef(bytes);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Tests/core/Util/Packed/TestPackedInts.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Util/Packed/TestPackedInts.cs b/src/Lucene.Net.Tests/core/Util/Packed/TestPackedInts.cs
index 35de442..6c64516 100644
--- a/src/Lucene.Net.Tests/core/Util/Packed/TestPackedInts.cs
+++ b/src/Lucene.Net.Tests/core/Util/Packed/TestPackedInts.cs
@@ -34,7 +34,7 @@ namespace Lucene.Net.Util.Packed
     using IndexOutput = Lucene.Net.Store.IndexOutput;
     using RAMDirectory = Lucene.Net.Store.RAMDirectory;
     //using Slow = Lucene.Net.Util.LuceneTestCase.Slow;
-    using Reader = Lucene.Net.Util.Packed.PackedInts.Reader;
+    using Reader = Lucene.Net.Util.Packed.PackedInt32s.Reader;
     using Attributes;
 
     [TestFixture]
@@ -47,14 +47,14 @@ namespace Lucene.Net.Util.Packed
             for (int i = 0; i < iters; ++i)
             {
                 int valueCount = RandomInts.NextIntBetween(Random(), 1, int.MaxValue);
-                foreach (PackedInts.Format format in PackedInts.Format.Values())
+                foreach (PackedInt32s.Format format in PackedInt32s.Format.Values())
                 {
                     for (int bpv = 1; bpv <= 64; ++bpv)
                     {
-                        long byteCount = format.ByteCount(PackedInts.VERSION_CURRENT, valueCount, bpv);
+                        long byteCount = format.ByteCount(PackedInt32s.VERSION_CURRENT, valueCount, bpv);
                         string msg = "format=" + format + ", byteCount=" + byteCount + ", valueCount=" + valueCount + ", bpv=" + bpv;
                         Assert.IsTrue(byteCount * 8 >= (long)valueCount * bpv, msg);
-                        if (format == PackedInts.Format.PACKED)
+                        if (format == PackedInt32s.Format.PACKED)
                         {
                             Assert.IsTrue((byteCount - 1) * 8 < (long)valueCount * bpv, msg);
                         }
@@ -66,20 +66,20 @@ namespace Lucene.Net.Util.Packed
         [Test]
         public virtual void TestBitsRequired()
         {
-            Assert.AreEqual(61, PackedInts.BitsRequired((long)Math.Pow(2, 61) - 1));
-            Assert.AreEqual(61, PackedInts.BitsRequired(0x1FFFFFFFFFFFFFFFL));
-            Assert.AreEqual(62, PackedInts.BitsRequired(0x3FFFFFFFFFFFFFFFL));
-            Assert.AreEqual(63, PackedInts.BitsRequired(0x7FFFFFFFFFFFFFFFL));
+            Assert.AreEqual(61, PackedInt32s.BitsRequired((long)Math.Pow(2, 61) - 1));
+            Assert.AreEqual(61, PackedInt32s.BitsRequired(0x1FFFFFFFFFFFFFFFL));
+            Assert.AreEqual(62, PackedInt32s.BitsRequired(0x3FFFFFFFFFFFFFFFL));
+            Assert.AreEqual(63, PackedInt32s.BitsRequired(0x7FFFFFFFFFFFFFFFL));
         }
 
         [Test]
         public virtual void TestMaxValues()
         {
-            Assert.AreEqual(1, PackedInts.MaxValue(1), "1 bit -> max == 1");
-            Assert.AreEqual(3, PackedInts.MaxValue(2), "2 bit -> max == 3");
-            Assert.AreEqual(255, PackedInts.MaxValue(8), "8 bit -> max == 255");
-            Assert.AreEqual(long.MaxValue, PackedInts.MaxValue(63), "63 bit -> max == Long.MAX_VALUE");
-            Assert.AreEqual(long.MaxValue, PackedInts.MaxValue(64), "64 bit -> max == Long.MAX_VALUE (same as for 63 bit)");
+            Assert.AreEqual(1, PackedInt32s.MaxValue(1), "1 bit -> max == 1");
+            Assert.AreEqual(3, PackedInt32s.MaxValue(2), "2 bit -> max == 3");
+            Assert.AreEqual(255, PackedInt32s.MaxValue(8), "8 bit -> max == 255");
+            Assert.AreEqual(long.MaxValue, PackedInt32s.MaxValue(63), "63 bit -> max == Long.MAX_VALUE");
+            Assert.AreEqual(long.MaxValue, PackedInt32s.MaxValue(64), "64 bit -> max == Long.MAX_VALUE (same as for 63 bit)");
         }
 
         [Test]
@@ -90,7 +90,7 @@ namespace Lucene.Net.Util.Packed
             {
                 for (int nbits = 1; nbits <= 64; nbits++)
                 {
-                    long maxValue = PackedInts.MaxValue(nbits);
+                    long maxValue = PackedInt32s.MaxValue(nbits);
                     int valueCount = TestUtil.NextInt(Random(), 1, 600);
                     int bufferSize = Random().NextBoolean() ? TestUtil.NextInt(Random(), 0, 48) : TestUtil.NextInt(Random(), 0, 4096);
                     Directory d = NewDirectory();
@@ -106,7 +106,7 @@ namespace Lucene.Net.Util.Packed
                     {
                         acceptableOverhead = Random().NextFloat();
                     }
-                    PackedInts.Writer w = PackedInts.GetWriter(@out, valueCount, nbits, acceptableOverhead);
+                    PackedInt32s.Writer w = PackedInt32s.GetWriter(@out, valueCount, nbits, acceptableOverhead);
                     long startFp = @out.FilePointer;
 
                     int actualValueCount = Random().NextBoolean() ? valueCount : TestUtil.NextInt(Random(), 0, valueCount);
@@ -128,13 +128,13 @@ namespace Lucene.Net.Util.Packed
                     @out.Dispose();
 
                     // ensure that finish() added the (valueCount-actualValueCount) missing values
-                    long bytes = w.Format.ByteCount(PackedInts.VERSION_CURRENT, valueCount, w.BitsPerValue);
+                    long bytes = w.Format.ByteCount(PackedInt32s.VERSION_CURRENT, valueCount, w.BitsPerValue);
                     Assert.AreEqual(bytes, fp - startFp);
 
                     { // test header
                         IndexInput @in = d.OpenInput("out.bin", NewIOContext(Random()));
                         // header = codec header | bitsPerValue | valueCount | format
-                        CodecUtil.CheckHeader(@in, PackedInts.CODEC_NAME, PackedInts.VERSION_START, PackedInts.VERSION_CURRENT); // codec header
+                        CodecUtil.CheckHeader(@in, PackedInt32s.CODEC_NAME, PackedInt32s.VERSION_START, PackedInt32s.VERSION_CURRENT); // codec header
                         Assert.AreEqual(w.BitsPerValue, @in.ReadVInt32());
                         Assert.AreEqual(valueCount, @in.ReadVInt32());
                         Assert.AreEqual(w.Format.Id, @in.ReadVInt32());
@@ -144,7 +144,7 @@ namespace Lucene.Net.Util.Packed
 
                     { // test reader
                         IndexInput @in = d.OpenInput("out.bin", NewIOContext(Random()));
-                        PackedInts.Reader r = PackedInts.GetReader(@in);
+                        PackedInt32s.Reader r = PackedInt32s.GetReader(@in);
                         Assert.AreEqual(fp, @in.FilePointer);
                         for (int i = 0; i < valueCount; i++)
                         {
@@ -159,7 +159,7 @@ namespace Lucene.Net.Util.Packed
 
                     { // test reader iterator next
                         IndexInput @in = d.OpenInput("out.bin", NewIOContext(Random()));
-                        PackedInts.IReaderIterator r = PackedInts.GetReaderIterator(@in, bufferSize);
+                        PackedInt32s.IReaderIterator r = PackedInt32s.GetReaderIterator(@in, bufferSize);
                         for (int i = 0; i < valueCount; i++)
                         {
                             Assert.AreEqual(values[i], r.Next(), "index=" + i + " valueCount=" + valueCount + " nbits=" + nbits + " for " + r.GetType().Name);
@@ -171,12 +171,12 @@ namespace Lucene.Net.Util.Packed
 
                     { // test reader iterator bulk next
                         IndexInput @in = d.OpenInput("out.bin", NewIOContext(Random()));
-                        PackedInts.IReaderIterator r = PackedInts.GetReaderIterator(@in, bufferSize);
+                        PackedInt32s.IReaderIterator r = PackedInt32s.GetReaderIterator(@in, bufferSize);
                         int i = 0;
                         while (i < valueCount)
                         {
                             int count = TestUtil.NextInt(Random(), 1, 95);
-                            LongsRef next = r.Next(count);
+                            Int64sRef next = r.Next(count);
                             for (int k = 0; k < next.Length; ++k)
                             {
                                 Assert.AreEqual(values[i + k], next.Int64s[next.Offset + k], "index=" + i + " valueCount=" + valueCount + " nbits=" + nbits + " for " + r.GetType().Name);
@@ -189,7 +189,7 @@ namespace Lucene.Net.Util.Packed
 
                     { // test direct reader get
                         IndexInput @in = d.OpenInput("out.bin", NewIOContext(Random()));
-                        PackedInts.Reader intsEnum = PackedInts.GetDirectReader(@in);
+                        PackedInt32s.Reader intsEnum = PackedInt32s.GetDirectReader(@in);
                         for (int i = 0; i < valueCount; i++)
                         {
                             string msg = "index=" + i + " valueCount=" + valueCount + " nbits=" + nbits + " for " + intsEnum.GetType().Name;
@@ -217,11 +217,11 @@ namespace Lucene.Net.Util.Packed
             }
             @out.Dispose();
             IndexInput @in = dir.OpenInput("tests.bin", NewIOContext(Random()));
-            for (int version = PackedInts.VERSION_START; version <= PackedInts.VERSION_CURRENT; ++version)
+            for (int version = PackedInt32s.VERSION_START; version <= PackedInt32s.VERSION_CURRENT; ++version)
             {
                 for (int bpv = 1; bpv <= 64; ++bpv)
                 {
-                    foreach (PackedInts.Format format in PackedInts.Format.Values())
+                    foreach (PackedInt32s.Format format in PackedInt32s.Format.Values())
                     {
                         if (!format.IsSupported(bpv))
                         {
@@ -232,7 +232,7 @@ namespace Lucene.Net.Util.Packed
 
                         // test iterator
                         @in.Seek(0L);
-                        PackedInts.IReaderIterator it = PackedInts.GetReaderIteratorNoHeader(@in, format, version, valueCount, bpv, RandomInts.NextIntBetween(Random(), 1, 1 << 16));
+                        PackedInt32s.IReaderIterator it = PackedInt32s.GetReaderIteratorNoHeader(@in, format, version, valueCount, bpv, RandomInts.NextIntBetween(Random(), 1, 1 << 16));
                         for (int i = 0; i < valueCount; ++i)
                         {
                             it.Next();
@@ -241,13 +241,13 @@ namespace Lucene.Net.Util.Packed
 
                         // test direct reader
                         @in.Seek(0L);
-                        PackedInts.Reader directReader = PackedInts.GetDirectReaderNoHeader(@in, format, version, valueCount, bpv);
+                        PackedInt32s.Reader directReader = PackedInt32s.GetDirectReaderNoHeader(@in, format, version, valueCount, bpv);
                         directReader.Get(valueCount - 1);
                         Assert.AreEqual(byteCount, @in.FilePointer, msg);
 
                         // test reader
                         @in.Seek(0L);
-                        PackedInts.GetReaderNoHeader(@in, format, version, valueCount, bpv);
+                        PackedInt32s.GetReaderNoHeader(@in, format, version, valueCount, bpv);
                         Assert.AreEqual(byteCount, @in.FilePointer, msg);
                     }
                 }
@@ -262,8 +262,8 @@ namespace Lucene.Net.Util.Packed
             const int VALUE_COUNT = 255;
             const int BITS_PER_VALUE = 8;
 
-            IList<PackedInts.Mutable> packedInts = CreatePackedInts(VALUE_COUNT, BITS_PER_VALUE);
-            foreach (PackedInts.Mutable packedInt in packedInts)
+            IList<PackedInt32s.Mutable> packedInts = CreatePackedInts(VALUE_COUNT, BITS_PER_VALUE);
+            foreach (PackedInt32s.Mutable packedInt in packedInts)
             {
                 for (int i = 0; i < packedInt.Count; i++)
                 {
@@ -297,10 +297,10 @@ namespace Lucene.Net.Util.Packed
                     Console.WriteLine("  valueCount=" + valueCount + " bits1=" + bits1 + " bits2=" + bits2);
                 }
 
-                PackedInts.Mutable packed1 = PackedInts.GetMutable(valueCount, bits1, PackedInts.COMPACT);
-                PackedInts.Mutable packed2 = PackedInts.GetMutable(valueCount, bits2, PackedInts.COMPACT);
+                PackedInt32s.Mutable packed1 = PackedInt32s.GetMutable(valueCount, bits1, PackedInt32s.COMPACT);
+                PackedInt32s.Mutable packed2 = PackedInt32s.GetMutable(valueCount, bits2, PackedInt32s.COMPACT);
 
-                long maxValue = PackedInts.MaxValue(bits1);
+                long maxValue = PackedInt32s.MaxValue(bits1);
                 for (int i = 0; i < valueCount; i++)
                 {
                     long val = TestUtil.NextLong(Random(), 0, maxValue);
@@ -337,7 +337,7 @@ namespace Lucene.Net.Util.Packed
                     }
                     else
                     {
-                        PackedInts.Copy(packed1, offset, packed2, offset, len, Random().Next(10 * len));
+                        PackedInt32s.Copy(packed1, offset, packed2, offset, len, Random().Next(10 * len));
                     }
 
                     /*
@@ -371,12 +371,12 @@ namespace Lucene.Net.Util.Packed
 
         private static void AssertRandomEquality(int valueCount, int bitsPerValue, long randomSeed)
         {
-            IList<PackedInts.Mutable> packedInts = CreatePackedInts(valueCount, bitsPerValue);
-            foreach (PackedInts.Mutable packedInt in packedInts)
+            IList<PackedInt32s.Mutable> packedInts = CreatePackedInts(valueCount, bitsPerValue);
+            foreach (PackedInt32s.Mutable packedInt in packedInts)
             {
                 try
                 {
-                    Fill(packedInt, PackedInts.MaxValue(bitsPerValue), randomSeed);
+                    Fill(packedInt, PackedInt32s.MaxValue(bitsPerValue), randomSeed);
                 }
                 catch (Exception e)
                 {
@@ -387,9 +387,9 @@ namespace Lucene.Net.Util.Packed
             AssertListEquality(packedInts);
         }
 
-        private static IList<PackedInts.Mutable> CreatePackedInts(int valueCount, int bitsPerValue)
+        private static IList<PackedInt32s.Mutable> CreatePackedInts(int valueCount, int bitsPerValue)
         {
-            IList<PackedInts.Mutable> packedInts = new List<PackedInts.Mutable>();
+            IList<PackedInt32s.Mutable> packedInts = new List<PackedInt32s.Mutable>();
             if (bitsPerValue <= 8)
             {
                 packedInts.Add(new Direct8(valueCount));
@@ -425,7 +425,7 @@ namespace Lucene.Net.Util.Packed
             return packedInts;
         }
 
-        private static void Fill(PackedInts.Mutable packedInt, long maxValue, long randomSeed)
+        private static void Fill(PackedInt32s.Mutable packedInt, long maxValue, long randomSeed)
         {
             Random rnd2 = new Random((int)randomSeed);
             for (int i = 0; i < packedInt.Count; i++)
@@ -436,20 +436,20 @@ namespace Lucene.Net.Util.Packed
             }
         }
 
-        private static void AssertListEquality<T1>(IList<T1> packedInts) where T1 : PackedInts.Reader
+        private static void AssertListEquality<T1>(IList<T1> packedInts) where T1 : PackedInt32s.Reader
         {
             AssertListEquality("", packedInts);
         }
 
-        private static void AssertListEquality<T1>(string message, IList<T1> packedInts) where T1 : PackedInts.Reader
+        private static void AssertListEquality<T1>(string message, IList<T1> packedInts) where T1 : PackedInt32s.Reader
         {
             if (packedInts.Count == 0)
             {
                 return;
             }
-            PackedInts.Reader @base = packedInts[0];
+            PackedInt32s.Reader @base = packedInts[0];
             int valueCount = @base.Count;
-            foreach (PackedInts.Reader packedInt in packedInts)
+            foreach (PackedInt32s.Reader packedInt in packedInts)
             {
                 Assert.AreEqual(valueCount, packedInt.Count, message + ". The number of values should be the same ");
             }
@@ -469,15 +469,15 @@ namespace Lucene.Net.Util.Packed
             {
                 Directory dir = NewDirectory();
                 IndexOutput @out = dir.CreateOutput("out", NewIOContext(Random()));
-                PackedInts.Writer w = PackedInts.GetWriter(@out, 1, bitsPerValue, PackedInts.DEFAULT);
-                long value = 17L & PackedInts.MaxValue(bitsPerValue);
+                PackedInt32s.Writer w = PackedInt32s.GetWriter(@out, 1, bitsPerValue, PackedInt32s.DEFAULT);
+                long value = 17L & PackedInt32s.MaxValue(bitsPerValue);
                 w.Add(value);
                 w.Finish();
                 long end = @out.FilePointer;
                 @out.Dispose();
 
                 IndexInput @in = dir.OpenInput("out", NewIOContext(Random()));
-                Reader reader = PackedInts.GetReader(@in);
+                Reader reader = PackedInt32s.GetReader(@in);
                 string msg = "Impl=" + w.GetType().Name + ", bitsPerValue=" + bitsPerValue;
                 Assert.AreEqual(1, reader.Count, msg);
                 Assert.AreEqual(value, reader.Get(0), msg);
@@ -491,7 +491,7 @@ namespace Lucene.Net.Util.Packed
         [Test]
         public virtual void TestSecondaryBlockChange()
         {
-            PackedInts.Mutable mutable = new Packed64(26, 5);
+            PackedInt32s.Mutable mutable = new Packed64(26, 5);
             mutable.Set(24, 31);
             Assert.AreEqual(31, mutable.Get(24), "The value #24 should be correct");
             mutable.Set(4, 16);
@@ -597,9 +597,9 @@ namespace Lucene.Net.Util.Packed
             int to = from + Random().Next(valueCount + 1 - from);
             for (int bpv = 1; bpv <= 64; ++bpv)
             {
-                long val = TestUtil.NextLong(Random(), 0, PackedInts.MaxValue(bpv));
-                IList<PackedInts.Mutable> packedInts = CreatePackedInts(valueCount, bpv);
-                foreach (PackedInts.Mutable ints in packedInts)
+                long val = TestUtil.NextLong(Random(), 0, PackedInt32s.MaxValue(bpv));
+                IList<PackedInt32s.Mutable> packedInts = CreatePackedInts(valueCount, bpv);
+                foreach (PackedInt32s.Mutable ints in packedInts)
                 {
                     string msg = ints.GetType().Name + " bpv=" + bpv + ", from=" + from + ", to=" + to + ", val=" + val;
                     ints.Fill(0, ints.Count, 1);
@@ -624,7 +624,7 @@ namespace Lucene.Net.Util.Packed
         {
             // must be > 10 for the bulk reads below
             int size = TestUtil.NextInt(Random(), 11, 256);
-            Reader packedInts = new PackedInts.NullReader(size);
+            Reader packedInts = new PackedInt32s.NullReader(size);
             Assert.AreEqual(0, packedInts.Get(TestUtil.NextInt(Random(), 0, size - 1)));
             long[] arr = new long[size + 10];
             int r;
@@ -655,10 +655,10 @@ namespace Lucene.Net.Util.Packed
 
             for (int bpv = 1; bpv <= 64; ++bpv)
             {
-                long mask = PackedInts.MaxValue(bpv);
-                IList<PackedInts.Mutable> packedInts = CreatePackedInts(valueCount, bpv);
+                long mask = PackedInt32s.MaxValue(bpv);
+                IList<PackedInt32s.Mutable> packedInts = CreatePackedInts(valueCount, bpv);
 
-                foreach (PackedInts.Mutable ints in packedInts)
+                foreach (PackedInt32s.Mutable ints in packedInts)
                 {
                     for (int i = 0; i < ints.Count; ++i)
                     {
@@ -699,14 +699,14 @@ namespace Lucene.Net.Util.Packed
 
             for (int bpv = 1; bpv <= 64; ++bpv)
             {
-                long mask = PackedInts.MaxValue(bpv);
-                IList<PackedInts.Mutable> packedInts = CreatePackedInts(valueCount, bpv);
+                long mask = PackedInt32s.MaxValue(bpv);
+                IList<PackedInt32s.Mutable> packedInts = CreatePackedInts(valueCount, bpv);
                 for (int i = 0; i < arr.Length; ++i)
                 {
                     arr[i] = (31L * i + 19) & mask;
                 }
 
-                foreach (PackedInts.Mutable ints in packedInts)
+                foreach (PackedInt32s.Mutable ints in packedInts)
                 {
                     string msg = ints.GetType().Name + " valueCount=" + valueCount + ", index=" + index + ", len=" + len + ", off=" + off;
                     int sets = ints.Set(index, arr, off, len);
@@ -740,17 +740,17 @@ namespace Lucene.Net.Util.Packed
 
             for (int bpv = 1; bpv <= 64; ++bpv)
             {
-                long mask = PackedInts.MaxValue(bpv);
-                foreach (PackedInts.Mutable r1 in CreatePackedInts(valueCount, bpv))
+                long mask = PackedInt32s.MaxValue(bpv);
+                foreach (PackedInt32s.Mutable r1 in CreatePackedInts(valueCount, bpv))
                 {
                     for (int i = 0; i < r1.Count; ++i)
                     {
                         r1.Set(i, (31L * i - 1023) & mask);
                     }
-                    foreach (PackedInts.Mutable r2 in CreatePackedInts(valueCount, bpv))
+                    foreach (PackedInt32s.Mutable r2 in CreatePackedInts(valueCount, bpv))
                     {
                         string msg = "src=" + r1 + ", dest=" + r2 + ", srcPos=" + off1 + ", destPos=" + off2 + ", len=" + len + ", mem=" + mem;
-                        PackedInts.Copy(r1, off1, r2, off2, len, mem);
+                        PackedInt32s.Copy(r1, off1, r2, off2, len, mem);
                         for (int i = 0; i < r2.Count; ++i)
                         {
                             string m = msg + ", i=" + i;
@@ -772,7 +772,7 @@ namespace Lucene.Net.Util.Packed
         public virtual void TestGrowableWriter()
         {
             int valueCount = 113 + Random().Next(1111);
-            GrowableWriter wrt = new GrowableWriter(1, valueCount, PackedInts.DEFAULT);
+            GrowableWriter wrt = new GrowableWriter(1, valueCount, PackedInt32s.DEFAULT);
             wrt.Set(4, 2);
             wrt.Set(7, 10);
             wrt.Set(valueCount - 10, 99);
@@ -804,7 +804,7 @@ namespace Lucene.Net.Util.Packed
             Assert.AreEqual(0, writer.Count);
 
             // compare against AppendingDeltaPackedLongBuffer
-            AppendingDeltaPackedLongBuffer buf = new AppendingDeltaPackedLongBuffer();
+            AppendingDeltaPackedInt64Buffer buf = new AppendingDeltaPackedInt64Buffer();
             int size = Random().Next(1000000);
             long max = 5;
             for (int i = 0; i < size; ++i)
@@ -812,7 +812,7 @@ namespace Lucene.Net.Util.Packed
                 buf.Add(TestUtil.NextLong(Random(), 0, max));
                 if (Rarely())
                 {
-                    max = PackedInts.MaxValue(Rarely() ? TestUtil.NextInt(Random(), 0, 63) : TestUtil.NextInt(Random(), 0, 31));
+                    max = PackedInt32s.MaxValue(Rarely() ? TestUtil.NextInt(Random(), 0, 63) : TestUtil.NextInt(Random(), 0, 31));
                 }
             }
             writer = new PagedGrowableWriter(size, pageSize, TestUtil.NextInt(Random(), 1, 64), Random().NextFloat());
@@ -862,14 +862,14 @@ namespace Lucene.Net.Util.Packed
         public virtual void TestPagedMutable()
         {
             int bitsPerValue = TestUtil.NextInt(Random(), 1, 64);
-            long max = PackedInts.MaxValue(bitsPerValue);
+            long max = PackedInt32s.MaxValue(bitsPerValue);
             int pageSize = 1 << (TestUtil.NextInt(Random(), 6, 30));
             // supports 0 values?
             PagedMutable writer = new PagedMutable(0, pageSize, bitsPerValue, Random().NextFloat() / 2);
             Assert.AreEqual(0, writer.Count);
 
             // compare against AppendingDeltaPackedLongBuffer
-            AppendingDeltaPackedLongBuffer buf = new AppendingDeltaPackedLongBuffer();
+            AppendingDeltaPackedInt64Buffer buf = new AppendingDeltaPackedInt64Buffer();
             int size = Random().Next(1000000);
 
             for (int i = 0; i < size; ++i)
@@ -949,10 +949,10 @@ namespace Lucene.Net.Util.Packed
             int valueCount = TestUtil.NextInt(Random(), 1, 2048);
             for (int bpv = 1; bpv <= 64; ++bpv)
             {
-                int maxValue = (int)Math.Min(PackedInts.MaxValue(31), PackedInts.MaxValue(bpv));
+                int maxValue = (int)Math.Min(PackedInt32s.MaxValue(31), PackedInt32s.MaxValue(bpv));
                 RAMDirectory directory = new RAMDirectory();
-                IList<PackedInts.Mutable> packedInts = CreatePackedInts(valueCount, bpv);
-                foreach (PackedInts.Mutable mutable in packedInts)
+                IList<PackedInt32s.Mutable> packedInts = CreatePackedInts(valueCount, bpv);
+                foreach (PackedInt32s.Mutable mutable in packedInts)
                 {
                     for (int i = 0; i < mutable.Count; ++i)
                     {
@@ -964,7 +964,7 @@ namespace Lucene.Net.Util.Packed
                     @out.Dispose();
 
                     IndexInput @in = directory.OpenInput("packed-ints.bin", IOContext.DEFAULT);
-                    PackedInts.Reader reader = PackedInts.GetReader(@in);
+                    PackedInt32s.Reader reader = PackedInt32s.GetReader(@in);
                     Assert.AreEqual(mutable.BitsPerValue, reader.BitsPerValue);
                     Assert.AreEqual(valueCount, reader.Count);
                     if (mutable is Packed64SingleBlock)
@@ -992,7 +992,7 @@ namespace Lucene.Net.Util.Packed
         [Test]
         public virtual void TestEncodeDecode()
         {
-            foreach (PackedInts.Format format in PackedInts.Format.Values())
+            foreach (PackedInt32s.Format format in PackedInt32s.Format.Values())
             {
                 for (int bpv = 1; bpv <= 64; ++bpv)
                 {
@@ -1002,8 +1002,8 @@ namespace Lucene.Net.Util.Packed
                     }
                     string msg = format + " " + bpv;
 
-                    PackedInts.IEncoder encoder = PackedInts.GetEncoder(format, PackedInts.VERSION_CURRENT, bpv);
-                    PackedInts.IDecoder decoder = PackedInts.GetDecoder(format, PackedInts.VERSION_CURRENT, bpv);
+                    PackedInt32s.IEncoder encoder = PackedInt32s.GetEncoder(format, PackedInt32s.VERSION_CURRENT, bpv);
+                    PackedInt32s.IDecoder decoder = PackedInt32s.GetDecoder(format, PackedInt32s.VERSION_CURRENT, bpv);
                     int longBlockCount = encoder.Int64BlockCount;
                     int longValueCount = encoder.Int64ValueCount;
                     int byteBlockCount = encoder.ByteBlockCount;
@@ -1026,7 +1026,7 @@ namespace Lucene.Net.Util.Packed
                     for (int i = 0; i < blocks.Length; ++i)
                     {
                         blocks[i] = Random().NextLong();
-                        if (format == PackedInts.Format.PACKED_SINGLE_BLOCK && 64 % bpv != 0)
+                        if (format == PackedInt32s.Format.PACKED_SINGLE_BLOCK && 64 % bpv != 0)
                         {
                             // clear highest bits for packed
                             int toClear = 64 % bpv;
@@ -1039,7 +1039,7 @@ namespace Lucene.Net.Util.Packed
                     decoder.Decode(blocks, blocksOffset, values, valuesOffset, longIterations);
                     foreach (long value in values)
                     {
-                        Assert.IsTrue(value <= PackedInts.MaxValue(bpv));
+                        Assert.IsTrue(value <= PackedInt32s.MaxValue(bpv));
                     }
                     // test decoding to int[]
                     int[] intValues;
@@ -1073,7 +1073,7 @@ namespace Lucene.Net.Util.Packed
                     decoder.Decode(byteBlocks, blocksOffset * 8, values2, valuesOffset, byteIterations);
                     foreach (long value in values2)
                     {
-                        Assert.IsTrue(value <= PackedInts.MaxValue(bpv), msg);
+                        Assert.IsTrue(value <= PackedInt32s.MaxValue(bpv), msg);
                     }
                     Assert.AreEqual(values, values2, msg);
                     // test decoding to int[]
@@ -1087,7 +1087,7 @@ namespace Lucene.Net.Util.Packed
                     // 5. byte[] encoding
                     byte[] blocks3_ = new byte[8 * (blocksOffset2 + blocksLen)];
                     encoder.Encode(values, valuesOffset, blocks3_, 8 * blocksOffset2, byteIterations);
-                    assertEquals(msg, LongBuffer.Wrap(blocks2), ByteBuffer.Wrap(blocks3_).AsInt64Buffer());
+                    assertEquals(msg, Int64Buffer.Wrap(blocks2), ByteBuffer.Wrap(blocks3_).AsInt64Buffer());
                     // test encoding from int[]
                     if (bpv <= 32)
                     {
@@ -1132,7 +1132,7 @@ namespace Lucene.Net.Util.Packed
         {
 
             long[] arr = new long[RandomInts.NextIntBetween(Random(), 1, 1000000)];
-            float[] ratioOptions = new float[] { PackedInts.DEFAULT, PackedInts.COMPACT, PackedInts.FAST };
+            float[] ratioOptions = new float[] { PackedInt32s.DEFAULT, PackedInt32s.COMPACT, PackedInt32s.FAST };
             foreach (int bpv in new int[] { 0, 1, 63, 64, RandomInts.NextIntBetween(Random(), 2, 62) })
             {
                 foreach (DataType dataType in Enum.GetValues(typeof(DataType)))
@@ -1140,20 +1140,20 @@ namespace Lucene.Net.Util.Packed
                     int pageSize = 1 << TestUtil.NextInt(Random(), 6, 20);
                     int initialPageCount = TestUtil.NextInt(Random(), 0, 16);
                     float acceptableOverheadRatio = ratioOptions[TestUtil.NextInt(Random(), 0, ratioOptions.Length - 1)];
-                    AbstractAppendingLongBuffer buf;
+                    AbstractAppendingInt64Buffer buf;
                     int inc;
                     switch (dataType)
                     {
                         case Lucene.Net.Util.Packed.TestPackedInts.DataType.PACKED:
-                            buf = new AppendingPackedLongBuffer(initialPageCount, pageSize, acceptableOverheadRatio);
+                            buf = new AppendingPackedInt64Buffer(initialPageCount, pageSize, acceptableOverheadRatio);
                             inc = 0;
                             break;
                         case Lucene.Net.Util.Packed.TestPackedInts.DataType.DELTA_PACKED:
-                            buf = new AppendingDeltaPackedLongBuffer(initialPageCount, pageSize, acceptableOverheadRatio);
+                            buf = new AppendingDeltaPackedInt64Buffer(initialPageCount, pageSize, acceptableOverheadRatio);
                             inc = 0;
                             break;
                         case Lucene.Net.Util.Packed.TestPackedInts.DataType.MONOTONIC:
-                            buf = new MonotonicAppendingLongBuffer(initialPageCount, pageSize, acceptableOverheadRatio);
+                            buf = new MonotonicAppendingInt64Buffer(initialPageCount, pageSize, acceptableOverheadRatio);
                             inc = TestUtil.NextInt(Random(), -1000, 1000);
                             break;
                         default:
@@ -1178,10 +1178,10 @@ namespace Lucene.Net.Util.Packed
                     }
                     else
                     {
-                        long minValue = TestUtil.NextLong(Random(), long.MinValue, long.MaxValue - PackedInts.MaxValue(bpv));
+                        long minValue = TestUtil.NextLong(Random(), long.MinValue, long.MaxValue - PackedInt32s.MaxValue(bpv));
                         for (int i = 0; i < arr.Length; ++i)
                         {
-                            arr[i] = minValue + inc * i + Random().NextLong() & PackedInts.MaxValue(bpv); // TestUtil.nextLong is too slow
+                            arr[i] = minValue + inc * i + Random().NextLong() & PackedInt32s.MaxValue(bpv); // TestUtil.nextLong is too slow
                         }
                     }
 
@@ -1206,7 +1206,7 @@ namespace Lucene.Net.Util.Packed
                         Assert.AreEqual(arr[i], buf.Get(i));
                     }
 
-                    AbstractAppendingLongBuffer.Iterator it = buf.GetIterator();
+                    AbstractAppendingInt64Buffer.Iterator it = buf.GetIterator();
                     for (int i = 0; i < arr.Length; ++i)
                     {
                         if (Random().NextBoolean())
@@ -1263,7 +1263,7 @@ namespace Lucene.Net.Util.Packed
                 }
                 else
                 {
-                    longs[i] = TestUtil.NextLong(Random(), 0, PackedInts.MaxValue(bpv));
+                    longs[i] = TestUtil.NextLong(Random(), 0, PackedInt32s.MaxValue(bpv));
                 }
                 skip[i] = Rarely();
             }
@@ -1352,7 +1352,7 @@ namespace Lucene.Net.Util.Packed
                 in1.Seek(0L);
                 ByteArrayDataInput in2 = new ByteArrayDataInput((byte[])(Array)buf);
                 DataInput @in = Random().NextBoolean() ? (DataInput)in1 : in2;
-                BlockPackedReaderIterator it = new BlockPackedReaderIterator(@in, PackedInts.VERSION_CURRENT, blockSize, valueCount);
+                BlockPackedReaderIterator it = new BlockPackedReaderIterator(@in, PackedInt32s.VERSION_CURRENT, blockSize, valueCount);
                 for (int i = 0; i < valueCount; )
                 {
                     if (Random().NextBoolean())
@@ -1362,7 +1362,7 @@ namespace Lucene.Net.Util.Packed
                     }
                     else
                     {
-                        LongsRef nextValues = it.Next(TestUtil.NextInt(Random(), 1, 1024));
+                        Int64sRef nextValues = it.Next(TestUtil.NextInt(Random(), 1, 1024));
                         for (int j = 0; j < nextValues.Length; ++j)
                         {
                             Assert.AreEqual(values[i + j], nextValues.Int64s[nextValues.Offset + j], "" + (i + j));
@@ -1392,7 +1392,7 @@ namespace Lucene.Net.Util.Packed
                 {
                     ((IndexInput)@in).Seek(0L);
                 }
-                BlockPackedReaderIterator it2 = new BlockPackedReaderIterator(@in, PackedInts.VERSION_CURRENT, blockSize, valueCount);
+                BlockPackedReaderIterator it2 = new BlockPackedReaderIterator(@in, PackedInt32s.VERSION_CURRENT, blockSize, valueCount);
                 int k = 0;
                 while (true)
                 {
@@ -1424,7 +1424,7 @@ namespace Lucene.Net.Util.Packed
                 }
 
                 in1.Seek(0L);
-                BlockPackedReader reader = new BlockPackedReader(in1, PackedInts.VERSION_CURRENT, blockSize, valueCount, Random().NextBoolean());
+                BlockPackedReader reader = new BlockPackedReader(in1, PackedInt32s.VERSION_CURRENT, blockSize, valueCount, Random().NextBoolean());
                 Assert.AreEqual(in1.FilePointer, in1.Length);
                 for (k = 0; k < valueCount; ++k)
                 {
@@ -1473,7 +1473,7 @@ namespace Lucene.Net.Util.Packed
                 @out.Dispose();
 
                 IndexInput @in = dir.OpenInput("out.bin", IOContext.DEFAULT);
-                MonotonicBlockPackedReader reader = new MonotonicBlockPackedReader(@in, PackedInts.VERSION_CURRENT, blockSize, valueCount, Random().NextBoolean());
+                MonotonicBlockPackedReader reader = new MonotonicBlockPackedReader(@in, PackedInt32s.VERSION_CURRENT, blockSize, valueCount, Random().NextBoolean());
                 Assert.AreEqual(fp, @in.FilePointer);
                 for (int i = 0; i < valueCount; ++i)
                 {
@@ -1520,11 +1520,11 @@ namespace Lucene.Net.Util.Packed
             writer.Finish();
             @out.Dispose();
             IndexInput @in = dir.OpenInput("out.bin", IOContext.DEFAULT);
-            BlockPackedReaderIterator it = new BlockPackedReaderIterator(@in, PackedInts.VERSION_CURRENT, blockSize, valueCount);
+            BlockPackedReaderIterator it = new BlockPackedReaderIterator(@in, PackedInt32s.VERSION_CURRENT, blockSize, valueCount);
             it.Skip(valueOffset);
             Assert.AreEqual(value, it.Next());
             @in.Seek(0L);
-            BlockPackedReader reader = new BlockPackedReader(@in, PackedInts.VERSION_CURRENT, blockSize, valueCount, Random().NextBoolean());
+            BlockPackedReader reader = new BlockPackedReader(@in, PackedInt32s.VERSION_CURRENT, blockSize, valueCount, Random().NextBoolean());
             Assert.AreEqual(value, reader.Get(valueOffset));
             for (int i = 0; i < 5; ++i)
             {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Tests/core/Util/TestIntsRef.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Util/TestIntsRef.cs b/src/Lucene.Net.Tests/core/Util/TestIntsRef.cs
index 7b50d74..4ed5c73 100644
--- a/src/Lucene.Net.Tests/core/Util/TestIntsRef.cs
+++ b/src/Lucene.Net.Tests/core/Util/TestIntsRef.cs
@@ -25,8 +25,8 @@ namespace Lucene.Net.Util
         [Test]
         public virtual void TestEmpty()
         {
-            IntsRef i = new IntsRef();
-            Assert.AreEqual(IntsRef.EMPTY_INTS, i.Int32s);
+            Int32sRef i = new Int32sRef();
+            Assert.AreEqual(Int32sRef.EMPTY_INTS, i.Int32s);
             Assert.AreEqual(0, i.Offset);
             Assert.AreEqual(0, i.Length);
         }
@@ -35,13 +35,13 @@ namespace Lucene.Net.Util
         public virtual void TestFromInts()
         {
             int[] ints = new int[] { 1, 2, 3, 4 };
-            IntsRef i = new IntsRef(ints, 0, 4);
+            Int32sRef i = new Int32sRef(ints, 0, 4);
             Assert.AreEqual(ints, i.Int32s);
             Assert.AreEqual(0, i.Offset);
             Assert.AreEqual(4, i.Length);
 
-            IntsRef i2 = new IntsRef(ints, 1, 3);
-            Assert.AreEqual(new IntsRef(new int[] { 2, 3, 4 }, 0, 3), i2);
+            Int32sRef i2 = new Int32sRef(ints, 1, 3);
+            Assert.AreEqual(new Int32sRef(new int[] { 2, 3, 4 }, 0, 3), i2);
 
             Assert.IsFalse(i.Equals(i2));
         }


[36/53] [abbrv] lucenenet git commit: Lucene.Net.Queries: Renamed all type-derived classes and interfaces from Short, Int, Long, and Float to match CLR types Int16, Int32, Int64, and Single, respectively.

Posted by ni...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/883ad7f4/src/Lucene.Net.Tests.Facet/Range/TestRangeFacetCounts.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests.Facet/Range/TestRangeFacetCounts.cs b/src/Lucene.Net.Tests.Facet/Range/TestRangeFacetCounts.cs
index b41e3df..9233dfd 100644
--- a/src/Lucene.Net.Tests.Facet/Range/TestRangeFacetCounts.cs
+++ b/src/Lucene.Net.Tests.Facet/Range/TestRangeFacetCounts.cs
@@ -50,8 +50,8 @@ namespace Lucene.Net.Facet.Range
     using ValueSource = Lucene.Net.Queries.Function.ValueSource;
     using DoubleDocValues = Lucene.Net.Queries.Function.DocValues.DoubleDocValues;
     using DoubleFieldSource = Lucene.Net.Queries.Function.ValueSources.DoubleFieldSource;
-    using FloatFieldSource = Lucene.Net.Queries.Function.ValueSources.FloatFieldSource;
-    using LongFieldSource = Lucene.Net.Queries.Function.ValueSources.LongFieldSource;
+    using SingleFieldSource = Lucene.Net.Queries.Function.ValueSources.SingleFieldSource;
+    using Int64FieldSource = Lucene.Net.Queries.Function.ValueSources.Int64FieldSource;
     using CachingWrapperFilter = Lucene.Net.Search.CachingWrapperFilter;
     using DocIdSet = Lucene.Net.Search.DocIdSet;
     using DocIdSetIterator = Lucene.Net.Search.DocIdSetIterator;
@@ -373,7 +373,7 @@ namespace Lucene.Net.Facet.Range
             IndexSearcher s = NewSearcher(r);
             s.Search(new MatchAllDocsQuery(), fc);
 
-            Facets facets = new DoubleRangeFacetCounts("field", new FloatFieldSource("field"), fc, new DoubleRange("less than 10", 0.0f, true, 10.0f, false), new DoubleRange("less than or equal to 10", 0.0f, true, 10.0f, true), new DoubleRange("over 90", 90.0f, false, 100.0f, false), new DoubleRange("90 or above", 90.0f, true, 100.0f, false), new DoubleRange("over 1000", 1000.0f, false, double.PositiveInfinity, false));
+            Facets facets = new DoubleRangeFacetCounts("field", new SingleFieldSource("field"), fc, new DoubleRange("less than 10", 0.0f, true, 10.0f, false), new DoubleRange("less than or equal to 10", 0.0f, true, 10.0f, true), new DoubleRange("over 90", 90.0f, false, 100.0f, false), new DoubleRange("90 or above", 90.0f, true, 100.0f, false), new DoubleRange("over 1000", 1000.0f, false, double.PositiveInfinity, false));
 
             Assert.AreEqual("dim=field path=[] value=21 childCount=5\n  less than 10 (10)\n  less than or equal to 10 (11)\n  over 90 (9)\n  90 or above (10)\n  over 1000 (0)\n", facets.GetTopChildren(10, "field").ToString());
 
@@ -533,7 +533,7 @@ namespace Lucene.Net.Facet.Range
                 {
                     fastMatchFilter = null;
                 }
-                ValueSource vs = new LongFieldSource("field");
+                ValueSource vs = new Int64FieldSource("field");
                 Facets facets = new Int64RangeFacetCounts("field", vs, sfc, fastMatchFilter, ranges);
                 FacetResult result = facets.GetTopChildren(10, "field");
                 Assert.AreEqual(numRange, result.LabelValues.Length);
@@ -738,7 +738,7 @@ namespace Lucene.Net.Facet.Range
                 {
                     fastMatchFilter = null;
                 }
-                ValueSource vs = new FloatFieldSource("field");
+                ValueSource vs = new SingleFieldSource("field");
                 Facets facets = new DoubleRangeFacetCounts("field", vs, sfc, fastMatchFilter, ranges);
                 FacetResult result = facets.GetTopChildren(10, "field");
                 Assert.AreEqual(numRange, result.LabelValues.Length);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/883ad7f4/src/Lucene.Net.Tests.Facet/Taxonomy/TestTaxonomyFacetSumValueSource.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests.Facet/Taxonomy/TestTaxonomyFacetSumValueSource.cs b/src/Lucene.Net.Tests.Facet/Taxonomy/TestTaxonomyFacetSumValueSource.cs
index 5f3972b..0ca9461 100644
--- a/src/Lucene.Net.Tests.Facet/Taxonomy/TestTaxonomyFacetSumValueSource.cs
+++ b/src/Lucene.Net.Tests.Facet/Taxonomy/TestTaxonomyFacetSumValueSource.cs
@@ -46,9 +46,9 @@ namespace Lucene.Net.Facet.Taxonomy
     using FunctionValues = Lucene.Net.Queries.Function.FunctionValues;
     using ValueSource = Lucene.Net.Queries.Function.ValueSource;
     using DoubleDocValues = Lucene.Net.Queries.Function.DocValues.DoubleDocValues;
-    using FloatFieldSource = Lucene.Net.Queries.Function.ValueSources.FloatFieldSource;
-    using IntFieldSource = Lucene.Net.Queries.Function.ValueSources.IntFieldSource;
-    using LongFieldSource = Lucene.Net.Queries.Function.ValueSources.LongFieldSource;
+    using SingleFieldSource = Lucene.Net.Queries.Function.ValueSources.SingleFieldSource;
+    using Int32FieldSource = Lucene.Net.Queries.Function.ValueSources.Int32FieldSource;
+    using Int64FieldSource = Lucene.Net.Queries.Function.ValueSources.Int64FieldSource;
     using ConstantScoreQuery = Lucene.Net.Search.ConstantScoreQuery;
     using IndexSearcher = Lucene.Net.Search.IndexSearcher;
     using MatchAllDocsQuery = Lucene.Net.Search.MatchAllDocsQuery;
@@ -123,7 +123,7 @@ namespace Lucene.Net.Facet.Taxonomy
             // Facets.search utility methods:
             searcher.Search(new MatchAllDocsQuery(), c);
 
-            TaxonomyFacetSumValueSource facets = new TaxonomyFacetSumValueSource(taxoReader, new FacetsConfig(), c, new IntFieldSource("num"));
+            TaxonomyFacetSumValueSource facets = new TaxonomyFacetSumValueSource(taxoReader, new FacetsConfig(), c, new Int32FieldSource("num"));
 
             // Retrieve & verify results:
             Assert.AreEqual("dim=Author path=[] value=145.0 childCount=4\n  Lisa (50.0)\n  Frank (45.0)\n  Susan (40.0)\n  Bob (10.0)\n", facets.GetTopChildren(10, "Author").ToString());
@@ -187,7 +187,7 @@ namespace Lucene.Net.Facet.Taxonomy
             FacetsCollector c = new FacetsCollector();
             searcher.Search(new MatchAllDocsQuery(), c);
 
-            TaxonomyFacetSumValueSource facets = new TaxonomyFacetSumValueSource(taxoReader, new FacetsConfig(), c, new IntFieldSource("num"));
+            TaxonomyFacetSumValueSource facets = new TaxonomyFacetSumValueSource(taxoReader, new FacetsConfig(), c, new Int32FieldSource("num"));
 
             // Ask for top 10 labels for any dims that have counts:
             IList<FacetResult> results = facets.GetAllDims(10);
@@ -232,7 +232,7 @@ namespace Lucene.Net.Facet.Taxonomy
             FacetsCollector c = new FacetsCollector();
             searcher.Search(new MatchAllDocsQuery(), c);
 
-            TaxonomyFacetSumValueSource facets = new TaxonomyFacetSumValueSource(taxoReader, config, c, new IntFieldSource("num"));
+            TaxonomyFacetSumValueSource facets = new TaxonomyFacetSumValueSource(taxoReader, config, c, new Int32FieldSource("num"));
 
             // Ask for top 10 labels for any dims that have counts:
             IList<FacetResult> results = facets.GetAllDims(10);
@@ -322,7 +322,7 @@ namespace Lucene.Net.Facet.Taxonomy
 
             FacetsCollector sfc = new FacetsCollector();
             NewSearcher(r).Search(new MatchAllDocsQuery(), sfc);
-            Facets facets = new TaxonomyFacetSumValueSource(taxoReader, config, sfc, new LongFieldSource("price"));
+            Facets facets = new TaxonomyFacetSumValueSource(taxoReader, config, sfc, new Int64FieldSource("price"));
             Assert.AreEqual("dim=a path=[] value=10.0 childCount=2\n  1 (6.0)\n  0 (4.0)\n", facets.GetTopChildren(10, "a").ToString());
 
             IOUtils.Close(taxoWriter, iw, taxoReader, taxoDir, r, indexDir);
@@ -353,7 +353,7 @@ namespace Lucene.Net.Facet.Taxonomy
 
             FacetsCollector fc = new FacetsCollector(true);
             // score documents by their 'price' field - makes asserting the correct counts for the categories easier
-            Query q = new FunctionQuery(new LongFieldSource("price"));
+            Query q = new FunctionQuery(new Int64FieldSource("price"));
             FacetsCollector.Search(NewSearcher(r), q, 10, fc);
             Facets facets = new TaxonomyFacetSumValueSource(taxoReader, config, fc, valueSource);
 
@@ -444,7 +444,7 @@ namespace Lucene.Net.Facet.Taxonomy
             DirectoryReader r = DirectoryReader.Open(iw, true);
             DirectoryTaxonomyReader taxoReader = new DirectoryTaxonomyReader(taxoWriter);
 
-            ValueSource valueSource = new LongFieldSource("price");
+            ValueSource valueSource = new Int64FieldSource("price");
             FacetsCollector sfc = new FacetsCollector();
             NewSearcher(r).Search(new MatchAllDocsQuery(), sfc);
             Facets facets = new TaxonomyFacetSumValueSource(taxoReader, config, sfc, valueSource);
@@ -523,7 +523,7 @@ namespace Lucene.Net.Facet.Taxonomy
             // NRT open
             var tr = new DirectoryTaxonomyReader(tw);
 
-            ValueSource values = new FloatFieldSource("value");
+            ValueSource values = new SingleFieldSource("value");
 
             int iters = AtLeast(100);
             for (int iter = 0; iter < iters; iter++)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/883ad7f4/src/Lucene.Net.Tests.Queries/Function/FunctionTestSetup.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests.Queries/Function/FunctionTestSetup.cs b/src/Lucene.Net.Tests.Queries/Function/FunctionTestSetup.cs
index 2fd778a..f89775c 100644
--- a/src/Lucene.Net.Tests.Queries/Function/FunctionTestSetup.cs
+++ b/src/Lucene.Net.Tests.Queries/Function/FunctionTestSetup.cs
@@ -31,11 +31,11 @@ namespace Lucene.Net.Tests.Queries.Function
 
 #pragma warning disable 612, 618
         protected internal ValueSource BYTE_VALUESOURCE = new ByteFieldSource(INT_FIELD);
-        protected internal ValueSource SHORT_VALUESOURCE = new ShortFieldSource(INT_FIELD);
+        protected internal ValueSource SHORT_VALUESOURCE = new Int16FieldSource(INT_FIELD);
 #pragma warning restore 612, 618
-        protected internal ValueSource INT_VALUESOURCE = new IntFieldSource(INT_FIELD);
-        protected internal ValueSource INT_AS_FLOAT_VALUESOURCE = new FloatFieldSource(INT_FIELD);
-        protected internal ValueSource FLOAT_VALUESOURCE = new FloatFieldSource(FLOAT_FIELD);
+        protected internal ValueSource INT_VALUESOURCE = new Int32FieldSource(INT_FIELD);
+        protected internal ValueSource INT_AS_FLOAT_VALUESOURCE = new SingleFieldSource(INT_FIELD);
+        protected internal ValueSource FLOAT_VALUESOURCE = new SingleFieldSource(FLOAT_FIELD);
 
         private static readonly string[] DOC_TEXT_LINES =
         {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/883ad7f4/src/Lucene.Net.Tests.Queries/Function/TestDocValuesFieldSources.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests.Queries/Function/TestDocValuesFieldSources.cs b/src/Lucene.Net.Tests.Queries/Function/TestDocValuesFieldSources.cs
index 835b170..fab9d0d 100644
--- a/src/Lucene.Net.Tests.Queries/Function/TestDocValuesFieldSources.cs
+++ b/src/Lucene.Net.Tests.Queries/Function/TestDocValuesFieldSources.cs
@@ -75,7 +75,7 @@ namespace Lucene.Net.Tests.Queries.Function
             DirectoryReader rd = DirectoryReader.Open(d);
             foreach (AtomicReaderContext leave in rd.Leaves)
             {
-                FunctionValues ids = (new LongFieldSource("id")).GetValues(null, leave);
+                FunctionValues ids = (new Int64FieldSource("id")).GetValues(null, leave);
                 ValueSource vs;
                 switch (type)
                 {
@@ -84,7 +84,7 @@ namespace Lucene.Net.Tests.Queries.Function
                         vs = new BytesRefFieldSource("dv");
                         break;
                     case DocValuesType.NUMERIC:
-                        vs = new LongFieldSource("dv");
+                        vs = new Int64FieldSource("dv");
                         break;
                     default:
                         throw new InvalidOperationException();
@@ -98,7 +98,7 @@ namespace Lucene.Net.Tests.Queries.Function
                     {
                         assertTrue(values.ObjectVal(i) is string);
                     }
-                    else if (vs is LongFieldSource)
+                    else if (vs is Int64FieldSource)
                     {
                         assertTrue(values.ObjectVal(i) is long?);
                         assertTrue(values.BytesVal(i, bytes));

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/883ad7f4/src/Lucene.Net.Tests.Queries/Function/TestFunctionQuerySort.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests.Queries/Function/TestFunctionQuerySort.cs b/src/Lucene.Net.Tests.Queries/Function/TestFunctionQuerySort.cs
index a8aec5e..50dfb43 100644
--- a/src/Lucene.Net.Tests.Queries/Function/TestFunctionQuerySort.cs
+++ b/src/Lucene.Net.Tests.Queries/Function/TestFunctionQuerySort.cs
@@ -40,7 +40,7 @@ namespace Lucene.Net.Tests.Queries.Function
             IndexSearcher searcher = NewSearcher(reader);
 
             // Get ValueSource from FieldCache
-            IntFieldSource src = new IntFieldSource("value");
+            Int32FieldSource src = new Int32FieldSource("value");
             // ...and make it a sort criterion
             SortField sf = src.GetSortField(false).Rewrite(searcher);
             Sort orderBy = new Sort(sf);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/883ad7f4/src/Lucene.Net.Tests.Queries/Function/TestValueSources.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests.Queries/Function/TestValueSources.cs b/src/Lucene.Net.Tests.Queries/Function/TestValueSources.cs
index 35ce6a0..8df2b1a 100644
--- a/src/Lucene.Net.Tests.Queries/Function/TestValueSources.cs
+++ b/src/Lucene.Net.Tests.Queries/Function/TestValueSources.cs
@@ -108,7 +108,7 @@ namespace Lucene.Net.Tests.Queries.Function
         [Test]
         public void TestDiv()
         {
-            AssertHits(new FunctionQuery(new DivFloatFunction(new ConstValueSource(10f), new ConstValueSource(5f))), new[] { 2f, 2f });
+            AssertHits(new FunctionQuery(new DivSingleFunction(new ConstValueSource(10f), new ConstValueSource(5f))), new[] { 2f, 2f });
         }
 
         [Test]
@@ -132,7 +132,7 @@ namespace Lucene.Net.Tests.Queries.Function
         [Test]
         public void TestFloat()
         {
-            AssertHits(new FunctionQuery(new FloatFieldSource("float")), new[] { 5.2f, 9.3f });
+            AssertHits(new FunctionQuery(new SingleFieldSource("float")), new[] { 5.2f, 9.3f });
         }
 
         [Test]
@@ -163,7 +163,7 @@ namespace Lucene.Net.Tests.Queries.Function
         [Test]
         public void TestInt()
         {
-            AssertHits(new FunctionQuery(new IntFieldSource("int")), new[] { 35f, 54f });
+            AssertHits(new FunctionQuery(new Int32FieldSource("int")), new[] { 35f, 54f });
         }
 
         [Test]
@@ -175,13 +175,13 @@ namespace Lucene.Net.Tests.Queries.Function
         [Test]
         public void TestLinearFloat()
         {
-            AssertHits(new FunctionQuery(new LinearFloatFunction(new ConstValueSource(2.0f), 3, 1)), new[] { 7f, 7f });
+            AssertHits(new FunctionQuery(new LinearSingleFunction(new ConstValueSource(2.0f), 3, 1)), new[] { 7f, 7f });
         }
 
         [Test]
         public void TestLong()
         {
-            AssertHits(new FunctionQuery(new LongFieldSource("long")), new[] { 4343f, 1954f });
+            AssertHits(new FunctionQuery(new Int64FieldSource("long")), new[] { 4343f, 1954f });
         }
 
         [Test]
@@ -193,13 +193,13 @@ namespace Lucene.Net.Tests.Queries.Function
         [Test]
         public void TestMaxFloat()
         {
-            AssertHits(new FunctionQuery(new MaxFloatFunction(new ValueSource[] { new ConstValueSource(1f), new ConstValueSource(2f) })), new[] { 2f, 2f });
+            AssertHits(new FunctionQuery(new MaxSingleFunction(new ValueSource[] { new ConstValueSource(1f), new ConstValueSource(2f) })), new[] { 2f, 2f });
         }
 
         [Test]
         public void TestMinFloat()
         {
-            AssertHits(new FunctionQuery(new MinFloatFunction(new ValueSource[] { new ConstValueSource(1f), new ConstValueSource(2f) })), new[] { 1f, 1f });
+            AssertHits(new FunctionQuery(new MinSingleFunction(new ValueSource[] { new ConstValueSource(1f), new ConstValueSource(2f) })), new[] { 1f, 1f });
         }
 
         [Test]
@@ -227,13 +227,13 @@ namespace Lucene.Net.Tests.Queries.Function
         [Test]
         public void TestPow()
         {
-            AssertHits(new FunctionQuery(new PowFloatFunction(new ConstValueSource(2f), new ConstValueSource(3f))), new[] { 8f, 8f });
+            AssertHits(new FunctionQuery(new PowSingleFunction(new ConstValueSource(2f), new ConstValueSource(3f))), new[] { 8f, 8f });
         }
 
         [Test]
         public void TestProduct()
         {
-            AssertHits(new FunctionQuery(new ProductFloatFunction(new ValueSource[] { new ConstValueSource(2f), new ConstValueSource(3f) })), new[] { 6f, 6f });
+            AssertHits(new FunctionQuery(new ProductSingleFunction(new ValueSource[] { new ConstValueSource(2f), new ConstValueSource(3f) })), new[] { 6f, 6f });
         }
 
         [Test]
@@ -245,34 +245,34 @@ namespace Lucene.Net.Tests.Queries.Function
         [Test]
         public void TestRangeMap()
         {
-            AssertHits(new FunctionQuery(new RangeMapFloatFunction(new FloatFieldSource("float"), 5, 6, 1, 0f)), new[] { 1f, 0f });
-            AssertHits(new FunctionQuery(new RangeMapFloatFunction(new FloatFieldSource("float"), 5, 6, new SumFloatFunction(new ValueSource[] { new ConstValueSource(1f), new ConstValueSource(2f) }), new ConstValueSource(11f))), new[] { 3f, 11f });
+            AssertHits(new FunctionQuery(new RangeMapSingleFunction(new SingleFieldSource("float"), 5, 6, 1, 0f)), new[] { 1f, 0f });
+            AssertHits(new FunctionQuery(new RangeMapSingleFunction(new SingleFieldSource("float"), 5, 6, new SumSingleFunction(new ValueSource[] { new ConstValueSource(1f), new ConstValueSource(2f) }), new ConstValueSource(11f))), new[] { 3f, 11f });
         }
 
         [Test]
         public void TestReciprocal()
         {
-            AssertHits(new FunctionQuery(new ReciprocalFloatFunction(new ConstValueSource(2f), 3, 1, 4)), new[] { 0.1f, 0.1f });
+            AssertHits(new FunctionQuery(new ReciprocalSingleFunction(new ConstValueSource(2f), 3, 1, 4)), new[] { 0.1f, 0.1f });
         }
 
         [Test]
         public void TestScale()
         {
-            AssertHits(new FunctionQuery(new ScaleFloatFunction(new IntFieldSource("int"), 0, 1)), new[] { 0.0f, 1.0f });
+            AssertHits(new FunctionQuery(new ScaleSingleFunction(new Int32FieldSource("int"), 0, 1)), new[] { 0.0f, 1.0f });
         }
 
         [Test]
         public void TestShort()
         {
 #pragma warning disable 612, 618
-            AssertHits(new FunctionQuery(new ShortFieldSource("short")), new[] { 945f, 123f });
+            AssertHits(new FunctionQuery(new Int16FieldSource("short")), new[] { 945f, 123f });
 #pragma warning restore 612, 618
         }
 
         [Test]
         public void TestSumFloat()
         {
-            AssertHits(new FunctionQuery(new SumFloatFunction(new ValueSource[] { new ConstValueSource(1f), new ConstValueSource(2f) })), new[] { 3f, 3f });
+            AssertHits(new FunctionQuery(new SumSingleFunction(new ValueSource[] { new ConstValueSource(1f), new ConstValueSource(2f) })), new[] { 3f, 3f });
         }
 
         [Test]

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/883ad7f4/src/Lucene.Net.Tests.Suggest/Suggest/DocumentValueSourceDictionaryTest.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests.Suggest/Suggest/DocumentValueSourceDictionaryTest.cs b/src/Lucene.Net.Tests.Suggest/Suggest/DocumentValueSourceDictionaryTest.cs
index 463c773..6508dc6 100644
--- a/src/Lucene.Net.Tests.Suggest/Suggest/DocumentValueSourceDictionaryTest.cs
+++ b/src/Lucene.Net.Tests.Suggest/Suggest/DocumentValueSourceDictionaryTest.cs
@@ -106,8 +106,8 @@ namespace Lucene.Net.Search.Suggest
             writer.Dispose();
 
             IndexReader ir = DirectoryReader.Open(dir);
-            ValueSource[] toAdd = new ValueSource[] { new LongFieldSource(WEIGHT_FIELD_NAME_1), new LongFieldSource(WEIGHT_FIELD_NAME_2), new LongFieldSource(WEIGHT_FIELD_NAME_3) };
-            IDictionary dictionary = new DocumentValueSourceDictionary(ir, FIELD_NAME, new SumFloatFunction(toAdd), PAYLOAD_FIELD_NAME);
+            ValueSource[] toAdd = new ValueSource[] { new Int64FieldSource(WEIGHT_FIELD_NAME_1), new Int64FieldSource(WEIGHT_FIELD_NAME_2), new Int64FieldSource(WEIGHT_FIELD_NAME_3) };
+            IDictionary dictionary = new DocumentValueSourceDictionary(ir, FIELD_NAME, new SumSingleFunction(toAdd), PAYLOAD_FIELD_NAME);
             IInputIterator inputIterator = dictionary.EntryIterator;
             BytesRef f;
             while ((f = inputIterator.Next()) != null)
@@ -144,8 +144,8 @@ namespace Lucene.Net.Search.Suggest
             writer.Dispose();
 
             IndexReader ir = DirectoryReader.Open(dir);
-            ValueSource[] toAdd = new ValueSource[] { new LongFieldSource(WEIGHT_FIELD_NAME_1), new LongFieldSource(WEIGHT_FIELD_NAME_2), new LongFieldSource(WEIGHT_FIELD_NAME_3) };
-            IDictionary dictionary = new DocumentValueSourceDictionary(ir, FIELD_NAME, new SumFloatFunction(toAdd), PAYLOAD_FIELD_NAME, CONTEXTS_FIELD_NAME);
+            ValueSource[] toAdd = new ValueSource[] { new Int64FieldSource(WEIGHT_FIELD_NAME_1), new Int64FieldSource(WEIGHT_FIELD_NAME_2), new Int64FieldSource(WEIGHT_FIELD_NAME_3) };
+            IDictionary dictionary = new DocumentValueSourceDictionary(ir, FIELD_NAME, new SumSingleFunction(toAdd), PAYLOAD_FIELD_NAME, CONTEXTS_FIELD_NAME);
             IInputIterator inputIterator = dictionary.EntryIterator;
             BytesRef f;
             while ((f = inputIterator.Next()) != null)
@@ -187,8 +187,8 @@ namespace Lucene.Net.Search.Suggest
             writer.Dispose();
 
             IndexReader ir = DirectoryReader.Open(dir);
-            ValueSource[] toAdd = new ValueSource[] { new LongFieldSource(WEIGHT_FIELD_NAME_1), new LongFieldSource(WEIGHT_FIELD_NAME_2), new LongFieldSource(WEIGHT_FIELD_NAME_3) };
-            IDictionary dictionary = new DocumentValueSourceDictionary(ir, FIELD_NAME, new SumFloatFunction(toAdd));
+            ValueSource[] toAdd = new ValueSource[] { new Int64FieldSource(WEIGHT_FIELD_NAME_1), new Int64FieldSource(WEIGHT_FIELD_NAME_2), new Int64FieldSource(WEIGHT_FIELD_NAME_3) };
+            IDictionary dictionary = new DocumentValueSourceDictionary(ir, FIELD_NAME, new SumSingleFunction(toAdd));
             IInputIterator inputIterator = dictionary.EntryIterator;
             BytesRef f;
             while ((f = inputIterator.Next()) != null)
@@ -251,9 +251,9 @@ namespace Lucene.Net.Search.Suggest
             IndexReader ir = DirectoryReader.Open(dir);
             assertTrue("NumDocs should be > 0 but was " + ir.NumDocs, ir.NumDocs > 0);
             assertEquals(ir.NumDocs, docs.size());
-            ValueSource[] toAdd = new ValueSource[] { new LongFieldSource(WEIGHT_FIELD_NAME_1), new LongFieldSource(WEIGHT_FIELD_NAME_2) };
+            ValueSource[] toAdd = new ValueSource[] { new Int64FieldSource(WEIGHT_FIELD_NAME_1), new Int64FieldSource(WEIGHT_FIELD_NAME_2) };
 
-            IDictionary dictionary = new DocumentValueSourceDictionary(ir, FIELD_NAME, new SumFloatFunction(toAdd), PAYLOAD_FIELD_NAME);
+            IDictionary dictionary = new DocumentValueSourceDictionary(ir, FIELD_NAME, new SumSingleFunction(toAdd), PAYLOAD_FIELD_NAME);
             IInputIterator inputIterator = dictionary.EntryIterator;
             BytesRef f;
             while ((f = inputIterator.Next()) != null)


[49/53] [abbrv] lucenenet git commit: Lucene.Net.Tartarus.Snowball.Ext: Added exceptions to the .NET numeric convention rule for r_shortv()

Posted by ni...@apache.org.
Lucene.Net.Tartarus.Snowball.Ext: Added exceptions to the .NET numeric convention rule for r_shortv()


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

Branch: refs/heads/api-work
Commit: aef52053f3fba8b96355d6cc105361033689ec98
Parents: e67e0b5
Author: Shad Storhaug <sh...@shadstorhaug.com>
Authored: Wed Feb 8 17:50:17 2017 +0700
Committer: Shad Storhaug <sh...@shadstorhaug.com>
Committed: Wed Feb 8 21:08:25 2017 +0700

----------------------------------------------------------------------
 .../Tartarus/Snowball/Ext/EnglishStemmer.cs                     | 5 ++++-
 .../Tartarus/Snowball/Ext/PorterStemmer.cs                      | 5 ++++-
 2 files changed, 8 insertions(+), 2 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/lucenenet/blob/aef52053/src/Lucene.Net.Analysis.Common/Tartarus/Snowball/Ext/EnglishStemmer.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Analysis.Common/Tartarus/Snowball/Ext/EnglishStemmer.cs b/src/Lucene.Net.Analysis.Common/Tartarus/Snowball/Ext/EnglishStemmer.cs
index 7eda965..109d6a5 100644
--- a/src/Lucene.Net.Analysis.Common/Tartarus/Snowball/Ext/EnglishStemmer.cs
+++ b/src/Lucene.Net.Analysis.Common/Tartarus/Snowball/Ext/EnglishStemmer.cs
@@ -1,4 +1,6 @@
-\ufeffnamespace Lucene.Net.Tartarus.Snowball.Ext
+\ufeffusing Lucene.Net.Support;
+
+namespace Lucene.Net.Tartarus.Snowball.Ext
 {
     /// <summary>
     /// This class was automatically generated by a Snowball to Java compiler
@@ -423,6 +425,7 @@
             return true;
         }
 
+        [ExceptionToNetNumericConvention]
         private bool r_shortv()
         {
             int v_1;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/aef52053/src/Lucene.Net.Analysis.Common/Tartarus/Snowball/Ext/PorterStemmer.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Analysis.Common/Tartarus/Snowball/Ext/PorterStemmer.cs b/src/Lucene.Net.Analysis.Common/Tartarus/Snowball/Ext/PorterStemmer.cs
index 5b64ec9..4eafd24 100644
--- a/src/Lucene.Net.Analysis.Common/Tartarus/Snowball/Ext/PorterStemmer.cs
+++ b/src/Lucene.Net.Analysis.Common/Tartarus/Snowball/Ext/PorterStemmer.cs
@@ -1,4 +1,6 @@
-\ufeffnamespace Lucene.Net.Tartarus.Snowball.Ext
+\ufeffusing Lucene.Net.Support;
+
+namespace Lucene.Net.Tartarus.Snowball.Ext
 {
     /// <summary>
     /// This class was automatically generated by a Snowball to Java compiler
@@ -108,6 +110,7 @@
             base.CopyFrom(other);
         }
 
+        [ExceptionToNetNumericConvention]
         private bool r_shortv()
         {
             // (, line 19


[50/53] [abbrv] lucenenet git commit: Lucene.Net.TestFramework.Util.ApiScanTestBase - changed TestForMembersAcceptingOrReturningListOrDictionary to only scan public members

Posted by ni...@apache.org.
Lucene.Net.TestFramework.Util.ApiScanTestBase - changed TestForMembersAcceptingOrReturningListOrDictionary to only scan public members


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

Branch: refs/heads/api-work
Commit: 1200b29e7a6f4a634a9e5c768225e30e75cbc583
Parents: 546dfe4
Author: Shad Storhaug <sh...@shadstorhaug.com>
Authored: Wed Feb 8 17:21:45 2017 +0700
Committer: Shad Storhaug <sh...@shadstorhaug.com>
Committed: Wed Feb 8 21:08:25 2017 +0700

----------------------------------------------------------------------
 src/Lucene.Net.TestFramework/Util/ApiScanTestBase.cs | 4 ++--
 1 file changed, 2 insertions(+), 2 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/lucenenet/blob/1200b29e/src/Lucene.Net.TestFramework/Util/ApiScanTestBase.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.TestFramework/Util/ApiScanTestBase.cs b/src/Lucene.Net.TestFramework/Util/ApiScanTestBase.cs
index 3eac4f1..3bbdf7a 100644
--- a/src/Lucene.Net.TestFramework/Util/ApiScanTestBase.cs
+++ b/src/Lucene.Net.TestFramework/Util/ApiScanTestBase.cs
@@ -349,8 +349,8 @@ namespace Lucene.Net.Util
         public virtual void TestForMembersAcceptingOrReturningListOrDictionary(Type typeFromTargetAssembly)
         {
             var names = new List<string>();
-            names.AddRange(GetMembersAcceptingOrReturningType(typeof(List<>), typeFromTargetAssembly.Assembly, false));
-            names.AddRange(GetMembersAcceptingOrReturningType(typeof(Dictionary<,>), typeFromTargetAssembly.Assembly, false));
+            names.AddRange(GetMembersAcceptingOrReturningType(typeof(List<>), typeFromTargetAssembly.Assembly, true));
+            names.AddRange(GetMembersAcceptingOrReturningType(typeof(Dictionary<,>), typeFromTargetAssembly.Assembly, true));
 
             //if (VERBOSE)
             //{


[05/53] [abbrv] lucenenet git commit: Lucene.Net.Core: Renamed all type-derived properties and methods from Short, Int, Long, and Float to match CLR types Int16, Int32, Int64, and Single, respectively.

Posted by ni...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Util/Packed/PackedInts.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Packed/PackedInts.cs b/src/Lucene.Net.Core/Util/Packed/PackedInts.cs
index e04d916..6b2997a 100644
--- a/src/Lucene.Net.Core/Util/Packed/PackedInts.cs
+++ b/src/Lucene.Net.Core/Util/Packed/PackedInts.cs
@@ -248,7 +248,10 @@ namespace Lucene.Net.Util.Packed
             {
             }
 
-            public override int LongCount(int packedIntsVersion, int valueCount, int bitsPerValue)
+            /// <summary>
+            /// NOTE: This was longCount() in Lucene
+            /// </summary>
+            public override int Int64Count(int packedIntsVersion, int valueCount, int bitsPerValue)
             {
                 int valuesPerBlock = 64 / bitsPerValue;
                 return (int)Math.Ceiling((double)valueCount / valuesPerBlock);
@@ -308,10 +311,13 @@ namespace Lucene.Net.Util.Packed
             public virtual long ByteCount(int packedIntsVersion, int valueCount, int bitsPerValue)
             {
                 // assume long-aligned
-                return 8L * LongCount(packedIntsVersion, valueCount, bitsPerValue);
+                return 8L * Int64Count(packedIntsVersion, valueCount, bitsPerValue);
             }
 
-            public virtual int LongCount(int packedIntsVersion, int valueCount, int bitsPerValue) // LUCENENET TODO: Rename Int64Count ?
+            /// <summary>
+            /// NOTE: This was longCount() in Lucene
+            /// </summary>
+            public virtual int Int64Count(int packedIntsVersion, int valueCount, int bitsPerValue)
             {
                 long byteCount = ByteCount(packedIntsVersion, valueCount, bitsPerValue);
 
@@ -447,14 +453,18 @@ namespace Lucene.Net.Util.Packed
             /// <summary>
             /// The minimum number of long blocks to encode in a single iteration, when
             /// using long encoding.
+            /// <para/>
+            /// NOTE: This was longBlockCount() in Lucene
             /// </summary>
-            int LongBlockCount { get; } // LUCENENET TODO: Rename Int64BlockCount ?
+            int Int64BlockCount { get; }
 
             /// <summary>
             /// The number of values that can be stored in <seealso cref="#longBlockCount()"/> long
             /// blocks.
+            /// <para/>
+            /// NOTE: This was longValueCount() in Lucene
             /// </summary>
-            int LongValueCount { get; } // LUCENENET TODO: Rename Int64ValueCount ?
+            int Int64ValueCount { get; }
 
             /// <summary>
             /// The minimum number of byte blocks to encode in a single iteration, when
@@ -525,14 +535,18 @@ namespace Lucene.Net.Util.Packed
             /// <summary>
             /// The minimum number of long blocks to encode in a single iteration, when
             /// using long encoding.
+            /// <para/>
+            /// NOTE: This was longBlockCount() in Lucene
             /// </summary>
-            int LongBlockCount { get; } // LUCENENET TODO: Rename Int64BlockCount ?
+            int Int64BlockCount { get; }
 
             /// <summary>
             /// The number of values that can be stored in <seealso cref="#longBlockCount()"/> long
             /// blocks.
+            /// <para/>
+            /// NOTE: This was longValueCount() in Lucene
             /// </summary>
-            int LongValueCount { get; } // LUCENENET TODO:  Rename Int64ValueCount ?
+            int Int64ValueCount { get; }
 
             /// <summary>
             /// The minimum number of byte blocks to encode in a single iteration, when
@@ -711,7 +725,7 @@ namespace Lucene.Net.Util.Packed
             {
                 LongsRef nextValues = Next(1);
                 Debug.Assert(nextValues.Length > 0);
-                long result = nextValues.Longs[nextValues.Offset];
+                long result = nextValues.Int64s[nextValues.Offset];
                 ++nextValues.Offset;
                 --nextValues.Length;
                 return result;
@@ -943,9 +957,9 @@ namespace Lucene.Net.Util.Packed
             {
                 Debug.Assert(m_valueCount != -1);
                 CodecUtil.WriteHeader(m_out, CODEC_NAME, VERSION_CURRENT);
-                m_out.WriteVInt(m_bitsPerValue);
-                m_out.WriteVInt(m_valueCount);
-                m_out.WriteVInt(Format.Id);
+                m_out.WriteVInt32(m_bitsPerValue);
+                m_out.WriteVInt32(m_valueCount);
+                m_out.WriteVInt32(Format.Id);
             }
 
             /// <summary>
@@ -1087,10 +1101,10 @@ namespace Lucene.Net.Util.Packed
         public static Reader GetReader(DataInput @in)
         {
             int version = CodecUtil.CheckHeader(@in, CODEC_NAME, VERSION_START, VERSION_CURRENT);
-            int bitsPerValue = @in.ReadVInt();
+            int bitsPerValue = @in.ReadVInt32();
             Debug.Assert(bitsPerValue > 0 && bitsPerValue <= 64, "bitsPerValue=" + bitsPerValue);
-            int valueCount = @in.ReadVInt();
-            Format format = Format.ById(@in.ReadVInt());
+            int valueCount = @in.ReadVInt32();
+            Format format = Format.ById(@in.ReadVInt32());
 
             return GetReaderNoHeader(@in, format, version, valueCount, bitsPerValue);
         }
@@ -1126,10 +1140,10 @@ namespace Lucene.Net.Util.Packed
         public static IReaderIterator GetReaderIterator(DataInput @in, int mem)
         {
             int version = CodecUtil.CheckHeader(@in, CODEC_NAME, VERSION_START, VERSION_CURRENT);
-            int bitsPerValue = @in.ReadVInt();
+            int bitsPerValue = @in.ReadVInt32();
             Debug.Assert(bitsPerValue > 0 && bitsPerValue <= 64, "bitsPerValue=" + bitsPerValue);
-            int valueCount = @in.ReadVInt();
-            Format format = Format.ById(@in.ReadVInt());
+            int valueCount = @in.ReadVInt32();
+            Format format = Format.ById(@in.ReadVInt32());
             return GetReaderIteratorNoHeader(@in, format, version, valueCount, bitsPerValue, mem);
         }
 
@@ -1246,10 +1260,10 @@ namespace Lucene.Net.Util.Packed
         public static Reader GetDirectReader(IndexInput @in)
         {
             int version = CodecUtil.CheckHeader(@in, CODEC_NAME, VERSION_START, VERSION_CURRENT);
-            int bitsPerValue = @in.ReadVInt();
+            int bitsPerValue = @in.ReadVInt32();
             Debug.Assert(bitsPerValue > 0 && bitsPerValue <= 64, "bitsPerValue=" + bitsPerValue);
-            int valueCount = @in.ReadVInt();
-            Format format = Format.ById(@in.ReadVInt());
+            int valueCount = @in.ReadVInt32();
+            Format format = Format.ById(@in.ReadVInt32());
             return GetDirectReaderNoHeader(@in, format, version, valueCount, bitsPerValue);
         }
 
@@ -1512,10 +1526,10 @@ namespace Lucene.Net.Util.Packed
         public static Header ReadHeader(DataInput @in)
         {
             int version = CodecUtil.CheckHeader(@in, CODEC_NAME, VERSION_START, VERSION_CURRENT);
-            int bitsPerValue = @in.ReadVInt();
+            int bitsPerValue = @in.ReadVInt32();
             Debug.Assert(bitsPerValue > 0 && bitsPerValue <= 64, "bitsPerValue=" + bitsPerValue);
-            int valueCount = @in.ReadVInt();
-            Format format = Format.ById(@in.ReadVInt());
+            int valueCount = @in.ReadVInt32();
+            Format format = Format.ById(@in.ReadVInt32());
             return new Header(format, valueCount, bitsPerValue, version);
         }
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Util/Packed/PackedReaderIterator.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Packed/PackedReaderIterator.cs b/src/Lucene.Net.Core/Util/Packed/PackedReaderIterator.cs
index 9dd90c9..27a0680 100644
--- a/src/Lucene.Net.Core/Util/Packed/PackedReaderIterator.cs
+++ b/src/Lucene.Net.Core/Util/Packed/PackedReaderIterator.cs
@@ -43,7 +43,7 @@ namespace Lucene.Net.Util.Packed
             Debug.Assert(valueCount == 0 || iterations > 0);
             nextBlocks = new byte[iterations * bulkOperation.ByteBlockCount];
             nextValues = new LongsRef(new long[iterations * bulkOperation.ByteValueCount], 0, 0);
-            nextValues.Offset = nextValues.Longs.Length;
+            nextValues.Offset = nextValues.Int64s.Length;
             position = -1;
         }
 
@@ -62,7 +62,7 @@ namespace Lucene.Net.Util.Packed
         {
             Debug.Assert(nextValues.Length >= 0);
             Debug.Assert(count > 0);
-            Debug.Assert(nextValues.Offset + nextValues.Length <= nextValues.Longs.Length);
+            Debug.Assert(nextValues.Offset + nextValues.Length <= nextValues.Int64s.Length);
 
             nextValues.Offset += nextValues.Length;
 
@@ -73,7 +73,7 @@ namespace Lucene.Net.Util.Packed
             }
             count = Math.Min(remaining, count);
 
-            if (nextValues.Offset == nextValues.Longs.Length)
+            if (nextValues.Offset == nextValues.Int64s.Length)
             {
                 long remainingBlocks = format.ByteCount(packedIntsVersion, remaining, m_bitsPerValue);
                 int blocksToRead = (int)Math.Min(remainingBlocks, nextBlocks.Length);
@@ -83,11 +83,11 @@ namespace Lucene.Net.Util.Packed
                     Arrays.Fill(nextBlocks, blocksToRead, nextBlocks.Length, (byte)0);
                 }
 
-                bulkOperation.Decode(nextBlocks, 0, nextValues.Longs, 0, iterations);
+                bulkOperation.Decode(nextBlocks, 0, nextValues.Int64s, 0, iterations);
                 nextValues.Offset = 0;
             }
 
-            nextValues.Length = Math.Min(nextValues.Longs.Length - nextValues.Offset, count);
+            nextValues.Length = Math.Min(nextValues.Int64s.Length - nextValues.Offset, count);
             position += nextValues.Length;
             return nextValues;
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Util/RecyclingIntBlockAllocator.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/RecyclingIntBlockAllocator.cs b/src/Lucene.Net.Core/Util/RecyclingIntBlockAllocator.cs
index b2b3648..19e7537 100644
--- a/src/Lucene.Net.Core/Util/RecyclingIntBlockAllocator.cs
+++ b/src/Lucene.Net.Core/Util/RecyclingIntBlockAllocator.cs
@@ -79,7 +79,10 @@ namespace Lucene.Net.Util
         {
         }
 
-        public override int[] GetIntBlock() // LUCENENET TODO: Rename GetInt32Block() ?
+        /// <summary>
+        /// NOTE: This was getIntBlock() in Lucene
+        /// </summary>
+        public override int[] GetInt32Block()
         {
             if (freeBlocks == 0)
             {
@@ -91,7 +94,10 @@ namespace Lucene.Net.Util
             return b;
         }
 
-        public override void RecycleIntBlocks(int[][] blocks, int start, int end) // LUCENENET TODO: Rename RecycleInt32Blocks ?
+        /// <summary>
+        /// NOTE: This was recycleIntBlocks in Lucene
+        /// </summary>
+        public override void RecycleInt32Blocks(int[][] blocks, int start, int end)
         {
             int numBlocks = Math.Min(maxBufferedBlocks - freeBlocks, end - start);
             int size = freeBlocks + numBlocks;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Util/SmallFloat.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/SmallFloat.cs b/src/Lucene.Net.Core/Util/SmallFloat.cs
index 5053bcf..ca87e46 100644
--- a/src/Lucene.Net.Core/Util/SmallFloat.cs
+++ b/src/Lucene.Net.Core/Util/SmallFloat.cs
@@ -37,13 +37,15 @@ namespace Lucene.Net.Util
         /// <br>Values less than zero are all mapped to zero.
         /// <br>Values are truncated (rounded down) to the nearest 8 bit value.
         /// <br>Values between zero and the smallest representable value
-        ///  are rounded up.
+        /// are rounded up.
+        /// <para/>
+        /// NOTE: This was floatToByte() in Lucene
         /// </summary>
         /// <param name="f"> the 32 bit float to be converted to an 8 bit float (byte) </param>
         /// <param name="numMantissaBits"> the number of mantissa bits to use in the byte, with the remainder to be used in the exponent </param>
         /// <param name="zeroExp"> the zero-point in the range of exponent values </param>
         /// <returns> the 8 bit float representation </returns>
-        public static sbyte FloatToByte(float f, int numMantissaBits, int zeroExp) // LUCENENET TODO: rename SingleToByte ? can we remove the sbyte?
+        public static sbyte SingleToByte(float f, int numMantissaBits, int zeroExp) // LUCENENET TODO: can we remove the sbyte?
         {
             // Adjustment from a float zero exponent to our zero exponent,
             // shifted over to our exponent position.
@@ -65,8 +67,11 @@ namespace Lucene.Net.Util
         }
 
         /// <summary>
-        /// Converts an 8 bit float to a 32 bit float. </summary>
-        public static float ByteToFloat(sbyte b, int numMantissaBits, int zeroExp) // LUCENENET TODO: rename ByteToSingle ? can we remove the sbyte?
+        /// Converts an 8 bit float to a 32 bit float. 
+        /// <para/>
+        /// NOTE: This was byteToFloat() in Lucene
+        /// </summary>
+        public static float ByteToSingle(sbyte b, int numMantissaBits, int zeroExp) // LUCENENET TODO: can we remove the sbyte?
         {
             // on Java1.5 & 1.6 JVMs, prebuilding a decoding array and doing a lookup
             // is only a little bit faster (anywhere from 0% to 7%)
@@ -90,8 +95,10 @@ namespace Lucene.Net.Util
         /// <br>smallest non-zero value = 5.820766E-10
         /// <br>largest value = 7.5161928E9
         /// <br>epsilon = 0.125
+        /// <para/>
+        /// NOTE: This was floatToByte315() in Lucene
         /// </summary>
-        public static sbyte FloatToByte315(float f) // LUCENENET TODO: rename SingleToByte315 ? can we remove the sbyte?
+        public static sbyte SingleToByte315(float f) // LUCENENET TODO: can we remove the sbyte?
         {
             int bits = BitConverter.ToInt32(BitConverter.GetBytes(f), 0);
             int smallfloat = bits >> (24 - 3);
@@ -107,8 +114,11 @@ namespace Lucene.Net.Util
         }
 
         /// <summary>
-        /// byteToFloat(b, mantissaBits=3, zeroExponent=15) </summary>
-        public static float Byte315ToFloat(sbyte b) // LUCENENET TODO: rename Byte315ToSingle ? can we remove the sbyte?
+        /// byteToFloat(b, mantissaBits=3, zeroExponent=15) 
+        /// <para/>
+        /// NOTE: This was byte315ToFloat() in Lucene
+        /// </summary>
+        public static float Byte315ToSingle(sbyte b) // LUCENENET TODO: can we remove the sbyte?
         {
             // on Java1.5 & 1.6 JVMs, prebuilding a decoding array and doing a lookup
             // is only a little bit faster (anywhere from 0% to 7%)
@@ -126,8 +136,10 @@ namespace Lucene.Net.Util
         /// <br>smallest nonzero value = 0.033203125
         /// <br>largest value = 1984.0
         /// <br>epsilon = 0.03125
+        /// <para/>
+        /// NOTE: This was floatToByte52() in Lucene
         /// </summary>
-        public static sbyte FloatToByte52(float f) // LUCENENET TODO: rename SingleToByte52 ? can we remove the sbyte?
+        public static sbyte SingleToByte52(float f) // LUCENENET TODO: can we remove the sbyte?
         {
             int bits = BitConverter.ToInt32(BitConverter.GetBytes(f), 0);
             int smallfloat = bits >> (24 - 5);
@@ -143,8 +155,11 @@ namespace Lucene.Net.Util
         }
 
         /// <summary>
-        /// byteToFloat(b, mantissaBits=5, zeroExponent=2) </summary>
-        public static float Byte52ToFloat(sbyte b) // LUCENENET TODO: rename Byte52ToSingle ? can we remove the sbyte?
+        /// byteToFloat(b, mantissaBits=5, zeroExponent=2) 
+        /// <para/>
+        /// NOTE: This was byte52ToFloat() in Lucene
+        /// </summary>
+        public static float Byte52ToSingle(sbyte b) // LUCENENET TODO: can we remove the sbyte?
         {
             // on Java1.5 & 1.6 JVMs, prebuilding a decoding array and doing a lookup
             // is only a little bit faster (anywhere from 0% to 7%)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Util/ToStringUtils.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/ToStringUtils.cs b/src/Lucene.Net.Core/Util/ToStringUtils.cs
index 0cce51d..af1e127 100644
--- a/src/Lucene.Net.Core/Util/ToStringUtils.cs
+++ b/src/Lucene.Net.Core/Util/ToStringUtils.cs
@@ -57,7 +57,10 @@ namespace Lucene.Net.Util
 
         private static readonly char[] HEX = "0123456789abcdef".ToCharArray();
 
-        public static string LongHex(long x)
+        /// <summary>
+        /// NOTE: This was longHex() in Lucene
+        /// </summary>
+        public static string Int64Hex(long x)
         {
             char[] asHex = new char[16];
             for (int i = 16; --i >= 0; x = (long)((ulong)x >> 4))

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Util/UnicodeUtil.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/UnicodeUtil.cs b/src/Lucene.Net.Core/Util/UnicodeUtil.cs
index 797d5e1..a9d1e34 100644
--- a/src/Lucene.Net.Core/Util/UnicodeUtil.cs
+++ b/src/Lucene.Net.Core/Util/UnicodeUtil.cs
@@ -539,13 +539,13 @@ namespace Lucene.Net.Util
             // TODO: broken if incoming result.offset != 0
             // pre-alloc for worst case
             // TODO: ints cannot be null, should be an assert
-            if (utf32.Ints == null || utf32.Ints.Length < utf8.Length)
+            if (utf32.Int32s == null || utf32.Int32s.Length < utf8.Length)
             {
-                utf32.Ints = new int[utf8.Length];
+                utf32.Int32s = new int[utf8.Length];
             }
             int utf32Count = 0;
             int utf8Upto = utf8.Offset;
-            int[] ints = utf32.Ints;
+            int[] ints = utf32.Int32s;
             var bytes = utf8.Bytes;
             int utf8Limit = utf8.Offset + utf8.Length;
             while (utf8Upto < utf8Limit)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Util/WAH8DocIdSet.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/WAH8DocIdSet.cs b/src/Lucene.Net.Core/Util/WAH8DocIdSet.cs
index 3540399..f6ac44a 100644
--- a/src/Lucene.Net.Core/Util/WAH8DocIdSet.cs
+++ b/src/Lucene.Net.Core/Util/WAH8DocIdSet.cs
@@ -330,11 +330,11 @@ namespace Lucene.Net.Util
                 @out.WriteByte((byte)(sbyte)token);
                 if (cleanLengthMinus2 > 0x03)
                 {
-                    @out.WriteVInt((int)((uint)cleanLengthMinus2 >> 2));
+                    @out.WriteVInt32((int)((uint)cleanLengthMinus2 >> 2));
                 }
                 if (dirtyLength > 0x07)
                 {
-                    @out.WriteVInt((int)((uint)dirtyLength >> 3));
+                    @out.WriteVInt32((int)((uint)dirtyLength >> 3));
                 }
             }
 
@@ -616,7 +616,7 @@ namespace Lucene.Net.Util
             int startPosition = @in.Position;
             if ((len & 0x04) != 0)
             {
-                len = (len & 0x03) | (@in.ReadVInt() << 2);
+                len = (len & 0x03) | (@in.ReadVInt32() << 2);
             }
             if (startPosition != 1)
             {
@@ -630,7 +630,7 @@ namespace Lucene.Net.Util
             int len = token & 0x0F;
             if ((len & 0x08) != 0)
             {
-                len = (len & 0x07) | (@in.ReadVInt() << 3);
+                len = (len & 0x07) | (@in.ReadVInt32() << 3);
             }
             return len;
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Facet/FacetsConfig.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Facet/FacetsConfig.cs b/src/Lucene.Net.Facet/FacetsConfig.cs
index 1d5cb52..adb1af0 100644
--- a/src/Lucene.Net.Facet/FacetsConfig.cs
+++ b/src/Lucene.Net.Facet/FacetsConfig.cs
@@ -425,11 +425,11 @@ namespace Lucene.Net.Facet
 
                     CheckTaxoWriter(taxoWriter);
                     int ordinal = taxoWriter.AddCategory(cp);
-                    if (ordinals.Length == ordinals.Ints.Length)
+                    if (ordinals.Length == ordinals.Int32s.Length)
                     {
                         ordinals.Grow(ordinals.Length + 1);
                     }
-                    ordinals.Ints[ordinals.Length++] = ordinal;
+                    ordinals.Int32s[ordinals.Length++] = ordinal;
                     //System.out.println("ords[" + (ordinals.length-1) + "]=" + ordinal);
                     //System.out.println("  add cp=" + cp);
 
@@ -440,11 +440,11 @@ namespace Lucene.Net.Facet
                         int parent = taxoWriter.GetParent(ordinal);
                         while (parent > 0)
                         {
-                            if (ordinals.Ints.Length == ordinals.Length)
+                            if (ordinals.Int32s.Length == ordinals.Length)
                             {
                                 ordinals.Grow(ordinals.Length + 1);
                             }
-                            ordinals.Ints[ordinals.Length++] = parent;
+                            ordinals.Int32s[ordinals.Length++] = parent;
                             parent = taxoWriter.GetParent(parent);
                         }
 
@@ -538,13 +538,13 @@ namespace Lucene.Net.Facet
         /// </summary>
         protected virtual BytesRef DedupAndEncode(IntsRef ordinals)
         {
-            Array.Sort(ordinals.Ints, ordinals.Offset, ordinals.Length);
+            Array.Sort(ordinals.Int32s, ordinals.Offset, ordinals.Length);
             byte[] bytes = new byte[5 * ordinals.Length];
             int lastOrd = -1;
             int upto = 0;
             for (int i = 0; i < ordinals.Length; i++)
             {
-                int ord = ordinals.Ints[ordinals.Offset + i];
+                int ord = ordinals.Int32s[ordinals.Offset + i];
                 // ord could be == lastOrd, so we must dedup:
                 if (ord > lastOrd)
                 {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Facet/Range/DoubleRange.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Facet/Range/DoubleRange.cs b/src/Lucene.Net.Facet/Range/DoubleRange.cs
index 3bdb9fc..3f3d034 100644
--- a/src/Lucene.Net.Facet/Range/DoubleRange.cs
+++ b/src/Lucene.Net.Facet/Range/DoubleRange.cs
@@ -107,7 +107,7 @@ namespace Lucene.Net.Facet.Range
 
         internal LongRange ToLongRange()
         {
-            return new LongRange(Label, NumericUtils.DoubleToSortableLong(minIncl), true, NumericUtils.DoubleToSortableLong(maxIncl), true);
+            return new LongRange(Label, NumericUtils.DoubleToSortableInt64(minIncl), true, NumericUtils.DoubleToSortableInt64(maxIncl), true);
         }
 
         public override string ToString()

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Facet/Range/DoubleRangeFacetCounts.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Facet/Range/DoubleRangeFacetCounts.cs b/src/Lucene.Net.Facet/Range/DoubleRangeFacetCounts.cs
index b5ba376..c37f999 100644
--- a/src/Lucene.Net.Facet/Range/DoubleRangeFacetCounts.cs
+++ b/src/Lucene.Net.Facet/Range/DoubleRangeFacetCounts.cs
@@ -91,7 +91,7 @@ namespace Lucene.Net.Facet.Range
             for (int i = 0; i < ranges.Length; i++)
             {
                 DoubleRange range = ranges[i];
-                longRanges[i] = new LongRange(range.Label, NumericUtils.DoubleToSortableLong(range.minIncl), true, NumericUtils.DoubleToSortableLong(range.maxIncl), true);
+                longRanges[i] = new LongRange(range.Label, NumericUtils.DoubleToSortableInt64(range.minIncl), true, NumericUtils.DoubleToSortableInt64(range.maxIncl), true);
             }
 
             LongRangeCounter counter = new LongRangeCounter(longRanges);
@@ -135,7 +135,7 @@ namespace Lucene.Net.Facet.Range
                     // Skip missing docs:
                     if (fv.Exists(doc))
                     {
-                        counter.Add(NumericUtils.DoubleToSortableLong(fv.DoubleVal(doc)));
+                        counter.Add(NumericUtils.DoubleToSortableInt64(fv.DoubleVal(doc)));
                     }
                     else
                     {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Facet/Taxonomy/CachedOrdinalsReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Facet/Taxonomy/CachedOrdinalsReader.cs b/src/Lucene.Net.Facet/Taxonomy/CachedOrdinalsReader.cs
index a63e5da..a3dd984 100644
--- a/src/Lucene.Net.Facet/Taxonomy/CachedOrdinalsReader.cs
+++ b/src/Lucene.Net.Facet/Taxonomy/CachedOrdinalsReader.cs
@@ -116,7 +116,7 @@ namespace Lucene.Net.Facet.Taxonomy
 
             public override void Get(int docID, IntsRef ordinals)
             {
-                ordinals.Ints = cachedOrds.Ordinals;
+                ordinals.Int32s = cachedOrds.Ordinals;
                 ordinals.Offset = cachedOrds.Offsets[docID];
                 ordinals.Length = cachedOrds.Offsets[docID + 1] - ordinals.Offset;
             }
@@ -166,7 +166,7 @@ namespace Lucene.Net.Facet.Taxonomy
                         }
                         ords = ArrayUtil.Grow(ords, (int)nextLength);
                     }
-                    Array.Copy(values.Ints, 0, ords, (int)totOrds, values.Length);
+                    Array.Copy(values.Int32s, 0, ords, (int)totOrds, values.Length);
                     totOrds = nextLength;
                 }
                 Offsets[maxDoc] = (int)totOrds;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Facet/Taxonomy/Directory/DirectoryTaxonomyWriter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Facet/Taxonomy/Directory/DirectoryTaxonomyWriter.cs b/src/Lucene.Net.Facet/Taxonomy/Directory/DirectoryTaxonomyWriter.cs
index 44bccb8..c8fcbd6 100644
--- a/src/Lucene.Net.Facet/Taxonomy/Directory/DirectoryTaxonomyWriter.cs
+++ b/src/Lucene.Net.Facet/Taxonomy/Directory/DirectoryTaxonomyWriter.cs
@@ -1047,13 +1047,13 @@ namespace Lucene.Net.Facet.Taxonomy.Directory
 
             public void AddMapping(int origOrdinal, int newOrdinal)
             {
-                @out.WriteInt(origOrdinal);
-                @out.WriteInt(newOrdinal);
+                @out.WriteInt32(origOrdinal);
+                @out.WriteInt32(newOrdinal);
             }
 
             public void SetSize(int taxonomySize)
             {
-                @out.WriteInt(taxonomySize);
+                @out.WriteInt32(taxonomySize);
             }
 
             public void AddDone()
@@ -1077,14 +1077,14 @@ namespace Lucene.Net.Facet.Taxonomy.Directory
 
                 var ifs = new FileStream(tmpfile, FileMode.OpenOrCreate, FileAccess.Read);
                 var @in = new InputStreamDataInput(ifs);
-                map = new int[@in.ReadInt()];
+                map = new int[@in.ReadInt32()];
                 // NOTE: The current code assumes here that the map is complete,
                 // i.e., every ordinal gets one and exactly one value. Otherwise,
                 // we may run into an EOF here, or vice versa, not read everything.
                 for (int i = 0; i < map.Length; i++)
                 {
-                    int origordinal = @in.ReadInt();
-                    int newordinal = @in.ReadInt();
+                    int origordinal = @in.ReadInt32();
+                    int newordinal = @in.ReadInt32();
                     map[origordinal] = newordinal;
                 }
                 @in.Dispose();

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Facet/Taxonomy/DocValuesOrdinalsReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Facet/Taxonomy/DocValuesOrdinalsReader.cs b/src/Lucene.Net.Facet/Taxonomy/DocValuesOrdinalsReader.cs
index cc8137c..22ac0e5 100644
--- a/src/Lucene.Net.Facet/Taxonomy/DocValuesOrdinalsReader.cs
+++ b/src/Lucene.Net.Facet/Taxonomy/DocValuesOrdinalsReader.cs
@@ -97,9 +97,9 @@
             // grow the buffer up front, even if by a large number of values (buf.length)
             // that saves the need to check inside the loop for every decoded value if
             // the buffer needs to grow.
-            if (ordinals.Ints.Length < buf.Length)
+            if (ordinals.Int32s.Length < buf.Length)
             {
-                ordinals.Ints = ArrayUtil.Grow(ordinals.Ints, buf.Length);
+                ordinals.Int32s = ArrayUtil.Grow(ordinals.Int32s, buf.Length);
             }
 
             ordinals.Offset = 0;
@@ -116,9 +116,9 @@
                 byte b = buf.Bytes[offset++];
                 if ((sbyte)b >= 0)
                 {
-                    ordinals.Ints[ordinals.Length] = ((value << 7) | b) + prev;
+                    ordinals.Int32s[ordinals.Length] = ((value << 7) | b) + prev;
                     value = 0;
-                    prev = ordinals.Ints[ordinals.Length];
+                    prev = ordinals.Int32s[ordinals.Length];
                     ordinals.Length++;
                 }
                 else

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Facet/Taxonomy/FloatAssociationFacetField.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Facet/Taxonomy/FloatAssociationFacetField.cs b/src/Lucene.Net.Facet/Taxonomy/FloatAssociationFacetField.cs
index dbcf615..67026cc 100644
--- a/src/Lucene.Net.Facet/Taxonomy/FloatAssociationFacetField.cs
+++ b/src/Lucene.Net.Facet/Taxonomy/FloatAssociationFacetField.cs
@@ -46,7 +46,7 @@ namespace Lucene.Net.Facet.Taxonomy
         /// </summary>
         public static BytesRef FloatToBytesRef(float v)
         {
-            return IntAssociationFacetField.IntToBytesRef(Number.FloatToIntBits(v));
+            return IntAssociationFacetField.IntToBytesRef(Number.SingleToInt32Bits(v));
         }
 
         /// <summary>
@@ -54,7 +54,7 @@ namespace Lucene.Net.Facet.Taxonomy
         /// </summary>
         public static float BytesRefToFloat(BytesRef b)
         {
-            return Number.IntBitsToFloat(IntAssociationFacetField.BytesRefToInt(b));
+            return Number.Int32BitsToSingle(IntAssociationFacetField.BytesRefToInt(b));
         }
 
         public override string ToString()

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Facet/Taxonomy/TaxonomyFacetCounts.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Facet/Taxonomy/TaxonomyFacetCounts.cs b/src/Lucene.Net.Facet/Taxonomy/TaxonomyFacetCounts.cs
index f6c4ca4..3c5ce9e 100644
--- a/src/Lucene.Net.Facet/Taxonomy/TaxonomyFacetCounts.cs
+++ b/src/Lucene.Net.Facet/Taxonomy/TaxonomyFacetCounts.cs
@@ -60,7 +60,7 @@ namespace Lucene.Net.Facet.Taxonomy
                     ords.Get(doc, scratch);
                     for (int i = 0; i < scratch.Length; i++)
                     {
-                        m_values[scratch.Ints[scratch.Offset + i]]++;
+                        m_values[scratch.Int32s[scratch.Offset + i]]++;
                     }
                 }
             }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Facet/Taxonomy/TaxonomyFacetSumFloatAssociations.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Facet/Taxonomy/TaxonomyFacetSumFloatAssociations.cs b/src/Lucene.Net.Facet/Taxonomy/TaxonomyFacetSumFloatAssociations.cs
index 9a4612a..b36474e 100644
--- a/src/Lucene.Net.Facet/Taxonomy/TaxonomyFacetSumFloatAssociations.cs
+++ b/src/Lucene.Net.Facet/Taxonomy/TaxonomyFacetSumFloatAssociations.cs
@@ -85,7 +85,7 @@ namespace Lucene.Net.Facet.Taxonomy
                         int value = ((bytes[offset] & 0xFF) << 24) | ((bytes[offset + 1] & 0xFF) << 16) | 
                             ((bytes[offset + 2] & 0xFF) << 8) | (bytes[offset + 3] & 0xFF);
                         offset += 4;
-                        m_values[ord] += Number.IntBitsToFloat(value);
+                        m_values[ord] += Number.Int32BitsToSingle(value);
                     }
                 }
             }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Facet/Taxonomy/TaxonomyFacetSumValueSource.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Facet/Taxonomy/TaxonomyFacetSumValueSource.cs b/src/Lucene.Net.Facet/Taxonomy/TaxonomyFacetSumValueSource.cs
index eee089d..ae5c251 100644
--- a/src/Lucene.Net.Facet/Taxonomy/TaxonomyFacetSumValueSource.cs
+++ b/src/Lucene.Net.Facet/Taxonomy/TaxonomyFacetSumValueSource.cs
@@ -146,7 +146,7 @@ namespace Lucene.Net.Facet.Taxonomy
                     float value = (float)functionValues.DoubleVal(doc);
                     for (int i = 0; i < scratch.Length; i++)
                     {
-                        m_values[scratch.Ints[i]] += value;
+                        m_values[scratch.Int32s[i]] += value;
                     }
                 }
             }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Highlighter/VectorHighlight/FieldPhraseList.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Highlighter/VectorHighlight/FieldPhraseList.cs b/src/Lucene.Net.Highlighter/VectorHighlight/FieldPhraseList.cs
index a664b54..136cb82 100644
--- a/src/Lucene.Net.Highlighter/VectorHighlight/FieldPhraseList.cs
+++ b/src/Lucene.Net.Highlighter/VectorHighlight/FieldPhraseList.cs
@@ -418,7 +418,7 @@ namespace Lucene.Net.Search.VectorHighlight
                 int result = 1;
                 result = prime * result + StartOffset;
                 result = prime * result + EndOffset;
-                long b = Number.DoubleToLongBits(Boost);
+                long b = Number.DoubleToInt64Bits(Boost);
                 result = prime * result + (int)(b ^ TripleShift(b, 32));
                 return result;
             }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Memory/MemoryIndex.MemoryIndexReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Memory/MemoryIndex.MemoryIndexReader.cs b/src/Lucene.Net.Memory/MemoryIndex.MemoryIndexReader.cs
index 3553d01..2be3ad6 100644
--- a/src/Lucene.Net.Memory/MemoryIndex.MemoryIndexReader.cs
+++ b/src/Lucene.Net.Memory/MemoryIndex.MemoryIndexReader.cs
@@ -533,14 +533,14 @@ namespace Lucene.Net.Index.Memory
                     Debug.Assert(!sliceReader.EndOfSlice(), " stores offsets : " + startOffset_Renamed);
                     if (outerInstance.outerInstance.storeOffsets)
                     {
-                        int pos = sliceReader.ReadInt();
-                        startOffset_Renamed = sliceReader.ReadInt();
-                        endOffset_Renamed = sliceReader.ReadInt();
+                        int pos = sliceReader.ReadInt32();
+                        startOffset_Renamed = sliceReader.ReadInt32();
+                        endOffset_Renamed = sliceReader.ReadInt32();
                         return pos;
                     }
                     else
                     {
-                        return sliceReader.ReadInt();
+                        return sliceReader.ReadInt32();
                     }
                 }
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Memory/MemoryIndex.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Memory/MemoryIndex.cs b/src/Lucene.Net.Memory/MemoryIndex.cs
index cd4a284..2923214 100644
--- a/src/Lucene.Net.Memory/MemoryIndex.cs
+++ b/src/Lucene.Net.Memory/MemoryIndex.cs
@@ -458,13 +458,13 @@ namespace Lucene.Net.Index.Memory
                     sumTotalTermFreq++;
                     if (!storeOffsets)
                     {
-                        postingsWriter.WriteInt(pos);
+                        postingsWriter.WriteInt32(pos);
                     }
                     else
                     {
-                        postingsWriter.WriteInt(pos);
-                        postingsWriter.WriteInt(offsetAtt.StartOffset + offset);
-                        postingsWriter.WriteInt(offsetAtt.EndOffset + offset);
+                        postingsWriter.WriteInt32(pos);
+                        postingsWriter.WriteInt32(offsetAtt.StartOffset + offset);
+                        postingsWriter.WriteInt32(offsetAtt.EndOffset + offset);
                     }
                     sliceArray.end[ord] = postingsWriter.CurrentOffset;
                 }
@@ -672,7 +672,7 @@ namespace Lucene.Net.Index.Memory
 
                         for (int k = 0; k < iters; k++)
                         {
-                            result.Append(postingsReader.ReadInt());
+                            result.Append(postingsReader.ReadInt32());
                             if (k < iters - 1)
                             {
                                 result.Append(", ");

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Misc/Index/Sorter/SortingAtomicReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Misc/Index/Sorter/SortingAtomicReader.cs b/src/Lucene.Net.Misc/Index/Sorter/SortingAtomicReader.cs
index 32e7783..6b4e60d 100644
--- a/src/Lucene.Net.Misc/Index/Sorter/SortingAtomicReader.cs
+++ b/src/Lucene.Net.Misc/Index/Sorter/SortingAtomicReader.cs
@@ -682,7 +682,7 @@ namespace Lucene.Net.Index.Sorter
             internal virtual void AddPositions(DocsAndPositionsEnum @in, IndexOutput @out)
             {
                 int freq = @in.Freq;
-                @out.WriteVInt(freq);
+                @out.WriteVInt32(freq);
                 int previousPosition = 0;
                 int previousEndOffset = 0;
                 for (int i = 0; i < freq; i++)
@@ -692,19 +692,19 @@ namespace Lucene.Net.Index.Sorter
                     // The low-order bit of token is set only if there is a payload, the
                     // previous bits are the delta-encoded position. 
                     int token = (pos - previousPosition) << 1 | (payload == null ? 0 : 1);
-                    @out.WriteVInt(token);
+                    @out.WriteVInt32(token);
                     previousPosition = pos;
                     if (storeOffsets) // don't encode offsets if they are not stored
                     {
                         int startOffset = @in.StartOffset;
                         int endOffset = @in.EndOffset;
-                        @out.WriteVInt(startOffset - previousEndOffset);
-                        @out.WriteVInt(endOffset - startOffset);
+                        @out.WriteVInt32(startOffset - previousEndOffset);
+                        @out.WriteVInt32(endOffset - startOffset);
                         previousEndOffset = endOffset;
                     }
                     if (payload != null)
                     {
-                        @out.WriteVInt(payload.Length);
+                        @out.WriteVInt32(payload.Length);
                         @out.WriteBytes(payload.Bytes, payload.Offset, payload.Length);
                     }
                 }
@@ -744,7 +744,7 @@ namespace Lucene.Net.Index.Sorter
                     return DocIdSetIterator.NO_MORE_DOCS;
                 }
                 postingInput.Seek(offsets[docIt]);
-                currFreq = postingInput.ReadVInt();
+                currFreq = postingInput.ReadVInt32();
                 // reset variables used in nextPosition
                 pos = 0;
                 endOffset = 0;
@@ -753,17 +753,17 @@ namespace Lucene.Net.Index.Sorter
 
             public override int NextPosition()
             {
-                int token = postingInput.ReadVInt();
+                int token = postingInput.ReadVInt32();
                 pos += (int)((uint)token >> 1);
                 if (storeOffsets)
                 {
-                    startOffset = endOffset + postingInput.ReadVInt();
-                    endOffset = startOffset + postingInput.ReadVInt();
+                    startOffset = endOffset + postingInput.ReadVInt32();
+                    endOffset = startOffset + postingInput.ReadVInt32();
                 }
                 if ((token & 1) != 0)
                 {
                     payload.Offset = 0;
-                    payload.Length = postingInput.ReadVInt();
+                    payload.Length = postingInput.ReadVInt32();
                     if (payload.Length > payload.Bytes.Length)
                     {
                         payload.Bytes = new byte[ArrayUtil.Oversize(payload.Length, 1)];

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Misc/Util/Fst/ListOfOutputs.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Misc/Util/Fst/ListOfOutputs.cs b/src/Lucene.Net.Misc/Util/Fst/ListOfOutputs.cs
index 851f7cb..bf5a057 100644
--- a/src/Lucene.Net.Misc/Util/Fst/ListOfOutputs.cs
+++ b/src/Lucene.Net.Misc/Util/Fst/ListOfOutputs.cs
@@ -112,13 +112,13 @@ namespace Lucene.Net.Util.Fst
         {
             if (!(output is IList))
             {
-                @out.WriteVInt(1);
+                @out.WriteVInt32(1);
                 outputs.Write((T)output, @out);
             }
             else
             {
                 IList outputList = (IList)output;
-                @out.WriteVInt(outputList.Count);
+                @out.WriteVInt32(outputList.Count);
                 foreach (var eachOutput in outputList)
                 {
                     outputs.Write((T)eachOutput, @out);
@@ -133,7 +133,7 @@ namespace Lucene.Net.Util.Fst
 
         public override object ReadFinalOutput(DataInput @in)
         {
-            int count = @in.ReadVInt();
+            int count = @in.ReadVInt32();
             if (count == 1)
             {
                 return outputs.Read(@in);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Misc/Util/Fst/UpToTwoPositiveIntOutputs.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Misc/Util/Fst/UpToTwoPositiveIntOutputs.cs b/src/Lucene.Net.Misc/Util/Fst/UpToTwoPositiveIntOutputs.cs
index 1e4cb0f..c4db55a 100644
--- a/src/Lucene.Net.Misc/Util/Fst/UpToTwoPositiveIntOutputs.cs
+++ b/src/Lucene.Net.Misc/Util/Fst/UpToTwoPositiveIntOutputs.cs
@@ -215,19 +215,19 @@ namespace Lucene.Net.Util.Fst
             if (output is long?)
             {
                 long? output2 = (long?)output;
-                @out.WriteVLong(output2.GetValueOrDefault() << 1);
+                @out.WriteVInt64(output2.GetValueOrDefault() << 1);
             }
             else
             {
                 TwoLongs output3 = (TwoLongs)output;
-                @out.WriteVLong((output3.First << 1) | 1);
-                @out.WriteVLong(output3.Second);
+                @out.WriteVInt64((output3.First << 1) | 1);
+                @out.WriteVInt64(output3.Second);
             }
         }
 
         public override object Read(DataInput @in)
         {
-            long code = @in.ReadVLong();
+            long code = @in.ReadVInt64();
             if ((code & 1) == 0)
             {
                 // single long
@@ -245,7 +245,7 @@ namespace Lucene.Net.Util.Fst
             {
                 // two longs
                 long first = (long)((ulong)code >> 1);
-                long second = @in.ReadVLong();
+                long second = @in.ReadVInt64();
                 return new TwoLongs(first, second);
             }
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Queries/BoostingQuery.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/BoostingQuery.cs b/src/Lucene.Net.Queries/BoostingQuery.cs
index 364bfc5..57c9bd9 100644
--- a/src/Lucene.Net.Queries/BoostingQuery.cs
+++ b/src/Lucene.Net.Queries/BoostingQuery.cs
@@ -107,7 +107,7 @@ namespace Lucene.Net.Queries
         {
             const int prime = 31;
             int result = base.GetHashCode();
-            result = prime * result + Number.FloatToIntBits(boost);
+            result = prime * result + Number.SingleToInt32Bits(boost);
             result = prime * result + ((context == null) ? 0 : context.GetHashCode());
             result = prime * result + ((match == null) ? 0 : match.GetHashCode());
             return result;
@@ -134,7 +134,7 @@ namespace Lucene.Net.Queries
             }
 
             var other = (BoostingQuery)obj;
-            if (Number.FloatToIntBits(boost) != Number.FloatToIntBits(other.boost))
+            if (Number.SingleToInt32Bits(boost) != Number.SingleToInt32Bits(other.boost))
             {
                 return false;
             }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Queries/CommonTermsQuery.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/CommonTermsQuery.cs b/src/Lucene.Net.Queries/CommonTermsQuery.cs
index de2382b..8735514 100644
--- a/src/Lucene.Net.Queries/CommonTermsQuery.cs
+++ b/src/Lucene.Net.Queries/CommonTermsQuery.cs
@@ -390,13 +390,13 @@ namespace Lucene.Net.Queries
             const int prime = 31;
             int result = base.GetHashCode();
             result = prime * result + (m_disableCoord ? 1231 : 1237);
-            result = prime * result + Number.FloatToIntBits(m_highFreqBoost);
+            result = prime * result + Number.SingleToInt32Bits(m_highFreqBoost);
             result = prime * result + /*((highFreqOccur == null) ? 0 :*/ m_highFreqOccur.GetHashCode()/*)*/;
-            result = prime * result + Number.FloatToIntBits(m_lowFreqBoost);
+            result = prime * result + Number.SingleToInt32Bits(m_lowFreqBoost);
             result = prime * result + /*((lowFreqOccur == null) ? 0 :*/ m_lowFreqOccur.GetHashCode()/*)*/;
-            result = prime * result + Number.FloatToIntBits(m_maxTermFrequency);
-            result = prime * result + Number.FloatToIntBits(m_lowFreqMinNrShouldMatch);
-            result = prime * result + Number.FloatToIntBits(m_highFreqMinNrShouldMatch);
+            result = prime * result + Number.SingleToInt32Bits(m_maxTermFrequency);
+            result = prime * result + Number.SingleToInt32Bits(m_lowFreqMinNrShouldMatch);
+            result = prime * result + Number.SingleToInt32Bits(m_highFreqMinNrShouldMatch);
             result = prime * result + ((m_terms == null) ? 0 : m_terms.GetValueHashCode());
             return result;
         }
@@ -420,7 +420,7 @@ namespace Lucene.Net.Queries
             {
                 return false;
             }
-            if (Number.FloatToIntBits(m_highFreqBoost) != Number.FloatToIntBits(other.m_highFreqBoost))
+            if (Number.SingleToInt32Bits(m_highFreqBoost) != Number.SingleToInt32Bits(other.m_highFreqBoost))
             {
                 return false;
             }
@@ -428,7 +428,7 @@ namespace Lucene.Net.Queries
             {
                 return false;
             }
-            if (Number.FloatToIntBits(m_lowFreqBoost) != Number.FloatToIntBits(other.m_lowFreqBoost))
+            if (Number.SingleToInt32Bits(m_lowFreqBoost) != Number.SingleToInt32Bits(other.m_lowFreqBoost))
             {
                 return false;
             }
@@ -436,7 +436,7 @@ namespace Lucene.Net.Queries
             {
                 return false;
             }
-            if (Number.FloatToIntBits(m_maxTermFrequency) != Number.FloatToIntBits(other.m_maxTermFrequency))
+            if (Number.SingleToInt32Bits(m_maxTermFrequency) != Number.SingleToInt32Bits(other.m_maxTermFrequency))
             {
                 return false;
             }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Queries/CustomScoreQuery.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/CustomScoreQuery.cs b/src/Lucene.Net.Queries/CustomScoreQuery.cs
index 2fef745..decceea 100644
--- a/src/Lucene.Net.Queries/CustomScoreQuery.cs
+++ b/src/Lucene.Net.Queries/CustomScoreQuery.cs
@@ -179,7 +179,7 @@ namespace Lucene.Net.Queries
         public override int GetHashCode()
         {
             return (this.GetType().GetHashCode() + subQuery.GetHashCode() + Arrays.GetHashCode(scoringQueries)) ^
-                   Number.FloatToIntBits(Boost) ^ (strict ? 1234 : 4321);
+                   Number.SingleToInt32Bits(Boost) ^ (strict ? 1234 : 4321);
         }
 
         /// <summary>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Queries/Function/BoostedQuery.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/BoostedQuery.cs b/src/Lucene.Net.Queries/Function/BoostedQuery.cs
index 7afdd5c..1cd591e 100644
--- a/src/Lucene.Net.Queries/Function/BoostedQuery.cs
+++ b/src/Lucene.Net.Queries/Function/BoostedQuery.cs
@@ -243,7 +243,7 @@ namespace Lucene.Net.Queries.Function
             h ^= (h << 17) | ((int)((uint)h >> 16));
             h += boostVal.GetHashCode();
             h ^= (h << 8) | ((int)((uint)h >> 25));
-            h += Number.FloatToIntBits(Boost);
+            h += Number.SingleToInt32Bits(Boost);
             return h;
         }
     }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Queries/Function/FunctionQuery.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/FunctionQuery.cs b/src/Lucene.Net.Queries/Function/FunctionQuery.cs
index 0b088e2..a82ec72 100644
--- a/src/Lucene.Net.Queries/Function/FunctionQuery.cs
+++ b/src/Lucene.Net.Queries/Function/FunctionQuery.cs
@@ -231,7 +231,7 @@ namespace Lucene.Net.Queries.Function
         /// </summary>
         public override int GetHashCode()
         {
-            return func.GetHashCode() * 31 + Number.FloatToIntBits(Boost);
+            return func.GetHashCode() * 31 + Number.SingleToInt32Bits(Boost);
         }
     }
 }
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Queries/Function/ValueSources/ByteFieldSource.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/ByteFieldSource.cs b/src/Lucene.Net.Queries/Function/ValueSources/ByteFieldSource.cs
index b040454..e915d36 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/ByteFieldSource.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/ByteFieldSource.cs
@@ -24,7 +24,7 @@ namespace Lucene.Net.Queries.Function.ValueSources
     
     /// <summary>
     /// Obtains <see cref="int"/> field values from the <see cref="Search.FieldCache"/>
-    /// using <see cref="IFieldCache.GetInts"/>
+    /// using <see cref="IFieldCache.GetInt32s"/>
     /// and makes those values available as other numeric types, casting as needed. *
     /// </summary>
     [Obsolete]

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Queries/Function/ValueSources/ConstValueSource.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/ConstValueSource.cs b/src/Lucene.Net.Queries/Function/ValueSources/ConstValueSource.cs
index 1aee2db..bd9a8aa 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/ConstValueSource.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/ConstValueSource.cs
@@ -88,7 +88,7 @@ namespace Lucene.Net.Queries.Function.ValueSources
 
         public override int GetHashCode()
         {
-            return Number.FloatToIntBits(constant) * 31;
+            return Number.SingleToInt32Bits(constant) * 31;
         }
 
         public override bool Equals(object o)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Queries/Function/ValueSources/DoubleConstValueSource.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/DoubleConstValueSource.cs b/src/Lucene.Net.Queries/Function/ValueSources/DoubleConstValueSource.cs
index 2003dab..73407ae 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/DoubleConstValueSource.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/DoubleConstValueSource.cs
@@ -96,7 +96,7 @@ namespace Lucene.Net.Queries.Function.ValueSources
 
         public override int GetHashCode()
         {
-            long bits = Lucene.Net.Support.Number.DoubleToRawLongBits(constant);
+            long bits = Lucene.Net.Support.Number.DoubleToRawInt64Bits(constant);
             return (int)(bits ^ ((long)((ulong)bits >> 32)));
         }
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Queries/Function/ValueSources/EnumFieldSource.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/EnumFieldSource.cs b/src/Lucene.Net.Queries/Function/ValueSources/EnumFieldSource.cs
index 4e4f32b..a642ab8 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/EnumFieldSource.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/EnumFieldSource.cs
@@ -28,7 +28,7 @@ namespace Lucene.Net.Queries.Function.ValueSources
      */
 
     /// <summary>
-    /// Obtains <see cref="int"/> field values from <see cref="IFieldCache.GetInts"/> and makes
+    /// Obtains <see cref="int"/> field values from <see cref="IFieldCache.GetInt32s"/> and makes
     /// those values available as other numeric types, casting as needed.
     /// StrVal of the value is not the <see cref="int"/> value, but its <see cref="string"/> (displayed) value
     /// </summary>
@@ -114,7 +114,7 @@ namespace Lucene.Net.Queries.Function.ValueSources
 
         public override FunctionValues GetValues(IDictionary context, AtomicReaderContext readerContext)
         {
-            var arr = m_cache.GetInts(readerContext.AtomicReader, m_field, parser, true);
+            var arr = m_cache.GetInt32s(readerContext.AtomicReader, m_field, parser, true);
             var valid = m_cache.GetDocsWithField(readerContext.AtomicReader, m_field);
 
             return new IntDocValuesAnonymousInnerClassHelper(this, this, arr, valid);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Queries/Function/ValueSources/FloatFieldSource.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/FloatFieldSource.cs b/src/Lucene.Net.Queries/Function/ValueSources/FloatFieldSource.cs
index 5143b5c..3207939 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/FloatFieldSource.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/FloatFieldSource.cs
@@ -50,7 +50,7 @@ namespace Lucene.Net.Queries.Function.ValueSources
 
         public override FunctionValues GetValues(IDictionary context, AtomicReaderContext readerContext)
         {
-            var arr = m_cache.GetFloats(readerContext.AtomicReader, m_field, m_parser, true);
+            var arr = m_cache.GetSingles(readerContext.AtomicReader, m_field, m_parser, true);
             var valid = m_cache.GetDocsWithField(readerContext.AtomicReader, m_field);
             return new FloatDocValuesAnonymousInnerClassHelper(this, arr, valid);
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Queries/Function/ValueSources/IntFieldSource.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/IntFieldSource.cs b/src/Lucene.Net.Queries/Function/ValueSources/IntFieldSource.cs
index 5d13611..e4af2e0 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/IntFieldSource.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/IntFieldSource.cs
@@ -26,7 +26,7 @@ namespace Lucene.Net.Queries.Function.ValueSources
      */
 
     /// <summary>
-    /// Obtains <see cref="int"/> field values from <see cref="IFieldCache.GetInts"/> and makes those
+    /// Obtains <see cref="int"/> field values from <see cref="IFieldCache.GetInt32s"/> and makes those
     /// values available as other numeric types, casting as needed.
     /// </summary>
     public class IntFieldSource : FieldCacheSource
@@ -51,7 +51,7 @@ namespace Lucene.Net.Queries.Function.ValueSources
 
         public override FunctionValues GetValues(IDictionary context, AtomicReaderContext readerContext)
         {
-            FieldCache.Ints arr = m_cache.GetInts(readerContext.AtomicReader, m_field, parser, true);
+            FieldCache.Ints arr = m_cache.GetInt32s(readerContext.AtomicReader, m_field, parser, true);
             IBits valid = m_cache.GetDocsWithField(readerContext.AtomicReader, m_field);
 
             return new IntDocValuesAnonymousInnerClassHelper(this, this, arr, valid);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Queries/Function/ValueSources/LinearFloatFunction.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/LinearFloatFunction.cs b/src/Lucene.Net.Queries/Function/ValueSources/LinearFloatFunction.cs
index d7cf53f..df56910 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/LinearFloatFunction.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/LinearFloatFunction.cs
@@ -82,9 +82,9 @@ namespace Lucene.Net.Queries.Function.ValueSources
 
         public override int GetHashCode()
         {
-            int h = Number.FloatToIntBits(m_slope);
+            int h = Number.SingleToInt32Bits(m_slope);
             h = ((int)((uint)h >> 2)) | (h << 30);
-            h += Number.FloatToIntBits(m_intercept);
+            h += Number.SingleToInt32Bits(m_intercept);
             h ^= (h << 14) | ((int)((uint)h >> 19));
             return h + m_source.GetHashCode();
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Queries/Function/ValueSources/LongFieldSource.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/LongFieldSource.cs b/src/Lucene.Net.Queries/Function/ValueSources/LongFieldSource.cs
index d13862a..c057651 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/LongFieldSource.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/LongFieldSource.cs
@@ -26,7 +26,7 @@ namespace Lucene.Net.Queries.Function.ValueSources
      */
 
     /// <summary>
-    /// Obtains <see cref="long"/> field values from <see cref="IFieldCache.GetLongs"/> and makes those
+    /// Obtains <see cref="long"/> field values from <see cref="IFieldCache.GetInt64s"/> and makes those
     /// values available as other numeric types, casting as needed.
     /// </summary>
     public class LongFieldSource : FieldCacheSource
@@ -66,7 +66,7 @@ namespace Lucene.Net.Queries.Function.ValueSources
 
         public override FunctionValues GetValues(IDictionary context, AtomicReaderContext readerContext)
         {
-            var arr = m_cache.GetLongs(readerContext.AtomicReader, m_field, m_parser, true);
+            var arr = m_cache.GetInt64s(readerContext.AtomicReader, m_field, m_parser, true);
             var valid = m_cache.GetDocsWithField(readerContext.AtomicReader, m_field);
             return new LongDocValuesAnonymousInnerClassHelper(this, this, arr, valid);
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Queries/Function/ValueSources/RangeMapFloatFunction.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/RangeMapFloatFunction.cs b/src/Lucene.Net.Queries/Function/ValueSources/RangeMapFloatFunction.cs
index d510257..a3f1f19 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/RangeMapFloatFunction.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/RangeMapFloatFunction.cs
@@ -101,9 +101,9 @@ namespace Lucene.Net.Queries.Function.ValueSources
         {
             int h = m_source.GetHashCode();
             h ^= (h << 10) | ((int)((uint)h >> 23));
-            h += Number.FloatToIntBits(m_min);
+            h += Number.SingleToInt32Bits(m_min);
             h ^= (h << 14) | ((int)((uint)h >> 19));
-            h += Number.FloatToIntBits(m_max);
+            h += Number.SingleToInt32Bits(m_max);
             h += m_target.GetHashCode();
             if (m_defaultVal != null)
             {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Queries/Function/ValueSources/ReciprocalFloatFunction.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/ReciprocalFloatFunction.cs b/src/Lucene.Net.Queries/Function/ValueSources/ReciprocalFloatFunction.cs
index 70032c8..02de918 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/ReciprocalFloatFunction.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/ReciprocalFloatFunction.cs
@@ -96,9 +96,9 @@ namespace Lucene.Net.Queries.Function.ValueSources
 
         public override int GetHashCode()
         {
-            int h = Number.FloatToIntBits(m_a) + Number.FloatToIntBits(m_m);
+            int h = Number.SingleToInt32Bits(m_a) + Number.SingleToInt32Bits(m_m);
             h ^= (h << 13) | ((int)((uint)h >> 20));
-            return h + (Number.FloatToIntBits(m_b)) + m_source.GetHashCode();
+            return h + (Number.SingleToInt32Bits(m_b)) + m_source.GetHashCode();
         }
 
         public override bool Equals(object o)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Queries/Function/ValueSources/ScaleFloatFunction.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/ScaleFloatFunction.cs b/src/Lucene.Net.Queries/Function/ValueSources/ScaleFloatFunction.cs
index a321258..2be917d 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/ScaleFloatFunction.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/ScaleFloatFunction.cs
@@ -73,7 +73,7 @@ namespace Lucene.Net.Queries.Function.ValueSources
                 {
 
                     float val = vals.FloatVal(i);
-                    if ((Number.FloatToRawIntBits(val) & (0xff << 23)) == 0xff << 23)
+                    if ((Number.SingleToRawInt32Bits(val) & (0xff << 23)) == 0xff << 23)
                     {
                         // if the exponent in the float is all ones, then this is +Inf, -Inf or NaN
                         // which don't make sense to factor into the scale function
@@ -154,9 +154,9 @@ namespace Lucene.Net.Queries.Function.ValueSources
 
         public override int GetHashCode()
         {
-            int h = Number.FloatToIntBits(m_min);
+            int h = Number.SingleToInt32Bits(m_min);
             h = h * 29;
-            h += Number.FloatToIntBits(m_max);
+            h += Number.SingleToInt32Bits(m_max);
             h = h * 29;
             h += m_source.GetHashCode();
             return h;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Queries/Function/ValueSources/ShortFieldSource.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/ShortFieldSource.cs b/src/Lucene.Net.Queries/Function/ValueSources/ShortFieldSource.cs
index d2d7c23..7419010 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/ShortFieldSource.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/ShortFieldSource.cs
@@ -50,7 +50,7 @@ namespace Lucene.Net.Queries.Function.ValueSources
 
         public override FunctionValues GetValues(IDictionary context, AtomicReaderContext readerContext)
         {
-            var arr = m_cache.GetShorts(readerContext.AtomicReader, m_field, parser, false);
+            var arr = m_cache.GetInt16s(readerContext.AtomicReader, m_field, parser, false);
             return new FunctionValuesAnonymousInnerClassHelper(this, arr);
         }
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Queries/Mlt/MoreLikeThisQuery.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Mlt/MoreLikeThisQuery.cs b/src/Lucene.Net.Queries/Mlt/MoreLikeThisQuery.cs
index 0aaa4de..62fd903 100644
--- a/src/Lucene.Net.Queries/Mlt/MoreLikeThisQuery.cs
+++ b/src/Lucene.Net.Queries/Mlt/MoreLikeThisQuery.cs
@@ -145,7 +145,7 @@ namespace Lucene.Net.Queries.Mlt
             result = prime * result + minDocFreq;
             result = prime * result + minTermFrequency;
             result = prime * result + Arrays.GetHashCode(moreLikeFields);
-            result = prime * result + Number.FloatToIntBits(percentTermsToMatch);
+            result = prime * result + Number.SingleToInt32Bits(percentTermsToMatch);
             result = prime * result + ((stopWords == null) ? 0 : stopWords.GetValueHashCode());
             return result;
         }
@@ -214,7 +214,7 @@ namespace Lucene.Net.Queries.Mlt
             {
                 return false;
             }
-            if (Number.FloatToIntBits(percentTermsToMatch) != Number.FloatToIntBits(other.percentTermsToMatch))
+            if (Number.SingleToInt32Bits(percentTermsToMatch) != Number.SingleToInt32Bits(other.percentTermsToMatch))
             {
                 return false;
             }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.QueryParser/Classic/QueryParserBase.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.QueryParser/Classic/QueryParserBase.cs b/src/Lucene.Net.QueryParser/Classic/QueryParserBase.cs
index f2a9798..0f0521d 100644
--- a/src/Lucene.Net.QueryParser/Classic/QueryParserBase.cs
+++ b/src/Lucene.Net.QueryParser/Classic/QueryParserBase.cs
@@ -544,7 +544,7 @@ namespace Lucene.Net.QueryParsers.Classic
             // FuzzyQuery doesn't yet allow constant score rewrite
             string text = term.Text();
 #pragma warning disable 612, 618
-            int numEdits = FuzzyQuery.FloatToEdits(minimumSimilarity,
+            int numEdits = FuzzyQuery.SingleToEdits(minimumSimilarity,
                 text.CodePointCount(0, text.Length));
 #pragma warning restore 612, 618
             return new FuzzyQuery(term, numEdits, prefixLength);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.QueryParser/Flexible/Standard/Builders/FuzzyQueryNodeBuilder.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.QueryParser/Flexible/Standard/Builders/FuzzyQueryNodeBuilder.cs b/src/Lucene.Net.QueryParser/Flexible/Standard/Builders/FuzzyQueryNodeBuilder.cs
index 3fa9c06..6ae4c99 100644
--- a/src/Lucene.Net.QueryParser/Flexible/Standard/Builders/FuzzyQueryNodeBuilder.cs
+++ b/src/Lucene.Net.QueryParser/Flexible/Standard/Builders/FuzzyQueryNodeBuilder.cs
@@ -38,7 +38,7 @@ namespace Lucene.Net.QueryParsers.Flexible.Standard.Builders
             string text = fuzzyNode.GetTextAsString();
 
 #pragma warning disable 612, 618
-            int numEdits = FuzzyQuery.FloatToEdits(fuzzyNode.Similarity,
+            int numEdits = FuzzyQuery.SingleToEdits(fuzzyNode.Similarity,
                 text.CodePointCount(0, text.Length));
 #pragma warning restore 612, 618
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.QueryParser/Flexible/Standard/Builders/NumericRangeQueryNodeBuilder.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.QueryParser/Flexible/Standard/Builders/NumericRangeQueryNodeBuilder.cs b/src/Lucene.Net.QueryParser/Flexible/Standard/Builders/NumericRangeQueryNodeBuilder.cs
index 52a8eb0..dffcd8b 100644
--- a/src/Lucene.Net.QueryParser/Flexible/Standard/Builders/NumericRangeQueryNodeBuilder.cs
+++ b/src/Lucene.Net.QueryParser/Flexible/Standard/Builders/NumericRangeQueryNodeBuilder.cs
@@ -64,16 +64,16 @@ namespace Lucene.Net.QueryParsers.Flexible.Standard.Builders
             switch (numberType)
             {
                 case NumericType.LONG:
-                    return NumericRangeQuery.NewLongRange(field, precisionStep,
+                    return NumericRangeQuery.NewInt64Range(field, precisionStep,
                         (long?)lowerNumber, (long?)upperNumber, minInclusive, maxInclusive);
 
                 case NumericType.INT:
-                    return NumericRangeQuery.NewIntRange(field, precisionStep,
+                    return NumericRangeQuery.NewInt32Range(field, precisionStep,
                         (int?)lowerNumber, (int?)upperNumber, minInclusive,
                         maxInclusive);
 
                 case NumericType.FLOAT:
-                    return NumericRangeQuery.NewFloatRange(field, precisionStep,
+                    return NumericRangeQuery.NewSingleRange(field, precisionStep,
                         (float?)lowerNumber, (float?)upperNumber, minInclusive,
                         maxInclusive);
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.QueryParser/Xml/Builders/NumericRangeFilterBuilder.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.QueryParser/Xml/Builders/NumericRangeFilterBuilder.cs b/src/Lucene.Net.QueryParser/Xml/Builders/NumericRangeFilterBuilder.cs
index d7d4130..d37193b 100644
--- a/src/Lucene.Net.QueryParser/Xml/Builders/NumericRangeFilterBuilder.cs
+++ b/src/Lucene.Net.QueryParser/Xml/Builders/NumericRangeFilterBuilder.cs
@@ -121,12 +121,12 @@ namespace Lucene.Net.QueryParsers.Xml.Builders
                 Filter filter;
                 if (type.Equals("int", StringComparison.OrdinalIgnoreCase))
                 {
-                    filter = NumericRangeFilter.NewIntRange(field, precisionStep, Convert.ToInt32(lowerTerm), Convert.ToInt32(upperTerm), lowerInclusive,
+                    filter = NumericRangeFilter.NewInt32Range(field, precisionStep, Convert.ToInt32(lowerTerm), Convert.ToInt32(upperTerm), lowerInclusive,
                         upperInclusive);
                 }
                 else if (type.Equals("long", StringComparison.OrdinalIgnoreCase))
                 {
-                    filter = NumericRangeFilter.NewLongRange(field, precisionStep, Convert
+                    filter = NumericRangeFilter.NewInt64Range(field, precisionStep, Convert
                         .ToInt64(lowerTerm), Convert.ToInt64(upperTerm), lowerInclusive,
                         upperInclusive);
                 }
@@ -138,7 +138,7 @@ namespace Lucene.Net.QueryParsers.Xml.Builders
                 }
                 else if (type.Equals("float", StringComparison.OrdinalIgnoreCase))
                 {
-                    filter = NumericRangeFilter.NewFloatRange(field, precisionStep, Convert
+                    filter = NumericRangeFilter.NewSingleRange(field, precisionStep, Convert
                         .ToSingle(lowerTerm), Convert.ToSingle(upperTerm), lowerInclusive,
                         upperInclusive);
                 }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.QueryParser/Xml/Builders/NumericRangeQueryBuilder.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.QueryParser/Xml/Builders/NumericRangeQueryBuilder.cs b/src/Lucene.Net.QueryParser/Xml/Builders/NumericRangeQueryBuilder.cs
index 4b4b128..668f56e 100644
--- a/src/Lucene.Net.QueryParser/Xml/Builders/NumericRangeQueryBuilder.cs
+++ b/src/Lucene.Net.QueryParser/Xml/Builders/NumericRangeQueryBuilder.cs
@@ -99,13 +99,13 @@ namespace Lucene.Net.QueryParsers.Xml.Builders
                 Query filter;
                 if (type.Equals("int", StringComparison.OrdinalIgnoreCase))
                 {
-                    filter = NumericRangeQuery.NewIntRange(field, precisionStep, Convert
+                    filter = NumericRangeQuery.NewInt32Range(field, precisionStep, Convert
                         .ToInt32(lowerTerm), Convert.ToInt32(upperTerm), lowerInclusive,
                         upperInclusive);
                 }
                 else if (type.Equals("long", StringComparison.OrdinalIgnoreCase))
                 {
-                    filter = NumericRangeQuery.NewLongRange(field, precisionStep, Convert
+                    filter = NumericRangeQuery.NewInt64Range(field, precisionStep, Convert
                         .ToInt64(lowerTerm), Convert.ToInt64(upperTerm), lowerInclusive,
                         upperInclusive);
                 }
@@ -117,7 +117,7 @@ namespace Lucene.Net.QueryParsers.Xml.Builders
                 }
                 else if (type.Equals("float", StringComparison.OrdinalIgnoreCase))
                 {
-                    filter = NumericRangeQuery.NewFloatRange(field, precisionStep, Convert
+                    filter = NumericRangeQuery.NewSingleRange(field, precisionStep, Convert
                         .ToSingle(lowerTerm), Convert.ToSingle(upperTerm), lowerInclusive,
                         upperInclusive);
                 }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Sandbox/Queries/FuzzyLikeThisQuery.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Sandbox/Queries/FuzzyLikeThisQuery.cs b/src/Lucene.Net.Sandbox/Queries/FuzzyLikeThisQuery.cs
index 48c2b3e..b833083 100644
--- a/src/Lucene.Net.Sandbox/Queries/FuzzyLikeThisQuery.cs
+++ b/src/Lucene.Net.Sandbox/Queries/FuzzyLikeThisQuery.cs
@@ -136,7 +136,7 @@ namespace Lucene.Net.Sandbox.Queries
                 int result = 1;
                 result = prime * result
                     + ((fieldName == null) ? 0 : fieldName.GetHashCode());
-                result = prime * result + Number.FloatToIntBits(minSimilarity);
+                result = prime * result + Number.SingleToInt32Bits(minSimilarity);
                 result = prime * result + prefixLength;
                 result = prime * result
                     + ((queryString == null) ? 0 : queryString.GetHashCode());
@@ -159,8 +159,8 @@ namespace Lucene.Net.Sandbox.Queries
                 }
                 else if (!fieldName.Equals(other.fieldName, StringComparison.Ordinal))
                     return false;
-                if (Number.FloatToIntBits(minSimilarity) != Number
-                    .FloatToIntBits(other.minSimilarity))
+                if (Number.SingleToInt32Bits(minSimilarity) != Number
+                    .SingleToInt32Bits(other.minSimilarity))
                     return false;
                 if (prefixLength != other.prefixLength)
                     return false;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Sandbox/Queries/SlowFuzzyQuery.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Sandbox/Queries/SlowFuzzyQuery.cs b/src/Lucene.Net.Sandbox/Queries/SlowFuzzyQuery.cs
index 77ec159..9a068f1 100644
--- a/src/Lucene.Net.Sandbox/Queries/SlowFuzzyQuery.cs
+++ b/src/Lucene.Net.Sandbox/Queries/SlowFuzzyQuery.cs
@@ -182,7 +182,7 @@ namespace Lucene.Net.Sandbox.Queries
         {
             int prime = 31;
             int result = base.GetHashCode();
-            result = prime * result + Number.FloatToIntBits(minimumSimilarity);
+            result = prime * result + Number.SingleToInt32Bits(minimumSimilarity);
             result = prime * result + prefixLength;
             result = prime * result + ((m_term == null) ? 0 : m_term.GetHashCode());
             return result;
@@ -197,8 +197,8 @@ namespace Lucene.Net.Sandbox.Queries
             if (GetType() != obj.GetType())
                 return false;
             SlowFuzzyQuery other = (SlowFuzzyQuery)obj;
-            if (Number.FloatToIntBits(minimumSimilarity) != Number
-                .FloatToIntBits(other.minimumSimilarity))
+            if (Number.SingleToInt32Bits(minimumSimilarity) != Number
+                .SingleToInt32Bits(other.minimumSimilarity))
                 return false;
             if (prefixLength != other.prefixLength)
                 return false;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Sandbox/Queries/SlowFuzzyTermsEnum.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Sandbox/Queries/SlowFuzzyTermsEnum.cs b/src/Lucene.Net.Sandbox/Queries/SlowFuzzyTermsEnum.cs
index 05121db..ef44345 100644
--- a/src/Lucene.Net.Sandbox/Queries/SlowFuzzyTermsEnum.cs
+++ b/src/Lucene.Net.Sandbox/Queries/SlowFuzzyTermsEnum.cs
@@ -124,7 +124,7 @@ namespace Lucene.Net.Sandbox.Queries
                 if (StringHelper.StartsWith(term, prefixBytesRef))
                 {
                     UnicodeUtil.UTF8toUTF32(term, utf32);
-                    int distance = CalcDistance(utf32.Ints, outerInstance.m_realPrefixLength, utf32.Length - outerInstance.m_realPrefixLength);
+                    int distance = CalcDistance(utf32.Int32s, outerInstance.m_realPrefixLength, utf32.Length - outerInstance.m_realPrefixLength);
 
                     //Integer.MIN_VALUE is the sentinel that Levenshtein stopped early
                     if (distance == int.MinValue)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Spatial/Util/DistanceToShapeValueSource.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Spatial/Util/DistanceToShapeValueSource.cs b/src/Lucene.Net.Spatial/Util/DistanceToShapeValueSource.cs
index c5c0125..b0a6de1 100644
--- a/src/Lucene.Net.Spatial/Util/DistanceToShapeValueSource.cs
+++ b/src/Lucene.Net.Spatial/Util/DistanceToShapeValueSource.cs
@@ -122,7 +122,7 @@ namespace Lucene.Net.Spatial.Util
             long temp;
             result = shapeValueSource.GetHashCode();
             result = 31 * result + queryPoint.GetHashCode();
-            temp = Number.DoubleToLongBits(multiplier);
+            temp = Number.DoubleToInt64Bits(multiplier);
             result = 31 * result + (int)(temp ^ ((long)((ulong)temp) >> 32));
             return result;
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Suggest/Spell/JaroWinklerDistance.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Suggest/Spell/JaroWinklerDistance.cs b/src/Lucene.Net.Suggest/Spell/JaroWinklerDistance.cs
index c17f7cd..bc29dc3 100644
--- a/src/Lucene.Net.Suggest/Spell/JaroWinklerDistance.cs
+++ b/src/Lucene.Net.Suggest/Spell/JaroWinklerDistance.cs
@@ -142,7 +142,7 @@ namespace Lucene.Net.Search.Spell
 
         public override int GetHashCode()
         {
-            return 113 * Number.FloatToIntBits(threshold) * this.GetType().GetHashCode();
+            return 113 * Number.SingleToInt32Bits(threshold) * this.GetType().GetHashCode();
         }
 
         public override bool Equals(object obj)
@@ -157,7 +157,7 @@ namespace Lucene.Net.Search.Spell
             }
 
             JaroWinklerDistance o = (JaroWinklerDistance)obj;
-            return (Number.FloatToIntBits(o.threshold) == Number.FloatToIntBits(this.threshold));
+            return (Number.SingleToInt32Bits(o.threshold) == Number.SingleToInt32Bits(this.threshold));
         }
 
         public override string ToString()

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Suggest/Spell/LuceneLevenshteinDistance.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Suggest/Spell/LuceneLevenshteinDistance.cs b/src/Lucene.Net.Suggest/Spell/LuceneLevenshteinDistance.cs
index 2867150..ab0c9b7 100644
--- a/src/Lucene.Net.Suggest/Spell/LuceneLevenshteinDistance.cs
+++ b/src/Lucene.Net.Suggest/Spell/LuceneLevenshteinDistance.cs
@@ -103,15 +103,15 @@ namespace Lucene.Net.Search.Spell
 
             for (j = 1; j <= m; j++)
             {
-                t_j = otherPoints.Ints[j - 1];
+                t_j = otherPoints.Int32s[j - 1];
 
                 for (i = 1; i <= n; i++)
                 {
-                    cost = targetPoints.Ints[i - 1] == t_j ? 0 : 1;
+                    cost = targetPoints.Int32s[i - 1] == t_j ? 0 : 1;
                     // minimum of cell to the left+1, to the top+1, diagonally left and up +cost
                     d[i][j] = Math.Min(Math.Min(d[i - 1][j] + 1, d[i][j - 1] + 1), d[i - 1][j - 1] + cost);
                     // transposition
-                    if (i > 1 && j > 1 && targetPoints.Ints[i - 1] == otherPoints.Ints[j - 2] && targetPoints.Ints[i - 2] == otherPoints.Ints[j - 1])
+                    if (i > 1 && j > 1 && targetPoints.Int32s[i - 1] == otherPoints.Int32s[j - 2] && targetPoints.Int32s[i - 2] == otherPoints.Int32s[j - 1])
                     {
                         d[i][j] = Math.Min(d[i][j], d[i - 2][j - 2] + cost);
                     }
@@ -127,7 +127,7 @@ namespace Lucene.Net.Search.Spell
             int utf16Len = s.Length;
             for (int i = 0, cp = 0; i < utf16Len; i += Character.CharCount(cp))
             {
-                cp = @ref.Ints[@ref.Length++] = Character.CodePointAt(s, i);
+                cp = @ref.Int32s[@ref.Length++] = Character.CodePointAt(s, i);
             }
             return @ref;
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Suggest/Suggest/Analyzing/AnalyzingSuggester.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Suggest/Suggest/Analyzing/AnalyzingSuggester.cs b/src/Lucene.Net.Suggest/Suggest/Analyzing/AnalyzingSuggester.cs
index 8eef805..be3d918 100644
--- a/src/Lucene.Net.Suggest/Suggest/Analyzing/AnalyzingSuggester.cs
+++ b/src/Lucene.Net.Suggest/Suggest/Analyzing/AnalyzingSuggester.cs
@@ -339,13 +339,13 @@ namespace Lucene.Net.Search.Suggest.Analyzing
 
                 // First by analyzed form:
                 readerA.Reset(a.Bytes, a.Offset, a.Length);
-                scratchA.Length = (ushort)readerA.ReadShort();
+                scratchA.Length = (ushort)readerA.ReadInt16();
                 scratchA.Bytes = a.Bytes;
                 scratchA.Offset = readerA.Position;
 
                 readerB.Reset(b.Bytes, b.Offset, b.Length);
                 scratchB.Bytes = b.Bytes;
-                scratchB.Length = (ushort)readerB.ReadShort();
+                scratchB.Length = (ushort)readerB.ReadInt16();
                 scratchB.Offset = readerB.Position;
 
                 int cmp = scratchA.CompareTo(scratchB);
@@ -357,8 +357,8 @@ namespace Lucene.Net.Search.Suggest.Analyzing
                 readerB.SkipBytes(scratchB.Length);
 
                 // Next by cost:
-                long aCost = readerA.ReadInt();
-                long bCost = readerB.ReadInt();
+                long aCost = readerA.ReadInt32();
+                long bCost = readerB.ReadInt32();
                 Debug.Assert(DecodeWeight(aCost) >= 0);
                 Debug.Assert(DecodeWeight(bCost) >= 0);
                 if (aCost < bCost)
@@ -373,8 +373,8 @@ namespace Lucene.Net.Search.Suggest.Analyzing
                 // Finally by surface form:
                 if (hasPayloads)
                 {
-                    scratchA.Length = (ushort)readerA.ReadShort();
-                    scratchB.Length = (ushort)readerB.ReadShort();
+                    scratchA.Length = (ushort)readerA.ReadInt16();
+                    scratchB.Length = (ushort)readerB.ReadInt16();
                     scratchA.Offset = readerA.Position;
                     scratchB.Offset = readerB.Position;
                 }
@@ -462,11 +462,11 @@ namespace Lucene.Net.Search.Suggest.Analyzing
 
                         output.Reset(buffer);
 
-                        output.WriteShort((short)analyzedLength);
+                        output.WriteInt16((short)analyzedLength);
 
                         output.WriteBytes(scratch.Bytes, scratch.Offset, scratch.Length);
 
-                        output.WriteInt(EncodeWeight(iterator.Weight));
+                        output.WriteInt32(EncodeWeight(iterator.Weight));
 
                         if (hasPayloads)
                         {
@@ -478,7 +478,7 @@ namespace Lucene.Net.Search.Suggest.Analyzing
                                         "surface form cannot contain unit separator character U+001F; this character is reserved");
                                 }
                             }
-                            output.WriteShort((short)surfaceForm.Length);
+                            output.WriteInt16((short)surfaceForm.Length);
                             output.WriteBytes(surfaceForm.Bytes, surfaceForm.Offset, surfaceForm.Length);
                             output.WriteBytes(payload.Bytes, payload.Offset, payload.Length);
                         }
@@ -524,17 +524,17 @@ namespace Lucene.Net.Search.Suggest.Analyzing
                 while (reader.Read(scratch))
                 {
                     input.Reset(scratch.Bytes, scratch.Offset, scratch.Length);
-                    ushort analyzedLength = (ushort)input.ReadShort();
+                    ushort analyzedLength = (ushort)input.ReadInt16();
                     analyzed.Grow(analyzedLength + 2);
                     input.ReadBytes(analyzed.Bytes, 0, analyzedLength);
                     analyzed.Length = analyzedLength;
 
-                    long cost = input.ReadInt();
+                    long cost = input.ReadInt32();
 
                     surface.Bytes = scratch.Bytes;
                     if (hasPayloads)
                     {
-                        surface.Length = (ushort)input.ReadShort();
+                        surface.Length = (ushort)input.ReadInt16();
                         surface.Offset = input.Position;
                     }
                     else
@@ -584,7 +584,7 @@ namespace Lucene.Net.Search.Suggest.Analyzing
                     analyzed.Bytes[analyzed.Offset + analyzed.Length + 1] = (byte)dedup;
                     analyzed.Length += 2;
 
-                    Util.Fst.Util.ToIntsRef(analyzed, scratchInts);
+                    Util.Fst.Util.ToInt32sRef(analyzed, scratchInts);
                     //System.out.println("ADD: " + scratchInts + " -> " + cost + ": " + surface.utf8ToString());
                     if (!hasPayloads)
                     {
@@ -626,23 +626,23 @@ namespace Lucene.Net.Search.Suggest.Analyzing
 
         public override bool Store(DataOutput output)
         {
-            output.WriteVLong(count);
+            output.WriteVInt64(count);
             if (fst == null)
             {
                 return false;
             }
 
             fst.Save(output);
-            output.WriteVInt(maxAnalyzedPathsForOneInput);
+            output.WriteVInt32(maxAnalyzedPathsForOneInput);
             output.WriteByte((byte)(hasPayloads ? 1 : 0));
             return true;
         }
 
         public override bool Load(DataInput input)
         {
-            count = input.ReadVLong();
+            count = input.ReadVInt64();
             this.fst = new FST<PairOutputs<long?, BytesRef>.Pair>(input, new PairOutputs<long?, BytesRef>(PositiveIntOutputs.Singleton, ByteSequenceOutputs.Singleton));
-            maxAnalyzedPathsForOneInput = input.ReadVInt();
+            maxAnalyzedPathsForOneInput = input.ReadVInt32();
             hasPayloads = input.ReadByte() == 1;
             return true;
         }


[40/53] [abbrv] lucenenet git commit: Lucene.Net.Facet.Taxonomy.WriterCache refactor: Changed constants CharBlockArray.DefaultBlockSize > DEFAULT_BLOCK_SIZE, Cl2oTaxonomyWriterCache.LockTimeOut > LOCK_TIMEOUT

Posted by ni...@apache.org.
Lucene.Net.Facet.Taxonomy.WriterCache refactor: Changed constants CharBlockArray.DefaultBlockSize > DEFAULT_BLOCK_SIZE, Cl2oTaxonomyWriterCache.LockTimeOut > LOCK_TIMEOUT


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

Branch: refs/heads/api-work
Commit: 34075f29977ff9646c7a09d2cb9f3436604cebee
Parents: 883ad7f
Author: Shad Storhaug <sh...@shadstorhaug.com>
Authored: Wed Feb 8 13:09:56 2017 +0700
Committer: Shad Storhaug <sh...@shadstorhaug.com>
Committed: Wed Feb 8 21:08:24 2017 +0700

----------------------------------------------------------------------
 src/Lucene.Net.Facet/Taxonomy/WriterCache/CharBlockArray.cs  | 4 ++--
 .../Taxonomy/WriterCache/Cl2oTaxonomyWriterCache.cs          | 8 ++++----
 2 files changed, 6 insertions(+), 6 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/lucenenet/blob/34075f29/src/Lucene.Net.Facet/Taxonomy/WriterCache/CharBlockArray.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Facet/Taxonomy/WriterCache/CharBlockArray.cs b/src/Lucene.Net.Facet/Taxonomy/WriterCache/CharBlockArray.cs
index e576223..821b4d3 100644
--- a/src/Lucene.Net.Facet/Taxonomy/WriterCache/CharBlockArray.cs
+++ b/src/Lucene.Net.Facet/Taxonomy/WriterCache/CharBlockArray.cs
@@ -43,7 +43,7 @@ namespace Lucene.Net.Facet.Taxonomy.WriterCache
     {
         private const long serialVersionUID = 1L;
 
-        private const int DefaultBlockSize = 32 * 1024; // 32 KB default size
+        private const int DEFAULT_BLOCK_SIZE = 32 * 1024; // 32 KB default size
 
 #if FEATURE_SERIALIZABLE
         [Serializable]
@@ -76,7 +76,7 @@ namespace Lucene.Net.Facet.Taxonomy.WriterCache
         internal int length_Renamed;
 
         public CharBlockArray()
-            : this(DefaultBlockSize)
+            : this(DEFAULT_BLOCK_SIZE)
         {
         }
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/34075f29/src/Lucene.Net.Facet/Taxonomy/WriterCache/Cl2oTaxonomyWriterCache.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Facet/Taxonomy/WriterCache/Cl2oTaxonomyWriterCache.cs b/src/Lucene.Net.Facet/Taxonomy/WriterCache/Cl2oTaxonomyWriterCache.cs
index ac522dc..19abe80 100644
--- a/src/Lucene.Net.Facet/Taxonomy/WriterCache/Cl2oTaxonomyWriterCache.cs
+++ b/src/Lucene.Net.Facet/Taxonomy/WriterCache/Cl2oTaxonomyWriterCache.cs
@@ -30,7 +30,7 @@ namespace Lucene.Net.Facet.Taxonomy.WriterCache
     /// </summary>
     public class Cl2oTaxonomyWriterCache : ITaxonomyWriterCache
     {
-        private const int LockTimeOut = 1000;
+        private const int LOCK_TIMEOUT = 1000;
         private readonly ReaderWriterLockSlim @lock = new ReaderWriterLockSlim();
         private readonly int initialCapcity, numHashArrays;
         private readonly float loadFactor;
@@ -50,7 +50,7 @@ namespace Lucene.Net.Facet.Taxonomy.WriterCache
 
         public virtual void Clear()
         {
-            if (@lock.TryEnterWriteLock(LockTimeOut))
+            if (@lock.TryEnterWriteLock(LOCK_TIMEOUT))
             {
                 try
                 {
@@ -86,7 +86,7 @@ namespace Lucene.Net.Facet.Taxonomy.WriterCache
 
         public virtual int Get(FacetLabel categoryPath)
         {
-            if (@lock.TryEnterReadLock(LockTimeOut))
+            if (@lock.TryEnterReadLock(LOCK_TIMEOUT))
             {
                 try
                 {
@@ -106,7 +106,7 @@ namespace Lucene.Net.Facet.Taxonomy.WriterCache
 
         public virtual bool Put(FacetLabel categoryPath, int ordinal)
         {
-            if (@lock.TryEnterWriteLock(LockTimeOut))
+            if (@lock.TryEnterWriteLock(LOCK_TIMEOUT))
             {
                 try
                 {


[33/53] [abbrv] lucenenet git commit: Lucene.Net.Misc: Renamed all type-derived classes and interfaces from Short, Int, Long, and Float to match CLR types Int16, Int32, Int64, and Single, respectively.

Posted by ni...@apache.org.
Lucene.Net.Misc: Renamed all type-derived classes and interfaces from Short, Int, Long, and Float to match CLR types Int16, Int32, Int64, and Single, respectively.


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

Branch: refs/heads/api-work
Commit: 89e3de620d92acf9ceb48a7d98f82a0edcf473e9
Parents: c348531
Author: Shad Storhaug <sh...@shadstorhaug.com>
Authored: Wed Feb 8 02:55:53 2017 +0700
Committer: Shad Storhaug <sh...@shadstorhaug.com>
Committed: Wed Feb 8 21:08:23 2017 +0700

----------------------------------------------------------------------
 src/Lucene.Net.Misc/Util/Fst/ListOfOutputs.cs   |  2 +-
 .../Util/Fst/UpToTwoPositiveIntOutputs.cs       | 48 +++++++++++---------
 .../Util/Fst/TestFSTsMisc.cs                    | 10 ++--
 3 files changed, 32 insertions(+), 28 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/lucenenet/blob/89e3de62/src/Lucene.Net.Misc/Util/Fst/ListOfOutputs.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Misc/Util/Fst/ListOfOutputs.cs b/src/Lucene.Net.Misc/Util/Fst/ListOfOutputs.cs
index 5bc303b..27ca0f3 100644
--- a/src/Lucene.Net.Misc/Util/Fst/ListOfOutputs.cs
+++ b/src/Lucene.Net.Misc/Util/Fst/ListOfOutputs.cs
@@ -42,7 +42,7 @@ namespace Lucene.Net.Util.Fst
     /// how the FST maps a single input to multiple outputs (e.g. you
     /// cannot pass a List&lt;Object&gt; to <see cref="Builder{T}.Add(Int32sRef, T)"/>).  If
     /// your outputs are longs, and you need at most 2, then use
-    /// <see cref="UpToTwoPositiveIntOutputs"/> instead since it stores
+    /// <see cref="UpToTwoPositiveInt64Outputs"/> instead since it stores
     /// the outputs more compactly (by stealing a bit from each
     /// long value).
     /// 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/89e3de62/src/Lucene.Net.Misc/Util/Fst/UpToTwoPositiveIntOutputs.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Misc/Util/Fst/UpToTwoPositiveIntOutputs.cs b/src/Lucene.Net.Misc/Util/Fst/UpToTwoPositiveIntOutputs.cs
index 0a21fb2..d4442ee 100644
--- a/src/Lucene.Net.Misc/Util/Fst/UpToTwoPositiveIntOutputs.cs
+++ b/src/Lucene.Net.Misc/Util/Fst/UpToTwoPositiveIntOutputs.cs
@@ -34,7 +34,7 @@ namespace Lucene.Net.Util.Fst
     /// <para>NOTE: the only way to create a TwoLongs output is to
     /// add the same input to the FST twice in a row.  This is
     /// how the FST maps a single input to two outputs (e.g. you
-    /// cannot pass a <see cref="TwoLongs"/> to <see cref="Builder{T}.Add(Int32sRef, T)"/>.  If you
+    /// cannot pass a <see cref="TwoInt64s"/> to <see cref="Builder{T}.Add(Int32sRef, T)"/>.  If you
     /// need more than two then use <see cref="ListOfOutputs{T}"/>, but if
     /// you only have at most 2 then this implementation will
     /// require fewer bytes as it steals one bit from each long
@@ -43,16 +43,20 @@ namespace Lucene.Net.Util.Fst
     /// </para>
     /// <para>NOTE: the resulting FST is not guaranteed to be minimal!
     /// See <see cref="Builder{T}"/>.
-    /// 
-    /// @lucene.experimental
     /// </para>
+    /// <para>
+    /// NOTE: This was UpToTwoPositiveIntOutputs in Lucene - the data type (int) was wrong there - it should have been long
+    /// </para>
+    /// @lucene.experimental
     /// </summary>
-    public sealed class UpToTwoPositiveIntOutputs : Outputs<object>
+    public sealed class UpToTwoPositiveInt64Outputs : Outputs<object>
     {
-
         /// <summary>
-        /// Holds two long outputs. </summary>
-        public sealed class TwoLongs
+        /// Holds two long outputs.
+        /// <para/>
+        /// NOTE: This was TwoLongs in Lucene
+        /// </summary>
+        public sealed class TwoInt64s
         {
             public long First
             {
@@ -66,7 +70,7 @@ namespace Lucene.Net.Util.Fst
             }
             private readonly long second;
 
-            public TwoLongs(long first, long second)
+            public TwoInt64s(long first, long second)
             {
                 this.first = first;
                 this.second = second;
@@ -81,9 +85,9 @@ namespace Lucene.Net.Util.Fst
 
             public override bool Equals(object other)
             {
-                if (other is TwoLongs)
+                if (other is TwoInt64s)
                 {
-                    TwoLongs other2 = (TwoLongs)other;
+                    TwoInt64s other2 = (TwoInt64s)other;
                     return first == other2.first && second == other2.second;
                 }
                 else
@@ -102,15 +106,15 @@ namespace Lucene.Net.Util.Fst
 
         private readonly bool doShare;
 
-        private static readonly UpToTwoPositiveIntOutputs singletonShare = new UpToTwoPositiveIntOutputs(true);
-        private static readonly UpToTwoPositiveIntOutputs singletonNoShare = new UpToTwoPositiveIntOutputs(false);
+        private static readonly UpToTwoPositiveInt64Outputs singletonShare = new UpToTwoPositiveInt64Outputs(true);
+        private static readonly UpToTwoPositiveInt64Outputs singletonNoShare = new UpToTwoPositiveInt64Outputs(false);
 
-        private UpToTwoPositiveIntOutputs(bool doShare)
+        private UpToTwoPositiveInt64Outputs(bool doShare)
         {
             this.doShare = doShare;
         }
 
-        public static UpToTwoPositiveIntOutputs GetSingleton(bool doShare)
+        public static UpToTwoPositiveInt64Outputs GetSingleton(bool doShare)
         {
             return doShare ? singletonShare : singletonNoShare;
         }
@@ -127,9 +131,9 @@ namespace Lucene.Net.Util.Fst
             }
         }
 
-        public TwoLongs Get(long first, long second)
+        public TwoInt64s Get(long first, long second)
         {
-            return new TwoLongs(first, second);
+            return new TwoInt64s(first, second);
         }
 
         public override object Common(object output1, object output2)
@@ -203,9 +207,9 @@ namespace Lucene.Net.Util.Fst
             }
             else
             {
-                TwoLongs output3 = (TwoLongs)output;
+                TwoInt64s output3 = (TwoInt64s)output;
                 long v = prefix2.Value;
-                return new TwoLongs(output3.First + v, output3.Second + v);
+                return new TwoInt64s(output3.First + v, output3.Second + v);
             }
         }
 
@@ -219,7 +223,7 @@ namespace Lucene.Net.Util.Fst
             }
             else
             {
-                TwoLongs output3 = (TwoLongs)output;
+                TwoInt64s output3 = (TwoInt64s)output;
                 @out.WriteVInt64((output3.First << 1) | 1);
                 @out.WriteVInt64(output3.Second);
             }
@@ -246,7 +250,7 @@ namespace Lucene.Net.Util.Fst
                 // two longs
                 long first = (long)((ulong)code >> 1);
                 long second = @in.ReadVInt64();
-                return new TwoLongs(first, second);
+                return new TwoInt64s(first, second);
             }
         }
 
@@ -266,7 +270,7 @@ namespace Lucene.Net.Util.Fst
                 Debug.Assert(o is long?);
                 return Valid((long?)o);
             }
-            else if (o is TwoLongs)
+            else if (o is TwoInt64s)
             {
                 return true;
             }
@@ -293,7 +297,7 @@ namespace Lucene.Net.Util.Fst
         {
             Debug.Assert(Valid(first, false));
             Debug.Assert(Valid(second, false));
-            return new TwoLongs(((long?)first).GetValueOrDefault(), ((long?)second).GetValueOrDefault());
+            return new TwoInt64s(((long?)first).GetValueOrDefault(), ((long?)second).GetValueOrDefault());
         }
     }
 }
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/89e3de62/src/Lucene.Net.Tests.Misc/Util/Fst/TestFSTsMisc.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests.Misc/Util/Fst/TestFSTsMisc.cs b/src/Lucene.Net.Tests.Misc/Util/Fst/TestFSTsMisc.cs
index 7ad22ef..304f11d 100644
--- a/src/Lucene.Net.Tests.Misc/Util/Fst/TestFSTsMisc.cs
+++ b/src/Lucene.Net.Tests.Misc/Util/Fst/TestFSTsMisc.cs
@@ -67,7 +67,7 @@ namespace Lucene.Net.Util.Fst
                 {
                     Console.WriteLine("TEST: now test UpToTwoPositiveIntOutputs");
                 }
-                UpToTwoPositiveIntOutputs outputs = UpToTwoPositiveIntOutputs.GetSingleton(true);
+                UpToTwoPositiveInt64Outputs outputs = UpToTwoPositiveInt64Outputs.GetSingleton(true);
                 List<Lucene.Net.Util.Fst.FSTTester<object>.InputOutput<object>> pairs = new List<Lucene.Net.Util.Fst.FSTTester<object>.InputOutput<object>>(terms.Length);
                 long lastOutput = 0;
                 for (int idx = 0; idx < terms.Length; idx++)
@@ -153,16 +153,16 @@ namespace Lucene.Net.Util.Fst
 
             protected internal override bool OutputsEqual(T output1, T output2)
             {
-                if (output1 is UpToTwoPositiveIntOutputs.TwoLongs && output2 is IEnumerable<long>)
+                if (output1 is UpToTwoPositiveInt64Outputs.TwoInt64s && output2 is IEnumerable<long>)
                 {
-                    UpToTwoPositiveIntOutputs.TwoLongs twoLongs1 = output1 as UpToTwoPositiveIntOutputs.TwoLongs;
+                    UpToTwoPositiveInt64Outputs.TwoInt64s twoLongs1 = output1 as UpToTwoPositiveInt64Outputs.TwoInt64s;
                     long[] list2 = (output2 as IEnumerable<long>).ToArray();
                     return (new long[] { twoLongs1.First, twoLongs1.Second }).SequenceEqual(list2);
                 }
-                else if (output2 is UpToTwoPositiveIntOutputs.TwoLongs && output1 is IEnumerable<long>)
+                else if (output2 is UpToTwoPositiveInt64Outputs.TwoInt64s && output1 is IEnumerable<long>)
                 {
                     long[] list1 = (output1 as IEnumerable<long>).ToArray();
-                    UpToTwoPositiveIntOutputs.TwoLongs twoLongs2 = output2 as UpToTwoPositiveIntOutputs.TwoLongs;
+                    UpToTwoPositiveInt64Outputs.TwoInt64s twoLongs2 = output2 as UpToTwoPositiveInt64Outputs.TwoInt64s;
                     return (new long[] { twoLongs2.First, twoLongs2.Second }).SequenceEqual(list1);
                 }
 


[07/53] [abbrv] lucenenet git commit: Lucene.Net.Core: Renamed all type-derived properties and methods from Short, Int, Long, and Float to match CLR types Int16, Int32, Int64, and Single, respectively.

Posted by ni...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Search/Spans/FieldMaskingSpanQuery.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Search/Spans/FieldMaskingSpanQuery.cs b/src/Lucene.Net.Core/Search/Spans/FieldMaskingSpanQuery.cs
index 357dc4b..52d8905 100644
--- a/src/Lucene.Net.Core/Search/Spans/FieldMaskingSpanQuery.cs
+++ b/src/Lucene.Net.Core/Search/Spans/FieldMaskingSpanQuery.cs
@@ -161,7 +161,7 @@ namespace Lucene.Net.Search.Spans
 
         public override int GetHashCode()
         {
-            return MaskedQuery.GetHashCode() ^ Field.GetHashCode() ^ Number.FloatToIntBits(Boost);
+            return MaskedQuery.GetHashCode() ^ Field.GetHashCode() ^ Number.SingleToInt32Bits(Boost);
         }
     }
 }
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Search/Spans/SpanFirstQuery.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Search/Spans/SpanFirstQuery.cs b/src/Lucene.Net.Core/Search/Spans/SpanFirstQuery.cs
index 2f0cd56..93d0d93 100644
--- a/src/Lucene.Net.Core/Search/Spans/SpanFirstQuery.cs
+++ b/src/Lucene.Net.Core/Search/Spans/SpanFirstQuery.cs
@@ -98,7 +98,7 @@ namespace Lucene.Net.Search.Spans
         {
             int h = m_match.GetHashCode();
             h ^= (h << 8) | ((int)((uint)h >> 25)); // reversible
-            h ^= Number.FloatToIntBits(Boost) ^ m_end; // LUCENENET TODO: This was FloatToRawIntBits in the original
+            h ^= Number.SingleToInt32Bits(Boost) ^ m_end; // LUCENENET TODO: This was FloatToRawIntBits in the original
             return h;
         }
     }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Search/Spans/SpanNearPayloadCheckQuery.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Search/Spans/SpanNearPayloadCheckQuery.cs b/src/Lucene.Net.Core/Search/Spans/SpanNearPayloadCheckQuery.cs
index 82cf4e9..411daa9 100644
--- a/src/Lucene.Net.Core/Search/Spans/SpanNearPayloadCheckQuery.cs
+++ b/src/Lucene.Net.Core/Search/Spans/SpanNearPayloadCheckQuery.cs
@@ -126,7 +126,7 @@ namespace Lucene.Net.Search.Spans
             h ^= (h << 8) | ((int)((uint)h >> 25)); // reversible
             //TODO: is this right?
             h ^= m_payloadToMatch.GetHashCode();
-            h ^= Number.FloatToIntBits(Boost); // LUCENENET TODO: This was FloatToRawIntBits in the original
+            h ^= Number.SingleToInt32Bits(Boost); // LUCENENET TODO: This was FloatToRawIntBits in the original
             return h;
         }
     }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Search/Spans/SpanNearQuery.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Search/Spans/SpanNearQuery.cs b/src/Lucene.Net.Core/Search/Spans/SpanNearQuery.cs
index af3757f..eac1aa2 100644
--- a/src/Lucene.Net.Core/Search/Spans/SpanNearQuery.cs
+++ b/src/Lucene.Net.Core/Search/Spans/SpanNearQuery.cs
@@ -242,7 +242,7 @@ namespace Lucene.Net.Search.Spans
             // last element of clauses.  this particular mix also serves to
             // differentiate SpanNearQuery hashcodes from others.
             result ^= (result << 14) | ((int)((uint)result >> 19)); // reversible
-            result += Number.FloatToIntBits(Boost); // LUCENENET TODO: This was FloatToRawIntBits in the original
+            result += Number.SingleToInt32Bits(Boost); // LUCENENET TODO: This was FloatToRawIntBits in the original
             result += m_slop;
             result ^= (m_inOrder ? unchecked((int)0x99AFD3BD) : 0);
             return result;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Search/Spans/SpanOrQuery.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Search/Spans/SpanOrQuery.cs b/src/Lucene.Net.Core/Search/Spans/SpanOrQuery.cs
index 2d1758a..29f2c5e 100644
--- a/src/Lucene.Net.Core/Search/Spans/SpanOrQuery.cs
+++ b/src/Lucene.Net.Core/Search/Spans/SpanOrQuery.cs
@@ -170,7 +170,7 @@ namespace Lucene.Net.Search.Spans
             //If this doesn't work, hash all elemnts together instead. This version was used to reduce time complexity
             int h = clauses.Count == 0 ? 0 : HashHelpers.CombineHashCodes(clauses.First().GetHashCode(), clauses.Last().GetHashCode(), clauses.Count);
             h ^= (h << 10) | ((int)(((uint)h) >> 23));
-            h ^= Number.FloatToIntBits(Boost);
+            h ^= Number.SingleToInt32Bits(Boost);
             return h;
         }
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Search/Spans/SpanPayloadCheckQuery.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Search/Spans/SpanPayloadCheckQuery.cs b/src/Lucene.Net.Core/Search/Spans/SpanPayloadCheckQuery.cs
index a7a024e..12f61da 100644
--- a/src/Lucene.Net.Core/Search/Spans/SpanPayloadCheckQuery.cs
+++ b/src/Lucene.Net.Core/Search/Spans/SpanPayloadCheckQuery.cs
@@ -126,7 +126,7 @@ namespace Lucene.Net.Search.Spans
             h ^= (h << 8) | ((int)((uint)h >> 25)); // reversible
             //TODO: is this right?
             h ^= m_payloadToMatch.GetHashCode();
-            h ^= Number.FloatToIntBits(Boost); // LUCENENET TODO: This was FloatToRawIntBits in the original
+            h ^= Number.SingleToInt32Bits(Boost); // LUCENENET TODO: This was FloatToRawIntBits in the original
             return h;
         }
     }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Search/Spans/SpanPositionRangeQuery.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Search/Spans/SpanPositionRangeQuery.cs b/src/Lucene.Net.Core/Search/Spans/SpanPositionRangeQuery.cs
index 557ec16..b8c5ae0 100644
--- a/src/Lucene.Net.Core/Search/Spans/SpanPositionRangeQuery.cs
+++ b/src/Lucene.Net.Core/Search/Spans/SpanPositionRangeQuery.cs
@@ -112,7 +112,7 @@ namespace Lucene.Net.Search.Spans
         {
             int h = m_match.GetHashCode();
             h ^= (h << 8) | ((int)((uint)h >> 25)); // reversible
-            h ^= Number.FloatToIntBits(Boost) ^ m_end ^ m_start; // LUCENENET TODO: This was FloatToRawIntBits in the original
+            h ^= Number.SingleToInt32Bits(Boost) ^ m_end ^ m_start; // LUCENENET TODO: This was FloatToRawIntBits in the original
             return h;
         }
     }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Search/TermQuery.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Search/TermQuery.cs b/src/Lucene.Net.Core/Search/TermQuery.cs
index e2e3ec7..a8b548f 100644
--- a/src/Lucene.Net.Core/Search/TermQuery.cs
+++ b/src/Lucene.Net.Core/Search/TermQuery.cs
@@ -249,7 +249,7 @@ namespace Lucene.Net.Search
         /// Returns a hash code value for this object. </summary>
         public override int GetHashCode()
         {
-            return Number.FloatToIntBits(Boost) ^ term.GetHashCode();
+            return Number.SingleToInt32Bits(Boost) ^ term.GetHashCode();
         }
     }
 }
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Store/BufferedIndexInput.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Store/BufferedIndexInput.cs b/src/Lucene.Net.Core/Store/BufferedIndexInput.cs
index 93cf2c5..4a22bae 100644
--- a/src/Lucene.Net.Core/Store/BufferedIndexInput.cs
+++ b/src/Lucene.Net.Core/Store/BufferedIndexInput.cs
@@ -204,7 +204,10 @@ namespace Lucene.Net.Store
             }
         }
 
-        public override sealed short ReadShort()
+        /// <summary>
+        /// NOTE: this was readShort() in Lucene
+        /// </summary>
+        public override sealed short ReadInt16()
         {
             if (2 <= (bufferLength - bufferPosition))
             {
@@ -212,11 +215,11 @@ namespace Lucene.Net.Store
             }
             else
             {
-                return base.ReadShort();
+                return base.ReadInt16();
             }
         }
 
-        public override sealed int ReadInt()
+        public override sealed int ReadInt32()
         {
             if (4 <= (bufferLength - bufferPosition))
             {
@@ -224,11 +227,11 @@ namespace Lucene.Net.Store
             }
             else
             {
-                return base.ReadInt();
+                return base.ReadInt32();
             }
         }
 
-        public override sealed long ReadLong()
+        public override sealed long ReadInt64()
         {
             if (8 <= (bufferLength - bufferPosition))
             {
@@ -238,11 +241,11 @@ namespace Lucene.Net.Store
             }
             else
             {
-                return base.ReadLong();
+                return base.ReadInt64();
             }
         }
 
-        public override sealed int ReadVInt()
+        public override sealed int ReadVInt32()
         {
             if (5 <= (bufferLength - bufferPosition))
             {
@@ -281,11 +284,11 @@ namespace Lucene.Net.Store
             }
             else
             {
-                return base.ReadVInt();
+                return base.ReadVInt32();
             }
         }
 
-        public override sealed long ReadVLong()
+        public override sealed long ReadVInt64()
         {
             if (9 <= bufferLength - bufferPosition)
             {
@@ -347,7 +350,7 @@ namespace Lucene.Net.Store
             }
             else
             {
-                return base.ReadVLong();
+                return base.ReadVInt64();
             }
         }
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Store/ByteArrayDataInput.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Store/ByteArrayDataInput.cs b/src/Lucene.Net.Core/Store/ByteArrayDataInput.cs
index e237867..f966460 100644
--- a/src/Lucene.Net.Core/Store/ByteArrayDataInput.cs
+++ b/src/Lucene.Net.Core/Store/ByteArrayDataInput.cs
@@ -97,25 +97,36 @@ namespace Lucene.Net.Store
         /// <summary>
         /// LUCENENET NOTE: Important - always cast to ushort (System.UInt16) before using to ensure
         /// the value is positive!
+        /// <para/>
+        /// NOTE: this was readShort() in Lucene
         /// </summary>
-        public override short ReadShort()
+        public override short ReadInt16()
         {
             return (short)(ushort)(((bytes[pos++] & 0xFF) << 8) | (bytes[pos++] & 0xFF));
         }
 
-        public override int ReadInt()
+        /// <summary>
+        /// NOTE: this was readInt() in Lucene
+        /// </summary>
+        public override int ReadInt32()
         {
             return ((bytes[pos++] & 0xFF) << 24) | ((bytes[pos++] & 0xFF) << 16) | ((bytes[pos++] & 0xFF) << 8) | (bytes[pos++] & 0xFF);
         }
 
-        public override long ReadLong()
+        /// <summary>
+        /// NOTE: this was readLong() in Lucene
+        /// </summary>
+        public override long ReadInt64()
         {
             int i1 = ((bytes[pos++] & 0xff) << 24) | ((bytes[pos++] & 0xff) << 16) | ((bytes[pos++] & 0xff) << 8) | (bytes[pos++] & 0xff);
             int i2 = ((bytes[pos++] & 0xff) << 24) | ((bytes[pos++] & 0xff) << 16) | ((bytes[pos++] & 0xff) << 8) | (bytes[pos++] & 0xff);
             return (((long)i1) << 32) | (i2 & 0xFFFFFFFFL);
         }
 
-        public override int ReadVInt()
+        /// <summary>
+        /// NOTE: this was readVInt() in Lucene
+        /// </summary>
+        public override int ReadVInt32()
         {
             // .NET Port: going back to original style code instead of Java code below due to sbyte/byte diff
             /*byte b = Bytes[Pos++];
@@ -161,7 +172,10 @@ namespace Lucene.Net.Store
             throw new Exception("Invalid vInt detected (too many bits)");
         }
 
-        public override long ReadVLong()
+        /// <summary>
+        /// NOTE: this was readVLong() in Lucene
+        /// </summary>
+        public override long ReadVInt64()
         {
             // .NET Port: going back to old style code
             /*byte b = Bytes[Pos++];

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Store/ByteBufferIndexInput.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Store/ByteBufferIndexInput.cs b/src/Lucene.Net.Core/Store/ByteBufferIndexInput.cs
index d25e47c..5a27cd6 100644
--- a/src/Lucene.Net.Core/Store/ByteBufferIndexInput.cs
+++ b/src/Lucene.Net.Core/Store/ByteBufferIndexInput.cs
@@ -140,15 +140,18 @@ namespace Lucene.Net.Store
             }
         }
 
-        public override sealed short ReadShort()
+        /// <summary>
+        /// NOTE: this was readShort() in Lucene
+        /// </summary>
+        public override sealed short ReadInt16()
         {
             try
             {
-                return curBuf.GetShort();
+                return curBuf.GetInt16();
             }
             catch (BufferUnderflowException)
             {
-                return base.ReadShort();
+                return base.ReadInt16();
             }
             catch (System.NullReferenceException)
             {
@@ -156,15 +159,18 @@ namespace Lucene.Net.Store
             }
         }
 
-        public override sealed int ReadInt()
+        /// <summary>
+        /// NOTE: this was readInt() in Lucene
+        /// </summary>
+        public override sealed int ReadInt32()
         {
             try
             {
-                return curBuf.GetInt();
+                return curBuf.GetInt32();
             }
             catch (BufferUnderflowException)
             {
-                return base.ReadInt();
+                return base.ReadInt32();
             }
             catch (System.NullReferenceException)
             {
@@ -172,15 +178,18 @@ namespace Lucene.Net.Store
             }
         }
 
-        public override sealed long ReadLong()
+        /// <summary>
+        /// NOTE: this was readLong() in Lucene
+        /// </summary>
+        public override sealed long ReadInt64()
         {
             try
             {
-                return curBuf.GetLong();
+                return curBuf.GetInt64();
             }
             catch (BufferUnderflowException)
             {
-                return base.ReadLong();
+                return base.ReadInt64();
             }
             catch (System.NullReferenceException)
             {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Store/CompoundFileDirectory.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Store/CompoundFileDirectory.cs b/src/Lucene.Net.Core/Store/CompoundFileDirectory.cs
index 71436f8..d6049f8 100644
--- a/src/Lucene.Net.Core/Store/CompoundFileDirectory.cs
+++ b/src/Lucene.Net.Core/Store/CompoundFileDirectory.cs
@@ -147,7 +147,7 @@ namespace Lucene.Net.Store
 #pragma warning disable 612, 618
                 stream = handle.OpenFullSlice();
 #pragma warning restore 612, 618
-                int firstInt = stream.ReadVInt();
+                int firstInt = stream.ReadVInt32();
                 // impossible for 3.0 to have 63 files in a .cfs, CFS writer was not visible
                 // and separate norms/etc are outside of cfs.
                 if (firstInt == CODEC_MAGIC_BYTE1)
@@ -163,7 +163,7 @@ namespace Lucene.Net.Store
                     string entriesFileName = IndexFileNames.SegmentFileName(IndexFileNames.StripExtension(name), "", IndexFileNames.COMPOUND_FILE_ENTRIES_EXTENSION);
                     entriesStream = dir.OpenChecksumInput(entriesFileName, IOContext.READ_ONCE);
                     CodecUtil.CheckHeader(entriesStream, CompoundFileWriter.ENTRY_CODEC, CompoundFileWriter.VERSION_START, CompoundFileWriter.VERSION_CURRENT);
-                    int numEntries = entriesStream.ReadVInt();
+                    int numEntries = entriesStream.ReadVInt32();
                     mapping = new Dictionary<string, FileEntry>(numEntries);
                     for (int i = 0; i < numEntries; i++)
                     {
@@ -179,8 +179,8 @@ namespace Lucene.Net.Store
                         {
                             mapping[id] = fileEntry;
                         }
-                        fileEntry.Offset = entriesStream.ReadLong();
-                        fileEntry.Length = entriesStream.ReadLong();
+                        fileEntry.Offset = entriesStream.ReadInt64();
+                        fileEntry.Length = entriesStream.ReadInt64();
                     }
                     if (version >= CompoundFileWriter.VERSION_CHECKSUM)
                     {
@@ -224,7 +224,7 @@ namespace Lucene.Net.Store
                     throw new CorruptIndexException("Incompatible format version: " + firstInt + " expected >= " + CompoundFileWriter.FORMAT_NO_SEGMENT_PREFIX + " (resource: " + stream + ")");
                 }
                 // It's a post-3.1 index, read the count.
-                count = stream.ReadVInt();
+                count = stream.ReadVInt32();
                 stripSegmentName = false;
             }
             else
@@ -238,7 +238,7 @@ namespace Lucene.Net.Store
             FileEntry entry = null;
             for (int i = 0; i < count; i++)
             {
-                long offset = stream.ReadLong();
+                long offset = stream.ReadInt64();
                 if (offset < 0 || offset > streamLength)
                 {
                     throw new CorruptIndexException("Invalid CFS entry offset: " + offset + " (resource: " + stream + ")");

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Store/CompoundFileWriter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Store/CompoundFileWriter.cs b/src/Lucene.Net.Core/Store/CompoundFileWriter.cs
index 321e2aa..6287c12 100644
--- a/src/Lucene.Net.Core/Store/CompoundFileWriter.cs
+++ b/src/Lucene.Net.Core/Store/CompoundFileWriter.cs
@@ -247,12 +247,12 @@ namespace Lucene.Net.Store
         private void WriteEntryTable(ICollection<FileEntry> entries, IndexOutput entryOut)
         {
             CodecUtil.WriteHeader(entryOut, ENTRY_CODEC, VERSION_CURRENT);
-            entryOut.WriteVInt(entries.Count);
+            entryOut.WriteVInt32(entries.Count);
             foreach (FileEntry fe in entries)
             {
                 entryOut.WriteString(IndexFileNames.StripSegmentName(fe.File));
-                entryOut.WriteLong(fe.Offset);
-                entryOut.WriteLong(fe.Length);
+                entryOut.WriteInt64(fe.Offset);
+                entryOut.WriteInt64(fe.Length);
             }
             CodecUtil.WriteFooter(entryOut);
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Store/DataInput.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Store/DataInput.cs b/src/Lucene.Net.Core/Store/DataInput.cs
index 15738c3..8f13785 100644
--- a/src/Lucene.Net.Core/Store/DataInput.cs
+++ b/src/Lucene.Net.Core/Store/DataInput.cs
@@ -80,20 +80,25 @@ namespace Lucene.Net.Store
 
         /// <summary>
         /// Reads two bytes and returns a short. 
-        /// 
+        /// <para/>
         /// LUCENENET NOTE: Important - always cast to ushort (System.UInt16) before using to ensure
         /// the value is positive!
+        /// <para/>
+        /// NOTE: this was readShort() in Lucene
         /// </summary>
         /// <seealso cref= DataOutput#writeByte(byte) </seealso>
-        public virtual short ReadShort() // LUCENENET TODO: Rename ReadInt16() ?
+        public virtual short ReadInt16()
         {
             return (short)(ushort)(((ReadByte() & 0xFF) << 8) | (ReadByte() & 0xFF));
         }
 
         /// <summary>
-        /// Reads four bytes and returns an int. </summary>
+        /// Reads four bytes and returns an int. 
+        /// <para/>
+        /// NOTE: this was readInt() in Lucene
+        /// </summary>
         /// <seealso cref= DataOutput#writeInt(int) </seealso>
-        public virtual int ReadInt() // LUCENENET TODO: Rename ReadInt32() ?
+        public virtual int ReadInt32()
         {
             return ((ReadByte() & 0xFF) << 24) | ((ReadByte() & 0xFF) << 16) | ((ReadByte() & 0xFF) << 8) | (ReadByte() & 0xFF);
         }
@@ -102,11 +107,13 @@ namespace Lucene.Net.Store
         /// Reads an int stored in variable-length format.  Reads between one and
         /// five bytes.  Smaller values take fewer bytes.  Negative numbers are not
         /// supported.
-        /// <p>
+        /// <para/>
         /// The format is described further in <seealso cref="DataOutput#writeVInt(int)"/>.
+        /// <para/>
+        /// NOTE: this was readVInt() in Lucene
         /// </summary>
         /// <seealso cref= DataOutput#writeVInt(int) </seealso>
-        public virtual int ReadVInt() // LUCENENET TODO: Rename ReadVInt32() ?
+        public virtual int ReadVInt32()
         {
             // .NET Port: Going back to original code instead of Java code below due to sbyte/byte diff
             /*byte b = ReadByte();
@@ -153,12 +160,15 @@ namespace Lucene.Net.Store
         }
 
         /// <summary>
-        /// Reads eight bytes and returns a long. </summary>
+        /// Reads eight bytes and returns a long. 
+        /// <para/>
+        /// NOTE: this was readLong() in Lucene
+        /// </summary>
         /// <seealso cref= DataOutput#writeLong(long) </seealso>
-        public virtual long ReadLong() // LUCENENET TODO: Rename ReadInt64() ?
+        public virtual long ReadInt64()
         {
-            long halfA = ((long)ReadInt()) << 32;
-            long halfB = (ReadInt() & 0xFFFFFFFFL);
+            long halfA = ((long)ReadInt32()) << 32;
+            long halfB = (ReadInt32() & 0xFFFFFFFFL);
             long ret = halfA | halfB;
             return ret;
         }
@@ -167,11 +177,13 @@ namespace Lucene.Net.Store
         /// Reads a long stored in variable-length format.  Reads between one and
         /// nine bytes.  Smaller values take fewer bytes.  Negative numbers are not
         /// supported.
-        /// <p>
+        /// <para/>
         /// The format is described further in <seealso cref="DataOutput#writeVInt(int)"/>.
+        /// <para/>
+        /// NOTE: this was readVLong() in Lucene
         /// </summary>
         /// <seealso cref= DataOutput#writeVLong(long) </seealso>
-        public virtual long ReadVLong() // LUCENENET TODO: Rename ReadVInt64() ?
+        public virtual long ReadVInt64()
         {
             // .NET Port: going back to old style code
             /*byte b = ReadByte();
@@ -245,7 +257,7 @@ namespace Lucene.Net.Store
         /// <seealso cref= DataOutput#writeString(String) </seealso>
         public virtual string ReadString()
         {
-            var length = ReadVInt();
+            var length = ReadVInt32();
             var bytes = new byte[length];
             ReadBytes(bytes, 0, length);
 
@@ -283,7 +295,7 @@ namespace Lucene.Net.Store
         public virtual IDictionary<string, string> ReadStringStringMap()
         {
             IDictionary<string, string> map = new Dictionary<string, string>();
-            int count = ReadInt();
+            int count = ReadInt32();
             for (int i = 0; i < count; i++)
             {
                 string key = ReadString();
@@ -301,7 +313,7 @@ namespace Lucene.Net.Store
         public virtual ISet<string> ReadStringSet()
         {
             ISet<string> set = new HashSet<string>();
-            int count = ReadInt();
+            int count = ReadInt32();
             for (int i = 0; i < count; i++)
             {
                 set.Add(ReadString());

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Store/DataOutput.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Store/DataOutput.cs b/src/Lucene.Net.Core/Store/DataOutput.cs
index ac51f65..55960d2 100644
--- a/src/Lucene.Net.Core/Store/DataOutput.cs
+++ b/src/Lucene.Net.Core/Store/DataOutput.cs
@@ -63,11 +63,13 @@ namespace Lucene.Net.Store
 
         /// <summary>
         /// Writes an int as four bytes.
-        /// <p>
+        /// <para/>
         /// 32-bit unsigned integer written as four bytes, high-order bytes first.
+        /// <para/>
+        /// NOTE: this was writeInt() in Lucene
         /// </summary>
         /// <seealso cref= DataInput#readInt() </seealso>
-        public virtual void WriteInt(int i) // LUCENENET TODO: Rename WriteInt32() ?
+        public virtual void WriteInt32(int i)
         {
             WriteByte((byte)(sbyte)(i >> 24));
             WriteByte((byte)(sbyte)(i >> 16));
@@ -76,9 +78,12 @@ namespace Lucene.Net.Store
         }
 
         /// <summary>
-        /// Writes a short as two bytes. </summary>
+        /// Writes a short as two bytes. 
+        /// <para/>
+        /// NOTE: this was writeShort() in Lucene
+        /// </summary>
         /// <seealso cref= DataInput#readShort() </seealso>
-        public virtual void WriteShort(short i) // LUCENENET TODO: Rename WriteInt16() ?
+        public virtual void WriteInt16(short i)
         {
             WriteByte((byte)(sbyte)((ushort)i >> 8));
             WriteByte((byte)(sbyte)(ushort)i);
@@ -185,12 +190,14 @@ namespace Lucene.Net.Store
         /// </tr>
         /// </table>
         /// <p>this provides compression while still being efficient to decode.</p>
+        /// <para/>
+        /// NOTE: this was writeVInt() in Lucene
         /// </summary>
         /// <param name="i"> Smaller values take fewer bytes.  Negative numbers are
         /// supported, but should be avoided. </param>
         /// <exception cref="System.IO.IOException"> If there is an I/O error writing to the underlying medium. </exception>
         /// <seealso cref= DataInput#readVInt() </seealso>
-        public void WriteVInt(int i) // LUCENENET TODO: Rename WriteVInt32() ?
+        public void WriteVInt32(int i)
         {
             while ((i & ~0x7F) != 0)
             {
@@ -202,24 +209,29 @@ namespace Lucene.Net.Store
 
         /// <summary>
         /// Writes a long as eight bytes.
-        /// <p>
+        /// <para/>
         /// 64-bit unsigned integer written as eight bytes, high-order bytes first.
+        /// <para/>
+        /// NOTE: this was writeLong() in Lucene
         /// </summary>
         /// <seealso cref= DataInput#readLong() </seealso>
-        public virtual void WriteLong(long i) // LUCENENET TODO: Rename WriteInt64() ?
+        public virtual void WriteInt64(long i)
         {
-            WriteInt((int)(i >> 32));
-            WriteInt((int)i);
+            WriteInt32((int)(i >> 32));
+            WriteInt32((int)i);
         }
 
         /// <summary>
         /// Writes an long in a variable-length format.  Writes between one and nine
         /// bytes.  Smaller values take fewer bytes.  Negative numbers are not
         /// supported.
-        /// <p>
-        /// The format is described further in <seealso cref="DataOutput#writeVInt(int)"/>. </summary>
+        /// <para/>
+        /// The format is described further in <seealso cref="DataOutput#writeVInt(int)"/>. 
+        /// <para/>
+        /// NOTE: this was writeVLong() in Lucene
+        /// </summary>
         /// <seealso cref= DataInput#readVLong() </seealso>
-        public void WriteVLong(long i) // LUCENENET TODO: Rename WriteVInt64() ?
+        public void WriteVInt64(long i)
         {
             Debug.Assert(i >= 0L);
             while ((i & ~0x7FL) != 0L)
@@ -241,7 +253,7 @@ namespace Lucene.Net.Store
         {
             var utf8Result = new BytesRef(10);
             UnicodeUtil.UTF16toUTF8(s.ToCharArray(), 0, s.Length, utf8Result);
-            WriteVInt(utf8Result.Length);
+            WriteVInt32(utf8Result.Length);
             WriteBytes(utf8Result.Bytes, 0, utf8Result.Length);
         }
 
@@ -287,11 +299,11 @@ namespace Lucene.Net.Store
         {
             if (map == null)
             {
-                WriteInt(0);
+                WriteInt32(0);
             }
             else
             {
-                WriteInt(map.Count);
+                WriteInt32(map.Count);
                 foreach (KeyValuePair<string, string> entry in map)
                 {
                     WriteString(entry.Key);
@@ -312,11 +324,11 @@ namespace Lucene.Net.Store
         {
             if (set == null)
             {
-                WriteInt(0);
+                WriteInt32(0);
             }
             else
             {
-                WriteInt(set.Count);
+                WriteInt32(set.Count);
                 foreach (string value in set)
                 {
                     WriteString(value);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Support/ByteBuffer.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Support/ByteBuffer.cs b/src/Lucene.Net.Core/Support/ByteBuffer.cs
index 9185b58..051d724 100644
--- a/src/Lucene.Net.Core/Support/ByteBuffer.cs
+++ b/src/Lucene.Net.Core/Support/ByteBuffer.cs
@@ -529,43 +529,94 @@ namespace Lucene.Net.Support
 
         //public abstract CharBuffer AsCharBuffer();
 
-        public abstract short GetShort();
+        /// <summary>
+        /// NOTE: This was getShort() in the JDK
+        /// </summary>
+        public abstract short GetInt16();
 
-        public abstract ByteBuffer PutShort(short value);
+        /// <summary>
+        /// NOTE: This was putShort() in the JDK
+        /// </summary>
+        public abstract ByteBuffer PutInt16(short value);
 
-        public abstract short GetShort(int index);
+        /// <summary>
+        /// NOTE: This was getShort() in the JDK
+        /// </summary>
+        public abstract short GetInt16(int index);
 
-        public abstract ByteBuffer PutShort(int index, short value);
+        /// <summary>
+        /// NOTE: This was putShort() in the JDK
+        /// </summary>
+        public abstract ByteBuffer PutInt16(int index, short value);
 
         // public abstract ShortBuffer AsShortBuffer();
 
-        public abstract int GetInt();
+        /// <summary>
+        /// NOTE: This was getInt() in the JDK
+        /// </summary>
+        public abstract int GetInt32();
 
-        public abstract ByteBuffer PutInt(int value);
+        /// <summary>
+        /// NOTE: This was putInt() in the JDK
+        /// </summary>
+        public abstract ByteBuffer PutInt32(int value);
 
-        public abstract int GetInt(int index);
+        /// <summary>
+        /// NOTE: This was getInt() in the JDK
+        /// </summary>
+        public abstract int GetInt32(int index);
 
-        public abstract ByteBuffer PutInt(int index, int value);
+        /// <summary>
+        /// NOTE: This was putInt() in the JDK
+        /// </summary>
+        public abstract ByteBuffer PutInt32(int index, int value);
 
         //public abstract IntBuffer AsIntBuffer();
 
-        public abstract long GetLong();
+        /// <summary>
+        /// NOTE: This was getLong() in the JDK
+        /// </summary>
+        public abstract long GetInt64();
 
-        public abstract ByteBuffer PutLong(long value);
+        /// <summary>
+        /// NOTE: This was putLong() in the JDK
+        /// </summary>
+        public abstract ByteBuffer PutInt64(long value);
 
-        public abstract long GetLong(int index);
+        /// <summary>
+        /// NOTE: This was getLong() in the JDK
+        /// </summary>
+        public abstract long GetInt64(int index);
 
-        public abstract ByteBuffer PutLong(int index, long value);
+        /// <summary>
+        /// NOTE: This was putLong() in the JDK
+        /// </summary>
+        public abstract ByteBuffer PutInt64(int index, long value);
 
-        public abstract LongBuffer AsLongBuffer();
+        /// <summary>
+        /// NOTE: This was asLongBuffer() in the JDK
+        /// </summary>
+        public abstract LongBuffer AsInt64Buffer();
 
-        public abstract float GetFloat();
+        /// <summary>
+        /// NOTE: This was getFloat() in the JDK
+        /// </summary>
+        public abstract float GetSingle();
 
-        public abstract ByteBuffer PutFloat(float value);
+        /// <summary>
+        /// NOTE: This was putFloat() in the JDK
+        /// </summary>
+        public abstract ByteBuffer PutSingle(float value);
 
-        public abstract float GetFloat(int index);
+        /// <summary>
+        /// NOTE: This was getFloat() in the JDK
+        /// </summary>
+        public abstract float GetSingle(int index);
 
-        public abstract ByteBuffer PutFloat(int index, float value);
+        /// <summary>
+        /// NOTE: This was putFloat() in the JDK
+        /// </summary>
+        public abstract ByteBuffer PutSingle(int index, float value);
 
         //public abstract FloatBuffer AsFloatBuffer();
 
@@ -823,7 +874,10 @@ namespace Lucene.Net.Support
 
             // short
 
-            public override short GetShort()
+            /// <summary>
+            /// NOTE: This was getShort() in the JDK
+            /// </summary>
+            public override short GetInt16()
             {
                 var littleEndian = BitConverter.ToInt16(hb, Ix(NextGetIndex(2)));
                 if (bigEndian)
@@ -833,7 +887,10 @@ namespace Lucene.Net.Support
                 return littleEndian;
             }
 
-            public override short GetShort(int index)
+            /// <summary>
+            /// NOTE: This was getShort() in the JDK
+            /// </summary>
+            public override short GetInt16(int index)
             {
                 var littleEndian = BitConverter.ToInt16(hb, Ix(CheckIndex(index, 2)));
                 if (bigEndian)
@@ -843,7 +900,10 @@ namespace Lucene.Net.Support
                 return littleEndian;
             }
 
-            public override ByteBuffer PutShort(short value)
+            /// <summary>
+            /// NOTE: This was putShort() in the JDK
+            /// </summary>
+            public override ByteBuffer PutInt16(short value)
             {
                 var bytes = BitConverter.GetBytes(bigEndian ? Number.FlipEndian(value) : value);
 
@@ -854,8 +914,10 @@ namespace Lucene.Net.Support
             }
 
 
-
-            public override ByteBuffer PutShort(int index, short value)
+            /// <summary>
+            /// NOTE: This was putShort() in the JDK
+            /// </summary>
+            public override ByteBuffer PutInt16(int index, short value)
             {
                 var bytes = BitConverter.GetBytes(bigEndian ? Number.FlipEndian(value) : value);
 
@@ -886,7 +948,10 @@ namespace Lucene.Net.Support
 
             // int
 
-            public override int GetInt()
+            /// <summary>
+            /// NOTE: This was getInt() in the JDK
+            /// </summary>
+            public override int GetInt32()
             {
                 var littleEndian = BitConverter.ToInt32(hb, Ix(NextGetIndex(4)));
                 if (bigEndian)
@@ -896,7 +961,10 @@ namespace Lucene.Net.Support
                 return littleEndian;
             }
 
-            public override int GetInt(int index)
+            /// <summary>
+            /// NOTE: This was getInt() in the JDK
+            /// </summary>
+            public override int GetInt32(int index)
             {
                 var littleEndian = BitConverter.ToInt32(hb, Ix(CheckIndex(index, 4)));
                 if (bigEndian)
@@ -906,7 +974,10 @@ namespace Lucene.Net.Support
                 return littleEndian;
             }
 
-            public override ByteBuffer PutInt(int value)
+            /// <summary>
+            /// NOTE: This was putInt() in the JDK
+            /// </summary>
+            public override ByteBuffer PutInt32(int value)
             {
                 var bytes = BitConverter.GetBytes(bigEndian ? Number.FlipEndian(value) : value);
 
@@ -918,7 +989,10 @@ namespace Lucene.Net.Support
                 return this;
             }
 
-            public override ByteBuffer PutInt(int index, int value)
+            /// <summary>
+            /// NOTE: This was putInt() in the JDK
+            /// </summary>
+            public override ByteBuffer PutInt32(int index, int value)
             {
                 var bytes = BitConverter.GetBytes(bigEndian ? Number.FlipEndian(value) : value);
 
@@ -951,7 +1025,10 @@ namespace Lucene.Net.Support
 
             // long
 
-            public override long GetLong()
+            /// <summary>
+            /// NOTE: This was getLong() in the JDK
+            /// </summary>
+            public override long GetInt64()
             {
                 var littleEndian = BitConverter.ToInt64(hb, Ix(NextGetIndex(8)));
                 if (bigEndian)
@@ -961,7 +1038,10 @@ namespace Lucene.Net.Support
                 return littleEndian;
             }
 
-            public override long GetLong(int index)
+            /// <summary>
+            /// NOTE: This was getLong() in the JDK
+            /// </summary>
+            public override long GetInt64(int index)
             {
                 var littleEndian = BitConverter.ToInt64(hb, Ix(CheckIndex(index, 8)));
                 if (bigEndian)
@@ -971,7 +1051,10 @@ namespace Lucene.Net.Support
                 return littleEndian;
             }
 
-            public override ByteBuffer PutLong(long value)
+            /// <summary>
+            /// NOTE: This was putLong() in the JDK
+            /// </summary>
+            public override ByteBuffer PutInt64(long value)
             {
                 var bytes = BitConverter.GetBytes(bigEndian ? Number.FlipEndian(value) : value);
 
@@ -988,8 +1071,10 @@ namespace Lucene.Net.Support
             }
 
 
-
-            public override ByteBuffer PutLong(int index, long value)
+            /// <summary>
+            /// NOTE: This was putLong() in the JDK
+            /// </summary>
+            public override ByteBuffer PutInt64(int index, long value)
             {
                 var bytes = BitConverter.GetBytes(bigEndian ? Number.FlipEndian(value) : value);
 
@@ -1005,7 +1090,10 @@ namespace Lucene.Net.Support
                 return this;
             }
 
-            public override LongBuffer AsLongBuffer()
+            /// <summary>
+            /// NOTE: This was asLongBuffer() in the JDK
+            /// </summary>
+            public override LongBuffer AsInt64Buffer()
             {
                 int size = this.Remaining >> 3;
                 int off = offset + Position;
@@ -1032,7 +1120,10 @@ namespace Lucene.Net.Support
                 //                                                       off)));
             }
 
-            public override float GetFloat()
+            /// <summary>
+            /// NOTE: This was getFloat() in the JDK
+            /// </summary>
+            public override float GetSingle()
             {
                 byte[] temp = new byte[4];
                 System.Array.Copy(hb, Ix(NextGetIndex(4)), temp, 0, 4);
@@ -1043,7 +1134,10 @@ namespace Lucene.Net.Support
                 return BitConverter.ToSingle(temp, 0);
             }
 
-            public override float GetFloat(int index)
+            /// <summary>
+            /// NOTE: This was getFloat() in the JDK
+            /// </summary>
+            public override float GetSingle(int index)
             {
                 var littleEndian = BitConverter.ToSingle(hb, Ix(CheckIndex(index, 4)));
                 if (bigEndian)
@@ -1053,7 +1147,10 @@ namespace Lucene.Net.Support
                 return littleEndian;
             }
 
-            public override ByteBuffer PutFloat(float value)
+            /// <summary>
+            /// NOTE: This was putFloat() in the JDK
+            /// </summary>
+            public override ByteBuffer PutSingle(float value)
             {
                 var bytes = BitConverter.GetBytes(value);
 
@@ -1071,8 +1168,10 @@ namespace Lucene.Net.Support
             }
 
 
-
-            public override ByteBuffer PutFloat(int index, float value)
+            /// <summary>
+            /// NOTE: This was putFloat() in the JDK
+            /// </summary>
+            public override ByteBuffer PutSingle(int index, float value)
             {
                 var bytes = BitConverter.GetBytes(value);
 
@@ -1305,12 +1404,18 @@ namespace Lucene.Net.Support
 
             // short
 
-            public override ByteBuffer PutShort(short x)
+            /// <summary>
+            /// NOTE: This was putShort() in the JDK
+            /// </summary>
+            public override ByteBuffer PutInt16(short x)
             {
                 throw new ReadOnlyBufferException();
             }
 
-            public override ByteBuffer PutShort(int i, short x)
+            /// <summary>
+            /// NOTE: This was putShort() in the JDK
+            /// </summary>
+            public override ByteBuffer PutInt16(int i, short x)
             {
                 throw new ReadOnlyBufferException();
             }
@@ -1337,12 +1442,18 @@ namespace Lucene.Net.Support
 
             // int
 
-            public override ByteBuffer PutInt(int x)
+            /// <summary>
+            /// NOTE: This was putInt() in the JDK
+            /// </summary>
+            public override ByteBuffer PutInt32(int x)
             {
                 throw new ReadOnlyBufferException();
             }
 
-            public override ByteBuffer PutInt(int i, int x)
+            /// <summary>
+            /// NOTE: This was putInt() in the JDK
+            /// </summary>
+            public override ByteBuffer PutInt32(int i, int x)
             {
                 throw new ReadOnlyBufferException();
             }
@@ -1369,17 +1480,26 @@ namespace Lucene.Net.Support
 
             // long
 
-            public override ByteBuffer PutLong(long x)
+            /// <summary>
+            /// NOTE: This was putLong() in the JDK
+            /// </summary>
+            public override ByteBuffer PutInt64(long x)
             {
                 throw new ReadOnlyBufferException();
             }
 
-            public override ByteBuffer PutLong(int i, long x)
+            /// <summary>
+            /// NOTE: This was putLong() in the JDK
+            /// </summary>
+            public override ByteBuffer PutInt64(int i, long x)
             {
                 throw new ReadOnlyBufferException();
             }
 
-            public override LongBuffer AsLongBuffer()
+            /// <summary>
+            /// NOTE: This was asLongBuffer() in the JDK
+            /// </summary>
+            public override LongBuffer AsInt64Buffer()
             {
                 throw new NotImplementedException();
                 //int size = this.remaining() >> 3;
@@ -1401,12 +1521,18 @@ namespace Lucene.Net.Support
 
             // float
 
-            public override ByteBuffer PutFloat(float x)
+            /// <summary>
+            /// NOTE: This was putFloat() in the JDK
+            /// </summary>
+            public override ByteBuffer PutSingle(float x)
             {
                 throw new ReadOnlyBufferException();
             }
 
-            public override ByteBuffer PutFloat(int i, float x)
+            /// <summary>
+            /// NOTE: This was putFloat() in the JDK
+            /// </summary>
+            public override ByteBuffer PutSingle(int i, float x)
             {
                 throw new ReadOnlyBufferException();
             }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Support/DataInputStream.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Support/DataInputStream.cs b/src/Lucene.Net.Core/Support/DataInputStream.cs
index b135125..71cd5b1 100644
--- a/src/Lucene.Net.Core/Support/DataInputStream.cs
+++ b/src/Lucene.Net.Core/Support/DataInputStream.cs
@@ -96,7 +96,7 @@ namespace Lucene.Net.Support
             return (ch != 0);
         }
 
-        public byte ReadByte()
+        public byte ReadByte() // LUCENENET TODO: Rename ReadSByte() ... change this to int the same as Stream.ReadByte() ? (since putting sbyte here is ugly)
         {
             int ch = @in.ReadByte();
             if (ch < 0)
@@ -104,7 +104,7 @@ namespace Lucene.Net.Support
             return (byte)(ch);
         }
 
-        public int ReadUnsignedByte()
+        public int ReadUnsignedByte() // LUCENET TODO: Rename ReadByte() after above method is fixed
         {
             int ch = @in.ReadByte();
             if (ch < 0)
@@ -112,7 +112,10 @@ namespace Lucene.Net.Support
             return ch;
         }
 
-        public short ReadShort()
+        /// <summary>
+        /// NOTE: This was readShort() in the JDK
+        /// </summary>
+        public short ReadInt16()
         {
             int ch1 = @in.ReadByte();
             int ch2 = @in.ReadByte();
@@ -121,7 +124,10 @@ namespace Lucene.Net.Support
             return (short)((ch1 << 8) + (ch2 << 0));
         }
 
-        public int ReadUnsignedShort()
+        /// <summary>
+        /// NOTE: This was readUnsignedShort() in the JDK
+        /// </summary>
+        public int ReadUInt16()
         {
             int ch1 = @in.ReadByte();
             int ch2 = @in.ReadByte();
@@ -139,7 +145,10 @@ namespace Lucene.Net.Support
             return (char)((ch1 << 8) + (ch2 << 0));
         }
 
-        public int ReadInt()
+        /// <summary>
+        /// NOTE: This was readInt() in the JDK
+        /// </summary>
+        public int ReadInt32()
         {
             int ch1 = @in.ReadByte();
             int ch2 = @in.ReadByte();
@@ -152,7 +161,10 @@ namespace Lucene.Net.Support
 
         private byte[] readBuffer = new byte[8];
 
-        public long ReadLong()
+        /// <summary>
+        /// NOTE: This was readLong() in the JDK
+        /// </summary>
+        public long ReadInt64()
         {
             ReadFully(readBuffer, 0, 8);
             return (((long)readBuffer[0] << 56) +
@@ -165,9 +177,12 @@ namespace Lucene.Net.Support
                     ((readBuffer[7] & 255) << 0));
         }
 
-        public float ReadFloat()
+        /// <summary>
+        /// NOTE: This was readFloat() in the JDK
+        /// </summary>
+        public float ReadSingle()
         {
-            return Number.IntBitsToFloat(ReadInt());
+            return Number.Int32BitsToSingle(ReadInt32());
         }
 
         public double ReadDouble()
@@ -243,7 +258,7 @@ namespace Lucene.Net.Support
 
         public static string ReadUTF(IDataInput @in)
         {
-            int utflen = @in.ReadUnsignedShort();
+            int utflen = @in.ReadUInt16();
             byte[] bytearr = null;
             char[] chararr = null;
             if (@in is DataInputStream)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Support/DataOutputStream.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Support/DataOutputStream.cs b/src/Lucene.Net.Core/Support/DataOutputStream.cs
index ffc2ba5..fb6d57f 100644
--- a/src/Lucene.Net.Core/Support/DataOutputStream.cs
+++ b/src/Lucene.Net.Core/Support/DataOutputStream.cs
@@ -98,7 +98,10 @@ namespace Lucene.Net.Support
             IncCount(1);
         }
 
-        public void WriteShort(int v)
+        /// <summary>
+        /// NOTE: This was writeShort() in the JDK
+        /// </summary>
+        public void WriteInt16(int v)
         {
             @out.WriteByte((byte)((int)((uint)v >> 8) & 0xFF));
             @out.WriteByte((byte)((int)((uint)v >> 0) & 0xFF));
@@ -112,7 +115,10 @@ namespace Lucene.Net.Support
             IncCount(2);
         }
 
-        public void WriteInt(int v)
+        /// <summary>
+        /// NOTE: This was writeInt() in the JDK
+        /// </summary>
+        public void WriteInt32(int v)
         {
             @out.WriteByte((byte)(int)(((uint)v >> 24) & 0xFF));
             @out.WriteByte((byte)(int)(((uint)v >> 16) & 0xFF));
@@ -123,7 +129,10 @@ namespace Lucene.Net.Support
 
         private byte[] writeBuffer = new byte[8];
 
-        public void WriteLong(long v)
+        /// <summary>
+        /// NOTE: This was writeLong() in the JDK
+        /// </summary>
+        public void WriteInt64(long v)
         {
             writeBuffer[0] = (byte)(long)((ulong)v >> 56);
             writeBuffer[1] = (byte)(long)((ulong)v >> 48);
@@ -137,14 +146,17 @@ namespace Lucene.Net.Support
             IncCount(8);
         }
 
-        public void WriteFloat(float v)
+        /// <summary>
+        /// NOTE: This was writeFloat() in the JDK
+        /// </summary>
+        public void WriteSingle(float v)
         {
-            WriteInt(Number.FloatToIntBits(v));
+            WriteInt32(Number.SingleToInt32Bits(v));
         }
 
         public void WriteDouble(double v)
         {
-            WriteLong(Number.DoubleToLongBits(v));
+            WriteInt64(Number.DoubleToInt64Bits(v));
         }
 
         public void WriteBytes(string s)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Support/IDataInput.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Support/IDataInput.cs b/src/Lucene.Net.Core/Support/IDataInput.cs
index 40d56cf..c1c39fa 100644
--- a/src/Lucene.Net.Core/Support/IDataInput.cs
+++ b/src/Lucene.Net.Core/Support/IDataInput.cs
@@ -11,12 +11,28 @@
         bool ReadBoolean();
         byte ReadByte();
         int ReadUnsignedByte();
-        short ReadShort();
-        int ReadUnsignedShort();
+
+        /// <summary>
+        /// NOTE: This was readShort() in the JDK
+        /// </summary>
+        short ReadInt16();
+
+        /// <summary>
+        /// NOTE: This was readUnsignedShort() in the JDK
+        /// </summary>
+        int ReadUInt16();
         char ReadChar();
-        int ReadInt();
-        long ReadLong();
-        float ReadFloat();
+
+        /// <summary>
+        /// NOTE: This was readInt() in the JDK
+        /// </summary>
+        int ReadInt32();
+
+        /// <summary>
+        /// NOTE: This was readLong() in the JDK
+        /// </summary>
+        long ReadInt64();
+        float ReadSingle();
         double ReadDouble();
         string ReadLine();
         string ReadUTF();

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Support/IDataOutput.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Support/IDataOutput.cs b/src/Lucene.Net.Core/Support/IDataOutput.cs
index 6f81351..a40fd87 100644
--- a/src/Lucene.Net.Core/Support/IDataOutput.cs
+++ b/src/Lucene.Net.Core/Support/IDataOutput.cs
@@ -10,11 +10,27 @@
         void Write(byte[] b, int off, int len);
         void WriteBoolean(bool v);
         void WriteByte(int v);
-        void WriteShort(int v);
+
+        /// <summary>
+        /// NOTE: This was writeShort() in the JDK
+        /// </summary>
+        void WriteInt16(int v);
         void WriteChar(int v);
-        void WriteInt(int v);
-        void WriteLong(long v);
-        void WriteFloat(float v);
+
+        /// <summary>
+        /// NOTE: This was writeInt() in the JDK
+        /// </summary>
+        void WriteInt32(int v);
+
+        /// <summary>
+        /// NOTE: This was writeInt64() in the JDK
+        /// </summary>
+        void WriteInt64(long v);
+
+        /// <summary>
+        /// NOTE: This was writeSingle() in the JDK
+        /// </summary>
+        void WriteSingle(float v);
         void WriteDouble(double v);
         void WriteBytes(string s);
         void WriteChars(string s);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Support/LongBuffer.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Support/LongBuffer.cs b/src/Lucene.Net.Core/Support/LongBuffer.cs
index 89cb0fd..0bfdcf2 100644
--- a/src/Lucene.Net.Core/Support/LongBuffer.cs
+++ b/src/Lucene.Net.Core/Support/LongBuffer.cs
@@ -6,7 +6,7 @@ namespace Lucene.Net.Support
     /// <summary>
     /// Ported from Java's nio.LongBuffer
     /// </summary>
-    public abstract class LongBuffer : Buffer, IComparable<LongBuffer>
+    public abstract class LongBuffer : Buffer, IComparable<LongBuffer> // LUCENENET TODO: Rename Int64Buffer
     {
         // These fields are declared here rather than in Heap-X-Buffer in order to
         // reduce the number of virtual method invocations needed to access these

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Support/MemoryMappedFileByteBuffer.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Support/MemoryMappedFileByteBuffer.cs b/src/Lucene.Net.Core/Support/MemoryMappedFileByteBuffer.cs
index 3ac6654..2d29ae7 100644
--- a/src/Lucene.Net.Core/Support/MemoryMappedFileByteBuffer.cs
+++ b/src/Lucene.Net.Core/Support/MemoryMappedFileByteBuffer.cs
@@ -124,7 +124,10 @@ namespace Lucene.Net.Support
             return this;
         }
 
-        public override short GetShort()
+        /// <summary>
+        /// NOTE: This was getShort() in the JDK
+        /// </summary>
+        public override short GetInt16()
         {
             var littleEndian = _accessor.ReadInt16(Ix(NextGetIndex(2)));
             if (bigEndian)
@@ -134,7 +137,10 @@ namespace Lucene.Net.Support
             return littleEndian;
         }
 
-        public override short GetShort(int index)
+        /// <summary>
+        /// NOTE: This was getShort() in the JDK
+        /// </summary>
+        public override short GetInt16(int index)
         {
             var littleEndian = _accessor.ReadInt16(Ix(CheckIndex(index, 2)));
             if (bigEndian)
@@ -144,19 +150,28 @@ namespace Lucene.Net.Support
             return littleEndian;
         }
 
-        public override ByteBuffer PutShort(short value)
+        /// <summary>
+        /// NOTE: This was putShort() in the JDK
+        /// </summary>
+        public override ByteBuffer PutInt16(short value)
         {
             _accessor.Write(Ix(NextPutIndex(2)), bigEndian ? Number.FlipEndian(value) : value);
             return this;
         }
 
-        public override ByteBuffer PutShort(int index, short value)
+        /// <summary>
+        /// NOTE: This was putShort() in the JDK
+        /// </summary>
+        public override ByteBuffer PutInt16(int index, short value)
         {
             _accessor.Write(Ix(CheckIndex(index, 2)), bigEndian ? Number.FlipEndian(value) : value);
             return this;
         }
 
-        public override int GetInt()
+        /// <summary>
+        /// NOTE: This was getInt() in the JDK
+        /// </summary>
+        public override int GetInt32()
         {
             var littleEndian = _accessor.ReadInt32(Ix(NextGetIndex(4)));
             if (bigEndian)
@@ -166,7 +181,10 @@ namespace Lucene.Net.Support
             return littleEndian;
         }
 
-        public override int GetInt(int index)
+        /// <summary>
+        /// NOTE: This was getInt() in the JDK
+        /// </summary>
+        public override int GetInt32(int index)
         {
             var littleEndian = _accessor.ReadInt32(Ix(CheckIndex(index, 4)));
             if (bigEndian)
@@ -176,21 +194,29 @@ namespace Lucene.Net.Support
             return littleEndian;
         }
 
-        public override ByteBuffer PutInt(int value)
+        /// <summary>
+        /// NOTE: This was putInt() in the JDK
+        /// </summary>
+        public override ByteBuffer PutInt32(int value)
         {
             _accessor.Write(Ix(NextPutIndex(4)), bigEndian ? Number.FlipEndian(value) : value);
             return this;
         }
 
-        
 
-        public override ByteBuffer PutInt(int index, int value)
+        /// <summary>
+        /// NOTE: This was putInt() in the JDK
+        /// </summary>
+        public override ByteBuffer PutInt32(int index, int value)
         {
             _accessor.Write(Ix(CheckIndex(index, 4)), bigEndian ? Number.FlipEndian(value) : value);
             return this;
         }
 
-        public override long GetLong()
+        /// <summary>
+        /// NOTE: This was getLong() in the JDK
+        /// </summary>
+        public override long GetInt64()
         {
             var littleEndian = _accessor.ReadInt64(Ix(NextGetIndex(8)));
             if (bigEndian)
@@ -200,7 +226,10 @@ namespace Lucene.Net.Support
             return littleEndian;
         }
 
-        public override long GetLong(int index)
+        /// <summary>
+        /// NOTE: This was getLong() in the JDK
+        /// </summary>
+        public override long GetInt64(int index)
         {
             var littleEndian = _accessor.ReadInt64(Ix(CheckIndex(index, 8)));
             if (bigEndian)
@@ -210,19 +239,28 @@ namespace Lucene.Net.Support
             return littleEndian;
         }
 
-        public override ByteBuffer PutLong(long value)
+        /// <summary>
+        /// NOTE: This was putLong() in the JDK
+        /// </summary>
+        public override ByteBuffer PutInt64(long value)
         {
             _accessor.Write(Ix(NextPutIndex(8)), bigEndian ? Number.FlipEndian(value) : value);
             return this;
         }
 
-        public override ByteBuffer PutLong(int index, long value)
+        /// <summary>
+        /// NOTE: This was putLong() in the JDK
+        /// </summary>
+        public override ByteBuffer PutInt64(int index, long value)
         {
             _accessor.Write(Ix(CheckIndex(index, 8)), bigEndian ? Number.FlipEndian(value) : value);
             return this;
         }
 
-        public override float GetFloat()
+        /// <summary>
+        /// NOTE: This was getFloat() in the JDK
+        /// </summary>
+        public override float GetSingle()
         {
             byte[] temp = new byte[4];
             temp[0] = _accessor.ReadByte(Ix(NextGetIndex()));
@@ -236,7 +274,10 @@ namespace Lucene.Net.Support
             return BitConverter.ToSingle(temp, 0);
         }
 
-        public override float GetFloat(int index)
+        /// <summary>
+        /// NOTE: This was getFloat() in the JDK
+        /// </summary>
+        public override float GetSingle(int index)
         {
             byte[] temp = new byte[4];
             temp[0] = _accessor.ReadByte(Ix(NextGetIndex(index)));
@@ -250,7 +291,10 @@ namespace Lucene.Net.Support
             return BitConverter.ToSingle(temp, 0);
         }
 
-        public override ByteBuffer PutFloat(float value)
+        /// <summary>
+        /// NOTE: This was putFloat() in the JDK
+        /// </summary>
+        public override ByteBuffer PutSingle(float value)
         {
             var bytes = BitConverter.GetBytes(value);
 
@@ -266,7 +310,10 @@ namespace Lucene.Net.Support
             return this;
         }
 
-        public override ByteBuffer PutFloat(int index, float value)
+        /// <summary>
+        /// NOTE: This was putFloat() in the JDK
+        /// </summary>
+        public override ByteBuffer PutSingle(int index, float value)
         {
             var bytes = BitConverter.GetBytes(value);
 
@@ -322,7 +369,10 @@ namespace Lucene.Net.Support
             _accessor = null;
         }
 
-        public override LongBuffer AsLongBuffer()
+        /// <summary>
+        /// NOTE: This was asLongBuffer() in the JDK
+        /// </summary>
+        public override LongBuffer AsInt64Buffer()
         {
             throw new NotSupportedException();
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Support/Number.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Support/Number.cs b/src/Lucene.Net.Core/Support/Number.cs
index d5f6ab0..dad6dc5 100644
--- a/src/Lucene.Net.Core/Support/Number.cs
+++ b/src/Lucene.Net.Core/Support/Number.cs
@@ -391,18 +391,27 @@ namespace Lucene.Net.Support
             return Convert.ToString(value, 2);
         }
 
-        public static float IntBitsToFloat(int value)
+        /// <summary>
+        /// NOTE: This was intBitsToFloat() in the JDK
+        /// </summary>
+        public static float Int32BitsToSingle(int value)
         {
             return BitConverter.ToSingle(BitConverter.GetBytes(value), 0);
         }
 
-        public static int FloatToRawIntBits(float value)
+        /// <summary>
+        /// NOTE: This was floatToRawIntBits() in the JDK
+        /// </summary>
+        public static int SingleToRawInt32Bits(float value)
         {
             // TODO: does this handle NaNs the same?
             return BitConverter.ToInt32(BitConverter.GetBytes(value), 0);
         }
 
-        public static int FloatToIntBits(float value)
+        /// <summary>
+        /// NOTE: This was floatToIntBits() in the JDK
+        /// </summary>
+        public static int SingleToInt32Bits(float value)
         {
             if (float.IsNaN(value))
             {
@@ -413,17 +422,26 @@ namespace Lucene.Net.Support
             return BitConverter.ToInt32(BitConverter.GetBytes(value), 0);
         }
 
-        public static long FloatToLongBits(float value)
+        /// <summary>
+        /// NOTE: This was floatToLongBits() in the JDK
+        /// </summary>
+        public static long SingleToInt64Bits(float value)
         {
             return BitConverter.ToInt64(BitConverter.GetBytes(value), 0);
         }
 
-        public static long DoubleToRawLongBits(double value)
+        /// <summary>
+        /// NOTE: This was doubleToRawLongBits() in the JDK
+        /// </summary>
+        public static long DoubleToRawInt64Bits(double value)
         {
             return BitConverter.DoubleToInt64Bits(value);
         }
 
-        public static long DoubleToLongBits(double value)
+        /// <summary>
+        /// NOTE: This was doubleToLongBits() in the JDK
+        /// </summary>
+        public static long DoubleToInt64Bits(double value)
         {
             if (double.IsNaN(value))
             {
@@ -467,8 +485,8 @@ namespace Lucene.Net.Support
         //4 bytes
         public static float FlipEndian(float f)
         {
-            int x = FloatToIntBits(f);
-            return IntBitsToFloat(FlipEndian(x));
+            int x = SingleToInt32Bits(f);
+            return Int32BitsToSingle(FlipEndian(x));
         }
 
         //8 bytes

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Util/ArrayUtil.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/ArrayUtil.cs b/src/Lucene.Net.Core/Util/ArrayUtil.cs
index 2df630e..474bb64 100644
--- a/src/Lucene.Net.Core/Util/ArrayUtil.cs
+++ b/src/Lucene.Net.Core/Util/ArrayUtil.cs
@@ -53,25 +53,30 @@ namespace Lucene.Net.Util
         /// Parses the string argument as if it was an int value and returns the
         /// result. Throws NumberFormatException if the string does not represent an
         /// int quantity.
+        /// <para/>
+        /// NOTE: This was parseInt() in Lucene
         /// </summary>
         /// <param name="chars"> a string representation of an int quantity. </param>
         /// <returns> int the value represented by the argument </returns>
         /// <exception cref="NumberFormatException"> if the argument could not be parsed as an int quantity. </exception>
-        public static int ParseInt(char[] chars) // LUCENENET TODO: Rename ParseInt32 ?
+        public static int ParseInt32(char[] chars)
         {
-            return ParseInt(chars, 0, chars.Length, 10);
+            return ParseInt32(chars, 0, chars.Length, 10);
         }
 
         /// <summary>
-        /// Parses a char array into an int. </summary>
+        /// Parses a char array into an int. 
+        /// <para/>
+        /// NOTE: This was parseInt() in Lucene
+        /// </summary>
         /// <param name="chars"> the character array </param>
         /// <param name="offset"> The offset into the array </param>
         /// <param name="len"> The length </param>
         /// <returns> the int </returns>
         /// <exception cref="NumberFormatException"> if it can't parse </exception>
-        public static int ParseInt(char[] chars, int offset, int len) // LUCENENET TODO: Rename ParseInt32 ?
+        public static int ParseInt32(char[] chars, int offset, int len)
         {
-            return ParseInt(chars, offset, len, 10);
+            return ParseInt32(chars, offset, len, 10);
         }
 
         /// <summary>
@@ -79,12 +84,14 @@ namespace Lucene.Net.Util
         /// result. Throws NumberFormatException if the string does not represent an
         /// int quantity. The second argument specifies the radix to use when parsing
         /// the value.
+        /// <para/>
+        /// NOTE: This was parseInt() in Lucene
         /// </summary>
         /// <param name="chars"> a string representation of an int quantity. </param>
         /// <param name="radix"> the base to use for conversion. </param>
         /// <returns> int the value represented by the argument </returns>
         /// <exception cref="NumberFormatException"> if the argument could not be parsed as an int quantity. </exception>
-        public static int ParseInt(char[] chars, int offset, int len, int radix) // LUCENENET TODO: Rename ParseInt32 ?
+        public static int ParseInt32(char[] chars, int offset, int len, int radix)
         {
             int minRadix = 2, maxRadix = 36;
             if (chars == null || radix < minRadix || radix > maxRadix)
@@ -757,7 +764,10 @@ namespace Lucene.Net.Util
             return false;
         }
 
-        public static int[] ToIntArray(ICollection<int?> ints) // LUCENENET TODO: Nullable issue - the cast to int probably won't work here
+        /// <summary>
+        /// NOTE: This was toIntArray() in Lucene
+        /// </summary>
+        public static int[] ToInt32Array(ICollection<int?> ints) // LUCENENET TODO: Nullable issue - the cast to int probably won't work here
         {
             int[] result = new int[ints.Count];
             int upto = 0;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Util/Automaton/BasicOperations.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Automaton/BasicOperations.cs b/src/Lucene.Net.Core/Util/Automaton/BasicOperations.cs
index 5b560b3..1e6ee2c 100644
--- a/src/Lucene.Net.Core/Util/Automaton/BasicOperations.cs
+++ b/src/Lucene.Net.Core/Util/Automaton/BasicOperations.cs
@@ -861,7 +861,7 @@ namespace Lucene.Net.Util.Automaton
                         statesSet.ComputeHash();
 
                         State q;
-                        newstate.TryGetValue(statesSet.ToFrozenIntSet(), out q);
+                        newstate.TryGetValue(statesSet.ToFrozenInt32Set(), out q);
                         if (q == null)
                         {
                             q = new State();

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Util/Automaton/SortedIntSet.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Automaton/SortedIntSet.cs b/src/Lucene.Net.Core/Util/Automaton/SortedIntSet.cs
index 32688d5..44b9a8a 100644
--- a/src/Lucene.Net.Core/Util/Automaton/SortedIntSet.cs
+++ b/src/Lucene.Net.Core/Util/Automaton/SortedIntSet.cs
@@ -25,7 +25,7 @@ namespace Lucene.Net.Util.Automaton
     // Just holds a set of int[] states, plus a corresponding
     // int[] count per state.  Used by
     // BasicOperations.determinize
-    internal sealed class SortedIntSet : IEquatable<SortedIntSet>, IEquatable<SortedIntSet.FrozenIntSet>
+    internal sealed class SortedIntSet : IEquatable<SortedIntSet>, IEquatable<SortedIntSet.FrozenIntSet> // LUCENENET TODO: Rename SortedInt32Set
     {
         internal int[] values;
         internal int[] counts;
@@ -184,7 +184,7 @@ namespace Lucene.Net.Util.Automaton
             }
         }
 
-        public FrozenIntSet ToFrozenIntSet() // LUCENENET TODO: This didn't exist in the original
+        public FrozenIntSet ToFrozenInt32Set() // LUCENENET TODO: This didn't exist in the original
         {
             int[] c = new int[upto];
             Array.Copy(values, 0, c, 0, upto);
@@ -280,7 +280,7 @@ namespace Lucene.Net.Util.Automaton
             return sb.ToString();
         }
 
-        public sealed class FrozenIntSet : IEquatable<SortedIntSet>, IEquatable<FrozenIntSet>
+        public sealed class FrozenIntSet : IEquatable<SortedIntSet>, IEquatable<FrozenIntSet> // LUCENENET TODO: Rename FrozenInt32Set
         {
             internal readonly int[] values;
             internal readonly int hashCode;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Util/Automaton/SpecialOperations.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Automaton/SpecialOperations.cs b/src/Lucene.Net.Core/Util/Automaton/SpecialOperations.cs
index 2053fed..609a3a5 100644
--- a/src/Lucene.Net.Core/Util/Automaton/SpecialOperations.cs
+++ b/src/Lucene.Net.Core/Util/Automaton/SpecialOperations.cs
@@ -319,7 +319,7 @@ namespace Lucene.Net.Util.Automaton
                 for (int n = t.min; n <= t.max; n++)
                 {
                     path.Grow(path.Length + 1);
-                    path.Ints[path.Length] = n;
+                    path.Int32s[path.Length] = n;
                     path.Length++;
                     if (t.to.accept)
                     {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Util/Fst/Builder.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Fst/Builder.cs b/src/Lucene.Net.Core/Util/Fst/Builder.cs
index 39adf42..b147f4d 100644
--- a/src/Lucene.Net.Core/Util/Fst/Builder.cs
+++ b/src/Lucene.Net.Core/Util/Fst/Builder.cs
@@ -314,7 +314,7 @@ namespace Lucene.Net.Util.Fst
                     {
                         // this node doesn't make it -- deref it
                         node.Clear();
-                        parent.DeleteLast(lastInput.Ints[lastInput.Offset + idx - 1], node);
+                        parent.DeleteLast(lastInput.Int32s[lastInput.Offset + idx - 1], node);
                     }
                     else
                     {
@@ -336,13 +336,13 @@ namespace Lucene.Net.Util.Fst
                             // this node makes it and we now compile it.  first,
                             // compile any targets that were previously
                             // undecided:
-                            parent.ReplaceLast(lastInput.Ints[lastInput.Offset + idx - 1], CompileNode(node, 1 + lastInput.Length - idx), nextFinalOutput, isFinal);
+                            parent.ReplaceLast(lastInput.Int32s[lastInput.Offset + idx - 1], CompileNode(node, 1 + lastInput.Length - idx), nextFinalOutput, isFinal);
                         }
                         else
                         {
                             // replaceLast just to install
                             // nextFinalOutput/isFinal onto the arc
-                            parent.ReplaceLast(lastInput.Ints[lastInput.Offset + idx - 1], node, nextFinalOutput, isFinal);
+                            parent.ReplaceLast(lastInput.Int32s[lastInput.Offset + idx - 1], node, nextFinalOutput, isFinal);
                             // this node will stay in play for now, since we are
                             // undecided on whether to prune it.  later, it
                             // will be either compiled or pruned, so we must
@@ -425,7 +425,7 @@ namespace Lucene.Net.Util.Fst
             {
                 frontier[pos1].InputCount++;
                 //System.out.println("  incr " + pos1 + " ct=" + frontier[pos1].inputCount + " n=" + frontier[pos1]);
-                if (pos1 >= pos1Stop || lastInput.Ints[pos1] != input.Ints[pos2])
+                if (pos1 >= pos1Stop || lastInput.Int32s[pos1] != input.Int32s[pos2])
                 {
                     break;
                 }
@@ -452,7 +452,7 @@ namespace Lucene.Net.Util.Fst
             // init tail states for current input
             for (int idx = prefixLenPlus1; idx <= input.Length; idx++)
             {
-                frontier[idx - 1].AddArc(input.Ints[input.Offset + idx - 1], frontier[idx]);
+                frontier[idx - 1].AddArc(input.Int32s[input.Offset + idx - 1], frontier[idx]);
                 frontier[idx].InputCount++;
             }
 
@@ -470,7 +470,7 @@ namespace Lucene.Net.Util.Fst
                 UnCompiledNode<T> node = frontier[idx];
                 UnCompiledNode<T> parentNode = frontier[idx - 1];
 
-                T lastOutput = parentNode.GetLastOutput(input.Ints[input.Offset + idx - 1]);
+                T lastOutput = parentNode.GetLastOutput(input.Int32s[input.Offset + idx - 1]);
                 Debug.Assert(ValidOutput(lastOutput));
 
                 T commonOutputPrefix;
@@ -482,7 +482,7 @@ namespace Lucene.Net.Util.Fst
                     Debug.Assert(ValidOutput(commonOutputPrefix));
                     wordSuffix = fst.Outputs.Subtract(lastOutput, commonOutputPrefix);
                     Debug.Assert(ValidOutput(wordSuffix));
-                    parentNode.SetLastOutput(input.Ints[input.Offset + idx - 1], commonOutputPrefix);
+                    parentNode.SetLastOutput(input.Int32s[input.Offset + idx - 1], commonOutputPrefix);
                     node.PrependOutput(wordSuffix);
                 }
                 else
@@ -504,11 +504,11 @@ namespace Lucene.Net.Util.Fst
             {
                 // this new arc is private to this new input; set its
                 // arc output to the leftover output:
-                frontier[prefixLenPlus1 - 1].SetLastOutput(input.Ints[input.Offset + prefixLenPlus1 - 1], output);
+                frontier[prefixLenPlus1 - 1].SetLastOutput(input.Int32s[input.Offset + prefixLenPlus1 - 1], output);
             }
 
             // save last input
-            lastInput.CopyInts(input);
+            lastInput.CopyInt32s(input);
 
             //System.out.println("  count[0]=" + frontier[0].inputCount);
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Util/Fst/ByteSequenceOutputs.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Fst/ByteSequenceOutputs.cs b/src/Lucene.Net.Core/Util/Fst/ByteSequenceOutputs.cs
index f045b67..7f41142 100644
--- a/src/Lucene.Net.Core/Util/Fst/ByteSequenceOutputs.cs
+++ b/src/Lucene.Net.Core/Util/Fst/ByteSequenceOutputs.cs
@@ -134,13 +134,13 @@ namespace Lucene.Net.Util.Fst
         public override void Write(BytesRef prefix, DataOutput @out)
         {
             Debug.Assert(prefix != null);
-            @out.WriteVInt(prefix.Length);
+            @out.WriteVInt32(prefix.Length);
             @out.WriteBytes(prefix.Bytes, prefix.Offset, prefix.Length);
         }
 
         public override BytesRef Read(DataInput @in)
         {
-            int len = @in.ReadVInt();
+            int len = @in.ReadVInt32();
             if (len == 0)
             {
                 return NO_OUTPUT;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Util/Fst/BytesStore.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Fst/BytesStore.cs b/src/Lucene.Net.Core/Util/Fst/BytesStore.cs
index 25e473e..294165f 100644
--- a/src/Lucene.Net.Core/Util/Fst/BytesStore.cs
+++ b/src/Lucene.Net.Core/Util/Fst/BytesStore.cs
@@ -266,9 +266,11 @@ namespace Lucene.Net.Util.Fst
 
         /// <summary>
         /// Writes an int at the absolute position without
-        ///  changing the current pointer.
+        /// changing the current pointer.
+        /// <para/>
+        /// NOTE: This was writeInt() in Lucene
         /// </summary>
-        public virtual void WriteInt(long pos, int value) // LUCENENET TODO: Change to WriteInt32 ?
+        public virtual void WriteInt32(long pos, int value)
         {
             int blockIndex = (int)(pos >> blockBits);
             int upto = (int)(pos & blockMask);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Util/Fst/CharSequenceOutputs.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Fst/CharSequenceOutputs.cs b/src/Lucene.Net.Core/Util/Fst/CharSequenceOutputs.cs
index 017ca94..36e4297 100644
--- a/src/Lucene.Net.Core/Util/Fst/CharSequenceOutputs.cs
+++ b/src/Lucene.Net.Core/Util/Fst/CharSequenceOutputs.cs
@@ -134,17 +134,17 @@ namespace Lucene.Net.Util.Fst
         public override void Write(CharsRef prefix, DataOutput @out)
         {
             Debug.Assert(prefix != null);
-            @out.WriteVInt(prefix.Length);
+            @out.WriteVInt32(prefix.Length);
             // TODO: maybe UTF8?
             for (int idx = 0; idx < prefix.Length; idx++)
             {
-                @out.WriteVInt(prefix.Chars[prefix.Offset + idx]);
+                @out.WriteVInt32(prefix.Chars[prefix.Offset + idx]);
             }
         }
 
         public override CharsRef Read(DataInput @in)
         {
-            int len = @in.ReadVInt();
+            int len = @in.ReadVInt32();
             if (len == 0)
             {
                 return NO_OUTPUT;
@@ -154,7 +154,7 @@ namespace Lucene.Net.Util.Fst
                 CharsRef output = new CharsRef(len);
                 for (int idx = 0; idx < len; idx++)
                 {
-                    output.Chars[idx] = (char)@in.ReadVInt();
+                    output.Chars[idx] = (char)@in.ReadVInt32();
                 }
                 output.Length = len;
                 return output;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Util/Fst/FST.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Fst/FST.cs b/src/Lucene.Net.Core/Util/Fst/FST.cs
index 1f9fc1d..8cc840d 100644
--- a/src/Lucene.Net.Core/Util/Fst/FST.cs
+++ b/src/Lucene.Net.Core/Util/Fst/FST.cs
@@ -251,7 +251,7 @@ namespace Lucene.Net.Util.Fst
                 // accepts empty string
                 // 1 KB blocks:
                 BytesStore emptyBytes = new BytesStore(10);
-                int numBytes = @in.ReadVInt();
+                int numBytes = @in.ReadVInt32();
                 emptyBytes.CopyBytes(@in, numBytes);
 
                 // De-serialize empty-string output:
@@ -303,12 +303,12 @@ namespace Lucene.Net.Util.Fst
             {
                 nodeRefToAddress = null;
             }
-            startNode = @in.ReadVLong();
-            nodeCount = @in.ReadVLong();
-            arcCount = @in.ReadVLong();
-            arcWithOutputCount = @in.ReadVLong();
+            startNode = @in.ReadVInt64();
+            nodeCount = @in.ReadVInt64();
+            arcCount = @in.ReadVInt64();
+            arcWithOutputCount = @in.ReadVInt64();
 
-            long numBytes_ = @in.ReadVLong();
+            long numBytes_ = @in.ReadVInt64();
             bytes = new BytesStore(@in, numBytes_, 1 << maxBlockBits);
 
             NO_OUTPUT = outputs.NoOutput;
@@ -533,7 +533,7 @@ namespace Lucene.Net.Util.Fst
                         upto++;
                     }
                 }
-                @out.WriteVInt(emptyOutputBytes.Length);
+                @out.WriteVInt32(emptyOutputBytes.Length);
                 @out.WriteBytes(emptyOutputBytes, 0, emptyOutputBytes.Length);
             }
             else
@@ -558,12 +558,12 @@ namespace Lucene.Net.Util.Fst
             {
                 ((PackedInts.Mutable)nodeRefToAddress).Save(@out);
             }
-            @out.WriteVLong(startNode);
-            @out.WriteVLong(nodeCount);
-            @out.WriteVLong(arcCount);
-            @out.WriteVLong(arcWithOutputCount);
+            @out.WriteVInt64(startNode);
+            @out.WriteVInt64(nodeCount);
+            @out.WriteVInt64(arcCount);
+            @out.WriteVInt64(arcWithOutputCount);
             long numBytes = bytes.Position;
-            @out.WriteVLong(numBytes);
+            @out.WriteVInt64(numBytes);
             bytes.WriteTo(@out);
         }
 
@@ -604,11 +604,11 @@ namespace Lucene.Net.Util.Fst
             else if (inputType == FST.INPUT_TYPE.BYTE2)
             {
                 Debug.Assert(v <= 65535, "v=" + v);
-                @out.WriteShort((short)v);
+                @out.WriteInt16((short)v);
             }
             else
             {
-                @out.WriteVInt(v);
+                @out.WriteVInt32(v);
             }
         }
 
@@ -623,11 +623,11 @@ namespace Lucene.Net.Util.Fst
             else if (inputType == FST.INPUT_TYPE.BYTE2)
             {
                 // Unsigned short:
-                v = @in.ReadShort() & 0xFFFF;
+                v = @in.ReadInt16() & 0xFFFF;
             }
             else
             {
-                v = @in.ReadVInt();
+                v = @in.ReadVInt32();
             }
             return v;
         }
@@ -748,7 +748,7 @@ namespace Lucene.Net.Util.Fst
                 {
                     Debug.Assert(target.Node > 0);
                     //System.out.println("    write target");
-                    bytes.WriteVLong(target.Node);
+                    bytes.WriteVInt64(target.Node);
                 }
 
                 // just write the arcs "like normal" on first pass,
@@ -797,8 +797,8 @@ namespace Lucene.Net.Util.Fst
                 var bad = new ByteArrayDataOutput(header);
                 // write a "false" first arc:
                 bad.WriteByte((byte)FST.ARCS_AS_FIXED_ARRAY);
-                bad.WriteVInt(nodeIn.NumArcs);
-                bad.WriteVInt(maxBytesPerArc);
+                bad.WriteVInt32(nodeIn.NumArcs);
+                bad.WriteVInt32(maxBytesPerArc);
                 int headerLen = bad.Position;
 
                 long fixedArrayStart = startAddress + headerLen;
@@ -919,14 +919,14 @@ namespace Lucene.Net.Util.Fst
                 if (b == FST.ARCS_AS_FIXED_ARRAY)
                 {
                     // array: jump straight to end
-                    arc.NumArcs = @in.ReadVInt();
+                    arc.NumArcs = @in.ReadVInt32();
                     if (packed || version >= FST.VERSION_VINT_TARGET)
                     {
-                        arc.BytesPerArc = @in.ReadVInt();
+                        arc.BytesPerArc = @in.ReadVInt32();
                     }
                     else
                     {
-                        arc.BytesPerArc = @in.ReadInt();
+                        arc.BytesPerArc = @in.ReadInt32();
                     }
                     //System.out.println("  array numArcs=" + arc.numArcs + " bpa=" + arc.bytesPerArc);
                     arc.PosArcsStart = @in.Position;
@@ -958,7 +958,7 @@ namespace Lucene.Net.Util.Fst
                         }
                         else if (packed)
                         {
-                            @in.ReadVLong();
+                            @in.ReadVInt64();
                         }
                         else
                         {
@@ -981,11 +981,11 @@ namespace Lucene.Net.Util.Fst
             long target;
             if (version < FST.VERSION_VINT_TARGET)
             {
-                target = @in.ReadInt();
+                target = @in.ReadInt32();
             }
             else
             {
-                target = @in.ReadVLong();
+                target = @in.ReadVInt64();
             }
             return target;
         }
@@ -1039,14 +1039,14 @@ namespace Lucene.Net.Util.Fst
             {
                 //System.out.println("  fixedArray");
                 // this is first arc in a fixed-array
-                arc.NumArcs = @in.ReadVInt();
+                arc.NumArcs = @in.ReadVInt32();
                 if (packed || version >= FST.VERSION_VINT_TARGET)
                 {
-                    arc.BytesPerArc = @in.ReadVInt();
+                    arc.BytesPerArc = @in.ReadVInt32();
                 }
                 else
                 {
-                    arc.BytesPerArc = @in.ReadInt();
+                    arc.BytesPerArc = @in.ReadInt32();
                 }
                 arc.ArcIdx = -1;
                 arc.NextArc = arc.PosArcsStart = @in.Position;
@@ -1118,16 +1118,16 @@ namespace Lucene.Net.Util.Fst
                 if (b == FST.ARCS_AS_FIXED_ARRAY)
                 {
                     //System.out.println("    nextArc fixed array");
-                    @in.ReadVInt();
+                    @in.ReadVInt32();
 
                     // Skip bytesPerArc:
                     if (packed || version >= FST.VERSION_VINT_TARGET)
                     {
-                        @in.ReadVInt();
+                        @in.ReadVInt32();
                     }
                     else
                     {
-                        @in.ReadInt();
+                        @in.ReadInt32();
                     }
                 }
                 else
@@ -1245,7 +1245,7 @@ namespace Lucene.Net.Util.Fst
                 if (packed)
                 {
                     long pos = @in.Position;
-                    long code = @in.ReadVLong();
+                    long code = @in.ReadVInt64();
                     if (arc.Flag(FST.BIT_TARGET_DELTA))
                     {
                         // Address is delta-coded from current address:
@@ -1340,14 +1340,14 @@ namespace Lucene.Net.Util.Fst
             if (@in.ReadByte() == FST.ARCS_AS_FIXED_ARRAY)
             {
                 // Arcs are full array; do binary search:
-                arc.NumArcs = @in.ReadVInt();
+                arc.NumArcs = @in.ReadVInt32();
                 if (packed || version >= FST.VERSION_VINT_TARGET)
                 {
-                    arc.BytesPerArc = @in.ReadVInt();
+                    arc.BytesPerArc = @in.ReadVInt32();
                 }
                 else
                 {
-                    arc.BytesPerArc = @in.ReadInt();
+                    arc.BytesPerArc = @in.ReadInt32();
                 }
                 arc.PosArcsStart = @in.Position;
                 int low = 0;
@@ -1429,7 +1429,7 @@ namespace Lucene.Net.Util.Fst
                 {
                     if (packed)
                     {
-                        @in.ReadVLong();
+                        @in.ReadVInt64();
                     }
                     else
                     {
@@ -1812,8 +1812,8 @@ namespace Lucene.Net.Util.Fst
                                 bytesPerArc = arc.BytesPerArc;
                             }
                             writer.WriteByte((byte)FST.ARCS_AS_FIXED_ARRAY);
-                            writer.WriteVInt(arc.NumArcs);
-                            writer.WriteVInt(bytesPerArc);
+                            writer.WriteVInt32(arc.NumArcs);
+                            writer.WriteVInt32(bytesPerArc);
                             //System.out.println("node " + node + ": " + arc.numArcs + " arcs");
                         }
 
@@ -1930,7 +1930,7 @@ namespace Lucene.Net.Util.Fst
                                 if (Flag(flags, FST.BIT_TARGET_DELTA))
                                 {
                                     //System.out.println("        delta");
-                                    writer.WriteVLong(delta);
+                                    writer.WriteVInt64(delta);
                                     if (!retry)
                                     {
                                         deltaCount++;
@@ -1945,7 +1945,7 @@ namespace Lucene.Net.Util.Fst
                                       System.out.println("        abs");
                                     }
                                     */
-                                    writer.WriteVLong(absPtr);
+                                    writer.WriteVInt64(absPtr);
                                     if (!retry)
                                     {
                                         if (absPtr >= topNodeMap.Count)


[46/53] [abbrv] lucenenet git commit: Lucene.Net.TestFramework.Util.ApiScanTestBase.TestForMembersAcceptingOrReturningListOrDictionary: Added functionality to exclude members based on a regex match

Posted by ni...@apache.org.
Lucene.Net.TestFramework.Util.ApiScanTestBase.TestForMembersAcceptingOrReturningListOrDictionary: Added functionality to exclude members based on a regex match


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

Branch: refs/heads/api-work
Commit: 96dd76c02f660bb475ae7e08a649f2518d11c618
Parents: 1200b29
Author: Shad Storhaug <sh...@shadstorhaug.com>
Authored: Wed Feb 8 17:40:26 2017 +0700
Committer: Shad Storhaug <sh...@shadstorhaug.com>
Committed: Wed Feb 8 21:08:25 2017 +0700

----------------------------------------------------------------------
 .../Util/ApiScanTestBase.cs                     | 62 ++++++++++++++++----
 src/Lucene.Net.Tests/core/TestApiConsistency.cs |  2 +-
 2 files changed, 53 insertions(+), 11 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/lucenenet/blob/96dd76c0/src/Lucene.Net.TestFramework/Util/ApiScanTestBase.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.TestFramework/Util/ApiScanTestBase.cs b/src/Lucene.Net.TestFramework/Util/ApiScanTestBase.cs
index 3bbdf7a..fc8b96b 100644
--- a/src/Lucene.Net.TestFramework/Util/ApiScanTestBase.cs
+++ b/src/Lucene.Net.TestFramework/Util/ApiScanTestBase.cs
@@ -332,7 +332,13 @@ namespace Lucene.Net.Util
         //[Test, LuceneNetSpecific]
         public virtual void TestForMembersAcceptingOrReturningIEnumerable(Type typeFromTargetAssembly)
         {
-            var names = GetMembersAcceptingOrReturningType(typeof(IEnumerable<>), typeFromTargetAssembly.Assembly, false);
+            TestForMembersAcceptingOrReturningIEnumerable(typeFromTargetAssembly, null);
+        }
+
+        //[Test, LuceneNetSpecific]
+        public virtual void TestForMembersAcceptingOrReturningIEnumerable(Type typeFromTargetAssembly, string exceptionRegex)
+        {
+            var names = GetMembersAcceptingOrReturningType(typeof(IEnumerable<>), typeFromTargetAssembly.Assembly, false, exceptionRegex);
 
             //if (VERBOSE)
             //{
@@ -348,9 +354,15 @@ namespace Lucene.Net.Util
         //[Test, LuceneNetSpecific]
         public virtual void TestForMembersAcceptingOrReturningListOrDictionary(Type typeFromTargetAssembly)
         {
+            TestForMembersAcceptingOrReturningListOrDictionary(typeFromTargetAssembly, null);
+        }
+
+        //[Test, LuceneNetSpecific]
+        public virtual void TestForMembersAcceptingOrReturningListOrDictionary(Type typeFromTargetAssembly, string exceptionRegex)
+        {
             var names = new List<string>();
-            names.AddRange(GetMembersAcceptingOrReturningType(typeof(List<>), typeFromTargetAssembly.Assembly, true));
-            names.AddRange(GetMembersAcceptingOrReturningType(typeof(Dictionary<,>), typeFromTargetAssembly.Assembly, true));
+            names.AddRange(GetMembersAcceptingOrReturningType(typeof(List<>), typeFromTargetAssembly.Assembly, true, exceptionRegex));
+            names.AddRange(GetMembersAcceptingOrReturningType(typeof(Dictionary<,>), typeFromTargetAssembly.Assembly, true, exceptionRegex));
 
             //if (VERBOSE)
             //{
@@ -389,8 +401,12 @@ namespace Lucene.Net.Util
                     if ((field.IsPrivate || field.IsAssembly) && !PrivateFieldName.IsMatch(field.Name) && field.DeclaringType.Equals(c.UnderlyingSystemType))
                     {
                         var name = string.Concat(c.FullName, ".", field.Name);
-                        bool hasExceptions = !string.IsNullOrWhiteSpace(exceptionRegex);
-                        if (!hasExceptions || (hasExceptions && !Regex.IsMatch(name, exceptionRegex)))
+                        //bool hasExceptions = !string.IsNullOrWhiteSpace(exceptionRegex);
+                        //if (!hasExceptions || (hasExceptions && !Regex.IsMatch(name, exceptionRegex)))
+                        //{
+                        //    result.Add(name);
+                        //}
+                        if (!IsException(name, exceptionRegex))
                         {
                             result.Add(name);
                         }
@@ -929,6 +945,12 @@ namespace Lucene.Net.Util
                 (setMethod != null && !setMethod.IsPrivate));
         }
 
+        private static bool IsException(string name, string exceptionRegex)
+        {
+            bool hasExceptions = !string.IsNullOrWhiteSpace(exceptionRegex);
+            return (hasExceptions && Regex.IsMatch(name, exceptionRegex));
+        }
+
         /// <summary>
         /// Some parameters were incorrectly changed from List to IEnumerable during the port. This is
         /// to track down constructor and method parameters and property and method return types
@@ -936,7 +958,7 @@ namespace Lucene.Net.Util
         /// </summary>
         /// <param name="assembly"></param>
         /// <returns></returns>
-        private static IEnumerable<string> GetMembersAcceptingOrReturningType(Type lookFor, Assembly assembly, bool publiclyVisibleOnly)
+        private static IEnumerable<string> GetMembersAcceptingOrReturningType(Type lookFor, Assembly assembly, bool publiclyVisibleOnly, string exceptionRegex)
         {
             var result = new List<string>();
 
@@ -966,7 +988,12 @@ namespace Lucene.Net.Util
                                     && method.ReturnParameter.ParameterType.IsGenericType
                                     && method.ReturnParameter.ParameterType.GetGenericTypeDefinition().IsAssignableFrom(lookFor))
                                 {
-                                    result.Add(string.Concat(t.FullName, ".", member.Name, "()"));
+                                    var name = string.Concat(t.FullName, ".", member.Name, "()");
+
+                                    if (!IsException(name, exceptionRegex))
+                                    {
+                                        result.Add(name);
+                                    }
                                 }
 
                                 var parameters = method.GetParameters();
@@ -977,7 +1004,12 @@ namespace Lucene.Net.Util
                                         && parameter.ParameterType.GetGenericTypeDefinition().IsAssignableFrom(lookFor)
                                         && member.DeclaringType.Equals(t.UnderlyingSystemType))
                                     {
-                                        result.Add(string.Concat(t.FullName, ".", member.Name, "()", " -parameter- ", parameter.Name));
+                                        var name = string.Concat(t.FullName, ".", member.Name, "()", " -parameter- ", parameter.Name);
+
+                                        if (!IsException(name, exceptionRegex))
+                                        {
+                                            result.Add(name);
+                                        }
                                     }
                                 }
                             }
@@ -996,7 +1028,12 @@ namespace Lucene.Net.Util
                                         && parameter.ParameterType.GetGenericTypeDefinition().IsAssignableFrom(lookFor)
                                         && member.DeclaringType.Equals(t.UnderlyingSystemType))
                                     {
-                                        result.Add(string.Concat(t.FullName, ".", member.Name, "()", " -parameter- ", parameter.Name));
+                                        var name = string.Concat(t.FullName, ".", member.Name, "()", " -parameter- ", parameter.Name);
+
+                                        if (!IsException(name, exceptionRegex))
+                                        {
+                                            result.Add(name);
+                                        }
                                     }
                                 }
                             }
@@ -1006,7 +1043,12 @@ namespace Lucene.Net.Util
                             && ((PropertyInfo)member).PropertyType.GetGenericTypeDefinition().IsAssignableFrom(lookFor)
                             && (!publiclyVisibleOnly || IsNonPrivateProperty((PropertyInfo)member)))
                         {
-                            result.Add(string.Concat(t.FullName, ".", member.Name));
+                            var name = string.Concat(string.Concat(t.FullName, ".", member.Name));
+
+                            if (!IsException(name, exceptionRegex))
+                            {
+                                result.Add(name);
+                            }
                         }
                         //else if (member.MemberType == MemberTypes.Field
                         //    && ((FieldInfo)member).FieldType.IsGenericType

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/96dd76c0/src/Lucene.Net.Tests/core/TestApiConsistency.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/TestApiConsistency.cs b/src/Lucene.Net.Tests/core/TestApiConsistency.cs
index ed6c3e1..f0dde4a 100644
--- a/src/Lucene.Net.Tests/core/TestApiConsistency.cs
+++ b/src/Lucene.Net.Tests/core/TestApiConsistency.cs
@@ -121,7 +121,7 @@ namespace Lucene.Net
         [TestCase(typeof(Lucene.Net.Analysis.Analyzer))]
         public override void TestForMembersAcceptingOrReturningListOrDictionary(Type typeFromTargetAssembly)
         {
-            base.TestForMembersAcceptingOrReturningListOrDictionary(typeFromTargetAssembly);
+            base.TestForMembersAcceptingOrReturningListOrDictionary(typeFromTargetAssembly, @"Support\.Arrays\.AsList");
         }
     }
 }


[08/53] [abbrv] lucenenet git commit: Lucene.Net.Core: Renamed all type-derived properties and methods from Short, Int, Long, and Float to match CLR types Int16, Int32, Int64, and Single, respectively.

Posted by ni...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Index/SegmentInfos.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Index/SegmentInfos.cs b/src/Lucene.Net.Core/Index/SegmentInfos.cs
index 2d97137..4f5700d 100644
--- a/src/Lucene.Net.Core/Index/SegmentInfos.cs
+++ b/src/Lucene.Net.Core/Index/SegmentInfos.cs
@@ -286,9 +286,9 @@ namespace Lucene.Net.Index
                 IndexOutput genOutput = dir.CreateOutput(IndexFileNames.SEGMENTS_GEN, IOContext.READ_ONCE);
                 try
                 {
-                    genOutput.WriteInt(FORMAT_SEGMENTS_GEN_CURRENT);
-                    genOutput.WriteLong(generation);
-                    genOutput.WriteLong(generation);
+                    genOutput.WriteInt32(FORMAT_SEGMENTS_GEN_CURRENT);
+                    genOutput.WriteInt64(generation);
+                    genOutput.WriteInt64(generation);
                     CodecUtil.WriteFooter(genOutput);
                 }
                 finally
@@ -353,15 +353,15 @@ namespace Lucene.Net.Index
             var input = directory.OpenChecksumInput(segmentFileName, IOContext.READ);
             try
             {
-                int format = input.ReadInt();
+                int format = input.ReadInt32();
                 int actualFormat;
                 if (format == CodecUtil.CODEC_MAGIC)
                 {
                     // 4.0+
                     actualFormat = CodecUtil.CheckHeaderNoMagic(input, "segments", VERSION_40, VERSION_48);
-                    Version = input.ReadLong();
-                    Counter = input.ReadInt();
-                    int numSegments = input.ReadInt();
+                    Version = input.ReadInt64();
+                    Counter = input.ReadInt32();
+                    int numSegments = input.ReadInt32();
                     if (numSegments < 0)
                     {
                         throw new CorruptIndexException("invalid segment count: " + numSegments + " (resource: " + input + ")");
@@ -373,8 +373,8 @@ namespace Lucene.Net.Index
                         //System.out.println("SIS.read seg=" + seg + " codec=" + codec);
                         var info = codec.SegmentInfoFormat.SegmentInfoReader.Read(directory, segName, IOContext.READ);
                         info.Codec = codec;
-                        long delGen = input.ReadLong();
-                        int delCount = input.ReadInt();
+                        long delGen = input.ReadInt64();
+                        int delCount = input.ReadInt32();
                         if (delCount < 0 || delCount > info.DocCount)
                         {
                             throw new CorruptIndexException("invalid deletion count: " + delCount + " vs docCount=" + info.DocCount + " (resource: " + input + ")");
@@ -382,12 +382,12 @@ namespace Lucene.Net.Index
                         long fieldInfosGen = -1;
                         if (actualFormat >= VERSION_46)
                         {
-                            fieldInfosGen = input.ReadLong();
+                            fieldInfosGen = input.ReadInt64();
                         }
                         var siPerCommit = new SegmentCommitInfo(info, delCount, delGen, fieldInfosGen);
                         if (actualFormat >= VERSION_46)
                         {
-                            int numGensUpdatesFiles = input.ReadInt();
+                            int numGensUpdatesFiles = input.ReadInt32();
                             IDictionary<long, ISet<string>> genUpdatesFiles;
                             if (numGensUpdatesFiles == 0)
                             {
@@ -398,7 +398,7 @@ namespace Lucene.Net.Index
                                 genUpdatesFiles = new Dictionary<long, ISet<string>>(numGensUpdatesFiles);
                                 for (int i = 0; i < numGensUpdatesFiles; i++)
                                 {
-                                    genUpdatesFiles[input.ReadLong()] = input.ReadStringSet();
+                                    genUpdatesFiles[input.ReadInt64()] = input.ReadStringSet();
                                 }
                             }
                             siPerCommit.SetGenUpdatesFiles(genUpdatesFiles);
@@ -425,7 +425,7 @@ namespace Lucene.Net.Index
                 else
                 {
                     long checksumNow = input.Checksum;
-                    long checksumThen = input.ReadLong();
+                    long checksumThen = input.ReadInt64();
                     if (checksumNow != checksumThen)
                     {
                         throw new CorruptIndexException("checksum mismatch in segments file (resource: " + input + ")");
@@ -511,27 +511,27 @@ namespace Lucene.Net.Index
             {
                 segnOutput = directory.CreateOutput(segmentsFileName, IOContext.DEFAULT);
                 CodecUtil.WriteHeader(segnOutput, "segments", VERSION_48);
-                segnOutput.WriteLong(Version);
-                segnOutput.WriteInt(Counter); // write counter
-                segnOutput.WriteInt(Count); // write infos
+                segnOutput.WriteInt64(Version);
+                segnOutput.WriteInt32(Counter); // write counter
+                segnOutput.WriteInt32(Count); // write infos
                 foreach (SegmentCommitInfo siPerCommit in segments)
                 {
                     SegmentInfo si = siPerCommit.Info;
                     segnOutput.WriteString(si.Name);
                     segnOutput.WriteString(si.Codec.Name);
-                    segnOutput.WriteLong(siPerCommit.DelGen);
+                    segnOutput.WriteInt64(siPerCommit.DelGen);
                     int delCount = siPerCommit.DelCount;
                     if (delCount < 0 || delCount > si.DocCount)
                     {
                         throw new InvalidOperationException("cannot write segment: invalid docCount segment=" + si.Name + " docCount=" + si.DocCount + " delCount=" + delCount);
                     }
-                    segnOutput.WriteInt(delCount);
-                    segnOutput.WriteLong(siPerCommit.FieldInfosGen);
+                    segnOutput.WriteInt32(delCount);
+                    segnOutput.WriteInt64(siPerCommit.FieldInfosGen);
                     IDictionary<long, ISet<string>> genUpdatesFiles = siPerCommit.UpdatesFiles;
-                    segnOutput.WriteInt(genUpdatesFiles.Count);
+                    segnOutput.WriteInt32(genUpdatesFiles.Count);
                     foreach (KeyValuePair<long, ISet<string>> e in genUpdatesFiles)
                     {
-                        segnOutput.WriteLong(e.Key);
+                        segnOutput.WriteInt64(e.Key);
                         segnOutput.WriteStringSet(e.Value);
                     }
                     Debug.Assert(si.Dir == directory);
@@ -659,7 +659,7 @@ namespace Lucene.Net.Index
                 CodecUtil.WriteHeader(output, Lucene3xSegmentInfoFormat.UPGRADED_SI_CODEC_NAME, Lucene3xSegmentInfoFormat.UPGRADED_SI_VERSION_CURRENT);
                 // Write the Lucene version that created this segment, since 3.1
                 output.WriteString(si.Version);
-                output.WriteInt(si.DocCount);
+                output.WriteInt32(si.DocCount);
 
                 output.WriteStringStringMap(si.Attributes);
 
@@ -915,11 +915,11 @@ namespace Lucene.Net.Index
                         {
                             try
                             {
-                                int version = genInput.ReadInt();
+                                int version = genInput.ReadInt32();
                                 if (version == FORMAT_SEGMENTS_GEN_47 || version == FORMAT_SEGMENTS_GEN_CHECKSUM)
                                 {
-                                    long gen0 = genInput.ReadLong();
-                                    long gen1 = genInput.ReadLong();
+                                    long gen0 = genInput.ReadInt64();
+                                    long gen1 = genInput.ReadInt64();
                                     if (infoStream != null)
                                     {
                                         Message("fallback check: " + gen0 + "; " + gen1);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Index/TermVectorsConsumerPerField.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Index/TermVectorsConsumerPerField.cs b/src/Lucene.Net.Core/Index/TermVectorsConsumerPerField.cs
index 1fc4d59..bec57fb 100644
--- a/src/Lucene.Net.Core/Index/TermVectorsConsumerPerField.cs
+++ b/src/Lucene.Net.Core/Index/TermVectorsConsumerPerField.cs
@@ -261,8 +261,8 @@ namespace Lucene.Net.Index
                 int startOffset = fieldState.Offset + offsetAttribute.StartOffset;
                 int endOffset = fieldState.Offset + offsetAttribute.EndOffset;
 
-                termsHashPerField.WriteVInt(1, startOffset - postings.lastOffsets[termID]);
-                termsHashPerField.WriteVInt(1, endOffset - startOffset);
+                termsHashPerField.WriteVInt32(1, startOffset - postings.lastOffsets[termID]);
+                termsHashPerField.WriteVInt32(1, endOffset - startOffset);
                 postings.lastOffsets[termID] = endOffset;
             }
 
@@ -281,14 +281,14 @@ namespace Lucene.Net.Index
                 int pos = fieldState.Position - postings.lastPositions[termID];
                 if (payload != null && payload.Length > 0)
                 {
-                    termsHashPerField.WriteVInt(0, (pos << 1) | 1);
-                    termsHashPerField.WriteVInt(0, payload.Length);
+                    termsHashPerField.WriteVInt32(0, (pos << 1) | 1);
+                    termsHashPerField.WriteVInt32(0, payload.Length);
                     termsHashPerField.WriteBytes(0, payload.Bytes, payload.Offset, payload.Length);
                     hasPayloads = true;
                 }
                 else
                 {
-                    termsHashPerField.WriteVInt(0, pos << 1);
+                    termsHashPerField.WriteVInt32(0, pos << 1);
                 }
                 postings.lastPositions[termID] = fieldState.Position;
             }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Index/TermsHashPerField.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Index/TermsHashPerField.cs b/src/Lucene.Net.Core/Index/TermsHashPerField.cs
index 997e64c..3b451f6 100644
--- a/src/Lucene.Net.Core/Index/TermsHashPerField.cs
+++ b/src/Lucene.Net.Core/Index/TermsHashPerField.cs
@@ -160,7 +160,7 @@ namespace Lucene.Net.Index
                 // First time we are seeing this token since we last
                 // flushed the hash.
                 // Init stream slices
-                if (numPostingInt + intPool.IntUpto > IntBlockPool.INT_BLOCK_SIZE)
+                if (numPostingInt + intPool.Int32Upto > IntBlockPool.INT_BLOCK_SIZE)
                 {
                     intPool.NextBuffer();
                 }
@@ -171,10 +171,10 @@ namespace Lucene.Net.Index
                 }
 
                 intUptos = intPool.Buffer;
-                intUptoStart = intPool.IntUpto;
-                intPool.IntUpto += streamCount;
+                intUptoStart = intPool.Int32Upto;
+                intPool.Int32Upto += streamCount;
 
-                postingsArray.intStarts[termID] = intUptoStart + intPool.IntOffset;
+                postingsArray.intStarts[termID] = intUptoStart + intPool.Int32Offset;
 
                 for (int i = 0; i < streamCount; i++)
                 {
@@ -235,7 +235,7 @@ namespace Lucene.Net.Index
             {
                 bytesHash.ByteStart(termID);
                 // Init stream slices
-                if (numPostingInt + intPool.IntUpto > IntBlockPool.INT_BLOCK_SIZE)
+                if (numPostingInt + intPool.Int32Upto > IntBlockPool.INT_BLOCK_SIZE)
                 {
                     intPool.NextBuffer();
                 }
@@ -246,10 +246,10 @@ namespace Lucene.Net.Index
                 }
 
                 intUptos = intPool.Buffer;
-                intUptoStart = intPool.IntUpto;
-                intPool.IntUpto += streamCount;
+                intUptoStart = intPool.Int32Upto;
+                intPool.Int32Upto += streamCount;
 
-                postingsArray.intStarts[termID] = intUptoStart + intPool.IntOffset;
+                postingsArray.intStarts[termID] = intUptoStart + intPool.Int32Offset;
 
                 for (int i = 0; i < streamCount; i++)
                 {
@@ -310,7 +310,10 @@ namespace Lucene.Net.Index
             }
         }
 
-        internal void WriteVInt(int stream, int i)
+        /// <summary>
+        /// NOTE: This was writeVInt() in Lucene
+        /// </summary>
+        internal void WriteVInt32(int stream, int i)
         {
             Debug.Assert(stream < streamCount);
             while ((i & ~0x7F) != 0)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Search/BooleanQuery.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Search/BooleanQuery.cs b/src/Lucene.Net.Core/Search/BooleanQuery.cs
index 2a5d6a2..7debdff 100644
--- a/src/Lucene.Net.Core/Search/BooleanQuery.cs
+++ b/src/Lucene.Net.Core/Search/BooleanQuery.cs
@@ -675,7 +675,7 @@ namespace Lucene.Net.Search
         /// Returns a hash code value for this object. </summary>
         public override int GetHashCode()
         {
-            return Number.FloatToIntBits(Boost) ^ (clauses.Count == 0 ? 0 : HashHelpers.CombineHashCodes(clauses.First().GetHashCode(), clauses.Last().GetHashCode(), clauses.Count)) + MinimumNumberShouldMatch + (disableCoord ? 17 : 0);
+            return Number.SingleToInt32Bits(Boost) ^ (clauses.Count == 0 ? 0 : HashHelpers.CombineHashCodes(clauses.First().GetHashCode(), clauses.Last().GetHashCode(), clauses.Count)) + MinimumNumberShouldMatch + (disableCoord ? 17 : 0);
         }
     }
 }
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Search/DisjunctionMaxQuery.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Search/DisjunctionMaxQuery.cs b/src/Lucene.Net.Core/Search/DisjunctionMaxQuery.cs
index 8b27c55..69da69e 100644
--- a/src/Lucene.Net.Core/Search/DisjunctionMaxQuery.cs
+++ b/src/Lucene.Net.Core/Search/DisjunctionMaxQuery.cs
@@ -363,8 +363,8 @@ namespace Lucene.Net.Search
         /// <returns> the hash code </returns>
         public override int GetHashCode()
         {
-            return Number.FloatToIntBits(Boost) 
-                + Number.FloatToIntBits(tieBreakerMultiplier) 
+            return Number.SingleToInt32Bits(Boost) 
+                + Number.SingleToInt32Bits(tieBreakerMultiplier) 
                 + disjuncts.GetHashCode();
         }
     }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Search/FieldCache.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Search/FieldCache.cs b/src/Lucene.Net.Core/Search/FieldCache.cs
index d4c36d5..ea165c9 100644
--- a/src/Lucene.Net.Core/Search/FieldCache.cs
+++ b/src/Lucene.Net.Core/Search/FieldCache.cs
@@ -86,7 +86,10 @@ namespace Lucene.Net.Search
         /// Checks the internal cache for an appropriate entry, and if none is
         /// found, reads the terms in <code>field</code> as shorts and returns an array
         /// of size <code>reader.maxDoc()</code> of the value each document
-        /// has in the given field. </summary>
+        /// has in the given field. 
+        /// <para/>
+        /// NOTE: this was getShorts() in Lucene
+        /// </summary>
         /// <param name="reader">  Used to get field values. </param>
         /// <param name="field">   Which field contains the shorts. </param>
         /// <param name="setDocsWithField">  If true then <seealso cref="#getDocsWithField"/> will
@@ -94,14 +97,17 @@ namespace Lucene.Net.Search
         /// <returns> The values in the given field for each document. </returns>
         /// <exception cref="IOException">  If any error occurs. </exception>
         /// @deprecated (4.4) Index as a numeric field using <seealso cref="IntField"/> and then use <seealso cref="#getInts(AtomicReader, String, boolean)"/> instead.
-        [Obsolete("(4.4) Index as a numeric field using IntField and then use GetInt32s(AtomicReader, string, bool) instead.")]
-        FieldCache.Shorts GetShorts(AtomicReader reader, string field, bool setDocsWithField);
+        [Obsolete("(4.4) Index as a numeric field using Int32Field and then use GetInt32s(AtomicReader, string, bool) instead.")]
+        FieldCache.Shorts GetInt16s(AtomicReader reader, string field, bool setDocsWithField);
 
         /// <summary>
         /// Checks the internal cache for an appropriate entry, and if none is found,
         /// reads the terms in <code>field</code> as shorts and returns an array of
         /// size <code>reader.maxDoc()</code> of the value each document has in the
-        /// given field. </summary>
+        /// given field. 
+        /// <para/>
+        /// NOTE: this was getShorts() in Lucene
+        /// </summary>
         /// <param name="reader">  Used to get field values. </param>
         /// <param name="field">   Which field contains the shorts. </param>
         /// <param name="parser">  Computes short for string values. </param>
@@ -110,15 +116,17 @@ namespace Lucene.Net.Search
         /// <returns> The values in the given field for each document. </returns>
         /// <exception cref="IOException">  If any error occurs. </exception>
         /// @deprecated (4.4) Index as a numeric field using <seealso cref="IntField"/> and then use <seealso cref="#getInts(AtomicReader, String, boolean)"/> instead.
-        [Obsolete("(4.4) Index as a numeric field using IntField and then use GetInt32s(AtomicReader, string, bool) instead.")]
-        FieldCache.Shorts GetShorts(AtomicReader reader, string field, FieldCache.IShortParser parser, bool setDocsWithField); // LUCENENET TODO: Rename GetInt16s
+        [Obsolete("(4.4) Index as a numeric field using Int32Field and then use GetInt32s(AtomicReader, string, bool) instead.")]
+        FieldCache.Shorts GetInt16s(AtomicReader reader, string field, FieldCache.IShortParser parser, bool setDocsWithField);
 
         /// <summary>
         /// Returns an <seealso cref="FieldCache.Ints"/> over the values found in documents in the given
         /// field.
+        /// <para/>
+        /// NOTE: this was getInts() in Lucene
         /// </summary>
         /// <seealso cref= #getInts(AtomicReader, String, IntParser, boolean) </seealso>
-        FieldCache.Ints GetInts(AtomicReader reader, string field, bool setDocsWithField); // LUCENENET TODO: Rename GetInt32s
+        FieldCache.Ints GetInt32s(AtomicReader reader, string field, bool setDocsWithField);
 
         /// <summary>
         /// Returns an <seealso cref="FieldCache.Ints"/> over the values found in documents in the given
@@ -128,6 +136,8 @@ namespace Lucene.Net.Search
         /// none is found, reads the terms in <code>field</code> as ints and returns
         /// an array of size <code>reader.maxDoc()</code> of the value each document
         /// has in the given field.
+        /// <para/>
+        /// NOTE: this was getInts() in Lucene
         /// </summary>
         /// <param name="reader">
         ///          Used to get field values. </param>
@@ -143,14 +153,16 @@ namespace Lucene.Net.Search
         /// <returns> The values in the given field for each document. </returns>
         /// <exception cref="IOException">
         ///           If any error occurs. </exception>
-        FieldCache.Ints GetInts(AtomicReader reader, string field, FieldCache.IIntParser parser, bool setDocsWithField); // LUCENENET TODO: Rename GetInt32s
+        FieldCache.Ints GetInt32s(AtomicReader reader, string field, FieldCache.IIntParser parser, bool setDocsWithField);
 
         /// <summary>
         /// Returns a <seealso cref="Floats"/> over the values found in documents in the given
         /// field.
+        /// <para/>
+        /// NOTE: this was getFloats() in Lucene
         /// </summary>
         /// <seealso cref= #getFloats(AtomicReader, String, FloatParser, boolean) </seealso>
-        FieldCache.Floats GetFloats(AtomicReader reader, string field, bool setDocsWithField); // LUCENENET TODO: Rename GetSingles
+        FieldCache.Floats GetSingles(AtomicReader reader, string field, bool setDocsWithField);
 
         /// <summary>
         /// Returns a <seealso cref="Floats"/> over the values found in documents in the given
@@ -160,6 +172,8 @@ namespace Lucene.Net.Search
         /// none is found, reads the terms in <code>field</code> as floats and returns
         /// an array of size <code>reader.maxDoc()</code> of the value each document
         /// has in the given field.
+        /// <para/>
+        /// NOTE: this was getFloats() in Lucene
         /// </summary>
         /// <param name="reader">
         ///          Used to get field values. </param>
@@ -175,14 +189,16 @@ namespace Lucene.Net.Search
         /// <returns> The values in the given field for each document. </returns>
         /// <exception cref="IOException">
         ///           If any error occurs. </exception>
-        FieldCache.Floats GetFloats(AtomicReader reader, string field, FieldCache.IFloatParser parser, bool setDocsWithField); // LUCENENET TODO: Rename GetSingles
+        FieldCache.Floats GetSingles(AtomicReader reader, string field, FieldCache.IFloatParser parser, bool setDocsWithField);
 
         /// <summary>
         /// Returns a <seealso cref="Longs"/> over the values found in documents in the given
         /// field.
+        /// <para/>
+        /// NOTE: this was getLongs() in Lucene
         /// </summary>
         /// <seealso cref= #getLongs(AtomicReader, String, LongParser, boolean) </seealso>
-        FieldCache.Longs GetLongs(AtomicReader reader, string field, bool setDocsWithField); // LUCENENET TODO: Rename GetInt64s
+        FieldCache.Longs GetInt64s(AtomicReader reader, string field, bool setDocsWithField);
 
         /// <summary>
         /// Returns a <seealso cref="Longs"/> over the values found in documents in the given
@@ -192,6 +208,8 @@ namespace Lucene.Net.Search
         /// none is found, reads the terms in <code>field</code> as longs and returns
         /// an array of size <code>reader.maxDoc()</code> of the value each document
         /// has in the given field.
+        /// <para/>
+        /// NOTE: this was getLongs() in Lucene
         /// </summary>
         /// <param name="reader">
         ///          Used to get field values. </param>
@@ -207,7 +225,7 @@ namespace Lucene.Net.Search
         /// <returns> The values in the given field for each document. </returns>
         /// <exception cref="IOException">
         ///           If any error occurs. </exception>
-        FieldCache.Longs GetLongs(AtomicReader reader, string field, FieldCache.ILongParser parser, bool setDocsWithField); // LUCENENET TODO: Rename GetInt64s
+        FieldCache.Longs GetInt64s(AtomicReader reader, string field, FieldCache.ILongParser parser, bool setDocsWithField);
 
         /// <summary>
         /// Returns a <seealso cref="Doubles"/> over the values found in documents in the given
@@ -348,7 +366,7 @@ namespace Lucene.Net.Search
 
     // LUCENENET TODO: Copy documentation from Lucene
 
-    public static class FieldCache
+    public static class FieldCache // LUCENENET TODO: Make this a partial class, so we can use the name FieldCache instead of FieldCacheImpl for the rest
     {
         public abstract class Bytes
         {
@@ -365,13 +383,13 @@ namespace Lucene.Net.Search
             }
         }
 
-        public abstract class Shorts
+        public abstract class Shorts // LUCENENET TODO: Rename Int16s
         {
             public abstract short Get(int docID);
 
             public static readonly Shorts EMPTY = new EmptyShorts();
 
-            public sealed class EmptyShorts : Shorts
+            public sealed class EmptyShorts : Shorts // LUCENENET TODO: Rename EmptyInt16s
             {
                 public override short Get(int docID)
                 {
@@ -380,13 +398,13 @@ namespace Lucene.Net.Search
             }
         }
 
-        public abstract class Ints
+        public abstract class Ints // LUCENENET TODO: Rename Int32s
         {
             public abstract int Get(int docID);
 
             public static readonly Ints EMPTY = new EmptyInts();
 
-            public sealed class EmptyInts : Ints
+            public sealed class EmptyInts : Ints // LUCENENET TODO: Rename EmptyInt32s
             {
                 public override int Get(int docID)
                 {
@@ -395,13 +413,13 @@ namespace Lucene.Net.Search
             }
         }
 
-        public abstract class Longs
+        public abstract class Longs // LUCENENET TODO: Rename Int64s
         {
             public abstract long Get(int docID);
 
             public static readonly Longs EMPTY = new EmptyLongs();
 
-            public sealed class EmptyLongs : Longs
+            public sealed class EmptyLongs : Longs // LUCENENET TODO: Rename EmptyInt64s
             {
                 public override long Get(int docID)
                 {
@@ -410,13 +428,13 @@ namespace Lucene.Net.Search
             }
         }
 
-        public abstract class Floats
+        public abstract class Floats // LUCENENET TODO: Rename Singles
         {
             public abstract float Get(int docID);
 
             public static readonly Floats EMPTY = new EmptyFloats();
 
-            public sealed class EmptyFloats : Floats
+            public sealed class EmptyFloats : Floats // LUCENENET TODO: Rename EmptySingles
             {
                 public override float Get(int docID)
                 {
@@ -455,24 +473,36 @@ namespace Lucene.Net.Search
             sbyte ParseByte(BytesRef term); // LUCENENET TODO: can this be byte?
         }
 
-        public interface IShortParser : IParser
+        public interface IShortParser : IParser // LUCENENET TODO: Rename IInt16Parser
         {
-            short ParseShort(BytesRef term); // LUCENENET TODO: Rename ParseInt16
+            /// <summary>
+            /// NOTE: This was parseShort() in Lucene
+            /// </summary>
+            short ParseInt16(BytesRef term);
         }
 
-        public interface IIntParser : IParser
+        public interface IIntParser : IParser // LUCENENET TODO: Rename IInt32Parser
         {
-            int ParseInt(BytesRef term); // LUCENENET TODO: Rename ParseInt32
+            /// <summary>
+            /// NOTE: This was parseInt() in Lucene
+            /// </summary>
+            int ParseInt32(BytesRef term);
         }
 
-        public interface IFloatParser : IParser
+        public interface IFloatParser : IParser // LUCENENET TODO: Rename ISingleParser
         {
-            float ParseFloat(BytesRef term); // LUCENENET TODO: Rename ParseSingle
+            /// <summary>
+            /// NOTE: This was parseFloat() in Lucene
+            /// </summary>
+            float ParseSingle(BytesRef term);
         }
 
-        public interface ILongParser : IParser
+        public interface ILongParser : IParser // LUCENENET TODO: Rename IInt64Parser
         {
-            long ParseLong(BytesRef term); // LUCENENET TODO: Rename ParseInt64
+            /// <summary>
+            /// NOTE: This was parseLong() in Lucene
+            /// </summary>
+            long ParseInt64(BytesRef term);
         }
 
         public interface IDoubleParser : IParser
@@ -506,11 +536,14 @@ namespace Lucene.Net.Search
             }
         }
 
-        public static readonly IShortParser DEFAULT_SHORT_PARSER = new AnonymousShortParser();
+        public static readonly IShortParser DEFAULT_SHORT_PARSER = new AnonymousShortParser(); // LUCENENET TODO: Rename DEFAULT_INT16_PARSER
 
         private sealed class AnonymousShortParser : IShortParser
         {
-            public short ParseShort(BytesRef term)
+            /// <summary>
+            /// NOTE: This was parseShort() in Lucene
+            /// </summary>
+            public short ParseInt16(BytesRef term)
             {
                 // TODO: would be far better to directly parse from
                 // UTF8 bytes... but really users should use
@@ -521,7 +554,7 @@ namespace Lucene.Net.Search
 
             public override string ToString()
             {
-                return typeof(IFieldCache).FullName + ".DEFAULT_SHORT_PARSER";
+                return typeof(IFieldCache).FullName + ".DEFAULT_SHORT_PARSER"; // LUCENENET TODO: Rename DEFAULT_INT16_PARSER
             }
 
             public TermsEnum TermsEnum(Terms terms)
@@ -530,11 +563,14 @@ namespace Lucene.Net.Search
             }
         }
 
-        public static readonly IIntParser DEFAULT_INT_PARSER = new AnonymousIntParser();
+        public static readonly IIntParser DEFAULT_INT_PARSER = new AnonymousIntParser(); // LUCENENET TODO: Rename DEFAULT_INT32_PARSER
 
         private sealed class AnonymousIntParser : IIntParser
         {
-            public int ParseInt(BytesRef term)
+            /// <summary>
+            /// NOTE: This was parseInt() in Lucene
+            /// </summary>
+            public int ParseInt32(BytesRef term)
             {
                 // TODO: would be far better to directly parse from
                 // UTF8 bytes... but really users should use
@@ -550,15 +586,18 @@ namespace Lucene.Net.Search
 
             public override string ToString()
             {
-                return typeof(IFieldCache).FullName + ".DEFAULT_INT_PARSER";
+                return typeof(IFieldCache).FullName + ".DEFAULT_INT_PARSER"; // LUCENENET TODO: Rename DEFAULT_INT32_PARSER
             }
         }
 
-        public static readonly IFloatParser DEFAULT_FLOAT_PARSER = new AnonymousFloatParser();
+        public static readonly IFloatParser DEFAULT_FLOAT_PARSER = new AnonymousFloatParser();  // LUCENENET TODO: Rename DEFAULT_SINGLE_PARSER
 
         private sealed class AnonymousFloatParser : IFloatParser
         {
-            public float ParseFloat(BytesRef term)
+            /// <summary>
+            /// NOTE: This was parseFloat() in Lucene
+            /// </summary>
+            public float ParseSingle(BytesRef term)
             {
                 // TODO: would be far better to directly parse from
                 // UTF8 bytes... but really users should use
@@ -578,15 +617,18 @@ namespace Lucene.Net.Search
 
             public override string ToString()
             {
-                return typeof(IFieldCache).FullName + ".DEFAULT_FLOAT_PARSER";
+                return typeof(IFieldCache).FullName + ".DEFAULT_FLOAT_PARSER"; // LUCENENET TODO: Rename DEFAULT_SINGLE_PARSER
             }
         }
 
-        public static readonly ILongParser DEFAULT_LONG_PARSER = new AnonymousLongParser();
+        public static readonly ILongParser DEFAULT_LONG_PARSER = new AnonymousLongParser(); // LUCENENET TODO: Rename DEFAULT_INT64_PARSER
 
         private sealed class AnonymousLongParser : ILongParser
         {
-            public long ParseLong(BytesRef term)
+            /// <summary>
+            /// NOTE: This was parseLong() in Lucene
+            /// </summary>
+            public long ParseInt64(BytesRef term)
             {
                 // TODO: would be far better to directly parse from
                 // UTF8 bytes... but really users should use
@@ -602,7 +644,7 @@ namespace Lucene.Net.Search
 
             public override string ToString()
             {
-                return typeof(IFieldCache).FullName + ".DEFAULT_LONG_PARSER";
+                return typeof(IFieldCache).FullName + ".DEFAULT_LONG_PARSER"; // LUCENENET TODO: Rename DEFAULT_INT64_PARSER
             }
         }
 
@@ -634,14 +676,17 @@ namespace Lucene.Net.Search
 
         private sealed class AnonymousNumericUtilsIntParser : IIntParser
         {
-            public int ParseInt(BytesRef term)
+            /// <summary>
+            /// NOTE: This was parseInt() in Lucene
+            /// </summary>
+            public int ParseInt32(BytesRef term)
             {
-                return NumericUtils.PrefixCodedToInt(term);
+                return NumericUtils.PrefixCodedToInt32(term);
             }
 
             public TermsEnum TermsEnum(Terms terms)
             {
-                return NumericUtils.FilterPrefixCodedInts(terms.GetIterator(null));
+                return NumericUtils.FilterPrefixCodedInt32s(terms.GetIterator(null));
             }
 
             public override string ToString()
@@ -654,9 +699,12 @@ namespace Lucene.Net.Search
 
         private sealed class AnonymousNumericUtilsFloatParser : IFloatParser
         {
-            public float ParseFloat(BytesRef term)
+            /// <summary>
+            /// NOTE: This was parseFloat() in Lucene
+            /// </summary>
+            public float ParseSingle(BytesRef term)
             {
-                return NumericUtils.SortableIntToFloat(NumericUtils.PrefixCodedToInt(term));
+                return NumericUtils.SortableInt32ToSingle(NumericUtils.PrefixCodedToInt32(term));
             }
 
             public override string ToString()
@@ -666,7 +714,7 @@ namespace Lucene.Net.Search
 
             public TermsEnum TermsEnum(Terms terms)
             {
-                return NumericUtils.FilterPrefixCodedInts(terms.GetIterator(null));
+                return NumericUtils.FilterPrefixCodedInt32s(terms.GetIterator(null));
             }
         }
 
@@ -674,9 +722,12 @@ namespace Lucene.Net.Search
 
         private sealed class AnonymousNumericUtilsLongParser : ILongParser
         {
-            public long ParseLong(BytesRef term)
+            /// <summary>
+            /// NOTE: This was parseLong() in Lucene
+            /// </summary>
+            public long ParseInt64(BytesRef term)
             {
-                return NumericUtils.PrefixCodedToLong(term);
+                return NumericUtils.PrefixCodedToInt64(term);
             }
 
             public override string ToString()
@@ -686,7 +737,7 @@ namespace Lucene.Net.Search
 
             public TermsEnum TermsEnum(Terms terms)
             {
-                return NumericUtils.FilterPrefixCodedLongs(terms.GetIterator(null));
+                return NumericUtils.FilterPrefixCodedInt64s(terms.GetIterator(null));
             }
         }
 
@@ -696,7 +747,7 @@ namespace Lucene.Net.Search
         {
             public double ParseDouble(BytesRef term)
             {
-                return NumericUtils.SortableLongToDouble(NumericUtils.PrefixCodedToLong(term));
+                return NumericUtils.SortableInt64ToDouble(NumericUtils.PrefixCodedToInt64(term));
             }
 
             public override string ToString()
@@ -706,7 +757,7 @@ namespace Lucene.Net.Search
 
             public TermsEnum TermsEnum(Terms terms)
             {
-                return NumericUtils.FilterPrefixCodedLongs(terms.GetIterator(null));
+                return NumericUtils.FilterPrefixCodedInt64s(terms.GetIterator(null));
             }
         }
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Search/FieldCacheImpl.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Search/FieldCacheImpl.cs b/src/Lucene.Net.Core/Search/FieldCacheImpl.cs
index 455836d..e1e7c21 100644
--- a/src/Lucene.Net.Core/Search/FieldCacheImpl.cs
+++ b/src/Lucene.Net.Core/Search/FieldCacheImpl.cs
@@ -605,13 +605,19 @@ namespace Lucene.Net.Search
         }
 
         // inherit javadocs
-        public virtual FieldCache.Shorts GetShorts(AtomicReader reader, string field, bool setDocsWithField)
+        /// <summary>
+        /// NOTE: this was getShorts() in Lucene
+        /// </summary>
+        public virtual FieldCache.Shorts GetInt16s(AtomicReader reader, string field, bool setDocsWithField)
         {
-            return GetShorts(reader, field, null, setDocsWithField);
+            return GetInt16s(reader, field, null, setDocsWithField);
         }
 
         // inherit javadocs
-        public virtual FieldCache.Shorts GetShorts(AtomicReader reader, string field, FieldCache.IShortParser parser, bool setDocsWithField)
+        /// <summary>
+        /// NOTE: this was getShorts() in Lucene
+        /// </summary>
+        public virtual FieldCache.Shorts GetInt16s(AtomicReader reader, string field, FieldCache.IShortParser parser, bool setDocsWithField)
         {
             NumericDocValues valuesIn = reader.GetNumericDocValues(field);
             if (valuesIn != null)
@@ -689,7 +695,7 @@ namespace Lucene.Net.Search
                     // Confusing: must delegate to wrapper (vs simply
                     // setting parser = DEFAULT_SHORT_PARSER) so cache
                     // key includes DEFAULT_SHORT_PARSER:
-                    return wrapper.GetShorts(reader, key.field, FieldCache.DEFAULT_SHORT_PARSER, setDocsWithField);
+                    return wrapper.GetInt16s(reader, key.field, FieldCache.DEFAULT_SHORT_PARSER, setDocsWithField);
                 }
 
                 values = new short[maxDoc];
@@ -722,7 +728,7 @@ namespace Lucene.Net.Search
 
                 protected override void VisitTerm(BytesRef term)
                 {
-                    currentValue = parser.ParseShort(term);
+                    currentValue = parser.ParseInt16(term);
                 }
 
                 protected override void VisitDoc(int docID)
@@ -738,12 +744,18 @@ namespace Lucene.Net.Search
         }
 
         // inherit javadocs
-        public virtual FieldCache.Ints GetInts(AtomicReader reader, string field, bool setDocsWithField)
+        /// <summary>
+        /// NOTE: this was getInts() in Lucene
+        /// </summary>
+        public virtual FieldCache.Ints GetInt32s(AtomicReader reader, string field, bool setDocsWithField)
         {
-            return GetInts(reader, field, null, setDocsWithField);
+            return GetInt32s(reader, field, null, setDocsWithField);
         }
 
-        public virtual FieldCache.Ints GetInts(AtomicReader reader, string field, FieldCache.IIntParser parser, bool setDocsWithField)
+        /// <summary>
+        /// NOTE: this was getInts() in Lucene
+        /// </summary>
+        public virtual FieldCache.Ints GetInt32s(AtomicReader reader, string field, FieldCache.IIntParser parser, bool setDocsWithField)
         {
             NumericDocValues valuesIn = reader.GetNumericDocValues(field);
             if (valuesIn != null)
@@ -854,11 +866,11 @@ namespace Lucene.Net.Search
                     // DEFAULT_INT_PARSER/NUMERIC_UTILS_INT_PARSER:
                     try
                     {
-                        return wrapper.GetInts(reader, key.field, FieldCache.DEFAULT_INT_PARSER, setDocsWithField);
+                        return wrapper.GetInt32s(reader, key.field, FieldCache.DEFAULT_INT_PARSER, setDocsWithField);
                     }
                     catch (System.FormatException)
                     {
-                        return wrapper.GetInts(reader, key.field, FieldCache.NUMERIC_UTILS_INT_PARSER, setDocsWithField);
+                        return wrapper.GetInt32s(reader, key.field, FieldCache.NUMERIC_UTILS_INT_PARSER, setDocsWithField);
                     }
                 }
 
@@ -902,7 +914,7 @@ namespace Lucene.Net.Search
 
                 protected override void VisitTerm(BytesRef term)
                 {
-                    currentValue = parser.ParseInt(term);
+                    currentValue = parser.ParseInt32(term);
                     if (values == null)
                     {
                         // Lazy alloc so for the numeric field case
@@ -1028,12 +1040,18 @@ namespace Lucene.Net.Search
             }
         }
 
-        public virtual FieldCache.Floats GetFloats(AtomicReader reader, string field, bool setDocsWithField)
+        /// <summary>
+        /// NOTE: this was getFloats() in Lucene
+        /// </summary>
+        public virtual FieldCache.Floats GetSingles(AtomicReader reader, string field, bool setDocsWithField)
         {
-            return GetFloats(reader, field, null, setDocsWithField);
+            return GetSingles(reader, field, null, setDocsWithField);
         }
 
-        public virtual FieldCache.Floats GetFloats(AtomicReader reader, string field, FieldCache.IFloatParser parser, bool setDocsWithField)
+        /// <summary>
+        /// NOTE: this was getFloats() in Lucene
+        /// </summary>
+        public virtual FieldCache.Floats GetSingles(AtomicReader reader, string field, FieldCache.IFloatParser parser, bool setDocsWithField)
         {
             NumericDocValues valuesIn = reader.GetNumericDocValues(field);
             if (valuesIn != null)
@@ -1075,7 +1093,7 @@ namespace Lucene.Net.Search
 
             public override float Get(int docID)
             {
-                return Number.IntBitsToFloat((int)valuesIn.Get(docID));
+                return Number.Int32BitsToSingle((int)valuesIn.Get(docID));
             }
         }
 
@@ -1113,11 +1131,11 @@ namespace Lucene.Net.Search
                     // DEFAULT_FLOAT_PARSER/NUMERIC_UTILS_FLOAT_PARSER:
                     try
                     {
-                        return wrapper.GetFloats(reader, key.field, FieldCache.DEFAULT_FLOAT_PARSER, setDocsWithField);
+                        return wrapper.GetSingles(reader, key.field, FieldCache.DEFAULT_FLOAT_PARSER, setDocsWithField);
                     }
                     catch (System.FormatException)
                     {
-                        return wrapper.GetFloats(reader, key.field, FieldCache.NUMERIC_UTILS_FLOAT_PARSER, setDocsWithField);
+                        return wrapper.GetSingles(reader, key.field, FieldCache.NUMERIC_UTILS_FLOAT_PARSER, setDocsWithField);
                     }
                 }
 
@@ -1161,7 +1179,7 @@ namespace Lucene.Net.Search
 
                 protected override void VisitTerm(BytesRef term)
                 {
-                    currentValue = parser.ParseFloat(term);
+                    currentValue = parser.ParseSingle(term);
                     if (values == null)
                     {
                         // Lazy alloc so for the numeric field case
@@ -1185,12 +1203,18 @@ namespace Lucene.Net.Search
             }
         }
 
-        public virtual FieldCache.Longs GetLongs(AtomicReader reader, string field, bool setDocsWithField)
+        /// <summary>
+        /// NOTE: this was getLongs() in Lucene
+        /// </summary>
+        public virtual FieldCache.Longs GetInt64s(AtomicReader reader, string field, bool setDocsWithField)
         {
-            return GetLongs(reader, field, null, setDocsWithField);
+            return GetInt64s(reader, field, null, setDocsWithField);
         }
 
-        public virtual FieldCache.Longs GetLongs(AtomicReader reader, string field, FieldCache.ILongParser parser, bool setDocsWithField)
+        /// <summary>
+        /// NOTE: this was getLongs() in Lucene
+        /// </summary>
+        public virtual FieldCache.Longs GetInt64s(AtomicReader reader, string field, FieldCache.ILongParser parser, bool setDocsWithField)
         {
             NumericDocValues valuesIn = reader.GetNumericDocValues(field);
             if (valuesIn != null)
@@ -1272,11 +1296,11 @@ namespace Lucene.Net.Search
                     // DEFAULT_LONG_PARSER/NUMERIC_UTILS_LONG_PARSER:
                     try
                     {
-                        return wrapper.GetLongs(reader, key.field, FieldCache.DEFAULT_LONG_PARSER, setDocsWithField);
+                        return wrapper.GetInt64s(reader, key.field, FieldCache.DEFAULT_LONG_PARSER, setDocsWithField);
                     }
                     catch (System.FormatException)
                     {
-                        return wrapper.GetLongs(reader, key.field, FieldCache.NUMERIC_UTILS_LONG_PARSER, setDocsWithField);
+                        return wrapper.GetInt64s(reader, key.field, FieldCache.NUMERIC_UTILS_LONG_PARSER, setDocsWithField);
                     }
                 }
 
@@ -1320,7 +1344,7 @@ namespace Lucene.Net.Search
 
                 protected override void VisitTerm(BytesRef term)
                 {
-                    currentValue = parser.ParseLong(term);
+                    currentValue = parser.ParseInt64(term);
                     if (values == null)
                     {
                         // Lazy alloc so for the numeric field case

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Search/FieldCacheRangeFilter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Search/FieldCacheRangeFilter.cs b/src/Lucene.Net.Core/Search/FieldCacheRangeFilter.cs
index 404f226..b48805e 100644
--- a/src/Lucene.Net.Core/Search/FieldCacheRangeFilter.cs
+++ b/src/Lucene.Net.Core/Search/FieldCacheRangeFilter.cs
@@ -371,7 +371,7 @@ namespace Lucene.Net.Search
                     return null;
 
 #pragma warning disable 612, 618
-                FieldCache.Shorts values = FieldCache.DEFAULT.GetShorts(context.AtomicReader, field, (FieldCache.IShortParser)parser, false);
+                FieldCache.Shorts values = FieldCache.DEFAULT.GetInt16s(context.AtomicReader, field, (FieldCache.IShortParser)parser, false);
 #pragma warning restore 612, 618
 
                 // we only request the usage of termDocs, if the range contains 0
@@ -440,7 +440,7 @@ namespace Lucene.Net.Search
                 if (inclusiveLowerPoint > inclusiveUpperPoint)
                     return null;
 
-                FieldCache.Ints values = FieldCache.DEFAULT.GetInts(context.AtomicReader, field, (FieldCache.IIntParser)parser, false);
+                FieldCache.Ints values = FieldCache.DEFAULT.GetInt32s(context.AtomicReader, field, (FieldCache.IIntParser)parser, false);
                 // we only request the usage of termDocs, if the range contains 0
                 return new AnonymousClassFieldCacheDocIdSet(values, inclusiveLowerPoint, inclusiveUpperPoint, context.Reader.MaxDoc, acceptDocs);
             }
@@ -507,7 +507,7 @@ namespace Lucene.Net.Search
                 if (inclusiveLowerPoint > inclusiveUpperPoint)
                     return null;
 
-                FieldCache.Longs values = FieldCache.DEFAULT.GetLongs(context.AtomicReader, field, (FieldCache.ILongParser)parser, false);
+                FieldCache.Longs values = FieldCache.DEFAULT.GetInt64s(context.AtomicReader, field, (FieldCache.ILongParser)parser, false);
                 // we only request the usage of termDocs, if the range contains 0
                 return new AnonymousClassFieldCacheDocIdSet(values, inclusiveLowerPoint, inclusiveUpperPoint, context.Reader.MaxDoc, acceptDocs);
             }
@@ -555,8 +555,8 @@ namespace Lucene.Net.Search
                     float f = (float)lowerVal;
                     if (!includeUpper && f > 0.0f && float.IsInfinity(f))
                         return null;
-                    int i = NumericUtils.FloatToSortableInt(f);
-                    inclusiveLowerPoint = NumericUtils.SortableIntToFloat(includeLower ? i : (i + 1));
+                    int i = NumericUtils.SingleToSortableInt32(f);
+                    inclusiveLowerPoint = NumericUtils.SortableInt32ToSingle(includeLower ? i : (i + 1));
                 }
                 else
                 {
@@ -567,8 +567,8 @@ namespace Lucene.Net.Search
                     float f = (float)upperVal;
                     if (!includeUpper && f < 0.0f && float.IsInfinity(f))
                         return null;
-                    int i = NumericUtils.FloatToSortableInt(f);
-                    inclusiveUpperPoint = NumericUtils.SortableIntToFloat(includeUpper ? i : (i - 1));
+                    int i = NumericUtils.SingleToSortableInt32(f);
+                    inclusiveUpperPoint = NumericUtils.SortableInt32ToSingle(includeUpper ? i : (i - 1));
                 }
                 else
                 {
@@ -578,7 +578,7 @@ namespace Lucene.Net.Search
                 if (inclusiveLowerPoint > inclusiveUpperPoint)
                     return null;
 
-                FieldCache.Floats values = FieldCache.DEFAULT.GetFloats(context.AtomicReader, field, (FieldCache.IFloatParser)parser, false);
+                FieldCache.Floats values = FieldCache.DEFAULT.GetSingles(context.AtomicReader, field, (FieldCache.IFloatParser)parser, false);
 
                 // we only request the usage of termDocs, if the range contains 0
                 return new AnonymousClassFieldCacheDocIdSet(values, inclusiveLowerPoint, inclusiveUpperPoint, context.Reader.MaxDoc, acceptDocs);
@@ -627,8 +627,8 @@ namespace Lucene.Net.Search
                     double f = (double)lowerVal;
                     if (!includeUpper && f > 0.0 && double.IsInfinity(f))
                         return null;
-                    long i = NumericUtils.DoubleToSortableLong(f);
-                    inclusiveLowerPoint = NumericUtils.SortableLongToDouble(includeLower ? i : (i + 1L));
+                    long i = NumericUtils.DoubleToSortableInt64(f);
+                    inclusiveLowerPoint = NumericUtils.SortableInt64ToDouble(includeLower ? i : (i + 1L));
                 }
                 else
                 {
@@ -639,8 +639,8 @@ namespace Lucene.Net.Search
                     double f = (double)upperVal;
                     if (!includeUpper && f < 0.0 && double.IsInfinity(f))
                         return null;
-                    long i = NumericUtils.DoubleToSortableLong(f);
-                    inclusiveUpperPoint = NumericUtils.SortableLongToDouble(includeUpper ? i : (i - 1L));
+                    long i = NumericUtils.DoubleToSortableInt64(f);
+                    inclusiveUpperPoint = NumericUtils.SortableInt64ToDouble(includeUpper ? i : (i - 1L));
                 }
                 else
                 {
@@ -706,22 +706,24 @@ namespace Lucene.Net.Search
         /// Creates a numeric range filter using <seealso cref="IFieldCache#getShorts(AtomicReader,String,boolean)"/>. this works with all
         /// short fields containing exactly one numeric term in the field. The range can be half-open by setting one
         /// of the values to <code>null</code>.
+        /// <para/>
+        /// NOTE: this was newShortRange() in Lucene
         /// </summary>
-        // LUCENENET TODO: Rename NewInt16Range
         [Obsolete]
-        public static FieldCacheRangeFilter<short?> NewShortRange(string field, short? lowerVal, short? upperVal, bool includeLower, bool includeUpper)
+        public static FieldCacheRangeFilter<short?> NewInt16Range(string field, short? lowerVal, short? upperVal, bool includeLower, bool includeUpper)
         {
-            return NewShortRange(field, null, lowerVal, upperVal, includeLower, includeUpper);
+            return NewInt16Range(field, null, lowerVal, upperVal, includeLower, includeUpper);
         }
 
         /// <summary>
         /// Creates a numeric range filter using <seealso cref="IFieldCache#getShorts(AtomicReader,String,FieldCache.ShortParser,boolean)"/>. this works with all
         /// short fields containing exactly one numeric term in the field. The range can be half-open by setting one
         /// of the values to <code>null</code>.
+        /// <para/>
+        /// NOTE: this was newShortRange() in Lucene
         /// </summary>
-        // LUCENENET TODO: Rename NewInt16Range
         [Obsolete]
-        public static FieldCacheRangeFilter<short?> NewShortRange(string field, FieldCache.IShortParser parser, short? lowerVal, short? upperVal, bool includeLower, bool includeUpper)
+        public static FieldCacheRangeFilter<short?> NewInt16Range(string field, FieldCache.IShortParser parser, short? lowerVal, short? upperVal, bool includeLower, bool includeUpper)
         {
             return new AnonymousShortFieldCacheRangeFilter(field, parser, lowerVal, upperVal, includeLower, includeUpper);
         }
@@ -730,20 +732,22 @@ namespace Lucene.Net.Search
         /// Creates a numeric range filter using <seealso cref="IFieldCache#getInts(AtomicReader,String,boolean)"/>. this works with all
         /// int fields containing exactly one numeric term in the field. The range can be half-open by setting one
         /// of the values to <code>null</code>.
+        /// <para/>
+        /// NOTE: this was newIntRange() in Lucene
         /// </summary>
-        // LUCENENET TODO: Rename NewInt32Range
-        public static FieldCacheRangeFilter<int?> NewIntRange(string field, int? lowerVal, int? upperVal, bool includeLower, bool includeUpper)
+        public static FieldCacheRangeFilter<int?> NewInt32Range(string field, int? lowerVal, int? upperVal, bool includeLower, bool includeUpper)
         {
-            return NewIntRange(field, null, lowerVal, upperVal, includeLower, includeUpper);
+            return NewInt32Range(field, null, lowerVal, upperVal, includeLower, includeUpper);
         }
 
         /// <summary>
         /// Creates a numeric range filter using <seealso cref="IFieldCache#getInts(AtomicReader,String,FieldCache.IntParser,boolean)"/>. this works with all
         /// int fields containing exactly one numeric term in the field. The range can be half-open by setting one
         /// of the values to <code>null</code>.
+        /// <para/>
+        /// NOTE: this was newIntRange() in Lucene
         /// </summary>
-        // LUCENENET TODO: Rename NewInt32Range
-        public static FieldCacheRangeFilter<int?> NewIntRange(string field, FieldCache.IIntParser parser, int? lowerVal, int? upperVal, bool includeLower, bool includeUpper)
+        public static FieldCacheRangeFilter<int?> NewInt32Range(string field, FieldCache.IIntParser parser, int? lowerVal, int? upperVal, bool includeLower, bool includeUpper)
         {
             return new AnonymousIntFieldCacheRangeFilter(field, parser, lowerVal, upperVal, includeLower, includeUpper);
         }
@@ -754,18 +758,19 @@ namespace Lucene.Net.Search
         /// of the values to <code>null</code>.
         /// </summary>
         // LUCENENET TODO: Rename NewInt64Range
-        public static FieldCacheRangeFilter<long?> NewLongRange(string field, long? lowerVal, long? upperVal, bool includeLower, bool includeUpper)
+        public static FieldCacheRangeFilter<long?> NewInt64Range(string field, long? lowerVal, long? upperVal, bool includeLower, bool includeUpper)
         {
-            return NewLongRange(field, null, lowerVal, upperVal, includeLower, includeUpper);
+            return NewInt64Range(field, null, lowerVal, upperVal, includeLower, includeUpper);
         }
 
         /// <summary>
         /// Creates a numeric range filter using <seealso cref="IFieldCache#getLongs(AtomicReader,String,FieldCache.LongParser,boolean)"/>. this works with all
         /// long fields containing exactly one numeric term in the field. The range can be half-open by setting one
         /// of the values to <code>null</code>.
+        /// <para/>
+        /// NOTE: this was newLongRange() in Lucene
         /// </summary>
-        // LUCENENET TODO: Rename NewInt64Range
-        public static FieldCacheRangeFilter<long?> NewLongRange(string field, FieldCache.ILongParser parser, long? lowerVal, long? upperVal, bool includeLower, bool includeUpper)
+        public static FieldCacheRangeFilter<long?> NewInt64Range(string field, FieldCache.ILongParser parser, long? lowerVal, long? upperVal, bool includeLower, bool includeUpper)
         {
             return new AnonymousLongFieldCacheRangeFilter(field, parser, lowerVal, upperVal, includeLower, includeUpper);
         }
@@ -774,20 +779,22 @@ namespace Lucene.Net.Search
         /// Creates a numeric range filter using <seealso cref="IFieldCache#getFloats(AtomicReader,String,boolean)"/>. this works with all
         /// float fields containing exactly one numeric term in the field. The range can be half-open by setting one
         /// of the values to <code>null</code>.
+        /// <para/>
+        /// NOTE: this was newFloatRange() in Lucene
         /// </summary>
-        // LUCENENET TODO: Rename NewSingleRange
-        public static FieldCacheRangeFilter<float?> NewFloatRange(string field, float? lowerVal, float? upperVal, bool includeLower, bool includeUpper)
+        public static FieldCacheRangeFilter<float?> NewSingleRange(string field, float? lowerVal, float? upperVal, bool includeLower, bool includeUpper)
         {
-            return NewFloatRange(field, null, lowerVal, upperVal, includeLower, includeUpper);
+            return NewSingleRange(field, null, lowerVal, upperVal, includeLower, includeUpper);
         }
 
         /// <summary>
         /// Creates a numeric range filter using <seealso cref="IFieldCache#getFloats(AtomicReader,String,FieldCache.FloatParser,boolean)"/>. this works with all
         /// float fields containing exactly one numeric term in the field. The range can be half-open by setting one
         /// of the values to <code>null</code>.
+        /// <para/>
+        /// NOTE: this was newFloatRange() in Lucene
         /// </summary>
-        // LUCENENET TODO: Rename NewSingleRange
-        public static FieldCacheRangeFilter<float?> NewFloatRange(string field, FieldCache.IFloatParser parser, float? lowerVal, float? upperVal, bool includeLower, bool includeUpper)
+        public static FieldCacheRangeFilter<float?> NewSingleRange(string field, FieldCache.IFloatParser parser, float? lowerVal, float? upperVal, bool includeLower, bool includeUpper)
         {
             return new AnonymousFloatFieldCacheRangeFilter(field, parser, lowerVal, upperVal, includeLower, includeUpper);
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Search/FieldComparator.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Search/FieldComparator.cs b/src/Lucene.Net.Core/Search/FieldComparator.cs
index 06e04b3..e4b0026 100644
--- a/src/Lucene.Net.Core/Search/FieldComparator.cs
+++ b/src/Lucene.Net.Core/Search/FieldComparator.cs
@@ -582,7 +582,7 @@ namespace Lucene.Net.Search
             {
                 // NOTE: must do this before calling super otherwise
                 // we compute the docsWithField Bits twice!
-                currentReaderValues = FieldCache.DEFAULT.GetFloats((context.AtomicReader), m_field, parser, m_missingValue != null);
+                currentReaderValues = FieldCache.DEFAULT.GetSingles((context.AtomicReader), m_field, parser, m_missingValue != null);
                 return base.SetNextReader(context);
             }
 
@@ -672,7 +672,7 @@ namespace Lucene.Net.Search
             {
                 // NOTE: must do this before calling super otherwise
                 // we compute the docsWithField Bits twice!
-                currentReaderValues = FieldCache.DEFAULT.GetShorts((context.AtomicReader), m_field, parser, m_missingValue != null);
+                currentReaderValues = FieldCache.DEFAULT.GetInt16s((context.AtomicReader), m_field, parser, m_missingValue != null);
                 return base.SetNextReader(context);
             }
 
@@ -758,7 +758,7 @@ namespace Lucene.Net.Search
             {
                 // NOTE: must do this before calling super otherwise
                 // we compute the docsWithField Bits twice!
-                currentReaderValues = FieldCache.DEFAULT.GetInts((context.AtomicReader), m_field, parser, m_missingValue != null);
+                currentReaderValues = FieldCache.DEFAULT.GetInt32s((context.AtomicReader), m_field, parser, m_missingValue != null);
                 return base.SetNextReader(context);
             }
 
@@ -849,7 +849,7 @@ namespace Lucene.Net.Search
             {
                 // NOTE: must do this before calling super otherwise
                 // we compute the docsWithField Bits twice!
-                currentReaderValues = FieldCache.DEFAULT.GetLongs((context.AtomicReader), m_field, parser, m_missingValue != null);
+                currentReaderValues = FieldCache.DEFAULT.GetInt64s((context.AtomicReader), m_field, parser, m_missingValue != null);
                 return base.SetNextReader(context);
             }
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Search/FuzzyQuery.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Search/FuzzyQuery.cs b/src/Lucene.Net.Core/Search/FuzzyQuery.cs
index 35bbc87..bb39c56 100644
--- a/src/Lucene.Net.Core/Search/FuzzyQuery.cs
+++ b/src/Lucene.Net.Core/Search/FuzzyQuery.cs
@@ -263,13 +263,15 @@ namespace Lucene.Net.Search
         /// <summary>
         /// Helper function to convert from deprecated "minimumSimilarity" fractions
         /// to raw edit distances.
+        /// <para/>
+        /// NOTE: this was floatToEdits() in Lucene
         /// </summary>
         /// <param name="minimumSimilarity"> scaled similarity </param>
         /// <param name="termLen"> length (in unicode codepoints) of the term. </param>
         /// <returns> equivalent number of maxEdits </returns>
         /// @deprecated pass integer edit distances instead.
         [Obsolete("pass integer edit distances instead.")]
-        public static int FloatToEdits(float minimumSimilarity, int termLen)
+        public static int SingleToEdits(float minimumSimilarity, int termLen)
         {
             if (minimumSimilarity >= 1f)
             {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Search/MatchAllDocsQuery.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Search/MatchAllDocsQuery.cs b/src/Lucene.Net.Core/Search/MatchAllDocsQuery.cs
index c664823..b1031f7 100644
--- a/src/Lucene.Net.Core/Search/MatchAllDocsQuery.cs
+++ b/src/Lucene.Net.Core/Search/MatchAllDocsQuery.cs
@@ -177,7 +177,7 @@ namespace Lucene.Net.Search
 
         public override int GetHashCode()
         {
-            return Number.FloatToIntBits(Boost) ^ 0x1AA71190;
+            return Number.SingleToInt32Bits(Boost) ^ 0x1AA71190;
         }
     }
 }
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Search/MultiPhraseQuery.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Search/MultiPhraseQuery.cs b/src/Lucene.Net.Core/Search/MultiPhraseQuery.cs
index f893fe6..7fff3c8 100644
--- a/src/Lucene.Net.Core/Search/MultiPhraseQuery.cs
+++ b/src/Lucene.Net.Core/Search/MultiPhraseQuery.cs
@@ -448,7 +448,7 @@ namespace Lucene.Net.Search
         public override int GetHashCode() // LUCENENET TODO: Check this algorithm - it may not be working correctly
         {
             //If this doesn't work hash all elements of positions. This was used to reduce time overhead
-            return Number.FloatToIntBits(Boost) 
+            return Number.SingleToInt32Bits(Boost) 
                 ^ slop 
                 ^ TermArraysHashCode() 
                 ^ ((positions.Count == 0) ? 0 : HashHelpers.CombineHashCodes(positions.First().GetHashCode(), positions.Last().GetHashCode(), positions.Count) 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Search/MultiTermQuery.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Search/MultiTermQuery.cs b/src/Lucene.Net.Core/Search/MultiTermQuery.cs
index e004169..95556e0 100644
--- a/src/Lucene.Net.Core/Search/MultiTermQuery.cs
+++ b/src/Lucene.Net.Core/Search/MultiTermQuery.cs
@@ -369,7 +369,7 @@ namespace Lucene.Net.Search
         {
             const int prime = 31;
             int result = 1;
-            result = prime * result + Number.FloatToIntBits(Boost);
+            result = prime * result + Number.SingleToInt32Bits(Boost);
             result = prime * result + m_rewriteMethod.GetHashCode();
             if (m_field != null)
             {
@@ -393,7 +393,7 @@ namespace Lucene.Net.Search
                 return false;
             }
             MultiTermQuery other = (MultiTermQuery)obj;
-            if (Number.FloatToIntBits(Boost) != Number.FloatToIntBits(other.Boost))
+            if (Number.SingleToInt32Bits(Boost) != Number.SingleToInt32Bits(other.Boost))
             {
                 return false;
             }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Search/NGramPhraseQuery.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Search/NGramPhraseQuery.cs b/src/Lucene.Net.Core/Search/NGramPhraseQuery.cs
index 38334cf..38d1865 100644
--- a/src/Lucene.Net.Core/Search/NGramPhraseQuery.cs
+++ b/src/Lucene.Net.Core/Search/NGramPhraseQuery.cs
@@ -108,7 +108,7 @@ namespace Lucene.Net.Search
         /// Returns a hash code value for this object. </summary>
         public override int GetHashCode()
         {
-            return Number.FloatToIntBits(Boost) 
+            return Number.SingleToInt32Bits(Boost) 
                 ^ Slop 
                 ^ GetTerms().GetHashCode() 
                 ^ GetPositions().GetHashCode() 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Search/NumericRangeFilter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Search/NumericRangeFilter.cs b/src/Lucene.Net.Core/Search/NumericRangeFilter.cs
index ef927e4..112d163 100644
--- a/src/Lucene.Net.Core/Search/NumericRangeFilter.cs
+++ b/src/Lucene.Net.Core/Search/NumericRangeFilter.cs
@@ -105,11 +105,12 @@ namespace Lucene.Net.Search
         /// You can have half-open ranges (which are in fact &lt;/&lt;= or &gt;/&gt;= queries)
         /// by setting the min or max value to <code>null</code>. By setting inclusive to false, it will
         /// match all documents excluding the bounds, with inclusive on, the boundaries are hits, too.
+        /// <para/>
+        /// NOTE: This was newLongRange() in Lucene
         /// </summary>
-         // LUCENENET TODO: Rename NewInt64Range
-        public static NumericRangeFilter<long> NewLongRange(string field, int precisionStep, long? min, long? max, bool minInclusive, bool maxInclusive)
+        public static NumericRangeFilter<long> NewInt64Range(string field, int precisionStep, long? min, long? max, bool minInclusive, bool maxInclusive)
         {
-            return new NumericRangeFilter<long>(NumericRangeQuery.NewLongRange(field, precisionStep, min, max, minInclusive, maxInclusive));
+            return new NumericRangeFilter<long>(NumericRangeQuery.NewInt64Range(field, precisionStep, min, max, minInclusive, maxInclusive));
         }
 
         /// <summary>
@@ -118,11 +119,12 @@ namespace Lucene.Net.Search
         /// You can have half-open ranges (which are in fact &lt;/&lt;= or &gt;/&gt;= queries)
         /// by setting the min or max value to <code>null</code>. By setting inclusive to false, it will
         /// match all documents excluding the bounds, with inclusive on, the boundaries are hits, too.
+        /// <para/>
+        /// NOTE: This was newLongRange() in Lucene
         /// </summary>
-         // LUCENENET TODO: Rename NewInt64Range
-        public static NumericRangeFilter<long> NewLongRange(string field, long? min, long? max, bool minInclusive, bool maxInclusive)
+        public static NumericRangeFilter<long> NewInt64Range(string field, long? min, long? max, bool minInclusive, bool maxInclusive)
         {
-            return new NumericRangeFilter<long>(NumericRangeQuery.NewLongRange(field, min, max, minInclusive, maxInclusive));
+            return new NumericRangeFilter<long>(NumericRangeQuery.NewInt64Range(field, min, max, minInclusive, maxInclusive));
         }
 
         /// <summary>
@@ -131,11 +133,12 @@ namespace Lucene.Net.Search
         /// You can have half-open ranges (which are in fact &lt;/&lt;= or &gt;/&gt;= queries)
         /// by setting the min or max value to <code>null</code>. By setting inclusive to false, it will
         /// match all documents excluding the bounds, with inclusive on, the boundaries are hits, too.
+        /// <para/>
+        /// NOTE: This was newIntRange() in Lucene
         /// </summary>
-         // LUCENENET TODO: Rename NewInt32Range
-        public static NumericRangeFilter<int> NewIntRange(string field, int precisionStep, int? min, int? max, bool minInclusive, bool maxInclusive)
+        public static NumericRangeFilter<int> NewInt32Range(string field, int precisionStep, int? min, int? max, bool minInclusive, bool maxInclusive)
         {
-            return new NumericRangeFilter<int>(NumericRangeQuery.NewIntRange(field, precisionStep, min, max, minInclusive, maxInclusive));
+            return new NumericRangeFilter<int>(NumericRangeQuery.NewInt32Range(field, precisionStep, min, max, minInclusive, maxInclusive));
         }
 
         /// <summary>
@@ -144,11 +147,12 @@ namespace Lucene.Net.Search
         /// You can have half-open ranges (which are in fact &lt;/&lt;= or &gt;/&gt;= queries)
         /// by setting the min or max value to <code>null</code>. By setting inclusive to false, it will
         /// match all documents excluding the bounds, with inclusive on, the boundaries are hits, too.
+        /// <para/>
+        /// NOTE: This was newIntRange() in Lucene
         /// </summary>
-         // LUCENENET TODO: Rename NewInt32Range
-        public static NumericRangeFilter<int> NewIntRange(string field, int? min, int? max, bool minInclusive, bool maxInclusive)
+        public static NumericRangeFilter<int> NewInt32Range(string field, int? min, int? max, bool minInclusive, bool maxInclusive)
         {
-            return new NumericRangeFilter<int>(NumericRangeQuery.NewIntRange(field, min, max, minInclusive, maxInclusive));
+            return new NumericRangeFilter<int>(NumericRangeQuery.NewInt32Range(field, min, max, minInclusive, maxInclusive));
         }
 
         /// <summary>
@@ -187,11 +191,12 @@ namespace Lucene.Net.Search
         /// <seealso cref="Float#NaN"/> will never match a half-open range, to hit {@code NaN} use a query
         /// with {@code min == max == Float.NaN}. By setting inclusive to false, it will
         /// match all documents excluding the bounds, with inclusive on, the boundaries are hits, too.
+        /// <para/>
+        /// NOTE: This was newFloatRange() in Lucene
         /// </summary>
-         // LUCENENET TODO: Rename NewSingleRange
-        public static NumericRangeFilter<float> NewFloatRange(string field, int precisionStep, float? min, float? max, bool minInclusive, bool maxInclusive)
+        public static NumericRangeFilter<float> NewSingleRange(string field, int precisionStep, float? min, float? max, bool minInclusive, bool maxInclusive)
         {
-            return new NumericRangeFilter<float>(NumericRangeQuery.NewFloatRange(field, precisionStep, min, max, minInclusive, maxInclusive));
+            return new NumericRangeFilter<float>(NumericRangeQuery.NewSingleRange(field, precisionStep, min, max, minInclusive, maxInclusive));
         }
 
         /// <summary>
@@ -202,11 +207,12 @@ namespace Lucene.Net.Search
         /// <seealso cref="Float#NaN"/> will never match a half-open range, to hit {@code NaN} use a query
         /// with {@code min == max == Float.NaN}. By setting inclusive to false, it will
         /// match all documents excluding the bounds, with inclusive on, the boundaries are hits, too.
+        /// <para/>
+        /// NOTE: This was newFloatRange() in Lucene
         /// </summary>
-         // LUCENENET TODO: Rename NewSingleRange
-        public static NumericRangeFilter<float> NewFloatRange(string field, float? min, float? max, bool minInclusive, bool maxInclusive)
+        public static NumericRangeFilter<float> NewSingleRange(string field, float? min, float? max, bool minInclusive, bool maxInclusive)
         {
-            return new NumericRangeFilter<float>(NumericRangeQuery.NewFloatRange(field, min, max, minInclusive, maxInclusive));
+            return new NumericRangeFilter<float>(NumericRangeQuery.NewSingleRange(field, min, max, minInclusive, maxInclusive));
         }
     }
 }
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Search/NumericRangeQuery.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Search/NumericRangeQuery.cs b/src/Lucene.Net.Core/Search/NumericRangeQuery.cs
index 7c17a5f..003078f 100644
--- a/src/Lucene.Net.Core/Search/NumericRangeQuery.cs
+++ b/src/Lucene.Net.Core/Search/NumericRangeQuery.cs
@@ -287,11 +287,11 @@ namespace Lucene.Net.Search
         internal readonly bool minInclusive, maxInclusive;
 
         // used to handle float/double infinity correcty
-        internal static readonly long LONG_NEGATIVE_INFINITY = NumericUtils.DoubleToSortableLong(double.NegativeInfinity);
+        internal static readonly long LONG_NEGATIVE_INFINITY = NumericUtils.DoubleToSortableInt64(double.NegativeInfinity);
 
-        internal static readonly long LONG_POSITIVE_INFINITY = NumericUtils.DoubleToSortableLong(double.PositiveInfinity);
-        internal static readonly int INT_NEGATIVE_INFINITY = NumericUtils.FloatToSortableInt(float.NegativeInfinity);
-        internal static readonly int INT_POSITIVE_INFINITY = NumericUtils.FloatToSortableInt(float.PositiveInfinity);
+        internal static readonly long LONG_POSITIVE_INFINITY = NumericUtils.DoubleToSortableInt64(double.PositiveInfinity);
+        internal static readonly int INT_NEGATIVE_INFINITY = NumericUtils.SingleToSortableInt32(float.NegativeInfinity);
+        internal static readonly int INT_POSITIVE_INFINITY = NumericUtils.SingleToSortableInt32(float.PositiveInfinity);
 
         /// <summary>
         /// Subclass of FilteredTermsEnum for enumerating all terms that match the
@@ -330,7 +330,7 @@ namespace Lucene.Net.Search
                             else
                             {
                                 Debug.Assert(this.outerInstance.dataType == NumericType.DOUBLE);
-                                minBound = (this.outerInstance.min == null) ? LONG_NEGATIVE_INFINITY : NumericUtils.DoubleToSortableLong(Convert.ToDouble(this.outerInstance.min.Value));
+                                minBound = (this.outerInstance.min == null) ? LONG_NEGATIVE_INFINITY : NumericUtils.DoubleToSortableInt64(Convert.ToDouble(this.outerInstance.min.Value));
                             }
                             if (!this.outerInstance.minInclusive && this.outerInstance.min != null)
                             {
@@ -350,7 +350,7 @@ namespace Lucene.Net.Search
                             else
                             {
                                 Debug.Assert(this.outerInstance.dataType == NumericType.DOUBLE);
-                                maxBound = (this.outerInstance.max == null) ? LONG_POSITIVE_INFINITY : NumericUtils.DoubleToSortableLong(Convert.ToDouble(this.outerInstance.max));
+                                maxBound = (this.outerInstance.max == null) ? LONG_POSITIVE_INFINITY : NumericUtils.DoubleToSortableInt64(Convert.ToDouble(this.outerInstance.max));
                             }
                             if (!this.outerInstance.maxInclusive && this.outerInstance.max != null)
                             {
@@ -361,7 +361,7 @@ namespace Lucene.Net.Search
                                 maxBound--;
                             }
 
-                            NumericUtils.SplitLongRange(new LongRangeBuilderAnonymousInnerClassHelper(this), this.outerInstance.precisionStep, minBound, maxBound);
+                            NumericUtils.SplitInt64Range(new LongRangeBuilderAnonymousInnerClassHelper(this), this.outerInstance.precisionStep, minBound, maxBound);
                             break;
                         }
 
@@ -377,7 +377,7 @@ namespace Lucene.Net.Search
                             else
                             {
                                 Debug.Assert(this.outerInstance.dataType == NumericType.FLOAT);
-                                minBound = (this.outerInstance.min == null) ? INT_NEGATIVE_INFINITY : NumericUtils.FloatToSortableInt(Convert.ToSingle(this.outerInstance.min));
+                                minBound = (this.outerInstance.min == null) ? INT_NEGATIVE_INFINITY : NumericUtils.SingleToSortableInt32(Convert.ToSingle(this.outerInstance.min));
                             }
                             if (!this.outerInstance.minInclusive && this.outerInstance.min != null)
                             {
@@ -397,7 +397,7 @@ namespace Lucene.Net.Search
                             else
                             {
                                 Debug.Assert(this.outerInstance.dataType == NumericType.FLOAT);
-                                maxBound = (this.outerInstance.max == null) ? INT_POSITIVE_INFINITY : NumericUtils.FloatToSortableInt(Convert.ToSingle(this.outerInstance.max));
+                                maxBound = (this.outerInstance.max == null) ? INT_POSITIVE_INFINITY : NumericUtils.SingleToSortableInt32(Convert.ToSingle(this.outerInstance.max));
                             }
                             if (!this.outerInstance.maxInclusive && this.outerInstance.max != null)
                             {
@@ -408,7 +408,7 @@ namespace Lucene.Net.Search
                                 maxBound--;
                             }
 
-                            NumericUtils.SplitIntRange(new IntRangeBuilderAnonymousInnerClassHelper(this), this.outerInstance.precisionStep, minBound, maxBound);
+                            NumericUtils.SplitInt32Range(new IntRangeBuilderAnonymousInnerClassHelper(this), this.outerInstance.precisionStep, minBound, maxBound);
                             break;
                         }
 
@@ -514,9 +514,10 @@ namespace Lucene.Net.Search
         /// You can have half-open ranges (which are in fact &lt;/&lt;= or &gt;/&gt;= queries)
         /// by setting the min or max value to <code>null</code>. By setting inclusive to false, it will
         /// match all documents excluding the bounds, with inclusive on, the boundaries are hits, too.
+        /// <para/>
+        /// NOTE: This was newLongRange() in Lucene
         /// </summary>
-         // LUCENENET TODO: Rename NewInt64Range
-        public static NumericRangeQuery<long> NewLongRange(string field, int precisionStep, long? min, long? max, bool minInclusive, bool maxInclusive)
+        public static NumericRangeQuery<long> NewInt64Range(string field, int precisionStep, long? min, long? max, bool minInclusive, bool maxInclusive)
         {
             return new NumericRangeQuery<long>(field, precisionStep, NumericType.LONG, min, max, minInclusive, maxInclusive);
         }
@@ -527,9 +528,10 @@ namespace Lucene.Net.Search
         /// You can have half-open ranges (which are in fact &lt;/&lt;= or &gt;/&gt;= queries)
         /// by setting the min or max value to <code>null</code>. By setting inclusive to false, it will
         /// match all documents excluding the bounds, with inclusive on, the boundaries are hits, too.
+        /// <para/>
+        /// NOTE: This was newLongRange() in Lucene
         /// </summary>
-         // LUCENENET TODO: Rename NewInt64Range
-        public static NumericRangeQuery<long> NewLongRange(string field, long? min, long? max, bool minInclusive, bool maxInclusive)
+        public static NumericRangeQuery<long> NewInt64Range(string field, long? min, long? max, bool minInclusive, bool maxInclusive)
         {
             return new NumericRangeQuery<long>(field, NumericUtils.PRECISION_STEP_DEFAULT, NumericType.LONG, min, max, minInclusive, maxInclusive);
         }
@@ -540,9 +542,10 @@ namespace Lucene.Net.Search
         /// You can have half-open ranges (which are in fact &lt;/&lt;= or &gt;/&gt;= queries)
         /// by setting the min or max value to <code>null</code>. By setting inclusive to false, it will
         /// match all documents excluding the bounds, with inclusive on, the boundaries are hits, too.
+        /// <para/>
+        /// NOTE: This was newIntRange() in Lucene
         /// </summary>
-         // LUCENENET TODO: Rename NewInt32Range
-        public static NumericRangeQuery<int> NewIntRange(string field, int precisionStep, int? min, int? max, bool minInclusive, bool maxInclusive)
+        public static NumericRangeQuery<int> NewInt32Range(string field, int precisionStep, int? min, int? max, bool minInclusive, bool maxInclusive)
         {
             return new NumericRangeQuery<int>(field, precisionStep, NumericType.INT, min, max, minInclusive, maxInclusive);
         }
@@ -553,9 +556,10 @@ namespace Lucene.Net.Search
         /// You can have half-open ranges (which are in fact &lt;/&lt;= or &gt;/&gt;= queries)
         /// by setting the min or max value to <code>null</code>. By setting inclusive to false, it will
         /// match all documents excluding the bounds, with inclusive on, the boundaries are hits, too.
+        /// <para/>
+        /// NOTE: This was newIntRange() in Lucene
         /// </summary>
-         // LUCENENET TODO: Rename NewInt32Range
-        public static NumericRangeQuery<int> NewIntRange(string field, int? min, int? max, bool minInclusive, bool maxInclusive)
+        public static NumericRangeQuery<int> NewInt32Range(string field, int? min, int? max, bool minInclusive, bool maxInclusive)
         {
             return new NumericRangeQuery<int>(field, NumericUtils.PRECISION_STEP_DEFAULT, NumericType.INT, min, max, minInclusive, maxInclusive);
         }
@@ -596,9 +600,10 @@ namespace Lucene.Net.Search
         /// <seealso cref="Float#NaN"/> will never match a half-open range, to hit {@code NaN} use a query
         /// with {@code min == max == Float.NaN}.  By setting inclusive to false, it will
         /// match all documents excluding the bounds, with inclusive on, the boundaries are hits, too.
+        /// <para/>
+        /// NOTE: This was newFloatRange() in Lucene
         /// </summary>
-         // LUCENENET TODO: Rename NewSingleRange
-        public static NumericRangeQuery<float> NewFloatRange(string field, int precisionStep, float? min, float? max, bool minInclusive, bool maxInclusive)
+        public static NumericRangeQuery<float> NewSingleRange(string field, int precisionStep, float? min, float? max, bool minInclusive, bool maxInclusive)
         {
             return new NumericRangeQuery<float>(field, precisionStep, NumericType.FLOAT, min, max, minInclusive, maxInclusive);
         }
@@ -611,9 +616,10 @@ namespace Lucene.Net.Search
         /// <seealso cref="Float#NaN"/> will never match a half-open range, to hit {@code NaN} use a query
         /// with {@code min == max == Float.NaN}.  By setting inclusive to false, it will
         /// match all documents excluding the bounds, with inclusive on, the boundaries are hits, too.
+        /// <para/>
+        /// NOTE: This was newFloatRange() in Lucene
         /// </summary>
-         // LUCENENET TODO: Rename NewSingleRange
-        public static NumericRangeQuery<float> NewFloatRange(string field, float? min, float? max, bool minInclusive, bool maxInclusive)
+        public static NumericRangeQuery<float> NewSingleRange(string field, float? min, float? max, bool minInclusive, bool maxInclusive)
         {
             return new NumericRangeQuery<float>(field, NumericUtils.PRECISION_STEP_DEFAULT, NumericType.FLOAT, min, max, minInclusive, maxInclusive);
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Search/PhraseQuery.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Search/PhraseQuery.cs b/src/Lucene.Net.Core/Search/PhraseQuery.cs
index 10d660b..e8ab3c4 100644
--- a/src/Lucene.Net.Core/Search/PhraseQuery.cs
+++ b/src/Lucene.Net.Core/Search/PhraseQuery.cs
@@ -509,7 +509,7 @@ namespace Lucene.Net.Search
         /// Returns a hash code value for this object. </summary>
         public override int GetHashCode()
         {
-            return Number.FloatToIntBits(Boost) 
+            return Number.SingleToInt32Bits(Boost) 
                 ^ slop 
                 ^ terms.GetHashCode() 
                 ^ positions.GetHashCode();

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Search/Query.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Search/Query.cs b/src/Lucene.Net.Core/Search/Query.cs
index 2ea4d2b..67860e5 100644
--- a/src/Lucene.Net.Core/Search/Query.cs
+++ b/src/Lucene.Net.Core/Search/Query.cs
@@ -126,7 +126,7 @@ namespace Lucene.Net.Search
         {
             const int prime = 31;
             int result = 1;
-            result = prime * result + Number.FloatToIntBits(Boost);
+            result = prime * result + Number.SingleToInt32Bits(Boost);
             return result;
         }
 
@@ -149,7 +149,7 @@ namespace Lucene.Net.Search
 
             var other = obj as Query;
 
-            if (Number.FloatToIntBits(Boost) != Number.FloatToIntBits(other.Boost))
+            if (Number.SingleToInt32Bits(Boost) != Number.SingleToInt32Bits(other.Boost))
             {
                 return false;
             }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Search/Similarities/BM25Similarity.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Search/Similarities/BM25Similarity.cs b/src/Lucene.Net.Core/Search/Similarities/BM25Similarity.cs
index 310e637..2f363d8 100644
--- a/src/Lucene.Net.Core/Search/Similarities/BM25Similarity.cs
+++ b/src/Lucene.Net.Core/Search/Similarities/BM25Similarity.cs
@@ -108,7 +108,7 @@ namespace Lucene.Net.Search.Similarities
         /// </summary>
         protected internal virtual sbyte EncodeNormValue(float boost, int fieldLength) // LUCENENET TODO: Can we use byte?
         {
-            return SmallFloat.FloatToByte315(boost / (float)Math.Sqrt(fieldLength));
+            return SmallFloat.SingleToByte315(boost / (float)Math.Sqrt(fieldLength));
         }
 
         /// <summary>
@@ -151,7 +151,7 @@ namespace Lucene.Net.Search.Similarities
         {
             for (int i = 0; i < 256; i++)
             {
-                float f = SmallFloat.Byte315ToFloat((sbyte)i);
+                float f = SmallFloat.Byte315ToSingle((sbyte)i);
                 NORM_TABLE[i] = 1.0f / (f * f);
             }
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Search/Similarities/DefaultSimilarity.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Search/Similarities/DefaultSimilarity.cs b/src/Lucene.Net.Core/Search/Similarities/DefaultSimilarity.cs
index 3d139e5..2ea6e9a 100644
--- a/src/Lucene.Net.Core/Search/Similarities/DefaultSimilarity.cs
+++ b/src/Lucene.Net.Core/Search/Similarities/DefaultSimilarity.cs
@@ -54,7 +54,7 @@ namespace Lucene.Net.Search.Similarities
         {
             for (int i = 0; i < 256; i++)
             {
-                NORM_TABLE[i] = SmallFloat.Byte315ToFloat((sbyte)i);
+                NORM_TABLE[i] = SmallFloat.Byte315ToSingle((sbyte)i);
             }
         }
 
@@ -93,7 +93,7 @@ namespace Lucene.Net.Search.Similarities
         /// <seealso cref= Lucene.Net.Util.SmallFloat </seealso>
         public override sealed long EncodeNormValue(float f)
         {
-            return SmallFloat.FloatToByte315(f);
+            return SmallFloat.SingleToByte315(f);
         }
 
         /// <summary>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Search/Similarities/SimilarityBase.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Search/Similarities/SimilarityBase.cs b/src/Lucene.Net.Core/Search/Similarities/SimilarityBase.cs
index d880b6d..9337174 100644
--- a/src/Lucene.Net.Core/Search/Similarities/SimilarityBase.cs
+++ b/src/Lucene.Net.Core/Search/Similarities/SimilarityBase.cs
@@ -235,7 +235,7 @@ namespace Lucene.Net.Search.Similarities
         {
             for (int i = 0; i < 256; i++)
             {
-                float floatNorm = SmallFloat.Byte315ToFloat((sbyte)i);
+                float floatNorm = SmallFloat.Byte315ToSingle((sbyte)i);
                 NORM_TABLE[i] = 1.0f / (floatNorm * floatNorm);
             }
         }
@@ -268,7 +268,7 @@ namespace Lucene.Net.Search.Similarities
         /// Encodes the length to a byte via SmallFloat. </summary>
         protected internal virtual sbyte EncodeNormValue(float boost, float length) // LUCENENET TODO: Can this be byte?
         {
-            return SmallFloat.FloatToByte315((boost / (float)Math.Sqrt(length)));
+            return SmallFloat.SingleToByte315((boost / (float)Math.Sqrt(length)));
         }
 
         // ----------------------------- Static methods ------------------------------


[12/53] [abbrv] lucenenet git commit: Lucene.Net.Core: Renamed all type-derived properties and methods from Short, Int, Long, and Float to match CLR types Int16, Int32, Int64, and Single, respectively.

Posted by ni...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/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
index 627c3d0..0068143 100644
--- a/src/Lucene.Net.Codecs/Memory/FSTOrdTermsReader.cs
+++ b/src/Lucene.Net.Codecs/Memory/FSTOrdTermsReader.cs
@@ -69,16 +69,16 @@ namespace Lucene.Net.Codecs.Memory
                 SeekDir(blockIn);
 
                 FieldInfos fieldInfos = state.FieldInfos;
-                int numFields = blockIn.ReadVInt();
+                int numFields = blockIn.ReadVInt32();
                 for (int i = 0; i < numFields; i++)
                 {
-                    FieldInfo fieldInfo = fieldInfos.FieldInfo(blockIn.ReadVInt());
+                    FieldInfo fieldInfo = fieldInfos.FieldInfo(blockIn.ReadVInt32());
                     bool hasFreq = fieldInfo.IndexOptions != 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();
+                    long numTerms = blockIn.ReadVInt64();
+                    long sumTotalTermFreq = hasFreq ? blockIn.ReadVInt64() : -1;
+                    long sumDocFreq = blockIn.ReadVInt64();
+                    int docCount = blockIn.ReadVInt32();
+                    int longsSize = blockIn.ReadVInt32();
                     var index = new FST<long?>(indexIn, PositiveIntOutputs.Singleton);
 
                     var current = new TermsReader(this, fieldInfo, blockIn, numTerms, sumTotalTermFreq, sumDocFreq, docCount, longsSize, index);
@@ -129,7 +129,7 @@ namespace Lucene.Net.Codecs.Memory
             {
                 @in.Seek(@in.Length - 8);
             }
-            @in.Seek(@in.ReadLong());
+            @in.Seek(@in.ReadInt64());
         }
 
         private void CheckFieldSummary(SegmentInfo info, IndexInput indexIn, IndexInput blockIn, TermsReader field, TermsReader previous)
@@ -221,9 +221,9 @@ namespace Lucene.Net.Codecs.Memory
                 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()];
+                this.statsBlock = new byte[(int)blockIn.ReadVInt64()];
+                this.metaLongsBlock = new byte[(int)blockIn.ReadVInt64()];
+                this.metaBytesBlock = new byte[(int)blockIn.ReadVInt64()];
 
                 int last = 0, next = 0;
                 for (int i = 1; i < numBlocks; i++)
@@ -231,7 +231,7 @@ namespace Lucene.Net.Codecs.Memory
                     next = numSkipInfo * i;
                     for (int j = 0; j < numSkipInfo; j++)
                     {
-                        skipInfo[next + j] = skipInfo[last + j] + blockIn.ReadVLong();
+                        skipInfo[next + j] = skipInfo[last + j] + blockIn.ReadVInt64();
                     }
                     last = next;
                 }
@@ -408,7 +408,7 @@ namespace Lucene.Net.Codecs.Memory
                     statsReader.Position = statsFP;
                     for (int i = 0; i < INTERVAL && !statsReader.Eof; i++)
                     {
-                        int code = statsReader.ReadVInt();
+                        int code = statsReader.ReadVInt32();
                         if (outerInstance.HasFreqs)
                         {
                             docFreq_Renamed[i] = ((int)((uint)code >> 1));
@@ -418,7 +418,7 @@ namespace Lucene.Net.Codecs.Memory
                             }
                             else
                             {
-                                totalTermFreq_Renamed[i] = docFreq_Renamed[i] + statsReader.ReadVLong();
+                                totalTermFreq_Renamed[i] = docFreq_Renamed[i] + statsReader.ReadVInt64();
                             }
                         }
                         else
@@ -438,18 +438,18 @@ namespace Lucene.Net.Codecs.Memory
                     metaLongsReader.Position = metaLongsFP;
                     for (int j = 0; j < outerInstance.longsSize; j++)
                     {
-                        longs[0][j] = outerInstance.skipInfo[offset + 3 + j] + metaLongsReader.ReadVLong();
+                        longs[0][j] = outerInstance.skipInfo[offset + 3 + j] + metaLongsReader.ReadVInt64();
                     }
                     bytesStart[0] = metaBytesFP;
-                    bytesLength[0] = (int)metaLongsReader.ReadVLong();
+                    bytesLength[0] = (int)metaLongsReader.ReadVInt64();
                     for (int i = 1; i < INTERVAL && !metaLongsReader.Eof; i++)
                     {
                         for (int j = 0; j < outerInstance.longsSize; j++)
                         {
-                            longs[i][j] = longs[i - 1][j] + metaLongsReader.ReadVLong();
+                            longs[i][j] = longs[i - 1][j] + metaLongsReader.ReadVInt64();
                         }
                         bytesStart[i] = bytesStart[i - 1] + bytesLength[i - 1];
-                        bytesLength[i] = (int)metaLongsReader.ReadVLong();
+                        bytesLength[i] = (int)metaLongsReader.ReadVInt64();
                     }
                 }
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/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
index 9299b55..6c8a3d9 100644
--- a/src/Lucene.Net.Codecs/Memory/FSTOrdTermsWriter.cs
+++ b/src/Lucene.Net.Codecs/Memory/FSTOrdTermsWriter.cs
@@ -195,21 +195,21 @@ namespace Lucene.Net.Codecs.Memory
                 var blockDirStart = blockOut.FilePointer;
 
                 // write field summary
-                blockOut.WriteVInt(_fields.Count);
+                blockOut.WriteVInt32(_fields.Count);
                 foreach (var field in _fields)
                 {
-                    blockOut.WriteVInt(field.FieldInfo.Number);
-                    blockOut.WriteVLong(field.NumTerms);
+                    blockOut.WriteVInt32(field.FieldInfo.Number);
+                    blockOut.WriteVInt64(field.NumTerms);
                     if (field.FieldInfo.IndexOptions != IndexOptions.DOCS_ONLY)
                     {
-                        blockOut.WriteVLong(field.SumTotalTermFreq);
+                        blockOut.WriteVInt64(field.SumTotalTermFreq);
                     }
-                    blockOut.WriteVLong(field.SumDocFreq);
-                    blockOut.WriteVInt(field.DocCount);
-                    blockOut.WriteVInt(field.LongsSize);
-                    blockOut.WriteVLong(field.StatsOut.FilePointer);
-                    blockOut.WriteVLong(field.MetaLongsOut.FilePointer);
-                    blockOut.WriteVLong(field.MetaBytesOut.FilePointer);
+                    blockOut.WriteVInt64(field.SumDocFreq);
+                    blockOut.WriteVInt32(field.DocCount);
+                    blockOut.WriteVInt32(field.LongsSize);
+                    blockOut.WriteVInt64(field.StatsOut.FilePointer);
+                    blockOut.WriteVInt64(field.MetaLongsOut.FilePointer);
+                    blockOut.WriteVInt64(field.MetaBytesOut.FilePointer);
 
                     field.SkipOut.WriteTo(blockOut);
                     field.StatsOut.WriteTo(blockOut);
@@ -239,7 +239,7 @@ namespace Lucene.Net.Codecs.Memory
 
         private void WriteTrailer(IndexOutput output, long dirStart)
         {
-            output.WriteLong(dirStart);
+            output.WriteInt64(dirStart);
         }
 
         private class FieldMetaData
@@ -332,17 +332,17 @@ namespace Lucene.Net.Codecs.Memory
                 {
                     if (delta == 0)
                     {
-                        _statsOut.WriteVInt(stats.DocFreq << 1 | 1);
+                        _statsOut.WriteVInt32(stats.DocFreq << 1 | 1);
                     }
                     else
                     {
-                        _statsOut.WriteVInt(stats.DocFreq << 1 | 0);
-                        _statsOut.WriteVLong(stats.TotalTermFreq - stats.DocFreq);
+                        _statsOut.WriteVInt32(stats.DocFreq << 1 | 0);
+                        _statsOut.WriteVInt64(stats.TotalTermFreq - stats.DocFreq);
                     }
                 }
                 else
                 {
-                    _statsOut.WriteVInt(stats.DocFreq);
+                    _statsOut.WriteVInt32(stats.DocFreq);
                 }
                 var state = _outerInstance.postingsWriter.NewTermState();
                 state.DocFreq = stats.DocFreq;
@@ -351,12 +351,12 @@ namespace Lucene.Net.Codecs.Memory
                 _outerInstance.postingsWriter.EncodeTerm(longs, _metaBytesOut, _fieldInfo, state, true);
                 for (var i = 0; i < _longsSize; i++)
                 {
-                    _metaLongsOut.WriteVLong(longs[i] - _lastLongs[i]);
+                    _metaLongsOut.WriteVInt64(longs[i] - _lastLongs[i]);
                     _lastLongs[i] = longs[i];
                 }
-                _metaLongsOut.WriteVLong(_metaBytesOut.FilePointer - _lastMetaBytesFp);
+                _metaLongsOut.WriteVInt64(_metaBytesOut.FilePointer - _lastMetaBytesFp);
 
-                _builder.Add(Util.ToIntsRef(text, _scratchTerm), _numTerms);
+                _builder.Add(Util.ToInt32sRef(text, _scratchTerm), _numTerms);
                 _numTerms++;
 
                 _lastMetaBytesFp = _metaBytesOut.FilePointer;
@@ -385,12 +385,12 @@ namespace Lucene.Net.Codecs.Memory
 
             private void BufferSkip()
             {
-                _skipOut.WriteVLong(_statsOut.FilePointer - _lastBlockStatsFp);
-                _skipOut.WriteVLong(_metaLongsOut.FilePointer - _lastBlockMetaLongsFp);
-                _skipOut.WriteVLong(_metaBytesOut.FilePointer - _lastBlockMetaBytesFp);
+                _skipOut.WriteVInt64(_statsOut.FilePointer - _lastBlockStatsFp);
+                _skipOut.WriteVInt64(_metaLongsOut.FilePointer - _lastBlockMetaLongsFp);
+                _skipOut.WriteVInt64(_metaBytesOut.FilePointer - _lastBlockMetaBytesFp);
                 for (var i = 0; i < _longsSize; i++)
                 {
-                    _skipOut.WriteVLong(_lastLongs[i] - _lastBlockLongs[i]);
+                    _skipOut.WriteVInt64(_lastLongs[i] - _lastBlockLongs[i]);
                 }
                 _lastBlockStatsFp = _statsOut.FilePointer;
                 _lastBlockMetaLongsFp = _metaLongsOut.FilePointer;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/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
index 376896b..33d614c 100644
--- a/src/Lucene.Net.Codecs/Memory/FSTTermOutputs.cs
+++ b/src/Lucene.Net.Codecs/Memory/FSTTermOutputs.cs
@@ -261,7 +261,7 @@ namespace Lucene.Net.Codecs.Memory
                 else
                 {
                     output.WriteByte((byte) bits);
-                    output.WriteVInt(data.bytes.Length);
+                    output.WriteVInt32(data.bytes.Length);
                 }
             }
             else
@@ -272,7 +272,7 @@ namespace Lucene.Net.Codecs.Memory
             {
                 for (int pos = 0; pos < _longsSize; pos++)
                 {
-                    output.WriteVLong(data.longs[pos]);
+                    output.WriteVInt64(data.longs[pos]);
                 }
             }
             if (bit1 > 0) // bytes exists
@@ -285,17 +285,17 @@ namespace Lucene.Net.Codecs.Memory
                 {
                     if (data.docFreq == data.totalTermFreq)
                     {
-                        output.WriteVInt((data.docFreq << 1) | 1);
+                        output.WriteVInt32((data.docFreq << 1) | 1);
                     }
                     else
                     {
-                        output.WriteVInt((data.docFreq << 1));
-                        output.WriteVLong(data.totalTermFreq - data.docFreq);
+                        output.WriteVInt32((data.docFreq << 1));
+                        output.WriteVInt64(data.totalTermFreq - data.docFreq);
                     }
                 }
                 else
                 {
-                    output.WriteVInt(data.docFreq);
+                    output.WriteVInt32(data.docFreq);
                 }
             }
         }
@@ -313,13 +313,13 @@ namespace Lucene.Net.Codecs.Memory
             var bytesSize = ((int) ((uint) bits >> 3));
             if (bit1 > 0 && bytesSize == 0) // determine extra length
             {
-                bytesSize = input.ReadVInt();
+                bytesSize = input.ReadVInt32();
             }
             if (bit0 > 0) // not all-zero case
             {
                 for (int pos = 0; pos < _longsSize; pos++)
                 {
-                    longs[pos] = input.ReadVLong();
+                    longs[pos] = input.ReadVInt64();
                 }
             }
             if (bit1 > 0) // bytes exists
@@ -329,13 +329,13 @@ namespace Lucene.Net.Codecs.Memory
             }
             if (bit2 > 0) // stats exist
             {
-                int code = input.ReadVInt();
+                int code = input.ReadVInt32();
                 if (_hasPos)
                 {
                     totalTermFreq = docFreq = (int) ((uint) code >> 1);
                     if ((code & 1) == 0)
                     {
-                        totalTermFreq += input.ReadVLong();
+                        totalTermFreq += input.ReadVInt64();
                     }
                 }
                 else

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/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
index 2e77f4b..b2cf9b8 100644
--- a/src/Lucene.Net.Codecs/Memory/FSTTermsReader.cs
+++ b/src/Lucene.Net.Codecs/Memory/FSTTermsReader.cs
@@ -82,16 +82,16 @@ namespace Lucene.Net.Codecs.Memory
                 SeekDir(@in);
 
                 FieldInfos fieldInfos = state.FieldInfos;
-                int numFields = @in.ReadVInt();
+                int numFields = @in.ReadVInt32();
                 for (int i = 0; i < numFields; i++)
                 {
-                    int fieldNumber = @in.ReadVInt();
+                    int fieldNumber = @in.ReadVInt32();
                     FieldInfo fieldInfo = fieldInfos.FieldInfo(fieldNumber);
-                    long numTerms = @in.ReadVLong();
-                    long sumTotalTermFreq = fieldInfo.IndexOptions == IndexOptions.DOCS_ONLY ? -1 : @in.ReadVLong();
-                    long sumDocFreq = @in.ReadVLong();
-                    int docCount = @in.ReadVInt();
-                    int longsSize = @in.ReadVInt();
+                    long numTerms = @in.ReadVInt64();
+                    long sumTotalTermFreq = fieldInfo.IndexOptions == IndexOptions.DOCS_ONLY ? -1 : @in.ReadVInt64();
+                    long sumDocFreq = @in.ReadVInt64();
+                    int docCount = @in.ReadVInt32();
+                    int longsSize = @in.ReadVInt32();
                     TermsReader current = new TermsReader(this, fieldInfo, @in, numTerms, sumTotalTermFreq, sumDocFreq, docCount, longsSize);
                     TermsReader previous;
                     // LUCENENET NOTE: This simulates a put operation in Java,
@@ -130,7 +130,7 @@ namespace Lucene.Net.Codecs.Memory
             {
                 @in.Seek(@in.Length - 8);
             }
-            @in.Seek(@in.ReadLong());
+            @in.Seek(@in.ReadInt64());
         }
         
         

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/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
index 9d7e448..9f01c13 100644
--- a/src/Lucene.Net.Codecs/Memory/FSTTermsWriter.cs
+++ b/src/Lucene.Net.Codecs/Memory/FSTTermsWriter.cs
@@ -156,7 +156,7 @@ namespace Lucene.Net.Codecs.Memory
 
         private void WriteTrailer(IndexOutput output, long dirStart)
         {
-            output.WriteLong(dirStart);
+            output.WriteInt64(dirStart);
         }
 
         public override TermsConsumer AddField(FieldInfo field)
@@ -174,18 +174,18 @@ namespace Lucene.Net.Codecs.Memory
                 // write field summary
                 var dirStart = _output.FilePointer;
 
-                _output.WriteVInt(_fields.Count);
+                _output.WriteVInt32(_fields.Count);
                 foreach (var field in _fields)
                 {
-                    _output.WriteVInt(field.FieldInfo.Number);
-                    _output.WriteVLong(field.NumTerms);
+                    _output.WriteVInt32(field.FieldInfo.Number);
+                    _output.WriteVInt64(field.NumTerms);
                     if (field.FieldInfo.IndexOptions != IndexOptions.DOCS_ONLY)
                     {
-                        _output.WriteVLong(field.SumTotalTermFreq);
+                        _output.WriteVInt64(field.SumTotalTermFreq);
                     }
-                    _output.WriteVLong(field.SumDocFreq);
-                    _output.WriteVInt(field.DocCount);
-                    _output.WriteVInt(field.LongsSize);
+                    _output.WriteVInt64(field.SumDocFreq);
+                    _output.WriteVInt32(field.DocCount);
+                    _output.WriteVInt32(field.LongsSize);
                     field.Dict.Save(_output);
                 }
                 WriteTrailer(_output, dirStart);
@@ -282,7 +282,7 @@ namespace Lucene.Net.Codecs.Memory
                     _metaWriter.WriteTo(meta.bytes, 0);
                     _metaWriter.Reset();
                 }
-                _builder.Add(Util.ToIntsRef(text, _scratchTerm), meta);
+                _builder.Add(Util.ToInt32sRef(text, _scratchTerm), meta);
                 _numTerms++;
             }
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/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
index ce252f3..94224fc 100644
--- a/src/Lucene.Net.Codecs/Memory/MemoryDocValuesConsumer.cs
+++ b/src/Lucene.Net.Codecs/Memory/MemoryDocValuesConsumer.cs
@@ -84,9 +84,9 @@ namespace Lucene.Net.Codecs.Memory
 
         internal virtual void AddNumericField(FieldInfo field, IEnumerable<long?> values, bool optimizeStorage)
         {
-            meta.WriteVInt(field.Number);
+            meta.WriteVInt32(field.Number);
             meta.WriteByte(MemoryDocValuesProducer.NUMBER);
-            meta.WriteLong(data.FilePointer);
+            meta.WriteInt64(data.FilePointer);
             long minValue = long.MaxValue;
             long maxValue = long.MinValue;
             long gcd = 0;
@@ -149,12 +149,12 @@ namespace Lucene.Net.Codecs.Memory
             {
                 long start = data.FilePointer;
                 WriteMissingBitset(values);
-                meta.WriteLong(start);
-                meta.WriteLong(data.FilePointer - start);
+                meta.WriteInt64(start);
+                meta.WriteInt64(data.FilePointer - start);
             }
             else
             {
-                meta.WriteLong(-1L);
+                meta.WriteInt64(-1L);
             }
 
             if (uniqueValues != null)
@@ -178,16 +178,16 @@ namespace Lucene.Net.Codecs.Memory
                     long?[] decode = uniqueValues.ToArray();
 
                     var encode = new Dictionary<long?, int?>();
-                    data.WriteVInt(decode.Length);
+                    data.WriteVInt32(decode.Length);
                     for (int i = 0; i < decode.Length; i++)
                     {
-                        data.WriteLong(decode[i].Value);
+                        data.WriteInt64(decode[i].Value);
                         encode[decode[i]] = i;
                     }
 
-                    meta.WriteVInt(PackedInts.VERSION_CURRENT);
-                    data.WriteVInt(formatAndBits.Format.Id);
-                    data.WriteVInt(formatAndBits.BitsPerValue);
+                    meta.WriteVInt32(PackedInts.VERSION_CURRENT);
+                    data.WriteVInt32(formatAndBits.Format.Id);
+                    data.WriteVInt32(formatAndBits.BitsPerValue);
 
                     PackedInts.Writer writer = PackedInts.GetWriterNoHeader(data, formatAndBits.Format, maxDoc,
                         formatAndBits.BitsPerValue, PackedInts.DEFAULT_BUFFER_SIZE);
@@ -203,10 +203,10 @@ namespace Lucene.Net.Codecs.Memory
             else if (gcd != 0 && gcd != 1)
             {
                 meta.WriteByte(MemoryDocValuesProducer.GCD_COMPRESSED);
-                meta.WriteVInt(PackedInts.VERSION_CURRENT);
-                data.WriteLong(minValue);
-                data.WriteLong(gcd);
-                data.WriteVInt(MemoryDocValuesProducer.BLOCK_SIZE);
+                meta.WriteVInt32(PackedInts.VERSION_CURRENT);
+                data.WriteInt64(minValue);
+                data.WriteInt64(gcd);
+                data.WriteVInt32(MemoryDocValuesProducer.BLOCK_SIZE);
 
                 var writer = new BlockPackedWriter(data, MemoryDocValuesProducer.BLOCK_SIZE);
                 foreach (var nv in values)
@@ -219,8 +219,8 @@ namespace Lucene.Net.Codecs.Memory
             {
                 meta.WriteByte(MemoryDocValuesProducer.DELTA_COMPRESSED); // delta-compressed
 
-                meta.WriteVInt(PackedInts.VERSION_CURRENT);
-                data.WriteVInt(MemoryDocValuesProducer.BLOCK_SIZE);
+                meta.WriteVInt32(PackedInts.VERSION_CURRENT);
+                data.WriteVInt32(MemoryDocValuesProducer.BLOCK_SIZE);
 
                 var writer = new BlockPackedWriter(data, MemoryDocValuesProducer.BLOCK_SIZE);
                 foreach (var nv in values)
@@ -240,7 +240,7 @@ namespace Lucene.Net.Codecs.Memory
             {
                 if (meta != null)
                 {
-                    meta.WriteVInt(-1); // write EOF marker
+                    meta.WriteVInt32(-1); // write EOF marker
                     CodecUtil.WriteFooter(meta); // write checksum
                 }
                 if (data != null)
@@ -266,7 +266,7 @@ namespace Lucene.Net.Codecs.Memory
         public override void AddBinaryField(FieldInfo field, IEnumerable<BytesRef> values)
         {
             // write the byte[] data
-            meta.WriteVInt(field.Number);
+            meta.WriteVInt32(field.Number);
             meta.WriteByte(MemoryDocValuesProducer.BYTES);
             var minLength = int.MaxValue;
             var maxLength = int.MinValue;
@@ -297,28 +297,28 @@ namespace Lucene.Net.Codecs.Memory
                     data.WriteBytes(v.Bytes, v.Offset, v.Length);
                 }
             }
-            meta.WriteLong(startFP);
-            meta.WriteLong(data.FilePointer - startFP);
+            meta.WriteInt64(startFP);
+            meta.WriteInt64(data.FilePointer - startFP);
             if (missing)
             {
                 long start = data.FilePointer;
                 WriteMissingBitset(values);
-                meta.WriteLong(start);
-                meta.WriteLong(data.FilePointer - start);
+                meta.WriteInt64(start);
+                meta.WriteInt64(data.FilePointer - start);
             }
             else
             {
-                meta.WriteLong(-1L);
+                meta.WriteInt64(-1L);
             }
-            meta.WriteVInt(minLength);
-            meta.WriteVInt(maxLength);
+            meta.WriteVInt32(minLength);
+            meta.WriteVInt32(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(MemoryDocValuesProducer.BLOCK_SIZE);
+                meta.WriteVInt32(PackedInts.VERSION_CURRENT);
+                meta.WriteVInt32(MemoryDocValuesProducer.BLOCK_SIZE);
 
 
                 var writer = new MonotonicBlockPackedWriter(data, MemoryDocValuesProducer.BLOCK_SIZE);
@@ -337,16 +337,16 @@ namespace Lucene.Net.Codecs.Memory
 
         private void WriteFST(FieldInfo field, IEnumerable<BytesRef> values)
         {
-            meta.WriteVInt(field.Number);
+            meta.WriteVInt32(field.Number);
             meta.WriteByte(MemoryDocValuesProducer.FST);
-            meta.WriteLong(data.FilePointer);
+            meta.WriteInt64(data.FilePointer);
             PositiveIntOutputs outputs = PositiveIntOutputs.Singleton;
             var builder = new Builder<long?>(INPUT_TYPE.BYTE1, outputs);
             var scratch = new IntsRef();
             long ord = 0;
             foreach (BytesRef v in values)
             {
-                builder.Add(Util.ToIntsRef(v, scratch), ord);
+                builder.Add(Util.ToInt32sRef(v, scratch), ord);
                 ord++;
             }
             FST<long?> fst = builder.Finish();
@@ -354,7 +354,7 @@ namespace Lucene.Net.Codecs.Memory
             {
                 fst.Save(data);
             }
-            meta.WriteVLong(ord);
+            meta.WriteVInt64(ord);
         }
 
         // TODO: in some cases representing missing with minValue-1 wouldn't take up additional space and so on,
@@ -368,7 +368,7 @@ namespace Lucene.Net.Codecs.Memory
             {
                 if (count == 64)
                 {
-                    data.WriteLong(bits);
+                    data.WriteInt64(bits);
                     count = 0;
                     bits = 0;
                 }
@@ -380,7 +380,7 @@ namespace Lucene.Net.Codecs.Memory
             }
             if (count > 0)
             {
-                data.WriteLong(bits);
+                data.WriteInt64(bits);
             }
         }
 
@@ -493,7 +493,7 @@ namespace Lucene.Net.Codecs.Memory
                         break;
 
                     long ord = ords.Current.Value;
-                    @out.WriteVLong(ord - lastOrd);
+                    @out.WriteVInt64(ord - lastOrd);
                     lastOrd = ord;
                 }
             }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/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
index 4ff434c..cab8547 100644
--- a/src/Lucene.Net.Codecs/Memory/MemoryDocValuesProducer.cs
+++ b/src/Lucene.Net.Codecs/Memory/MemoryDocValuesProducer.cs
@@ -134,16 +134,16 @@ namespace Lucene.Net.Codecs.Memory
 
         private void ReadFields(IndexInput meta, FieldInfos infos)
         {
-            int fieldNumber = meta.ReadVInt();
+            int fieldNumber = meta.ReadVInt32();
             while (fieldNumber != -1)
             {
                 int fieldType = meta.ReadByte();
                 if (fieldType == NUMBER)
                 {
-                    var entry = new NumericEntry {offset = meta.ReadLong(), missingOffset = meta.ReadLong()};
+                    var entry = new NumericEntry {offset = meta.ReadInt64(), missingOffset = meta.ReadInt64()};
                     if (entry.missingOffset != -1)
                     {
-                        entry.missingBytes = meta.ReadLong();
+                        entry.missingBytes = meta.ReadInt64();
                     }
                     else
                     {
@@ -162,7 +162,7 @@ namespace Lucene.Net.Codecs.Memory
                     }
                     if (entry.format != UNCOMPRESSED)
                     {
-                        entry.packedIntsVersion = meta.ReadVInt();
+                        entry.packedIntsVersion = meta.ReadVInt32();
                     }
                     numerics[fieldNumber] = entry;
                 }
@@ -170,37 +170,37 @@ namespace Lucene.Net.Codecs.Memory
                 {
                     var entry = new BinaryEntry
                     {
-                        offset = meta.ReadLong(),
-                        numBytes = meta.ReadLong(),
-                        missingOffset = meta.ReadLong()
+                        offset = meta.ReadInt64(),
+                        numBytes = meta.ReadInt64(),
+                        missingOffset = meta.ReadInt64()
                     };
                     if (entry.missingOffset != -1)
                     {
-                        entry.missingBytes = meta.ReadLong();
+                        entry.missingBytes = meta.ReadInt64();
                     }
                     else
                     {
                         entry.missingBytes = 0;
                     }
-                    entry.minLength = meta.ReadVInt();
-                    entry.maxLength = meta.ReadVInt();
+                    entry.minLength = meta.ReadVInt32();
+                    entry.maxLength = meta.ReadVInt32();
                     if (entry.minLength != entry.maxLength)
                     {
-                        entry.packedIntsVersion = meta.ReadVInt();
-                        entry.blockSize = meta.ReadVInt();
+                        entry.packedIntsVersion = meta.ReadVInt32();
+                        entry.blockSize = meta.ReadVInt32();
                     }
                     binaries[fieldNumber] = entry;
                 }
                 else if (fieldType == FST)
                 {
-                    var entry = new FSTEntry {offset = meta.ReadLong(), numOrds = meta.ReadVLong()};
+                    var entry = new FSTEntry {offset = meta.ReadInt64(), numOrds = meta.ReadVInt64()};
                     fsts[fieldNumber] = entry;
                 }
                 else
                 {
                     throw new CorruptIndexException("invalid entry type: " + fieldType + ", input=" + meta);
                 }
-                fieldNumber = meta.ReadVInt();
+                fieldNumber = meta.ReadVInt32();
             }
         }
 
@@ -238,7 +238,7 @@ namespace Lucene.Net.Codecs.Memory
             switch (entry.format)
             {
                 case TABLE_COMPRESSED:
-                    int size = data.ReadVInt();
+                    int size = data.ReadVInt32();
                     if (size > 256)
                     {
                         throw new CorruptIndexException(
@@ -247,16 +247,16 @@ namespace Lucene.Net.Codecs.Memory
                     var decode = new long[size];
                     for (int i = 0; i < decode.Length; i++)
                     {
-                        decode[i] = data.ReadLong();
+                        decode[i] = data.ReadInt64();
                     }
-                    int formatID = data.ReadVInt();
-                    int bitsPerValue = data.ReadVInt();
+                    int formatID = data.ReadVInt32();
+                    int bitsPerValue = data.ReadVInt32();
                     var ordsReader = PackedInts.GetReaderNoHeader(data, PackedInts.Format.ById(formatID),
                         entry.packedIntsVersion, maxDoc, bitsPerValue);
                     ramBytesUsed.AddAndGet(RamUsageEstimator.SizeOf(decode) + ordsReader.RamBytesUsed());
                     return new NumericDocValuesAnonymousInnerClassHelper(this, decode, ordsReader);
                 case DELTA_COMPRESSED:
-                    int blockSize = data.ReadVInt();
+                    int blockSize = data.ReadVInt32();
                     var reader = new BlockPackedReader(data, entry.packedIntsVersion, blockSize, maxDoc,
                         false);
                     ramBytesUsed.AddAndGet(reader.RamBytesUsed());
@@ -268,9 +268,9 @@ namespace Lucene.Net.Codecs.Memory
                     // LUCENENET: IMPORTANT - some bytes are negative here, so we need to pass as sbyte
                     return new NumericDocValuesAnonymousInnerClassHelper2(this, (sbyte[])(Array)bytes);
                 case GCD_COMPRESSED:
-                    long min = data.ReadLong();
-                    long mult = data.ReadLong();
-                    int quotientBlockSize = data.ReadVInt();
+                    long min = data.ReadInt64();
+                    long mult = data.ReadInt64();
+                    int quotientBlockSize = data.ReadVInt32();
                     var quotientReader = new BlockPackedReader(data, entry.packedIntsVersion,
                         quotientBlockSize, maxDoc, false);
                     ramBytesUsed.AddAndGet(quotientReader.RamBytesUsed());
@@ -603,7 +603,7 @@ namespace Lucene.Net.Codecs.Memory
                 }
                 else
                 {
-                    currentOrd += input.ReadVLong();
+                    currentOrd += input.ReadVInt64();
                     return currentOrd;
                 }
             }
@@ -687,7 +687,7 @@ namespace Lucene.Net.Codecs.Memory
                         var bits = new long[(int) length >> 3];
                         for (var i = 0; i < bits.Length; i++)
                         {
-                            bits[i] = data.ReadLong();
+                            bits[i] = data.ReadInt64();
                         }
                         instance = new FixedBitSet(bits, maxDoc);
                         docsWithFieldInstances[fieldNumber] = instance;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/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
index 3fda936..50e1116 100644
--- a/src/Lucene.Net.Codecs/Memory/MemoryPostingsFormat.cs
+++ b/src/Lucene.Net.Codecs/Memory/MemoryPostingsFormat.cs
@@ -149,17 +149,17 @@ namespace Lucene.Net.Codecs.Memory
 
                     if (outerInstance.field.IndexOptions == IndexOptions.DOCS_ONLY)
                     {
-                        buffer.WriteVInt(delta);
+                        buffer.WriteVInt32(delta);
                     }
                     else if (termDocFreq == 1)
                     {
-                        buffer.WriteVInt((delta << 1) | 1);
+                        buffer.WriteVInt32((delta << 1) | 1);
                     }
                     else
                     {
-                        buffer.WriteVInt(delta << 1);
+                        buffer.WriteVInt32(delta << 1);
                         Debug.Assert(termDocFreq > 0);
-                        buffer.WriteVInt(termDocFreq);
+                        buffer.WriteVInt32(termDocFreq);
                     }
 
                     lastPos = 0;
@@ -184,17 +184,17 @@ namespace Lucene.Net.Codecs.Memory
                         if (payloadLen != lastPayloadLen)
                         {
                             lastPayloadLen = payloadLen;
-                            buffer.WriteVInt((delta << 1) | 1);
-                            buffer.WriteVInt(payloadLen);
+                            buffer.WriteVInt32((delta << 1) | 1);
+                            buffer.WriteVInt32(payloadLen);
                         }
                         else
                         {
-                            buffer.WriteVInt(delta << 1);
+                            buffer.WriteVInt32(delta << 1);
                         }
                     }
                     else
                     {
-                        buffer.WriteVInt(delta);
+                        buffer.WriteVInt32(delta);
                     }
 
                     if (outerInstance.field.IndexOptions.Value.CompareTo(IndexOptions.DOCS_AND_FREQS_AND_POSITIONS_AND_OFFSETS) >= 0)
@@ -205,12 +205,12 @@ namespace Lucene.Net.Codecs.Memory
                         int offsetLength = endOffset - startOffset;
                         if (offsetLength != lastOffsetLength)
                         {
-                            buffer.WriteVInt(offsetDelta << 1 | 1);
-                            buffer.WriteVInt(offsetLength);
+                            buffer.WriteVInt32(offsetDelta << 1 | 1);
+                            buffer.WriteVInt32(offsetLength);
                         }
                         else
                         {
-                            buffer.WriteVInt(offsetDelta << 1);
+                            buffer.WriteVInt32(offsetDelta << 1);
                         }
                         lastOffset = startOffset;
                         lastOffsetLength = offsetLength;
@@ -256,10 +256,10 @@ namespace Lucene.Net.Codecs.Memory
 
                 Debug.Assert(buffer2.FilePointer == 0);
 
-                buffer2.WriteVInt(stats.DocFreq);
+                buffer2.WriteVInt32(stats.DocFreq);
                 if (field.IndexOptions != IndexOptions.DOCS_ONLY)
                 {
-                    buffer2.WriteVLong(stats.TotalTermFreq - stats.DocFreq);
+                    buffer2.WriteVInt64(stats.TotalTermFreq - stats.DocFreq);
                 }
                 int pos = (int)buffer2.FilePointer;
                 buffer2.WriteTo(finalBuffer, 0);
@@ -281,7 +281,7 @@ namespace Lucene.Net.Codecs.Memory
                 //  System.out.println("      " + Integer.toHexString(finalBuffer[i]&0xFF));
                 //}
 
-                builder.Add(Util.ToIntsRef(text, scratchIntsRef), BytesRef.DeepCopyOf(spare));
+                builder.Add(Util.ToInt32sRef(text, scratchIntsRef), BytesRef.DeepCopyOf(spare));
                 termCount++;
             }
 
@@ -289,14 +289,14 @@ namespace Lucene.Net.Codecs.Memory
             {
                 if (termCount > 0)
                 {
-                    @out.WriteVInt(termCount);
-                    @out.WriteVInt(field.Number);
+                    @out.WriteVInt32(termCount);
+                    @out.WriteVInt32(field.Number);
                     if (field.IndexOptions != IndexOptions.DOCS_ONLY)
                     {
-                        @out.WriteVLong(sumTotalTermFreq);
+                        @out.WriteVInt64(sumTotalTermFreq);
                     }
-                    @out.WriteVLong(sumDocFreq);
-                    @out.WriteVInt(docCount);
+                    @out.WriteVInt64(sumDocFreq);
+                    @out.WriteVInt32(docCount);
                     FST<BytesRef> fst = builder.Finish();
                     fst.Save(@out);
                     //System.out.println("finish field=" + field.name + " fp=" + out.getFilePointer());
@@ -362,7 +362,7 @@ namespace Lucene.Net.Codecs.Memory
                 // EOF marker:
                 try
                 {
-                    @out.WriteVInt(0);
+                    @out.WriteVInt32(0);
                     CodecUtil.WriteFooter(@out);
                 }
                 finally
@@ -433,11 +433,11 @@ namespace Lucene.Net.Codecs.Memory
                     docUpto++;
                     if (indexOptions == IndexOptions.DOCS_ONLY)
                     {
-                        accum += @in.ReadVInt();
+                        accum += @in.ReadVInt32();
                     }
                     else
                     {
-                        int code = @in.ReadVInt();
+                        int code = @in.ReadVInt32();
                         accum += (int)((uint)code >> 1);
                         //System.out.println("  docID=" + accum + " code=" + code);
                         if ((code & 1) != 0)
@@ -446,7 +446,7 @@ namespace Lucene.Net.Codecs.Memory
                         }
                         else
                         {
-                            freq_Renamed = @in.ReadVInt();
+                            freq_Renamed = @in.ReadVInt32();
                             Debug.Assert(freq_Renamed > 0);
                         }
 
@@ -457,14 +457,14 @@ namespace Lucene.Net.Codecs.Memory
                             {
                                 if (!storePayloads)
                                 {
-                                    @in.ReadVInt();
+                                    @in.ReadVInt32();
                                 }
                                 else
                                 {
-                                    int posCode = @in.ReadVInt();
+                                    int posCode = @in.ReadVInt32();
                                     if ((posCode & 1) != 0)
                                     {
-                                        payloadLen = @in.ReadVInt();
+                                        payloadLen = @in.ReadVInt32();
                                     }
                                     @in.SkipBytes(payloadLen);
                                 }
@@ -475,15 +475,15 @@ namespace Lucene.Net.Codecs.Memory
                             // Skip positions/offsets/payloads
                             for (int posUpto = 0; posUpto < freq_Renamed; posUpto++)
                             {
-                                int posCode = @in.ReadVInt();
+                                int posCode = @in.ReadVInt32();
                                 if (storePayloads && ((posCode & 1) != 0))
                                 {
-                                    payloadLen = @in.ReadVInt();
+                                    payloadLen = @in.ReadVInt32();
                                 }
-                                if ((@in.ReadVInt() & 1) != 0)
+                                if ((@in.ReadVInt32() & 1) != 0)
                                 {
                                     // new offset length
-                                    @in.ReadVInt();
+                                    @in.ReadVInt32();
                                 }
                                 if (storePayloads)
                                 {
@@ -604,7 +604,7 @@ namespace Lucene.Net.Codecs.Memory
                     }
                     docUpto++;
 
-                    int code = @in.ReadVInt();
+                    int code = @in.ReadVInt32();
                     accum += (int)((uint)code >> 1);
                     if ((code & 1) != 0)
                     {
@@ -612,7 +612,7 @@ namespace Lucene.Net.Codecs.Memory
                     }
                     else
                     {
-                        freq_Renamed = @in.ReadVInt();
+                        freq_Renamed = @in.ReadVInt32();
                         Debug.Assert(freq_Renamed > 0);
                     }
 
@@ -630,24 +630,24 @@ namespace Lucene.Net.Codecs.Memory
                     {
                         if (!storePayloads)
                         {
-                            @in.ReadVInt();
+                            @in.ReadVInt32();
                         }
                         else
                         {
-                            int skipCode = @in.ReadVInt();
+                            int skipCode = @in.ReadVInt32();
                             if ((skipCode & 1) != 0)
                             {
-                                payloadLength = @in.ReadVInt();
+                                payloadLength = @in.ReadVInt32();
                                 //System.out.println("    new payloadLen=" + payloadLength);
                             }
                         }
 
                         if (storeOffsets)
                         {
-                            if ((@in.ReadVInt() & 1) != 0)
+                            if ((@in.ReadVInt32() & 1) != 0)
                             {
                                 // new offset length
-                                offsetLength = @in.ReadVInt();
+                                offsetLength = @in.ReadVInt32();
                             }
                         }
 
@@ -666,15 +666,15 @@ namespace Lucene.Net.Codecs.Memory
                 posPending--;
                 if (!storePayloads)
                 {
-                    pos += @in.ReadVInt();
+                    pos += @in.ReadVInt32();
                 }
                 else
                 {
-                    int code = @in.ReadVInt();
+                    int code = @in.ReadVInt32();
                     pos += (int)((uint)code >> 1);
                     if ((code & 1) != 0)
                     {
-                        payloadLength = @in.ReadVInt();
+                        payloadLength = @in.ReadVInt32();
                         //System.out.println("      new payloadLen=" + payloadLength);
                         //} else {
                         //System.out.println("      same payloadLen=" + payloadLength);
@@ -683,11 +683,11 @@ namespace Lucene.Net.Codecs.Memory
 
                 if (storeOffsets)
                 {
-                    int offsetCode = @in.ReadVInt();
+                    int offsetCode = @in.ReadVInt32();
                     if ((offsetCode & 1) != 0)
                     {
                         // new offset length
-                        offsetLength = @in.ReadVInt();
+                        offsetLength = @in.ReadVInt32();
                     }
                     startOffset_Renamed += (int)((uint)offsetCode >> 1);
                 }
@@ -766,10 +766,10 @@ namespace Lucene.Net.Codecs.Memory
                 if (!didDecode)
                 {
                     buffer.Reset(current.Output.Bytes, current.Output.Offset, current.Output.Length);
-                    docFreq_Renamed = buffer.ReadVInt();
+                    docFreq_Renamed = buffer.ReadVInt32();
                     if (field.IndexOptions != IndexOptions.DOCS_ONLY)
                     {
-                        totalTermFreq_Renamed = docFreq_Renamed + buffer.ReadVLong();
+                        totalTermFreq_Renamed = docFreq_Renamed + buffer.ReadVInt64();
                     }
                     else
                     {
@@ -941,18 +941,18 @@ namespace Lucene.Net.Codecs.Memory
             public TermsReader(FieldInfos fieldInfos, IndexInput @in, int termCount)
             {
                 this.termCount = termCount;
-                int fieldNumber = @in.ReadVInt();
+                int fieldNumber = @in.ReadVInt32();
                 field = fieldInfos.FieldInfo(fieldNumber);
                 if (field.IndexOptions != IndexOptions.DOCS_ONLY)
                 {
-                    sumTotalTermFreq = @in.ReadVLong();
+                    sumTotalTermFreq = @in.ReadVInt64();
                 }
                 else
                 {
                     sumTotalTermFreq = -1;
                 }
-                sumDocFreq = @in.ReadVLong();
-                docCount = @in.ReadVInt();
+                sumDocFreq = @in.ReadVInt64();
+                docCount = @in.ReadVInt32();
 
                 fst = new FST<BytesRef>(@in, outputs);
             }
@@ -1036,7 +1036,7 @@ namespace Lucene.Net.Codecs.Memory
                 CodecUtil.CheckHeader(@in, CODEC_NAME, VERSION_START, VERSION_CURRENT);
                 while (true)
                 {
-                    int termCount = @in.ReadVInt();
+                    int termCount = @in.ReadVInt32();
                     if (termCount == 0)
                     {
                         break;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/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
index 3592de9..941b080 100644
--- a/src/Lucene.Net.Codecs/Pulsing/PulsingPostingsReader.cs
+++ b/src/Lucene.Net.Codecs/Pulsing/PulsingPostingsReader.cs
@@ -56,7 +56,7 @@ namespace Lucene.Net.Codecs.Pulsing
                 PulsingPostingsWriter.VERSION_START,
                 PulsingPostingsWriter.VERSION_CURRENT);
 
-            _maxPositions = termsIn.ReadVInt();
+            _maxPositions = termsIn.ReadVInt32();
             _wrappedPostingsReader.Init(termsIn);
 
             if (_wrappedPostingsReader is PulsingPostingsReader || _version < PulsingPostingsWriter.VERSION_META_ARRAY)
@@ -79,11 +79,11 @@ namespace Lucene.Net.Codecs.Pulsing
                         _version,
                         PulsingPostingsWriter.VERSION_CURRENT);
 
-                    var numField = input.ReadVInt();
+                    var numField = input.ReadVInt32();
                     for (var i = 0; i < numField; i++)
                     {
-                        var fieldNum = input.ReadVInt();
-                        var longsSize = input.ReadVInt();
+                        var fieldNum = input.ReadVInt32();
+                        var longsSize = input.ReadVInt32();
                         _fields.Add(fieldNum, longsSize);
                     }
                 }
@@ -180,7 +180,7 @@ namespace Lucene.Net.Codecs.Pulsing
                 // 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):
-                termState2.PostingsSize = input.ReadVInt();
+                termState2.PostingsSize = input.ReadVInt32();
                 if (termState2.Postings == null || termState2.Postings.Length < termState2.PostingsSize)
                 {
                     termState2.Postings = new byte[ArrayUtil.Oversize(termState2.PostingsSize, 1)];
@@ -202,7 +202,7 @@ namespace Lucene.Net.Codecs.Pulsing
                 }
                 for (var i = 0; i < longsSize; i++)
                 {
-                    termState2.Longs[i] = input.ReadVLong();
+                    termState2.Longs[i] = input.ReadVInt64();
                 }
                 termState2.PostingsSize = -1;
                 termState2.WrappedTermState.DocFreq = termState2.DocFreq;
@@ -368,7 +368,7 @@ namespace Lucene.Net.Codecs.Pulsing
                     if (_postings.Eof)
                         return _docId = NO_MORE_DOCS;
 
-                    var code = _postings.ReadVInt();
+                    var code = _postings.ReadVInt32();
                     if (_indexOptions == IndexOptions.DOCS_ONLY)
                     {
                         _accum += code;
@@ -376,7 +376,7 @@ namespace Lucene.Net.Codecs.Pulsing
                     else
                     {
                         _accum += (int)((uint)code >> 1); ; // shift off low bit
-                        _freq = (code & 1) != 0 ? 1 : _postings.ReadVInt();
+                        _freq = (code & 1) != 0 ? 1 : _postings.ReadVInt32();
 
                         if (_indexOptions.Value.CompareTo(IndexOptions.DOCS_AND_FREQS_AND_POSITIONS) >= 0)
                         {
@@ -385,15 +385,15 @@ namespace Lucene.Net.Codecs.Pulsing
                             {
                                 for (var pos = 0; pos < _freq; pos++)
                                 {
-                                    var posCode = _postings.ReadVInt();
+                                    var posCode = _postings.ReadVInt32();
                                     if ((posCode & 1) != 0)
                                     {
-                                        _payloadLength = _postings.ReadVInt();
+                                        _payloadLength = _postings.ReadVInt32();
                                     }
-                                    if (_storeOffsets && (_postings.ReadVInt() & 1) != 0)
+                                    if (_storeOffsets && (_postings.ReadVInt32() & 1) != 0)
                                     {
                                         // new offset length
-                                        _postings.ReadVInt();
+                                        _postings.ReadVInt32();
                                     }
                                     if (_payloadLength != 0)
                                     {
@@ -406,11 +406,11 @@ namespace Lucene.Net.Codecs.Pulsing
                                 for (var pos = 0; pos < _freq; pos++)
                                 {
                                     // TODO: skipVInt
-                                    _postings.ReadVInt();
-                                    if (_storeOffsets && (_postings.ReadVInt() & 1) != 0)
+                                    _postings.ReadVInt32();
+                                    if (_storeOffsets && (_postings.ReadVInt32() & 1) != 0)
                                     {
                                         // new offset length
-                                        _postings.ReadVInt();
+                                        _postings.ReadVInt32();
                                     }
                                 }
                             }
@@ -518,9 +518,9 @@ namespace Lucene.Net.Codecs.Pulsing
                         return _docId = NO_MORE_DOCS;
                     }
 
-                    var code = _postings.ReadVInt();
+                    var code = _postings.ReadVInt32();
                     _accum += (int)((uint)code >> 1); // shift off low bit 
-                    _freq = (code & 1) != 0 ? 1 : _postings.ReadVInt();
+                    _freq = (code & 1) != 0 ? 1 : _postings.ReadVInt32();
                     _posPending = _freq;
                     _startOffset = _storeOffsets ? 0 : -1; // always return -1 if no offsets are stored
 
@@ -558,26 +558,26 @@ namespace Lucene.Net.Codecs.Pulsing
                     {
                         _postings.SkipBytes(_payloadLength);
                     }
-                    int code = _postings.ReadVInt();
+                    int code = _postings.ReadVInt32();
                     if ((code & 1) != 0)
                     {
-                        _payloadLength = _postings.ReadVInt();
+                        _payloadLength = _postings.ReadVInt32();
                     }
                     _position += (int)((uint)code >> 1);
                     _payloadRetrieved = false;
                 }
                 else
                 {
-                    _position += _postings.ReadVInt();
+                    _position += _postings.ReadVInt32();
                 }
 
                 if (_storeOffsets)
                 {
-                    int offsetCode = _postings.ReadVInt();
+                    int offsetCode = _postings.ReadVInt32();
                     if ((offsetCode & 1) != 0)
                     {
                         // new offset length
-                        _offsetLength = _postings.ReadVInt();
+                        _offsetLength = _postings.ReadVInt32();
                     }
                     _startOffset += (int)((uint)offsetCode >> 1);
                 }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/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
index 729aa2a..acc29f0 100644
--- a/src/Lucene.Net.Codecs/Pulsing/PulsingPostingsWriter.cs
+++ b/src/Lucene.Net.Codecs/Pulsing/PulsingPostingsWriter.cs
@@ -133,7 +133,7 @@ namespace Lucene.Net.Codecs.Pulsing
         {
             _termsOut = termsOut;
             CodecUtil.WriteHeader(termsOut, CODEC, VERSION_CURRENT);
-            termsOut.WriteVInt(_pending.Length); // encode maxPositions in header
+            termsOut.WriteVInt32(_pending.Length); // encode maxPositions in header
             _wrappedPostingsWriter.Init(termsOut);
         }
 
@@ -302,12 +302,12 @@ namespace Lucene.Net.Codecs.Pulsing
 
                         if (doc.termFreq == 1)
                         {
-                            _buffer.WriteVInt((delta << 1) | 1);
+                            _buffer.WriteVInt32((delta << 1) | 1);
                         }
                         else
                         {
-                            _buffer.WriteVInt(delta << 1);
-                            _buffer.WriteVInt(doc.termFreq);
+                            _buffer.WriteVInt32(delta << 1);
+                            _buffer.WriteVInt32(doc.termFreq);
                         }
 
                         var lastPos = 0;
@@ -324,18 +324,18 @@ namespace Lucene.Net.Codecs.Pulsing
                             {
                                 if (payloadLength != lastPayloadLength)
                                 {
-                                    _buffer.WriteVInt((posDelta << 1) | 1);
-                                    _buffer.WriteVInt(payloadLength);
+                                    _buffer.WriteVInt32((posDelta << 1) | 1);
+                                    _buffer.WriteVInt32(payloadLength);
                                     lastPayloadLength = payloadLength;
                                 }
                                 else
                                 {
-                                    _buffer.WriteVInt(posDelta << 1);
+                                    _buffer.WriteVInt32(posDelta << 1);
                                 }
                             }
                             else
                             {
-                                _buffer.WriteVInt(posDelta);
+                                _buffer.WriteVInt32(posDelta);
                             }
 
                             if (_indexOptions >= IndexOptions.DOCS_AND_FREQS_AND_POSITIONS_AND_OFFSETS)
@@ -345,12 +345,12 @@ namespace Lucene.Net.Codecs.Pulsing
                                 var offsetLength = pos.endOffset - pos.startOffset;
                                 if (offsetLength != lastOffsetLength)
                                 {
-                                    _buffer.WriteVInt(offsetDelta << 1 | 1);
-                                    _buffer.WriteVInt(offsetLength);
+                                    _buffer.WriteVInt32(offsetDelta << 1 | 1);
+                                    _buffer.WriteVInt32(offsetLength);
                                 }
                                 else
                                 {
-                                    _buffer.WriteVInt(offsetDelta << 1);
+                                    _buffer.WriteVInt32(offsetDelta << 1);
                                 }
                                 lastOffset = pos.startOffset;
                                 lastOffsetLength = offsetLength;
@@ -378,12 +378,12 @@ namespace Lucene.Net.Codecs.Pulsing
 
                             if (doc.termFreq == 1)
                             {
-                                _buffer.WriteVInt((delta << 1) | 1);
+                                _buffer.WriteVInt32((delta << 1) | 1);
                             }
                             else
                             {
-                                _buffer.WriteVInt(delta << 1);
-                                _buffer.WriteVInt(doc.termFreq);
+                                _buffer.WriteVInt32(delta << 1);
+                                _buffer.WriteVInt32(doc.termFreq);
                             }
                             lastDocId = doc.docID;
                         }
@@ -395,7 +395,7 @@ namespace Lucene.Net.Codecs.Pulsing
                         for (var posIdx = 0; posIdx < _pendingCount; posIdx++)
                         {
                             var doc = _pending[posIdx];
-                            _buffer.WriteVInt(doc.docID - lastDocId);
+                            _buffer.WriteVInt32(doc.docID - lastDocId);
                             lastDocId = doc.docID;
                         }
                     }
@@ -420,7 +420,7 @@ namespace Lucene.Net.Codecs.Pulsing
                 _wrappedPostingsWriter.EncodeTerm(_longs, _buffer, fieldInfo, _state.wrappedState, _absolute);
                 for (var i = 0; i < _longsSize; i++)
                 {
-                    output.WriteVLong(_longs[i]);
+                    output.WriteVInt64(_longs[i]);
                 }
                 _buffer.WriteTo(output);
                 _buffer.Reset();
@@ -428,7 +428,7 @@ namespace Lucene.Net.Codecs.Pulsing
             }
             else
             {
-                output.WriteVInt(_state.bytes.Length);
+                output.WriteVInt32(_state.bytes.Length);
                 output.WriteBytes(_state.bytes, 0, _state.bytes.Length);
                 _absolute = _absolute || abs;
             }
@@ -452,11 +452,11 @@ namespace Lucene.Net.Codecs.Pulsing
                 output =
                     _segmentState.Directory.CreateOutput(summaryFileName, _segmentState.Context);
                 CodecUtil.WriteHeader(output, CODEC, VERSION_CURRENT);
-                output.WriteVInt(_fields.Count);
+                output.WriteVInt32(_fields.Count);
                 foreach (var field in _fields)
                 {
-                    output.WriteVInt(field.FieldNumber);
-                    output.WriteVInt(field.LongsSize);
+                    output.WriteVInt32(field.FieldNumber);
+                    output.WriteVInt32(field.LongsSize);
                 }
                 output.Dispose();
             }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/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
index 9226c2e..97f35db 100644
--- a/src/Lucene.Net.Codecs/Sep/SepPostingsReader.cs
+++ b/src/Lucene.Net.Codecs/Sep/SepPostingsReader.cs
@@ -102,9 +102,9 @@ namespace Lucene.Net.Codecs.Sep
             // 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();
+            _skipInterval = termsIn.ReadInt32();
+            _maxSkipLevels = termsIn.ReadInt32();
+            _skipMinimum = termsIn.ReadInt32();
         }
 
         protected override void Dispose(bool disposing)
@@ -215,11 +215,11 @@ namespace Lucene.Net.Codecs.Sep
                     {
                         if (absolute)
                         {
-                            termState.PAYLOAD_FP = input.ReadVLong();
+                            termState.PAYLOAD_FP = input.ReadVInt64();
                         }
                         else
                         {
-                            termState.PAYLOAD_FP += input.ReadVLong();
+                            termState.PAYLOAD_FP += input.ReadVInt64();
                         }
                     }
                 }
@@ -229,11 +229,11 @@ namespace Lucene.Net.Codecs.Sep
             {
                 if (absolute)
                 {
-                    termState.SKIP_FP = input.ReadVLong();
+                    termState.SKIP_FP = input.ReadVInt64();
                 }
                 else
                 {
-                    termState.SKIP_FP += input.ReadVLong();
+                    termState.SKIP_FP += input.ReadVInt64();
                 }
             }
             else if (absolute)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/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
index ff8bfb2..ad2f89f 100644
--- a/src/Lucene.Net.Codecs/Sep/SepPostingsWriter.cs
+++ b/src/Lucene.Net.Codecs/Sep/SepPostingsWriter.cs
@@ -158,9 +158,9 @@ namespace Lucene.Net.Codecs.Sep
         {
             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
+            termsOut.WriteInt32(skipInterval);    // write skipInterval
+            termsOut.WriteInt32(maxSkipLevels);   // write maxSkipLevels
+            termsOut.WriteInt32(skipMinimum);     // write skipMinimum
         }
 
         public override BlockTermState NewTermState()
@@ -377,11 +377,11 @@ namespace Lucene.Net.Codecs.Sep
                     {
                         if (absolute)
                         {
-                            output.WriteVLong(state.PayloadFp);
+                            output.WriteVInt64(state.PayloadFp);
                         }
                         else
                         {
-                            output.WriteVLong(state.PayloadFp - lastPayloadFP);
+                            output.WriteVInt64(state.PayloadFp - lastPayloadFP);
                         }
                         lastPayloadFP = state.PayloadFp;
                     }
@@ -391,11 +391,11 @@ namespace Lucene.Net.Codecs.Sep
 
             if (absolute)
             {
-                output.WriteVLong(state.SkipFp);
+                output.WriteVInt64(state.SkipFp);
             }
             else
             {
-                output.WriteVLong(state.SkipFp - lastSkipFP);
+                output.WriteVInt64(state.SkipFp - lastSkipFP);
             }
             lastSkipFP = state.SkipFp;
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/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
index cfae7df..aa090b5 100644
--- a/src/Lucene.Net.Codecs/Sep/SepSkipListReader.cs
+++ b/src/Lucene.Net.Codecs/Sep/SepSkipListReader.cs
@@ -180,16 +180,16 @@ namespace Lucene.Net.Codecs.Sep
                 // to read the current payload length
                 // because it differs from the length of the
                 // previous payload
-                delta = skipStream.ReadVInt();
+                delta = skipStream.ReadVInt32();
                 if ((delta & 1) != 0)
                 {
-                    _payloadLength[level] = skipStream.ReadVInt();
+                    _payloadLength[level] = skipStream.ReadVInt32();
                 }
                 delta = (int) ((uint) delta >> 1);
             }
             else
             {
-                delta = skipStream.ReadVInt();
+                delta = skipStream.ReadVInt32();
             }
 
             if (_indexOptions != IndexOptions.DOCS_ONLY)
@@ -201,7 +201,7 @@ namespace Lucene.Net.Codecs.Sep
             _posIndex[level].Read(skipStream, false);
             
             if (_currentFieldStoresPayloads)
-                _payloadPointer[level] += skipStream.ReadVInt();
+                _payloadPointer[level] += skipStream.ReadVInt32();
             
             return delta;
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/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
index feedd66..6e5bc5c 100644
--- a/src/Lucene.Net.Codecs/Sep/SepSkipListWriter.cs
+++ b/src/Lucene.Net.Codecs/Sep/SepSkipListWriter.cs
@@ -179,21 +179,21 @@ namespace Lucene.Net.Codecs.Sep
                 {
                     // the current payload length equals the length at the previous skip point,
                     // so we don't store the length again
-                    skipBuffer.WriteVInt(delta << 1);
+                    skipBuffer.WriteVInt32(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);
+                    skipBuffer.WriteVInt32(delta << 1 | 1);
+                    skipBuffer.WriteVInt32(_curPayloadLength);
                     _lastSkipPayloadLength[level] = _curPayloadLength;
                 }
             }
             else
             {
                 // current field does not store payloads
-                skipBuffer.WriteVInt(_curDoc - _lastSkipDoc[level]);
+                skipBuffer.WriteVInt32(_curDoc - _lastSkipDoc[level]);
             }
 
             if (_indexOptions != IndexOptions.DOCS_ONLY)
@@ -209,7 +209,7 @@ namespace Lucene.Net.Codecs.Sep
                 _posIndex[level].Write(skipBuffer, false);
                 if (_curStorePayloads)
                 {
-                    skipBuffer.WriteVInt((int)(_curPayloadPointer - _lastSkipPayloadPointer[level]));
+                    skipBuffer.WriteVInt32((int)(_curPayloadPointer - _lastSkipPayloadPointer[level]));
                 }
             }
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/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
index 5c2398c..fbe26ba 100644
--- a/src/Lucene.Net.Codecs/SimpleText/SimpleTextFieldsReader.cs
+++ b/src/Lucene.Net.Codecs/SimpleText/SimpleTextFieldsReader.cs
@@ -303,7 +303,7 @@ namespace Lucene.Net.Codecs.SimpleText
                         }
                         UnicodeUtil.UTF8toUTF16(_scratch.Bytes, _scratch.Offset + SimpleTextFieldsWriter.DOC.Length, _scratch.Length - SimpleTextFieldsWriter.DOC.Length,
                             _scratchUtf16);
-                        _docId = ArrayUtil.ParseInt(_scratchUtf16.Chars, 0, _scratchUtf16.Length);
+                        _docId = ArrayUtil.ParseInt32(_scratchUtf16.Chars, 0, _scratchUtf16.Length);
                         termFreq = 0;
                         first = false;
                     }
@@ -311,7 +311,7 @@ namespace Lucene.Net.Codecs.SimpleText
                     {
                         UnicodeUtil.UTF8toUTF16(_scratch.Bytes, _scratch.Offset + SimpleTextFieldsWriter.FREQ.Length,
                             _scratch.Length - SimpleTextFieldsWriter.FREQ.Length, _scratchUtf16);
-                        termFreq = ArrayUtil.ParseInt(_scratchUtf16.Chars, 0, _scratchUtf16.Length);
+                        termFreq = ArrayUtil.ParseInt32(_scratchUtf16.Chars, 0, _scratchUtf16.Length);
                     }
                     else if (StringHelper.StartsWith(_scratch, SimpleTextFieldsWriter.POS))
                     {
@@ -437,7 +437,7 @@ namespace Lucene.Net.Codecs.SimpleText
                         }
                         UnicodeUtil.UTF8toUTF16(_scratch.Bytes, _scratch.Offset + SimpleTextFieldsWriter.DOC.Length, _scratch.Length - SimpleTextFieldsWriter.DOC.Length,
                             _scratchUtf16);
-                        _docId = ArrayUtil.ParseInt(_scratchUtf16.Chars, 0, _scratchUtf16.Length);
+                        _docId = ArrayUtil.ParseInt32(_scratchUtf16.Chars, 0, _scratchUtf16.Length);
                         _tf = 0;
                         first = false;
                     }
@@ -445,7 +445,7 @@ namespace Lucene.Net.Codecs.SimpleText
                     {
                         UnicodeUtil.UTF8toUTF16(_scratch.Bytes, _scratch.Offset + SimpleTextFieldsWriter.FREQ.Length,
                             _scratch.Length - SimpleTextFieldsWriter.FREQ.Length, _scratchUtf16);
-                        _tf = ArrayUtil.ParseInt(_scratchUtf16.Chars, 0, _scratchUtf16.Length);
+                        _tf = ArrayUtil.ParseInt32(_scratchUtf16.Chars, 0, _scratchUtf16.Length);
                         posStart = _in.FilePointer;
                     }
                     else if (StringHelper.StartsWith(_scratch, SimpleTextFieldsWriter.POS))
@@ -495,7 +495,7 @@ namespace Lucene.Net.Codecs.SimpleText
                     Debug.Assert(StringHelper.StartsWith(_scratch, SimpleTextFieldsWriter.POS), "got line=" + _scratch.Utf8ToString());
                     UnicodeUtil.UTF8toUTF16(_scratch.Bytes, _scratch.Offset + SimpleTextFieldsWriter.POS.Length, _scratch.Length - SimpleTextFieldsWriter.POS.Length,
                         _scratchUtf162);
-                    pos = ArrayUtil.ParseInt(_scratchUtf162.Chars, 0, _scratchUtf162.Length);
+                    pos = ArrayUtil.ParseInt32(_scratchUtf162.Chars, 0, _scratchUtf162.Length);
                 }
                 else
                 {
@@ -508,12 +508,12 @@ namespace Lucene.Net.Codecs.SimpleText
                     Debug.Assert(StringHelper.StartsWith(_scratch, SimpleTextFieldsWriter.START_OFFSET), "got line=" + _scratch.Utf8ToString());
                     UnicodeUtil.UTF8toUTF16(_scratch.Bytes, _scratch.Offset + SimpleTextFieldsWriter.START_OFFSET.Length,
                         _scratch.Length - SimpleTextFieldsWriter.START_OFFSET.Length, _scratchUtf162);
-                    _startOffset = ArrayUtil.ParseInt(_scratchUtf162.Chars, 0, _scratchUtf162.Length);
+                    _startOffset = ArrayUtil.ParseInt32(_scratchUtf162.Chars, 0, _scratchUtf162.Length);
                     SimpleTextUtil.ReadLine(_in, _scratch);
                     Debug.Assert(StringHelper.StartsWith(_scratch, SimpleTextFieldsWriter.END_OFFSET), "got line=" + _scratch.Utf8ToString());
                     UnicodeUtil.UTF8toUTF16(_scratch.Bytes, _scratch.Offset + SimpleTextFieldsWriter.END_OFFSET.Length,
                         _scratch.Length - SimpleTextFieldsWriter.END_OFFSET.Length, _scratchUtf162);
-                    _endOffset = ArrayUtil.ParseInt(_scratchUtf162.Chars, 0, _scratchUtf162.Length);
+                    _endOffset = ArrayUtil.ParseInt32(_scratchUtf162.Chars, 0, _scratchUtf162.Length);
                 }
 
                 long fp = _in.FilePointer;
@@ -619,7 +619,7 @@ namespace Lucene.Net.Codecs.SimpleText
                     {
                         if (lastDocsStart != -1)
                         {
-                            b.Add(Util.ToIntsRef(lastTerm, scratchIntsRef),
+                            b.Add(Util.ToInt32sRef(lastTerm, scratchIntsRef),
                                 outputs.NewPair(lastDocsStart, outputsInner.NewPair(docFreq, totalTermFreq)));
                             _sumTotalTermFreq += totalTermFreq;
                         }
@@ -632,20 +632,20 @@ namespace Lucene.Net.Codecs.SimpleText
                         _sumDocFreq++;
                         UnicodeUtil.UTF8toUTF16(_scratch.Bytes, _scratch.Offset + SimpleTextFieldsWriter.DOC.Length, _scratch.Length - SimpleTextFieldsWriter.DOC.Length,
                             _scratchUtf16);
-                        int docId = ArrayUtil.ParseInt(_scratchUtf16.Chars, 0, _scratchUtf16.Length);
+                        int docId = ArrayUtil.ParseInt32(_scratchUtf16.Chars, 0, _scratchUtf16.Length);
                         visitedDocs.Set(docId);
                     }
                     else if (StringHelper.StartsWith(_scratch, SimpleTextFieldsWriter.FREQ))
                     {
                         UnicodeUtil.UTF8toUTF16(_scratch.Bytes, _scratch.Offset + SimpleTextFieldsWriter.FREQ.Length,
                             _scratch.Length - SimpleTextFieldsWriter.FREQ.Length, _scratchUtf16);
-                        totalTermFreq += ArrayUtil.ParseInt(_scratchUtf16.Chars, 0, _scratchUtf16.Length);
+                        totalTermFreq += ArrayUtil.ParseInt32(_scratchUtf16.Chars, 0, _scratchUtf16.Length);
                     }
                     else if (StringHelper.StartsWith(_scratch, SimpleTextFieldsWriter.TERM))
                     {
                         if (lastDocsStart != -1)
                         {
-                            b.Add(Util.ToIntsRef(lastTerm, scratchIntsRef),
+                            b.Add(Util.ToInt32sRef(lastTerm, scratchIntsRef),
                                 outputs.NewPair(lastDocsStart, outputsInner.NewPair(docFreq, totalTermFreq)));
                         }
                         lastDocsStart = input.FilePointer;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Codecs/SimpleText/SimpleTextLiveDocsFormat.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Codecs/SimpleText/SimpleTextLiveDocsFormat.cs b/src/Lucene.Net.Codecs/SimpleText/SimpleTextLiveDocsFormat.cs
index bd1d709..439049f 100644
--- a/src/Lucene.Net.Codecs/SimpleText/SimpleTextLiveDocsFormat.cs
+++ b/src/Lucene.Net.Codecs/SimpleText/SimpleTextLiveDocsFormat.cs
@@ -115,7 +115,7 @@ namespace Lucene.Net.Codecs.SimpleText
         private int ParseIntAt(BytesRef bytes, int offset, CharsRef scratch) // LUCENENET TODO: Rename ParseInt32At ?
         {
             UnicodeUtil.UTF8toUTF16(bytes.Bytes, bytes.Offset + offset, bytes.Length - offset, scratch);
-            return ArrayUtil.ParseInt(scratch.Chars, 0, scratch.Length);
+            return ArrayUtil.ParseInt32(scratch.Chars, 0, scratch.Length);
         }
 
         public override void WriteLiveDocs(IMutableBits bits, Directory dir, SegmentCommitInfo info, int newDelCount,

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Codecs/SimpleText/SimpleTextStoredFieldsReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Codecs/SimpleText/SimpleTextStoredFieldsReader.cs b/src/Lucene.Net.Codecs/SimpleText/SimpleTextStoredFieldsReader.cs
index d40d03a..335a23c 100644
--- a/src/Lucene.Net.Codecs/SimpleText/SimpleTextStoredFieldsReader.cs
+++ b/src/Lucene.Net.Codecs/SimpleText/SimpleTextStoredFieldsReader.cs
@@ -252,7 +252,7 @@ namespace Lucene.Net.Codecs.SimpleText
         private int ParseIntAt(int offset) // LUCENENET TODO: Rename ParseInt32At
         {
             UnicodeUtil.UTF8toUTF16(_scratch.Bytes, _scratch.Offset + offset, _scratch.Length - offset, _scratchUtf16);
-            return ArrayUtil.ParseInt(_scratchUtf16.Chars, 0, _scratchUtf16.Length);
+            return ArrayUtil.ParseInt32(_scratchUtf16.Chars, 0, _scratchUtf16.Length);
         }
 
         private bool EqualsAt(BytesRef a, BytesRef b, int bOffset)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Codecs/SimpleText/SimpleTextTermVectorsReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Codecs/SimpleText/SimpleTextTermVectorsReader.cs b/src/Lucene.Net.Codecs/SimpleText/SimpleTextTermVectorsReader.cs
index 1fd43bd..82c877d 100644
--- a/src/Lucene.Net.Codecs/SimpleText/SimpleTextTermVectorsReader.cs
+++ b/src/Lucene.Net.Codecs/SimpleText/SimpleTextTermVectorsReader.cs
@@ -260,7 +260,7 @@ namespace Lucene.Net.Codecs.SimpleText
         private int ParseIntAt(int offset) // LUCENENET TODO: Rename ParseInt32At ?
         {
             UnicodeUtil.UTF8toUTF16(_scratch.Bytes, _scratch.Offset + offset, _scratch.Length - offset, _scratchUtf16);
-            return ArrayUtil.ParseInt(_scratchUtf16.Chars, 0, _scratchUtf16.Length);
+            return ArrayUtil.ParseInt32(_scratchUtf16.Chars, 0, _scratchUtf16.Length);
         }
 
         private string ReadString(int offset, BytesRef scratch)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Core/Analysis/NumericTokenStream.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Analysis/NumericTokenStream.cs b/src/Lucene.Net.Core/Analysis/NumericTokenStream.cs
index a6b75f9..039c171 100644
--- a/src/Lucene.Net.Core/Analysis/NumericTokenStream.cs
+++ b/src/Lucene.Net.Core/Analysis/NumericTokenStream.cs
@@ -178,11 +178,11 @@ namespace Lucene.Net.Analysis
                 Debug.Assert(ValueSize == 64 || ValueSize == 32);
                 if (ValueSize == 64)
                 {
-                    NumericUtils.LongToPrefixCoded(_value, Shift, _bytes);
+                    NumericUtils.Int64ToPrefixCoded(_value, Shift, _bytes);
                 }
                 else
                 {
-                    NumericUtils.IntToPrefixCoded((int)_value, Shift, _bytes);
+                    NumericUtils.Int32ToPrefixCoded((int)_value, Shift, _bytes);
                 }
             }
 
@@ -275,22 +275,28 @@ namespace Lucene.Net.Analysis
         }
 
         /// <summary>
-        /// Initializes the token stream with the supplied <code>long</code> value. </summary>
+        /// Initializes the token stream with the supplied <code>long</code> value. 
+        /// <para/>
+        /// NOTE: This was setLongValue() in Lucene
+        /// </summary>
         /// <param name="value"> the value, for which this TokenStream should enumerate tokens. </param>
         /// <returns> this instance, because of this you can use it the following way:
         /// <code>new Field(name, new NumericTokenStream(precisionStep).setLongValue(value))</code> </returns>
-        public NumericTokenStream SetLongValue(long value)
+        public NumericTokenStream SetInt64Value(long value)
         {
             numericAtt.Init(value, valSize = 64, precisionStep, -precisionStep);
             return this;
         }
 
         /// <summary>
-        /// Initializes the token stream with the supplied <code>int</code> value. </summary>
+        /// Initializes the token stream with the supplied <code>int</code> value.
+        /// <para/>
+        /// NOTE: This was setIntValue() in Lucene
+        /// </summary>
         /// <param name="value"> the value, for which this TokenStream should enumerate tokens. </param>
         /// <returns> this instance, because of this you can use it the following way:
         /// <code>new Field(name, new NumericTokenStream(precisionStep).setIntValue(value))</code> </returns>
-        public NumericTokenStream SetIntValue(int value)
+        public NumericTokenStream SetInt32Value(int value)
         {
             numericAtt.Init(value, valSize = 32, precisionStep, -precisionStep);
             return this;
@@ -303,18 +309,21 @@ namespace Lucene.Net.Analysis
         /// <code>new Field(name, new NumericTokenStream(precisionStep).setDoubleValue(value))</code> </returns>
         public NumericTokenStream SetDoubleValue(double value)
         {
-            numericAtt.Init(NumericUtils.DoubleToSortableLong(value), valSize = 64, precisionStep, -precisionStep);
+            numericAtt.Init(NumericUtils.DoubleToSortableInt64(value), valSize = 64, precisionStep, -precisionStep);
             return this;
         }
 
         /// <summary>
-        /// Initializes the token stream with the supplied <code>float</code> value. </summary>
+        /// Initializes the token stream with the supplied <code>float</code> value. 
+        /// <para/>
+        /// NOTE: This was setFloatValue() in Lucene
+        /// </summary>
         /// <param name="value"> the value, for which this TokenStream should enumerate tokens. </param>
         /// <returns> this instance, because of this you can use it the following way:
         /// <code>new Field(name, new NumericTokenStream(precisionStep).setFloatValue(value))</code> </returns>
-        public NumericTokenStream SetFloatValue(float value)
+        public NumericTokenStream SetSingleValue(float value)
         {
-            numericAtt.Init(NumericUtils.FloatToSortableInt(value), valSize = 32, precisionStep, -precisionStep);
+            numericAtt.Init(NumericUtils.SingleToSortableInt32(value), valSize = 32, precisionStep, -precisionStep);
             return this;
         }
 


[47/53] [abbrv] lucenenet git commit: Lucene.Net.Core.Util.Constants refactor: Renamed JAVA_VERSION > RUNTIME_VERSION, JAVA_VENDOR > RUNTIME_VENDOR, JRE_IS_64BIT > RUNTIME_IS_64BIT. Commented unused JVM_ constants. Refactored RUNTIME_VERSION to pull the

Posted by ni...@apache.org.
Lucene.Net.Core.Util.Constants refactor: Renamed JAVA_VERSION > RUNTIME_VERSION, JAVA_VENDOR > RUNTIME_VENDOR, JRE_IS_64BIT > RUNTIME_IS_64BIT. Commented unused JVM_ constants. Refactored RUNTIME_VERSION to pull the correct setting from System.Environment.Version in .NET Framework and parsed from RuntimeInformation.FrameworkDescription in .NET Core. Commented unused JVM_INFO_STRING constant in RamUsageEstimator.


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

Branch: refs/heads/api-work
Commit: 45bb8132c3f9385f9caf9d6818f880090599b472
Parents: aef5205
Author: Shad Storhaug <sh...@shadstorhaug.com>
Authored: Wed Feb 8 20:45:35 2017 +0700
Committer: Shad Storhaug <sh...@shadstorhaug.com>
Committed: Wed Feb 8 21:08:25 2017 +0700

----------------------------------------------------------------------
 src/Lucene.Net.Core/Index/IndexWriter.cs        |  4 +-
 src/Lucene.Net.Core/Store/FSDirectory.cs        |  2 +-
 src/Lucene.Net.Core/Store/MMapDirectory.cs      |  2 +-
 src/Lucene.Net.Core/Util/ArrayUtil.cs           |  2 +-
 src/Lucene.Net.Core/Util/Constants.cs           | 77 +++++++++++++++-----
 src/Lucene.Net.Core/Util/Fst/FST.cs             |  2 +-
 src/Lucene.Net.Core/Util/RamUsageEstimator.cs   | 21 +++---
 .../core/Util/TestRamUsageEstimator.cs          |  2 +-
 8 files changed, 76 insertions(+), 36 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/lucenenet/blob/45bb8132/src/Lucene.Net.Core/Index/IndexWriter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Index/IndexWriter.cs b/src/Lucene.Net.Core/Index/IndexWriter.cs
index 2155239..3bc5253 100644
--- a/src/Lucene.Net.Core/Index/IndexWriter.cs
+++ b/src/Lucene.Net.Core/Index/IndexWriter.cs
@@ -4846,8 +4846,8 @@ namespace Lucene.Net.Index
             diagnostics["os"] = Constants.OS_NAME;
             diagnostics["os.arch"] = Constants.OS_ARCH;
             diagnostics["os.version"] = Constants.OS_VERSION;
-            diagnostics["java.version"] = Constants.JAVA_VERSION;
-            diagnostics["java.vendor"] = Constants.JAVA_VENDOR;
+            diagnostics["java.version"] = Constants.RUNTIME_VERSION;
+            diagnostics["java.vendor"] = Constants.RUNTIME_VENDOR;
             diagnostics["timestamp"] = Convert.ToString((DateTime.Now));
             if (details != null)
             {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/45bb8132/src/Lucene.Net.Core/Store/FSDirectory.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Store/FSDirectory.cs b/src/Lucene.Net.Core/Store/FSDirectory.cs
index 8a53c23..538d484 100644
--- a/src/Lucene.Net.Core/Store/FSDirectory.cs
+++ b/src/Lucene.Net.Core/Store/FSDirectory.cs
@@ -177,7 +177,7 @@ namespace Lucene.Net.Store
         /// </summary>
         public static FSDirectory Open(DirectoryInfo path, LockFactory lockFactory)
         {
-            if ((Constants.WINDOWS || Constants.SUN_OS || Constants.LINUX) && Constants.JRE_IS_64BIT &&
+            if ((Constants.WINDOWS || Constants.SUN_OS || Constants.LINUX) && Constants.RUNTIME_IS_64BIT &&
                 MMapDirectory.UNMAP_SUPPORTED)
             {
                 return new MMapDirectory(path, lockFactory);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/45bb8132/src/Lucene.Net.Core/Store/MMapDirectory.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Store/MMapDirectory.cs b/src/Lucene.Net.Core/Store/MMapDirectory.cs
index bc31b73..4bd2868 100644
--- a/src/Lucene.Net.Core/Store/MMapDirectory.cs
+++ b/src/Lucene.Net.Core/Store/MMapDirectory.cs
@@ -77,7 +77,7 @@ namespace Lucene.Net.Store
         /// <summary>
         /// Default max chunk size. </summary>
         /// <seealso cref= #MMapDirectory(File, LockFactory, int) </seealso>
-        public static readonly int DEFAULT_MAX_BUFF = Constants.JRE_IS_64BIT ? (1 << 30) : (1 << 28);
+        public static readonly int DEFAULT_MAX_BUFF = Constants.RUNTIME_IS_64BIT ? (1 << 30) : (1 << 28);
 
         private readonly int chunkSizePower;
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/45bb8132/src/Lucene.Net.Core/Util/ArrayUtil.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/ArrayUtil.cs b/src/Lucene.Net.Core/Util/ArrayUtil.cs
index 9fc79e0..2d9ba0c 100644
--- a/src/Lucene.Net.Core/Util/ArrayUtil.cs
+++ b/src/Lucene.Net.Core/Util/ArrayUtil.cs
@@ -210,7 +210,7 @@ namespace Lucene.Net.Util
                 return int.MaxValue;
             }
 
-            if (Constants.JRE_IS_64BIT)
+            if (Constants.RUNTIME_IS_64BIT)
             {
                 // round up to 8 byte alignment in 64bit env
                 switch (bytesPerElement)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/45bb8132/src/Lucene.Net.Core/Util/Constants.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Constants.cs b/src/Lucene.Net.Core/Util/Constants.cs
index 4bfc54a..2b853e8 100644
--- a/src/Lucene.Net.Core/Util/Constants.cs
+++ b/src/Lucene.Net.Core/Util/Constants.cs
@@ -34,17 +34,31 @@ namespace Lucene.Net.Util
         {
         }
 
+        // LUCENENET NOTE: IMPORTANT - this line must be placed before RUNTIME_VERSION so it can be parsed.
+        private static Regex VERSION_PARSER = new Regex(@"(\d+\.\d+\.\d+\.\d+)", RegexOptions.Compiled);
+
         /// <summary>
-        /// The value of <tt>System.getProperty("java.version")</tt>. * </summary>
-        public static readonly string JAVA_VERSION = AppSettings.Get("java.version", "");
+#if NETSTANDARD
+        /// The value of the version parsed from <see cref="RuntimeInformation.FrameworkDescription"/>.
+#else
+        /// The value of <see cref="Environment.Version"/>.
+#endif
+        /// <para/>
+        /// NOTE: This was JAVA_VERSION in Lucene
+        /// </summary>
+        public static readonly string RUNTIME_VERSION = GetEnvironmentVariable("RUNTIME_VERSION", "?");
 
-        public static readonly string JAVA_VENDOR = AppSettings.Get("java.vendor", "");
-        public static readonly string JVM_VENDOR = AppSettings.Get("java.vm.vendor", "");
-        public static readonly string JVM_VERSION = AppSettings.Get("java.vm.version", "");
-        public static readonly string JVM_NAME = AppSettings.Get("java.vm.name", "");
 
         /// <summary>
-        /// The value of <tt>System.getProperty("os.name")</tt>. * </summary>
+        /// NOTE: This was JAVA_VENDOR in Lucene
+        /// </summary>
+        public static readonly string RUNTIME_VENDOR = "Microsoft"; // AppSettings.Get("java.vendor", "");
+        //public static readonly string JVM_VENDOR = AppSettings.Get("java.vm.vendor", "");
+        //public static readonly string JVM_VERSION = AppSettings.Get("java.vm.version", "");
+        //public static readonly string JVM_NAME = AppSettings.Get("java.vm.name", "");
+
+        /// <summary>
+        /// The value of <see cref="Environment.GetEnvironmentVariable(string)"/> with parameter "OS".</summary>
         public static readonly string OS_NAME = GetEnvironmentVariable("OS", "Windows_NT") ?? "Linux";
 
         /// <summary>
@@ -70,27 +84,29 @@ namespace Lucene.Net.Util
         public static readonly string OS_ARCH = GetEnvironmentVariable("PROCESSOR_ARCHITECTURE", "x86");
         public static readonly string OS_VERSION = GetEnvironmentVariable("OS_VERSION", "?");
 
-        [Obsolete("We are not running on Java for heavens sake")]
-        public static readonly bool JRE_IS_MINIMUM_JAVA6 = (bool)new bool?(true); // prevent inlining in foreign class files
-
-        [Obsolete("We are not running on Java for heavens sake")]
-        public static readonly bool JRE_IS_MINIMUM_JAVA7 = (bool)new bool?(true); // prevent inlining in foreign class files
+        //[Obsolete("We are not running on Java for heavens sake")]
+        //public static readonly bool JRE_IS_MINIMUM_JAVA6 = (bool)new bool?(true); // prevent inlining in foreign class files
 
-        [Obsolete("We are not running on Java for heavens sake")]
-        public static readonly bool JRE_IS_MINIMUM_JAVA8;
+        //[Obsolete("We are not running on Java for heavens sake")]
+        //public static readonly bool JRE_IS_MINIMUM_JAVA7 = (bool)new bool?(true); // prevent inlining in foreign class files
 
         //[Obsolete("We are not running on Java for heavens sake")]
-        public static readonly bool JRE_IS_64BIT; // LUCENENET NOTE: We still need this constant to indicate 64 bit runtime.
+        //public static readonly bool JRE_IS_MINIMUM_JAVA8;
+
+        /// <summary>
+        /// NOTE: This was JRE_IS_64BIT in Lucene
+        /// </summary>
+        public static readonly bool RUNTIME_IS_64BIT; // LUCENENET NOTE: We still need this constant to indicate 64 bit runtime.
 
         static Constants()
         {
             if (IntPtr.Size == 8)
             {
-                JRE_IS_64BIT = true;// 64 bit machine
+                RUNTIME_IS_64BIT = true;// 64 bit machine
             }
             else if (IntPtr.Size == 4)
             {
-                JRE_IS_64BIT = false;// 32 bit machine
+                RUNTIME_IS_64BIT = false;// 32 bit machine
             }
 
             try
@@ -130,7 +146,7 @@ namespace Lucene.Net.Util
                 }
               }
             }
-            JRE_IS_64BIT = is64Bit;
+            RUNTIME_IS_64BIT = is64Bit;
 
             // this method only exists in Java 8:
             bool v8 = true;
@@ -190,8 +206,9 @@ namespace Lucene.Net.Util
         }
 
         private static Regex MAIN_VERSION_WITHOUT_ALPHA_BETA = new Regex("\\.", RegexOptions.Compiled);
+        
 
-        #region MEDIUM-TRUST Support
+#region MEDIUM-TRUST Support
 
         private static string GetEnvironmentVariable(string variable, string defaultValueOnSecurityException)
         {
@@ -208,10 +225,20 @@ namespace Lucene.Net.Util
 				
 #if NETSTANDARD
                 if (variable == "PROCESSOR_ARCHITECTURE") {
+                    
                     return RuntimeInformation.OSArchitecture.ToString();
                 }
 #endif
 
+                if (variable == "RUNTIME_VERSION")
+                {
+#if NETSTANDARD
+                    return ExtractString(RuntimeInformation.FrameworkDescription, VERSION_PARSER);
+#else
+                    return Environment.Version.ToString();
+#endif
+                }
+
                 return System.Environment.GetEnvironmentVariable(variable);
             }
             catch (System.Security.SecurityException)
@@ -221,5 +248,17 @@ namespace Lucene.Net.Util
         }
 
 #endregion MEDIUM-TRUST Support
+
+        // LUCENENET TODO: Move to Support ?
+        /// <summary>
+        /// Extracts the first group matched with the regex as a new string.
+        /// </summary>
+        /// <param name="input">The string to examine</param>
+        /// <param name="pattern">A regex object to use to extract the string</param>
+        private static string ExtractString(string input, Regex pattern)
+        {
+            Match m = pattern.Match(input);
+            return (m.Groups.Count > 1) ? m.Groups[1].Value : string.Empty;
+        }
     }
 }
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/45bb8132/src/Lucene.Net.Core/Util/Fst/FST.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Fst/FST.cs b/src/Lucene.Net.Core/Util/Fst/FST.cs
index 8e187a0..88d4d4c 100644
--- a/src/Lucene.Net.Core/Util/Fst/FST.cs
+++ b/src/Lucene.Net.Core/Util/Fst/FST.cs
@@ -2070,7 +2070,7 @@ namespace Lucene.Net.Util.Fst
     /// </summary>
     public sealed class FST
     {
-        public static readonly int DEFAULT_MAX_BLOCK_BITS = Constants.JRE_IS_64BIT ? 30 : 28;
+        public static readonly int DEFAULT_MAX_BLOCK_BITS = Constants.RUNTIME_IS_64BIT ? 30 : 28;
 
         public FST()
         { }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/45bb8132/src/Lucene.Net.Core/Util/RamUsageEstimator.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/RamUsageEstimator.cs b/src/Lucene.Net.Core/Util/RamUsageEstimator.cs
index 1f5aaf5..589e10c 100644
--- a/src/Lucene.Net.Core/Util/RamUsageEstimator.cs
+++ b/src/Lucene.Net.Core/Util/RamUsageEstimator.cs
@@ -36,9 +36,9 @@ namespace Lucene.Net.Util
     /// @lucene.internal </seealso>
     public sealed class RamUsageEstimator
     {
-        /// <summary>
-        /// JVM info string for debugging and reports. </summary>
-        public static readonly string JVM_INFO_STRING;
+        ///// <summary>
+        ///// JVM info string for debugging and reports. </summary>
+        //public static readonly string JVM_INFO_STRING; // LUCENENET specific - this is not being used
 
         /// <summary>
         /// One kilobyte bytes. </summary>
@@ -124,12 +124,12 @@ namespace Lucene.Net.Util
 
             // Initialize empirically measured defaults. We'll modify them to the current
             // JVM settings later on if possible.
-            int referenceSize = Constants.JRE_IS_64BIT ? 8 : 4;
-            int objectHeader = Constants.JRE_IS_64BIT ? 16 : 8;
+            int referenceSize = Constants.RUNTIME_IS_64BIT ? 8 : 4;
+            int objectHeader = Constants.RUNTIME_IS_64BIT ? 16 : 8;
             // The following is objectHeader + NUM_BYTES_INT32, but aligned (object alignment)
             // so on 64 bit JVMs it'll be align(16 + 4, @8) = 24.
-            int arrayHeader = Constants.JRE_IS_64BIT ? 24 : 12;
-            int objectAlignment = Constants.JRE_IS_64BIT ? 8 : 4;
+            int arrayHeader = Constants.RUNTIME_IS_64BIT ? 24 : 12;
+            int objectAlignment = Constants.RUNTIME_IS_64BIT ? 8 : 4;
 
 
             /* LUCENENET TODO
@@ -163,8 +163,8 @@ namespace Lucene.Net.Util
 
             // "best guess" based on reference size. We will attempt to modify
             // these to exact values if there is supported infrastructure.
-            objectHeader = Constants.JRE_IS_64BIT ? (8 + referenceSize) : 8;
-		    arrayHeader = Constants.JRE_IS_64BIT ? (8 + 2 * referenceSize) : 12;
+            objectHeader = Constants.RUNTIME_IS_64BIT ? (8 + referenceSize) : 8;
+		    arrayHeader = Constants.RUNTIME_IS_64BIT ? (8 + 2 * referenceSize) : 12;
 
             /* LUCENENET TODO
              
@@ -234,7 +234,8 @@ namespace Lucene.Net.Util
 
             NUM_BYTES_OBJECT_ALIGNMENT = objectAlignment;
 
-            JVM_INFO_STRING = "[JVM: " + Constants.JVM_NAME + ", " + Constants.JVM_VERSION + ", " + Constants.JVM_VENDOR + ", " + Constants.JAVA_VENDOR + ", " + Constants.JAVA_VERSION + "]";
+            // LUCENENET specific - this is not being used
+            //JVM_INFO_STRING = "[JVM: " + Constants.JVM_NAME + ", " + Constants.JVM_VERSION + ", " + Constants.JVM_VENDOR + ", " + Constants.JAVA_VENDOR + ", " + Constants.JAVA_VERSION + "]";
         }
 
         /// <summary>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/45bb8132/src/Lucene.Net.Tests/core/Util/TestRamUsageEstimator.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Util/TestRamUsageEstimator.cs b/src/Lucene.Net.Tests/core/Util/TestRamUsageEstimator.cs
index b08739d..dc6fb9b 100644
--- a/src/Lucene.Net.Tests/core/Util/TestRamUsageEstimator.cs
+++ b/src/Lucene.Net.Tests/core/Util/TestRamUsageEstimator.cs
@@ -109,7 +109,7 @@ namespace Lucene.Net.Util
             //}
 
             Assert.IsTrue(RamUsageEstimator.NUM_BYTES_OBJECT_REF == 4 || RamUsageEstimator.NUM_BYTES_OBJECT_REF == 8);
-            if (!Constants.JRE_IS_64BIT)
+            if (!Constants.RUNTIME_IS_64BIT)
             {
                 assertEquals("For 32bit JVMs, reference size must always be 4?", 4, RamUsageEstimator.NUM_BYTES_OBJECT_REF);
             }


[16/53] [abbrv] lucenenet git commit: Lucene.Net.Highlighter: Renamed all type-derived properties and methods from Short, Int, Long, and Float to match CLR types Int16, Int32, Int64, and Single, respectively.

Posted by ni...@apache.org.
Lucene.Net.Highlighter: Renamed all type-derived properties and methods from Short, Int, Long, and Float to match CLR types Int16, Int32, Int64, and Single, respectively.


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

Branch: refs/heads/api-work
Commit: 76f687c4402a15530453778315a9de243e90960f
Parents: 67f5e6c
Author: Shad Storhaug <sh...@shadstorhaug.com>
Authored: Wed Feb 8 00:35:05 2017 +0700
Committer: Shad Storhaug <sh...@shadstorhaug.com>
Committed: Wed Feb 8 21:08:21 2017 +0700

----------------------------------------------------------------------
 .../Highlight/GradientFormatter.cs              | 47 +++++++++++---------
 .../Highlight/HighlighterTest.cs                |  2 +-
 2 files changed, 27 insertions(+), 22 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/lucenenet/blob/76f687c4/src/Lucene.Net.Highlighter/Highlight/GradientFormatter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Highlighter/Highlight/GradientFormatter.cs b/src/Lucene.Net.Highlighter/Highlight/GradientFormatter.cs
index fe386ca..a666e33 100644
--- a/src/Lucene.Net.Highlighter/Highlight/GradientFormatter.cs
+++ b/src/Lucene.Net.Highlighter/Highlight/GradientFormatter.cs
@@ -73,13 +73,13 @@ namespace Lucene.Net.Search.Highlight
                     throw new ArgumentException("minForegroundColor is not 7 bytes long eg a hex " 
                         + "RGB value such as #FFFFFF");
                 }
-                m_fgRMin = HexToInt(minForegroundColor.Substring(1, 3 - 1));
-                m_fgGMin = HexToInt(minForegroundColor.Substring(3, 5 - 3));
-                m_fgBMin = HexToInt(minForegroundColor.Substring(5, 7 - 5));
+                m_fgRMin = HexToInt32(minForegroundColor.Substring(1, 3 - 1));
+                m_fgGMin = HexToInt32(minForegroundColor.Substring(3, 5 - 3));
+                m_fgBMin = HexToInt32(minForegroundColor.Substring(5, 7 - 5));
 
-                m_fgRMax = HexToInt(maxForegroundColor.Substring(1, 3 - 1));
-                m_fgGMax = HexToInt(maxForegroundColor.Substring(3, 5 - 3));
-                m_fgBMax = HexToInt(maxForegroundColor.Substring(5, 7 - 5));
+                m_fgRMax = HexToInt32(maxForegroundColor.Substring(1, 3 - 1));
+                m_fgGMax = HexToInt32(maxForegroundColor.Substring(3, 5 - 3));
+                m_fgBMax = HexToInt32(maxForegroundColor.Substring(5, 7 - 5));
             }
 
             m_highlightBackground = (minBackgroundColor != null) 
@@ -96,13 +96,13 @@ namespace Lucene.Net.Search.Highlight
                     throw new ArgumentException("minBackgroundColor is not 7 bytes long eg a hex " 
                         + "RGB value such as #FFFFFF");
                 }
-                m_bgRMin = HexToInt(minBackgroundColor.Substring(1, 3 - 1));
-                m_bgGMin = HexToInt(minBackgroundColor.Substring(3, 5 - 3));
-                m_bgBMin = HexToInt(minBackgroundColor.Substring(5, 7 - 5));
+                m_bgRMin = HexToInt32(minBackgroundColor.Substring(1, 3 - 1));
+                m_bgGMin = HexToInt32(minBackgroundColor.Substring(3, 5 - 3));
+                m_bgBMin = HexToInt32(minBackgroundColor.Substring(5, 7 - 5));
 
-                m_bgRMax = HexToInt(maxBackgroundColor.Substring(1, 3 - 1));
-                m_bgGMax = HexToInt(maxBackgroundColor.Substring(3, 5 - 3));
-                m_bgBMax = HexToInt(maxBackgroundColor.Substring(5, 7 - 5));
+                m_bgRMax = HexToInt32(maxBackgroundColor.Substring(1, 3 - 1));
+                m_bgGMax = HexToInt32(maxBackgroundColor.Substring(3, 5 - 3));
+                m_bgBMax = HexToInt32(maxBackgroundColor.Substring(5, 7 - 5));
             }
             //        this.corpusReader = corpusReader;
             this.maxScore = maxScore;
@@ -146,9 +146,9 @@ namespace Lucene.Net.Search.Highlight
             int bVal = GetColorVal(m_fgBMin, m_fgBMax, score);
             var sb = new StringBuilder();
             sb.Append("#");
-            sb.Append(IntToHex(rVal));
-            sb.Append(IntToHex(gVal));
-            sb.Append(IntToHex(bVal));
+            sb.Append(Int32ToHex(rVal));
+            sb.Append(Int32ToHex(gVal));
+            sb.Append(Int32ToHex(bVal));
             return sb.ToString();
         }
 
@@ -159,9 +159,9 @@ namespace Lucene.Net.Search.Highlight
             int bVal = GetColorVal(m_bgBMin, m_bgBMax, score);
             var sb = new StringBuilder();
             sb.Append("#");
-            sb.Append(IntToHex(rVal));
-            sb.Append(IntToHex(gVal));
-            sb.Append(IntToHex(bVal));
+            sb.Append(Int32ToHex(rVal));
+            sb.Append(Int32ToHex(gVal));
+            sb.Append(Int32ToHex(bVal));
             return sb.ToString();
         }
 
@@ -180,13 +180,18 @@ namespace Lucene.Net.Search.Highlight
         private static char[] hexDigits = new char[] { '0', '1', '2', '3', '4', '5', '6', '7',
             '8', '9', 'A', 'B', 'C', 'D', 'E', 'F' };
 
-        private static string IntToHex(int i)
+        /// <summary>
+        /// NOTE: This was intToHex() in Lucene
+        /// </summary>
+        private static string Int32ToHex(int i)
         {
             return "" + hexDigits[(i & 0xF0) >> 4] + hexDigits[i & 0x0F];
         }
 
         /// <summary> 
-        /// Converts a hex string into an <see cref="int"/>. 
+        /// Converts a hex string into an <see cref="int"/>.
+        /// <para/>
+        /// NOTE: This was hexToInt() in Lucene
         /// </summary>
         /// <param name="hex">
         /// A string in capital or lower case hex, of no more then 16
@@ -194,7 +199,7 @@ namespace Lucene.Net.Search.Highlight
         /// </param>
         /// <exception cref="FormatException">if the string is more than 16 characters long, or if any
         /// character is not in the set [0-9a-fA-f]</exception>
-        public static int HexToInt(string hex)
+        public static int HexToInt32(string hex)
         {
             int len = hex.Length;
             if (len > 16)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/76f687c4/src/Lucene.Net.Tests.Highlighter/Highlight/HighlighterTest.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests.Highlighter/Highlight/HighlighterTest.cs b/src/Lucene.Net.Tests.Highlighter/Highlight/HighlighterTest.cs
index 84d00a8..33fe884 100644
--- a/src/Lucene.Net.Tests.Highlighter/Highlight/HighlighterTest.cs
+++ b/src/Lucene.Net.Tests.Highlighter/Highlight/HighlighterTest.cs
@@ -2026,7 +2026,7 @@ namespace Lucene.Net.Search.Highlight
         [Test, LuceneNetSpecific]
         public void TestGradientHighlighterHexToInt()
         {
-            int result = GradientFormatter.HexToInt("#CFFFFF".Substring(1, 3 - 1));
+            int result = GradientFormatter.HexToInt32("#CFFFFF".Substring(1, 3 - 1));
 
             assertEquals(207, result);
         }


[44/53] [abbrv] lucenenet git commit: Lucene.Net.Core.Util.SmallFloat refactor: Renamed sbyte overloads SByte instead of Byte, and added overloads for Byte (for CLS compliance)

Posted by ni...@apache.org.
Lucene.Net.Core.Util.SmallFloat refactor: Renamed sbyte overloads SByte instead of Byte, and added overloads for Byte (for CLS compliance)


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

Branch: refs/heads/api-work
Commit: 8ca0267c89d1410628da2eaa4bfe2f9d3cf67d16
Parents: 73cb5b2
Author: Shad Storhaug <sh...@shadstorhaug.com>
Authored: Wed Feb 8 16:54:19 2017 +0700
Committer: Shad Storhaug <sh...@shadstorhaug.com>
Committed: Wed Feb 8 21:08:24 2017 +0700

----------------------------------------------------------------------
 .../Search/Similarities/BM25Similarity.cs       |   4 +-
 .../Search/Similarities/DefaultSimilarity.cs    |   4 +-
 .../Search/Similarities/SimilarityBase.cs       |   4 +-
 src/Lucene.Net.Core/Util/SmallFloat.cs          | 122 ++++++++++++++++---
 .../core/Util/TestSmallFloat.cs                 |  32 ++---
 5 files changed, 125 insertions(+), 41 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8ca0267c/src/Lucene.Net.Core/Search/Similarities/BM25Similarity.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Search/Similarities/BM25Similarity.cs b/src/Lucene.Net.Core/Search/Similarities/BM25Similarity.cs
index 86ae76f..584640b 100644
--- a/src/Lucene.Net.Core/Search/Similarities/BM25Similarity.cs
+++ b/src/Lucene.Net.Core/Search/Similarities/BM25Similarity.cs
@@ -108,7 +108,7 @@ namespace Lucene.Net.Search.Similarities
         /// </summary>
         protected internal virtual sbyte EncodeNormValue(float boost, int fieldLength) // LUCENENET TODO: Can we use byte?
         {
-            return SmallSingle.SingleToByte315(boost / (float)Math.Sqrt(fieldLength));
+            return SmallSingle.SingleToSByte315(boost / (float)Math.Sqrt(fieldLength));
         }
 
         /// <summary>
@@ -151,7 +151,7 @@ namespace Lucene.Net.Search.Similarities
         {
             for (int i = 0; i < 256; i++)
             {
-                float f = SmallSingle.Byte315ToSingle((sbyte)i);
+                float f = SmallSingle.SByte315ToSingle((sbyte)i);
                 NORM_TABLE[i] = 1.0f / (f * f);
             }
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8ca0267c/src/Lucene.Net.Core/Search/Similarities/DefaultSimilarity.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Search/Similarities/DefaultSimilarity.cs b/src/Lucene.Net.Core/Search/Similarities/DefaultSimilarity.cs
index b2a84a9..e96f2c8 100644
--- a/src/Lucene.Net.Core/Search/Similarities/DefaultSimilarity.cs
+++ b/src/Lucene.Net.Core/Search/Similarities/DefaultSimilarity.cs
@@ -54,7 +54,7 @@ namespace Lucene.Net.Search.Similarities
         {
             for (int i = 0; i < 256; i++)
             {
-                NORM_TABLE[i] = SmallSingle.Byte315ToSingle((sbyte)i);
+                NORM_TABLE[i] = SmallSingle.SByte315ToSingle((sbyte)i);
             }
         }
 
@@ -93,7 +93,7 @@ namespace Lucene.Net.Search.Similarities
         /// <seealso cref= Lucene.Net.Util.SmallSingle </seealso>
         public override sealed long EncodeNormValue(float f)
         {
-            return SmallSingle.SingleToByte315(f);
+            return SmallSingle.SingleToSByte315(f);
         }
 
         /// <summary>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8ca0267c/src/Lucene.Net.Core/Search/Similarities/SimilarityBase.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Search/Similarities/SimilarityBase.cs b/src/Lucene.Net.Core/Search/Similarities/SimilarityBase.cs
index 4ddaeb6..d0c4e18 100644
--- a/src/Lucene.Net.Core/Search/Similarities/SimilarityBase.cs
+++ b/src/Lucene.Net.Core/Search/Similarities/SimilarityBase.cs
@@ -235,7 +235,7 @@ namespace Lucene.Net.Search.Similarities
         {
             for (int i = 0; i < 256; i++)
             {
-                float floatNorm = SmallSingle.Byte315ToSingle((sbyte)i);
+                float floatNorm = SmallSingle.SByte315ToSingle((sbyte)i);
                 NORM_TABLE[i] = 1.0f / (floatNorm * floatNorm);
             }
         }
@@ -268,7 +268,7 @@ namespace Lucene.Net.Search.Similarities
         /// Encodes the length to a byte via SmallFloat. </summary>
         protected internal virtual sbyte EncodeNormValue(float boost, float length) // LUCENENET TODO: Can this be byte?
         {
-            return SmallSingle.SingleToByte315((boost / (float)Math.Sqrt(length)));
+            return SmallSingle.SingleToSByte315((boost / (float)Math.Sqrt(length)));
         }
 
         // ----------------------------- Static methods ------------------------------

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8ca0267c/src/Lucene.Net.Core/Util/SmallFloat.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/SmallFloat.cs b/src/Lucene.Net.Core/Util/SmallFloat.cs
index 2bff9ff..7eb3b07 100644
--- a/src/Lucene.Net.Core/Util/SmallFloat.cs
+++ b/src/Lucene.Net.Core/Util/SmallFloat.cs
@@ -35,19 +35,37 @@ namespace Lucene.Net.Util
         }
 
         /// <summary>
-        /// Converts a 32 bit float to an 8 bit float.
+        /// Converts a 32 bit <see cref="float"/> to an 8 bit <see cref="float"/>.
         /// <br>Values less than zero are all mapped to zero.
         /// <br>Values are truncated (rounded down) to the nearest 8 bit value.
         /// <br>Values between zero and the smallest representable value
         /// are rounded up.
+        /// </summary>
+        /// <param name="f"> the 32 bit <see cref="float"/> to be converted to an 8 bit <see cref="float"/> (<see cref="byte"/>)  </param>
+        /// <param name="numMantissaBits"> the number of mantissa bits to use in the byte, with the remainder to be used in the exponent </param>
+        /// <param name="zeroExp"> the zero-point in the range of exponent values </param>
+        /// <returns> the 8 bit float representation </returns>
+        // LUCENENET specific overload for CLS compliance
+        public static byte SingleToByte(float f, int numMantissaBits, int zeroExp)
+        {
+            return (byte)SingleToSByte(f, numMantissaBits, zeroExp);
+        }
+
+        /// <summary>
+        /// Converts a 32 bit <see cref="float"/> to an 8 bit <see cref="float"/>.
+        /// <para/>Values less than zero are all mapped to zero.
+        /// <para/>Values are truncated (rounded down) to the nearest 8 bit value.
+        /// <para/>Values between zero and the smallest representable value
+        /// are rounded up.
         /// <para/>
         /// NOTE: This was floatToByte() in Lucene
         /// </summary>
-        /// <param name="f"> the 32 bit float to be converted to an 8 bit float (byte) </param>
+        /// <param name="f"> the 32 bit <see cref="float"/> to be converted to an 8 bit <see cref="float"/> (<see cref="sbyte"/>) </param>
         /// <param name="numMantissaBits"> the number of mantissa bits to use in the byte, with the remainder to be used in the exponent </param>
         /// <param name="zeroExp"> the zero-point in the range of exponent values </param>
         /// <returns> the 8 bit float representation </returns>
-        public static sbyte SingleToByte(float f, int numMantissaBits, int zeroExp) // LUCENENET TODO: can we remove the sbyte?
+        [CLSCompliant(false)]
+        public static sbyte SingleToSByte(float f, int numMantissaBits, int zeroExp)
         {
             // Adjustment from a float zero exponent to our zero exponent,
             // shifted over to our exponent position.
@@ -69,11 +87,23 @@ namespace Lucene.Net.Util
         }
 
         /// <summary>
-        /// Converts an 8 bit float to a 32 bit float. 
+        /// Converts an 8 bit <see cref="float"/> to a 32 bit <see cref="float"/>. 
+        /// <para/>
+        /// NOTE: This was byteToFloat() in Lucene
+        /// </summary>
+        // LUCENENET specific overload for CLS compliance
+        public static float ByteToSingle(byte b, int numMantissaBits, int zeroExp)
+        {
+            return SByteToSingle((sbyte)b, numMantissaBits, zeroExp);
+        }
+
+        /// <summary>
+        /// Converts an 8 bit <see cref="float"/> to a 32 bit <see cref="float"/>. 
         /// <para/>
         /// NOTE: This was byteToFloat() in Lucene
         /// </summary>
-        public static float ByteToSingle(sbyte b, int numMantissaBits, int zeroExp) // LUCENENET TODO: can we remove the sbyte?
+        [CLSCompliant(false)]
+        public static float SByteToSingle(sbyte b, int numMantissaBits, int zeroExp)
         {
             // on Java1.5 & 1.6 JVMs, prebuilding a decoding array and doing a lookup
             // is only a little bit faster (anywhere from 0% to 7%)
@@ -93,14 +123,29 @@ namespace Lucene.Net.Util
         //
 
         /// <summary>
-        /// floatToByte(b, mantissaBits=3, zeroExponent=15)
-        /// <br>smallest non-zero value = 5.820766E-10
-        /// <br>largest value = 7.5161928E9
-        /// <br>epsilon = 0.125
+        /// SingleToSByte((byte)b, mantissaBits=3, zeroExponent=15)
+        /// <para/>smallest non-zero value = 5.820766E-10
+        /// <para/>largest value = 7.5161928E9
+        /// <para/>epsilon = 0.125
+        /// <para/>
+        /// NOTE: This was floatToByte315() in Lucene
+        /// </summary>
+        // LUCENENET specific overload for CLS compliance
+        public static byte SingleToByte315(float f)
+        {
+            return (byte)SingleToSByte315(f);
+        }
+
+        /// <summary>
+        /// SingleToSByte(b, mantissaBits=3, zeroExponent=15)
+        /// <para/>smallest non-zero value = 5.820766E-10
+        /// <para/>largest value = 7.5161928E9
+        /// <para/>epsilon = 0.125
         /// <para/>
         /// NOTE: This was floatToByte315() in Lucene
         /// </summary>
-        public static sbyte SingleToByte315(float f) // LUCENENET TODO: can we remove the sbyte?
+        [CLSCompliant(false)]
+        public static sbyte SingleToSByte315(float f) 
         {
             int bits = BitConverter.ToInt32(BitConverter.GetBytes(f), 0);
             int smallfloat = bits >> (24 - 3);
@@ -116,11 +161,23 @@ namespace Lucene.Net.Util
         }
 
         /// <summary>
-        /// byteToFloat(b, mantissaBits=3, zeroExponent=15) 
+        /// ByteToSingle(b, mantissaBits=3, zeroExponent=15) 
         /// <para/>
         /// NOTE: This was byte315ToFloat() in Lucene
         /// </summary>
-        public static float Byte315ToSingle(sbyte b) // LUCENENET TODO: can we remove the sbyte?
+        // LUCENENET specific overload for CLS compliance
+        public static float Byte315ToSingle(byte b)
+        {
+            return SByte315ToSingle((sbyte)b);
+        }
+
+        /// <summary>
+        /// SByteToSingle(b, mantissaBits=3, zeroExponent=15) 
+        /// <para/>
+        /// NOTE: This was byte315ToFloat() in Lucene
+        /// </summary>
+        [CLSCompliant(false)]
+        public static float SByte315ToSingle(sbyte b)
         {
             // on Java1.5 & 1.6 JVMs, prebuilding a decoding array and doing a lookup
             // is only a little bit faster (anywhere from 0% to 7%)
@@ -134,14 +191,29 @@ namespace Lucene.Net.Util
         }
 
         /// <summary>
-        /// floatToByte(b, mantissaBits=5, zeroExponent=2)
-        /// <br>smallest nonzero value = 0.033203125
-        /// <br>largest value = 1984.0
-        /// <br>epsilon = 0.03125
+        /// SingleToByte(b, mantissaBits=5, zeroExponent=2)
+        /// <para/>smallest nonzero value = 0.033203125
+        /// <para/>largest value = 1984.0
+        /// <para/>epsilon = 0.03125
+        /// <para/>
+        /// NOTE: This was floatToByte52() in Lucene
+        /// </summary>
+        // LUCENENET specific overload for CLS compliance
+        public static byte SingleToByte52(float f)
+        {
+            return (byte)SingleToSByte315(f);
+        }
+
+        /// <summary>
+        /// SingleToSByte(b, mantissaBits=5, zeroExponent=2)
+        /// <para/>smallest nonzero value = 0.033203125
+        /// <para/>largest value = 1984.0
+        /// <para/>epsilon = 0.03125
         /// <para/>
         /// NOTE: This was floatToByte52() in Lucene
         /// </summary>
-        public static sbyte SingleToByte52(float f) // LUCENENET TODO: can we remove the sbyte?
+        [CLSCompliant(false)]
+        public static sbyte SingleToSByte52(float f)
         {
             int bits = BitConverter.ToInt32(BitConverter.GetBytes(f), 0);
             int smallfloat = bits >> (24 - 5);
@@ -157,11 +229,23 @@ namespace Lucene.Net.Util
         }
 
         /// <summary>
-        /// byteToFloat(b, mantissaBits=5, zeroExponent=2) 
+        /// ByteToFloat(b, mantissaBits=5, zeroExponent=2) 
+        /// <para/>
+        /// NOTE: This was byte52ToFloat() in Lucene
+        /// </summary>
+        // LUCENENET specific overload for CLS compliance
+        public static float Byte52ToSingle(byte b)
+        {
+            return SByte52ToSingle((sbyte)b);
+        }
+
+        /// <summary>
+        /// SByteToFloat(b, mantissaBits=5, zeroExponent=2) 
         /// <para/>
         /// NOTE: This was byte52ToFloat() in Lucene
         /// </summary>
-        public static float Byte52ToSingle(sbyte b) // LUCENENET TODO: can we remove the sbyte?
+        [CLSCompliant(false)]
+        public static float SByte52ToSingle(sbyte b)
         {
             // on Java1.5 & 1.6 JVMs, prebuilding a decoding array and doing a lookup
             // is only a little bit faster (anywhere from 0% to 7%)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8ca0267c/src/Lucene.Net.Tests/core/Util/TestSmallFloat.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Util/TestSmallFloat.cs b/src/Lucene.Net.Tests/core/Util/TestSmallFloat.cs
index 0fe0e8a..34d9b9b 100644
--- a/src/Lucene.Net.Tests/core/Util/TestSmallFloat.cs
+++ b/src/Lucene.Net.Tests/core/Util/TestSmallFloat.cs
@@ -106,13 +106,13 @@ namespace Lucene.Net.Util
             for (int i = 0; i < 256; i++)
             {
                 float f1 = Orig_byteToFloat((sbyte)i);
-                float f2 = SmallSingle.ByteToSingle((sbyte)i, 3, 15);
-                float f3 = SmallSingle.Byte315ToSingle((sbyte)i);
+                float f2 = SmallSingle.SByteToSingle((sbyte)i, 3, 15);
+                float f3 = SmallSingle.SByte315ToSingle((sbyte)i);
                 Assert.AreEqual(f1, f2, 0.0);
                 Assert.AreEqual(f2, f3, 0.0);
 
-                float f4 = SmallSingle.ByteToSingle((sbyte)i, 5, 2);
-                float f5 = SmallSingle.Byte52ToSingle((sbyte)i);
+                float f4 = SmallSingle.SByteToSingle((sbyte)i, 5, 2);
+                float f5 = SmallSingle.SByte52ToSingle((sbyte)i);
                 Assert.AreEqual(f4, f5, 0.0);
             }
         }
@@ -122,19 +122,19 @@ namespace Lucene.Net.Util
         {
             Assert.AreEqual(0, Orig_floatToByte_v13(5.8123817E-10f)); // verify the old bug (see LUCENE-2937)
             Assert.AreEqual(1, Orig_floatToByte(5.8123817E-10f)); // verify it's fixed in this test code
-            Assert.AreEqual(1, SmallSingle.SingleToByte315(5.8123817E-10f)); // verify it's fixed
+            Assert.AreEqual(1, SmallSingle.SingleToSByte315(5.8123817E-10f)); // verify it's fixed
 
             // test some constants
-            Assert.AreEqual(0, SmallSingle.SingleToByte315(0));
+            Assert.AreEqual(0, SmallSingle.SingleToSByte315(0));
             //Java's Float.MIN_VALUE equals C#'s float.Epsilon
-            Assert.AreEqual(1, SmallSingle.SingleToByte315(float.Epsilon)); // underflow rounds up to smallest positive
-            Assert.AreEqual(255, SmallSingle.SingleToByte315(float.MaxValue) & 0xff); // overflow rounds down to largest positive
-            Assert.AreEqual(255, SmallSingle.SingleToByte315(float.PositiveInfinity) & 0xff);
+            Assert.AreEqual(1, SmallSingle.SingleToSByte315(float.Epsilon)); // underflow rounds up to smallest positive
+            Assert.AreEqual(255, SmallSingle.SingleToSByte315(float.MaxValue) & 0xff); // overflow rounds down to largest positive
+            Assert.AreEqual(255, SmallSingle.SingleToSByte315(float.PositiveInfinity) & 0xff);
 
             // all negatives map to 0
-            Assert.AreEqual(0, SmallSingle.SingleToByte315(-float.Epsilon));
-            Assert.AreEqual(0, SmallSingle.SingleToByte315(-float.MaxValue));
-            Assert.AreEqual(0, SmallSingle.SingleToByte315(float.NegativeInfinity));
+            Assert.AreEqual(0, SmallSingle.SingleToSByte315(-float.Epsilon));
+            Assert.AreEqual(0, SmallSingle.SingleToSByte315(-float.MaxValue));
+            Assert.AreEqual(0, SmallSingle.SingleToSByte315(float.NegativeInfinity));
 
             // up iterations for more exhaustive test after changing something
             int num = AtLeast(100000);
@@ -146,13 +146,13 @@ namespace Lucene.Net.Util
                     continue;
                 }
                 sbyte b1 = Orig_floatToByte(f);
-                sbyte b2 = SmallSingle.SingleToByte(f, 3, 15);
-                sbyte b3 = SmallSingle.SingleToByte315(f);
+                sbyte b2 = SmallSingle.SingleToSByte(f, 3, 15);
+                sbyte b3 = SmallSingle.SingleToSByte315(f);
                 Assert.AreEqual(b1, b2);
                 Assert.AreEqual(b2, b3);
 
-                sbyte b4 = SmallSingle.SingleToByte(f, 5, 2);
-                sbyte b5 = SmallSingle.SingleToByte52(f);
+                sbyte b4 = SmallSingle.SingleToSByte(f, 5, 2);
+                sbyte b5 = SmallSingle.SingleToSByte52(f);
                 Assert.AreEqual(b4, b5);
             }
         }


[48/53] [abbrv] lucenenet git commit: Re-added System.Reflection namespace to Lucene.Net.Analysis.Util.TypeExtensions

Posted by ni...@apache.org.
Re-added System.Reflection namespace to Lucene.Net.Analysis.Util.TypeExtensions


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

Branch: refs/heads/api-work
Commit: 4a2850807e2aefef21184aaf6681d51167301e90
Parents: 45bb813
Author: Shad Storhaug <sh...@shadstorhaug.com>
Authored: Wed Feb 8 20:47:04 2017 +0700
Committer: Shad Storhaug <sh...@shadstorhaug.com>
Committed: Wed Feb 8 21:08:25 2017 +0700

----------------------------------------------------------------------
 src/Lucene.Net.Analysis.Common/Analysis/Util/TypeExtensions.cs | 1 +
 1 file changed, 1 insertion(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/lucenenet/blob/4a285080/src/Lucene.Net.Analysis.Common/Analysis/Util/TypeExtensions.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Analysis.Common/Analysis/Util/TypeExtensions.cs b/src/Lucene.Net.Analysis.Common/Analysis/Util/TypeExtensions.cs
index 2c53dc4..e6f5d2e 100644
--- a/src/Lucene.Net.Analysis.Common/Analysis/Util/TypeExtensions.cs
+++ b/src/Lucene.Net.Analysis.Common/Analysis/Util/TypeExtensions.cs
@@ -1,4 +1,5 @@
 \ufeffusing System;
+using System.Reflection;
 
 namespace Lucene.Net.Analysis.Util
 {


[20/53] [abbrv] lucenenet git commit: Lucene.Net.Core: Renamed all type-derived classes and interfaces from Short, Int, Long, and Float to match CLR types Int16, Int32, Int64, and Single, respectively.

Posted by ni...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Tests/core/Util/TestLongBitSet.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Util/TestLongBitSet.cs b/src/Lucene.Net.Tests/core/Util/TestLongBitSet.cs
index 7267536..0fa9acf 100644
--- a/src/Lucene.Net.Tests/core/Util/TestLongBitSet.cs
+++ b/src/Lucene.Net.Tests/core/Util/TestLongBitSet.cs
@@ -27,7 +27,7 @@ namespace Lucene.Net.Util
     [TestFixture]
     public class TestLongBitSet : LuceneTestCase
     {
-        internal virtual void DoGet(BitArray a, LongBitSet b)
+        internal virtual void DoGet(BitArray a, Int64BitSet b)
         {
             long max = b.Length;
             for (int i = 0; i < max; i++)
@@ -39,7 +39,7 @@ namespace Lucene.Net.Util
             }
         }
 
-        internal virtual void DoNextSetBit(BitArray a, LongBitSet b)
+        internal virtual void DoNextSetBit(BitArray a, Int64BitSet b)
         {
             int aa = -1;
             long bb = -1;
@@ -51,7 +51,7 @@ namespace Lucene.Net.Util
             } while (aa >= 0);
         }
 
-        internal virtual void DoPrevSetBit(BitArray a, LongBitSet b)
+        internal virtual void DoPrevSetBit(BitArray a, Int64BitSet b)
         {
             int aa = a.Length + Random().Next(100);
             long bb = aa;
@@ -86,13 +86,13 @@ namespace Lucene.Net.Util
         internal virtual void DoRandomSets(int maxSize, int iter, int mode)
         {
             BitArray a0 = null;
-            LongBitSet b0 = null;
+            Int64BitSet b0 = null;
 
             for (int i = 0; i < iter; i++)
             {
                 int sz = TestUtil.NextInt(Random(), 2, maxSize);
                 BitArray a = new BitArray(sz);
-                LongBitSet b = new LongBitSet(sz);
+                Int64BitSet b = new Int64BitSet(sz);
 
                 // test the various ways of setting bits
                 if (sz > 0)
@@ -140,7 +140,7 @@ namespace Lucene.Net.Util
                 toIndex = fromIndex + Random().Next(sz - fromIndex);
                 BitArray aa =  new BitArray(a);
                 aa.Flip(fromIndex, toIndex);
-                LongBitSet bb = b.Clone();
+                Int64BitSet bb = b.Clone();
                 bb.Flip(fromIndex, toIndex);
 
                 fromIndex = Random().Next(sz / 2);
@@ -178,14 +178,14 @@ namespace Lucene.Net.Util
                     BitArray a_andn = new BitArray(a);
                     a_andn.AndNot(a0);
 
-                    LongBitSet b_and = b.Clone();
+                    Int64BitSet b_and = b.Clone();
                     Assert.AreEqual(b, b_and);
                     b_and.And(b0);
-                    LongBitSet b_or = b.Clone();
+                    Int64BitSet b_or = b.Clone();
                     b_or.Or(b0);
-                    LongBitSet b_xor = b.Clone();
+                    Int64BitSet b_xor = b.Clone();
                     b_xor.Xor(b0);
-                    LongBitSet b_andn = b.Clone();
+                    Int64BitSet b_andn = b.Clone();
                     b_andn.AndNot(b0);
 
                     Assert.AreEqual(a0.Cardinality(), b0.Cardinality());
@@ -214,7 +214,7 @@ namespace Lucene.Net.Util
         [Test, LuceneNetSpecific]
         public void TestClearSmall()
         {
-            LongBitSet a = new LongBitSet(30);   // 0110010111001000101101001001110...0
+            Int64BitSet a = new Int64BitSet(30);   // 0110010111001000101101001001110...0
             int[] onesA = { 1, 2, 5, 7, 8, 9, 12, 16, 18, 19, 21, 24, 27, 28, 29 };
 
             for (int i = 0; i < onesA.size(); i++)
@@ -222,7 +222,7 @@ namespace Lucene.Net.Util
                 a.Set(onesA[i]);
             }
 
-            LongBitSet b = new LongBitSet(30);   // 0110000001001000101101001001110...0
+            Int64BitSet b = new Int64BitSet(30);   // 0110000001001000101101001001110...0
             int[] onesB = { 1, 2, 9, 12, 16, 18, 19, 21, 24, 27, 28, 29 };
 
             for (int i = 0; i < onesB.size(); i++)
@@ -248,8 +248,8 @@ namespace Lucene.Net.Util
             {
                 Random random = new Random();
                 int sz = AtLeast(1200);
-                LongBitSet a = new LongBitSet(sz);
-                LongBitSet b = new LongBitSet(sz);
+                Int64BitSet a = new Int64BitSet(sz);
+                Int64BitSet b = new Int64BitSet(sz);
                 int from = random.Next(sz - 1);
                 int to = random.Next(from, sz);
 
@@ -282,8 +282,8 @@ namespace Lucene.Net.Util
         {
             // this test can't handle numBits==0:
             int numBits = Random().Next(2000) + 1;
-            LongBitSet b1 = new LongBitSet(numBits);
-            LongBitSet b2 = new LongBitSet(numBits);
+            Int64BitSet b1 = new Int64BitSet(numBits);
+            Int64BitSet b2 = new Int64BitSet(numBits);
             Assert.IsTrue(b1.Equals(b2));
             Assert.IsTrue(b2.Equals(b1));
             for (int iter = 0; iter < 10 * RANDOM_MULTIPLIER; iter++)
@@ -309,8 +309,8 @@ namespace Lucene.Net.Util
         {
             // this test can't handle numBits==0:
             int numBits = Random().Next(2000) + 1;
-            LongBitSet b1 = new LongBitSet(numBits);
-            LongBitSet b2 = new LongBitSet(numBits);
+            Int64BitSet b1 = new Int64BitSet(numBits);
+            Int64BitSet b2 = new Int64BitSet(numBits);
             Assert.IsTrue(b1.Equals(b2));
             Assert.IsTrue(b2.Equals(b1));
             for (int iter = 0; iter < 10 * RANDOM_MULTIPLIER; iter++)
@@ -334,8 +334,8 @@ namespace Lucene.Net.Util
             // Make sure size 0-10 bit sets are OK:
             for (int numBits = 0; numBits < 10; numBits++)
             {
-                LongBitSet b1 = new LongBitSet(numBits);
-                LongBitSet b2 = new LongBitSet(numBits);
+                Int64BitSet b1 = new Int64BitSet(numBits);
+                Int64BitSet b2 = new Int64BitSet(numBits);
                 Assert.IsTrue(b1.Equals(b2));
                 Assert.AreEqual(b1.GetHashCode(), b2.GetHashCode());
                 Assert.AreEqual(0, b1.Cardinality());
@@ -349,22 +349,22 @@ namespace Lucene.Net.Util
             }
         }
 
-        private LongBitSet MakeLongFixedBitSet(int[] a, int numBits)
+        private Int64BitSet MakeLongFixedBitSet(int[] a, int numBits)
         {
-            LongBitSet bs;
+            Int64BitSet bs;
             if (Random().NextBoolean())
             {
-                int bits2words = LongBitSet.Bits2words(numBits);
+                int bits2words = Int64BitSet.Bits2words(numBits);
                 long[] words = new long[bits2words + Random().Next(100)];
                 for (int i = bits2words; i < words.Length; i++)
                 {
                     words[i] = Random().NextLong();
                 }
-                bs = new LongBitSet(words, numBits);
+                bs = new Int64BitSet(words, numBits);
             }
             else
             {
-                bs = new LongBitSet(numBits);
+                bs = new Int64BitSet(numBits);
             }
             foreach (int e in a)
             {
@@ -385,7 +385,7 @@ namespace Lucene.Net.Util
 
         private void CheckPrevSetBitArray(int[] a, int numBits)
         {
-            LongBitSet obs = MakeLongFixedBitSet(a, numBits);
+            Int64BitSet obs = MakeLongFixedBitSet(a, numBits);
             BitArray bs = MakeBitSet(a);
             DoPrevSetBit(bs, obs);
         }
@@ -400,7 +400,7 @@ namespace Lucene.Net.Util
 
         private void CheckNextSetBitArray(int[] a, int numBits)
         {
-            LongBitSet obs = MakeLongFixedBitSet(a, numBits);
+            Int64BitSet obs = MakeLongFixedBitSet(a, numBits);
             BitArray bs = MakeBitSet(a);
             DoNextSetBit(bs, obs);
         }
@@ -421,11 +421,11 @@ namespace Lucene.Net.Util
         [Test]
         public virtual void TestEnsureCapacity()
         {
-            LongBitSet bits = new LongBitSet(5);
+            Int64BitSet bits = new Int64BitSet(5);
             bits.Set(1);
             bits.Set(4);
 
-            LongBitSet newBits = LongBitSet.EnsureCapacity(bits, 8); // grow within the word
+            Int64BitSet newBits = Int64BitSet.EnsureCapacity(bits, 8); // grow within the word
             Assert.IsTrue(newBits.Get(1));
             Assert.IsTrue(newBits.Get(4));
             newBits.Clear(1);
@@ -434,11 +434,11 @@ namespace Lucene.Net.Util
             Assert.IsFalse(newBits.Get(1));
 
             newBits.Set(1);
-            newBits = LongBitSet.EnsureCapacity(newBits, newBits.Length - 2); // reuse
+            newBits = Int64BitSet.EnsureCapacity(newBits, newBits.Length - 2); // reuse
             Assert.IsTrue(newBits.Get(1));
 
             bits.Set(1);
-            newBits = LongBitSet.EnsureCapacity(bits, 72); // grow beyond one word
+            newBits = Int64BitSet.EnsureCapacity(bits, 72); // grow beyond one word
             Assert.IsTrue(newBits.Get(1));
             Assert.IsTrue(newBits.Get(4));
             newBits.Clear(1);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Tests/core/Util/TestNumericUtils.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Util/TestNumericUtils.cs b/src/Lucene.Net.Tests/core/Util/TestNumericUtils.cs
index ab14b15..5c3de83 100644
--- a/src/Lucene.Net.Tests/core/Util/TestNumericUtils.cs
+++ b/src/Lucene.Net.Tests/core/Util/TestNumericUtils.cs
@@ -242,7 +242,7 @@ namespace Lucene.Net.Util
         private void AssertLongRangeSplit(long lower, long upper, int precisionStep, bool useBitSet, IEnumerable<long> expectedBounds, IEnumerable<int> expectedShifts)
         {
             // Cannot use FixedBitSet since the range could be long:
-            LongBitSet bits = useBitSet ? new LongBitSet(upper - lower + 1) : null;
+            Int64BitSet bits = useBitSet ? new Int64BitSet(upper - lower + 1) : null;
             IEnumerator<long> neededBounds = (expectedBounds == null) ? null : expectedBounds.GetEnumerator();
             IEnumerator<int> neededShifts = (expectedShifts == null) ? null : expectedShifts.GetEnumerator();
 
@@ -256,18 +256,18 @@ namespace Lucene.Net.Util
             }
         }
 
-        private class LongRangeBuilderAnonymousInnerClassHelper : NumericUtils.LongRangeBuilder
+        private class LongRangeBuilderAnonymousInnerClassHelper : NumericUtils.Int64RangeBuilder
         {
             private readonly TestNumericUtils OuterInstance;
 
             private long Lower;
             private long Upper;
             private bool UseBitSet;
-            private LongBitSet Bits;
+            private Int64BitSet Bits;
             private IEnumerator<long> NeededBounds;
             private IEnumerator<int> NeededShifts;
 
-            public LongRangeBuilderAnonymousInnerClassHelper(TestNumericUtils outerInstance, long lower, long upper, bool useBitSet, LongBitSet bits, IEnumerator<long> neededBounds, IEnumerator<int> neededShifts)
+            public LongRangeBuilderAnonymousInnerClassHelper(TestNumericUtils outerInstance, long lower, long upper, bool useBitSet, Int64BitSet bits, IEnumerator<long> neededBounds, IEnumerator<int> neededShifts)
             {
                 this.OuterInstance = outerInstance;
                 this.Lower = lower;
@@ -456,7 +456,7 @@ namespace Lucene.Net.Util
             }
         }
 
-        private class IntRangeBuilderAnonymousInnerClassHelper : NumericUtils.IntRangeBuilder
+        private class IntRangeBuilderAnonymousInnerClassHelper : NumericUtils.Int32RangeBuilder
         {
             private readonly TestNumericUtils OuterInstance;
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Tests/core/Util/TestRecyclingIntBlockAllocator.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Util/TestRecyclingIntBlockAllocator.cs b/src/Lucene.Net.Tests/core/Util/TestRecyclingIntBlockAllocator.cs
index b218493..8d8ea32 100644
--- a/src/Lucene.Net.Tests/core/Util/TestRecyclingIntBlockAllocator.cs
+++ b/src/Lucene.Net.Tests/core/Util/TestRecyclingIntBlockAllocator.cs
@@ -23,7 +23,7 @@ namespace Lucene.Net.Util
      */
 
     /// <summary>
-    /// Testcase for <seealso cref="RecyclingIntBlockAllocator"/>
+    /// Testcase for <seealso cref="RecyclingInt32BlockAllocator"/>
     /// </summary>
     [TestFixture]
     public class TestRecyclingIntBlockAllocator : LuceneTestCase
@@ -34,15 +34,15 @@ namespace Lucene.Net.Util
             base.SetUp();
         }
 
-        private RecyclingIntBlockAllocator NewAllocator()
+        private RecyclingInt32BlockAllocator NewAllocator()
         {
-            return new RecyclingIntBlockAllocator(1 << (2 + Random().Next(15)), Random().Next(97), Util.Counter.NewCounter());
+            return new RecyclingInt32BlockAllocator(1 << (2 + Random().Next(15)), Random().Next(97), Util.Counter.NewCounter());
         }
 
         [Test]
         public virtual void TestAllocate()
         {
-            RecyclingIntBlockAllocator allocator = NewAllocator();
+            RecyclingInt32BlockAllocator allocator = NewAllocator();
             HashSet<int[]> set = new HashSet<int[]>();
             int[] block = allocator.GetInt32Block();
             set.Add(block);
@@ -64,7 +64,7 @@ namespace Lucene.Net.Util
         [Test]
         public virtual void TestAllocateAndRecycle()
         {
-            RecyclingIntBlockAllocator allocator = NewAllocator();
+            RecyclingInt32BlockAllocator allocator = NewAllocator();
             HashSet<int[]> allocated = new HashSet<int[]>();
 
             int[] block = allocator.GetInt32Block();
@@ -106,7 +106,7 @@ namespace Lucene.Net.Util
         [Test]
         public virtual void TestAllocateAndFree()
         {
-            RecyclingIntBlockAllocator allocator = NewAllocator();
+            RecyclingInt32BlockAllocator allocator = NewAllocator();
             HashSet<int[]> allocated = new HashSet<int[]>();
             int freeButAllocated = 0;
             int[] block = allocator.GetInt32Block();

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Tests/core/Util/TestSentinelIntSet.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Util/TestSentinelIntSet.cs b/src/Lucene.Net.Tests/core/Util/TestSentinelIntSet.cs
index bfb48ea..e5c4188 100644
--- a/src/Lucene.Net.Tests/core/Util/TestSentinelIntSet.cs
+++ b/src/Lucene.Net.Tests/core/Util/TestSentinelIntSet.cs
@@ -27,7 +27,7 @@ namespace Lucene.Net.Util
         [Test]
         public virtual void Test()
         {
-            SentinelIntSet set = new SentinelIntSet(10, -1);
+            SentinelInt32Set set = new SentinelInt32Set(10, -1);
             Assert.IsFalse(set.Exists(50));
             set.Put(50);
             Assert.IsTrue(set.Exists(50));
@@ -56,7 +56,7 @@ namespace Lucene.Net.Util
                 int maxVal = (Random().NextBoolean() ? Random().Next(50) : Random().Next(int.MaxValue)) + 1;
 
                 HashSet<int> a = new HashSet<int>(/*initSz*/);
-                SentinelIntSet b = new SentinelIntSet(initSz, -1);
+                SentinelInt32Set b = new SentinelInt32Set(initSz, -1);
 
                 for (int j = 0; j < num; j++)
                 {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Tests/core/Util/TestSmallFloat.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Util/TestSmallFloat.cs b/src/Lucene.Net.Tests/core/Util/TestSmallFloat.cs
index a933ccd..0fe0e8a 100644
--- a/src/Lucene.Net.Tests/core/Util/TestSmallFloat.cs
+++ b/src/Lucene.Net.Tests/core/Util/TestSmallFloat.cs
@@ -106,13 +106,13 @@ namespace Lucene.Net.Util
             for (int i = 0; i < 256; i++)
             {
                 float f1 = Orig_byteToFloat((sbyte)i);
-                float f2 = SmallFloat.ByteToSingle((sbyte)i, 3, 15);
-                float f3 = SmallFloat.Byte315ToSingle((sbyte)i);
+                float f2 = SmallSingle.ByteToSingle((sbyte)i, 3, 15);
+                float f3 = SmallSingle.Byte315ToSingle((sbyte)i);
                 Assert.AreEqual(f1, f2, 0.0);
                 Assert.AreEqual(f2, f3, 0.0);
 
-                float f4 = SmallFloat.ByteToSingle((sbyte)i, 5, 2);
-                float f5 = SmallFloat.Byte52ToSingle((sbyte)i);
+                float f4 = SmallSingle.ByteToSingle((sbyte)i, 5, 2);
+                float f5 = SmallSingle.Byte52ToSingle((sbyte)i);
                 Assert.AreEqual(f4, f5, 0.0);
             }
         }
@@ -122,19 +122,19 @@ namespace Lucene.Net.Util
         {
             Assert.AreEqual(0, Orig_floatToByte_v13(5.8123817E-10f)); // verify the old bug (see LUCENE-2937)
             Assert.AreEqual(1, Orig_floatToByte(5.8123817E-10f)); // verify it's fixed in this test code
-            Assert.AreEqual(1, SmallFloat.SingleToByte315(5.8123817E-10f)); // verify it's fixed
+            Assert.AreEqual(1, SmallSingle.SingleToByte315(5.8123817E-10f)); // verify it's fixed
 
             // test some constants
-            Assert.AreEqual(0, SmallFloat.SingleToByte315(0));
+            Assert.AreEqual(0, SmallSingle.SingleToByte315(0));
             //Java's Float.MIN_VALUE equals C#'s float.Epsilon
-            Assert.AreEqual(1, SmallFloat.SingleToByte315(float.Epsilon)); // underflow rounds up to smallest positive
-            Assert.AreEqual(255, SmallFloat.SingleToByte315(float.MaxValue) & 0xff); // overflow rounds down to largest positive
-            Assert.AreEqual(255, SmallFloat.SingleToByte315(float.PositiveInfinity) & 0xff);
+            Assert.AreEqual(1, SmallSingle.SingleToByte315(float.Epsilon)); // underflow rounds up to smallest positive
+            Assert.AreEqual(255, SmallSingle.SingleToByte315(float.MaxValue) & 0xff); // overflow rounds down to largest positive
+            Assert.AreEqual(255, SmallSingle.SingleToByte315(float.PositiveInfinity) & 0xff);
 
             // all negatives map to 0
-            Assert.AreEqual(0, SmallFloat.SingleToByte315(-float.Epsilon));
-            Assert.AreEqual(0, SmallFloat.SingleToByte315(-float.MaxValue));
-            Assert.AreEqual(0, SmallFloat.SingleToByte315(float.NegativeInfinity));
+            Assert.AreEqual(0, SmallSingle.SingleToByte315(-float.Epsilon));
+            Assert.AreEqual(0, SmallSingle.SingleToByte315(-float.MaxValue));
+            Assert.AreEqual(0, SmallSingle.SingleToByte315(float.NegativeInfinity));
 
             // up iterations for more exhaustive test after changing something
             int num = AtLeast(100000);
@@ -146,13 +146,13 @@ namespace Lucene.Net.Util
                     continue;
                 }
                 sbyte b1 = Orig_floatToByte(f);
-                sbyte b2 = SmallFloat.SingleToByte(f, 3, 15);
-                sbyte b3 = SmallFloat.SingleToByte315(f);
+                sbyte b2 = SmallSingle.SingleToByte(f, 3, 15);
+                sbyte b3 = SmallSingle.SingleToByte315(f);
                 Assert.AreEqual(b1, b2);
                 Assert.AreEqual(b2, b3);
 
-                sbyte b4 = SmallFloat.SingleToByte(f, 5, 2);
-                sbyte b5 = SmallFloat.SingleToByte52(f);
+                sbyte b4 = SmallSingle.SingleToByte(f, 5, 2);
+                sbyte b5 = SmallSingle.SingleToByte52(f);
                 Assert.AreEqual(b4, b5);
             }
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Tests/core/Util/TestUnicodeUtil.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Util/TestUnicodeUtil.cs b/src/Lucene.Net.Tests/core/Util/TestUnicodeUtil.cs
index d4d40a7..67dc330 100644
--- a/src/Lucene.Net.Tests/core/Util/TestUnicodeUtil.cs
+++ b/src/Lucene.Net.Tests/core/Util/TestUnicodeUtil.cs
@@ -158,7 +158,7 @@ namespace Lucene.Net.Util
         public virtual void TestUTF8toUTF32()
         {
             BytesRef utf8 = new BytesRef(20);
-            IntsRef utf32 = new IntsRef(20);
+            Int32sRef utf32 = new Int32sRef(20);
             int[] codePoints = new int[20];
             int num = AtLeast(50000);
             for (int i = 0; i < num; i++)


[35/53] [abbrv] lucenenet git commit: Lucene.Net.Facet: Renamed all type-derived classes and interfaces from Short, Int, Long, and Float to match CLR types Int16, Int32, Int64, and Single, respectively.

Posted by ni...@apache.org.
Lucene.Net.Facet: Renamed all type-derived classes and interfaces from Short, Int, Long, and Float to match CLR types Int16, Int32, Int64, and Single, respectively.


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

Branch: refs/heads/api-work
Commit: c34853169551552110c399f150eadf7e89bb8527
Parents: d3dfb95
Author: Shad Storhaug <sh...@shadstorhaug.com>
Authored: Wed Feb 8 02:50:32 2017 +0700
Committer: Shad Storhaug <sh...@shadstorhaug.com>
Committed: Wed Feb 8 21:08:23 2017 +0700

----------------------------------------------------------------------
 src/Lucene.Net.Facet/FacetsConfig.cs            |  8 ++---
 src/Lucene.Net.Facet/Range/DoubleRange.cs       |  4 +--
 .../Range/DoubleRangeFacetCounts.cs             |  6 ++--
 src/Lucene.Net.Facet/Range/LongRange.cs         | 14 ++++----
 src/Lucene.Net.Facet/Range/LongRangeCounter.cs  | 36 +++++++++++---------
 .../Range/LongRangeFacetCounts.cs               | 25 +++++++-------
 .../SortedSet/SortedSetDocValuesFacetCounts.cs  | 10 +++---
 .../Taxonomy/AssociationFacetField.cs           |  4 +--
 src/Lucene.Net.Facet/Taxonomy/FacetLabel.cs     |  4 +--
 .../Taxonomy/FastTaxonomyFacetCounts.cs         |  2 +-
 .../Taxonomy/FloatAssociationFacetField.cs      | 16 +++++----
 .../Taxonomy/FloatTaxonomyFacets.cs             | 16 +++++----
 .../Taxonomy/IntAssociationFacetField.cs        |  8 +++--
 .../Taxonomy/IntTaxonomyFacets.cs               | 17 ++++-----
 .../Taxonomy/TaxonomyFacetCounts.cs             |  2 +-
 .../TaxonomyFacetSumFloatAssociations.cs        | 16 +++++----
 .../Taxonomy/TaxonomyFacetSumIntAssociations.cs | 16 +++++----
 .../Taxonomy/TaxonomyFacetSumValueSource.cs     |  2 +-
 .../WriterCache/LruTaxonomyWriterCache.cs       |  6 ++--
 .../Taxonomy/WriterCache/NameHashIntCacheLRU.cs |  8 +++--
 .../Taxonomy/WriterCache/NameIntCacheLRU.cs     |  6 ++--
 src/Lucene.Net.Facet/TopOrdAndFloatQueue.cs     | 10 +++---
 src/Lucene.Net.Facet/TopOrdAndIntQueue.cs       | 10 +++---
 .../Range/TestRangeFacetCounts.cs               | 26 +++++++-------
 .../Taxonomy/TestFacetLabel.cs                  | 12 +++----
 .../Taxonomy/TestTaxonomyFacetAssociations.cs   | 28 +++++++--------
 26 files changed, 169 insertions(+), 143 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/lucenenet/blob/c3485316/src/Lucene.Net.Facet/FacetsConfig.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Facet/FacetsConfig.cs b/src/Lucene.Net.Facet/FacetsConfig.cs
index 61fe046..ae6775d 100644
--- a/src/Lucene.Net.Facet/FacetsConfig.cs
+++ b/src/Lucene.Net.Facet/FacetsConfig.cs
@@ -32,10 +32,10 @@ namespace Lucene.Net.Facet
     using Document = Lucene.Net.Documents.Document;
     using FacetLabel = Lucene.Net.Facet.Taxonomy.FacetLabel;
     using Field = Lucene.Net.Documents.Field;
-    using FloatAssociationFacetField = Lucene.Net.Facet.Taxonomy.FloatAssociationFacetField;
+    using SingleAssociationFacetField = Lucene.Net.Facet.Taxonomy.SingleAssociationFacetField;
     using IIndexableField = Lucene.Net.Index.IIndexableField;
     using IIndexableFieldType = Lucene.Net.Index.IIndexableFieldType;
-    using IntAssociationFacetField = Lucene.Net.Facet.Taxonomy.IntAssociationFacetField;
+    using Int32AssociationFacetField = Lucene.Net.Facet.Taxonomy.Int32AssociationFacetField;
     using Int32sRef = Lucene.Net.Util.Int32sRef;
     using SortedSetDocValuesFacetField = Lucene.Net.Facet.SortedSet.SortedSetDocValuesFacetField;
     using SortedSetDocValuesField = Lucene.Net.Documents.SortedSetDocValuesField;
@@ -357,11 +357,11 @@ namespace Lucene.Net.Facet
                     // Best effort: detect mis-matched types in same
                     // indexed field:
                     string type;
-                    if (facetField is IntAssociationFacetField)
+                    if (facetField is Int32AssociationFacetField)
                     {
                         type = "int";
                     }
-                    else if (facetField is FloatAssociationFacetField)
+                    else if (facetField is SingleAssociationFacetField)
                     {
                         type = "float";
                     }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/c3485316/src/Lucene.Net.Facet/Range/DoubleRange.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Facet/Range/DoubleRange.cs b/src/Lucene.Net.Facet/Range/DoubleRange.cs
index c8201bc..ed17c23 100644
--- a/src/Lucene.Net.Facet/Range/DoubleRange.cs
+++ b/src/Lucene.Net.Facet/Range/DoubleRange.cs
@@ -108,9 +108,9 @@ namespace Lucene.Net.Facet.Range
         /// <summary>
         /// NOTE: This was toLongRange() in Lucene
         /// </summary>
-        internal LongRange ToInt64Range()
+        internal Int64Range ToInt64Range()
         {
-            return new LongRange(Label, NumericUtils.DoubleToSortableInt64(minIncl), true, NumericUtils.DoubleToSortableInt64(maxIncl), true);
+            return new Int64Range(Label, NumericUtils.DoubleToSortableInt64(minIncl), true, NumericUtils.DoubleToSortableInt64(maxIncl), true);
         }
 
         public override string ToString()

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/c3485316/src/Lucene.Net.Facet/Range/DoubleRangeFacetCounts.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Facet/Range/DoubleRangeFacetCounts.cs b/src/Lucene.Net.Facet/Range/DoubleRangeFacetCounts.cs
index bf9c03e..efcfbcf 100644
--- a/src/Lucene.Net.Facet/Range/DoubleRangeFacetCounts.cs
+++ b/src/Lucene.Net.Facet/Range/DoubleRangeFacetCounts.cs
@@ -87,14 +87,14 @@ namespace Lucene.Net.Facet.Range
 
             DoubleRange[] ranges = (DoubleRange[])this.m_ranges;
 
-            LongRange[] longRanges = new LongRange[ranges.Length];
+            Int64Range[] longRanges = new Int64Range[ranges.Length];
             for (int i = 0; i < ranges.Length; i++)
             {
                 DoubleRange range = ranges[i];
-                longRanges[i] = new LongRange(range.Label, NumericUtils.DoubleToSortableInt64(range.minIncl), true, NumericUtils.DoubleToSortableInt64(range.maxIncl), true);
+                longRanges[i] = new Int64Range(range.Label, NumericUtils.DoubleToSortableInt64(range.minIncl), true, NumericUtils.DoubleToSortableInt64(range.maxIncl), true);
             }
 
-            LongRangeCounter counter = new LongRangeCounter(longRanges);
+            Int64RangeCounter counter = new Int64RangeCounter(longRanges);
 
             int missingCount = 0;
             foreach (MatchingDocs hits in matchingDocs)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/c3485316/src/Lucene.Net.Facet/Range/LongRange.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Facet/Range/LongRange.cs b/src/Lucene.Net.Facet/Range/LongRange.cs
index 8267328..ac75ef6 100644
--- a/src/Lucene.Net.Facet/Range/LongRange.cs
+++ b/src/Lucene.Net.Facet/Range/LongRange.cs
@@ -28,11 +28,13 @@ namespace Lucene.Net.Facet.Range
     using ValueSource = Lucene.Net.Queries.Function.ValueSource;
 
     /// <summary>
-    /// Represents a range over long values.
+    /// Represents a range over <see cref="long"/> values.
+    /// <para/>
+    /// NOTE: This was LongRange in Lucene
     /// 
     /// @lucene.experimental 
     /// </summary>
-    public sealed class LongRange : Range
+    public sealed class Int64Range : Range
     {
         internal readonly long minIncl;
         internal readonly long maxIncl;
@@ -57,8 +59,8 @@ namespace Lucene.Net.Facet.Range
         // Double/FloatRange too)
 
         /// <summary>
-        /// Create a LongRange. </summary>
-        public LongRange(string label, long minIn, bool minInclusive, long maxIn, bool maxInclusive)
+        /// Create a <see cref="Int64Range"/>. </summary>
+        public Int64Range(string label, long minIn, bool minInclusive, long maxIn, bool maxInclusive)
             : base(label)
         {
             this.Min = minIn;
@@ -118,12 +120,12 @@ namespace Lucene.Net.Facet.Range
 
         private class FilterAnonymousInnerClassHelper : Filter
         {
-            private readonly LongRange outerInstance;
+            private readonly Int64Range outerInstance;
 
             private readonly Filter fastMatchFilter;
             private readonly ValueSource valueSource;
 
-            public FilterAnonymousInnerClassHelper(LongRange outerInstance, Filter fastMatchFilter, ValueSource valueSource)
+            public FilterAnonymousInnerClassHelper(Int64Range outerInstance, Filter fastMatchFilter, ValueSource valueSource)
             {
                 this.outerInstance = outerInstance;
                 this.fastMatchFilter = fastMatchFilter;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/c3485316/src/Lucene.Net.Facet/Range/LongRangeCounter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Facet/Range/LongRangeCounter.cs b/src/Lucene.Net.Facet/Range/LongRangeCounter.cs
index b6581b3..02cddec 100644
--- a/src/Lucene.Net.Facet/Range/LongRangeCounter.cs
+++ b/src/Lucene.Net.Facet/Range/LongRangeCounter.cs
@@ -25,11 +25,13 @@ namespace Lucene.Net.Facet.Range
     /// Counts how many times each range was seen;
     /// per-hit it's just a binary search (<see cref="Add"/>)
     /// against the elementary intervals, and in the end we
-    /// rollup back to the original ranges. 
+    /// rollup back to the original ranges.
+    /// <para/>
+    /// NOTE: This was LongRangeCounter in Lucene
     /// </summary>
-    internal sealed class LongRangeCounter
+    internal sealed class Int64RangeCounter
     {
-        internal readonly LongRangeNode root;
+        internal readonly Int64RangeNode root;
         internal readonly long[] boundaries;
         internal readonly int[] leafCounts;
 
@@ -37,7 +39,7 @@ namespace Lucene.Net.Facet.Range
         private int leafUpto;
         private int missingCount;
 
-        public LongRangeCounter(LongRange[] ranges)
+        public Int64RangeCounter(Int64Range[] ranges)
         {
             // Maps all range inclusive endpoints to int flags; 1
             // = start of interval, 2 = end of interval.  We need to
@@ -49,7 +51,7 @@ namespace Lucene.Net.Facet.Range
             endsMap[long.MinValue] = 1;
             endsMap[long.MaxValue] = 2;
 
-            foreach (LongRange range in ranges)
+            foreach (Int64Range range in ranges)
             {
                 int? cur;
                 if (!endsMap.TryGetValue(range.minIncl, out cur))
@@ -216,7 +218,7 @@ namespace Lucene.Net.Facet.Range
             return missingCount;
         }
 
-        private int Rollup(LongRangeNode node, int[] counts, bool sawOutputs)
+        private int Rollup(Int64RangeNode node, int[] counts, bool sawOutputs)
         {
             int count;
             sawOutputs |= node.outputs != null;
@@ -248,20 +250,20 @@ namespace Lucene.Net.Facet.Range
             return count;
         }
 
-        private static LongRangeNode Split(int start, int end, IList<InclusiveRange> elementaryIntervals)
+        private static Int64RangeNode Split(int start, int end, IList<InclusiveRange> elementaryIntervals)
         {
             if (start == end - 1)
             {
                 // leaf
                 InclusiveRange range = elementaryIntervals[start];
-                return new LongRangeNode(range.Start, range.End, null, null, start);
+                return new Int64RangeNode(range.Start, range.End, null, null, start);
             }
             else
             {
                 int mid = (int)((uint)(start + end) >> 1);
-                LongRangeNode left = Split(start, mid, elementaryIntervals);
-                LongRangeNode right = Split(mid, end, elementaryIntervals);
-                return new LongRangeNode(left.start, right.end, left, right, -1);
+                Int64RangeNode left = Split(start, mid, elementaryIntervals);
+                Int64RangeNode right = Split(mid, end, elementaryIntervals);
+                return new Int64RangeNode(left.start, right.end, left, right, -1);
             }
         }
 
@@ -285,11 +287,13 @@ namespace Lucene.Net.Facet.Range
 
         /// <summary>
         /// Holds one node of the segment tree.
+        /// <para/>
+        /// NOTE: This was LongRangeNode in Lucene
         /// </summary>
-        public sealed class LongRangeNode
+        public sealed class Int64RangeNode
         {
-            internal readonly LongRangeNode left;
-            internal readonly LongRangeNode right;
+            internal readonly Int64RangeNode left;
+            internal readonly Int64RangeNode right;
 
             // Our range, inclusive:
             internal readonly long start;
@@ -303,7 +307,7 @@ namespace Lucene.Net.Facet.Range
             // through this node:
             internal IList<int?> outputs;
 
-            public LongRangeNode(long start, long end, LongRangeNode left, LongRangeNode right, int leafIndex)
+            public Int64RangeNode(long start, long end, Int64RangeNode left, Int64RangeNode right, int leafIndex)
             {
                 this.start = start;
                 this.end = end;
@@ -330,7 +334,7 @@ namespace Lucene.Net.Facet.Range
             /// <summary>
             /// Recursively assigns range outputs to each node.
             /// </summary>
-            internal void AddOutputs(int index, LongRange range)
+            internal void AddOutputs(int index, Int64Range range)
             {
                 if (start >= range.minIncl && end <= range.maxIncl)
                 {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/c3485316/src/Lucene.Net.Facet/Range/LongRangeFacetCounts.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Facet/Range/LongRangeFacetCounts.cs b/src/Lucene.Net.Facet/Range/LongRangeFacetCounts.cs
index 81debc7..4f80fba 100644
--- a/src/Lucene.Net.Facet/Range/LongRangeFacetCounts.cs
+++ b/src/Lucene.Net.Facet/Range/LongRangeFacetCounts.cs
@@ -36,40 +36,41 @@ namespace Lucene.Net.Facet.Range
     /// relative time based dimension like "Past day", "Past 2
     /// days", etc.) or that change for each request (e.g. 
     /// distance from the user's location, "&lt; 1 km", "&lt; 2 km",
-    ///  etc.).
+    /// etc.).
+    /// <para/>
+    /// NOTE: This was LongRangeFacetCounts in Lucene
     /// 
     ///  @lucene.experimental 
     /// </summary>
-    public class LongRangeFacetCounts : RangeFacetCounts
+    public class Int64RangeFacetCounts : RangeFacetCounts
     {
-
         /// <summary>
-        /// Create <see cref="LongRangeFacetCounts"/>, using
+        /// Create <see cref="Int64RangeFacetCounts"/>, using
         /// <see cref="LongFieldSource"/> from the specified field. 
         /// </summary>
-        public LongRangeFacetCounts(string field, FacetsCollector hits, params LongRange[] ranges)
+        public Int64RangeFacetCounts(string field, FacetsCollector hits, params Int64Range[] ranges)
             : this(field, new LongFieldSource(field), hits, ranges)
         {
         }
 
         /// <summary>
-        /// Create <see cref="RangeFacetCounts"/>, using the provided
+        /// Create <see cref="Int64RangeFacetCounts"/>, using the provided
         /// <see cref="ValueSource"/>. 
         /// </summary>
-        public LongRangeFacetCounts(string field, ValueSource valueSource, FacetsCollector hits, params LongRange[] ranges)
+        public Int64RangeFacetCounts(string field, ValueSource valueSource, FacetsCollector hits, params Int64Range[] ranges)
             : this(field, valueSource, hits, null, ranges)
         {
         }
 
         /// <summary>
-        /// Create <see cref="RangeFacetCounts"/>, using the provided
+        /// Create <see cref="Int64RangeFacetCounts"/>, using the provided
         /// <see cref="ValueSource"/>, and using the provided Filter as
         /// a fastmatch: only documents passing the filter are
         /// checked for the matching ranges.  The filter must be
         /// random access (implement <see cref="DocIdSet.Bits"/>). 
         /// </summary>
-        public LongRangeFacetCounts(string field, ValueSource valueSource, 
-            FacetsCollector hits, Filter fastMatchFilter, params LongRange[] ranges)
+        public Int64RangeFacetCounts(string field, ValueSource valueSource, 
+            FacetsCollector hits, Filter fastMatchFilter, params Int64Range[] ranges)
             : base(field, ranges, fastMatchFilter)
         {
             Count(valueSource, hits.GetMatchingDocs());
@@ -78,9 +79,9 @@ namespace Lucene.Net.Facet.Range
         private void Count(ValueSource valueSource, IList<MatchingDocs> matchingDocs)
         {
 
-            LongRange[] ranges = (LongRange[])this.m_ranges;
+            Int64Range[] ranges = (Int64Range[])this.m_ranges;
 
-            LongRangeCounter counter = new LongRangeCounter(ranges);
+            Int64RangeCounter counter = new Int64RangeCounter(ranges);
 
             int missingCount = 0;
             foreach (MatchingDocs hits in matchingDocs)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/c3485316/src/Lucene.Net.Facet/SortedSet/SortedSetDocValuesFacetCounts.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Facet/SortedSet/SortedSetDocValuesFacetCounts.cs b/src/Lucene.Net.Facet/SortedSet/SortedSetDocValuesFacetCounts.cs
index 5e1d0b5..bd385f0 100644
--- a/src/Lucene.Net.Facet/SortedSet/SortedSetDocValuesFacetCounts.cs
+++ b/src/Lucene.Net.Facet/SortedSet/SortedSetDocValuesFacetCounts.cs
@@ -92,14 +92,14 @@ namespace Lucene.Net.Facet.SortedSet
 
         private FacetResult GetDim(string dim, OrdRange ordRange, int topN)
         {
-            TopOrdAndIntQueue q = null;
+            TopOrdAndInt32Queue q = null;
 
             int bottomCount = 0;
 
             int dimCount = 0;
             int childCount = 0;
 
-            TopOrdAndIntQueue.OrdAndValue reuse = null;
+            TopOrdAndInt32Queue.OrdAndValue reuse = null;
             //System.out.println("getDim : " + ordRange.start + " - " + ordRange.end);
             for (int ord = ordRange.Start; ord <= ordRange.End; ord++)
             {
@@ -112,7 +112,7 @@ namespace Lucene.Net.Facet.SortedSet
                     {
                         if (reuse == null)
                         {
-                            reuse = new TopOrdAndIntQueue.OrdAndValue();
+                            reuse = new TopOrdAndInt32Queue.OrdAndValue();
                         }
                         reuse.Ord = ord;
                         reuse.Value = counts[ord];
@@ -120,7 +120,7 @@ namespace Lucene.Net.Facet.SortedSet
                         {
                             // Lazy init, so we don't create this for the
                             // sparse case unnecessarily
-                            q = new TopOrdAndIntQueue(topN);
+                            q = new TopOrdAndInt32Queue(topN);
                         }
                         reuse = q.InsertWithOverflow(reuse);
                         if (q.Count == topN)
@@ -139,7 +139,7 @@ namespace Lucene.Net.Facet.SortedSet
             LabelAndValue[] labelValues = new LabelAndValue[q.Count];
             for (int i = labelValues.Length - 1; i >= 0; i--)
             {
-                TopOrdAndIntQueue.OrdAndValue ordAndValue = q.Pop();
+                TopOrdAndInt32Queue.OrdAndValue ordAndValue = q.Pop();
                 var term = new BytesRef();
                 dv.LookupOrd(ordAndValue.Ord, term);
                 string[] parts = FacetsConfig.StringToPath(term.Utf8ToString());

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/c3485316/src/Lucene.Net.Facet/Taxonomy/AssociationFacetField.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Facet/Taxonomy/AssociationFacetField.cs b/src/Lucene.Net.Facet/Taxonomy/AssociationFacetField.cs
index 1e4731f..5085ea1 100644
--- a/src/Lucene.Net.Facet/Taxonomy/AssociationFacetField.cs
+++ b/src/Lucene.Net.Facet/Taxonomy/AssociationFacetField.cs
@@ -29,8 +29,8 @@ namespace Lucene.Net.Facet.Taxonomy
     /// Add an instance of this to your <see cref="Document"/> to add
     /// a facet label associated with an arbitrary <see cref="T:byte[]"/>.
     /// This will require a custom <see cref="Facets"/>
-    /// implementation at search time; see <see cref="IntAssociationFacetField"/> 
-    /// and <see cref="FloatAssociationFacetField"/> to use existing 
+    /// implementation at search time; see <see cref="Int32AssociationFacetField"/> 
+    /// and <see cref="SingleAssociationFacetField"/> to use existing 
     /// <see cref="Facets"/> implementations.
     /// 
     ///  @lucene.experimental 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/c3485316/src/Lucene.Net.Facet/Taxonomy/FacetLabel.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Facet/Taxonomy/FacetLabel.cs b/src/Lucene.Net.Facet/Taxonomy/FacetLabel.cs
index 1a54c0d..4904eec 100644
--- a/src/Lucene.Net.Facet/Taxonomy/FacetLabel.cs
+++ b/src/Lucene.Net.Facet/Taxonomy/FacetLabel.cs
@@ -23,7 +23,7 @@ namespace Lucene.Net.Facet.Taxonomy
      */
 
     using LruTaxonomyWriterCache = Lucene.Net.Facet.Taxonomy.WriterCache.LruTaxonomyWriterCache;
-    using NameHashIntCacheLRU = Lucene.Net.Facet.Taxonomy.WriterCache.NameHashIntCacheLRU;
+    using NameHashInt32CacheLRU = Lucene.Net.Facet.Taxonomy.WriterCache.NameHashInt32CacheLRU;
 
     /// <summary>
     /// Holds a sequence of string components, specifying the hierarchical name of a
@@ -177,7 +177,7 @@ namespace Lucene.Net.Facet.Taxonomy
 
         /// <summary>
         /// Calculate a 64-bit hash function for this path.  This
-        /// is necessary for <see cref="NameHashIntCacheLRU"/> (the
+        /// is necessary for <see cref="NameHashInt32CacheLRU"/> (the
         /// default cache impl for <see cref="LruTaxonomyWriterCache"/>) 
         /// to reduce the chance of "silent but deadly" collisions.
         /// <para/>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/c3485316/src/Lucene.Net.Facet/Taxonomy/FastTaxonomyFacetCounts.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Facet/Taxonomy/FastTaxonomyFacetCounts.cs b/src/Lucene.Net.Facet/Taxonomy/FastTaxonomyFacetCounts.cs
index 44909ca..26713ea 100644
--- a/src/Lucene.Net.Facet/Taxonomy/FastTaxonomyFacetCounts.cs
+++ b/src/Lucene.Net.Facet/Taxonomy/FastTaxonomyFacetCounts.cs
@@ -30,7 +30,7 @@ namespace Lucene.Net.Facet.Taxonomy
     /// 
     /// @lucene.experimental 
     /// </summary>
-    public class FastTaxonomyFacetCounts : IntTaxonomyFacets
+    public class FastTaxonomyFacetCounts : Int32TaxonomyFacets
     {
         /// <summary>
         /// Create <see cref="FastTaxonomyFacetCounts"/>, which also

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/c3485316/src/Lucene.Net.Facet/Taxonomy/FloatAssociationFacetField.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Facet/Taxonomy/FloatAssociationFacetField.cs b/src/Lucene.Net.Facet/Taxonomy/FloatAssociationFacetField.cs
index 1257ff6..8595a0f 100644
--- a/src/Lucene.Net.Facet/Taxonomy/FloatAssociationFacetField.cs
+++ b/src/Lucene.Net.Facet/Taxonomy/FloatAssociationFacetField.cs
@@ -25,18 +25,20 @@ namespace Lucene.Net.Facet.Taxonomy
 
     /// <summary>
     /// Add an instance of this to your <see cref="Document"/> to add
-    /// a facet label associated with a float.  Use <see cref="TaxonomyFacetSumFloatAssociations"/>
-    /// to aggregate float values per facet label at search time.
+    /// a facet label associated with a <see cref="float"/>.  Use <see cref="TaxonomyFacetSumSingleAssociations"/>
+    /// to aggregate <see cref="float"/> values per facet label at search time.
+    /// <para/>
+    /// NOTE: This was FloatAssociationFacetField in Lucene
     /// 
     ///  @lucene.experimental 
     /// </summary>
-    public class FloatAssociationFacetField : AssociationFacetField
+    public class SingleAssociationFacetField : AssociationFacetField
     {
         /// <summary>
         /// Creates this from <paramref name="dim"/> and <paramref name="path"/> and a
-        /// float association 
+        /// <see cref="float"/> association 
         /// </summary>
-        public FloatAssociationFacetField(float assoc, string dim, params string[] path) 
+        public SingleAssociationFacetField(float assoc, string dim, params string[] path) 
             : base(SingleToBytesRef(assoc), dim, path)
         {
         }
@@ -48,7 +50,7 @@ namespace Lucene.Net.Facet.Taxonomy
         /// </summary>
         public static BytesRef SingleToBytesRef(float v)
         {
-            return IntAssociationFacetField.Int32ToBytesRef(Number.SingleToInt32Bits(v));
+            return Int32AssociationFacetField.Int32ToBytesRef(Number.SingleToInt32Bits(v));
         }
 
         /// <summary>
@@ -58,7 +60,7 @@ namespace Lucene.Net.Facet.Taxonomy
         /// </summary>
         public static float BytesRefToSingle(BytesRef b)
         {
-            return Number.Int32BitsToSingle(IntAssociationFacetField.BytesRefToInt32(b));
+            return Number.Int32BitsToSingle(Int32AssociationFacetField.BytesRefToInt32(b));
         }
 
         public override string ToString()

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/c3485316/src/Lucene.Net.Facet/Taxonomy/FloatTaxonomyFacets.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Facet/Taxonomy/FloatTaxonomyFacets.cs b/src/Lucene.Net.Facet/Taxonomy/FloatTaxonomyFacets.cs
index 608300b..3549c6f 100644
--- a/src/Lucene.Net.Facet/Taxonomy/FloatTaxonomyFacets.cs
+++ b/src/Lucene.Net.Facet/Taxonomy/FloatTaxonomyFacets.cs
@@ -25,9 +25,11 @@ namespace Lucene.Net.Facet.Taxonomy
 
     /// <summary>
     /// Base class for all taxonomy-based facets that aggregate
-    /// to a per-ords <see cref="T:float[]"/>. 
+    /// to a per-ords <see cref="T:float[]"/>.
+    /// <para/>
+    /// NOTE: This was FloatTaxonomyFacets in Lucene
     /// </summary>
-    public abstract class FloatTaxonomyFacets : TaxonomyFacets
+    public abstract class SingleTaxonomyFacets : TaxonomyFacets
     {
         /// <summary>
         /// Per-ordinal value. </summary>
@@ -36,7 +38,7 @@ namespace Lucene.Net.Facet.Taxonomy
         /// <summary>
         /// Sole constructor.
         /// </summary>
-        protected FloatTaxonomyFacets(string indexFieldName, TaxonomyReader taxoReader, FacetsConfig config)
+        protected SingleTaxonomyFacets(string indexFieldName, TaxonomyReader taxoReader, FacetsConfig config)
             : base(indexFieldName, taxoReader, config)
         {
             m_values = new float[taxoReader.Count];
@@ -114,14 +116,14 @@ namespace Lucene.Net.Facet.Taxonomy
                 return null;
             }
 
-            TopOrdAndFloatQueue q = new TopOrdAndFloatQueue(Math.Min(m_taxoReader.Count, topN));
+            TopOrdAndSingleQueue q = new TopOrdAndSingleQueue(Math.Min(m_taxoReader.Count, topN));
             float bottomValue = 0;
 
             int ord = m_children[dimOrd];
             float sumValues = 0;
             int childCount = 0;
 
-            TopOrdAndFloatQueue.OrdAndValue reuse = null;
+            TopOrdAndSingleQueue.OrdAndValue reuse = null;
             while (ord != TaxonomyReader.INVALID_ORDINAL)
             {
                 if (m_values[ord] > 0)
@@ -132,7 +134,7 @@ namespace Lucene.Net.Facet.Taxonomy
                     {
                         if (reuse == null)
                         {
-                            reuse = new TopOrdAndFloatQueue.OrdAndValue();
+                            reuse = new TopOrdAndSingleQueue.OrdAndValue();
                         }
                         reuse.Ord = ord;
                         reuse.Value = m_values[ord];
@@ -172,7 +174,7 @@ namespace Lucene.Net.Facet.Taxonomy
             LabelAndValue[] labelValues = new LabelAndValue[q.Count];
             for (int i = labelValues.Length - 1; i >= 0; i--)
             {
-                TopOrdAndFloatQueue.OrdAndValue ordAndValue = q.Pop();
+                TopOrdAndSingleQueue.OrdAndValue ordAndValue = q.Pop();
                 FacetLabel child = m_taxoReader.GetPath(ordAndValue.Ord);
                 labelValues[i] = new LabelAndValue(child.Components[cp.Length], ordAndValue.Value);
             }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/c3485316/src/Lucene.Net.Facet/Taxonomy/IntAssociationFacetField.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Facet/Taxonomy/IntAssociationFacetField.cs b/src/Lucene.Net.Facet/Taxonomy/IntAssociationFacetField.cs
index 3385cdb..c657976 100644
--- a/src/Lucene.Net.Facet/Taxonomy/IntAssociationFacetField.cs
+++ b/src/Lucene.Net.Facet/Taxonomy/IntAssociationFacetField.cs
@@ -24,18 +24,20 @@ namespace Lucene.Net.Facet.Taxonomy
 
     /// <summary>
     /// Add an instance of this to your <see cref="Document"/> to add
-    /// a facet label associated with an int.  Use <see cref="TaxonomyFacetSumIntAssociations"/>
+    /// a facet label associated with an <see cref="int"/>.  Use <see cref="TaxonomyFacetSumInt32Associations"/>
     /// to aggregate int values per facet label at search time.
+    /// <para/>
+    /// NOTE: This was IntAssociationFacetField in Lucene
     /// 
     ///  @lucene.experimental 
     /// </summary>
-    public class IntAssociationFacetField : AssociationFacetField
+    public class Int32AssociationFacetField : AssociationFacetField
     {
         /// <summary>
         /// Creates this from <paramref name="dim"/> and <paramref name="path"/> and an
         /// int association 
         /// </summary>
-        public IntAssociationFacetField(int assoc, string dim, params string[] path)
+        public Int32AssociationFacetField(int assoc, string dim, params string[] path)
             : base(Int32ToBytesRef(assoc), dim, path)
         {
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/c3485316/src/Lucene.Net.Facet/Taxonomy/IntTaxonomyFacets.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Facet/Taxonomy/IntTaxonomyFacets.cs b/src/Lucene.Net.Facet/Taxonomy/IntTaxonomyFacets.cs
index 2b223e6..f1ac66f 100644
--- a/src/Lucene.Net.Facet/Taxonomy/IntTaxonomyFacets.cs
+++ b/src/Lucene.Net.Facet/Taxonomy/IntTaxonomyFacets.cs
@@ -24,10 +24,11 @@ namespace Lucene.Net.Facet.Taxonomy
 
     /// <summary>
     /// Base class for all taxonomy-based facets that aggregate
-    /// to a per-ords <see cref="T:int[]"/>. 
+    /// to a per-ords <see cref="T:int[]"/>.
+    /// <para/>
+    /// NOTE: This was IntTaxonomyFacets in Lucene
     /// </summary>
-
-    public abstract class IntTaxonomyFacets : TaxonomyFacets
+    public abstract class Int32TaxonomyFacets : TaxonomyFacets
     {
         /// <summary>
         /// Per-ordinal value. </summary>
@@ -36,7 +37,7 @@ namespace Lucene.Net.Facet.Taxonomy
         /// <summary>
         /// Sole constructor.
         /// </summary>
-        protected IntTaxonomyFacets(string indexFieldName, TaxonomyReader taxoReader, FacetsConfig config)
+        protected Int32TaxonomyFacets(string indexFieldName, TaxonomyReader taxoReader, FacetsConfig config)
             : base(indexFieldName, taxoReader, config)
         {
             m_values = new int[taxoReader.Count];
@@ -118,7 +119,7 @@ namespace Lucene.Net.Facet.Taxonomy
                 return null;
             }
 
-            TopOrdAndIntQueue q = new TopOrdAndIntQueue(Math.Min(m_taxoReader.Count, topN));
+            TopOrdAndInt32Queue q = new TopOrdAndInt32Queue(Math.Min(m_taxoReader.Count, topN));
 
             int bottomValue = 0;
 
@@ -126,7 +127,7 @@ namespace Lucene.Net.Facet.Taxonomy
             int totValue = 0;
             int childCount = 0;
 
-            TopOrdAndIntQueue.OrdAndValue reuse = null;
+            TopOrdAndInt32Queue.OrdAndValue reuse = null;
             while (ord != TaxonomyReader.INVALID_ORDINAL)
             {
                 if (m_values[ord] > 0)
@@ -137,7 +138,7 @@ namespace Lucene.Net.Facet.Taxonomy
                     {
                         if (reuse == null)
                         {
-                            reuse = new TopOrdAndIntQueue.OrdAndValue();
+                            reuse = new TopOrdAndInt32Queue.OrdAndValue();
                         }
                         reuse.Ord = ord;
                         reuse.Value = m_values[ord];
@@ -177,7 +178,7 @@ namespace Lucene.Net.Facet.Taxonomy
             LabelAndValue[] labelValues = new LabelAndValue[q.Count];
             for (int i = labelValues.Length - 1; i >= 0; i--)
             {
-                TopOrdAndIntQueue.OrdAndValue ordAndValue = q.Pop();
+                TopOrdAndInt32Queue.OrdAndValue ordAndValue = q.Pop();
                 FacetLabel child = m_taxoReader.GetPath(ordAndValue.Ord);
                 labelValues[i] = new LabelAndValue(child.Components[cp.Length], ordAndValue.Value);
             }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/c3485316/src/Lucene.Net.Facet/Taxonomy/TaxonomyFacetCounts.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Facet/Taxonomy/TaxonomyFacetCounts.cs b/src/Lucene.Net.Facet/Taxonomy/TaxonomyFacetCounts.cs
index 181cc45..0014366 100644
--- a/src/Lucene.Net.Facet/Taxonomy/TaxonomyFacetCounts.cs
+++ b/src/Lucene.Net.Facet/Taxonomy/TaxonomyFacetCounts.cs
@@ -30,7 +30,7 @@ namespace Lucene.Net.Facet.Taxonomy
     /// 
     /// @lucene.experimental 
     /// </summary>
-    public class TaxonomyFacetCounts : IntTaxonomyFacets
+    public class TaxonomyFacetCounts : Int32TaxonomyFacets
     {
         private readonly OrdinalsReader ordinalsReader;
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/c3485316/src/Lucene.Net.Facet/Taxonomy/TaxonomyFacetSumFloatAssociations.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Facet/Taxonomy/TaxonomyFacetSumFloatAssociations.cs b/src/Lucene.Net.Facet/Taxonomy/TaxonomyFacetSumFloatAssociations.cs
index b36474e..2b907cb 100644
--- a/src/Lucene.Net.Facet/Taxonomy/TaxonomyFacetSumFloatAssociations.cs
+++ b/src/Lucene.Net.Facet/Taxonomy/TaxonomyFacetSumFloatAssociations.cs
@@ -26,28 +26,30 @@ namespace Lucene.Net.Facet.Taxonomy
     using MatchingDocs = FacetsCollector.MatchingDocs;
 
     /// <summary>
-    /// Aggregates sum of int values previously indexed with
-    /// <see cref="FloatAssociationFacetField"/>, assuming the default
+    /// Aggregates sum of <see cref="float"/> values previously indexed with
+    /// <see cref="SingleAssociationFacetField"/>, assuming the default
     /// encoding.
+    /// <para/>
+    /// NOTE: This was TaxonomyFacetSumFloatAssociations in Lucene
     /// 
     ///  @lucene.experimental 
     /// </summary>
-    public class TaxonomyFacetSumFloatAssociations : FloatTaxonomyFacets
+    public class TaxonomyFacetSumSingleAssociations : SingleTaxonomyFacets
     {
         /// <summary>
-        /// Create <see cref="TaxonomyFacetSumFloatAssociations"/> against
+        /// Create <see cref="TaxonomyFacetSumSingleAssociations"/> against
         /// the default index field. 
         /// </summary>
-        public TaxonomyFacetSumFloatAssociations(TaxonomyReader taxoReader, FacetsConfig config, FacetsCollector fc)
+        public TaxonomyFacetSumSingleAssociations(TaxonomyReader taxoReader, FacetsConfig config, FacetsCollector fc)
             : this(FacetsConfig.DEFAULT_INDEX_FIELD_NAME, taxoReader, config, fc)
         {
         }
 
         /// <summary>
-        /// Create <see cref="TaxonomyFacetSumFloatAssociations"/> against
+        /// Create <see cref="TaxonomyFacetSumSingleAssociations"/> against
         /// the specified index field. 
         /// </summary>
-        public TaxonomyFacetSumFloatAssociations(string indexFieldName, TaxonomyReader taxoReader, FacetsConfig config, FacetsCollector fc)
+        public TaxonomyFacetSumSingleAssociations(string indexFieldName, TaxonomyReader taxoReader, FacetsConfig config, FacetsCollector fc)
             : base(indexFieldName, taxoReader, config)
         {
             SumValues(fc.GetMatchingDocs());

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/c3485316/src/Lucene.Net.Facet/Taxonomy/TaxonomyFacetSumIntAssociations.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Facet/Taxonomy/TaxonomyFacetSumIntAssociations.cs b/src/Lucene.Net.Facet/Taxonomy/TaxonomyFacetSumIntAssociations.cs
index fc45bdb..7702b25 100644
--- a/src/Lucene.Net.Facet/Taxonomy/TaxonomyFacetSumIntAssociations.cs
+++ b/src/Lucene.Net.Facet/Taxonomy/TaxonomyFacetSumIntAssociations.cs
@@ -25,28 +25,30 @@ namespace Lucene.Net.Facet.Taxonomy
     using MatchingDocs = FacetsCollector.MatchingDocs;
 
     /// <summary>
-    /// Aggregates sum of int values previously indexed with
-    /// <see cref="IntAssociationFacetField"/>, assuming the default
+    /// Aggregates sum of <see cref="int"/> values previously indexed with
+    /// <see cref="Int32AssociationFacetField"/>, assuming the default
     /// encoding.
+    /// <para/>
+    /// NOTE: This was TaxonomyFacetSumIntAssociations in Lucene
     /// 
     ///  @lucene.experimental 
     /// </summary>
-    public class TaxonomyFacetSumIntAssociations : IntTaxonomyFacets
+    public class TaxonomyFacetSumInt32Associations : Int32TaxonomyFacets
     {
         /// <summary>
-        /// Create <see cref="TaxonomyFacetSumIntAssociations"/> against
+        /// Create <see cref="TaxonomyFacetSumInt32Associations"/> against
         /// the default index field. 
         /// </summary>
-        public TaxonomyFacetSumIntAssociations(TaxonomyReader taxoReader, FacetsConfig config, FacetsCollector fc)
+        public TaxonomyFacetSumInt32Associations(TaxonomyReader taxoReader, FacetsConfig config, FacetsCollector fc)
             : this(FacetsConfig.DEFAULT_INDEX_FIELD_NAME, taxoReader, config, fc)
         {
         }
 
         /// <summary>
-        /// Create <see cref="TaxonomyFacetSumIntAssociations"/> against
+        /// Create <see cref="TaxonomyFacetSumInt32Associations"/> against
         /// the specified index field. 
         /// </summary>
-        public TaxonomyFacetSumIntAssociations(string indexFieldName, TaxonomyReader taxoReader, FacetsConfig config, FacetsCollector fc)
+        public TaxonomyFacetSumInt32Associations(string indexFieldName, TaxonomyReader taxoReader, FacetsConfig config, FacetsCollector fc)
             : base(indexFieldName, taxoReader, config)
         {
             SumValues(fc.GetMatchingDocs());

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/c3485316/src/Lucene.Net.Facet/Taxonomy/TaxonomyFacetSumValueSource.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Facet/Taxonomy/TaxonomyFacetSumValueSource.cs b/src/Lucene.Net.Facet/Taxonomy/TaxonomyFacetSumValueSource.cs
index b2c6473..2004ad2 100644
--- a/src/Lucene.Net.Facet/Taxonomy/TaxonomyFacetSumValueSource.cs
+++ b/src/Lucene.Net.Facet/Taxonomy/TaxonomyFacetSumValueSource.cs
@@ -39,7 +39,7 @@ namespace Lucene.Net.Facet.Taxonomy
     /// 
     ///  @lucene.experimental 
     /// </summary>
-    public class TaxonomyFacetSumValueSource : FloatTaxonomyFacets
+    public class TaxonomyFacetSumValueSource : SingleTaxonomyFacets
     {
         private readonly OrdinalsReader ordinalsReader;
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/c3485316/src/Lucene.Net.Facet/Taxonomy/WriterCache/LruTaxonomyWriterCache.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Facet/Taxonomy/WriterCache/LruTaxonomyWriterCache.cs b/src/Lucene.Net.Facet/Taxonomy/WriterCache/LruTaxonomyWriterCache.cs
index d7d5676..af8324b 100644
--- a/src/Lucene.Net.Facet/Taxonomy/WriterCache/LruTaxonomyWriterCache.cs
+++ b/src/Lucene.Net.Facet/Taxonomy/WriterCache/LruTaxonomyWriterCache.cs
@@ -44,7 +44,7 @@
             LRU_STRING
         }
 
-        private NameIntCacheLRU cache;
+        private NameInt32CacheLRU cache;
 
         /// <summary>
         /// Creates this with <see cref="LRUType.LRU_HASHED"/> method.
@@ -73,11 +73,11 @@
             // mapped to the same ordinal...
             if (lruType == LRUType.LRU_HASHED)
             {
-                this.cache = new NameHashIntCacheLRU(cacheSize);
+                this.cache = new NameHashInt32CacheLRU(cacheSize);
             }
             else
             {
-                this.cache = new NameIntCacheLRU(cacheSize);
+                this.cache = new NameInt32CacheLRU(cacheSize);
             }
         }
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/c3485316/src/Lucene.Net.Facet/Taxonomy/WriterCache/NameHashIntCacheLRU.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Facet/Taxonomy/WriterCache/NameHashIntCacheLRU.cs b/src/Lucene.Net.Facet/Taxonomy/WriterCache/NameHashIntCacheLRU.cs
index 7e2c95e..0bc40d4 100644
--- a/src/Lucene.Net.Facet/Taxonomy/WriterCache/NameHashIntCacheLRU.cs
+++ b/src/Lucene.Net.Facet/Taxonomy/WriterCache/NameHashIntCacheLRU.cs
@@ -22,13 +22,15 @@
     /// Used to cache Ordinals of category paths.
     /// It uses as key, hash of the path instead of the path.
     /// This way the cache takes less RAM, but correctness depends on
-    /// assuming no collisions. 
+    /// assuming no collisions.
+    /// <para/>
+    /// NOTE: this was NameHashIntCacheLRU in Lucene
     /// 
     /// @lucene.experimental
     /// </summary>
-    public class NameHashIntCacheLRU : NameIntCacheLRU
+    public class NameHashInt32CacheLRU : NameInt32CacheLRU
     {
-        internal NameHashIntCacheLRU(int maxCacheSize)
+        internal NameHashInt32CacheLRU(int maxCacheSize)
             : base(maxCacheSize)
         {
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/c3485316/src/Lucene.Net.Facet/Taxonomy/WriterCache/NameIntCacheLRU.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Facet/Taxonomy/WriterCache/NameIntCacheLRU.cs b/src/Lucene.Net.Facet/Taxonomy/WriterCache/NameIntCacheLRU.cs
index 6b849f8..efe30c7 100644
--- a/src/Lucene.Net.Facet/Taxonomy/WriterCache/NameIntCacheLRU.cs
+++ b/src/Lucene.Net.Facet/Taxonomy/WriterCache/NameIntCacheLRU.cs
@@ -24,6 +24,8 @@ namespace Lucene.Net.Facet.Taxonomy.WriterCache
     /// <summary>
     /// An an LRU cache of mapping from name to int.
     /// Used to cache Ordinals of category paths.
+    /// <para/>
+    /// NOTE: This was NameIntCacheLRU in Lucene
     /// 
     /// @lucene.experimental
     /// </summary>
@@ -31,14 +33,14 @@ namespace Lucene.Net.Facet.Taxonomy.WriterCache
     /// Note: Nothing in this class is synchronized. The caller is assumed to be
     /// synchronized so that no two methods of this class are called concurrently.
     /// </remarks>
-    public class NameIntCacheLRU
+    public class NameInt32CacheLRU
     {
         private IDictionary<object, int> cache;
         internal long nMisses = 0; // for debug
         internal long nHits = 0; // for debug
         private int capacity;
 
-        internal NameIntCacheLRU(int capacity)
+        internal NameInt32CacheLRU(int capacity)
         {
             this.capacity = capacity;
             CreateCache(capacity);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/c3485316/src/Lucene.Net.Facet/TopOrdAndFloatQueue.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Facet/TopOrdAndFloatQueue.cs b/src/Lucene.Net.Facet/TopOrdAndFloatQueue.cs
index ffa52e7..62fb389 100644
--- a/src/Lucene.Net.Facet/TopOrdAndFloatQueue.cs
+++ b/src/Lucene.Net.Facet/TopOrdAndFloatQueue.cs
@@ -20,10 +20,12 @@ namespace Lucene.Net.Facet
 	 */
 
     /// <summary>
-    /// Keeps highest results, first by largest float value,
-    /// then tie break by smallest ord. 
+    /// Keeps highest results, first by largest <see cref="float"/> value,
+    /// then tie break by smallest ord.
+    /// <para/>
+    /// NOTE: This was TopOrdAndFloatQueue in Lucene
     /// </summary>
-    public class TopOrdAndFloatQueue : PriorityQueue<TopOrdAndFloatQueue.OrdAndValue>
+    public class TopOrdAndSingleQueue : PriorityQueue<TopOrdAndSingleQueue.OrdAndValue>
     {
         /// <summary>
         /// Holds a single entry.
@@ -49,7 +51,7 @@ namespace Lucene.Net.Facet
         /// <summary>
         /// Sole constructor.
         /// </summary>
-        public TopOrdAndFloatQueue(int topN) : base(topN, false)
+        public TopOrdAndSingleQueue(int topN) : base(topN, false)
         {
         }
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/c3485316/src/Lucene.Net.Facet/TopOrdAndIntQueue.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Facet/TopOrdAndIntQueue.cs b/src/Lucene.Net.Facet/TopOrdAndIntQueue.cs
index fb44dc9..cb78b69 100644
--- a/src/Lucene.Net.Facet/TopOrdAndIntQueue.cs
+++ b/src/Lucene.Net.Facet/TopOrdAndIntQueue.cs
@@ -20,10 +20,12 @@ namespace Lucene.Net.Facet
      */
 
     /// <summary>
-    /// Keeps highest results, first by largest int value,
-    /// then tie break by smallest ord. 
+    /// Keeps highest results, first by largest <see cref="int"/> value,
+    /// then tie break by smallest ord.
+    /// <para/>
+    /// NOTE: This was TopOrdAndIntQueue in Lucene
     /// </summary>
-    public class TopOrdAndIntQueue : PriorityQueue<TopOrdAndIntQueue.OrdAndValue>
+    public class TopOrdAndInt32Queue : PriorityQueue<TopOrdAndInt32Queue.OrdAndValue>
     {
         /// <summary>
         /// Holds a single entry.
@@ -49,7 +51,7 @@ namespace Lucene.Net.Facet
         /// <summary>
         /// Sole constructor.
         /// </summary>
-        public TopOrdAndIntQueue(int topN)
+        public TopOrdAndInt32Queue(int topN)
             : base(topN, false)
         {
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/c3485316/src/Lucene.Net.Tests.Facet/Range/TestRangeFacetCounts.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests.Facet/Range/TestRangeFacetCounts.cs b/src/Lucene.Net.Tests.Facet/Range/TestRangeFacetCounts.cs
index d128c36..b41e3df 100644
--- a/src/Lucene.Net.Tests.Facet/Range/TestRangeFacetCounts.cs
+++ b/src/Lucene.Net.Tests.Facet/Range/TestRangeFacetCounts.cs
@@ -94,7 +94,7 @@ namespace Lucene.Net.Facet.Range
             IndexSearcher s = NewSearcher(r);
             s.Search(new MatchAllDocsQuery(), fc);
 
-            Facets facets = new LongRangeFacetCounts("field", fc, new LongRange("less than 10", 0L, true, 10L, false), new LongRange("less than or equal to 10", 0L, true, 10L, true), new LongRange("over 90", 90L, false, 100L, false), new LongRange("90 or above", 90L, true, 100L, false), new LongRange("over 1000", 1000L, false, long.MaxValue, true));
+            Facets facets = new Int64RangeFacetCounts("field", fc, new Int64Range("less than 10", 0L, true, 10L, false), new Int64Range("less than or equal to 10", 0L, true, 10L, true), new Int64Range("over 90", 90L, false, 100L, false), new Int64Range("90 or above", 90L, true, 100L, false), new Int64Range("over 1000", 1000L, false, long.MaxValue, true));
 
             FacetResult result = facets.GetTopChildren(10, "field");
 
@@ -109,7 +109,7 @@ namespace Lucene.Net.Facet.Range
         {
             try
             {
-                new LongRange("useless", 7, true, 6, true);
+                new Int64Range("useless", 7, true, 6, true);
                 Fail("did not hit expected exception");
             }
             catch (System.ArgumentException)
@@ -118,7 +118,7 @@ namespace Lucene.Net.Facet.Range
             }
             try
             {
-                new LongRange("useless", 7, true, 7, false);
+                new Int64Range("useless", 7, true, 7, false);
                 Fail("did not hit expected exception");
             }
             catch (System.ArgumentException)
@@ -168,7 +168,7 @@ namespace Lucene.Net.Facet.Range
             IndexSearcher s = NewSearcher(r);
             s.Search(new MatchAllDocsQuery(), fc);
 
-            Facets facets = new LongRangeFacetCounts("field", fc, new LongRange("min", long.MinValue, true, long.MinValue, true), new LongRange("max", long.MaxValue, true, long.MaxValue, true), new LongRange("all0", long.MinValue, true, long.MaxValue, true), new LongRange("all1", long.MinValue, false, long.MaxValue, true), new LongRange("all2", long.MinValue, true, long.MaxValue, false), new LongRange("all3", long.MinValue, false, long.MaxValue, false));
+            Facets facets = new Int64RangeFacetCounts("field", fc, new Int64Range("min", long.MinValue, true, long.MinValue, true), new Int64Range("max", long.MaxValue, true, long.MaxValue, true), new Int64Range("all0", long.MinValue, true, long.MaxValue, true), new Int64Range("all1", long.MinValue, false, long.MaxValue, true), new Int64Range("all2", long.MinValue, true, long.MaxValue, false), new Int64Range("all3", long.MinValue, false, long.MaxValue, false));
 
             FacetResult result = facets.GetTopChildren(10, "field");
             Assert.AreEqual("dim=field path=[] value=3 childCount=6\n  min (1)\n  max (1)\n  all0 (3)\n  all1 (2)\n  all2 (2)\n  all3 (1)\n", result.ToString());
@@ -200,7 +200,7 @@ namespace Lucene.Net.Facet.Range
             IndexSearcher s = NewSearcher(r);
             s.Search(new MatchAllDocsQuery(), fc);
 
-            Facets facets = new LongRangeFacetCounts("field", fc, new LongRange("0-10", 0L, true, 10L, true), new LongRange("10-20", 10L, true, 20L, true), new LongRange("20-30", 20L, true, 30L, true), new LongRange("30-40", 30L, true, 40L, true));
+            Facets facets = new Int64RangeFacetCounts("field", fc, new Int64Range("0-10", 0L, true, 10L, true), new Int64Range("10-20", 10L, true, 20L, true), new Int64Range("20-30", 20L, true, 30L, true), new Int64Range("30-40", 30L, true, 40L, true));
 
             FacetResult result = facets.GetTopChildren(10, "field");
             Assert.AreEqual("dim=field path=[] value=41 childCount=4\n  0-10 (11)\n  10-20 (11)\n  20-30 (11)\n  30-40 (11)\n", result.ToString());
@@ -314,7 +314,7 @@ namespace Lucene.Net.Facet.Range
                 }
 
                 IDictionary<string, Facets> byDim = new Dictionary<string, Facets>();
-                byDim["field"] = new LongRangeFacetCounts("field", fieldFC, new LongRange("less than 10", 0L, true, 10L, false), new LongRange("less than or equal to 10", 0L, true, 10L, true), new LongRange("over 90", 90L, false, 100L, false), new LongRange("90 or above", 90L, true, 100L, false), new LongRange("over 1000", 1000L, false, long.MaxValue, false));
+                byDim["field"] = new Int64RangeFacetCounts("field", fieldFC, new Int64Range("less than 10", 0L, true, 10L, false), new Int64Range("less than or equal to 10", 0L, true, 10L, true), new Int64Range("over 90", 90L, false, 100L, false), new Int64Range("90 or above", 90L, true, 100L, false), new Int64Range("over 1000", 1000L, false, long.MaxValue, false));
                 byDim["dim"] = outerInstance.GetTaxonomyFacetCounts(m_taxoReader, m_config, dimFC);
                 return new MultiFacets(byDim, null);
             }
@@ -418,7 +418,7 @@ namespace Lucene.Net.Facet.Range
                     Console.WriteLine("TEST: iter=" + iter);
                 }
                 int numRange = TestUtil.NextInt(Random(), 1, 100);
-                LongRange[] ranges = new LongRange[numRange];
+                Int64Range[] ranges = new Int64Range[numRange];
                 int[] expectedCounts = new int[numRange];
                 long minAcceptedValue = long.MaxValue;
                 long maxAcceptedValue = long.MinValue;
@@ -428,7 +428,7 @@ namespace Lucene.Net.Facet.Range
                     if (rangeID > 0 && Random().Next(10) == 7)
                     {
                         // Use an existing boundary:
-                        LongRange prevRange = ranges[Random().Next(rangeID)];
+                        Int64Range prevRange = ranges[Random().Next(rangeID)];
                         if (Random().NextBoolean())
                         {
                             min = prevRange.Min;
@@ -446,7 +446,7 @@ namespace Lucene.Net.Facet.Range
                     if (rangeID > 0 && Random().Next(10) == 7)
                     {
                         // Use an existing boundary:
-                        LongRange prevRange = ranges[Random().Next(rangeID)];
+                        Int64Range prevRange = ranges[Random().Next(rangeID)];
                         if (Random().NextBoolean())
                         {
                             max = prevRange.Min;
@@ -479,7 +479,7 @@ namespace Lucene.Net.Facet.Range
                         minIncl = Random().NextBoolean();
                         maxIncl = Random().NextBoolean();
                     }
-                    ranges[rangeID] = new LongRange("r" + rangeID, min, minIncl, max, maxIncl);
+                    ranges[rangeID] = new Int64Range("r" + rangeID, min, minIncl, max, maxIncl);
                     if (VERBOSE)
                     {
                         Console.WriteLine("  range " + rangeID + ": " + ranges[rangeID]);
@@ -534,7 +534,7 @@ namespace Lucene.Net.Facet.Range
                     fastMatchFilter = null;
                 }
                 ValueSource vs = new LongFieldSource("field");
-                Facets facets = new LongRangeFacetCounts("field", vs, sfc, fastMatchFilter, ranges);
+                Facets facets = new Int64RangeFacetCounts("field", vs, sfc, fastMatchFilter, ranges);
                 FacetResult result = facets.GetTopChildren(10, "field");
                 Assert.AreEqual(numRange, result.LabelValues.Length);
                 for (int rangeID = 0; rangeID < numRange; rangeID++)
@@ -547,7 +547,7 @@ namespace Lucene.Net.Facet.Range
                     Assert.AreEqual("r" + rangeID, subNode.Label);
                     Assert.AreEqual(expectedCounts[rangeID], (int)subNode.Value);
 
-                    LongRange range = ranges[rangeID];
+                    Int64Range range = ranges[rangeID];
 
                     // Test drill-down:
                     DrillDownQuery ddq = new DrillDownQuery(config);
@@ -993,7 +993,7 @@ namespace Lucene.Net.Facet.Range
 
             IndexSearcher s = NewSearcher(r);
             s.Search(new MatchAllDocsQuery(), fc);
-            Facets facets = new LongRangeFacetCounts("field", fc, new LongRange("less than 10", 0L, true, 10L, false), new LongRange("less than or equal to 10", 0L, true, 10L, true), new LongRange("over 90", 90L, false, 100L, false), new LongRange("90 or above", 90L, true, 100L, false), new LongRange("over 1000", 1000L, false, long.MaxValue, false));
+            Facets facets = new Int64RangeFacetCounts("field", fc, new Int64Range("less than 10", 0L, true, 10L, false), new Int64Range("less than or equal to 10", 0L, true, 10L, true), new Int64Range("over 90", 90L, false, 100L, false), new Int64Range("90 or above", 90L, true, 100L, false), new Int64Range("over 1000", 1000L, false, long.MaxValue, false));
 
             Assert.AreEqual("dim=field path=[] value=16 childCount=5\n  less than 10 (8)\n  less than or equal to 10 (8)\n  over 90 (8)\n  90 or above (8)\n  over 1000 (0)\n", facets.GetTopChildren(10, "field").ToString());
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/c3485316/src/Lucene.Net.Tests.Facet/Taxonomy/TestFacetLabel.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests.Facet/Taxonomy/TestFacetLabel.cs b/src/Lucene.Net.Tests.Facet/Taxonomy/TestFacetLabel.cs
index 2b87829..a6ca76e 100644
--- a/src/Lucene.Net.Tests.Facet/Taxonomy/TestFacetLabel.cs
+++ b/src/Lucene.Net.Tests.Facet/Taxonomy/TestFacetLabel.cs
@@ -203,7 +203,7 @@ namespace Lucene.Net.Facet.Taxonomy
                 }
                 try
                 {
-                    new IntAssociationFacetField(17, "dim", components);
+                    new Int32AssociationFacetField(17, "dim", components);
                     Fail("empty or null components should not be allowed: " + Arrays.ToString(components));
                 }
                 catch (System.ArgumentException)
@@ -212,7 +212,7 @@ namespace Lucene.Net.Facet.Taxonomy
                 }
                 try
                 {
-                    new FloatAssociationFacetField(17.0f, "dim", components);
+                    new SingleAssociationFacetField(17.0f, "dim", components);
                     Fail("empty or null components should not be allowed: " + Arrays.ToString(components));
                 }
                 catch (System.ArgumentException)
@@ -240,7 +240,7 @@ namespace Lucene.Net.Facet.Taxonomy
             }
             try
             {
-                new IntAssociationFacetField(17, null, new string[] { "abc" });
+                new Int32AssociationFacetField(17, null, new string[] { "abc" });
                 Fail("empty or null components should not be allowed");
             }
             catch (System.ArgumentException)
@@ -249,7 +249,7 @@ namespace Lucene.Net.Facet.Taxonomy
             }
             try
             {
-                new IntAssociationFacetField(17, "", new string[] { "abc" });
+                new Int32AssociationFacetField(17, "", new string[] { "abc" });
                 Fail("empty or null components should not be allowed");
             }
             catch (System.ArgumentException)
@@ -258,7 +258,7 @@ namespace Lucene.Net.Facet.Taxonomy
             }
             try
             {
-                new FloatAssociationFacetField(17.0f, null, new string[] { "abc" });
+                new SingleAssociationFacetField(17.0f, null, new string[] { "abc" });
                 Fail("empty or null components should not be allowed");
             }
             catch (System.ArgumentException)
@@ -267,7 +267,7 @@ namespace Lucene.Net.Facet.Taxonomy
             }
             try
             {
-                new FloatAssociationFacetField(17.0f, "", new string[] { "abc" });
+                new SingleAssociationFacetField(17.0f, "", new string[] { "abc" });
                 Fail("empty or null components should not be allowed");
             }
             catch (System.ArgumentException)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/c3485316/src/Lucene.Net.Tests.Facet/Taxonomy/TestTaxonomyFacetAssociations.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests.Facet/Taxonomy/TestTaxonomyFacetAssociations.cs b/src/Lucene.Net.Tests.Facet/Taxonomy/TestTaxonomyFacetAssociations.cs
index fc38863..c7e4c32 100644
--- a/src/Lucene.Net.Tests.Facet/Taxonomy/TestTaxonomyFacetAssociations.cs
+++ b/src/Lucene.Net.Tests.Facet/Taxonomy/TestTaxonomyFacetAssociations.cs
@@ -75,12 +75,12 @@ namespace Lucene.Net.Facet.Taxonomy
                 // aggregators to go into an infinite loop
                 if (i % 11 != 0)
                 {
-                    doc.Add(new IntAssociationFacetField(2, "int", "a"));
-                    doc.Add(new FloatAssociationFacetField(0.5f, "float", "a"));
+                    doc.Add(new Int32AssociationFacetField(2, "int", "a"));
+                    doc.Add(new SingleAssociationFacetField(0.5f, "float", "a"));
                     if (i % 2 == 0) // 50
                     {
-                        doc.Add(new IntAssociationFacetField(3, "int", "b"));
-                        doc.Add(new FloatAssociationFacetField(0.2f, "float", "b"));
+                        doc.Add(new Int32AssociationFacetField(3, "int", "b"));
+                        doc.Add(new SingleAssociationFacetField(0.2f, "float", "b"));
                     }
                 }
                 writer.AddDocument(config.Build(taxoWriter, doc));
@@ -114,7 +114,7 @@ namespace Lucene.Net.Facet.Taxonomy
             IndexSearcher searcher = NewSearcher(reader);
             searcher.Search(new MatchAllDocsQuery(), fc);
 
-            Facets facets = new TaxonomyFacetSumIntAssociations("$facets.int", taxoReader, config, fc);
+            Facets facets = new TaxonomyFacetSumInt32Associations("$facets.int", taxoReader, config, fc);
             Assert.AreEqual("dim=int path=[] value=-1 childCount=2\n  a (200)\n  b (150)\n", facets.GetTopChildren(10, "int").ToString());
             Assert.AreEqual(200, (int)facets.GetSpecificValue("int", "a"), "Wrong count for category 'a'!");
             Assert.AreEqual(150, (int)facets.GetSpecificValue("int", "b"), "Wrong count for category 'b'!");
@@ -128,7 +128,7 @@ namespace Lucene.Net.Facet.Taxonomy
             IndexSearcher searcher = NewSearcher(reader);
             searcher.Search(new MatchAllDocsQuery(), fc);
 
-            Facets facets = new TaxonomyFacetSumFloatAssociations("$facets.float", taxoReader, config, fc);
+            Facets facets = new TaxonomyFacetSumSingleAssociations("$facets.float", taxoReader, config, fc);
             Assert.AreEqual("dim=float path=[] value=-1.0 childCount=2\n  a (50.0)\n  b (9.999995)\n", facets.GetTopChildren(10, "float").ToString());
             Assert.AreEqual(50f, (float)facets.GetSpecificValue("float", "a"), 0.00001, "Wrong count for category 'a'!");
             Assert.AreEqual(10f, (float)facets.GetSpecificValue("float", "b"), 0.00001, "Wrong count for category 'b'!");
@@ -146,11 +146,11 @@ namespace Lucene.Net.Facet.Taxonomy
             IndexSearcher searcher = NewSearcher(reader);
             searcher.Search(new MatchAllDocsQuery(), fc);
 
-            Facets facets = new TaxonomyFacetSumFloatAssociations("$facets.float", taxoReader, config, fc);
+            Facets facets = new TaxonomyFacetSumSingleAssociations("$facets.float", taxoReader, config, fc);
             Assert.AreEqual(50f, (float)facets.GetSpecificValue("float", "a"), 0.00001, "Wrong count for category 'a'!");
             Assert.AreEqual(10f, (float)facets.GetSpecificValue("float", "b"), 0.00001, "Wrong count for category 'b'!");
 
-            facets = new TaxonomyFacetSumIntAssociations("$facets.int", taxoReader, config, fc);
+            facets = new TaxonomyFacetSumInt32Associations("$facets.int", taxoReader, config, fc);
             Assert.AreEqual(200, (int)facets.GetSpecificValue("int", "a"), "Wrong count for category 'a'!");
             Assert.AreEqual(150, (int)facets.GetSpecificValue("int", "b"), "Wrong count for category 'b'!");
         }
@@ -163,7 +163,7 @@ namespace Lucene.Net.Facet.Taxonomy
 
             IndexSearcher searcher = NewSearcher(reader);
             searcher.Search(new MatchAllDocsQuery(), fc);
-            Facets facets = new TaxonomyFacetSumFloatAssociations(taxoReader, config, fc);
+            Facets facets = new TaxonomyFacetSumSingleAssociations(taxoReader, config, fc);
             try
             {
                 facets.GetSpecificValue("float");
@@ -196,8 +196,8 @@ namespace Lucene.Net.Facet.Taxonomy
             RandomIndexWriter writer = new RandomIndexWriter(Random(), dir, Similarity, TimeZone);
 
             Document doc = new Document();
-            doc.Add(new IntAssociationFacetField(14, "a", "x"));
-            doc.Add(new FloatAssociationFacetField(55.0f, "b", "y"));
+            doc.Add(new Int32AssociationFacetField(14, "a", "x"));
+            doc.Add(new SingleAssociationFacetField(55.0f, "b", "y"));
             try
             {
                 writer.AddDocument(config.Build(taxoWriter, doc));
@@ -222,7 +222,7 @@ namespace Lucene.Net.Facet.Taxonomy
             RandomIndexWriter writer = new RandomIndexWriter(Random(), dir, Similarity, TimeZone);
 
             Document doc = new Document();
-            doc.Add(new IntAssociationFacetField(14, "a", "x"));
+            doc.Add(new Int32AssociationFacetField(14, "a", "x"));
             try
             {
                 writer.AddDocument(config.Build(taxoWriter, doc));
@@ -247,7 +247,7 @@ namespace Lucene.Net.Facet.Taxonomy
             RandomIndexWriter writer = new RandomIndexWriter(Random(), dir, Similarity, TimeZone);
 
             Document doc = new Document();
-            doc.Add(new IntAssociationFacetField(14, "a", "x"));
+            doc.Add(new Int32AssociationFacetField(14, "a", "x"));
             try
             {
                 writer.AddDocument(config.Build(taxoWriter, doc));
@@ -270,7 +270,7 @@ namespace Lucene.Net.Facet.Taxonomy
             q.Add("int", "b");
             searcher.Search(q, fc);
 
-            Facets facets = new TaxonomyFacetSumIntAssociations("$facets.int", taxoReader, config, fc);
+            Facets facets = new TaxonomyFacetSumInt32Associations("$facets.int", taxoReader, config, fc);
             Assert.AreEqual("dim=int path=[] value=-1 childCount=2\n  b (150)\n  a (100)\n", facets.GetTopChildren(10, "int").ToString());
             Assert.AreEqual(100, (int)facets.GetSpecificValue("int", "a"), "Wrong count for category 'a'!");
             Assert.AreEqual(150, (int)facets.GetSpecificValue("int", "b"), "Wrong count for category 'b'!");


[53/53] [abbrv] lucenenet git commit: Lucene.Net.Core.Analysis.TokenAttributes: Removed unused TermToBytesRefAttribute class (wasn't in Lucene 4.8.0 anyway)

Posted by ni...@apache.org.
Lucene.Net.Core.Analysis.TokenAttributes: Removed unused TermToBytesRefAttribute class (wasn't in Lucene 4.8.0 anyway)


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

Branch: refs/heads/api-work
Commit: cfdda330ca0faf9f2e011b8c58e8990cbc00061c
Parents: 52da783
Author: Shad Storhaug <sh...@shadstorhaug.com>
Authored: Wed Feb 8 21:16:02 2017 +0700
Committer: Shad Storhaug <sh...@shadstorhaug.com>
Committed: Wed Feb 8 21:16:53 2017 +0700

----------------------------------------------------------------------
 .../TokenAttributes/TermToBytesRefAttribute.cs  | 29 --------------------
 src/Lucene.Net.Core/Lucene.Net.csproj           |  1 -
 2 files changed, 30 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/lucenenet/blob/cfdda330/src/Lucene.Net.Core/Analysis/TokenAttributes/TermToBytesRefAttribute.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Analysis/TokenAttributes/TermToBytesRefAttribute.cs b/src/Lucene.Net.Core/Analysis/TokenAttributes/TermToBytesRefAttribute.cs
deleted file mode 100644
index a9e05f2..0000000
--- a/src/Lucene.Net.Core/Analysis/TokenAttributes/TermToBytesRefAttribute.cs
+++ /dev/null
@@ -1,29 +0,0 @@
-\ufeff//using Lucene.Net.Util;
-//using System;
-//using Attribute = Lucene.Net.Util.Attribute;
-
-//namespace Lucene.Net.Analysis.TokenAttributes
-//{
-//    // LUCENENET TODO: This class does not exist in Java - Remove?
-//    public class TermToBytesRefAttribute : Attribute, ITermToBytesRefAttribute
-//    {
-//        private BytesRef bytes;
-
-//        public void FillBytesRef()
-//        {
-//            throw new NotImplementedException("I'm not sure what this should do");
-//        }
-
-//        public BytesRef BytesRef { get; set; }
-
-//        public override void Clear()
-//        {
-//        }
-
-//        public override void CopyTo(IAttribute target)
-//        {
-//            TermToBytesRefAttribute other = (TermToBytesRefAttribute)target;
-//            other.bytes = bytes;
-//        }
-//    }
-//}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/cfdda330/src/Lucene.Net.Core/Lucene.Net.csproj
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Lucene.Net.csproj b/src/Lucene.Net.Core/Lucene.Net.csproj
index a4b4d24..0cd852d 100644
--- a/src/Lucene.Net.Core/Lucene.Net.csproj
+++ b/src/Lucene.Net.Core/Lucene.Net.csproj
@@ -73,7 +73,6 @@
     <Compile Include="Analysis\TokenAttributes\PositionLengthAttribute.cs" />
     <Compile Include="Analysis\TokenAttributes\ITermToBytesRefAttribute.cs" />
     <Compile Include="Analysis\TokenAttributes\ITypeAttribute.cs" />
-    <Compile Include="Analysis\TokenAttributes\TermToBytesRefAttribute.cs" />
     <Compile Include="Analysis\TokenAttributes\TypeAttribute.cs" />
     <Compile Include="Analysis\TokenFilter.cs" />
     <Compile Include="Analysis\Tokenizer.cs" />


[23/53] [abbrv] lucenenet git commit: Lucene.Net.Core: Renamed all type-derived classes and interfaces from Short, Int, Long, and Float to match CLR types Int16, Int32, Int64, and Single, respectively.

Posted by ni...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.TestFramework/Codecs/lucene42/Lucene42DocValuesConsumer.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.TestFramework/Codecs/lucene42/Lucene42DocValuesConsumer.cs b/src/Lucene.Net.TestFramework/Codecs/lucene42/Lucene42DocValuesConsumer.cs
index 678d381..7441346 100644
--- a/src/Lucene.Net.TestFramework/Codecs/lucene42/Lucene42DocValuesConsumer.cs
+++ b/src/Lucene.Net.TestFramework/Codecs/lucene42/Lucene42DocValuesConsumer.cs
@@ -30,16 +30,16 @@ namespace Lucene.Net.Codecs.Lucene42
          */
 
     using FieldInfo = Lucene.Net.Index.FieldInfo;
-    using FormatAndBits = Lucene.Net.Util.Packed.PackedInts.FormatAndBits;
+    using FormatAndBits = Lucene.Net.Util.Packed.PackedInt32s.FormatAndBits;
     using IndexFileNames = Lucene.Net.Index.IndexFileNames;
     using IndexOutput = Lucene.Net.Store.IndexOutput;
     using INPUT_TYPE = Lucene.Net.Util.Fst.FST.INPUT_TYPE;
-    using IntsRef = Lucene.Net.Util.IntsRef;
+    using Int32sRef = Lucene.Net.Util.Int32sRef;
     using IOUtils = Lucene.Net.Util.IOUtils;
     using MathUtil = Lucene.Net.Util.MathUtil;
     using MonotonicBlockPackedWriter = Lucene.Net.Util.Packed.MonotonicBlockPackedWriter;
-    using PackedInts = Lucene.Net.Util.Packed.PackedInts;
-    using PositiveIntOutputs = Lucene.Net.Util.Fst.PositiveIntOutputs;
+    using PackedInt32s = Lucene.Net.Util.Packed.PackedInt32s;
+    using PositiveInt32Outputs = Lucene.Net.Util.Fst.PositiveInt32Outputs;
     using SegmentWriteState = Lucene.Net.Index.SegmentWriteState;
     using Util = Lucene.Net.Util.Fst.Util;
 
@@ -142,8 +142,8 @@ namespace Lucene.Net.Codecs.Lucene42
             if (uniqueValues != null)
             {
                 // small number of unique values
-                int bitsPerValue = PackedInts.BitsRequired(uniqueValues.Count - 1);
-                FormatAndBits formatAndBits = PackedInts.FastestFormatAndBits(MaxDoc, bitsPerValue, AcceptableOverheadRatio);
+                int bitsPerValue = PackedInt32s.BitsRequired(uniqueValues.Count - 1);
+                FormatAndBits formatAndBits = PackedInt32s.FastestFormatAndBits(MaxDoc, bitsPerValue, AcceptableOverheadRatio);
                 if (formatAndBits.BitsPerValue == 8 && minValue >= sbyte.MinValue && maxValue <= sbyte.MaxValue)
                 {
                     Meta.WriteByte((byte)Lucene42DocValuesProducer.UNCOMPRESSED); // uncompressed
@@ -164,11 +164,11 @@ namespace Lucene.Net.Codecs.Lucene42
                         encode[decode[i]] = i;
                     }
 
-                    Meta.WriteVInt32(PackedInts.VERSION_CURRENT);
+                    Meta.WriteVInt32(PackedInt32s.VERSION_CURRENT);
                     Data.WriteVInt32(formatAndBits.Format.Id);
                     Data.WriteVInt32(formatAndBits.BitsPerValue);
 
-                    PackedInts.Writer writer = PackedInts.GetWriterNoHeader(Data, formatAndBits.Format, MaxDoc, formatAndBits.BitsPerValue, PackedInts.DEFAULT_BUFFER_SIZE);
+                    PackedInt32s.Writer writer = PackedInt32s.GetWriterNoHeader(Data, formatAndBits.Format, MaxDoc, formatAndBits.BitsPerValue, PackedInt32s.DEFAULT_BUFFER_SIZE);
                     foreach (long? nv in values)
                     {
                         writer.Add(encode[nv == null ? 0 : (long)nv]);
@@ -179,7 +179,7 @@ namespace Lucene.Net.Codecs.Lucene42
             else if (gcd != 0 && gcd != 1)
             {
                 Meta.WriteByte((byte)Lucene42DocValuesProducer.GCD_COMPRESSED);
-                Meta.WriteVInt32(PackedInts.VERSION_CURRENT);
+                Meta.WriteVInt32(PackedInt32s.VERSION_CURRENT);
                 Data.WriteInt64(minValue);
                 Data.WriteInt64(gcd);
                 Data.WriteVInt32(Lucene42DocValuesProducer.BLOCK_SIZE);
@@ -196,7 +196,7 @@ namespace Lucene.Net.Codecs.Lucene42
             {
                 Meta.WriteByte((byte)Lucene42DocValuesProducer.DELTA_COMPRESSED); // delta-compressed
 
-                Meta.WriteVInt32(PackedInts.VERSION_CURRENT);
+                Meta.WriteVInt32(PackedInt32s.VERSION_CURRENT);
                 Data.WriteVInt32(Lucene42DocValuesProducer.BLOCK_SIZE);
 
                 BlockPackedWriter writer = new BlockPackedWriter(Data, Lucene42DocValuesProducer.BLOCK_SIZE);
@@ -266,7 +266,7 @@ namespace Lucene.Net.Codecs.Lucene42
             // otherwise, we need to record the length fields...
             if (minLength != maxLength)
             {
-                Meta.WriteVInt32(PackedInts.VERSION_CURRENT);
+                Meta.WriteVInt32(PackedInt32s.VERSION_CURRENT);
                 Meta.WriteVInt32(Lucene42DocValuesProducer.BLOCK_SIZE);
 
                 MonotonicBlockPackedWriter writer = new MonotonicBlockPackedWriter(Data, Lucene42DocValuesProducer.BLOCK_SIZE);
@@ -288,9 +288,9 @@ namespace Lucene.Net.Codecs.Lucene42
             Meta.WriteVInt32(field.Number);
             Meta.WriteByte((byte)Lucene42DocValuesProducer.FST);
             Meta.WriteInt64(Data.FilePointer);
-            PositiveIntOutputs outputs = PositiveIntOutputs.Singleton;
+            PositiveInt32Outputs outputs = PositiveInt32Outputs.Singleton;
             Builder<long?> builder = new Builder<long?>(INPUT_TYPE.BYTE1, outputs);
-            IntsRef scratch = new IntsRef();
+            Int32sRef scratch = new Int32sRef();
             long ord = 0;
             foreach (BytesRef v in values)
             {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.TestFramework/Codecs/ramonly/RAMOnlyPostingsFormat.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.TestFramework/Codecs/ramonly/RAMOnlyPostingsFormat.cs b/src/Lucene.Net.TestFramework/Codecs/ramonly/RAMOnlyPostingsFormat.cs
index 7cfddf4..2a10d2b 100644
--- a/src/Lucene.Net.TestFramework/Codecs/ramonly/RAMOnlyPostingsFormat.cs
+++ b/src/Lucene.Net.TestFramework/Codecs/ramonly/RAMOnlyPostingsFormat.cs
@@ -651,7 +651,7 @@ namespace Lucene.Net.Codecs.ramonly
         // Holds all indexes created, keyed by the ID assigned in fieldsConsumer
         private readonly IDictionary<int?, RAMPostings> State = new Dictionary<int?, RAMPostings>();
 
-        private readonly AtomicLong NextID = new AtomicLong();
+        private readonly AtomicInt64 NextID = new AtomicInt64();
 
         private readonly string RAM_ONLY_NAME = "RAMOnly";
         private const int VERSION_START = 0;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.TestFramework/Index/BaseCompressingDocValuesFormatTestCase.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.TestFramework/Index/BaseCompressingDocValuesFormatTestCase.cs b/src/Lucene.Net.TestFramework/Index/BaseCompressingDocValuesFormatTestCase.cs
index e0e7047..cf93d33 100644
--- a/src/Lucene.Net.TestFramework/Index/BaseCompressingDocValuesFormatTestCase.cs
+++ b/src/Lucene.Net.TestFramework/Index/BaseCompressingDocValuesFormatTestCase.cs
@@ -27,7 +27,7 @@ namespace Lucene.Net.Index
 
     using MockAnalyzer = Lucene.Net.Analysis.MockAnalyzer;
     using NumericDocValuesField = NumericDocValuesField;
-    using PackedInts = Lucene.Net.Util.Packed.PackedInts;
+    using PackedInt32s = Lucene.Net.Util.Packed.PackedInt32s;
     using RAMDirectory = Lucene.Net.Store.RAMDirectory;
     using TestUtil = Lucene.Net.Util.TestUtil;
 
@@ -114,7 +114,7 @@ namespace Lucene.Net.Index
             iwriter.ForceMerge(1);
             long size2 = DirSize(dir);
             // make sure the new longs costed less than if they had only been packed
-            Assert.IsTrue(size2 < size1 + (PackedInts.BitsRequired(day) * 50) / 8);
+            Assert.IsTrue(size2 < size1 + (PackedInt32s.BitsRequired(day) * 50) / 8);
         }
 
         // [Test] // LUCENENET NOTE: For now, we are overriding this test in every subclass to pull it into the right context for the subclass

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.TestFramework/Index/BaseDocValuesFormatTestCase.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.TestFramework/Index/BaseDocValuesFormatTestCase.cs b/src/Lucene.Net.TestFramework/Index/BaseDocValuesFormatTestCase.cs
index accdbbe..07a7970 100644
--- a/src/Lucene.Net.TestFramework/Index/BaseDocValuesFormatTestCase.cs
+++ b/src/Lucene.Net.TestFramework/Index/BaseDocValuesFormatTestCase.cs
@@ -38,7 +38,7 @@ namespace Lucene.Net.Index
     using Directory = Lucene.Net.Store.Directory;
     using Document = Documents.Document;
     using Field = Field;
-    using FloatDocValuesField = FloatDocValuesField;
+    using SingleDocValuesField = SingleDocValuesField;
     using IndexSearcher = Lucene.Net.Search.IndexSearcher;
     using Lucene42DocValuesFormat = Lucene.Net.Codecs.Lucene42.Lucene42DocValuesFormat;
     using MockAnalyzer = Lucene.Net.Analysis.MockAnalyzer;
@@ -128,7 +128,7 @@ namespace Lucene.Net.Index
             string longTerm = "longtermlongtermlongtermlongtermlongtermlongtermlongtermlongtermlongtermlongtermlongtermlongtermlongtermlongtermlongtermlongtermlongtermlongterm";
             string text = "this is the text to be indexed. " + longTerm;
             doc.Add(NewTextField("fieldname", text, Field.Store.YES));
-            doc.Add(new FloatDocValuesField("dv", 5.7f));
+            doc.Add(new SingleDocValuesField("dv", 5.7f));
             iwriter.AddDocument(doc);
             iwriter.Dispose();
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.TestFramework/Index/BaseStoredFieldsFormatTestCase.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.TestFramework/Index/BaseStoredFieldsFormatTestCase.cs b/src/Lucene.Net.TestFramework/Index/BaseStoredFieldsFormatTestCase.cs
index d7a414e..30ee047 100644
--- a/src/Lucene.Net.TestFramework/Index/BaseStoredFieldsFormatTestCase.cs
+++ b/src/Lucene.Net.TestFramework/Index/BaseStoredFieldsFormatTestCase.cs
@@ -23,10 +23,10 @@ namespace Lucene.Net.Index
     using DoubleField = DoubleField;
     using Field = Field;
     using FieldType = FieldType;
-    using FloatField = FloatField;
+    using SingleField = SingleField;
     using IndexSearcher = Lucene.Net.Search.IndexSearcher;
-    using IntField = IntField;
-    using LongField = LongField;
+    using Int32Field = Int32Field;
+    using Int64Field = Int64Field;
     using Lucene46Codec = Lucene.Net.Codecs.Lucene46.Lucene46Codec;
     using MMapDirectory = Lucene.Net.Store.MMapDirectory;
 
@@ -284,7 +284,7 @@ namespace Lucene.Net.Index
                     {
                         float f = Random().NextFloat();
                         answer = Convert.ToSingle(f);
-                        nf = new FloatField("nf", f, Field.Store.NO);
+                        nf = new SingleField("nf", f, Field.Store.NO);
                         sf = new StoredField("nf", f);
                         typeAnswer = NumericType.FLOAT;
                     }
@@ -304,7 +304,7 @@ namespace Lucene.Net.Index
                     {
                         int i = Random().Next();
                         answer = Convert.ToInt32(i);
-                        nf = new IntField("nf", i, Field.Store.NO);
+                        nf = new Int32Field("nf", i, Field.Store.NO);
                         sf = new StoredField("nf", i);
                         typeAnswer = NumericType.INT;
                     }
@@ -312,7 +312,7 @@ namespace Lucene.Net.Index
                     {
                         long l = Random().NextLong();
                         answer = Convert.ToInt64(l);
-                        nf = new LongField("nf", l, Field.Store.NO);
+                        nf = new Int64Field("nf", l, Field.Store.NO);
                         sf = new StoredField("nf", l);
                         typeAnswer = NumericType.LONG;
                     }
@@ -321,9 +321,9 @@ namespace Lucene.Net.Index
                 doc.Add(sf);
                 answers[id] = answer;
                 typeAnswers[id] = typeAnswer;
-                FieldType ft = new FieldType(IntField.TYPE_STORED);
+                FieldType ft = new FieldType(Int32Field.TYPE_STORED);
                 ft.NumericPrecisionStep = int.MaxValue;
-                doc.Add(new IntField("id", id, ft));
+                doc.Add(new Int32Field("id", id, ft));
                 w.AddDocument(doc);
             }
             DirectoryReader r = w.Reader;
@@ -334,7 +334,7 @@ namespace Lucene.Net.Index
             foreach (AtomicReaderContext ctx in r.Leaves)
             {
                 AtomicReader sub = (AtomicReader)ctx.Reader;
-                FieldCache.Ints ids = FieldCache.DEFAULT.GetInt32s(sub, "id", false);
+                FieldCache.Int32s ids = FieldCache.DEFAULT.GetInt32s(sub, "id", false);
                 for (int docID = 0; docID < sub.NumDocs; docID++)
                 {
                     Document doc = sub.Document(docID);
@@ -385,7 +385,7 @@ namespace Lucene.Net.Index
             float f = Random().NextFloat();
             double d = Random().NextDouble();
 
-            IList<Field> fields = Arrays.AsList(new Field("bytes", bytes, ft), new Field("string", @string, ft), new LongField("long", l, Field.Store.YES), new IntField("int", i, Field.Store.YES), new FloatField("float", f, Field.Store.YES), new DoubleField("double", d, Field.Store.YES)
+            IList<Field> fields = Arrays.AsList(new Field("bytes", bytes, ft), new Field("string", @string, ft), new Int64Field("long", l, Field.Store.YES), new Int32Field("int", i, Field.Store.YES), new SingleField("float", f, Field.Store.YES), new DoubleField("double", d, Field.Store.YES)
            );
 
             for (int k = 0; k < 100; ++k)
@@ -600,7 +600,7 @@ namespace Lucene.Net.Index
             FieldType type = new FieldType(StringField.TYPE_STORED);
             type.IsIndexed = false;
             type.Freeze();
-            IntField id = new IntField("id", 0, Field.Store.YES);
+            Int32Field id = new Int32Field("id", 0, Field.Store.YES);
             for (int i = 0; i < data.Length; ++i)
             {
                 Document doc = new Document();

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.TestFramework/Index/ThreadedIndexingAndSearchingTestCase.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.TestFramework/Index/ThreadedIndexingAndSearchingTestCase.cs b/src/Lucene.Net.TestFramework/Index/ThreadedIndexingAndSearchingTestCase.cs
index e3ccfb6..f2ee00b 100644
--- a/src/Lucene.Net.TestFramework/Index/ThreadedIndexingAndSearchingTestCase.cs
+++ b/src/Lucene.Net.TestFramework/Index/ThreadedIndexingAndSearchingTestCase.cs
@@ -64,9 +64,9 @@ namespace Lucene.Net.Index
     public abstract class ThreadedIndexingAndSearchingTestCase : LuceneTestCase
     {
         protected internal readonly AtomicBoolean Failed = new AtomicBoolean();
-        protected internal readonly AtomicInteger AddCount = new AtomicInteger();
-        protected internal readonly AtomicInteger DelCount = new AtomicInteger();
-        protected internal readonly AtomicInteger PackCount = new AtomicInteger();
+        protected internal readonly AtomicInt32 AddCount = new AtomicInt32();
+        protected internal readonly AtomicInt32 DelCount = new AtomicInt32();
+        protected internal readonly AtomicInt32 PackCount = new AtomicInt32();
 
         protected internal Directory Dir;
         protected internal IndexWriter Writer;
@@ -396,10 +396,10 @@ namespace Lucene.Net.Index
         {
             int numThreads = TestUtil.NextInt(Random(), 1, 5);
             ThreadClass[] searchThreads = new ThreadClass[numThreads];
-            AtomicInteger totHits = new AtomicInteger();
+            AtomicInt32 totHits = new AtomicInt32();
 
             // silly starting guess:
-            AtomicInteger totTermCount = new AtomicInteger(100);
+            AtomicInt32 totTermCount = new AtomicInt32(100);
 
             // TODO: we should enrich this to do more interesting searches
             for (int thread = 0; thread < searchThreads.Length; thread++)
@@ -425,10 +425,10 @@ namespace Lucene.Net.Index
             private readonly ThreadedIndexingAndSearchingTestCase OuterInstance;
 
             private DateTime StopTime;
-            private AtomicInteger TotHits;
-            private AtomicInteger TotTermCount;
+            private AtomicInt32 TotHits;
+            private AtomicInt32 TotTermCount;
 
-            public ThreadAnonymousInnerClassHelper2(ThreadedIndexingAndSearchingTestCase outerInstance, DateTime stopTime, AtomicInteger totHits, AtomicInteger totTermCount)
+            public ThreadAnonymousInnerClassHelper2(ThreadedIndexingAndSearchingTestCase outerInstance, DateTime stopTime, AtomicInt32 totHits, AtomicInt32 totTermCount)
             {
                 this.OuterInstance = outerInstance;
                 this.StopTime = stopTime;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.TestFramework/Store/MockDirectoryWrapper.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.TestFramework/Store/MockDirectoryWrapper.cs b/src/Lucene.Net.TestFramework/Store/MockDirectoryWrapper.cs
index 4064635..a287adc 100644
--- a/src/Lucene.Net.TestFramework/Store/MockDirectoryWrapper.cs
+++ b/src/Lucene.Net.TestFramework/Store/MockDirectoryWrapper.cs
@@ -80,7 +80,7 @@ namespace Lucene.Net.Store
         private Throttling_e throttling = Throttling_e.SOMETIMES;
         protected internal LockFactory LockFactory_Renamed;
 
-        internal readonly AtomicLong InputCloneCount_Renamed = new AtomicLong();
+        internal readonly AtomicInt64 InputCloneCount_Renamed = new AtomicInt64();
 
         // use this for tracking files for crash.
         // additionally: provides debugging information in case you leave one open

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.TestFramework/Util/LineFileDocs.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.TestFramework/Util/LineFileDocs.cs b/src/Lucene.Net.TestFramework/Util/LineFileDocs.cs
index 34abd32..0b71ef0 100644
--- a/src/Lucene.Net.TestFramework/Util/LineFileDocs.cs
+++ b/src/Lucene.Net.TestFramework/Util/LineFileDocs.cs
@@ -43,7 +43,7 @@ namespace Lucene.Net.Util
     {
         private TextReader Reader;
         //private static readonly int BUFFER_SIZE = 1 << 16; // 64K // LUCENENET NOTE: Not used because we don't have a BufferedReader in .NET
-        private readonly AtomicInteger Id = new AtomicInteger();
+        private readonly AtomicInt32 Id = new AtomicInt32();
         private readonly string Path;
         private readonly bool UseDocValues;
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.TestFramework/Util/TestUtil.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.TestFramework/Util/TestUtil.cs b/src/Lucene.Net.TestFramework/Util/TestUtil.cs
index dd3285a..7fee1f9 100644
--- a/src/Lucene.Net.TestFramework/Util/TestUtil.cs
+++ b/src/Lucene.Net.TestFramework/Util/TestUtil.cs
@@ -53,13 +53,13 @@ namespace Lucene.Net.Util
     using FieldDoc = Lucene.Net.Search.FieldDoc;
     using FieldType = FieldType;
     using FilteredQuery = Lucene.Net.Search.FilteredQuery;
-    using FloatField = FloatField;
+    using SingleField = SingleField;
     using IIndexableField = Lucene.Net.Index.IIndexableField;
     using IndexReader = Lucene.Net.Index.IndexReader;
     using IndexWriter = Lucene.Net.Index.IndexWriter;
-    using IntField = IntField;
+    using Int32Field = Int32Field;
     using LogMergePolicy = Lucene.Net.Index.LogMergePolicy;
-    using LongField = LongField;
+    using Int64Field = Int64Field;
     using Lucene46Codec = Lucene.Net.Codecs.Lucene46.Lucene46Codec;
     using MergePolicy = Lucene.Net.Index.MergePolicy;
     using MergeScheduler = Lucene.Net.Index.MergeScheduler;
@@ -1059,15 +1059,15 @@ namespace Lucene.Net.Util
                     switch (numType)
                     {
                         case NumericType.INT:
-                            field2 = new IntField(field1.Name, (int)field1.GetNumericValue(), (FieldType)field1.FieldType);
+                            field2 = new Int32Field(field1.Name, (int)field1.GetNumericValue(), (FieldType)field1.FieldType);
                             break;
 
                         case NumericType.FLOAT:
-                            field2 = new FloatField(field1.Name, (int)field1.GetNumericValue(), (FieldType)field1.FieldType);
+                            field2 = new SingleField(field1.Name, (int)field1.GetNumericValue(), (FieldType)field1.FieldType);
                             break;
 
                         case NumericType.LONG:
-                            field2 = new LongField(field1.Name, (int)field1.GetNumericValue(), (FieldType)field1.FieldType);
+                            field2 = new Int64Field(field1.Name, (int)field1.GetNumericValue(), (FieldType)field1.FieldType);
                             break;
 
                         case NumericType.DOUBLE:

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.TestFramework/Util/fst/FSTTester.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.TestFramework/Util/fst/FSTTester.cs b/src/Lucene.Net.TestFramework/Util/fst/FSTTester.cs
index 7889b94..46c6f61 100644
--- a/src/Lucene.Net.TestFramework/Util/fst/FSTTester.cs
+++ b/src/Lucene.Net.TestFramework/Util/fst/FSTTester.cs
@@ -32,7 +32,7 @@ namespace Lucene.Net.Util.Fst
     using IndexInput = Lucene.Net.Store.IndexInput;
     using IndexOutput = Lucene.Net.Store.IndexOutput;
     using IOContext = Lucene.Net.Store.IOContext;
-    using PackedInts = Lucene.Net.Util.Packed.PackedInts;
+    using PackedInt32s = Lucene.Net.Util.Packed.PackedInt32s;
 
     /// <summary>
     /// Helper class to test FSTs. </summary>
@@ -55,12 +55,12 @@ namespace Lucene.Net.Util.Fst
             this.DoReverseLookup = doReverseLookup;
         }
 
-        internal static string InputToString(int inputMode, IntsRef term)
+        internal static string InputToString(int inputMode, Int32sRef term)
         {
             return InputToString(inputMode, term, true);
         }
 
-        internal static string InputToString(int inputMode, IntsRef term, bool isValidUnicode)
+        internal static string InputToString(int inputMode, Int32sRef term, bool isValidUnicode)
         {
             if (!isValidUnicode)
             {
@@ -78,7 +78,7 @@ namespace Lucene.Net.Util.Fst
             }
         }
 
-        private static BytesRef ToBytesRef(IntsRef ir)
+        private static BytesRef ToBytesRef(Int32sRef ir)
         {
             BytesRef br = new BytesRef(ir.Length);
             for (int i = 0; i < ir.Length; i++)
@@ -124,12 +124,12 @@ namespace Lucene.Net.Util.Fst
             return new string(buffer, 0, end);
         }
 
-        internal static IntsRef ToIntsRef(string s, int inputMode)
+        internal static Int32sRef ToIntsRef(string s, int inputMode)
         {
-            return ToIntsRef(s, inputMode, new IntsRef(10));
+            return ToIntsRef(s, inputMode, new Int32sRef(10));
         }
 
-        internal static IntsRef ToIntsRef(string s, int inputMode, IntsRef ir)
+        internal static Int32sRef ToIntsRef(string s, int inputMode, Int32sRef ir)
         {
             if (inputMode == 0)
             {
@@ -143,7 +143,7 @@ namespace Lucene.Net.Util.Fst
             }
         }
 
-        internal static IntsRef ToIntsRefUTF32(string s, IntsRef ir)
+        internal static Int32sRef ToIntsRefUTF32(string s, Int32sRef ir)
         {
             int charLength = s.Length;
             int charIdx = 0;
@@ -163,7 +163,7 @@ namespace Lucene.Net.Util.Fst
             return ir;
         }
 
-        internal static IntsRef ToIntsRef(BytesRef br, IntsRef ir)
+        internal static Int32sRef ToIntsRef(BytesRef br, Int32sRef ir)
         {
             if (br.Length > ir.Int32s.Length)
             {
@@ -181,10 +181,10 @@ namespace Lucene.Net.Util.Fst
         /// Holds one input/output pair. </summary>
         public class InputOutput<T1> : IComparable<InputOutput<T1>>
         {
-            public readonly IntsRef Input;
+            public readonly Int32sRef Input;
             public readonly T1 Output;
 
-            public InputOutput(IntsRef input, T1 output)
+            public InputOutput(Int32sRef input, T1 output)
             {
                 this.Input = input;
                 this.Output = output;
@@ -215,7 +215,7 @@ namespace Lucene.Net.Util.Fst
         // isn't accepted.  if prefixLength is non-null it must be
         // length 1 int array; prefixLength[0] is set to the length
         // of the term prefix that matches
-        private T Run(FST<T> fst, IntsRef term, int[] prefixLength)
+        private T Run(FST<T> fst, Int32sRef term, int[] prefixLength)
         {
             Debug.Assert(prefixLength == null || prefixLength.Length == 1);
             FST.Arc<T> arc = fst.GetFirstArc(new FST.Arc<T>());
@@ -259,7 +259,7 @@ namespace Lucene.Net.Util.Fst
             return output;
         }
 
-        private T RandomAcceptedWord(FST<T> fst, IntsRef @in)
+        private T RandomAcceptedWord(FST<T> fst, Int32sRef @in)
         {
             FST.Arc<T> arc = fst.GetFirstArc(new FST.Arc<T>());
 
@@ -321,7 +321,7 @@ namespace Lucene.Net.Util.Fst
                                                 Outputs, 
                                                 null, 
                                                 willRewrite, 
-                                                PackedInts.DEFAULT, 
+                                                PackedInt32s.DEFAULT, 
                                                 true, 
                                                 15);
             if (LuceneTestCase.VERBOSE)
@@ -470,10 +470,10 @@ namespace Lucene.Net.Util.Fst
                 Console.WriteLine("TEST: check valid terms/next()");
             }
             {
-                IntsRefFSTEnum<T> fstEnum = new IntsRefFSTEnum<T>(fst);
+                Int32sRefFSTEnum<T> fstEnum = new Int32sRefFSTEnum<T>(fst);
                 foreach (InputOutput<T> pair in Pairs)
                 {
-                    IntsRef term = pair.Input;
+                    Int32sRef term = pair.Input;
                     if (LuceneTestCase.VERBOSE)
                     {
                         Console.WriteLine("TEST: check term=" + InputToString(inputMode, term) + " output=" + fst.Outputs.OutputToString(pair.Output));
@@ -483,7 +483,7 @@ namespace Lucene.Net.Util.Fst
                     Assert.IsTrue(OutputsEqual(pair.Output, output));
 
                     // verify enum's next
-                    IntsRefFSTEnum.InputOutput<T> t = fstEnum.Next();
+                    Int32sRefFSTEnum.InputOutput<T> t = fstEnum.Next();
                     Assert.IsNotNull(t);
                     Assert.AreEqual(term, t.Input, "expected input=" + InputToString(inputMode, term) + " but fstEnum returned " + InputToString(inputMode, t.Input));
                     Assert.IsTrue(OutputsEqual(pair.Output, t.Output));
@@ -491,7 +491,7 @@ namespace Lucene.Net.Util.Fst
                 Assert.IsNull(fstEnum.Next());
             }
 
-            IDictionary<IntsRef, T> termsMap = new Dictionary<IntsRef, T>();
+            IDictionary<Int32sRef, T> termsMap = new Dictionary<Int32sRef, T>();
             foreach (InputOutput<T> pair in Pairs)
             {
                 termsMap[pair.Input] = pair.Output;
@@ -508,7 +508,7 @@ namespace Lucene.Net.Util.Fst
                 for (int iter = 0; iter < num; iter++)
                 {
                     long v = TestUtil.NextLong(Random, minLong, maxLong);
-                    IntsRef input = Util.GetByOutput(fstLong, v);
+                    Int32sRef input = Util.GetByOutput(fstLong, v);
                     Assert.IsTrue(validOutputs.Contains(v) || input == null);
                 }
             }
@@ -518,7 +518,7 @@ namespace Lucene.Net.Util.Fst
             {
                 Console.WriteLine("TEST: verify random accepted terms");
             }
-            IntsRef scratch = new IntsRef(10);
+            Int32sRef scratch = new Int32sRef(10);
             int num_ = LuceneTestCase.AtLeast(Random, 500);
             for (int iter = 0; iter < num_; iter++)
             {
@@ -529,7 +529,7 @@ namespace Lucene.Net.Util.Fst
                 if (DoReverseLookup)
                 {
                     //System.out.println("lookup output=" + output + " outs=" + fst.Outputs);
-                    IntsRef input = Util.GetByOutput(fstLong, (output as long?).Value);
+                    Int32sRef input = Util.GetByOutput(fstLong, (output as long?).Value);
                     Assert.IsNotNull(input);
                     //System.out.println("  got " + Util.toBytesRef(input, new BytesRef()).utf8ToString());
                     Assert.AreEqual(scratch, input);
@@ -541,7 +541,7 @@ namespace Lucene.Net.Util.Fst
             {
                 Console.WriteLine("TEST: verify seek");
             }
-            IntsRefFSTEnum<T> fstEnum_ = new IntsRefFSTEnum<T>(fst);
+            Int32sRefFSTEnum<T> fstEnum_ = new Int32sRefFSTEnum<T>(fst);
             num_ = LuceneTestCase.AtLeast(Random, 100);
             for (int iter = 0; iter < num_; iter++)
             {
@@ -554,14 +554,14 @@ namespace Lucene.Net.Util.Fst
                     // seek to term that doesn't exist:
                     while (true)
                     {
-                        IntsRef term = ToIntsRef(GetRandomString(Random), inputMode);
+                        Int32sRef term = ToIntsRef(GetRandomString(Random), inputMode);
                         int pos = Pairs.BinarySearch(new InputOutput<T>(term, default(T)));
                         if (pos < 0)
                         {
                             pos = -(pos + 1);
                             // ok doesn't exist
                             //System.out.println("  seek " + inputToString(inputMode, term));
-                            IntsRefFSTEnum.InputOutput<T> seekResult;
+                            Int32sRefFSTEnum.InputOutput<T> seekResult;
                             if (Random.Next(3) == 0)
                             {
                                 if (LuceneTestCase.VERBOSE)
@@ -619,7 +619,7 @@ namespace Lucene.Net.Util.Fst
                 {
                     // seek to term that does exist:
                     InputOutput<T> pair = Pairs[Random.Next(Pairs.Count)];
-                    IntsRefFSTEnum.InputOutput<T> seekResult;
+                    Int32sRefFSTEnum.InputOutput<T> seekResult;
                     if (Random.Next(3) == 2)
                     {
                         if (LuceneTestCase.VERBOSE)
@@ -664,7 +664,7 @@ namespace Lucene.Net.Util.Fst
                     Console.WriteLine("TEST: iter " + iter);
                 }
                 // reset:
-                fstEnum_ = new IntsRefFSTEnum<T>(fst);
+                fstEnum_ = new Int32sRefFSTEnum<T>(fst);
                 int upto = -1;
                 while (true)
                 {
@@ -684,7 +684,7 @@ namespace Lucene.Net.Util.Fst
                         int attempt = 0;
                         for (; attempt < 10; attempt++)
                         {
-                            IntsRef term = ToIntsRef(GetRandomString(Random), inputMode);
+                            Int32sRef term = ToIntsRef(GetRandomString(Random), inputMode);
                             if (!termsMap.ContainsKey(term) && term.CompareTo(Pairs[upto].Input) > 0)
                             {
                                 int pos = Pairs.BinarySearch(new InputOutput<T>(term, default(T)));
@@ -820,8 +820,8 @@ namespace Lucene.Net.Util.Fst
             //System.out.println("TEST: tally prefixes");
 
             // build all prefixes
-            IDictionary<IntsRef, CountMinOutput<T>> prefixes = new HashMap<IntsRef, CountMinOutput<T>>();
-            IntsRef scratch = new IntsRef(10);
+            IDictionary<Int32sRef, CountMinOutput<T>> prefixes = new HashMap<Int32sRef, CountMinOutput<T>>();
+            Int32sRef scratch = new Int32sRef(10);
             foreach (InputOutput<T> pair in Pairs)
             {
                 scratch.CopyInt32s(pair.Input);
@@ -834,7 +834,7 @@ namespace Lucene.Net.Util.Fst
                         cmo = new CountMinOutput<T>();
                         cmo.Count = 1;
                         cmo.Output = pair.Output;
-                        prefixes[IntsRef.DeepCopyOf(scratch)] = cmo;
+                        prefixes[Int32sRef.DeepCopyOf(scratch)] = cmo;
                     }
                     else
                     {
@@ -870,8 +870,8 @@ namespace Lucene.Net.Util.Fst
             // in .NET you cannot delete records while enumerating forward through a dictionary.
             for (int i = prefixes.Count - 1; i >= 0; i--)
             {
-                KeyValuePair<IntsRef, CountMinOutput<T>> ent = prefixes.ElementAt(i);
-                IntsRef prefix = ent.Key;
+                KeyValuePair<Int32sRef, CountMinOutput<T>> ent = prefixes.ElementAt(i);
+                Int32sRef prefix = ent.Key;
                 CountMinOutput<T> cmo = ent.Value;
                 if (LuceneTestCase.VERBOSE)
                 {
@@ -935,7 +935,7 @@ namespace Lucene.Net.Util.Fst
             if (LuceneTestCase.VERBOSE)
             {
                 Console.WriteLine("TEST: after prune");
-                foreach (KeyValuePair<IntsRef, CountMinOutput<T>> ent in prefixes)
+                foreach (KeyValuePair<Int32sRef, CountMinOutput<T>> ent in prefixes)
                 {
                     Console.WriteLine("  " + InputToString(inputMode, ent.Key, false) + ": isLeaf=" + ent.Value.IsLeaf + " isFinal=" + ent.Value.IsFinal);
                     if (ent.Value.IsFinal)
@@ -958,8 +958,8 @@ namespace Lucene.Net.Util.Fst
             {
                 Console.WriteLine("TEST: check pruned enum");
             }
-            IntsRefFSTEnum<T> fstEnum = new IntsRefFSTEnum<T>(fst);
-            IntsRefFSTEnum.InputOutput<T> current;
+            Int32sRefFSTEnum<T> fstEnum = new Int32sRefFSTEnum<T>(fst);
+            Int32sRefFSTEnum.InputOutput<T> current;
             while ((current = fstEnum.Next()) != null)
             {
                 if (LuceneTestCase.VERBOSE)
@@ -986,7 +986,7 @@ namespace Lucene.Net.Util.Fst
                 Console.WriteLine("TEST: verify all prefixes");
             }
             int[] stopNode = new int[1];
-            foreach (KeyValuePair<IntsRef, CountMinOutput<T>> ent in prefixes)
+            foreach (KeyValuePair<Int32sRef, CountMinOutput<T>> ent in prefixes)
             {
                 if (ent.Key.Length > 0)
                 {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Tests.Analysis.Common/Analysis/Hunspell/TestDictionary.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests.Analysis.Common/Analysis/Hunspell/TestDictionary.cs b/src/Lucene.Net.Tests.Analysis.Common/Analysis/Hunspell/TestDictionary.cs
index ec404cf..44bc82e 100644
--- a/src/Lucene.Net.Tests.Analysis.Common/Analysis/Hunspell/TestDictionary.cs
+++ b/src/Lucene.Net.Tests.Analysis.Common/Analysis/Hunspell/TestDictionary.cs
@@ -40,7 +40,7 @@ namespace Lucene.Net.Analysis.Hunspell
                     Dictionary dictionary = new Dictionary(affixStream, dictStream);
                     assertEquals(3, dictionary.LookupSuffix(new char[] { 'e' }, 0, 1).Length);
                     assertEquals(1, dictionary.LookupPrefix(new char[] { 's' }, 0, 1).Length);
-                    IntsRef ordList = dictionary.LookupWord(new char[] { 'o', 'l', 'r' }, 0, 3);
+                    Int32sRef ordList = dictionary.LookupWord(new char[] { 'o', 'l', 'r' }, 0, 3);
                     assertNotNull(ordList);
                     assertEquals(1, ordList.Length);
 
@@ -70,7 +70,7 @@ namespace Lucene.Net.Analysis.Hunspell
                     Dictionary dictionary = new Dictionary(affixStream, dictStream);
                     assertEquals(3, dictionary.LookupSuffix(new char[] { 'e' }, 0, 1).Length);
                     assertEquals(1, dictionary.LookupPrefix(new char[] { 's' }, 0, 1).Length);
-                    IntsRef ordList = dictionary.LookupWord(new char[] { 'o', 'l', 'r' }, 0, 3);
+                    Int32sRef ordList = dictionary.LookupWord(new char[] { 'o', 'l', 'r' }, 0, 3);
                     BytesRef @ref = new BytesRef();
                     dictionary.flagLookup.Get(ordList.Int32s[0], @ref);
                     char[] flags = Dictionary.DecodeFlags(@ref);
@@ -90,7 +90,7 @@ namespace Lucene.Net.Analysis.Hunspell
                     Dictionary dictionary = new Dictionary(affixStream, dictStream);
                     assertEquals(3, dictionary.LookupSuffix(new char[] { 'e' }, 0, 1).Length);
                     assertEquals(1, dictionary.LookupPrefix(new char[] { 's' }, 0, 1).Length);
-                    IntsRef ordList = dictionary.LookupWord(new char[] { 'o', 'l', 'r' }, 0, 3);
+                    Int32sRef ordList = dictionary.LookupWord(new char[] { 'o', 'l', 'r' }, 0, 3);
                     BytesRef @ref = new BytesRef();
                     dictionary.flagLookup.Get(ordList.Int32s[0], @ref);
                     char[] flags = Dictionary.DecodeFlags(@ref);
@@ -109,7 +109,7 @@ namespace Lucene.Net.Analysis.Hunspell
                     Dictionary dictionary = new Dictionary(affixStream, dictStream);
                     assertEquals(3, dictionary.LookupSuffix(new char[] { 'e' }, 0, 1).Length);
                     assertEquals(1, dictionary.LookupPrefix(new char[] { 's' }, 0, 1).Length);
-                    IntsRef ordList = dictionary.LookupWord(new char[] { 'o', 'l', 'r' }, 0, 3);
+                    Int32sRef ordList = dictionary.LookupWord(new char[] { 'o', 'l', 'r' }, 0, 3);
                     BytesRef @ref = new BytesRef();
                     dictionary.flagLookup.Get(ordList.Int32s[0], @ref);
                     char[] flags = Dictionary.DecodeFlags(@ref);
@@ -289,7 +289,7 @@ namespace Lucene.Net.Analysis.Hunspell
         {
             Outputs<CharsRef> outputs = CharSequenceOutputs.Singleton;
             Builder<CharsRef> builder = new Builder<CharsRef>(FST.INPUT_TYPE.BYTE2, outputs);
-            IntsRef scratchInts = new IntsRef();
+            Int32sRef scratchInts = new Int32sRef();
 
             // a -> b
             Lucene.Net.Util.Fst.Util.ToUTF16("a", scratchInts);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Tests.Expressions/TestExpressionSorts.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests.Expressions/TestExpressionSorts.cs b/src/Lucene.Net.Tests.Expressions/TestExpressionSorts.cs
index 054d388..dcf6cd6 100644
--- a/src/Lucene.Net.Tests.Expressions/TestExpressionSorts.cs
+++ b/src/Lucene.Net.Tests.Expressions/TestExpressionSorts.cs
@@ -45,12 +45,12 @@ namespace Lucene.Net.Tests.Expressions
 				        ())), Field.Store.NO),
 				    NewStringField("short", string.Empty + ((short) Random().Next()), Field.Store
 				        .NO),
-				    new IntField("int", Random().Next(), Field.Store.NO),
-				    new LongField("long", Random().NextLong(), Field.Store.NO),
-				    new FloatField("float", Random().NextFloat(), Field.Store.NO),
+				    new Int32Field("int", Random().Next(), Field.Store.NO),
+				    new Int64Field("long", Random().NextLong(), Field.Store.NO),
+				    new SingleField("float", Random().NextFloat(), Field.Store.NO),
 				    new DoubleField("double", Random().NextDouble(), Field.Store.NO),
 				    new NumericDocValuesField("intdocvalues", Random().Next()),
-				    new FloatDocValuesField("floatdocvalues", Random().NextFloat())
+				    new SingleDocValuesField("floatdocvalues", Random().NextFloat())
 				};
                 iw.AddDocument(document);
             }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Tests.Facet/Range/TestRangeFacetCounts.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests.Facet/Range/TestRangeFacetCounts.cs b/src/Lucene.Net.Tests.Facet/Range/TestRangeFacetCounts.cs
index 14060c2..d128c36 100644
--- a/src/Lucene.Net.Tests.Facet/Range/TestRangeFacetCounts.cs
+++ b/src/Lucene.Net.Tests.Facet/Range/TestRangeFacetCounts.cs
@@ -32,9 +32,9 @@ namespace Lucene.Net.Facet.Range
     using DoubleDocValuesField = Lucene.Net.Documents.DoubleDocValuesField;
     using DoubleField = Lucene.Net.Documents.DoubleField;
     using Field = Lucene.Net.Documents.Field;
-    using FloatDocValuesField = Lucene.Net.Documents.FloatDocValuesField;
-    using FloatField = Lucene.Net.Documents.FloatField;
-    using LongField = Lucene.Net.Documents.LongField;
+    using SingleDocValuesField = Lucene.Net.Documents.SingleDocValuesField;
+    using SingleField = Lucene.Net.Documents.SingleField;
+    using Int64Field = Lucene.Net.Documents.Int64Field;
     using NumericDocValuesField = Lucene.Net.Documents.NumericDocValuesField;
     using DrillSidewaysResult = Lucene.Net.Facet.DrillSideways.DrillSidewaysResult;
     using TaxonomyReader = Lucene.Net.Facet.Taxonomy.TaxonomyReader;
@@ -229,7 +229,7 @@ namespace Lucene.Net.Facet.Range
                 // For computing range facet counts:
                 doc.Add(new NumericDocValuesField("field", l));
                 // For drill down by numeric range:
-                doc.Add(new LongField("field", l, Field.Store.NO));
+                doc.Add(new Int64Field("field", l, Field.Store.NO));
 
                 if ((l & 3) == 0)
                 {
@@ -358,7 +358,7 @@ namespace Lucene.Net.Facet.Range
             Directory d = NewDirectory();
             RandomIndexWriter w = new RandomIndexWriter(Random(), d, Similarity, TimeZone);
             Document doc = new Document();
-            FloatDocValuesField field = new FloatDocValuesField("field", 0.0f);
+            SingleDocValuesField field = new SingleDocValuesField("field", 0.0f);
             doc.Add(field);
             for (long l = 0; l < 100; l++)
             {
@@ -400,7 +400,7 @@ namespace Lucene.Net.Facet.Range
                 long v = Random().NextLong();
                 values[i] = v;
                 doc.Add(new NumericDocValuesField("field", v));
-                doc.Add(new LongField("field", v, Field.Store.NO));
+                doc.Add(new Int64Field("field", v, Field.Store.NO));
                 w.AddDocument(doc);
                 minValue = Math.Min(minValue, v);
                 maxValue = Math.Max(maxValue, v);
@@ -588,8 +588,8 @@ namespace Lucene.Net.Facet.Range
                 Document doc = new Document();
                 float v = Random().NextFloat();
                 values[i] = v;
-                doc.Add(new FloatDocValuesField("field", v));
-                doc.Add(new FloatField("field", v, Field.Store.NO));
+                doc.Add(new SingleDocValuesField("field", v));
+                doc.Add(new SingleField("field", v, Field.Store.NO));
                 w.AddDocument(doc);
                 minValue = Math.Min(minValue, v);
                 maxValue = Math.Max(maxValue, v);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Tests.Facet/Taxonomy/Directory/TestAddTaxonomy.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests.Facet/Taxonomy/Directory/TestAddTaxonomy.cs b/src/Lucene.Net.Tests.Facet/Taxonomy/Directory/TestAddTaxonomy.cs
index b896c94..2be7da3 100644
--- a/src/Lucene.Net.Tests.Facet/Taxonomy/Directory/TestAddTaxonomy.cs
+++ b/src/Lucene.Net.Tests.Facet/Taxonomy/Directory/TestAddTaxonomy.cs
@@ -39,7 +39,7 @@ namespace Lucene.Net.Facet.Taxonomy.Directory
     {
         private void Dotest(int ncats, int range)
         {
-            AtomicInteger numCats = new AtomicInteger(ncats);
+            AtomicInt32 numCats = new AtomicInt32(ncats);
             Directory[] dirs = new Directory[2];
             for (int i = 0; i < dirs.Length; i++)
             {
@@ -78,10 +78,10 @@ namespace Lucene.Net.Facet.Taxonomy.Directory
             private readonly TestAddTaxonomy outerInstance;
 
             private int range;
-            private AtomicInteger numCats;
+            private AtomicInt32 numCats;
             private DirectoryTaxonomyWriter tw;
 
-            public ThreadAnonymousInnerClassHelper(TestAddTaxonomy outerInstance, int range, AtomicInteger numCats, DirectoryTaxonomyWriter tw)
+            public ThreadAnonymousInnerClassHelper(TestAddTaxonomy outerInstance, int range, AtomicInt32 numCats, DirectoryTaxonomyWriter tw)
             {
                 this.outerInstance = outerInstance;
                 this.range = range;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Tests.Facet/Taxonomy/Directory/TestConcurrentFacetedIndexing.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests.Facet/Taxonomy/Directory/TestConcurrentFacetedIndexing.cs b/src/Lucene.Net.Tests.Facet/Taxonomy/Directory/TestConcurrentFacetedIndexing.cs
index f5971e2..1120661 100644
--- a/src/Lucene.Net.Tests.Facet/Taxonomy/Directory/TestConcurrentFacetedIndexing.cs
+++ b/src/Lucene.Net.Tests.Facet/Taxonomy/Directory/TestConcurrentFacetedIndexing.cs
@@ -106,7 +106,7 @@ namespace Lucene.Net.Facet.Taxonomy.Directory
         [Test]
         public virtual void TestConcurrency()
         {
-            AtomicInteger numDocs = new AtomicInteger(AtLeast(10000));
+            AtomicInt32 numDocs = new AtomicInt32(AtLeast(10000));
             Directory indexDir = NewDirectory();
             Directory taxoDir = NewDirectory();
             ConcurrentDictionary<string, string> values = new ConcurrentDictionary<string, string>();
@@ -172,13 +172,13 @@ namespace Lucene.Net.Facet.Taxonomy.Directory
         {
             private readonly TestConcurrentFacetedIndexing outerInstance;
 
-            private AtomicInteger numDocs;
+            private AtomicInt32 numDocs;
             private ConcurrentDictionary<string, string> values;
             private IndexWriter iw;
             private Lucene.Net.Facet.Taxonomy.Directory.DirectoryTaxonomyWriter tw;
             private FacetsConfig config;
 
-            public ThreadAnonymousInnerClassHelper(TestConcurrentFacetedIndexing outerInstance, AtomicInteger numDocs, ConcurrentDictionary<string, string> values, IndexWriter iw, Lucene.Net.Facet.Taxonomy.Directory.DirectoryTaxonomyWriter tw, FacetsConfig config)
+            public ThreadAnonymousInnerClassHelper(TestConcurrentFacetedIndexing outerInstance, AtomicInt32 numDocs, ConcurrentDictionary<string, string> values, IndexWriter iw, Lucene.Net.Facet.Taxonomy.Directory.DirectoryTaxonomyWriter tw, FacetsConfig config)
             {
                 this.outerInstance = outerInstance;
                 this.numDocs = numDocs;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Tests.Facet/Taxonomy/Directory/TestDirectoryTaxonomyWriter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests.Facet/Taxonomy/Directory/TestDirectoryTaxonomyWriter.cs b/src/Lucene.Net.Tests.Facet/Taxonomy/Directory/TestDirectoryTaxonomyWriter.cs
index db56de4..cb4e68e 100644
--- a/src/Lucene.Net.Tests.Facet/Taxonomy/Directory/TestDirectoryTaxonomyWriter.cs
+++ b/src/Lucene.Net.Tests.Facet/Taxonomy/Directory/TestDirectoryTaxonomyWriter.cs
@@ -268,7 +268,7 @@ namespace Lucene.Net.Facet.Taxonomy.Directory
         {
             int ncats = AtLeast(100000); // add many categories
             int range = ncats * 3; // affects the categories selection
-            AtomicInteger numCats = new AtomicInteger(ncats);
+            AtomicInt32 numCats = new AtomicInt32(ncats);
             Directory dir = NewDirectory();
             var values = new ConcurrentDictionary<string, string>();
             double d = Random().NextDouble();
@@ -350,11 +350,11 @@ namespace Lucene.Net.Facet.Taxonomy.Directory
             private readonly TestDirectoryTaxonomyWriter outerInstance;
 
             private int range;
-            private AtomicInteger numCats;
+            private AtomicInt32 numCats;
             private ConcurrentDictionary<string, string> values;
             private Lucene.Net.Facet.Taxonomy.Directory.DirectoryTaxonomyWriter tw;
 
-            public ThreadAnonymousInnerClassHelper(TestDirectoryTaxonomyWriter outerInstance, int range, AtomicInteger numCats, ConcurrentDictionary<string, string> values, Lucene.Net.Facet.Taxonomy.Directory.DirectoryTaxonomyWriter tw)
+            public ThreadAnonymousInnerClassHelper(TestDirectoryTaxonomyWriter outerInstance, int range, AtomicInt32 numCats, ConcurrentDictionary<string, string> values, Lucene.Net.Facet.Taxonomy.Directory.DirectoryTaxonomyWriter tw)
             {
                 this.outerInstance = outerInstance;
                 this.range = range;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Tests.Facet/Taxonomy/TestTaxonomyFacetSumValueSource.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests.Facet/Taxonomy/TestTaxonomyFacetSumValueSource.cs b/src/Lucene.Net.Tests.Facet/Taxonomy/TestTaxonomyFacetSumValueSource.cs
index 980f818..5f3972b 100644
--- a/src/Lucene.Net.Tests.Facet/Taxonomy/TestTaxonomyFacetSumValueSource.cs
+++ b/src/Lucene.Net.Tests.Facet/Taxonomy/TestTaxonomyFacetSumValueSource.cs
@@ -30,8 +30,8 @@ namespace Lucene.Net.Facet.Taxonomy
     using MockAnalyzer = Lucene.Net.Analysis.MockAnalyzer;
     using Document = Lucene.Net.Documents.Document;
     using Field = Lucene.Net.Documents.Field;
-    using FloatDocValuesField = Lucene.Net.Documents.FloatDocValuesField;
-    using IntField = Lucene.Net.Documents.IntField;
+    using SingleDocValuesField = Lucene.Net.Documents.SingleDocValuesField;
+    using Int32Field = Lucene.Net.Documents.Int32Field;
     using NumericDocValuesField = Lucene.Net.Documents.NumericDocValuesField;
     using StringField = Lucene.Net.Documents.StringField;
     using DirectoryTaxonomyReader = Lucene.Net.Facet.Taxonomy.Directory.DirectoryTaxonomyReader;
@@ -82,27 +82,27 @@ namespace Lucene.Net.Facet.Taxonomy
             // Reused across documents, to add the necessary facet
             // fields:
             Document doc = new Document();
-            doc.Add(new IntField("num", 10, Field.Store.NO));
+            doc.Add(new Int32Field("num", 10, Field.Store.NO));
             doc.Add(new FacetField("Author", "Bob"));
             writer.AddDocument(config.Build(taxoWriter, doc));
 
             doc = new Document();
-            doc.Add(new IntField("num", 20, Field.Store.NO));
+            doc.Add(new Int32Field("num", 20, Field.Store.NO));
             doc.Add(new FacetField("Author", "Lisa"));
             writer.AddDocument(config.Build(taxoWriter, doc));
 
             doc = new Document();
-            doc.Add(new IntField("num", 30, Field.Store.NO));
+            doc.Add(new Int32Field("num", 30, Field.Store.NO));
             doc.Add(new FacetField("Author", "Lisa"));
             writer.AddDocument(config.Build(taxoWriter, doc));
 
             doc = new Document();
-            doc.Add(new IntField("num", 40, Field.Store.NO));
+            doc.Add(new Int32Field("num", 40, Field.Store.NO));
             doc.Add(new FacetField("Author", "Susan"));
             writer.AddDocument(config.Build(taxoWriter, doc));
 
             doc = new Document();
-            doc.Add(new IntField("num", 45, Field.Store.NO));
+            doc.Add(new Int32Field("num", 45, Field.Store.NO));
             doc.Add(new FacetField("Author", "Frank"));
             writer.AddDocument(config.Build(taxoWriter, doc));
 
@@ -149,7 +149,7 @@ namespace Lucene.Net.Facet.Taxonomy
             FacetsConfig config = new FacetsConfig();
 
             Document doc = new Document();
-            doc.Add(new IntField("num", 10, Field.Store.NO));
+            doc.Add(new Int32Field("num", 10, Field.Store.NO));
             doc.Add(new FacetField("a", "foo1"));
             writer.AddDocument(config.Build(taxoWriter, doc));
 
@@ -159,7 +159,7 @@ namespace Lucene.Net.Facet.Taxonomy
             }
 
             doc = new Document();
-            doc.Add(new IntField("num", 20, Field.Store.NO));
+            doc.Add(new Int32Field("num", 20, Field.Store.NO));
             doc.Add(new FacetField("a", "foo2"));
             doc.Add(new FacetField("b", "bar1"));
             writer.AddDocument(config.Build(taxoWriter, doc));
@@ -170,7 +170,7 @@ namespace Lucene.Net.Facet.Taxonomy
             }
 
             doc = new Document();
-            doc.Add(new IntField("num", 30, Field.Store.NO));
+            doc.Add(new Int32Field("num", 30, Field.Store.NO));
             doc.Add(new FacetField("a", "foo3"));
             doc.Add(new FacetField("b", "bar2"));
             doc.Add(new FacetField("c", "baz1"));
@@ -217,7 +217,7 @@ namespace Lucene.Net.Facet.Taxonomy
             RandomIndexWriter writer = new RandomIndexWriter(Random(), dir, Similarity, TimeZone);
 
             Document doc = new Document();
-            doc.Add(new IntField("num", 10, Field.Store.NO));
+            doc.Add(new Int32Field("num", 10, Field.Store.NO));
             doc.Add(new FacetField("a", "foo1"));
             writer.AddDocument(config.Build(taxoWriter, doc));
 
@@ -506,7 +506,7 @@ namespace Lucene.Net.Facet.Taxonomy
                 Document doc = new Document();
                 doc.Add(NewStringField("content", testDoc.content, Field.Store.NO));
                 testDoc.value = Random().NextFloat();
-                doc.Add(new FloatDocValuesField("value", testDoc.value));
+                doc.Add(new SingleDocValuesField("value", testDoc.value));
                 for (int j = 0; j < numDims; j++)
                 {
                     if (testDoc.dims[j] != null)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Tests.Grouping/AllGroupHeadsCollectorTest.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests.Grouping/AllGroupHeadsCollectorTest.cs b/src/Lucene.Net.Tests.Grouping/AllGroupHeadsCollectorTest.cs
index 1835309..4008b34 100644
--- a/src/Lucene.Net.Tests.Grouping/AllGroupHeadsCollectorTest.cs
+++ b/src/Lucene.Net.Tests.Grouping/AllGroupHeadsCollectorTest.cs
@@ -252,7 +252,7 @@ namespace Lucene.Net.Search.Grouping
                 Field content = NewTextField("content", "", Field.Store.NO);
                 doc.Add(content);
                 docNoGroup.Add(content);
-                IntField id = new IntField("id", 0, Field.Store.NO);
+                Int32Field id = new Int32Field("id", 0, Field.Store.NO);
                 doc.Add(id);
                 docNoGroup.Add(id);
                 GroupDoc[] groupDocs = new GroupDoc[numDocs];
@@ -312,7 +312,7 @@ namespace Lucene.Net.Search.Grouping
                 w.Dispose();
 
                 // NOTE: intentional but temporary field cache insanity!
-                FieldCache.Ints docIdToFieldId = FieldCache.DEFAULT.GetInt32s(SlowCompositeReaderWrapper.Wrap(r), "id", false);
+                FieldCache.Int32s docIdToFieldId = FieldCache.DEFAULT.GetInt32s(SlowCompositeReaderWrapper.Wrap(r), "id", false);
                 int[] fieldIdToDocID = new int[numDocs];
                 for (int i = 0; i < numDocs; i++)
                 {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Tests.Grouping/TestGrouping.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests.Grouping/TestGrouping.cs b/src/Lucene.Net.Tests.Grouping/TestGrouping.cs
index b22e46d..6345b13 100644
--- a/src/Lucene.Net.Tests.Grouping/TestGrouping.cs
+++ b/src/Lucene.Net.Tests.Grouping/TestGrouping.cs
@@ -697,7 +697,7 @@ namespace Lucene.Net.Search.Grouping
                     }
                     doc.Add(NewStringField("sort1", groupValue.sort1.Utf8ToString(), Field.Store.NO));
                     doc.Add(NewStringField("sort2", groupValue.sort2.Utf8ToString(), Field.Store.NO));
-                    doc.Add(new IntField("id", groupValue.id, Field.Store.NO));
+                    doc.Add(new Int32Field("id", groupValue.id, Field.Store.NO));
                     doc.Add(NewTextField("content", groupValue.content, Field.Store.NO));
                     //Console.WriteLine("TEST:     doc content=" + groupValue.content + " group=" + (groupValue.group == null ? "null" : groupValue.group.utf8ToString()) + " sort1=" + groupValue.sort1.utf8ToString() + " id=" + groupValue.id);
                 }
@@ -836,7 +836,7 @@ namespace Lucene.Net.Search.Grouping
                 Field content = NewTextField("content", "", Field.Store.NO);
                 doc.Add(content);
                 docNoGroup.Add(content);
-                IntField id = new IntField("id", 0, Field.Store.NO);
+                Int32Field id = new Int32Field("id", 0, Field.Store.NO);
                 doc.Add(id);
                 docNoGroup.Add(id);
                 GroupDoc[] groupDocs = new GroupDoc[numDocs];
@@ -900,7 +900,7 @@ namespace Lucene.Net.Search.Grouping
                 w.Dispose();
 
                 // NOTE: intentional but temporary field cache insanity!
-                FieldCache.Ints docIDToID = FieldCache.DEFAULT.GetInt32s(SlowCompositeReaderWrapper.Wrap(r), "id", false);
+                FieldCache.Int32s docIDToID = FieldCache.DEFAULT.GetInt32s(SlowCompositeReaderWrapper.Wrap(r), "id", false);
                 DirectoryReader rBlocks = null;
                 Directory dirBlocks = null;
 
@@ -944,7 +944,7 @@ namespace Lucene.Net.Search.Grouping
                     dirBlocks = NewDirectory();
                     rBlocks = GetDocBlockReader(dirBlocks, groupDocs);
                     Filter lastDocInBlock = new CachingWrapperFilter(new QueryWrapperFilter(new TermQuery(new Term("groupend", "x"))));
-                    FieldCache.Ints docIDToIDBlocks = FieldCache.DEFAULT.GetInt32s(SlowCompositeReaderWrapper.Wrap(rBlocks), "id", false);
+                    FieldCache.Int32s docIDToIDBlocks = FieldCache.DEFAULT.GetInt32s(SlowCompositeReaderWrapper.Wrap(rBlocks), "id", false);
 
                     IndexSearcher sBlocks = NewSearcher(rBlocks);
                     ShardState shardsBlocks = new ShardState(sBlocks);
@@ -1557,7 +1557,7 @@ namespace Lucene.Net.Search.Grouping
             }
         }
 
-        private void AssertEquals(FieldCache.Ints docIDtoID, ITopGroups<BytesRef> expected, ITopGroups<BytesRef> actual, bool verifyGroupValues, bool verifyTotalGroupCount, bool verifySortValues, bool testScores, bool idvBasedImplsUsed)
+        private void AssertEquals(FieldCache.Int32s docIDtoID, ITopGroups<BytesRef> expected, ITopGroups<BytesRef> actual, bool verifyGroupValues, bool verifyTotalGroupCount, bool verifySortValues, bool testScores, bool idvBasedImplsUsed)
         {
             if (expected == null)
             {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Tests.Highlighter/Highlight/HighlighterTest.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests.Highlighter/Highlight/HighlighterTest.cs b/src/Lucene.Net.Tests.Highlighter/Highlight/HighlighterTest.cs
index 33fe884..2cc4b14 100644
--- a/src/Lucene.Net.Tests.Highlighter/Highlight/HighlighterTest.cs
+++ b/src/Lucene.Net.Tests.Highlighter/Highlight/HighlighterTest.cs
@@ -1971,22 +1971,22 @@ namespace Lucene.Net.Search.Highlight
                 addDoc(writer, text);
             }
             Document doc = new Document();
-            doc.Add(new IntField(NUMERIC_FIELD_NAME, 1, Field.Store.NO));
+            doc.Add(new Int32Field(NUMERIC_FIELD_NAME, 1, Field.Store.NO));
             doc.Add(new StoredField(NUMERIC_FIELD_NAME, 1));
             writer.AddDocument(doc, analyzer);
 
             doc = new Document();
-            doc.Add(new IntField(NUMERIC_FIELD_NAME, 3, Field.Store.NO));
+            doc.Add(new Int32Field(NUMERIC_FIELD_NAME, 3, Field.Store.NO));
             doc.Add(new StoredField(NUMERIC_FIELD_NAME, 3));
             writer.AddDocument(doc, analyzer);
 
             doc = new Document();
-            doc.Add(new IntField(NUMERIC_FIELD_NAME, 5, Field.Store.NO));
+            doc.Add(new Int32Field(NUMERIC_FIELD_NAME, 5, Field.Store.NO));
             doc.Add(new StoredField(NUMERIC_FIELD_NAME, 5));
             writer.AddDocument(doc, analyzer);
 
             doc = new Document();
-            doc.Add(new IntField(NUMERIC_FIELD_NAME, 7, Field.Store.NO));
+            doc.Add(new Int32Field(NUMERIC_FIELD_NAME, 7, Field.Store.NO));
             doc.Add(new StoredField(NUMERIC_FIELD_NAME, 7));
             writer.AddDocument(doc, analyzer);
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Tests.Join/TestBlockJoin.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests.Join/TestBlockJoin.cs b/src/Lucene.Net.Tests.Join/TestBlockJoin.cs
index a5f3ce2..24c00b9 100644
--- a/src/Lucene.Net.Tests.Join/TestBlockJoin.cs
+++ b/src/Lucene.Net.Tests.Join/TestBlockJoin.cs
@@ -51,7 +51,7 @@ namespace Lucene.Net.Tests.Join
         {
             Document job = new Document();
             job.Add(NewStringField("skill", skill, Field.Store.YES));
-            job.Add(new IntField("year", year, Field.Store.NO));
+            job.Add(new Int32Field("year", year, Field.Store.NO));
             job.Add(new StoredField("year", year));
             return job;
         }
@@ -61,7 +61,7 @@ namespace Lucene.Net.Tests.Join
         {
             Document job = new Document();
             job.Add(NewStringField("qualification", qualification, Field.Store.YES));
-            job.Add(new IntField("year", year, Field.Store.NO));
+            job.Add(new Int32Field("year", year, Field.Store.NO));
             return job;
         }
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Tests.Misc/Util/Fst/TestFSTsMisc.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests.Misc/Util/Fst/TestFSTsMisc.cs b/src/Lucene.Net.Tests.Misc/Util/Fst/TestFSTsMisc.cs
index 228b91f..7ad22ef 100644
--- a/src/Lucene.Net.Tests.Misc/Util/Fst/TestFSTsMisc.cs
+++ b/src/Lucene.Net.Tests.Misc/Util/Fst/TestFSTsMisc.cs
@@ -43,8 +43,8 @@ namespace Lucene.Net.Util.Fst
                 for (int inputMode = 0; inputMode < 2; inputMode++)
                 {
                     int numWords = random.nextInt(maxNumWords + 1);
-                    ISet<IntsRef> termsSet = new HashSet<IntsRef>();
-                    IntsRef[] terms = new IntsRef[numWords];
+                    ISet<Int32sRef> termsSet = new HashSet<Int32sRef>();
+                    Int32sRef[] terms = new Int32sRef[numWords];
                     while (termsSet.size() < numWords)
                     {
                         string term = FSTTester<object>.GetRandomString(random);
@@ -56,7 +56,7 @@ namespace Lucene.Net.Util.Fst
         }
 
 
-        private void DoTest(int inputMode, IntsRef[] terms)
+        private void DoTest(int inputMode, Int32sRef[] terms)
         {
             Array.Sort(terms);
 
@@ -106,7 +106,7 @@ namespace Lucene.Net.Util.Fst
                     {
                         Console.WriteLine("TEST: now test OneOrMoreOutputs");
                     }
-                    PositiveIntOutputs _outputs = PositiveIntOutputs.Singleton; // LUCENENET TODO: This should probably not be a nullable type
+                    PositiveInt32Outputs _outputs = PositiveInt32Outputs.Singleton; // LUCENENET TODO: This should probably not be a nullable type
                     ListOfOutputs<long?> outputs2 = new ListOfOutputs<long?>(_outputs);
                     List<FSTTester<object>.InputOutput<object>> pairs2 = new List<FSTTester<object>.InputOutput<object>>(terms.Length);
                     long lastOutput2 = 0;
@@ -174,11 +174,11 @@ namespace Lucene.Net.Util.Fst
         [Test]
         public void TestListOfOutputs()
         {
-            PositiveIntOutputs _outputs = PositiveIntOutputs.Singleton;
+            PositiveInt32Outputs _outputs = PositiveInt32Outputs.Singleton;
             ListOfOutputs<long?> outputs = new ListOfOutputs<long?>(_outputs);
             Builder<object> builder = new Builder<object>(Lucene.Net.Util.Fst.FST.INPUT_TYPE.BYTE1, outputs);
 
-            IntsRef scratch = new IntsRef();
+            Int32sRef scratch = new Int32sRef();
             // Add the same input more than once and the outputs
             // are merged:
             builder.Add(Util.ToInt32sRef(new BytesRef("a"), scratch), 1L);
@@ -205,11 +205,11 @@ namespace Lucene.Net.Util.Fst
         [Test]
         public void TestListOfOutputsEmptyString()
         {
-            PositiveIntOutputs _outputs = PositiveIntOutputs.Singleton;
+            PositiveInt32Outputs _outputs = PositiveInt32Outputs.Singleton;
             ListOfOutputs<long?> outputs = new ListOfOutputs<long?>(_outputs);
             Builder<object> builder = new Builder<object>(FST.INPUT_TYPE.BYTE1, outputs);
 
-            IntsRef scratch = new IntsRef();
+            Int32sRef scratch = new Int32sRef();
             builder.Add(scratch, 0L);
             builder.Add(scratch, 1L);
             builder.Add(scratch, 17L);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Tests.Queries/Function/TestDocValuesFieldSources.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests.Queries/Function/TestDocValuesFieldSources.cs b/src/Lucene.Net.Tests.Queries/Function/TestDocValuesFieldSources.cs
index 1692996..835b170 100644
--- a/src/Lucene.Net.Tests.Queries/Function/TestDocValuesFieldSources.cs
+++ b/src/Lucene.Net.Tests.Queries/Function/TestDocValuesFieldSources.cs
@@ -60,7 +60,7 @@ namespace Lucene.Net.Tests.Queries.Function
                         break;
                     case DocValuesType.NUMERIC:
                         int bitsPerValue = Random().NextIntBetween(1, 31); // keep it an int
-                        vals[i] = (long)Random().Next((int)PackedInts.MaxValue(bitsPerValue));
+                        vals[i] = (long)Random().Next((int)PackedInt32s.MaxValue(bitsPerValue));
                         f.SetInt64Value((long) vals[i]);
                         break;
                 }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Tests.Queries/TestCustomScoreQuery.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests.Queries/TestCustomScoreQuery.cs b/src/Lucene.Net.Tests.Queries/TestCustomScoreQuery.cs
index b188246..527b4df 100644
--- a/src/Lucene.Net.Tests.Queries/TestCustomScoreQuery.cs
+++ b/src/Lucene.Net.Tests.Queries/TestCustomScoreQuery.cs
@@ -184,7 +184,7 @@ namespace Lucene.Net.Tests.Queries
 
             protected override CustomScoreProvider GetCustomScoreProvider(AtomicReaderContext context)
             {
-                FieldCache.Ints values = FieldCache.DEFAULT.GetInt32s(context.AtomicReader, INT_FIELD, false);
+                FieldCache.Int32s values = FieldCache.DEFAULT.GetInt32s(context.AtomicReader, INT_FIELD, false);
                 return new CustomScoreProviderAnonymousInnerClassHelper(this, context, values);
             }
             
@@ -192,9 +192,9 @@ namespace Lucene.Net.Tests.Queries
             {
                 private readonly CustomExternalQuery outerInstance;
 
-                private FieldCache.Ints values;
+                private FieldCache.Int32s values;
 
-                public CustomScoreProviderAnonymousInnerClassHelper(CustomExternalQuery outerInstance, AtomicReaderContext context, FieldCache.Ints values) : base(context)
+                public CustomScoreProviderAnonymousInnerClassHelper(CustomExternalQuery outerInstance, AtomicReaderContext context, FieldCache.Int32s values) : base(context)
                 {
                     this.outerInstance = outerInstance;
                     this.values = values;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Tests.QueryParser/Flexible/Standard/TestNumericQueryParser.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests.QueryParser/Flexible/Standard/TestNumericQueryParser.cs b/src/Lucene.Net.Tests.QueryParser/Flexible/Standard/TestNumericQueryParser.cs
index ecad5e3..779e943 100644
--- a/src/Lucene.Net.Tests.QueryParser/Flexible/Standard/TestNumericQueryParser.cs
+++ b/src/Lucene.Net.Tests.QueryParser/Flexible/Standard/TestNumericQueryParser.cs
@@ -190,7 +190,7 @@ namespace Lucene.Net.QueryParsers.Flexible.Standard
                 numericConfigMap.Put(type.ToString(), new NumericConfig(PRECISION_STEP,
                     NUMBER_FORMAT, type)); 
 
-                FieldType ft2 = new FieldType(IntField.TYPE_NOT_STORED);
+                FieldType ft2 = new FieldType(Int32Field.TYPE_NOT_STORED);
                 ft2.NumericType = (type);
                 ft2.IsStored = (true);
                 ft2.NumericPrecisionStep = (PRECISION_STEP);
@@ -200,13 +200,13 @@ namespace Lucene.Net.QueryParsers.Flexible.Standard
                 switch (type)
                 {
                     case NumericType.INT:
-                        field = new IntField(type.ToString(), 0, ft2);
+                        field = new Int32Field(type.ToString(), 0, ft2);
                         break;
                     case NumericType.FLOAT:
-                        field = new FloatField(type.ToString(), 0.0f, ft2);
+                        field = new SingleField(type.ToString(), 0.0f, ft2);
                         break;
                     case NumericType.LONG:
-                        field = new LongField(type.ToString(), 0L, ft2);
+                        field = new Int64Field(type.ToString(), 0L, ft2);
                         break;
                     case NumericType.DOUBLE:
                         field = new DoubleField(type.ToString(), 0.0, ft2);
@@ -222,10 +222,10 @@ namespace Lucene.Net.QueryParsers.Flexible.Standard
 
             numericConfigMap.Put(DATE_FIELD_NAME, new NumericConfig(PRECISION_STEP,
                 DATE_FORMAT, NumericType.LONG));
-            FieldType ft = new FieldType(LongField.TYPE_NOT_STORED);
+            FieldType ft = new FieldType(Int64Field.TYPE_NOT_STORED);
             ft.IsStored = (true);
             ft.NumericPrecisionStep = (PRECISION_STEP);
-            LongField dateField = new LongField(DATE_FIELD_NAME, 0L, ft);
+            Int64Field dateField = new Int64Field(DATE_FIELD_NAME, 0L, ft);
             numericFieldMap.Put(DATE_FIELD_NAME, dateField);
             doc.Add(dateField);
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Tests.QueryParser/Xml/TestParser.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests.QueryParser/Xml/TestParser.cs b/src/Lucene.Net.Tests.QueryParser/Xml/TestParser.cs
index 6aa300b..7f8290a 100644
--- a/src/Lucene.Net.Tests.QueryParser/Xml/TestParser.cs
+++ b/src/Lucene.Net.Tests.QueryParser/Xml/TestParser.cs
@@ -60,7 +60,7 @@ namespace Lucene.Net.QueryParsers.Xml
                 Document doc = new Document();
                 doc.Add(NewTextField("date", date, Field.Store.YES));
                 doc.Add(NewTextField("contents", content, Field.Store.YES));
-                doc.Add(new IntField("date2", Convert.ToInt32(date), Field.Store.NO));
+                doc.Add(new Int32Field("date2", Convert.ToInt32(date), Field.Store.NO));
                 writer.AddDocument(doc);
                 line = d.ReadLine();
             }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Tests.Spatial/SpatialExample.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests.Spatial/SpatialExample.cs b/src/Lucene.Net.Tests.Spatial/SpatialExample.cs
index 4a03d78..bc1fa67 100644
--- a/src/Lucene.Net.Tests.Spatial/SpatialExample.cs
+++ b/src/Lucene.Net.Tests.Spatial/SpatialExample.cs
@@ -111,7 +111,7 @@ namespace Lucene.Net.Spatial
         private Document NewSampleDocument(int id, params IShape[] shapes)
         {
             Document doc = new Document();
-            doc.Add(new IntField("id", id, Field.Store.YES));
+            doc.Add(new Int32Field("id", id, Field.Store.YES));
             //Potentially more than one shape in this field is supported by some
             // strategies; see the javadocs of the SpatialStrategy impl to see.
             foreach (IShape shape in shapes)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Tests.Suggest/Suggest/Analyzing/FuzzySuggesterTest.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests.Suggest/Suggest/Analyzing/FuzzySuggesterTest.cs b/src/Lucene.Net.Tests.Suggest/Suggest/Analyzing/FuzzySuggesterTest.cs
index d0796d8..991233f 100644
--- a/src/Lucene.Net.Tests.Suggest/Suggest/Analyzing/FuzzySuggesterTest.cs
+++ b/src/Lucene.Net.Tests.Suggest/Suggest/Analyzing/FuzzySuggesterTest.cs
@@ -911,8 +911,8 @@ namespace Lucene.Net.Search.Suggest.Analyzing
                 foreach (TermFreqPayload2 e in slowCompletor)
                 {
                     spare.CopyChars(e.analyzedForm);
-                    ISet<IntsRef> finiteStrings = suggester.ToFiniteStrings(spare, tokenStreamToAutomaton);
-                    foreach (IntsRef intsRef in finiteStrings)
+                    ISet<Int32sRef> finiteStrings = suggester.ToFiniteStrings(spare, tokenStreamToAutomaton);
+                    foreach (Int32sRef intsRef in finiteStrings)
                     {
                         State p = automaton.GetInitialState();
                         BytesRef @ref = Lucene.Net.Util.Fst.Util.ToBytesRef(intsRef, spare);
@@ -1323,8 +1323,8 @@ namespace Lucene.Net.Search.Suggest.Analyzing
          * between two strings, including transpositions. */
         public int GetDistance(string target, string other, bool allowTransposition)
         {
-            IntsRef targetPoints;
-            IntsRef otherPoints;
+            Int32sRef targetPoints;
+            Int32sRef otherPoints;
             int n;
             int[][] d; // cost array
 
@@ -1413,9 +1413,9 @@ namespace Lucene.Net.Search.Suggest.Analyzing
             return array;
         }
 
-        private static IntsRef ToIntsRef(string s)
+        private static Int32sRef ToIntsRef(string s)
         {
-            IntsRef @ref = new IntsRef(s.Length); // worst case
+            Int32sRef @ref = new Int32sRef(s.Length); // worst case
             int utf16Len = s.Length;
             for (int i = 0, cp = 0; i < utf16Len; i += Character.CharCount(cp))
             {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Tests/core/Codecs/Compressing/TestCompressingStoredFieldsFormat.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Codecs/Compressing/TestCompressingStoredFieldsFormat.cs b/src/Lucene.Net.Tests/core/Codecs/Compressing/TestCompressingStoredFieldsFormat.cs
index 4c4494c..ef5ac7e 100644
--- a/src/Lucene.Net.Tests/core/Codecs/Compressing/TestCompressingStoredFieldsFormat.cs
+++ b/src/Lucene.Net.Tests/core/Codecs/Compressing/TestCompressingStoredFieldsFormat.cs
@@ -12,7 +12,7 @@ namespace Lucene.Net.Codecs.Compressing
     using Field = Field;
     using FieldType = FieldType;
     using IndexWriterConfig = Lucene.Net.Index.IndexWriterConfig;
-    using IntField = IntField;
+    using Int32Field = Int32Field;
 
     /*
          * Licensed to the Apache Software Foundation (ASF) under one or more
@@ -59,7 +59,7 @@ namespace Lucene.Net.Codecs.Compressing
             RandomIndexWriter iw = new RandomIndexWriter(Random(), dir, iwConf);
 
             Document validDoc = new Document();
-            validDoc.Add(new IntField("id", 0, Field.Store.YES));
+            validDoc.Add(new Int32Field("id", 0, Field.Store.YES));
             iw.AddDocument(validDoc);
             iw.Commit();
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Tests/core/Codecs/Lucene41/TestForUtil.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Codecs/Lucene41/TestForUtil.cs b/src/Lucene.Net.Tests/core/Codecs/Lucene41/TestForUtil.cs
index 02ee82e..2f6a7bc 100644
--- a/src/Lucene.Net.Tests/core/Codecs/Lucene41/TestForUtil.cs
+++ b/src/Lucene.Net.Tests/core/Codecs/Lucene41/TestForUtil.cs
@@ -26,7 +26,7 @@ namespace Lucene.Net.Codecs.Lucene41
     using IndexOutput = Lucene.Net.Store.IndexOutput;
     using IOContext = Lucene.Net.Store.IOContext;
     using LuceneTestCase = Lucene.Net.Util.LuceneTestCase;
-    using PackedInts = Lucene.Net.Util.Packed.PackedInts;
+    using PackedInt32s = Lucene.Net.Util.Packed.PackedInt32s;
     using RAMDirectory = Lucene.Net.Store.RAMDirectory;
 
     [TestFixture]
@@ -53,7 +53,7 @@ namespace Lucene.Net.Codecs.Lucene41
                 {
                     for (int j = 0; j < Lucene41PostingsFormat.BLOCK_SIZE; ++j)
                     {
-                        values[i * Lucene41PostingsFormat.BLOCK_SIZE + j] = RandomInts.NextIntBetween(Random(), 0, (int)PackedInts.MaxValue(bpv));
+                        values[i * Lucene41PostingsFormat.BLOCK_SIZE + j] = RandomInts.NextIntBetween(Random(), 0, (int)PackedInt32s.MaxValue(bpv));
                     }
                 }
             }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Tests/core/Document/TestDocument.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Document/TestDocument.cs b/src/Lucene.Net.Tests/core/Document/TestDocument.cs
index 3e51b12..11b108b 100644
--- a/src/Lucene.Net.Tests/core/Document/TestDocument.cs
+++ b/src/Lucene.Net.Tests/core/Document/TestDocument.cs
@@ -432,10 +432,10 @@ namespace Lucene.Net.Documents
         public virtual void TestNumericFieldAsString()
         {
             Documents.Document doc = new Documents.Document();
-            doc.Add(new IntField("int", 5, Field.Store.YES));
+            doc.Add(new Int32Field("int", 5, Field.Store.YES));
             Assert.AreEqual("5", doc.Get("int"));
             Assert.IsNull(doc.Get("somethingElse"));
-            doc.Add(new IntField("int", 4, Field.Store.YES));
+            doc.Add(new Int32Field("int", 4, Field.Store.YES));
             Assert.AreEqual(new string[] { "5", "4" }, doc.GetValues("int"));
 
             Directory dir = NewDirectory();

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Tests/core/Document/TestField.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Document/TestField.cs b/src/Lucene.Net.Tests/core/Document/TestField.cs
index c278fbf..f436364 100644
--- a/src/Lucene.Net.Tests/core/Document/TestField.cs
+++ b/src/Lucene.Net.Tests/core/Document/TestField.cs
@@ -80,7 +80,7 @@ namespace Lucene.Net.Documents
         [Test]
         public virtual void TestFloatDocValuesField()
         {
-            FloatDocValuesField field = new FloatDocValuesField("foo", 5f);
+            SingleDocValuesField field = new SingleDocValuesField("foo", 5f);
 
             TrySetBoost(field);
             TrySetByteValue(field);
@@ -101,7 +101,7 @@ namespace Lucene.Net.Documents
         [Test]
         public virtual void TestFloatField()
         {
-            Field[] fields = new Field[] { new FloatField("foo", 5f, Field.Store.NO), new FloatField("foo", 5f, Field.Store.YES) };
+            Field[] fields = new Field[] { new SingleField("foo", 5f, Field.Store.NO), new SingleField("foo", 5f, Field.Store.YES) };
 
             foreach (Field field in fields)
             {
@@ -125,7 +125,7 @@ namespace Lucene.Net.Documents
         [Test]
         public virtual void TestIntField()
         {
-            Field[] fields = new Field[] { new IntField("foo", 5, Field.Store.NO), new IntField("foo", 5, Field.Store.YES) };
+            Field[] fields = new Field[] { new Int32Field("foo", 5, Field.Store.NO), new Int32Field("foo", 5, Field.Store.YES) };
 
             foreach (Field field in fields)
             {
@@ -170,7 +170,7 @@ namespace Lucene.Net.Documents
         [Test]
         public virtual void TestLongField()
         {
-            Field[] fields = new Field[] { new LongField("foo", 5L, Field.Store.NO), new LongField("foo", 5L, Field.Store.YES) };
+            Field[] fields = new Field[] { new Int64Field("foo", 5L, Field.Store.NO), new Int64Field("foo", 5L, Field.Store.YES) };
 
             foreach (Field field in fields)
             {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Tests/core/Index/TestBackwardsCompatibility.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Index/TestBackwardsCompatibility.cs b/src/Lucene.Net.Tests/core/Index/TestBackwardsCompatibility.cs
index 5183860..96c40ab 100644
--- a/src/Lucene.Net.Tests/core/Index/TestBackwardsCompatibility.cs
+++ b/src/Lucene.Net.Tests/core/Index/TestBackwardsCompatibility.cs
@@ -34,9 +34,9 @@ namespace Lucene.Net.Index
     using DoubleDocValuesField = Lucene.Net.Documents.DoubleDocValuesField;
     using Field = Lucene.Net.Documents.Field;
     using FieldType = Lucene.Net.Documents.FieldType;
-    using FloatDocValuesField = Lucene.Net.Documents.FloatDocValuesField;
-    using IntField = Lucene.Net.Documents.IntField;
-    using LongField = Lucene.Net.Documents.LongField;
+    using SingleDocValuesField = Lucene.Net.Documents.SingleDocValuesField;
+    using Int32Field = Lucene.Net.Documents.Int32Field;
+    using Int64Field = Lucene.Net.Documents.Int64Field;
     using NumericDocValuesField = Lucene.Net.Documents.NumericDocValuesField;
     using SortedDocValuesField = Lucene.Net.Documents.SortedDocValuesField;
     using SortedSetDocValuesField = Lucene.Net.Documents.SortedSetDocValuesField;
@@ -715,8 +715,8 @@ namespace Lucene.Net.Index
             doc.Add(new Field("content2", "here is more content with aaa aaa aaa", customType2));
             doc.Add(new Field("fie\u2C77ld", "field with non-ascii name", customType2));
             // add numeric fields, to test if flex preserves encoding
-            doc.Add(new IntField("trieInt", id, Field.Store.NO));
-            doc.Add(new LongField("trieLong", (long)id, Field.Store.NO));
+            doc.Add(new Int32Field("trieInt", id, Field.Store.NO));
+            doc.Add(new Int64Field("trieLong", (long)id, Field.Store.NO));
             // add docvalues fields
             doc.Add(new NumericDocValuesField("dvByte", (sbyte)id));
             sbyte[] bytes = new sbyte[] { (sbyte)((int)((uint)id >> 24)), (sbyte)((int)((uint)id >> 16)), (sbyte)((int)((uint)id >> 8)), (sbyte)id };
@@ -728,7 +728,7 @@ namespace Lucene.Net.Index
             doc.Add(new BinaryDocValuesField("dvBytesStraightFixed", @ref));
             doc.Add(new BinaryDocValuesField("dvBytesStraightVar", @ref));
             doc.Add(new DoubleDocValuesField("dvDouble", (double)id));
-            doc.Add(new FloatDocValuesField("dvFloat", (float)id));
+            doc.Add(new SingleDocValuesField("dvFloat", (float)id));
             doc.Add(new NumericDocValuesField("dvInt", id));
             doc.Add(new NumericDocValuesField("dvLong", id));
             doc.Add(new NumericDocValuesField("dvPacked", id));
@@ -888,7 +888,7 @@ namespace Lucene.Net.Index
                 Assert.AreEqual(34, hits_.Length, "wrong number of hits");
 
                 // check decoding into field cache
-                FieldCache.Ints fci = FieldCache.DEFAULT.GetInt32s(SlowCompositeReaderWrapper.Wrap(searcher.IndexReader), "trieInt", false);
+                FieldCache.Int32s fci = FieldCache.DEFAULT.GetInt32s(SlowCompositeReaderWrapper.Wrap(searcher.IndexReader), "trieInt", false);
                 int maxDoc = searcher.IndexReader.MaxDoc;
                 for (int doc = 0; doc < maxDoc; doc++)
                 {
@@ -896,7 +896,7 @@ namespace Lucene.Net.Index
                     Assert.IsTrue(val >= 0 && val < 35, "value in id bounds");
                 }
 
-                FieldCache.Longs fcl = FieldCache.DEFAULT.GetInt64s(SlowCompositeReaderWrapper.Wrap(searcher.IndexReader), "trieLong", false);
+                FieldCache.Int64s fcl = FieldCache.DEFAULT.GetInt64s(SlowCompositeReaderWrapper.Wrap(searcher.IndexReader), "trieLong", false);
                 for (int doc = 0; doc < maxDoc; doc++)
                 {
                     long val = fcl.Get(doc);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Tests/core/Index/TestBackwardsCompatibility3x.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Index/TestBackwardsCompatibility3x.cs b/src/Lucene.Net.Tests/core/Index/TestBackwardsCompatibility3x.cs
index ba5cd08..eeadaa4 100644
--- a/src/Lucene.Net.Tests/core/Index/TestBackwardsCompatibility3x.cs
+++ b/src/Lucene.Net.Tests/core/Index/TestBackwardsCompatibility3x.cs
@@ -34,9 +34,9 @@ namespace Lucene.Net.Index
     using DoubleDocValuesField = Lucene.Net.Documents.DoubleDocValuesField;
     using Field = Lucene.Net.Documents.Field;
     using FieldType = Lucene.Net.Documents.FieldType;
-    using FloatDocValuesField = Lucene.Net.Documents.FloatDocValuesField;
-    using IntField = Lucene.Net.Documents.IntField;
-    using LongField = Lucene.Net.Documents.LongField;
+    using SingleDocValuesField = Lucene.Net.Documents.SingleDocValuesField;
+    using Int32Field = Lucene.Net.Documents.Int32Field;
+    using Int64Field = Lucene.Net.Documents.Int64Field;
     using NumericDocValuesField = Lucene.Net.Documents.NumericDocValuesField;
     using SortedDocValuesField = Lucene.Net.Documents.SortedDocValuesField;
     using StringField = Lucene.Net.Documents.StringField;
@@ -673,8 +673,8 @@ namespace Lucene.Net.Index
             doc.Add(new Field("content2", "here is more content with aaa aaa aaa", customType2));
             doc.Add(new Field("fie\u2C77ld", "field with non-ascii name", customType2));
             // add numeric fields, to test if flex preserves encoding
-            doc.Add(new IntField("trieInt", id, Field.Store.NO));
-            doc.Add(new LongField("trieLong", (long)id, Field.Store.NO));
+            doc.Add(new Int32Field("trieInt", id, Field.Store.NO));
+            doc.Add(new Int64Field("trieLong", (long)id, Field.Store.NO));
             // add docvalues fields
             doc.Add(new NumericDocValuesField("dvByte", (sbyte)id));
             sbyte[] bytes = new sbyte[] { (sbyte)((int)((uint)id >> 24)), (sbyte)((int)((uint)id >> 16)), (sbyte)((int)((uint)id >> 8)), (sbyte)id };
@@ -686,7 +686,7 @@ namespace Lucene.Net.Index
             doc.Add(new BinaryDocValuesField("dvBytesStraightFixed", @ref));
             doc.Add(new BinaryDocValuesField("dvBytesStraightVar", @ref));
             doc.Add(new DoubleDocValuesField("dvDouble", (double)id));
-            doc.Add(new FloatDocValuesField("dvFloat", (float)id));
+            doc.Add(new SingleDocValuesField("dvFloat", (float)id));
             doc.Add(new NumericDocValuesField("dvInt", id));
             doc.Add(new NumericDocValuesField("dvLong", id));
             doc.Add(new NumericDocValuesField("dvPacked", id));
@@ -846,7 +846,7 @@ namespace Lucene.Net.Index
                 Assert.AreEqual(34, hits_.Length, "wrong number of hits");
 
                 // check decoding into field cache
-                FieldCache.Ints fci = FieldCache.DEFAULT.GetInt32s(SlowCompositeReaderWrapper.Wrap(searcher.IndexReader), "trieInt", false);
+                FieldCache.Int32s fci = FieldCache.DEFAULT.GetInt32s(SlowCompositeReaderWrapper.Wrap(searcher.IndexReader), "trieInt", false);
                 int maxDoc = searcher.IndexReader.MaxDoc;
                 for (int doc = 0; doc < maxDoc; doc++)
                 {
@@ -854,7 +854,7 @@ namespace Lucene.Net.Index
                     Assert.IsTrue(val >= 0 && val < 35, "value in id bounds");
                 }
 
-                FieldCache.Longs fcl = FieldCache.DEFAULT.GetInt64s(SlowCompositeReaderWrapper.Wrap(searcher.IndexReader), "trieLong", false);
+                FieldCache.Int64s fcl = FieldCache.DEFAULT.GetInt64s(SlowCompositeReaderWrapper.Wrap(searcher.IndexReader), "trieLong", false);
                 for (int doc = 0; doc < maxDoc; doc++)
                 {
                     long val = fcl.Get(doc);


[42/53] [abbrv] lucenenet git commit: SWEEP: Renamed constant and enum value names from Short, Int, Long, and Float to match CLR types Int16, Int32, Int64, and Single, respectively.

Posted by ni...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Core/Util/Automaton/SortedIntSet.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Automaton/SortedIntSet.cs b/src/Lucene.Net.Core/Util/Automaton/SortedIntSet.cs
index 1ce3b7f..7412746 100644
--- a/src/Lucene.Net.Core/Util/Automaton/SortedIntSet.cs
+++ b/src/Lucene.Net.Core/Util/Automaton/SortedIntSet.cs
@@ -166,7 +166,7 @@ namespace Lucene.Net.Util.Automaton
             {
                 if (map.Count > values.Length)
                 {
-                    int size = ArrayUtil.Oversize(map.Count, RamUsageEstimator.NUM_BYTES_INT);
+                    int size = ArrayUtil.Oversize(map.Count, RamUsageEstimator.NUM_BYTES_INT32);
                     values = new int[size];
                     counts = new int[size];
                 }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Core/Util/BytesRefArray.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/BytesRefArray.cs b/src/Lucene.Net.Core/Util/BytesRefArray.cs
index cc5147d..dd650ff 100644
--- a/src/Lucene.Net.Core/Util/BytesRefArray.cs
+++ b/src/Lucene.Net.Core/Util/BytesRefArray.cs
@@ -46,7 +46,7 @@ namespace Lucene.Net.Util
         {
             this.pool = new ByteBlockPool(new ByteBlockPool.DirectTrackingAllocator(bytesUsed));
             pool.NextBuffer();
-            bytesUsed.AddAndGet(RamUsageEstimator.NUM_BYTES_ARRAY_HEADER + RamUsageEstimator.NUM_BYTES_INT);
+            bytesUsed.AddAndGet(RamUsageEstimator.NUM_BYTES_ARRAY_HEADER + RamUsageEstimator.NUM_BYTES_INT32);
             this.bytesUsed = bytesUsed;
         }
 
@@ -71,7 +71,7 @@ namespace Lucene.Net.Util
             {
                 int oldLen = offsets.Length;
                 offsets = ArrayUtil.Grow(offsets, offsets.Length + 1);
-                bytesUsed.AddAndGet((offsets.Length - oldLen) * RamUsageEstimator.NUM_BYTES_INT);
+                bytesUsed.AddAndGet((offsets.Length - oldLen) * RamUsageEstimator.NUM_BYTES_INT32);
             }
             pool.Append(bytes);
             offsets[lastElement++] = currentOffset;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Core/Util/BytesRefHash.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/BytesRefHash.cs b/src/Lucene.Net.Core/Util/BytesRefHash.cs
index b134712..a4934f7 100644
--- a/src/Lucene.Net.Core/Util/BytesRefHash.cs
+++ b/src/Lucene.Net.Core/Util/BytesRefHash.cs
@@ -91,7 +91,7 @@ namespace Lucene.Net.Util
             this.bytesStartArray = bytesStartArray;
             bytesStart = bytesStartArray.Init();
             bytesUsed = bytesStartArray.BytesUsed() == null ? Counter.NewCounter() : bytesStartArray.BytesUsed();
-            bytesUsed.AddAndGet(hashSize * RamUsageEstimator.NUM_BYTES_INT);
+            bytesUsed.AddAndGet(hashSize * RamUsageEstimator.NUM_BYTES_INT32);
         }
 
         /// <summary>
@@ -236,7 +236,7 @@ namespace Lucene.Net.Util
             }
             if (newSize != hashSize)
             {
-                bytesUsed.AddAndGet(RamUsageEstimator.NUM_BYTES_INT * -(hashSize - newSize));
+                bytesUsed.AddAndGet(RamUsageEstimator.NUM_BYTES_INT32 * -(hashSize - newSize));
                 hashSize = newSize;
                 ids = new int[hashSize];
                 Arrays.Fill(ids, -1);
@@ -282,7 +282,7 @@ namespace Lucene.Net.Util
         {
             Clear(true);
             ids = null;
-            bytesUsed.AddAndGet(RamUsageEstimator.NUM_BYTES_INT * -hashSize);
+            bytesUsed.AddAndGet(RamUsageEstimator.NUM_BYTES_INT32 * -hashSize);
         }
 
         /// <summary>
@@ -453,7 +453,7 @@ namespace Lucene.Net.Util
         private void Rehash(int newSize, bool hashOnData)
         {
             int newMask = newSize - 1;
-            bytesUsed.AddAndGet(RamUsageEstimator.NUM_BYTES_INT * (newSize));
+            bytesUsed.AddAndGet(RamUsageEstimator.NUM_BYTES_INT32 * (newSize));
             int[] newHash = new int[newSize];
             Arrays.Fill(newHash, -1);
             for (int i = 0; i < hashSize; i++)
@@ -504,7 +504,7 @@ namespace Lucene.Net.Util
             }
 
             hashMask = newMask;
-            bytesUsed.AddAndGet(RamUsageEstimator.NUM_BYTES_INT * (-ids.Length));
+            bytesUsed.AddAndGet(RamUsageEstimator.NUM_BYTES_INT32 * (-ids.Length));
             ids = newHash;
             hashSize = newSize;
             hashHalfSize = newSize / 2;
@@ -531,7 +531,7 @@ namespace Lucene.Net.Util
             if (ids == null)
             {
                 ids = new int[hashSize];
-                bytesUsed.AddAndGet(RamUsageEstimator.NUM_BYTES_INT * hashSize);
+                bytesUsed.AddAndGet(RamUsageEstimator.NUM_BYTES_INT32 * hashSize);
             }
         }
 
@@ -637,7 +637,7 @@ namespace Lucene.Net.Util
 
             public override int[] Init()
             {
-                return bytesStart = new int[ArrayUtil.Oversize(m_initSize, RamUsageEstimator.NUM_BYTES_INT)];
+                return bytesStart = new int[ArrayUtil.Oversize(m_initSize, RamUsageEstimator.NUM_BYTES_INT32)];
             }
 
             public override Counter BytesUsed()

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Core/Util/FieldCacheSanityChecker.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/FieldCacheSanityChecker.cs b/src/Lucene.Net.Core/Util/FieldCacheSanityChecker.cs
index cbb93ef..2641ee4 100644
--- a/src/Lucene.Net.Core/Util/FieldCacheSanityChecker.cs
+++ b/src/Lucene.Net.Core/Util/FieldCacheSanityChecker.cs
@@ -482,7 +482,7 @@ namespace Lucene.Net.Util
             /// tested -- if two cache entries have different parsers or datatypes but
             /// the cached values are the same Object (== not just equal()) this method
             /// does not consider that a red flag.  this allows for subtle variations
-            /// in the way a Parser is specified (null vs DEFAULT_LONG_PARSER, etc...)
+            /// in the way a Parser is specified (null vs DEFAULT_INT64_PARSER, etc...)
             /// </p>
             /// </summary>
             public static readonly InsanityType VALUEMISMATCH = new InsanityType("VALUEMISMATCH");

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Core/Util/Fst/FST.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Fst/FST.cs b/src/Lucene.Net.Core/Util/Fst/FST.cs
index 0c53847..8e187a0 100644
--- a/src/Lucene.Net.Core/Util/Fst/FST.cs
+++ b/src/Lucene.Net.Core/Util/Fst/FST.cs
@@ -244,7 +244,7 @@ namespace Lucene.Net.Util.Fst
 
             // NOTE: only reads most recent format; we don't have
             // back-compat promise for FSTs (they are experimental):
-            version = CodecUtil.CheckHeader(@in, FST.FILE_FORMAT_NAME, FST.VERSION_PACKED, FST.VERSION_VINT_TARGET);
+            version = CodecUtil.CheckHeader(@in, FST.FILE_FORMAT_NAME, FST.VERSION_PACKED, FST.VERSION_VINT32_TARGET);
             packed = @in.ReadByte() == 1;
             if (@in.ReadByte() == 1)
             {
@@ -920,7 +920,7 @@ namespace Lucene.Net.Util.Fst
                 {
                     // array: jump straight to end
                     arc.NumArcs = @in.ReadVInt32();
-                    if (packed || version >= FST.VERSION_VINT_TARGET)
+                    if (packed || version >= FST.VERSION_VINT32_TARGET)
                     {
                         arc.BytesPerArc = @in.ReadVInt32();
                     }
@@ -979,7 +979,7 @@ namespace Lucene.Net.Util.Fst
         private long ReadUnpackedNodeTarget(FST.BytesReader @in)
         {
             long target;
-            if (version < FST.VERSION_VINT_TARGET)
+            if (version < FST.VERSION_VINT32_TARGET)
             {
                 target = @in.ReadInt32();
             }
@@ -1040,7 +1040,7 @@ namespace Lucene.Net.Util.Fst
                 //System.out.println("  fixedArray");
                 // this is first arc in a fixed-array
                 arc.NumArcs = @in.ReadVInt32();
-                if (packed || version >= FST.VERSION_VINT_TARGET)
+                if (packed || version >= FST.VERSION_VINT32_TARGET)
                 {
                     arc.BytesPerArc = @in.ReadVInt32();
                 }
@@ -1121,7 +1121,7 @@ namespace Lucene.Net.Util.Fst
                     @in.ReadVInt32();
 
                     // Skip bytesPerArc:
-                    if (packed || version >= FST.VERSION_VINT_TARGET)
+                    if (packed || version >= FST.VERSION_VINT32_TARGET)
                     {
                         @in.ReadVInt32();
                     }
@@ -1341,7 +1341,7 @@ namespace Lucene.Net.Util.Fst
             {
                 // Arcs are full array; do binary search:
                 arc.NumArcs = @in.ReadVInt32();
-                if (packed || version >= FST.VERSION_VINT_TARGET)
+                if (packed || version >= FST.VERSION_VINT32_TARGET)
                 {
                     arc.BytesPerArc = @in.ReadVInt32();
                 }
@@ -2117,14 +2117,18 @@ namespace Lucene.Net.Util.Fst
         internal const int VERSION_START = 0;
 
         /// <summary>
-        /// Changed numBytesPerArc for array'd case from byte to int.
+        /// Changed numBytesPerArc for array'd case from byte to <see cref="int"/>.
+        /// <para/>
+        /// NOTE: This was VERSION_INT_NUM_BYTES_PER_ARC in Lucene
         /// </summary>
-        internal const int VERSION_INT_NUM_BYTES_PER_ARC = 1;
+        internal const int VERSION_INT32_NUM_BYTES_PER_ARC = 1;
 
         /// <summary>
-        /// Write BYTE2 labels as 2-byte short, not vInt.
+        /// Write BYTE2 labels as 2-byte <see cref="short"/>, not v<see cref="int"/>.
+        /// <para/>
+        /// NOTE: This was VERSION_SHORT_BYTE2_LABELS in Lucene
         /// </summary>
-        internal const int VERSION_SHORT_BYTE2_LABELS = 2;
+        internal const int VERSION_INT16_BYTE2_LABELS = 2;
 
         /// <summary>
         /// Added optional packed format.
@@ -2132,12 +2136,14 @@ namespace Lucene.Net.Util.Fst
         internal const int VERSION_PACKED = 3;
 
         /// <summary>
-        /// Changed from int to vInt for encoding arc targets.
-        /// Also changed maxBytesPerArc from int to vInt in the array case.
+        /// Changed from <see cref="int"/> to v<see cref="int"/> for encoding arc targets.
+        /// Also changed maxBytesPerArc from int to v<see cref="int"/> in the array case.
+        /// <para/>
+        /// NOTE: This was VERSION_VINT_TARGET in Lucene
         /// </summary>
-        internal const int VERSION_VINT_TARGET = 4;
+        internal const int VERSION_VINT32_TARGET = 4;
 
-        internal const int VERSION_CURRENT = VERSION_VINT_TARGET;
+        internal const int VERSION_CURRENT = VERSION_VINT32_TARGET;
 
         // Never serialized; just used to represent the virtual
         // final node w/ no arcs:

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Core/Util/IntBlockPool.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/IntBlockPool.cs b/src/Lucene.Net.Core/Util/IntBlockPool.cs
index 300a5f6..ec6c3de 100644
--- a/src/Lucene.Net.Core/Util/IntBlockPool.cs
+++ b/src/Lucene.Net.Core/Util/IntBlockPool.cs
@@ -30,13 +30,24 @@ namespace Lucene.Net.Util
     /// </summary>
     public sealed class Int32BlockPool
     {
-        public static readonly int INT_BLOCK_SHIFT = 13;
-        public static readonly int INT_BLOCK_SIZE = 1 << INT_BLOCK_SHIFT;
-        public static readonly int INT_BLOCK_MASK = INT_BLOCK_SIZE - 1;
+        /// <summary>
+        /// NOTE: This was INT_BLOCK_SHIFT in Lucene
+        /// </summary>
+        public static readonly int INT32_BLOCK_SHIFT = 13;
+
+        /// <summary>
+        /// NOTE: This was INT_BLOCK_SIZE in Lucene
+        /// </summary>
+        public static readonly int INT32_BLOCK_SIZE = 1 << INT32_BLOCK_SHIFT;
+
+        /// <summary>
+        /// NOTE: This was INT_BLOCK_MASK in Lucene
+        /// </summary>
+        public static readonly int INT32_BLOCK_MASK = INT32_BLOCK_SIZE - 1;
 
         /// <summary>
         /// Abstract class for allocating and freeing int
-        ///  blocks.
+        /// blocks.
         /// </summary>
         public abstract class Allocator
         {
@@ -69,7 +80,7 @@ namespace Lucene.Net.Util
             /// Creates a new <seealso cref="DirectAllocator"/> with a default block size
             /// </summary>
             public DirectAllocator()
-                : base(INT_BLOCK_SIZE)
+                : base(INT32_BLOCK_SIZE)
             {
             }
 
@@ -137,8 +148,8 @@ namespace Lucene.Net.Util
         public Int32BlockPool(Allocator allocator)
         {
             // set defaults
-            Int32Upto = INT_BLOCK_SIZE;
-            Int32Offset = -INT_BLOCK_SIZE;
+            Int32Upto = INT32_BLOCK_SIZE;
+            Int32Offset = -INT32_BLOCK_SIZE;
 
             this.allocator = allocator;
         }
@@ -195,8 +206,8 @@ namespace Lucene.Net.Util
                 else
                 {
                     bufferUpto = -1;
-                    Int32Upto = INT_BLOCK_SIZE;
-                    Int32Offset = -INT_BLOCK_SIZE;
+                    Int32Upto = INT32_BLOCK_SIZE;
+                    Int32Offset = -INT32_BLOCK_SIZE;
                     buffer = null;
                 }
             }
@@ -220,7 +231,7 @@ namespace Lucene.Net.Util
             bufferUpto++;
 
             Int32Upto = 0;
-            Int32Offset += INT_BLOCK_SIZE;
+            Int32Offset += INT32_BLOCK_SIZE;
         }
 
         /// <summary>
@@ -228,7 +239,7 @@ namespace Lucene.Net.Util
         /// <seealso cref= SliceReader </seealso>
         private int NewSlice(int size)
         {
-            if (Int32Upto > INT_BLOCK_SIZE - size)
+            if (Int32Upto > INT32_BLOCK_SIZE - size)
             {
                 NextBuffer();
                 Debug.Assert(AssertSliceBuffer(buffer));
@@ -277,7 +288,7 @@ namespace Lucene.Net.Util
             int newLevel = NEXT_LEVEL_ARRAY[level - 1];
             int newSize = LEVEL_SIZE_ARRAY[newLevel];
             // Maybe allocate another block
-            if (Int32Upto > INT_BLOCK_SIZE - newSize)
+            if (Int32Upto > INT32_BLOCK_SIZE - newSize)
             {
                 NextBuffer();
                 Debug.Assert(AssertSliceBuffer(buffer));
@@ -323,9 +334,9 @@ namespace Lucene.Net.Util
             /// </summary>
             public virtual void WriteInt32(int value)
             {
-                int[] ints = pool.buffers[offset >> INT_BLOCK_SHIFT];
+                int[] ints = pool.buffers[offset >> INT32_BLOCK_SHIFT];
                 Debug.Assert(ints != null);
-                int relativeOffset = offset & INT_BLOCK_MASK;
+                int relativeOffset = offset & INT32_BLOCK_MASK;
                 if (ints[relativeOffset] != 0)
                 {
                     // End of slice; allocate a new one
@@ -389,20 +400,20 @@ namespace Lucene.Net.Util
             /// </summary>
             public void Reset(int startOffset, int endOffset)
             {
-                bufferUpto = startOffset / INT_BLOCK_SIZE;
-                bufferOffset = bufferUpto * INT_BLOCK_SIZE;
+                bufferUpto = startOffset / INT32_BLOCK_SIZE;
+                bufferOffset = bufferUpto * INT32_BLOCK_SIZE;
                 this.end = endOffset;
                 upto = startOffset;
                 level = 1;
 
                 buffer = pool.buffers[bufferUpto];
-                upto = startOffset & INT_BLOCK_MASK;
+                upto = startOffset & INT32_BLOCK_MASK;
 
                 int firstSize = Int32BlockPool.LEVEL_SIZE_ARRAY[0];
                 if (startOffset + firstSize >= endOffset)
                 {
                     // There is only this one slice to read
-                    limit = endOffset & INT_BLOCK_MASK;
+                    limit = endOffset & INT32_BLOCK_MASK;
                 }
                 else
                 {
@@ -445,11 +456,11 @@ namespace Lucene.Net.Util
                 level = NEXT_LEVEL_ARRAY[level - 1];
                 int newSize = LEVEL_SIZE_ARRAY[level];
 
-                bufferUpto = nextIndex / INT_BLOCK_SIZE;
-                bufferOffset = bufferUpto * INT_BLOCK_SIZE;
+                bufferUpto = nextIndex / INT32_BLOCK_SIZE;
+                bufferOffset = bufferUpto * INT32_BLOCK_SIZE;
 
                 buffer = pool.Buffers[bufferUpto];
-                upto = nextIndex & INT_BLOCK_MASK;
+                upto = nextIndex & INT32_BLOCK_MASK;
 
                 if (nextIndex + newSize >= end)
                 {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Core/Util/IntsRef.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/IntsRef.cs b/src/Lucene.Net.Core/Util/IntsRef.cs
index c39aceb..c32f62f 100644
--- a/src/Lucene.Net.Core/Util/IntsRef.cs
+++ b/src/Lucene.Net.Core/Util/IntsRef.cs
@@ -24,9 +24,9 @@ namespace Lucene.Net.Util
      */
 
     /// <summary>
-    /// Represents int[], as a slice (offset + length) into an
-    /// existing int[].  The <seealso cref="#ints"/> member should never be null; use
-    /// <seealso cref="#EMPTY_INTS"/> if necessary.
+    /// Represents <see cref="T:int[]"/>, as a slice (offset + length) into an
+    /// existing <see cref="T:int[]"/>.  The <see cref="Int32s"/> member should never be null; use
+    /// <see cref="EMPTY_INT32S"/> if necessary.
     /// <para/>
     /// NOTE: This was IntsRef in Lucene
     /// 
@@ -35,8 +35,11 @@ namespace Lucene.Net.Util
     public sealed class Int32sRef : IComparable<Int32sRef>
     {
         /// <summary>
-        /// An empty integer array for convenience </summary>
-        public static readonly int[] EMPTY_INTS = new int[0];
+        /// An empty integer array for convenience
+        /// <para/>
+        /// NOTE: This was EMPTY_INTS in Lucene
+        /// </summary>
+        public static readonly int[] EMPTY_INT32S = new int[0];
 
         /// <summary>
         /// The contents of the IntsRef. Should never be {@code null}. 
@@ -68,10 +71,10 @@ namespace Lucene.Net.Util
         public int Length { get; set; }
 
         /// <summary>
-        /// Create a IntsRef with <seealso cref="#EMPTY_INTS"/> </summary>
+        /// Create a IntsRef with <see cref="EMPTY_INT32S"/> </summary>
         public Int32sRef()
         {
-            ints = EMPTY_INTS;
+            ints = EMPTY_INT32S;
         }
 
         /// <summary>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Core/Util/LongsRef.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/LongsRef.cs b/src/Lucene.Net.Core/Util/LongsRef.cs
index 4274922..fe27e80 100644
--- a/src/Lucene.Net.Core/Util/LongsRef.cs
+++ b/src/Lucene.Net.Core/Util/LongsRef.cs
@@ -24,10 +24,10 @@ namespace Lucene.Net.Util
      */
 
     /// <summary>
-    /// Represents long[], as a slice (offset + length) into an
-    ///  existing long[].  The <seealso cref="#longs"/> member should never be null; use
-    ///  <seealso cref="#EMPTY_LONGS"/> if necessary.
-    ///  <para/>
+    /// Represents <see cref="T:long[]"/>, as a slice (offset + length) into an
+    /// existing <see cref="T:long[]"/>.  The <see cref="Int64s"/> member should never be null; use
+    /// <see cref="EMPTY_INT64S"/> if necessary.
+    /// <para/>
     /// NOTE: This was LongsRef in Lucene
     ///
     ///  @lucene.internal
@@ -35,8 +35,11 @@ namespace Lucene.Net.Util
     public sealed class Int64sRef : IComparable<Int64sRef>
     {
         /// <summary>
-        /// An empty long array for convenience </summary>
-        public static readonly long[] EMPTY_LONGS = new long[0];
+        /// An empty long array for convenience
+        /// <para/>
+        /// NOTE: This was EMPTY_LONGS in Lucene
+        /// </summary>
+        public static readonly long[] EMPTY_INT64S = new long[0];
 
         /// <summary>
         /// The contents of the LongsRef. Should never be {@code null}. 
@@ -68,10 +71,10 @@ namespace Lucene.Net.Util
         public int Length { get; set; }
 
         /// <summary>
-        /// Create a LongsRef with <seealso cref="#EMPTY_LONGS"/> </summary>
+        /// Create a LongsRef with <see cref="EMPTY_INT64S"/> </summary>
         public Int64sRef()
         {
-            longs = EMPTY_LONGS;
+            longs = EMPTY_INT64S;
         }
 
         /// <summary>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Core/Util/NumericUtils.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/NumericUtils.cs b/src/Lucene.Net.Core/Util/NumericUtils.cs
index 4478e44..8f1bb66 100644
--- a/src/Lucene.Net.Core/Util/NumericUtils.cs
+++ b/src/Lucene.Net.Core/Util/NumericUtils.cs
@@ -75,27 +75,37 @@ namespace Lucene.Net.Util
 
         /// <summary>
         /// Longs are stored at lower precision by shifting off lower bits. The shift count is
-        /// stored as <code>SHIFT_START_LONG+shift</code> in the first byte
+        /// stored as <c>SHIFT_START_INT64+shift</c> in the first byte
+        /// <para/>
+        /// NOTE: This was SHIFT_START_LONG in Lucene
         /// </summary>
-        public const char SHIFT_START_LONG = (char)0x20;
+        public const char SHIFT_START_INT64 = (char)0x20;
 
         /// <summary>
         /// The maximum term length (used for <code>byte[]</code> buffer size)
-        /// for encoding <code>long</code> values. </summary>
-        /// <seealso cref= #longToPrefixCodedBytes </seealso>
-        public const int BUF_SIZE_LONG = 63 / 7 + 2;
+        /// for encoding <see cref="long"/> values.
+        /// <para/>
+        /// NOTE: This was BUF_SIZE_LONG in Lucene
+        /// </summary>
+        /// <seealso cref="Int64ToPrefixCodedBytes(long, int, BytesRef)"/>
+        public const int BUF_SIZE_INT64 = 63 / 7 + 2;
 
         /// <summary>
         /// Integers are stored at lower precision by shifting off lower bits. The shift count is
-        /// stored as <code>SHIFT_START_INT+shift</code> in the first byte
+        /// stored as <code>SHIFT_START_INT32+shift</code> in the first byte
+        /// <para/>
+        /// NOTE: This was SHIFT_START_INT in Lucene
         /// </summary>
-        public const byte SHIFT_START_INT = 0x60;
+        public const byte SHIFT_START_INT32 = 0x60;
 
         /// <summary>
-        /// The maximum term length (used for <code>byte[]</code> buffer size)
-        /// for encoding <code>int</code> values. </summary>
-        /// <seealso cref= #intToPrefixCodedBytes </seealso>
-        public const int BUF_SIZE_INT = 31 / 7 + 2;
+        /// The maximum term length (used for <see cref="T:byte[]"/> buffer size)
+        /// for encoding <see cref="int"/> values.
+        /// <para/>
+        /// NOTE: This was BUF_SIZE_INT in Lucene
+        /// </summary>
+        /// <seealso cref="Int32ToPrefixCodedBytes(int, int, BytesRef)"/>
+        public const int BUF_SIZE_INT32 = 31 / 7 + 2;
 
         /// <summary>
         /// Returns prefix coded bits after reducing the precision by <code>shift</code> bits.
@@ -148,9 +158,9 @@ namespace Lucene.Net.Util
             bytes.Length = nChars + 1; // one extra for the byte that contains the shift info
             if (bytes.Bytes.Length < bytes.Length)
             {
-                bytes.Bytes = new byte[NumericUtils.BUF_SIZE_LONG]; // use the max
+                bytes.Bytes = new byte[NumericUtils.BUF_SIZE_INT64]; // use the max
             }
-            bytes.Bytes[0] = (byte)(SHIFT_START_LONG + shift);
+            bytes.Bytes[0] = (byte)(SHIFT_START_INT64 + shift);
             ulong sortableBits = BitConverter.ToUInt64(BitConverter.GetBytes(val), 0) ^ 0x8000000000000000L;
             sortableBits = sortableBits >> shift;
             while (nChars > 0)
@@ -183,9 +193,9 @@ namespace Lucene.Net.Util
             bytes.Length = nChars + 1; // one extra for the byte that contains the shift info
             if (bytes.Bytes.Length < bytes.Length)
             {
-                bytes.Bytes = new byte[NumericUtils.BUF_SIZE_LONG]; // use the max
+                bytes.Bytes = new byte[NumericUtils.BUF_SIZE_INT64]; // use the max
             }
-            bytes.Bytes[0] = (byte)(SHIFT_START_INT + shift);
+            bytes.Bytes[0] = (byte)(SHIFT_START_INT32 + shift);
             int sortableBits = val ^ unchecked((int)0x80000000);
             sortableBits = Number.URShift(sortableBits, shift);
             while (nChars > 0)
@@ -206,7 +216,7 @@ namespace Lucene.Net.Util
         /// not correctly prefix encoded. </exception>
         public static int GetPrefixCodedInt64Shift(BytesRef val)
         {
-            int shift = val.Bytes[val.Offset] - SHIFT_START_LONG;
+            int shift = val.Bytes[val.Offset] - SHIFT_START_INT64;
             if (shift > 63 || shift < 0)
             {
                 throw new System.FormatException("Invalid shift value (" + shift + ") in prefixCoded bytes (is encoded value really an INT?)");
@@ -223,7 +233,7 @@ namespace Lucene.Net.Util
         /// not correctly prefix encoded. </exception>
         public static int GetPrefixCodedInt32Shift(BytesRef val)
         {
-            int shift = val.Bytes[val.Offset] - SHIFT_START_INT;
+            int shift = val.Bytes[val.Offset] - SHIFT_START_INT32;
             if (shift > 31 || shift < 0)
             {
                 throw new System.FormatException("Invalid shift value in prefixCoded bytes (is encoded value really an INT?)");
@@ -482,7 +492,7 @@ namespace Lucene.Net.Util
             /// </summary>
             public virtual void AddRange(long min, long max, int shift)
             {
-                BytesRef minBytes = new BytesRef(BUF_SIZE_LONG), maxBytes = new BytesRef(BUF_SIZE_LONG);
+                BytesRef minBytes = new BytesRef(BUF_SIZE_INT64), maxBytes = new BytesRef(BUF_SIZE_INT64);
                 Int64ToPrefixCodedBytes(min, shift, minBytes);
                 Int64ToPrefixCodedBytes(max, shift, maxBytes);
                 AddRange(minBytes, maxBytes);
@@ -515,7 +525,7 @@ namespace Lucene.Net.Util
             /// </summary>
             public virtual void AddRange(int min, int max, int shift)
             {
-                BytesRef minBytes = new BytesRef(BUF_SIZE_INT), maxBytes = new BytesRef(BUF_SIZE_INT);
+                BytesRef minBytes = new BytesRef(BUF_SIZE_INT32), maxBytes = new BytesRef(BUF_SIZE_INT32);
                 Int32ToPrefixCodedBytes(min, shift, minBytes);
                 Int32ToPrefixCodedBytes(max, shift, maxBytes);
                 AddRange(minBytes, maxBytes);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Core/Util/Packed/AbstractAppendingLongBuffer.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Packed/AbstractAppendingLongBuffer.cs b/src/Lucene.Net.Core/Util/Packed/AbstractAppendingLongBuffer.cs
index 1916751..eb650c6 100644
--- a/src/Lucene.Net.Core/Util/Packed/AbstractAppendingLongBuffer.cs
+++ b/src/Lucene.Net.Core/Util/Packed/AbstractAppendingLongBuffer.cs
@@ -221,10 +221,10 @@ namespace Lucene.Net.Util.Packed
         {
             return RamUsageEstimator.NUM_BYTES_OBJECT_HEADER 
                 + 2 * RamUsageEstimator.NUM_BYTES_OBJECT_REF 
-                + 2 * RamUsageEstimator.NUM_BYTES_INT 
-                + 2 * RamUsageEstimator.NUM_BYTES_INT 
-                + RamUsageEstimator.NUM_BYTES_FLOAT 
-                + RamUsageEstimator.NUM_BYTES_LONG; // valuesBytes -  acceptable overhead -  pageShift, pageMask -  the 2 offsets -  the 2 arrays
+                + 2 * RamUsageEstimator.NUM_BYTES_INT32 
+                + 2 * RamUsageEstimator.NUM_BYTES_INT32 
+                + RamUsageEstimator.NUM_BYTES_SINGLE 
+                + RamUsageEstimator.NUM_BYTES_INT64; // valuesBytes -  acceptable overhead -  pageShift, pageMask -  the 2 offsets -  the 2 arrays
         }
 
         /// <summary>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Core/Util/Packed/AbstractPagedMutable.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Packed/AbstractPagedMutable.cs b/src/Lucene.Net.Core/Util/Packed/AbstractPagedMutable.cs
index f3c88a0..82bd3ee 100644
--- a/src/Lucene.Net.Core/Util/Packed/AbstractPagedMutable.cs
+++ b/src/Lucene.Net.Core/Util/Packed/AbstractPagedMutable.cs
@@ -108,7 +108,7 @@ namespace Lucene.Net.Util.Packed
 
         protected virtual long BaseRamBytesUsed()
         {
-            return RamUsageEstimator.NUM_BYTES_OBJECT_HEADER + RamUsageEstimator.NUM_BYTES_OBJECT_REF + RamUsageEstimator.NUM_BYTES_LONG + 3 * RamUsageEstimator.NUM_BYTES_INT;
+            return RamUsageEstimator.NUM_BYTES_OBJECT_HEADER + RamUsageEstimator.NUM_BYTES_OBJECT_REF + RamUsageEstimator.NUM_BYTES_INT64 + 3 * RamUsageEstimator.NUM_BYTES_INT32;
         }
 
         /// <summary>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Core/Util/Packed/Direct16.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Packed/Direct16.cs b/src/Lucene.Net.Core/Util/Packed/Direct16.cs
index 75e2d37..a6088ac 100644
--- a/src/Lucene.Net.Core/Util/Packed/Direct16.cs
+++ b/src/Lucene.Net.Core/Util/Packed/Direct16.cs
@@ -68,7 +68,7 @@ namespace Lucene.Net.Util.Packed
         {
             return RamUsageEstimator.AlignObjectSize(
                 RamUsageEstimator.NUM_BYTES_OBJECT_HEADER 
-                + 2 * RamUsageEstimator.NUM_BYTES_INT // valueCount,bitsPerValue
+                + 2 * RamUsageEstimator.NUM_BYTES_INT32 // valueCount,bitsPerValue
                 + RamUsageEstimator.NUM_BYTES_OBJECT_REF) // values ref
                 + RamUsageEstimator.SizeOf(values);
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Core/Util/Packed/Direct32.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Packed/Direct32.cs b/src/Lucene.Net.Core/Util/Packed/Direct32.cs
index 575f2bf..6ecb585 100644
--- a/src/Lucene.Net.Core/Util/Packed/Direct32.cs
+++ b/src/Lucene.Net.Core/Util/Packed/Direct32.cs
@@ -68,7 +68,7 @@ namespace Lucene.Net.Util.Packed
         {
             return RamUsageEstimator.AlignObjectSize(
                 RamUsageEstimator.NUM_BYTES_OBJECT_HEADER 
-                + 2 * RamUsageEstimator.NUM_BYTES_INT // valueCount,bitsPerValue
+                + 2 * RamUsageEstimator.NUM_BYTES_INT32 // valueCount,bitsPerValue
                 + RamUsageEstimator.NUM_BYTES_OBJECT_REF) // values ref  
                 + RamUsageEstimator.SizeOf(values);
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Core/Util/Packed/Direct64.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Packed/Direct64.cs b/src/Lucene.Net.Core/Util/Packed/Direct64.cs
index 9a56944..b48c8d7 100644
--- a/src/Lucene.Net.Core/Util/Packed/Direct64.cs
+++ b/src/Lucene.Net.Core/Util/Packed/Direct64.cs
@@ -62,7 +62,7 @@ namespace Lucene.Net.Util.Packed
         {
             return RamUsageEstimator.AlignObjectSize(
                 RamUsageEstimator.NUM_BYTES_OBJECT_HEADER 
-                + 2 * RamUsageEstimator.NUM_BYTES_INT // valueCount,bitsPerValue
+                + 2 * RamUsageEstimator.NUM_BYTES_INT32 // valueCount,bitsPerValue
                 + RamUsageEstimator.NUM_BYTES_OBJECT_REF) // values ref 
                 + RamUsageEstimator.SizeOf(values); 
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Core/Util/Packed/Direct8.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Packed/Direct8.cs b/src/Lucene.Net.Core/Util/Packed/Direct8.cs
index 40ba1c5..d2345dc 100644
--- a/src/Lucene.Net.Core/Util/Packed/Direct8.cs
+++ b/src/Lucene.Net.Core/Util/Packed/Direct8.cs
@@ -65,7 +65,7 @@ namespace Lucene.Net.Util.Packed
         {
             return RamUsageEstimator.AlignObjectSize(
                 RamUsageEstimator.NUM_BYTES_OBJECT_HEADER 
-                + 2 * RamUsageEstimator.NUM_BYTES_INT // valueCount,bitsPerValue
+                + 2 * RamUsageEstimator.NUM_BYTES_INT32 // valueCount,bitsPerValue
                 + RamUsageEstimator.NUM_BYTES_OBJECT_REF) // values ref 
                 + RamUsageEstimator.SizeOf(values);  
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Core/Util/Packed/EliasFanoDecoder.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Packed/EliasFanoDecoder.cs b/src/Lucene.Net.Core/Util/Packed/EliasFanoDecoder.cs
index 7e4c1d6..0e62206 100644
--- a/src/Lucene.Net.Core/Util/Packed/EliasFanoDecoder.cs
+++ b/src/Lucene.Net.Core/Util/Packed/EliasFanoDecoder.cs
@@ -27,7 +27,10 @@ namespace Lucene.Net.Util.Packed
     /// </summary>
     public class EliasFanoDecoder
     {
-        private static readonly int LOG2_LONG_SIZE = Number.NumberOfTrailingZeros((sizeof(long) * 8));
+        /// <summary>
+        /// NOTE: This was LOG2_LONG_SIZE in Lucene
+        /// </summary>
+        private static readonly int LOG2_INT64_SIZE = Number.NumberOfTrailingZeros((sizeof(long) * 8));
 
         private readonly EliasFanoEncoder efEncoder;
         private readonly long numEncoded;
@@ -115,7 +118,7 @@ namespace Lucene.Net.Util.Packed
                 return 0;
             }
             long bitPos = packIndex * numBits;
-            int index = (int)((long)((ulong)bitPos >> LOG2_LONG_SIZE));
+            int index = (int)((long)((ulong)bitPos >> LOG2_INT64_SIZE));
             int bitPosAtIndex = (int)(bitPos & ((sizeof(long) * 8) - 1));
             long value = (long)((ulong)longArray[index] >> bitPosAtIndex);
             if ((bitPosAtIndex + numBits) > (sizeof(long) * 8))
@@ -187,7 +190,7 @@ namespace Lucene.Net.Util.Packed
                 return false;
             }
             setBitForIndex += 1;
-            int highIndex = (int)((long)((ulong)setBitForIndex >> LOG2_LONG_SIZE));
+            int highIndex = (int)((long)((ulong)setBitForIndex >> LOG2_INT64_SIZE));
             curHighLong = (long)((ulong)efEncoder.upperLongs[highIndex] >> CurrentRightShift);
             return true;
         }
@@ -202,7 +205,7 @@ namespace Lucene.Net.Util.Packed
         {
             setBitForIndex += (sizeof(long) * 8) - (setBitForIndex & ((sizeof(long) * 8) - 1));
             //assert getCurrentRightShift() == 0;
-            int highIndex = (int)((long)((ulong)setBitForIndex >> LOG2_LONG_SIZE));
+            int highIndex = (int)((long)((ulong)setBitForIndex >> LOG2_INT64_SIZE));
             curHighLong = efEncoder.upperLongs[highIndex];
         }
 
@@ -299,7 +302,7 @@ namespace Lucene.Net.Util.Packed
             }
             setBitForIndex += 1; // the high bit at setBitForIndex belongs to the unary code for efIndex
 
-            int highIndex = (int)((long)((ulong)setBitForIndex >> LOG2_LONG_SIZE));
+            int highIndex = (int)((long)((ulong)setBitForIndex >> LOG2_INT64_SIZE));
             long upperLong = efEncoder.upperLongs[highIndex];
             curHighLong = (long)((ulong)upperLong >> ((int)(setBitForIndex & ((sizeof(long) * 8) - 1)))); // may contain the unary 1 bit for efIndex
 
@@ -319,7 +322,7 @@ namespace Lucene.Net.Util.Packed
                 {
                     setBitForIndex = UnPackValue(efEncoder.upperZeroBitPositionIndex, efEncoder.nIndexEntryBits, indexEntryIndex, indexMask);
                     efIndex = setBitForIndex - indexHighValue; // the high bit at setBitForIndex belongs to the unary code for efIndex
-                    highIndex = (int)(((ulong)setBitForIndex >> LOG2_LONG_SIZE));
+                    highIndex = (int)(((ulong)setBitForIndex >> LOG2_INT64_SIZE));
                     upperLong = efEncoder.upperLongs[highIndex];
                     curHighLong = (long)((ulong)upperLong >> ((int)(setBitForIndex & ((sizeof(long) * 8) - 1)))); // may contain the unary 1 bit for efIndex
                 }
@@ -339,7 +342,7 @@ namespace Lucene.Net.Util.Packed
                 }
                 setBitForIndex += (sizeof(long) * 8) - (setBitForIndex & ((sizeof(long) * 8) - 1));
                 // highIndex = (int)(setBitForIndex >>> LOG2_LONG_SIZE);
-                Debug.Assert((highIndex + 1) == (int)((long)((ulong)setBitForIndex >> LOG2_LONG_SIZE)));
+                Debug.Assert((highIndex + 1) == (int)((long)((ulong)setBitForIndex >> LOG2_INT64_SIZE)));
                 highIndex += 1;
                 upperLong = efEncoder.upperLongs[highIndex];
                 curHighLong = upperLong;
@@ -350,7 +353,7 @@ namespace Lucene.Net.Util.Packed
             while (curHighLong == 0L)
             {
                 setBitForIndex += (sizeof(long) * 8) - (setBitForIndex & ((sizeof(long) * 8) - 1));
-                Debug.Assert((highIndex + 1) == (int)((ulong)setBitForIndex >> LOG2_LONG_SIZE));
+                Debug.Assert((highIndex + 1) == (int)((ulong)setBitForIndex >> LOG2_INT64_SIZE));
                 highIndex += 1;
                 upperLong = efEncoder.upperLongs[highIndex];
                 curHighLong = upperLong;
@@ -374,14 +377,14 @@ namespace Lucene.Net.Util.Packed
 
                 if ((setBitForIndex & ((sizeof(long) * 8) - 1)) == 0L) // exhausted curHighLong
                 {
-                    Debug.Assert((highIndex + 1) == (int)((ulong)setBitForIndex >> LOG2_LONG_SIZE));
+                    Debug.Assert((highIndex + 1) == (int)((ulong)setBitForIndex >> LOG2_INT64_SIZE));
                     highIndex += 1;
                     upperLong = efEncoder.upperLongs[highIndex];
                     curHighLong = upperLong;
                 }
                 else
                 {
-                    Debug.Assert(highIndex == (int)((ulong)setBitForIndex >> LOG2_LONG_SIZE));
+                    Debug.Assert(highIndex == (int)((ulong)setBitForIndex >> LOG2_INT64_SIZE));
                     curHighLong = (long)((ulong)upperLong >> ((int)(setBitForIndex & ((sizeof(long) * 8) - 1))));
                 }
                 // curHighLong has enough clear bits to reach highTarget, and may not have enough set bits.
@@ -389,7 +392,7 @@ namespace Lucene.Net.Util.Packed
                 while (curHighLong == 0L)
                 {
                     setBitForIndex += (sizeof(long) * 8) - (setBitForIndex & ((sizeof(long) * 8) - 1));
-                    Debug.Assert((highIndex + 1) == (int)((ulong)setBitForIndex >> LOG2_LONG_SIZE));
+                    Debug.Assert((highIndex + 1) == (int)((ulong)setBitForIndex >> LOG2_INT64_SIZE));
                     highIndex += 1;
                     upperLong = efEncoder.upperLongs[highIndex];
                     curHighLong = upperLong;
@@ -444,7 +447,7 @@ namespace Lucene.Net.Util.Packed
                 return false;
             }
             setBitForIndex -= 1;
-            int highIndex = (int)((ulong)setBitForIndex >> LOG2_LONG_SIZE);
+            int highIndex = (int)((ulong)setBitForIndex >> LOG2_INT64_SIZE);
             curHighLong = efEncoder.upperLongs[highIndex] << CurrentLeftShift;
             return true;
         }
@@ -459,7 +462,7 @@ namespace Lucene.Net.Util.Packed
         {
             setBitForIndex -= (setBitForIndex & ((sizeof(long) * 8) - 1)) + 1;
             //assert getCurrentLeftShift() == 0;
-            int highIndex = (int)((ulong)setBitForIndex >> LOG2_LONG_SIZE);
+            int highIndex = (int)((ulong)setBitForIndex >> LOG2_INT64_SIZE);
             curHighLong = efEncoder.upperLongs[highIndex];
         }
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Core/Util/Packed/EliasFanoEncoder.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Packed/EliasFanoEncoder.cs b/src/Lucene.Net.Core/Util/Packed/EliasFanoEncoder.cs
index 2e09188..6963115 100644
--- a/src/Lucene.Net.Core/Util/Packed/EliasFanoEncoder.cs
+++ b/src/Lucene.Net.Core/Util/Packed/EliasFanoEncoder.cs
@@ -91,7 +91,11 @@ namespace Lucene.Net.Util.Packed
         internal readonly long lowerBitsMask;
         internal readonly long[] upperLongs;
         internal readonly long[] lowerLongs;
-        private static readonly int LOG2_LONG_SIZE = Number.NumberOfTrailingZeros(sizeof(long) * 8);
+
+        /// <summary>
+        /// NOTE: This was LOG2_LONG_SIZE in Lucene
+        /// </summary>
+        private static readonly int LOG2_INT64_SIZE = Number.NumberOfTrailingZeros(sizeof(long) * 8);
 
         internal long numEncoded = 0L;
         internal long lastEncoded = 0L;
@@ -213,7 +217,7 @@ namespace Lucene.Net.Util.Packed
         private static long NumInt64sForBits(long numBits) // Note: int version in FixedBitSet.bits2words()
         {
             Debug.Assert(numBits >= 0, numBits.ToString());
-            return (long)((ulong)(numBits + (sizeof(long) * 8 - 1)) >> LOG2_LONG_SIZE);
+            return (long)((ulong)(numBits + (sizeof(long) * 8 - 1)) >> LOG2_INT64_SIZE);
         }
 
         /// <summary>
@@ -258,7 +262,7 @@ namespace Lucene.Net.Util.Packed
         private void EncodeUpperBits(long highValue)
         {
             long nextHighBitNum = numEncoded + highValue; // sequence of unary gaps
-            upperLongs[(int)((long)((ulong)nextHighBitNum >> LOG2_LONG_SIZE))] |= (1L << (int)(nextHighBitNum & ((sizeof(long) * 8) - 1)));
+            upperLongs[(int)((long)((ulong)nextHighBitNum >> LOG2_INT64_SIZE))] |= (1L << (int)(nextHighBitNum & ((sizeof(long) * 8) - 1)));
         }
 
         private void EncodeLowerBits(long lowValue)
@@ -271,7 +275,7 @@ namespace Lucene.Net.Util.Packed
             if (numBits != 0)
             {
                 long bitPos = numBits * packIndex;
-                int index = (int)((long)((ulong)bitPos >> LOG2_LONG_SIZE));
+                int index = (int)((long)((ulong)bitPos >> LOG2_INT64_SIZE));
                 int bitPosAtIndex = (int)(bitPos & ((sizeof(long) * 8) - 1));
                 longArray[index] |= (value << bitPosAtIndex);
                 if ((bitPosAtIndex + numBits) > (sizeof(long) * 8))

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Core/Util/Packed/GrowableWriter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Packed/GrowableWriter.cs b/src/Lucene.Net.Core/Util/Packed/GrowableWriter.cs
index 590746a..34da357 100644
--- a/src/Lucene.Net.Core/Util/Packed/GrowableWriter.cs
+++ b/src/Lucene.Net.Core/Util/Packed/GrowableWriter.cs
@@ -152,8 +152,8 @@ namespace Lucene.Net.Util.Packed
             return RamUsageEstimator.AlignObjectSize(
                 RamUsageEstimator.NUM_BYTES_OBJECT_HEADER 
                 + RamUsageEstimator.NUM_BYTES_OBJECT_REF 
-                + RamUsageEstimator.NUM_BYTES_LONG 
-                + RamUsageEstimator.NUM_BYTES_FLOAT) 
+                + RamUsageEstimator.NUM_BYTES_INT64 
+                + RamUsageEstimator.NUM_BYTES_SINGLE) 
                 + current.RamBytesUsed();
         }
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Core/Util/Packed/Packed16ThreeBlocks.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Packed/Packed16ThreeBlocks.cs b/src/Lucene.Net.Core/Util/Packed/Packed16ThreeBlocks.cs
index 2323d1d..af0d9e9 100644
--- a/src/Lucene.Net.Core/Util/Packed/Packed16ThreeBlocks.cs
+++ b/src/Lucene.Net.Core/Util/Packed/Packed16ThreeBlocks.cs
@@ -127,7 +127,7 @@ namespace Lucene.Net.Util.Packed
         {
             return RamUsageEstimator.AlignObjectSize(
                 RamUsageEstimator.NUM_BYTES_OBJECT_HEADER 
-                + 2 * RamUsageEstimator.NUM_BYTES_INT // valueCount,bitsPerValue
+                + 2 * RamUsageEstimator.NUM_BYTES_INT32 // valueCount,bitsPerValue
                 + RamUsageEstimator.NUM_BYTES_OBJECT_REF) // blocks ref 
                 + RamUsageEstimator.SizeOf(blocks);
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Core/Util/Packed/Packed64.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Packed/Packed64.cs b/src/Lucene.Net.Core/Util/Packed/Packed64.cs
index f6f56bd..301d26e 100644
--- a/src/Lucene.Net.Core/Util/Packed/Packed64.cs
+++ b/src/Lucene.Net.Core/Util/Packed/Packed64.cs
@@ -298,8 +298,8 @@ namespace Lucene.Net.Util.Packed
         {
             return RamUsageEstimator.AlignObjectSize(
                 RamUsageEstimator.NUM_BYTES_OBJECT_HEADER 
-                + 3 * RamUsageEstimator.NUM_BYTES_INT // bpvMinusBlockSize,valueCount,bitsPerValue
-                + RamUsageEstimator.NUM_BYTES_LONG // maskRight
+                + 3 * RamUsageEstimator.NUM_BYTES_INT32 // bpvMinusBlockSize,valueCount,bitsPerValue
+                + RamUsageEstimator.NUM_BYTES_INT64 // maskRight
                 + RamUsageEstimator.NUM_BYTES_OBJECT_REF) // blocks ref
                 + RamUsageEstimator.SizeOf(blocks);
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Core/Util/Packed/Packed64SingleBlock.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Packed/Packed64SingleBlock.cs b/src/Lucene.Net.Core/Util/Packed/Packed64SingleBlock.cs
index 4119a4b..3b98323 100644
--- a/src/Lucene.Net.Core/Util/Packed/Packed64SingleBlock.cs
+++ b/src/Lucene.Net.Core/Util/Packed/Packed64SingleBlock.cs
@@ -65,7 +65,7 @@ namespace Lucene.Net.Util.Packed
         {
             return RamUsageEstimator.AlignObjectSize(
                 RamUsageEstimator.NUM_BYTES_OBJECT_HEADER 
-                + 2 * RamUsageEstimator.NUM_BYTES_INT // valueCount,bitsPerValue
+                + 2 * RamUsageEstimator.NUM_BYTES_INT32 // valueCount,bitsPerValue
                 + RamUsageEstimator.NUM_BYTES_OBJECT_REF) // blocks ref 
                 + RamUsageEstimator.SizeOf(blocks);
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Core/Util/Packed/Packed8ThreeBlocks.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Packed/Packed8ThreeBlocks.cs b/src/Lucene.Net.Core/Util/Packed/Packed8ThreeBlocks.cs
index eac8677..9643a60 100644
--- a/src/Lucene.Net.Core/Util/Packed/Packed8ThreeBlocks.cs
+++ b/src/Lucene.Net.Core/Util/Packed/Packed8ThreeBlocks.cs
@@ -124,7 +124,7 @@ namespace Lucene.Net.Util.Packed
         {
             return RamUsageEstimator.AlignObjectSize(
                 RamUsageEstimator.NUM_BYTES_OBJECT_HEADER 
-                + 2 * RamUsageEstimator.NUM_BYTES_INT // valueCount,bitsPerValue
+                + 2 * RamUsageEstimator.NUM_BYTES_INT32 // valueCount,bitsPerValue
                 + RamUsageEstimator.NUM_BYTES_OBJECT_REF) // blocks ref
                 + RamUsageEstimator.SizeOf(blocks);
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Core/Util/Packed/PackedInts.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Packed/PackedInts.cs b/src/Lucene.Net.Core/Util/Packed/PackedInts.cs
index a440651..1a5649a 100644
--- a/src/Lucene.Net.Core/Util/Packed/PackedInts.cs
+++ b/src/Lucene.Net.Core/Util/Packed/PackedInts.cs
@@ -932,7 +932,7 @@ namespace Lucene.Net.Util.Packed
 
             public override long RamBytesUsed()
             {
-                return RamUsageEstimator.AlignObjectSize(RamUsageEstimator.NUM_BYTES_OBJECT_HEADER + RamUsageEstimator.NUM_BYTES_INT);
+                return RamUsageEstimator.AlignObjectSize(RamUsageEstimator.NUM_BYTES_OBJECT_HEADER + RamUsageEstimator.NUM_BYTES_INT32);
             }
         }
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Core/Util/Packed/PagedGrowableWriter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/Packed/PagedGrowableWriter.cs b/src/Lucene.Net.Core/Util/Packed/PagedGrowableWriter.cs
index 3de2bb8..f05202b 100644
--- a/src/Lucene.Net.Core/Util/Packed/PagedGrowableWriter.cs
+++ b/src/Lucene.Net.Core/Util/Packed/PagedGrowableWriter.cs
@@ -65,7 +65,7 @@ namespace Lucene.Net.Util.Packed
 
         protected override long BaseRamBytesUsed()
         {
-            return base.BaseRamBytesUsed() + RamUsageEstimator.NUM_BYTES_FLOAT;
+            return base.BaseRamBytesUsed() + RamUsageEstimator.NUM_BYTES_SINGLE;
         }
     }
 }
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Core/Util/RamUsageEstimator.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/RamUsageEstimator.cs b/src/Lucene.Net.Core/Util/RamUsageEstimator.cs
index 6450ee8..1f5aaf5 100644
--- a/src/Lucene.Net.Core/Util/RamUsageEstimator.cs
+++ b/src/Lucene.Net.Core/Util/RamUsageEstimator.cs
@@ -61,10 +61,26 @@ namespace Lucene.Net.Util
         public const int NUM_BYTES_BOOLEAN = 1;
         public const int NUM_BYTES_BYTE = 1;
         public const int NUM_BYTES_CHAR = 2;
-        public const int NUM_BYTES_SHORT = 2;
-        public const int NUM_BYTES_INT = 4;
-        public const int NUM_BYTES_FLOAT = 4;
-        public const int NUM_BYTES_LONG = 8;
+
+        /// <summary>
+        /// NOTE: This was NUM_BYTES_SHORT in Lucene
+        /// </summary>
+        public const int NUM_BYTES_INT16 = 2;
+
+        /// <summary>
+        /// NOTE: This was NUM_BYTES_INT in Lucene
+        /// </summary>
+        public const int NUM_BYTES_INT32 = 4;
+
+        /// <summary>
+        /// NOTE: This was NUM_BYTES_FLOAT in Lucene
+        /// </summary>
+        public const int NUM_BYTES_SINGLE = 4;
+
+        /// <summary>
+        /// NOTE: This was NUM_BYTES_LONG in Lucene
+        /// </summary>
+        public const int NUM_BYTES_INT64 = 8;
         public const int NUM_BYTES_DOUBLE = 8;
 
         /// <summary>
@@ -100,17 +116,17 @@ namespace Lucene.Net.Util
             primitiveSizes[typeof(bool)] = Convert.ToInt32(NUM_BYTES_BOOLEAN);
             primitiveSizes[typeof(sbyte)] = Convert.ToInt32(NUM_BYTES_BYTE);
             primitiveSizes[typeof(char)] = Convert.ToInt32(NUM_BYTES_CHAR);
-            primitiveSizes[typeof(short)] = Convert.ToInt32(NUM_BYTES_SHORT);
-            primitiveSizes[typeof(int)] = Convert.ToInt32(NUM_BYTES_INT);
-            primitiveSizes[typeof(float)] = Convert.ToInt32(NUM_BYTES_FLOAT);
+            primitiveSizes[typeof(short)] = Convert.ToInt32(NUM_BYTES_INT16);
+            primitiveSizes[typeof(int)] = Convert.ToInt32(NUM_BYTES_INT32);
+            primitiveSizes[typeof(float)] = Convert.ToInt32(NUM_BYTES_SINGLE);
             primitiveSizes[typeof(double)] = Convert.ToInt32(NUM_BYTES_DOUBLE);
-            primitiveSizes[typeof(long)] = Convert.ToInt32(NUM_BYTES_LONG);
+            primitiveSizes[typeof(long)] = Convert.ToInt32(NUM_BYTES_INT64);
 
             // Initialize empirically measured defaults. We'll modify them to the current
             // JVM settings later on if possible.
             int referenceSize = Constants.JRE_IS_64BIT ? 8 : 4;
             int objectHeader = Constants.JRE_IS_64BIT ? 16 : 8;
-            // The following is objectHeader + NUM_BYTES_INT, but aligned (object alignment)
+            // The following is objectHeader + NUM_BYTES_INT32, but aligned (object alignment)
             // so on 64 bit JVMs it'll be align(16 + 4, @8) = 24.
             int arrayHeader = Constants.JRE_IS_64BIT ? 24 : 12;
             int objectAlignment = Constants.JRE_IS_64BIT ? 8 : 4;
@@ -305,28 +321,28 @@ namespace Lucene.Net.Util
         /// Returns the size in bytes of the short[] object. </summary>
         public static long SizeOf(short[] arr)
         {
-            return AlignObjectSize((long)NUM_BYTES_ARRAY_HEADER + (long)NUM_BYTES_SHORT * arr.Length);
+            return AlignObjectSize((long)NUM_BYTES_ARRAY_HEADER + (long)NUM_BYTES_INT16 * arr.Length);
         }
 
         /// <summary>
         /// Returns the size in bytes of the int[] object. </summary>
         public static long SizeOf(int[] arr)
         {
-            return AlignObjectSize((long)NUM_BYTES_ARRAY_HEADER + (long)NUM_BYTES_INT * arr.Length);
+            return AlignObjectSize((long)NUM_BYTES_ARRAY_HEADER + (long)NUM_BYTES_INT32 * arr.Length);
         }
 
         /// <summary>
         /// Returns the size in bytes of the float[] object. </summary>
         public static long SizeOf(float[] arr)
         {
-            return AlignObjectSize((long)NUM_BYTES_ARRAY_HEADER + (long)NUM_BYTES_FLOAT * arr.Length);
+            return AlignObjectSize((long)NUM_BYTES_ARRAY_HEADER + (long)NUM_BYTES_SINGLE * arr.Length);
         }
 
         /// <summary>
         /// Returns the size in bytes of the long[] object. </summary>
         public static long SizeOf(long[] arr)
         {
-            return AlignObjectSize((long)NUM_BYTES_ARRAY_HEADER + (long)NUM_BYTES_LONG * arr.Length);
+            return AlignObjectSize((long)NUM_BYTES_ARRAY_HEADER + (long)NUM_BYTES_INT64 * arr.Length);
         }
 
         /// <summary>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Core/Util/RecyclingIntBlockAllocator.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/RecyclingIntBlockAllocator.cs b/src/Lucene.Net.Core/Util/RecyclingIntBlockAllocator.cs
index 271515e..073ea2d 100644
--- a/src/Lucene.Net.Core/Util/RecyclingIntBlockAllocator.cs
+++ b/src/Lucene.Net.Core/Util/RecyclingIntBlockAllocator.cs
@@ -72,13 +72,13 @@ namespace Lucene.Net.Util
         }
 
         /// <summary>
-        /// Creates a new <seealso cref="RecyclingInt32BlockAllocator"/> with a block size of
-        /// <seealso cref="Int32BlockPool#INT_BLOCK_SIZE"/>, upper buffered docs limit of
-        /// <seealso cref="#DEFAULT_BUFFERED_BLOCKS"/> ({@value #DEFAULT_BUFFERED_BLOCKS}).
+        /// Creates a new <see cref="RecyclingInt32BlockAllocator"/> with a block size of
+        /// <see cref="Int32BlockPool.INT32_BLOCK_SIZE"/>, upper buffered docs limit of
+        /// <see cref="DEFAULT_BUFFERED_BLOCKS"/>.
         ///
         /// </summary>
         public RecyclingInt32BlockAllocator()
-            : this(Int32BlockPool.INT_BLOCK_SIZE, 64, Counter.NewCounter(false))
+            : this(Int32BlockPool.INT32_BLOCK_SIZE, 64, Counter.NewCounter(false))
         {
         }
 
@@ -89,7 +89,7 @@ namespace Lucene.Net.Util
         {
             if (freeBlocks == 0)
             {
-                bytesUsed.AddAndGet(m_blockSize * RamUsageEstimator.NUM_BYTES_INT);
+                bytesUsed.AddAndGet(m_blockSize * RamUsageEstimator.NUM_BYTES_INT32);
                 return new int[m_blockSize];
             }
             int[] b = freeByteBlocks[--freeBlocks];
@@ -120,7 +120,7 @@ namespace Lucene.Net.Util
             {
                 blocks[i] = null;
             }
-            bytesUsed.AddAndGet(-(end - stop) * (m_blockSize * RamUsageEstimator.NUM_BYTES_INT));
+            bytesUsed.AddAndGet(-(end - stop) * (m_blockSize * RamUsageEstimator.NUM_BYTES_INT32));
             Debug.Assert(bytesUsed.Get() >= 0);
         }
 
@@ -167,7 +167,7 @@ namespace Lucene.Net.Util
             {
                 freeByteBlocks[--freeBlocks] = null;
             }
-            bytesUsed.AddAndGet(-count * m_blockSize * RamUsageEstimator.NUM_BYTES_INT);
+            bytesUsed.AddAndGet(-count * m_blockSize * RamUsageEstimator.NUM_BYTES_INT32);
             Debug.Assert(bytesUsed.Get() >= 0);
             return count;
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Core/Util/WAH8DocIdSet.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/WAH8DocIdSet.cs b/src/Lucene.Net.Core/Util/WAH8DocIdSet.cs
index 46fca06..dad410c 100644
--- a/src/Lucene.Net.Core/Util/WAH8DocIdSet.cs
+++ b/src/Lucene.Net.Core/Util/WAH8DocIdSet.cs
@@ -903,7 +903,7 @@ namespace Lucene.Net.Util
         /// Return the memory usage of this class in bytes. </summary>
         public long RamBytesUsed()
         {
-            return RamUsageEstimator.AlignObjectSize(3 * RamUsageEstimator.NUM_BYTES_OBJECT_REF + 2 * RamUsageEstimator.NUM_BYTES_INT) 
+            return RamUsageEstimator.AlignObjectSize(3 * RamUsageEstimator.NUM_BYTES_OBJECT_REF + 2 * RamUsageEstimator.NUM_BYTES_INT32) 
                 + RamUsageEstimator.SizeOf(data) 
                 + positions.RamBytesUsed() 
                 + wordNums.RamBytesUsed();

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Expressions/SimpleBindings.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Expressions/SimpleBindings.cs b/src/Lucene.Net.Expressions/SimpleBindings.cs
index 89c121b..2c638b6 100644
--- a/src/Lucene.Net.Expressions/SimpleBindings.cs
+++ b/src/Lucene.Net.Expressions/SimpleBindings.cs
@@ -90,17 +90,17 @@ namespace Lucene.Net.Expressions
             SortField field = (SortField)o;
             switch (field.Type)
             {
-                case SortFieldType.INT:
+                case SortFieldType.INT32:
                     {
                         return new Int32FieldSource(field.Field, (FieldCache.IInt32Parser)field.Parser);
                     }
 
-                case SortFieldType.LONG:
+                case SortFieldType.INT64:
                     {
                         return new Int64FieldSource(field.Field, (FieldCache.IInt64Parser)field.Parser);
                     }
 
-                case SortFieldType.FLOAT:
+                case SortFieldType.SINGLE:
                     {
                         return new SingleFieldSource(field.Field, (FieldCache.ISingleParser)field.Parser);
                     }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Memory/MemoryIndex.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Memory/MemoryIndex.cs b/src/Lucene.Net.Memory/MemoryIndex.cs
index 1d46b1b..2152d43 100644
--- a/src/Lucene.Net.Memory/MemoryIndex.cs
+++ b/src/Lucene.Net.Memory/MemoryIndex.cs
@@ -215,10 +215,10 @@ namespace Lucene.Net.Index.Memory
             this.storeOffsets = storeOffsets;
             this.bytesUsed = Counter.NewCounter();
             int maxBufferedByteBlocks = (int)((maxReusedBytes / 2) / ByteBlockPool.BYTE_BLOCK_SIZE);
-            int maxBufferedIntBlocks = (int)((maxReusedBytes - (maxBufferedByteBlocks * ByteBlockPool.BYTE_BLOCK_SIZE)) / (Int32BlockPool.INT_BLOCK_SIZE * RamUsageEstimator.NUM_BYTES_INT));
-            Debug.Assert((maxBufferedByteBlocks * ByteBlockPool.BYTE_BLOCK_SIZE) + (maxBufferedIntBlocks * Int32BlockPool.INT_BLOCK_SIZE * RamUsageEstimator.NUM_BYTES_INT) <= maxReusedBytes);
+            int maxBufferedIntBlocks = (int)((maxReusedBytes - (maxBufferedByteBlocks * ByteBlockPool.BYTE_BLOCK_SIZE)) / (Int32BlockPool.INT32_BLOCK_SIZE * RamUsageEstimator.NUM_BYTES_INT32));
+            Debug.Assert((maxBufferedByteBlocks * ByteBlockPool.BYTE_BLOCK_SIZE) + (maxBufferedIntBlocks * Int32BlockPool.INT32_BLOCK_SIZE * RamUsageEstimator.NUM_BYTES_INT32) <= maxReusedBytes);
             byteBlockPool = new ByteBlockPool(new RecyclingByteBlockAllocator(ByteBlockPool.BYTE_BLOCK_SIZE, maxBufferedByteBlocks, bytesUsed));
-            intBlockPool = new Int32BlockPool(new RecyclingInt32BlockAllocator(Int32BlockPool.INT_BLOCK_SIZE, maxBufferedIntBlocks, bytesUsed));
+            intBlockPool = new Int32BlockPool(new RecyclingInt32BlockAllocator(Int32BlockPool.INT32_BLOCK_SIZE, maxBufferedIntBlocks, bytesUsed));
             postingsWriter = new Int32BlockPool.SliceWriter(intBlockPool);
         }
 
@@ -730,9 +730,9 @@ namespace Lucene.Net.Index.Memory
             public override int[] Init()
             {
                 int[] ord = base.Init();
-                start = new int[ArrayUtil.Oversize(ord.Length, RamUsageEstimator.NUM_BYTES_INT)];
-                end = new int[ArrayUtil.Oversize(ord.Length, RamUsageEstimator.NUM_BYTES_INT)];
-                freq = new int[ArrayUtil.Oversize(ord.Length, RamUsageEstimator.NUM_BYTES_INT)];
+                start = new int[ArrayUtil.Oversize(ord.Length, RamUsageEstimator.NUM_BYTES_INT32)];
+                end = new int[ArrayUtil.Oversize(ord.Length, RamUsageEstimator.NUM_BYTES_INT32)];
+                freq = new int[ArrayUtil.Oversize(ord.Length, RamUsageEstimator.NUM_BYTES_INT32)];
                 Debug.Assert(start.Length >= ord.Length);
                 Debug.Assert(end.Length >= ord.Length);
                 Debug.Assert(freq.Length >= ord.Length);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.QueryParser/Flexible/Standard/Builders/NumericRangeQueryNodeBuilder.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.QueryParser/Flexible/Standard/Builders/NumericRangeQueryNodeBuilder.cs b/src/Lucene.Net.QueryParser/Flexible/Standard/Builders/NumericRangeQueryNodeBuilder.cs
index dffcd8b..ae8197a 100644
--- a/src/Lucene.Net.QueryParser/Flexible/Standard/Builders/NumericRangeQueryNodeBuilder.cs
+++ b/src/Lucene.Net.QueryParser/Flexible/Standard/Builders/NumericRangeQueryNodeBuilder.cs
@@ -63,16 +63,16 @@ namespace Lucene.Net.QueryParsers.Flexible.Standard.Builders
 
             switch (numberType)
             {
-                case NumericType.LONG:
+                case NumericType.INT64:
                     return NumericRangeQuery.NewInt64Range(field, precisionStep,
                         (long?)lowerNumber, (long?)upperNumber, minInclusive, maxInclusive);
 
-                case NumericType.INT:
+                case NumericType.INT32:
                     return NumericRangeQuery.NewInt32Range(field, precisionStep,
                         (int?)lowerNumber, (int?)upperNumber, minInclusive,
                         maxInclusive);
 
-                case NumericType.FLOAT:
+                case NumericType.SINGLE:
                     return NumericRangeQuery.NewSingleRange(field, precisionStep,
                         (float?)lowerNumber, (float?)upperNumber, minInclusive,
                         maxInclusive);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.QueryParser/Flexible/Standard/Nodes/NumericRangeQueryNode.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.QueryParser/Flexible/Standard/Nodes/NumericRangeQueryNode.cs b/src/Lucene.Net.QueryParser/Flexible/Standard/Nodes/NumericRangeQueryNode.cs
index a6f161c..8c2d2bb 100644
--- a/src/Lucene.Net.QueryParser/Flexible/Standard/Nodes/NumericRangeQueryNode.cs
+++ b/src/Lucene.Net.QueryParser/Flexible/Standard/Nodes/NumericRangeQueryNode.cs
@@ -55,11 +55,11 @@ namespace Lucene.Net.QueryParsers.Flexible.Standard.Nodes
         {
             if (number is long)
             {
-                return NumericType.LONG;
+                return NumericType.INT64;
             }
             else if (number is int)
             {
-                return NumericType.INT;
+                return NumericType.INT32;
             }
             else if (number is double)
             {
@@ -67,7 +67,7 @@ namespace Lucene.Net.QueryParsers.Flexible.Standard.Nodes
             }
             else if (number is float)
             {
-                return NumericType.FLOAT;
+                return NumericType.SINGLE;
             }
             else
             {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.QueryParser/Flexible/Standard/Processors/NumericQueryNodeProcessor.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.QueryParser/Flexible/Standard/Processors/NumericQueryNodeProcessor.cs b/src/Lucene.Net.QueryParser/Flexible/Standard/Processors/NumericQueryNodeProcessor.cs
index 4ab43a3..cb71fac 100644
--- a/src/Lucene.Net.QueryParser/Flexible/Standard/Processors/NumericQueryNodeProcessor.cs
+++ b/src/Lucene.Net.QueryParser/Flexible/Standard/Processors/NumericQueryNodeProcessor.cs
@@ -100,16 +100,16 @@ namespace Lucene.Net.QueryParsers.Flexible.Standard.Processors
 
                                 switch (numericConfig.Type)
                                 {
-                                    case NumericType.LONG:
+                                    case NumericType.INT64:
                                         number = Convert.ToInt64(number);
                                         break;
-                                    case NumericType.INT:
+                                    case NumericType.INT32:
                                         number = Convert.ToInt32(number);
                                         break;
                                     case NumericType.DOUBLE:
                                         number = Convert.ToDouble(number);
                                         break;
-                                    case NumericType.FLOAT:
+                                    case NumericType.SINGLE:
                                         number = Convert.ToSingle(number);
                                         break;
                                 }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.QueryParser/Flexible/Standard/Processors/NumericRangeQueryNodeProcessor.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.QueryParser/Flexible/Standard/Processors/NumericRangeQueryNodeProcessor.cs b/src/Lucene.Net.QueryParser/Flexible/Standard/Processors/NumericRangeQueryNodeProcessor.cs
index 1dcbe51..89dc1ba 100644
--- a/src/Lucene.Net.QueryParser/Flexible/Standard/Processors/NumericRangeQueryNodeProcessor.cs
+++ b/src/Lucene.Net.QueryParser/Flexible/Standard/Processors/NumericRangeQueryNodeProcessor.cs
@@ -114,11 +114,11 @@ namespace Lucene.Net.QueryParsers.Flexible.Standard.Processors
 
                             switch (numericConfig.Type)
                             {
-                                case NumericType.LONG:
+                                case NumericType.INT64:
                                     if (upperNumber != null) upperNumber = Convert.ToInt64(upperNumber);
                                     if (lowerNumber != null) lowerNumber = Convert.ToInt64(lowerNumber);
                                     break;
-                                case NumericType.INT:
+                                case NumericType.INT32:
                                     if (upperNumber != null) upperNumber = Convert.ToInt32(upperNumber);
                                     if (lowerNumber != null) lowerNumber = Convert.ToInt32(lowerNumber);
                                     break;
@@ -126,7 +126,7 @@ namespace Lucene.Net.QueryParsers.Flexible.Standard.Processors
                                     if (upperNumber != null) upperNumber = Convert.ToDouble(upperNumber);
                                     if (lowerNumber != null) lowerNumber = Convert.ToDouble(lowerNumber);
                                     break;
-                                case NumericType.FLOAT:
+                                case NumericType.SINGLE:
                                     if (upperNumber != null) upperNumber = Convert.ToSingle(upperNumber);
                                     if (lowerNumber != null) lowerNumber = Convert.ToSingle(lowerNumber);
                                     break;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Suggest/Suggest/Analyzing/AnalyzingInfixSuggester.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Suggest/Suggest/Analyzing/AnalyzingInfixSuggester.cs b/src/Lucene.Net.Suggest/Suggest/Analyzing/AnalyzingInfixSuggester.cs
index fce571d..27cb7b5 100644
--- a/src/Lucene.Net.Suggest/Suggest/Analyzing/AnalyzingInfixSuggester.cs
+++ b/src/Lucene.Net.Suggest/Suggest/Analyzing/AnalyzingInfixSuggester.cs
@@ -106,7 +106,7 @@ namespace Lucene.Net.Search.Suggest.Analyzing
 
         /// <summary>
         /// How we sort the postings and search results. </summary>
-        private static readonly Sort SORT = new Sort(new SortField("weight", SortFieldType.LONG, true));
+        private static readonly Sort SORT = new Sort(new SortField("weight", SortFieldType.INT64, true));
 
         /// <summary>
         /// Create a new instance, loading from a previously built

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.TestFramework/Index/BaseStoredFieldsFormatTestCase.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.TestFramework/Index/BaseStoredFieldsFormatTestCase.cs b/src/Lucene.Net.TestFramework/Index/BaseStoredFieldsFormatTestCase.cs
index 30ee047..4b831fb 100644
--- a/src/Lucene.Net.TestFramework/Index/BaseStoredFieldsFormatTestCase.cs
+++ b/src/Lucene.Net.TestFramework/Index/BaseStoredFieldsFormatTestCase.cs
@@ -286,7 +286,7 @@ namespace Lucene.Net.Index
                         answer = Convert.ToSingle(f);
                         nf = new SingleField("nf", f, Field.Store.NO);
                         sf = new StoredField("nf", f);
-                        typeAnswer = NumericType.FLOAT;
+                        typeAnswer = NumericType.SINGLE;
                     }
                     else
                     {
@@ -306,7 +306,7 @@ namespace Lucene.Net.Index
                         answer = Convert.ToInt32(i);
                         nf = new Int32Field("nf", i, Field.Store.NO);
                         sf = new StoredField("nf", i);
-                        typeAnswer = NumericType.INT;
+                        typeAnswer = NumericType.INT32;
                     }
                     else
                     {
@@ -314,7 +314,7 @@ namespace Lucene.Net.Index
                         answer = Convert.ToInt64(l);
                         nf = new Int64Field("nf", l, Field.Store.NO);
                         sf = new StoredField("nf", l);
-                        typeAnswer = NumericType.LONG;
+                        typeAnswer = NumericType.INT64;
                     }
                 }
                 doc.Add(nf);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.TestFramework/Util/ApiScanTestBase.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.TestFramework/Util/ApiScanTestBase.cs b/src/Lucene.Net.TestFramework/Util/ApiScanTestBase.cs
index 2889000..3eac4f1 100644
--- a/src/Lucene.Net.TestFramework/Util/ApiScanTestBase.cs
+++ b/src/Lucene.Net.TestFramework/Util/ApiScanTestBase.cs
@@ -58,6 +58,11 @@ namespace Lucene.Net.Util
         private static Regex ContainsNonNetNumeric = new Regex("(?<![Pp]o|[Pp]r|[Jj]o)[Ii]nt(?!16|32|64|er|eg|ro)|[Ll]ong(?!est|er)|[Ss]hort(?!est|er)|[Ff]loat", RegexOptions.Compiled);
 
         /// <summary>
+        /// Constants should not contain the word INT that is not followed by 16, 32, or 64, LONG, SHORT, or FLOAT
+        /// </summary>
+        private static Regex ConstContainsNonNetNumeric = new Regex("(?<!PO|PR|JO)INT(?!16|32|64|ER|EG|RO)|LONG(?!EST|ER)|SHORT(?!EST|ER)|FLOAT", RegexOptions.Compiled);
+
+        /// <summary>
         /// Matches IL code pattern for a method body with only a return statement for a local variable.
         /// In this case, the array is writable by the consumer.
         /// </summary>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.TestFramework/Util/TestUtil.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.TestFramework/Util/TestUtil.cs b/src/Lucene.Net.TestFramework/Util/TestUtil.cs
index 7fee1f9..ee6cf6f 100644
--- a/src/Lucene.Net.TestFramework/Util/TestUtil.cs
+++ b/src/Lucene.Net.TestFramework/Util/TestUtil.cs
@@ -1058,15 +1058,15 @@ namespace Lucene.Net.Util
                 {
                     switch (numType)
                     {
-                        case NumericType.INT:
+                        case NumericType.INT32:
                             field2 = new Int32Field(field1.Name, (int)field1.GetNumericValue(), (FieldType)field1.FieldType);
                             break;
 
-                        case NumericType.FLOAT:
+                        case NumericType.SINGLE:
                             field2 = new SingleField(field1.Name, (int)field1.GetNumericValue(), (FieldType)field1.FieldType);
                             break;
 
-                        case NumericType.LONG:
+                        case NumericType.INT64:
                             field2 = new Int64Field(field1.Name, (int)field1.GetNumericValue(), (FieldType)field1.FieldType);
                             break;
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Tests.Expressions/TestDemoExpressions.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests.Expressions/TestDemoExpressions.cs b/src/Lucene.Net.Tests.Expressions/TestDemoExpressions.cs
index a1864e6..4d6a51a 100644
--- a/src/Lucene.Net.Tests.Expressions/TestDemoExpressions.cs
+++ b/src/Lucene.Net.Tests.Expressions/TestDemoExpressions.cs
@@ -76,7 +76,7 @@ namespace Lucene.Net.Tests.Expressions
 			// we use SimpleBindings: which just maps variables to SortField instances
 			SimpleBindings bindings = new SimpleBindings();
 			bindings.Add(new SortField("_score", SortFieldType.SCORE));
-			bindings.Add(new SortField("popularity", SortFieldType.INT));
+			bindings.Add(new SortField("popularity", SortFieldType.INT32));
 			// create a sort field and sort by it (reverse order)
 			Sort sort = new Sort(expr.GetSortField(bindings, true));
 			Query query = new TermQuery(new Term("body", "contents"));

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Tests.Expressions/TestExpressionRescorer.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests.Expressions/TestExpressionRescorer.cs b/src/Lucene.Net.Tests.Expressions/TestExpressionRescorer.cs
index 91b046a..1899640 100644
--- a/src/Lucene.Net.Tests.Expressions/TestExpressionRescorer.cs
+++ b/src/Lucene.Net.Tests.Expressions/TestExpressionRescorer.cs
@@ -72,7 +72,7 @@ namespace Lucene.Net.Tests.Expressions
 			// Now, rescore:
 			Expression e = JavascriptCompiler.Compile("sqrt(_score) + ln(popularity)");
 			SimpleBindings bindings = new SimpleBindings();
-			bindings.Add(new SortField("popularity", SortFieldType.INT));
+			bindings.Add(new SortField("popularity", SortFieldType.INT32));
 			bindings.Add(new SortField("_score", SortFieldType.SCORE));
 			Rescorer rescorer = e.GetRescorer(bindings);
 			hits = rescorer.Rescore(searcher, hits, 10);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Tests.Expressions/TestExpressionSortField.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests.Expressions/TestExpressionSortField.cs b/src/Lucene.Net.Tests.Expressions/TestExpressionSortField.cs
index 062047e..985e843 100644
--- a/src/Lucene.Net.Tests.Expressions/TestExpressionSortField.cs
+++ b/src/Lucene.Net.Tests.Expressions/TestExpressionSortField.cs
@@ -13,7 +13,7 @@ namespace Lucene.Net.Tests.Expressions
 			Expression expr = JavascriptCompiler.Compile("sqrt(_score) + ln(popularity)");
 			SimpleBindings bindings = new SimpleBindings();
 			bindings.Add(new SortField("_score", SortFieldType.SCORE));
-			bindings.Add(new SortField("popularity", SortFieldType.INT));
+			bindings.Add(new SortField("popularity", SortFieldType.INT32));
 			SortField sf = expr.GetSortField(bindings, true);
 			AreEqual("<expr \"sqrt(_score) + ln(popularity)\">!", sf.ToString());
 		}
@@ -24,10 +24,10 @@ namespace Lucene.Net.Tests.Expressions
 			Expression expr = JavascriptCompiler.Compile("sqrt(_score) + ln(popularity)");
 			SimpleBindings bindings = new SimpleBindings();
 			bindings.Add(new SortField("_score", SortFieldType.SCORE));
-			bindings.Add(new SortField("popularity", SortFieldType.INT));
+			bindings.Add(new SortField("popularity", SortFieldType.INT32));
 			SimpleBindings otherBindings = new SimpleBindings();
-			otherBindings.Add(new SortField("_score", SortFieldType.LONG));
-			otherBindings.Add(new SortField("popularity", SortFieldType.INT));
+			otherBindings.Add(new SortField("_score", SortFieldType.INT64));
+			otherBindings.Add(new SortField("popularity", SortFieldType.INT32));
 			SortField sf1 = expr.GetSortField(bindings, true);
 			// different order
 			SortField sf2 = expr.GetSortField(bindings, false);
@@ -68,7 +68,7 @@ namespace Lucene.Net.Tests.Expressions
 			// several variables
 			Expression exprI = JavascriptCompiler.Compile("b / c + e * g");
 			bindings.Add(new SortField("_score", SortFieldType.SCORE));
-			bindings.Add(new SortField("intfield", SortFieldType.INT));
+			bindings.Add(new SortField("intfield", SortFieldType.INT32));
 			bindings.Add("a", exprA);
 			bindings.Add("b", exprB);
 			bindings.Add("c", exprC);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Tests.Expressions/TestExpressionSorts.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests.Expressions/TestExpressionSorts.cs b/src/Lucene.Net.Tests.Expressions/TestExpressionSorts.cs
index dcf6cd6..4852778 100644
--- a/src/Lucene.Net.Tests.Expressions/TestExpressionSorts.cs
+++ b/src/Lucene.Net.Tests.Expressions/TestExpressionSorts.cs
@@ -96,11 +96,11 @@ namespace Lucene.Net.Tests.Expressions
             {
                 bool reversed = Random().NextBoolean();
                 SortField[] fields =
-				{ new SortField("int", SortFieldType.INT, reversed
-				    ), new SortField("long", SortFieldType.LONG, reversed), new SortField("float", 
-				        SortFieldType.FLOAT, reversed), new SortField("double", SortFieldType.DOUBLE, 
-				            reversed), new SortField("intdocvalues", SortFieldType.INT, reversed), new SortField
-				                ("floatdocvalues", SortFieldType.FLOAT, reversed), new SortField("score", SortFieldType.SCORE) };
+				{ new SortField("int", SortFieldType.INT32, reversed
+				    ), new SortField("long", SortFieldType.INT64, reversed), new SortField("float", 
+				        SortFieldType.SINGLE, reversed), new SortField("double", SortFieldType.DOUBLE, 
+				            reversed), new SortField("intdocvalues", SortFieldType.INT32, reversed), new SortField
+				                ("floatdocvalues", SortFieldType.SINGLE, reversed), new SortField("score", SortFieldType.SCORE) };
                 //TODO: Add Shuffle extension
                 //Collections.Shuffle(Arrays.AsList(fields), Random());
                 int numSorts = TestUtil.NextInt(Random(), 1, fields.Length);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Tests.Expressions/TestExpressionValidation.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests.Expressions/TestExpressionValidation.cs b/src/Lucene.Net.Tests.Expressions/TestExpressionValidation.cs
index 14d0539..9912128 100644
--- a/src/Lucene.Net.Tests.Expressions/TestExpressionValidation.cs
+++ b/src/Lucene.Net.Tests.Expressions/TestExpressionValidation.cs
@@ -13,9 +13,9 @@ namespace Lucene.Net.Tests.Expressions
 		public virtual void TestValidExternals()
 		{
 			SimpleBindings bindings = new SimpleBindings();
-			bindings.Add(new SortField("valid0", SortFieldType.INT));
-			bindings.Add(new SortField("valid1", SortFieldType.INT));
-			bindings.Add(new SortField("valid2", SortFieldType.INT));
+			bindings.Add(new SortField("valid0", SortFieldType.INT32));
+			bindings.Add(new SortField("valid1", SortFieldType.INT32));
+			bindings.Add(new SortField("valid2", SortFieldType.INT32));
 			bindings.Add(new SortField("_score", SortFieldType.SCORE));
 			bindings.Add("valide0", JavascriptCompiler.Compile("valid0 - valid1 + valid2 + _score"
 				));
@@ -30,7 +30,7 @@ namespace Lucene.Net.Tests.Expressions
 		public virtual void TestInvalidExternal()
 		{
 			SimpleBindings bindings = new SimpleBindings();
-			bindings.Add(new SortField("valid", SortFieldType.INT));
+			bindings.Add(new SortField("valid", SortFieldType.INT32));
 			bindings.Add("invalid", JavascriptCompiler.Compile("badreference"));
 			try
 			{
@@ -47,7 +47,7 @@ namespace Lucene.Net.Tests.Expressions
 		public virtual void TestInvalidExternal2()
 		{
 			SimpleBindings bindings = new SimpleBindings();
-			bindings.Add(new SortField("valid", SortFieldType.INT));
+			bindings.Add(new SortField("valid", SortFieldType.INT32));
 			bindings.Add("invalid", JavascriptCompiler.Compile("valid + badreference"));
 			try
 			{

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Tests.Expressions/TestExpressionValueSource.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests.Expressions/TestExpressionValueSource.cs b/src/Lucene.Net.Tests.Expressions/TestExpressionValueSource.cs
index a088eae..cc1b9b4 100644
--- a/src/Lucene.Net.Tests.Expressions/TestExpressionValueSource.cs
+++ b/src/Lucene.Net.Tests.Expressions/TestExpressionValueSource.cs
@@ -66,7 +66,7 @@ namespace Lucene.Net.Tests.Expressions
 		{
 			Expression expr = JavascriptCompiler.Compile("2*popularity");
 			SimpleBindings bindings = new SimpleBindings();
-			bindings.Add(new SortField("popularity", SortFieldType.LONG));
+			bindings.Add(new SortField("popularity", SortFieldType.INT64));
 			ValueSource vs = expr.GetValueSource(bindings);
 			AreEqual(1, reader.Leaves.Count);
 			AtomicReaderContext leaf = reader.Leaves[0];
@@ -102,7 +102,7 @@ namespace Lucene.Net.Tests.Expressions
 		{
 			Expression expr = JavascriptCompiler.Compile("2*popularity");
 			SimpleBindings bindings = new SimpleBindings();
-			bindings.Add(new SortField("popularity", SortFieldType.LONG));
+			bindings.Add(new SortField("popularity", SortFieldType.INT64));
 			ValueSource vs = expr.GetValueSource(bindings);
 			AreEqual(1, reader.Leaves.Count);
 			AtomicReaderContext leaf = reader.Leaves[0];
@@ -127,8 +127,8 @@ namespace Lucene.Net.Tests.Expressions
 		{
 			Expression expr = JavascriptCompiler.Compile("sqrt(a) + ln(b)");
 			SimpleBindings bindings = new SimpleBindings();
-			bindings.Add(new SortField("a", SortFieldType.INT));
-			bindings.Add(new SortField("b", SortFieldType.INT));
+			bindings.Add(new SortField("a", SortFieldType.INT32));
+			bindings.Add(new SortField("b", SortFieldType.INT32));
 			ValueSource vs1 = expr.GetValueSource(bindings);
 			// same instance
 			AreEqual(vs1, vs1);
@@ -142,14 +142,14 @@ namespace Lucene.Net.Tests.Expressions
 			AreEqual(vs1, vs2);
 			// equiv bindings (different instance)
 			SimpleBindings bindings2 = new SimpleBindings();
-			bindings2.Add(new SortField("a", SortFieldType.INT));
-			bindings2.Add(new SortField("b", SortFieldType.INT));
+			bindings2.Add(new SortField("a", SortFieldType.INT32));
+			bindings2.Add(new SortField("b", SortFieldType.INT32));
 			ValueSource vs3 = expr.GetValueSource(bindings2);
 			AreEqual(vs1, vs3);
 			// different bindings (same names, different types)
 			SimpleBindings bindings3 = new SimpleBindings();
-			bindings3.Add(new SortField("a", SortFieldType.LONG));
-			bindings3.Add(new SortField("b", SortFieldType.INT));
+			bindings3.Add(new SortField("a", SortFieldType.INT64));
+			bindings3.Add(new SortField("b", SortFieldType.INT32));
 			ValueSource vs4 = expr.GetValueSource(bindings3);
 			IsFalse(vs1.Equals(vs4));
 		}

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Tests.Facet/TestDrillSideways.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests.Facet/TestDrillSideways.cs b/src/Lucene.Net.Tests.Facet/TestDrillSideways.cs
index f090be7..0d3d0ab 100644
--- a/src/Lucene.Net.Tests.Facet/TestDrillSideways.cs
+++ b/src/Lucene.Net.Tests.Facet/TestDrillSideways.cs
@@ -1315,7 +1315,7 @@ namespace Lucene.Net.Facet
             DrillSidewaysResult r = ds.Search(ddq, 10); // this used to fail on IllegalArgEx
             Assert.AreEqual(0, r.Hits.TotalHits);
 
-            r = ds.Search(ddq, null, null, 10, new Sort(new SortField("foo", SortFieldType.INT)), false, false); // this used to fail on IllegalArgEx
+            r = ds.Search(ddq, null, null, 10, new Sort(new SortField("foo", SortFieldType.INT32)), false, false); // this used to fail on IllegalArgEx
             Assert.AreEqual(0, r.Hits.TotalHits);
 
             IOUtils.Close(writer, taxoWriter, searcher.IndexReader, taxoReader, dir, taxoDir);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Tests.Grouping/AllGroupHeadsCollectorTest.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests.Grouping/AllGroupHeadsCollectorTest.cs b/src/Lucene.Net.Tests.Grouping/AllGroupHeadsCollectorTest.cs
index 4008b34..5daab0c 100644
--- a/src/Lucene.Net.Tests.Grouping/AllGroupHeadsCollectorTest.cs
+++ b/src/Lucene.Net.Tests.Grouping/AllGroupHeadsCollectorTest.cs
@@ -123,7 +123,7 @@ namespace Lucene.Net.Search.Grouping
             w.Dispose();
             int maxDoc = reader.MaxDoc;
 
-            Sort sortWithinGroup = new Sort(new SortField("id_1", SortFieldType.INT, true));
+            Sort sortWithinGroup = new Sort(new SortField("id_1", SortFieldType.INT32, true));
             var allGroupHeadsCollector = CreateRandomCollector(groupField, sortWithinGroup, canUseIDV, valueType);
             indexSearcher.Search(new TermQuery(new Term("content", "random")), allGroupHeadsCollector);
             assertTrue(ArrayContains(new int[] { 2, 3, 5, 7 }, allGroupHeadsCollector.RetrieveGroupHeads()));
@@ -549,7 +549,7 @@ namespace Lucene.Net.Search.Grouping
             }
             else if (!scoreOnly)
             {
-                sortFields.Add(new SortField("id", SortFieldType.INT));
+                sortFields.Add(new SortField("id", SortFieldType.INT32));
             }
             return new Sort(sortFields.ToArray(/*new SortField[sortFields.size()]*/));
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Tests.Grouping/TestGrouping.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests.Grouping/TestGrouping.cs b/src/Lucene.Net.Tests.Grouping/TestGrouping.cs
index 6345b13..7be434f 100644
--- a/src/Lucene.Net.Tests.Grouping/TestGrouping.cs
+++ b/src/Lucene.Net.Tests.Grouping/TestGrouping.cs
@@ -406,7 +406,7 @@ namespace Lucene.Net.Search.Grouping
                 }
             }
             // Break ties:
-            sortFields.Add(new SortField("id", SortFieldType.INT));
+            sortFields.Add(new SortField("id", SortFieldType.INT32));
             return new Sort(sortFields.ToArray(/*new SortField[sortFields.size()]*/));
         }
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Tests.Join/TestBlockJoin.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests.Join/TestBlockJoin.cs b/src/Lucene.Net.Tests.Join/TestBlockJoin.cs
index 24c00b9..c28b350 100644
--- a/src/Lucene.Net.Tests.Join/TestBlockJoin.cs
+++ b/src/Lucene.Net.Tests.Join/TestBlockJoin.cs
@@ -495,7 +495,7 @@ namespace Lucene.Net.Tests.Join
                 sortFields.Add(new SortField(prefix + Random().Next(numFields), SortFieldType.STRING, Random().NextBoolean()));
             }
             // Break ties:
-            sortFields.Add(new SortField(prefix + "ID", SortFieldType.INT));
+            sortFields.Add(new SortField(prefix + "ID", SortFieldType.INT32));
             return new Sort(sortFields.ToArray());
         }
 


[37/53] [abbrv] lucenenet git commit: Lucene.Net.Queries: Renamed all type-derived classes and interfaces from Short, Int, Long, and Float to match CLR types Int16, Int32, Int64, and Single, respectively.

Posted by ni...@apache.org.
Lucene.Net.Queries: Renamed all type-derived classes and interfaces from Short, Int, Long, and Float to match CLR types Int16, Int32, Int64, and Single, respectively.


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

Branch: refs/heads/api-work
Commit: 883ad7f4765881702dc009d606f71da8e5d01aa8
Parents: 89e3de6
Author: Shad Storhaug <sh...@shadstorhaug.com>
Authored: Wed Feb 8 03:24:41 2017 +0700
Committer: Shad Storhaug <sh...@shadstorhaug.com>
Committed: Wed Feb 8 21:08:23 2017 +0700

----------------------------------------------------------------------
 src/Lucene.Net.Expressions/SimpleBindings.cs    |  6 ++--
 .../Range/DoubleRangeFacetCounts.cs             |  2 +-
 .../Range/LongRangeFacetCounts.cs               |  6 ++--
 .../Function/DocValues/FloatDocValues.cs        | 10 ++++---
 .../Function/DocValues/IntDocValues.cs          | 14 +++++----
 .../Function/DocValues/LongDocValues.cs         | 14 +++++----
 .../Function/ValueSources/ConstValueSource.cs   |  6 ++--
 .../Function/ValueSources/DivFloatFunction.cs   |  6 ++--
 .../Function/ValueSources/DocFreqValueSource.cs |  9 ++++--
 .../Function/ValueSources/DualFloatFunction.cs  | 16 ++++++-----
 .../Function/ValueSources/EnumFieldSource.cs    | 14 ++++-----
 .../Function/ValueSources/FloatFieldSource.cs   | 20 +++++++------
 .../Function/ValueSources/IntFieldSource.cs     | 22 +++++++-------
 .../ValueSources/JoinDocFreqValueSource.cs      |  6 ++--
 .../ValueSources/LinearFloatFunction.cs         | 18 ++++++------
 .../Function/ValueSources/LongFieldSource.cs    | 22 +++++++-------
 .../Function/ValueSources/MaxDocValueSource.cs  |  2 +-
 .../Function/ValueSources/MaxFloatFunction.cs   |  8 ++++--
 .../Function/ValueSources/MinFloatFunction.cs   |  8 ++++--
 .../Function/ValueSources/MultiFloatFunction.cs | 16 ++++++-----
 .../Function/ValueSources/NormValueSource.cs    |  6 ++--
 .../Function/ValueSources/NumDocsValueSource.cs |  2 +-
 .../Function/ValueSources/OrdFieldSource.cs     | 10 +++----
 .../Function/ValueSources/PowFloatFunction.cs   |  6 ++--
 .../ValueSources/ProductFloatFunction.cs        |  8 ++++--
 .../Function/ValueSources/QueryValueSource.cs   |  2 +-
 .../ValueSources/RangeMapFloatFunction.cs       | 22 +++++++-------
 .../ValueSources/ReciprocalFloatFunction.cs     | 20 +++++++------
 .../ValueSources/ReverseOrdFieldSource.cs       |  6 ++--
 .../Function/ValueSources/ScaleFloatFunction.cs | 16 ++++++-----
 .../Function/ValueSources/ShortFieldSource.cs   | 16 ++++++-----
 .../ValueSources/SimpleFloatFunction.cs         | 14 +++++----
 .../Function/ValueSources/SingleFunction.cs     |  2 +-
 .../Function/ValueSources/SumFloatFunction.cs   |  8 ++++--
 .../ValueSources/SumTotalTermFreqValueSource.cs |  6 ++--
 .../Function/ValueSources/TFValueSource.cs      | 10 +++----
 .../ValueSources/TermFreqValueSource.cs         | 10 +++----
 .../ValueSources/TotalTermFreqValueSource.cs    |  6 ++--
 src/Lucene.Net.Queries/Mlt/MoreLikeThis.cs      | 26 +++++++++--------
 src/Lucene.Net.Spatial/SpatialStrategy.cs       |  2 +-
 .../Range/TestRangeFacetCounts.cs               | 10 +++----
 .../Taxonomy/TestTaxonomyFacetSumValueSource.cs | 20 ++++++-------
 .../Function/FunctionTestSetup.cs               |  8 +++---
 .../Function/TestDocValuesFieldSources.cs       |  6 ++--
 .../Function/TestFunctionQuerySort.cs           |  2 +-
 .../Function/TestValueSources.cs                | 30 ++++++++++----------
 .../DocumentValueSourceDictionaryTest.cs        | 16 +++++------
 47 files changed, 280 insertions(+), 235 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/lucenenet/blob/883ad7f4/src/Lucene.Net.Expressions/SimpleBindings.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Expressions/SimpleBindings.cs b/src/Lucene.Net.Expressions/SimpleBindings.cs
index dd8747e..89c121b 100644
--- a/src/Lucene.Net.Expressions/SimpleBindings.cs
+++ b/src/Lucene.Net.Expressions/SimpleBindings.cs
@@ -92,17 +92,17 @@ namespace Lucene.Net.Expressions
             {
                 case SortFieldType.INT:
                     {
-                        return new IntFieldSource(field.Field, (FieldCache.IInt32Parser)field.Parser);
+                        return new Int32FieldSource(field.Field, (FieldCache.IInt32Parser)field.Parser);
                     }
 
                 case SortFieldType.LONG:
                     {
-                        return new LongFieldSource(field.Field, (FieldCache.IInt64Parser)field.Parser);
+                        return new Int64FieldSource(field.Field, (FieldCache.IInt64Parser)field.Parser);
                     }
 
                 case SortFieldType.FLOAT:
                     {
-                        return new FloatFieldSource(field.Field, (FieldCache.ISingleParser)field.Parser);
+                        return new SingleFieldSource(field.Field, (FieldCache.ISingleParser)field.Parser);
                     }
 
                 case SortFieldType.DOUBLE:

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/883ad7f4/src/Lucene.Net.Facet/Range/DoubleRangeFacetCounts.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Facet/Range/DoubleRangeFacetCounts.cs b/src/Lucene.Net.Facet/Range/DoubleRangeFacetCounts.cs
index efcfbcf..c15eb0d 100644
--- a/src/Lucene.Net.Facet/Range/DoubleRangeFacetCounts.cs
+++ b/src/Lucene.Net.Facet/Range/DoubleRangeFacetCounts.cs
@@ -40,7 +40,7 @@ namespace Lucene.Net.Facet.Range
     ///  etc.).
     /// 
     ///  <para> If you had indexed your field using <see cref="Documents.SingleDocValuesField"/> 
-    ///  then pass <see cref="Queries.Function.ValueSources.FloatFieldSource"/>
+    ///  then pass <see cref="Queries.Function.ValueSources.SingleFieldSource"/>
     ///  as the <see cref="ValueSource"/>; if you used 
     ///  <see cref="Documents.DoubleDocValuesField"/> then pass 
     ///  <see cref="DoubleFieldSource"/> (this is the default used when you

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/883ad7f4/src/Lucene.Net.Facet/Range/LongRangeFacetCounts.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Facet/Range/LongRangeFacetCounts.cs b/src/Lucene.Net.Facet/Range/LongRangeFacetCounts.cs
index 4f80fba..7cebc9d 100644
--- a/src/Lucene.Net.Facet/Range/LongRangeFacetCounts.cs
+++ b/src/Lucene.Net.Facet/Range/LongRangeFacetCounts.cs
@@ -24,7 +24,7 @@ namespace Lucene.Net.Facet.Range
     using DocIdSetIterator = Lucene.Net.Search.DocIdSetIterator;
     using Filter = Lucene.Net.Search.Filter;
     using FunctionValues = Lucene.Net.Queries.Function.FunctionValues;
-    using LongFieldSource = Lucene.Net.Queries.Function.ValueSources.LongFieldSource;
+    using Int64FieldSource = Lucene.Net.Queries.Function.ValueSources.Int64FieldSource;
     using MatchingDocs = FacetsCollector.MatchingDocs;
     using ValueSource = Lucene.Net.Queries.Function.ValueSource;
 
@@ -46,10 +46,10 @@ namespace Lucene.Net.Facet.Range
     {
         /// <summary>
         /// Create <see cref="Int64RangeFacetCounts"/>, using
-        /// <see cref="LongFieldSource"/> from the specified field. 
+        /// <see cref="Int64FieldSource"/> from the specified field. 
         /// </summary>
         public Int64RangeFacetCounts(string field, FacetsCollector hits, params Int64Range[] ranges)
-            : this(field, new LongFieldSource(field), hits, ranges)
+            : this(field, new Int64FieldSource(field), hits, ranges)
         {
         }
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/883ad7f4/src/Lucene.Net.Queries/Function/DocValues/FloatDocValues.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/DocValues/FloatDocValues.cs b/src/Lucene.Net.Queries/Function/DocValues/FloatDocValues.cs
index 4991266..91d0b9a 100644
--- a/src/Lucene.Net.Queries/Function/DocValues/FloatDocValues.cs
+++ b/src/Lucene.Net.Queries/Function/DocValues/FloatDocValues.cs
@@ -23,12 +23,14 @@ namespace Lucene.Net.Queries.Function.DocValues
     /// <summary>
     /// Abstract <see cref="FunctionValues"/> implementation which supports retrieving <see cref="float"/> values.
     /// Implementations can control how the <see cref="float"/> values are loaded through <see cref="SingleVal(int)"/>
+    /// <para/>
+    /// NOTE: This was FloatDocValues in Lucene
     /// </summary>
-    public abstract class FloatDocValues : FunctionValues
+    public abstract class SingleDocValues : FunctionValues
     {
         protected readonly ValueSource m_vs;
 
-        public FloatDocValues(ValueSource vs)
+        public SingleDocValues(ValueSource vs)
         {
             this.m_vs = vs;
         }
@@ -94,9 +96,9 @@ namespace Lucene.Net.Queries.Function.DocValues
 
         private class ValueFillerAnonymousInnerClassHelper : ValueFiller
         {
-            private readonly FloatDocValues outerInstance;
+            private readonly SingleDocValues outerInstance;
 
-            public ValueFillerAnonymousInnerClassHelper(FloatDocValues outerInstance)
+            public ValueFillerAnonymousInnerClassHelper(SingleDocValues outerInstance)
             {
                 this.outerInstance = outerInstance;
                 mval = new MutableValueSingle();

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/883ad7f4/src/Lucene.Net.Queries/Function/DocValues/IntDocValues.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/DocValues/IntDocValues.cs b/src/Lucene.Net.Queries/Function/DocValues/IntDocValues.cs
index 2173e8c..01f66f0 100644
--- a/src/Lucene.Net.Queries/Function/DocValues/IntDocValues.cs
+++ b/src/Lucene.Net.Queries/Function/DocValues/IntDocValues.cs
@@ -24,12 +24,14 @@ namespace Lucene.Net.Queries.Function.DocValues
     /// <summary>
     /// Abstract <see cref="FunctionValues"/> implementation which supports retrieving <see cref="int"/> values.
     /// Implementations can control how the <see cref="int"/> values are loaded through <see cref="Int32Val(int)"/>
+    /// <para/>
+    /// NOTE: This was IntDocValues in Lucene
     /// </summary>
-    public abstract class IntDocValues : FunctionValues
+    public abstract class Int32DocValues : FunctionValues
     {
         protected readonly ValueSource m_vs;
 
-        public IntDocValues(ValueSource vs)
+        public Int32DocValues(ValueSource vs)
         {
             this.m_vs = vs;
         }
@@ -128,12 +130,12 @@ namespace Lucene.Net.Queries.Function.DocValues
 
         private class ValueSourceScorerAnonymousInnerClassHelper : ValueSourceScorer
         {
-            private readonly IntDocValues outerInstance;
+            private readonly Int32DocValues outerInstance;
 
             private int ll;
             private int uu;
 
-            public ValueSourceScorerAnonymousInnerClassHelper(IntDocValues outerInstance, IndexReader reader, IntDocValues @this, int ll, int uu)
+            public ValueSourceScorerAnonymousInnerClassHelper(Int32DocValues outerInstance, IndexReader reader, Int32DocValues @this, int ll, int uu)
                 : base(reader, @this)
             {
                 this.outerInstance = outerInstance;
@@ -157,9 +159,9 @@ namespace Lucene.Net.Queries.Function.DocValues
 
         private class ValueFillerAnonymousInnerClassHelper : ValueFiller
         {
-            private readonly IntDocValues outerInstance;
+            private readonly Int32DocValues outerInstance;
 
-            public ValueFillerAnonymousInnerClassHelper(IntDocValues outerInstance)
+            public ValueFillerAnonymousInnerClassHelper(Int32DocValues outerInstance)
             {
                 this.outerInstance = outerInstance;
                 mval = new MutableValueInt32();

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/883ad7f4/src/Lucene.Net.Queries/Function/DocValues/LongDocValues.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/DocValues/LongDocValues.cs b/src/Lucene.Net.Queries/Function/DocValues/LongDocValues.cs
index afc059e..f779a60 100644
--- a/src/Lucene.Net.Queries/Function/DocValues/LongDocValues.cs
+++ b/src/Lucene.Net.Queries/Function/DocValues/LongDocValues.cs
@@ -24,12 +24,14 @@ namespace Lucene.Net.Queries.Function.DocValues
     /// <summary>
     /// Abstract <see cref="FunctionValues"/> implementation which supports retrieving <see cref="long"/> values.
     /// Implementations can control how the <see cref="long"/> values are loaded through <see cref="Int64Val(int)"/>
+    /// <para/>
+    /// NOTE: This was LongDocValues in Lucene
     /// </summary>
-    public abstract class LongDocValues : FunctionValues
+    public abstract class Int64DocValues : FunctionValues
     {
         protected readonly ValueSource m_vs;
 
-        public LongDocValues(ValueSource vs)
+        public Int64DocValues(ValueSource vs)
         {
             this.m_vs = vs;
         }
@@ -138,12 +140,12 @@ namespace Lucene.Net.Queries.Function.DocValues
 
         private class ValueSourceScorerAnonymousInnerClassHelper : ValueSourceScorer
         {
-            private readonly LongDocValues outerInstance;
+            private readonly Int64DocValues outerInstance;
 
             private readonly long ll;
             private readonly long uu;
 
-            public ValueSourceScorerAnonymousInnerClassHelper(LongDocValues outerInstance, IndexReader reader, LongDocValues @this, long ll, long uu)
+            public ValueSourceScorerAnonymousInnerClassHelper(Int64DocValues outerInstance, IndexReader reader, Int64DocValues @this, long ll, long uu)
                 : base(reader, @this)
             {
                 this.outerInstance = outerInstance;
@@ -167,9 +169,9 @@ namespace Lucene.Net.Queries.Function.DocValues
 
         private class ValueFillerAnonymousInnerClassHelper : ValueFiller
         {
-            private readonly LongDocValues outerInstance;
+            private readonly Int64DocValues outerInstance;
 
-            public ValueFillerAnonymousInnerClassHelper(LongDocValues outerInstance)
+            public ValueFillerAnonymousInnerClassHelper(Int64DocValues outerInstance)
             {
                 this.outerInstance = outerInstance;
                 mval = new MutableValueInt64();

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/883ad7f4/src/Lucene.Net.Queries/Function/ValueSources/ConstValueSource.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/ConstValueSource.cs b/src/Lucene.Net.Queries/Function/ValueSources/ConstValueSource.cs
index a9bd1b5..884adf2 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/ConstValueSource.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/ConstValueSource.cs
@@ -43,14 +43,14 @@ namespace Lucene.Net.Queries.Function.ValueSources
 
         public override FunctionValues GetValues(IDictionary context, AtomicReaderContext readerContext)
         {
-            return new FloatDocValuesAnonymousInnerClassHelper(this, this);
+            return new SingleDocValuesAnonymousInnerClassHelper(this, this);
         }
 
-        private class FloatDocValuesAnonymousInnerClassHelper : FloatDocValues
+        private class SingleDocValuesAnonymousInnerClassHelper : SingleDocValues
         {
             private readonly ConstValueSource outerInstance;
 
-            public FloatDocValuesAnonymousInnerClassHelper(ConstValueSource outerInstance, ConstValueSource @this)
+            public SingleDocValuesAnonymousInnerClassHelper(ConstValueSource outerInstance, ConstValueSource @this)
                 : base(@this)
             {
                 this.outerInstance = outerInstance;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/883ad7f4/src/Lucene.Net.Queries/Function/ValueSources/DivFloatFunction.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/DivFloatFunction.cs b/src/Lucene.Net.Queries/Function/ValueSources/DivFloatFunction.cs
index 1ee5d96..d902ec2 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/DivFloatFunction.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/DivFloatFunction.cs
@@ -19,12 +19,14 @@
 
     /// <summary>
     /// Function to divide "a" by "b"
+    /// <para/>
+    /// NOTE: This was DivFloatFunction in Lucene
     /// </summary>
-    public class DivFloatFunction : DualFloatFunction
+    public class DivSingleFunction : DualSingleFunction
     {
         /// <param name="a">  the numerator. </param>
         /// <param name="b">  the denominator. </param>
-        public DivFloatFunction(ValueSource a, ValueSource b)
+        public DivSingleFunction(ValueSource a, ValueSource b)
             : base(a, b)
         {
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/883ad7f4/src/Lucene.Net.Queries/Function/ValueSources/DocFreqValueSource.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/DocFreqValueSource.cs b/src/Lucene.Net.Queries/Function/ValueSources/DocFreqValueSource.cs
index 5e46da2..9bab31f 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/DocFreqValueSource.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/DocFreqValueSource.cs
@@ -24,7 +24,10 @@ namespace Lucene.Net.Queries.Function.ValueSources
      * limitations under the License.
      */
 
-    internal class ConstIntDocValues : IntDocValues
+    /// <summary>
+    /// NOTE: This was ConstIntDocValues in Lucene
+    /// </summary>
+    internal class ConstInt32DocValues : Int32DocValues
     {
         internal readonly int ival;
         internal readonly float fval;
@@ -33,7 +36,7 @@ namespace Lucene.Net.Queries.Function.ValueSources
         internal readonly string sval;
         internal readonly ValueSource parent;
 
-        internal ConstIntDocValues(int val, ValueSource parent)
+        internal ConstInt32DocValues(int val, ValueSource parent)
             : base(parent)
         {
             ival = val;
@@ -172,7 +175,7 @@ namespace Lucene.Net.Queries.Function.ValueSources
         {
             var searcher = (IndexSearcher)context["searcher"];
             int docfreq = searcher.IndexReader.DocFreq(new Term(m_indexedField, m_indexedBytes));
-            return new ConstIntDocValues(docfreq, this);
+            return new ConstInt32DocValues(docfreq, this);
         }
 
         public override void CreateWeight(IDictionary context, IndexSearcher searcher)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/883ad7f4/src/Lucene.Net.Queries/Function/ValueSources/DualFloatFunction.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/DualFloatFunction.cs b/src/Lucene.Net.Queries/Function/ValueSources/DualFloatFunction.cs
index 7d43753..f7621aa 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/DualFloatFunction.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/DualFloatFunction.cs
@@ -25,15 +25,17 @@ namespace Lucene.Net.Queries.Function.ValueSources
     /// <summary>
     /// Abstract <see cref="ValueSource"/> implementation which wraps two <see cref="ValueSource"/>s
     /// and applies an extendible <see cref="float"/> function to their values.
+    /// <para/>
+    /// NOTE: This was DualFloatFunction in Lucene
     /// </summary>
-    public abstract class DualFloatFunction : ValueSource
+    public abstract class DualSingleFunction : ValueSource
     {
         protected readonly ValueSource m_a;
         protected readonly ValueSource m_b;
 
         /// <param name="a">  the base. </param>
         /// <param name="b">  the exponent. </param>
-        public DualFloatFunction(ValueSource a, ValueSource b)
+        public DualSingleFunction(ValueSource a, ValueSource b)
         {
             this.m_a = a;
             this.m_b = b;
@@ -51,17 +53,17 @@ namespace Lucene.Net.Queries.Function.ValueSources
         {
             FunctionValues aVals = m_a.GetValues(context, readerContext);
             FunctionValues bVals = m_b.GetValues(context, readerContext);
-            return new FloatDocValuesAnonymousInnerClassHelper(this, this, aVals, bVals);
+            return new SingleDocValuesAnonymousInnerClassHelper(this, this, aVals, bVals);
         }
 
-        private class FloatDocValuesAnonymousInnerClassHelper : FloatDocValues
+        private class SingleDocValuesAnonymousInnerClassHelper : SingleDocValues
         {
-            private readonly DualFloatFunction outerInstance;
+            private readonly DualSingleFunction outerInstance;
 
             private readonly FunctionValues aVals;
             private readonly FunctionValues bVals;
 
-            public FloatDocValuesAnonymousInnerClassHelper(DualFloatFunction outerInstance, DualFloatFunction @this, FunctionValues aVals, FunctionValues bVals)
+            public SingleDocValuesAnonymousInnerClassHelper(DualSingleFunction outerInstance, DualSingleFunction @this, FunctionValues aVals, FunctionValues bVals)
                 : base(@this)
             {
                 this.outerInstance = outerInstance;
@@ -101,7 +103,7 @@ namespace Lucene.Net.Queries.Function.ValueSources
 
         public override bool Equals(object o)
         {
-            var other = o as DualFloatFunction;
+            var other = o as DualSingleFunction;
             if (other == null)
             {
                 return false;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/883ad7f4/src/Lucene.Net.Queries/Function/ValueSources/EnumFieldSource.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/EnumFieldSource.cs b/src/Lucene.Net.Queries/Function/ValueSources/EnumFieldSource.cs
index 7092e78..4dd4c02 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/EnumFieldSource.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/EnumFieldSource.cs
@@ -126,17 +126,17 @@ namespace Lucene.Net.Queries.Function.ValueSources
             var arr = m_cache.GetInt32s(readerContext.AtomicReader, m_field, parser, true);
             var valid = m_cache.GetDocsWithField(readerContext.AtomicReader, m_field);
 
-            return new IntDocValuesAnonymousInnerClassHelper(this, this, arr, valid);
+            return new Int32DocValuesAnonymousInnerClassHelper(this, this, arr, valid);
         }
 
-        private class IntDocValuesAnonymousInnerClassHelper : IntDocValues
+        private class Int32DocValuesAnonymousInnerClassHelper : Int32DocValues
         {
             private readonly EnumFieldSource outerInstance;
 
             private readonly FieldCache.Int32s arr;
             private readonly IBits valid;
 
-            public IntDocValuesAnonymousInnerClassHelper(EnumFieldSource outerInstance, EnumFieldSource @this, FieldCache.Int32s arr, IBits valid)
+            public Int32DocValuesAnonymousInnerClassHelper(EnumFieldSource outerInstance, EnumFieldSource @this, FieldCache.Int32s arr, IBits valid)
                 : base(@this)
             {
                 this.outerInstance = outerInstance;
@@ -237,12 +237,12 @@ namespace Lucene.Net.Queries.Function.ValueSources
 
             private class ValueSourceScorerAnonymousInnerClassHelper : ValueSourceScorer
             {
-                private readonly IntDocValuesAnonymousInnerClassHelper outerInstance;
+                private readonly Int32DocValuesAnonymousInnerClassHelper outerInstance;
 
                 private readonly int ll;
                 private readonly int uu;
 
-                public ValueSourceScorerAnonymousInnerClassHelper(IntDocValuesAnonymousInnerClassHelper outerInstance, IndexReader reader, EnumFieldSource @this, int ll, int uu)
+                public ValueSourceScorerAnonymousInnerClassHelper(Int32DocValuesAnonymousInnerClassHelper outerInstance, IndexReader reader, EnumFieldSource @this, int ll, int uu)
                     : base(reader, outerInstance)
                 {
                     this.outerInstance = outerInstance;
@@ -266,9 +266,9 @@ namespace Lucene.Net.Queries.Function.ValueSources
 
             private class ValueFillerAnonymousInnerClassHelper : ValueFiller
             {
-                private readonly IntDocValuesAnonymousInnerClassHelper outerInstance;
+                private readonly Int32DocValuesAnonymousInnerClassHelper outerInstance;
 
-                public ValueFillerAnonymousInnerClassHelper(IntDocValuesAnonymousInnerClassHelper outerInstance)
+                public ValueFillerAnonymousInnerClassHelper(Int32DocValuesAnonymousInnerClassHelper outerInstance)
                 {
                     this.outerInstance = outerInstance;
                     mval = new MutableValueInt32();

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/883ad7f4/src/Lucene.Net.Queries/Function/ValueSources/FloatFieldSource.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/FloatFieldSource.cs b/src/Lucene.Net.Queries/Function/ValueSources/FloatFieldSource.cs
index ec0732c..26584e3 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/FloatFieldSource.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/FloatFieldSource.cs
@@ -27,17 +27,19 @@ namespace Lucene.Net.Queries.Function.ValueSources
     /// <summary>
     /// Obtains <see cref="float"/> field values from <see cref="IFieldCache.GetFloats"/> and makes those
     /// values available as other numeric types, casting as needed.
+    /// <para/>
+    /// NOTE: This was FloatFieldSource in Lucene
     /// </summary>
-    public class FloatFieldSource : FieldCacheSource
+    public class SingleFieldSource : FieldCacheSource
     {
         protected readonly FieldCache.ISingleParser m_parser;
 
-        public FloatFieldSource(string field)
+        public SingleFieldSource(string field)
             : this(field, null)
         {
         }
 
-        public FloatFieldSource(string field, FieldCache.ISingleParser parser)
+        public SingleFieldSource(string field, FieldCache.ISingleParser parser)
             : base(field)
         {
             this.m_parser = parser;
@@ -52,15 +54,15 @@ namespace Lucene.Net.Queries.Function.ValueSources
         {
             var arr = m_cache.GetSingles(readerContext.AtomicReader, m_field, m_parser, true);
             var valid = m_cache.GetDocsWithField(readerContext.AtomicReader, m_field);
-            return new FloatDocValuesAnonymousInnerClassHelper(this, arr, valid);
+            return new SingleDocValuesAnonymousInnerClassHelper(this, arr, valid);
         }
 
-        private class FloatDocValuesAnonymousInnerClassHelper : FloatDocValues
+        private class SingleDocValuesAnonymousInnerClassHelper : SingleDocValues
         {
             private readonly FieldCache.Singles arr;
             private readonly IBits valid;
 
-            public FloatDocValuesAnonymousInnerClassHelper(FloatFieldSource @this, FieldCache.Singles arr, IBits valid)
+            public SingleDocValuesAnonymousInnerClassHelper(SingleFieldSource @this, FieldCache.Singles arr, IBits valid)
                 : base(@this)
             {
                 this.arr = arr;
@@ -92,9 +94,9 @@ namespace Lucene.Net.Queries.Function.ValueSources
 
             private class ValueFillerAnonymousInnerClassHelper : ValueFiller
             {
-                private readonly FloatDocValuesAnonymousInnerClassHelper outerInstance;
+                private readonly SingleDocValuesAnonymousInnerClassHelper outerInstance;
 
-                public ValueFillerAnonymousInnerClassHelper(FloatDocValuesAnonymousInnerClassHelper outerInstance)
+                public ValueFillerAnonymousInnerClassHelper(SingleDocValuesAnonymousInnerClassHelper outerInstance)
                 {
                     this.outerInstance = outerInstance;
                     mval = new MutableValueSingle();
@@ -120,7 +122,7 @@ namespace Lucene.Net.Queries.Function.ValueSources
 
         public override bool Equals(object o)
         {
-            var other = o as FloatFieldSource;
+            var other = o as SingleFieldSource;
             if (other == null)
                 return false;
             return base.Equals(other) && (this.m_parser == null ? other.m_parser == null : this.m_parser.GetType() == other.m_parser.GetType());

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/883ad7f4/src/Lucene.Net.Queries/Function/ValueSources/IntFieldSource.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/IntFieldSource.cs b/src/Lucene.Net.Queries/Function/ValueSources/IntFieldSource.cs
index 136f22a..d021256 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/IntFieldSource.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/IntFieldSource.cs
@@ -28,17 +28,19 @@ namespace Lucene.Net.Queries.Function.ValueSources
     /// <summary>
     /// Obtains <see cref="int"/> field values from <see cref="IFieldCache.GetInt32s"/> and makes those
     /// values available as other numeric types, casting as needed.
+    /// <para/>
+    /// NOTE: This was IntFieldSource in Lucene
     /// </summary>
-    public class IntFieldSource : FieldCacheSource
+    public class Int32FieldSource : FieldCacheSource
     {
         private readonly FieldCache.IInt32Parser parser;
 
-        public IntFieldSource(string field)
+        public Int32FieldSource(string field)
             : this(field, null)
         {
         }
 
-        public IntFieldSource(string field, FieldCache.IInt32Parser parser)
+        public Int32FieldSource(string field, FieldCache.IInt32Parser parser)
             : base(field)
         {
             this.parser = parser;
@@ -54,17 +56,17 @@ namespace Lucene.Net.Queries.Function.ValueSources
             FieldCache.Int32s arr = m_cache.GetInt32s(readerContext.AtomicReader, m_field, parser, true);
             IBits valid = m_cache.GetDocsWithField(readerContext.AtomicReader, m_field);
 
-            return new IntDocValuesAnonymousInnerClassHelper(this, this, arr, valid);
+            return new Int32DocValuesAnonymousInnerClassHelper(this, this, arr, valid);
         }
 
-        private class IntDocValuesAnonymousInnerClassHelper : IntDocValues
+        private class Int32DocValuesAnonymousInnerClassHelper : Int32DocValues
         {
-            private readonly IntFieldSource outerInstance;
+            private readonly Int32FieldSource outerInstance;
 
             private readonly FieldCache.Int32s arr;
             private readonly IBits valid;
 
-            public IntDocValuesAnonymousInnerClassHelper(IntFieldSource outerInstance, IntFieldSource @this, FieldCache.Int32s arr, IBits valid)
+            public Int32DocValuesAnonymousInnerClassHelper(Int32FieldSource outerInstance, Int32FieldSource @this, FieldCache.Int32s arr, IBits valid)
                 : base(@this)
             {
                 this.outerInstance = outerInstance;
@@ -131,9 +133,9 @@ namespace Lucene.Net.Queries.Function.ValueSources
 
             private class ValueFillerAnonymousInnerClassHelper : ValueFiller
             {
-                private readonly IntDocValuesAnonymousInnerClassHelper outerInstance;
+                private readonly Int32DocValuesAnonymousInnerClassHelper outerInstance;
 
-                public ValueFillerAnonymousInnerClassHelper(IntDocValuesAnonymousInnerClassHelper outerInstance)
+                public ValueFillerAnonymousInnerClassHelper(Int32DocValuesAnonymousInnerClassHelper outerInstance)
                 {
                     this.outerInstance = outerInstance;
                     mval = new MutableValueInt32();
@@ -159,7 +161,7 @@ namespace Lucene.Net.Queries.Function.ValueSources
 
         public override bool Equals(object o)
         {
-            var other = o as IntFieldSource;
+            var other = o as Int32FieldSource;
             if (other == null)
                 return false;
             return base.Equals(other) && (this.parser == null ? other.parser == null : this.parser.GetType() == other.parser.GetType());

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/883ad7f4/src/Lucene.Net.Queries/Function/ValueSources/JoinDocFreqValueSource.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/JoinDocFreqValueSource.cs b/src/Lucene.Net.Queries/Function/ValueSources/JoinDocFreqValueSource.cs
index 5a8d6e8..bca06eb 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/JoinDocFreqValueSource.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/JoinDocFreqValueSource.cs
@@ -54,17 +54,17 @@ namespace Lucene.Net.Queries.Function.ValueSources
             Terms t = MultiFields.GetTerms(top, m_qfield);
             TermsEnum termsEnum = t == null ? TermsEnum.EMPTY : t.GetIterator(null);
 
-            return new IntDocValuesAnonymousInnerClassHelper(this, this, terms, termsEnum);
+            return new Int32DocValuesAnonymousInnerClassHelper(this, this, terms, termsEnum);
         }
 
-        private class IntDocValuesAnonymousInnerClassHelper : IntDocValues
+        private class Int32DocValuesAnonymousInnerClassHelper : Int32DocValues
         {
             private readonly JoinDocFreqValueSource outerInstance;
 
             private readonly BinaryDocValues terms;
             private readonly TermsEnum termsEnum;
 
-            public IntDocValuesAnonymousInnerClassHelper(JoinDocFreqValueSource outerInstance, JoinDocFreqValueSource @this, BinaryDocValues terms, TermsEnum termsEnum)
+            public Int32DocValuesAnonymousInnerClassHelper(JoinDocFreqValueSource outerInstance, JoinDocFreqValueSource @this, BinaryDocValues terms, TermsEnum termsEnum)
                 : base(@this)
             {
                 this.outerInstance = outerInstance;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/883ad7f4/src/Lucene.Net.Queries/Function/ValueSources/LinearFloatFunction.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/LinearFloatFunction.cs b/src/Lucene.Net.Queries/Function/ValueSources/LinearFloatFunction.cs
index 179995f..ba7f20b 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/LinearFloatFunction.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/LinearFloatFunction.cs
@@ -24,18 +24,20 @@ namespace Lucene.Net.Queries.Function.ValueSources
      */
 
     /// <summary>
-    /// <see cref="LinearFloatFunction"/> implements a linear function over
+    /// <see cref="LinearSingleFunction"/> implements a linear function over
     /// another <see cref="ValueSource"/>.
     /// <para/>
     /// Normally Used as an argument to a <see cref="FunctionQuery"/>
+    /// <para/>
+    /// NOTE: This was LinearFloatFunction in Lucene
     /// </summary>
-    public class LinearFloatFunction : ValueSource
+    public class LinearSingleFunction : ValueSource
     {
         protected readonly ValueSource m_source;
         protected readonly float m_slope;
         protected readonly float m_intercept;
 
-        public LinearFloatFunction(ValueSource source, float slope, float intercept)
+        public LinearSingleFunction(ValueSource source, float slope, float intercept)
         {
             this.m_source = source;
             this.m_slope = slope;
@@ -50,15 +52,15 @@ namespace Lucene.Net.Queries.Function.ValueSources
         public override FunctionValues GetValues(IDictionary context, AtomicReaderContext readerContext)
         {
             FunctionValues vals = m_source.GetValues(context, readerContext);
-            return new FloatDocValuesAnonymousInnerClassHelper(this, this, vals);
+            return new SingleDocValuesAnonymousInnerClassHelper(this, this, vals);
         }
 
-        private class FloatDocValuesAnonymousInnerClassHelper : FloatDocValues
+        private class SingleDocValuesAnonymousInnerClassHelper : SingleDocValues
         {
-            private readonly LinearFloatFunction outerInstance;
+            private readonly LinearSingleFunction outerInstance;
             private readonly FunctionValues vals;
 
-            public FloatDocValuesAnonymousInnerClassHelper(LinearFloatFunction outerInstance, LinearFloatFunction @this, FunctionValues vals)
+            public SingleDocValuesAnonymousInnerClassHelper(LinearSingleFunction outerInstance, LinearSingleFunction @this, FunctionValues vals)
                 : base(@this)
             {
                 this.outerInstance = outerInstance;
@@ -94,7 +96,7 @@ namespace Lucene.Net.Queries.Function.ValueSources
 
         public override bool Equals(object o)
         {
-            var other = o as LinearFloatFunction;
+            var other = o as LinearSingleFunction;
             if (other == null)
                 return false;
             return this.m_slope == other.m_slope && this.m_intercept == other.m_intercept && this.m_source.Equals(other.m_source);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/883ad7f4/src/Lucene.Net.Queries/Function/ValueSources/LongFieldSource.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/LongFieldSource.cs b/src/Lucene.Net.Queries/Function/ValueSources/LongFieldSource.cs
index fffa459..6c48b86 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/LongFieldSource.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/LongFieldSource.cs
@@ -28,17 +28,19 @@ namespace Lucene.Net.Queries.Function.ValueSources
     /// <summary>
     /// Obtains <see cref="long"/> field values from <see cref="IFieldCache.GetInt64s"/> and makes those
     /// values available as other numeric types, casting as needed.
+    /// <para/>
+    /// NOTE: This was LongFieldSource in Lucene
     /// </summary>
-    public class LongFieldSource : FieldCacheSource
+    public class Int64FieldSource : FieldCacheSource
     {
         protected readonly FieldCache.IInt64Parser m_parser;
 
-        public LongFieldSource(string field)
+        public Int64FieldSource(string field)
             : this(field, null)
         {
         }
 
-        public LongFieldSource(string field, FieldCache.IInt64Parser parser)
+        public Int64FieldSource(string field, FieldCache.IInt64Parser parser)
             : base(field)
         {
             this.m_parser = parser;
@@ -77,17 +79,17 @@ namespace Lucene.Net.Queries.Function.ValueSources
         {
             var arr = m_cache.GetInt64s(readerContext.AtomicReader, m_field, m_parser, true);
             var valid = m_cache.GetDocsWithField(readerContext.AtomicReader, m_field);
-            return new LongDocValuesAnonymousInnerClassHelper(this, this, arr, valid);
+            return new Int64DocValuesAnonymousInnerClassHelper(this, this, arr, valid);
         }
 
-        private class LongDocValuesAnonymousInnerClassHelper : LongDocValues
+        private class Int64DocValuesAnonymousInnerClassHelper : Int64DocValues
         {
-            private readonly LongFieldSource outerInstance;
+            private readonly Int64FieldSource outerInstance;
 
             private readonly FieldCache.Int64s arr;
             private readonly IBits valid;
 
-            public LongDocValuesAnonymousInnerClassHelper(LongFieldSource outerInstance, LongFieldSource @this, FieldCache.Int64s arr, IBits valid)
+            public Int64DocValuesAnonymousInnerClassHelper(Int64FieldSource outerInstance, Int64FieldSource @this, FieldCache.Int64s arr, IBits valid)
                 : base(@this)
             {
                 this.outerInstance = outerInstance;
@@ -133,9 +135,9 @@ namespace Lucene.Net.Queries.Function.ValueSources
 
             private class ValueFillerAnonymousInnerClassHelper : ValueFiller
             {
-                private readonly LongDocValuesAnonymousInnerClassHelper outerInstance;
+                private readonly Int64DocValuesAnonymousInnerClassHelper outerInstance;
 
-                public ValueFillerAnonymousInnerClassHelper(LongDocValuesAnonymousInnerClassHelper outerInstance)
+                public ValueFillerAnonymousInnerClassHelper(Int64DocValuesAnonymousInnerClassHelper outerInstance)
                 {
                     this.outerInstance = outerInstance;
                     mval = outerInstance.outerInstance.NewMutableValueInt64();
@@ -173,7 +175,7 @@ namespace Lucene.Net.Queries.Function.ValueSources
             {
                 return false;
             }
-            var other = o as LongFieldSource;
+            var other = o as Int64FieldSource;
             if (other == null)
                 return false;
             return base.Equals(other) && (this.m_parser == null ? other.m_parser == null : this.m_parser.GetType() == other.m_parser.GetType());

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/883ad7f4/src/Lucene.Net.Queries/Function/ValueSources/MaxDocValueSource.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/MaxDocValueSource.cs b/src/Lucene.Net.Queries/Function/ValueSources/MaxDocValueSource.cs
index f231997..229c0cf 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/MaxDocValueSource.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/MaxDocValueSource.cs
@@ -46,7 +46,7 @@ namespace Lucene.Net.Queries.Function.ValueSources
         public override FunctionValues GetValues(IDictionary context, AtomicReaderContext readerContext)
         {
             var searcher = (IndexSearcher)context["searcher"];
-            return new ConstIntDocValues(searcher.IndexReader.MaxDoc, this);
+            return new ConstInt32DocValues(searcher.IndexReader.MaxDoc, this);
         }
 
         public override bool Equals(object o)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/883ad7f4/src/Lucene.Net.Queries/Function/ValueSources/MaxFloatFunction.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/MaxFloatFunction.cs b/src/Lucene.Net.Queries/Function/ValueSources/MaxFloatFunction.cs
index 914df30..726f6cb 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/MaxFloatFunction.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/MaxFloatFunction.cs
@@ -20,11 +20,13 @@ namespace Lucene.Net.Queries.Function.ValueSources
      */
 
     /// <summary>
-    /// <see cref="MaxFloatFunction"/> returns the max of it's components.
+    /// <see cref="MaxSingleFunction"/> returns the max of it's components.
+    /// <para/>
+    /// NOTE: This was MaxFloatFunction in Lucene
     /// </summary>
-    public class MaxFloatFunction : MultiFloatFunction
+    public class MaxSingleFunction : MultiSingleFunction
     {
-        public MaxFloatFunction(ValueSource[] sources)
+        public MaxSingleFunction(ValueSource[] sources)
             : base(sources)
         {
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/883ad7f4/src/Lucene.Net.Queries/Function/ValueSources/MinFloatFunction.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/MinFloatFunction.cs b/src/Lucene.Net.Queries/Function/ValueSources/MinFloatFunction.cs
index 83e6784..0a41dd5 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/MinFloatFunction.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/MinFloatFunction.cs
@@ -20,11 +20,13 @@ namespace Lucene.Net.Queries.Function.ValueSources
      */
 
     /// <summary>
-    /// <see cref="MinFloatFunction"/> returns the min of it's components.
+    /// <see cref="MinSingleFunction"/> returns the min of it's components.
+    /// <para/>
+    /// NOTE: This was MinFloatFunction in Lucene
     /// </summary>
-    public class MinFloatFunction : MultiFloatFunction
+    public class MinSingleFunction : MultiSingleFunction
     {
-        public MinFloatFunction(ValueSource[] sources)
+        public MinSingleFunction(ValueSource[] sources)
             : base(sources)
         {
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/883ad7f4/src/Lucene.Net.Queries/Function/ValueSources/MultiFloatFunction.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/MultiFloatFunction.cs b/src/Lucene.Net.Queries/Function/ValueSources/MultiFloatFunction.cs
index a4ac19c..3815796 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/MultiFloatFunction.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/MultiFloatFunction.cs
@@ -27,12 +27,14 @@ namespace Lucene.Net.Queries.Function.ValueSources
     /// <summary>
     /// Abstract <see cref="ValueSource"/> implementation which wraps multiple <see cref="ValueSource"/>s
     /// and applies an extendible <see cref="float"/> function to their values.
+    /// <para/>
+    /// NOTE: This was MultiFloatFunction in Lucene
     /// </summary>
-    public abstract class MultiFloatFunction : ValueSource
+    public abstract class MultiSingleFunction : ValueSource
     {
         protected readonly ValueSource[] m_sources;
 
-        public MultiFloatFunction(ValueSource[] sources)
+        public MultiSingleFunction(ValueSource[] sources)
         {
             this.m_sources = sources;
         }
@@ -70,16 +72,16 @@ namespace Lucene.Net.Queries.Function.ValueSources
                 valsArr[i] = m_sources[i].GetValues(context, readerContext);
             }
 
-            return new FloatDocValuesAnonymousInnerClassHelper(this, this, valsArr);
+            return new SingleDocValuesAnonymousInnerClassHelper(this, this, valsArr);
         }
 
-        private class FloatDocValuesAnonymousInnerClassHelper : FloatDocValues
+        private class SingleDocValuesAnonymousInnerClassHelper : SingleDocValues
         {
-            private readonly MultiFloatFunction outerInstance;
+            private readonly MultiSingleFunction outerInstance;
 
             private readonly FunctionValues[] valsArr;
 
-            public FloatDocValuesAnonymousInnerClassHelper(MultiFloatFunction outerInstance, MultiFloatFunction @this, FunctionValues[] valsArr)
+            public SingleDocValuesAnonymousInnerClassHelper(MultiSingleFunction outerInstance, MultiSingleFunction @this, FunctionValues[] valsArr)
                 : base(@this)
             {
                 this.outerInstance = outerInstance;
@@ -134,7 +136,7 @@ namespace Lucene.Net.Queries.Function.ValueSources
             {
                 return false;
             }
-            var other = o as MultiFloatFunction;
+            var other = o as MultiSingleFunction;
             if (other == null)
                 return false;
             return Name.Equals(other.Name) && Arrays.Equals(this.m_sources, other.m_sources);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/883ad7f4/src/Lucene.Net.Queries/Function/ValueSources/NormValueSource.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/NormValueSource.cs b/src/Lucene.Net.Queries/Function/ValueSources/NormValueSource.cs
index 5fd0546..7d06ab8 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/NormValueSource.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/NormValueSource.cs
@@ -70,17 +70,17 @@ namespace Lucene.Net.Queries.Function.ValueSources
                 return new ConstDoubleDocValues(0.0, this);
             }
 
-            return new FloatDocValuesAnonymousInnerClassHelper(this, this, similarity, norms);
+            return new SingleDocValuesAnonymousInnerClassHelper(this, this, similarity, norms);
         }
 
-        private class FloatDocValuesAnonymousInnerClassHelper : FloatDocValues
+        private class SingleDocValuesAnonymousInnerClassHelper : SingleDocValues
         {
             private readonly NormValueSource outerInstance;
 
             private readonly TFIDFSimilarity similarity;
             private readonly NumericDocValues norms;
 
-            public FloatDocValuesAnonymousInnerClassHelper(NormValueSource outerInstance, NormValueSource @this, TFIDFSimilarity similarity, NumericDocValues norms)
+            public SingleDocValuesAnonymousInnerClassHelper(NormValueSource outerInstance, NormValueSource @this, TFIDFSimilarity similarity, NumericDocValues norms)
                 : base(@this)
             {
                 this.outerInstance = outerInstance;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/883ad7f4/src/Lucene.Net.Queries/Function/ValueSources/NumDocsValueSource.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/NumDocsValueSource.cs b/src/Lucene.Net.Queries/Function/ValueSources/NumDocsValueSource.cs
index f0d6531..f34e14b 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/NumDocsValueSource.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/NumDocsValueSource.cs
@@ -40,7 +40,7 @@ namespace Lucene.Net.Queries.Function.ValueSources
         public override FunctionValues GetValues(IDictionary context, AtomicReaderContext readerContext)
         {
             // Searcher has no numdocs so we must use the reader instead
-            return new ConstIntDocValues(ReaderUtil.GetTopLevelContext(readerContext).Reader.NumDocs, this);
+            return new ConstInt32DocValues(ReaderUtil.GetTopLevelContext(readerContext).Reader.NumDocs, this);
         }
 
         public override bool Equals(object o)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/883ad7f4/src/Lucene.Net.Queries/Function/ValueSources/OrdFieldSource.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/OrdFieldSource.cs b/src/Lucene.Net.Queries/Function/ValueSources/OrdFieldSource.cs
index ef50b28..9bb3ab8 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/OrdFieldSource.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/OrdFieldSource.cs
@@ -65,17 +65,17 @@ namespace Lucene.Net.Queries.Function.ValueSources
             IndexReader topReader = ReaderUtil.GetTopLevelContext(readerContext).Reader;
             AtomicReader r = SlowCompositeReaderWrapper.Wrap(topReader);
             SortedDocValues sindex = FieldCache.DEFAULT.GetTermsIndex(r, m_field);
-            return new IntDocValuesAnonymousInnerClassHelper(this, this, off, sindex);
+            return new Int32DocValuesAnonymousInnerClassHelper(this, this, off, sindex);
         }
 
-        private sealed class IntDocValuesAnonymousInnerClassHelper : IntDocValues
+        private sealed class Int32DocValuesAnonymousInnerClassHelper : Int32DocValues
         {
             private readonly OrdFieldSource outerInstance;
 
             private readonly int off;
             private readonly SortedDocValues sindex;
 
-            public IntDocValuesAnonymousInnerClassHelper(OrdFieldSource outerInstance, OrdFieldSource @this, int off, SortedDocValues sindex)
+            public Int32DocValuesAnonymousInnerClassHelper(OrdFieldSource outerInstance, OrdFieldSource @this, int off, SortedDocValues sindex)
                 : base(@this)
             {
                 this.outerInstance = outerInstance;
@@ -116,9 +116,9 @@ namespace Lucene.Net.Queries.Function.ValueSources
 
             private class ValueFillerAnonymousInnerClassHelper : ValueFiller
             {
-                private readonly IntDocValuesAnonymousInnerClassHelper outerInstance;
+                private readonly Int32DocValuesAnonymousInnerClassHelper outerInstance;
 
-                public ValueFillerAnonymousInnerClassHelper(IntDocValuesAnonymousInnerClassHelper outerInstance)
+                public ValueFillerAnonymousInnerClassHelper(Int32DocValuesAnonymousInnerClassHelper outerInstance)
                 {
                     this.outerInstance = outerInstance;
                     mval = new MutableValueInt32();

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/883ad7f4/src/Lucene.Net.Queries/Function/ValueSources/PowFloatFunction.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/PowFloatFunction.cs b/src/Lucene.Net.Queries/Function/ValueSources/PowFloatFunction.cs
index 8a2a10b..7f849f0 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/PowFloatFunction.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/PowFloatFunction.cs
@@ -21,12 +21,14 @@ namespace Lucene.Net.Queries.Function.ValueSources
 
     /// <summary>
     /// Function to raise the base "a" to the power "b"
+    /// <para/>
+    /// NOTE: This was PowFloatFunction in Lucene
     /// </summary>
-    public class PowFloatFunction : DualFloatFunction
+    public class PowSingleFunction : DualSingleFunction
     {
         /// <param name="a">  the base. </param>
         /// <param name="b">  the exponent. </param>
-        public PowFloatFunction(ValueSource a, ValueSource b)
+        public PowSingleFunction(ValueSource a, ValueSource b)
             : base(a, b)
         {
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/883ad7f4/src/Lucene.Net.Queries/Function/ValueSources/ProductFloatFunction.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/ProductFloatFunction.cs b/src/Lucene.Net.Queries/Function/ValueSources/ProductFloatFunction.cs
index 1fda318..24c5235 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/ProductFloatFunction.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/ProductFloatFunction.cs
@@ -20,11 +20,13 @@ namespace Lucene.Net.Queries.Function.ValueSources
      */
 
     /// <summary>
-    /// <see cref="ProductFloatFunction"/> returns the product of it's components.
+    /// <see cref="ProductSingleFunction"/> returns the product of it's components.
+    /// <para/>
+    /// NOTE: This was ProductFloatFunction in Lucene
     /// </summary>
-    public class ProductFloatFunction : MultiFloatFunction
+    public class ProductSingleFunction : MultiSingleFunction
     {
-        public ProductFloatFunction(ValueSource[] sources)
+        public ProductSingleFunction(ValueSource[] sources)
             : base(sources)
         {
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/883ad7f4/src/Lucene.Net.Queries/Function/ValueSources/QueryValueSource.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/QueryValueSource.cs b/src/Lucene.Net.Queries/Function/ValueSources/QueryValueSource.cs
index 7eedfab..c321dc2 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/QueryValueSource.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/QueryValueSource.cs
@@ -90,7 +90,7 @@ namespace Lucene.Net.Queries.Function.ValueSources
     }
 
 
-    internal class QueryDocValues : FloatDocValues
+    internal class QueryDocValues : SingleDocValues
     {
         internal readonly AtomicReaderContext readerContext;
         internal readonly IBits acceptDocs;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/883ad7f4/src/Lucene.Net.Queries/Function/ValueSources/RangeMapFloatFunction.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/RangeMapFloatFunction.cs b/src/Lucene.Net.Queries/Function/ValueSources/RangeMapFloatFunction.cs
index 3d7ecc6..23a15e3 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/RangeMapFloatFunction.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/RangeMapFloatFunction.cs
@@ -24,12 +24,14 @@ namespace Lucene.Net.Queries.Function.ValueSources
      */
 
     /// <summary>
-    /// <see cref="RangeMapFloatFunction"/> implements a map function over
+    /// <see cref="RangeMapSingleFunction"/> implements a map function over
     /// another <see cref="ValueSource"/> whose values fall within <c>min</c> and <c>max</c> inclusive to <c>target</c>.
     /// <para/>
     /// Normally used as an argument to a <see cref="FunctionQuery"/>
+    /// <para/>
+    /// NOTE: This was RangeMapFloatFunction in Lucene
     /// </summary>
-    public class RangeMapFloatFunction : ValueSource
+    public class RangeMapSingleFunction : ValueSource
     {
         protected readonly ValueSource m_source;
         protected readonly float m_min;
@@ -37,12 +39,12 @@ namespace Lucene.Net.Queries.Function.ValueSources
         protected readonly ValueSource m_target;
         protected readonly ValueSource m_defaultVal;
 
-        public RangeMapFloatFunction(ValueSource source, float min, float max, float target, float? def)
+        public RangeMapSingleFunction(ValueSource source, float min, float max, float target, float? def)
             : this(source, min, max, new ConstValueSource(target), def == null ? null : new ConstValueSource(def.Value))
         {
         }
 
-        public RangeMapFloatFunction(ValueSource source, float min, float max, ValueSource target, ValueSource def)
+        public RangeMapSingleFunction(ValueSource source, float min, float max, ValueSource target, ValueSource def)
         {
             this.m_source = source;
             this.m_min = min;
@@ -61,18 +63,18 @@ namespace Lucene.Net.Queries.Function.ValueSources
             FunctionValues vals = m_source.GetValues(context, readerContext);
             FunctionValues targets = m_target.GetValues(context, readerContext);
             FunctionValues defaults = (this.m_defaultVal == null) ? null : m_defaultVal.GetValues(context, readerContext);
-            return new FloatDocValuesAnonymousInnerClassHelper(this, this, vals, targets, defaults);
+            return new SingleDocValuesAnonymousInnerClassHelper(this, this, vals, targets, defaults);
         }
 
-        private class FloatDocValuesAnonymousInnerClassHelper : FloatDocValues
+        private class SingleDocValuesAnonymousInnerClassHelper : SingleDocValues
         {
-            private readonly RangeMapFloatFunction outerInstance;
+            private readonly RangeMapSingleFunction outerInstance;
 
             private readonly FunctionValues vals;
             private readonly FunctionValues targets;
             private readonly FunctionValues defaults;
 
-            public FloatDocValuesAnonymousInnerClassHelper(RangeMapFloatFunction outerInstance, RangeMapFloatFunction @this, FunctionValues vals, FunctionValues targets, FunctionValues defaults)
+            public SingleDocValuesAnonymousInnerClassHelper(RangeMapSingleFunction outerInstance, RangeMapSingleFunction @this, FunctionValues vals, FunctionValues targets, FunctionValues defaults)
                 : base(@this)
             {
                 this.outerInstance = outerInstance;
@@ -117,11 +119,11 @@ namespace Lucene.Net.Queries.Function.ValueSources
 
         public override bool Equals(object o)
         {
-            if (typeof(RangeMapFloatFunction) != o.GetType())
+            if (typeof(RangeMapSingleFunction) != o.GetType())
             {
                 return false;
             }
-            var other = o as RangeMapFloatFunction;
+            var other = o as RangeMapSingleFunction;
             if (other == null)
                 return false;
             return this.m_min == other.m_min 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/883ad7f4/src/Lucene.Net.Queries/Function/ValueSources/ReciprocalFloatFunction.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/ReciprocalFloatFunction.cs b/src/Lucene.Net.Queries/Function/ValueSources/ReciprocalFloatFunction.cs
index a803e8c..4f8bae6 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/ReciprocalFloatFunction.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/ReciprocalFloatFunction.cs
@@ -25,7 +25,7 @@ namespace Lucene.Net.Queries.Function.ValueSources
      */
 
     /// <summary>
-    /// <see cref="ReciprocalFloatFunction"/> implements a reciprocal function <c>f(x) = a/(mx+b)</c>, based on
+    /// <see cref="ReciprocalSingleFunction"/> implements a reciprocal function <c>f(x) = a/(mx+b)</c>, based on
     /// the <see cref="float"/> value of a field or function as exported by <see cref="ValueSource"/>.
     /// <para/>
     /// When a and b are equal, and <c>x&gt;=0</c>, this function has a maximum value of 1 that drops as x increases.
@@ -36,9 +36,11 @@ namespace Lucene.Net.Queries.Function.ValueSources
     /// per year).  Thus, a very recent date will yield a value close to 1/(0+1) or 1,
     /// a date a year in the past will get a multiplier of about 1/(1+1) or 1/2,
     /// and date two years old will yield 1/(2+1) or 1/3.
+    /// <para/>
+    /// NOTE: This was ReciprocalFloatFunction in Lucene
     /// </summary>
     /// <seealso cref="FunctionQuery"/>
-    public class ReciprocalFloatFunction : ValueSource
+    public class ReciprocalSingleFunction : ValueSource
     {
         protected readonly ValueSource m_source;
         protected readonly float m_m;
@@ -48,7 +50,7 @@ namespace Lucene.Net.Queries.Function.ValueSources
         /// <summary>
         ///  f(source) = a/(m*float(source)+b)
         /// </summary>
-        public ReciprocalFloatFunction(ValueSource source, float m, float a, float b)
+        public ReciprocalSingleFunction(ValueSource source, float m, float a, float b)
         {
             this.m_source = source;
             this.m_m = m;
@@ -59,15 +61,15 @@ namespace Lucene.Net.Queries.Function.ValueSources
         public override FunctionValues GetValues(IDictionary context, AtomicReaderContext readerContext)
         {
             var vals = m_source.GetValues(context, readerContext);
-            return new FloatDocValuesAnonymousInnerClassHelper(this, this, vals);
+            return new SingleDocValuesAnonymousInnerClassHelper(this, this, vals);
         }
 
-        private class FloatDocValuesAnonymousInnerClassHelper : FloatDocValues
+        private class SingleDocValuesAnonymousInnerClassHelper : SingleDocValues
         {
-            private readonly ReciprocalFloatFunction outerInstance;
+            private readonly ReciprocalSingleFunction outerInstance;
             private readonly FunctionValues vals;
 
-            public FloatDocValuesAnonymousInnerClassHelper(ReciprocalFloatFunction outerInstance, ReciprocalFloatFunction @this, FunctionValues vals)
+            public SingleDocValuesAnonymousInnerClassHelper(ReciprocalSingleFunction outerInstance, ReciprocalSingleFunction @this, FunctionValues vals)
                 : base(@this)
             {
                 this.outerInstance = outerInstance;
@@ -106,11 +108,11 @@ namespace Lucene.Net.Queries.Function.ValueSources
 
         public override bool Equals(object o)
         {
-            if (typeof(ReciprocalFloatFunction) != o.GetType())
+            if (typeof(ReciprocalSingleFunction) != o.GetType())
             {
                 return false;
             }
-            var other = o as ReciprocalFloatFunction;
+            var other = o as ReciprocalSingleFunction;
             if (other == null)
                 return false;
             return this.m_m == other.m_m && this.m_a == other.m_a && this.m_b == other.m_b && this.m_source.Equals(other.m_source);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/883ad7f4/src/Lucene.Net.Queries/Function/ValueSources/ReverseOrdFieldSource.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/ReverseOrdFieldSource.cs b/src/Lucene.Net.Queries/Function/ValueSources/ReverseOrdFieldSource.cs
index 88c9d1b..3374c0c 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/ReverseOrdFieldSource.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/ReverseOrdFieldSource.cs
@@ -71,10 +71,10 @@ namespace Lucene.Net.Queries.Function.ValueSources
             var sindex = FieldCache.DEFAULT.GetTermsIndex(r, field);
             var end = sindex.ValueCount;
 
-            return new IntDocValuesAnonymousInnerClassHelper(this, this, off, sindex, end);
+            return new Int32DocValuesAnonymousInnerClassHelper(this, this, off, sindex, end);
         }
 
-        private class IntDocValuesAnonymousInnerClassHelper : IntDocValues
+        private class Int32DocValuesAnonymousInnerClassHelper : Int32DocValues
         {
             private readonly ReverseOrdFieldSource outerInstance;
 
@@ -82,7 +82,7 @@ namespace Lucene.Net.Queries.Function.ValueSources
             private readonly SortedDocValues sindex;
             private readonly int end;
 
-            public IntDocValuesAnonymousInnerClassHelper(ReverseOrdFieldSource outerInstance, ReverseOrdFieldSource @this, int off, SortedDocValues sindex, int end)
+            public Int32DocValuesAnonymousInnerClassHelper(ReverseOrdFieldSource outerInstance, ReverseOrdFieldSource @this, int off, SortedDocValues sindex, int end)
                 : base(@this)
             {
                 this.outerInstance = outerInstance;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/883ad7f4/src/Lucene.Net.Queries/Function/ValueSources/ScaleFloatFunction.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/ScaleFloatFunction.cs b/src/Lucene.Net.Queries/Function/ValueSources/ScaleFloatFunction.cs
index ffae7c7..4c798a2 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/ScaleFloatFunction.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/ScaleFloatFunction.cs
@@ -33,14 +33,16 @@ namespace Lucene.Net.Queries.Function.ValueSources
     /// still end up with 0.0 as the min value to map from.  In these cases, an
     /// appropriate map() function could be used as a workaround to change 0.0
     /// to a value in the real range.
+    /// <para/>
+    /// NOTE: This was ScaleFloatFunction in Lucene
     /// </summary>
-    public class ScaleFloatFunction : ValueSource
+    public class ScaleSingleFunction : ValueSource
     {
         protected readonly ValueSource m_source;
         protected readonly float m_min;
         protected readonly float m_max;
 
-        public ScaleFloatFunction(ValueSource source, float min, float max)
+        public ScaleSingleFunction(ValueSource source, float min, float max)
         {
             this.m_source = source;
             this.m_min = min;
@@ -115,19 +117,19 @@ namespace Lucene.Net.Queries.Function.ValueSources
             float maxSource = scaleInfo.MaxVal;
 
             var vals = m_source.GetValues(context, readerContext);
-            return new FloatDocValuesAnonymousInnerClassHelper(this, this, scale, minSource, maxSource, vals);
+            return new SingleDocValuesAnonymousInnerClassHelper(this, this, scale, minSource, maxSource, vals);
         }
 
-        private class FloatDocValuesAnonymousInnerClassHelper : FloatDocValues
+        private class SingleDocValuesAnonymousInnerClassHelper : SingleDocValues
         {
-            private readonly ScaleFloatFunction outerInstance;
+            private readonly ScaleSingleFunction outerInstance;
 
             private readonly float scale;
             private readonly float minSource;
             private readonly float maxSource;
             private readonly FunctionValues vals;
 
-            public FloatDocValuesAnonymousInnerClassHelper(ScaleFloatFunction outerInstance, ScaleFloatFunction @this, float scale, float minSource, float maxSource, FunctionValues vals)
+            public SingleDocValuesAnonymousInnerClassHelper(ScaleSingleFunction outerInstance, ScaleSingleFunction @this, float scale, float minSource, float maxSource, FunctionValues vals)
                 : base(@this)
             {
                 this.outerInstance = outerInstance;
@@ -167,7 +169,7 @@ namespace Lucene.Net.Queries.Function.ValueSources
 
         public override bool Equals(object o)
         {
-            var other = o as ScaleFloatFunction;
+            var other = o as ScaleSingleFunction;
             if (other == null)
                 return false;
             return this.m_min == other.m_min 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/883ad7f4/src/Lucene.Net.Queries/Function/ValueSources/ShortFieldSource.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/ShortFieldSource.cs b/src/Lucene.Net.Queries/Function/ValueSources/ShortFieldSource.cs
index d8b8708..dab833f 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/ShortFieldSource.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/ShortFieldSource.cs
@@ -24,20 +24,22 @@ namespace Lucene.Net.Queries.Function.ValueSources
 
     /// <summary>
     /// Obtains <see cref="short"/> field values from the <see cref="FieldCache"/>
-    /// using <see cref="IFieldCache.GetShorts"/>
+    /// using <see cref="IFieldCache.GetInt16s"/>
     /// and makes those values available as other numeric types, casting as needed.
+    /// <para/>
+    /// NOTE: This was ShortFieldSource in Lucene
     /// </summary>
     [Obsolete]
-    public class ShortFieldSource : FieldCacheSource
+    public class Int16FieldSource : FieldCacheSource
     {
         private readonly FieldCache.IInt16Parser parser;
 
-        public ShortFieldSource(string field)
+        public Int16FieldSource(string field)
             : this(field, null)
         {
         }
 
-        public ShortFieldSource(string field, FieldCache.IInt16Parser parser)
+        public Int16FieldSource(string field, FieldCache.IInt16Parser parser)
             : base(field)
         {
             this.parser = parser;
@@ -56,10 +58,10 @@ namespace Lucene.Net.Queries.Function.ValueSources
 
         private class FunctionValuesAnonymousInnerClassHelper : FunctionValues
         {
-            private readonly ShortFieldSource outerInstance;
+            private readonly Int16FieldSource outerInstance;
             private readonly FieldCache.Int16s arr;
 
-            public FunctionValuesAnonymousInnerClassHelper(ShortFieldSource outerInstance, FieldCache.Int16s arr)
+            public FunctionValuesAnonymousInnerClassHelper(Int16FieldSource outerInstance, FieldCache.Int16s arr)
             {
                 this.outerInstance = outerInstance;
                 this.arr = arr;
@@ -120,7 +122,7 @@ namespace Lucene.Net.Queries.Function.ValueSources
 
         public override bool Equals(object o)
         {
-            var other = o as ShortFieldSource;
+            var other = o as Int16FieldSource;
             if (other == null)
                 return false;
             return base.Equals(other) 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/883ad7f4/src/Lucene.Net.Queries/Function/ValueSources/SimpleFloatFunction.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/SimpleFloatFunction.cs b/src/Lucene.Net.Queries/Function/ValueSources/SimpleFloatFunction.cs
index 400e496..eef0434 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/SimpleFloatFunction.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/SimpleFloatFunction.cs
@@ -23,10 +23,12 @@ namespace Lucene.Net.Queries.Function.ValueSources
 
     /// <summary>
     /// A simple <see cref="float"/> function with a single argument
+    /// <para/>
+    /// NOTE: This was SimpleFloatFunction in Lucene
     /// </summary>
-    public abstract class SimpleFloatFunction : SingularFunction
+    public abstract class SimpleSingleFunction : SingularFunction
     {
-        public SimpleFloatFunction(ValueSource source)
+        public SimpleSingleFunction(ValueSource source)
             : base(source)
         {
         }
@@ -36,15 +38,15 @@ namespace Lucene.Net.Queries.Function.ValueSources
         public override FunctionValues GetValues(IDictionary context, AtomicReaderContext readerContext)
         {
             FunctionValues vals = m_source.GetValues(context, readerContext);
-            return new FloatDocValuesAnonymousInnerClassHelper(this, this, vals);
+            return new SingleDocValuesAnonymousInnerClassHelper(this, this, vals);
         }
 
-        private class FloatDocValuesAnonymousInnerClassHelper : FloatDocValues
+        private class SingleDocValuesAnonymousInnerClassHelper : SingleDocValues
         {
-            private readonly SimpleFloatFunction outerInstance;
+            private readonly SimpleSingleFunction outerInstance;
             private readonly FunctionValues vals;
 
-            public FloatDocValuesAnonymousInnerClassHelper(SimpleFloatFunction outerInstance, SimpleFloatFunction @this, FunctionValues vals)
+            public SingleDocValuesAnonymousInnerClassHelper(SimpleSingleFunction outerInstance, SimpleSingleFunction @this, FunctionValues vals)
                 : base(@this)
             {
                 this.outerInstance = outerInstance;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/883ad7f4/src/Lucene.Net.Queries/Function/ValueSources/SingleFunction.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/SingleFunction.cs b/src/Lucene.Net.Queries/Function/ValueSources/SingleFunction.cs
index f74cd34..89c225f 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/SingleFunction.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/SingleFunction.cs
@@ -21,7 +21,7 @@ namespace Lucene.Net.Queries.Function.ValueSources
      */
 
     /// <summary>
-    /// A function with a single argument.
+    /// A function with a single (one) argument.
     /// <para/>
     /// NOTE: This was SingleFunction in Lucene, changed to avoid conusion with operations on the datatype <see cref="System.Single"/>.
     /// </summary>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/883ad7f4/src/Lucene.Net.Queries/Function/ValueSources/SumFloatFunction.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/SumFloatFunction.cs b/src/Lucene.Net.Queries/Function/ValueSources/SumFloatFunction.cs
index 90472a2..3ec8ffc 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/SumFloatFunction.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/SumFloatFunction.cs
@@ -20,11 +20,13 @@ namespace Lucene.Net.Queries.Function.ValueSources
      */
 
     /// <summary>
-    /// <see cref="SumFloatFunction"/> returns the sum of its components.
+    /// <see cref="SumSingleFunction"/> returns the sum of its components.
+    /// <para/>
+    /// NOTE: This was SumFloatFunction in Lucene
     /// </summary>
-    public class SumFloatFunction : MultiFloatFunction
+    public class SumSingleFunction : MultiSingleFunction
     {
-        public SumFloatFunction(ValueSource[] sources)
+        public SumSingleFunction(ValueSource[] sources)
             : base(sources)
         {
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/883ad7f4/src/Lucene.Net.Queries/Function/ValueSources/SumTotalTermFreqValueSource.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/SumTotalTermFreqValueSource.cs b/src/Lucene.Net.Queries/Function/ValueSources/SumTotalTermFreqValueSource.cs
index 27de789..0ffc576 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/SumTotalTermFreqValueSource.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/SumTotalTermFreqValueSource.cs
@@ -80,16 +80,16 @@ namespace Lucene.Net.Queries.Function.ValueSources
                 }
             }
             long ttf = sumTotalTermFreq;
-            context[this] = new LongDocValuesAnonymousInnerClassHelper(this, this, ttf);
+            context[this] = new Int64DocValuesAnonymousInnerClassHelper(this, this, ttf);
         }
 
-        private class LongDocValuesAnonymousInnerClassHelper : LongDocValues
+        private class Int64DocValuesAnonymousInnerClassHelper : Int64DocValues
         {
             private readonly SumTotalTermFreqValueSource outerInstance;
 
             private long ttf;
 
-            public LongDocValuesAnonymousInnerClassHelper(SumTotalTermFreqValueSource outerInstance, SumTotalTermFreqValueSource @this, long ttf)
+            public Int64DocValuesAnonymousInnerClassHelper(SumTotalTermFreqValueSource outerInstance, SumTotalTermFreqValueSource @this, long ttf)
                 : base(@this)
             {
                 this.outerInstance = outerInstance;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/883ad7f4/src/Lucene.Net.Queries/Function/ValueSources/TFValueSource.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/TFValueSource.cs b/src/Lucene.Net.Queries/Function/ValueSources/TFValueSource.cs
index e9bbee7..2ffe4f8 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/TFValueSource.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/TFValueSource.cs
@@ -62,17 +62,17 @@ namespace Lucene.Net.Queries.Function.ValueSources
                 throw new System.NotSupportedException("requires a TFIDFSimilarity (such as DefaultSimilarity)");
             }
 
-            return new FloatDocValuesAnonymousInnerClassHelper(this, this, terms, similarity);
+            return new SingleDocValuesAnonymousInnerClassHelper(this, this, terms, similarity);
         }
 
-        private class FloatDocValuesAnonymousInnerClassHelper : FloatDocValues
+        private class SingleDocValuesAnonymousInnerClassHelper : SingleDocValues
         {
             private readonly TFValueSource outerInstance;
 
             private readonly Terms terms;
             private readonly TFIDFSimilarity similarity;
 
-            public FloatDocValuesAnonymousInnerClassHelper(TFValueSource outerInstance, TFValueSource @this, Terms terms, TFIDFSimilarity similarity)
+            public SingleDocValuesAnonymousInnerClassHelper(TFValueSource outerInstance, TFValueSource @this, Terms terms, TFIDFSimilarity similarity)
                 : base(@this)
             {
                 this.outerInstance = outerInstance;
@@ -116,9 +116,9 @@ namespace Lucene.Net.Queries.Function.ValueSources
 
             private class DocsEnumAnonymousInnerClassHelper : DocsEnum
             {
-                private readonly FloatDocValuesAnonymousInnerClassHelper outerInstance;
+                private readonly SingleDocValuesAnonymousInnerClassHelper outerInstance;
 
-                public DocsEnumAnonymousInnerClassHelper(FloatDocValuesAnonymousInnerClassHelper outerInstance)
+                public DocsEnumAnonymousInnerClassHelper(SingleDocValuesAnonymousInnerClassHelper outerInstance)
                 {
                     this.outerInstance = outerInstance;
                 }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/883ad7f4/src/Lucene.Net.Queries/Function/ValueSources/TermFreqValueSource.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/TermFreqValueSource.cs b/src/Lucene.Net.Queries/Function/ValueSources/TermFreqValueSource.cs
index 749c208..96b9ad7 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/TermFreqValueSource.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/TermFreqValueSource.cs
@@ -49,16 +49,16 @@ namespace Lucene.Net.Queries.Function.ValueSources
             Fields fields = readerContext.AtomicReader.Fields;
             Terms terms = fields.Terms(m_indexedField);
 
-            return new IntDocValuesAnonymousInnerClassHelper(this, this, terms);
+            return new Int32DocValuesAnonymousInnerClassHelper(this, this, terms);
         }
 
-        private class IntDocValuesAnonymousInnerClassHelper : IntDocValues
+        private class Int32DocValuesAnonymousInnerClassHelper : Int32DocValues
         {
             private readonly TermFreqValueSource outerInstance;
 
             private Terms terms;
 
-            public IntDocValuesAnonymousInnerClassHelper(TermFreqValueSource outerInstance, TermFreqValueSource @this, Terms terms)
+            public Int32DocValuesAnonymousInnerClassHelper(TermFreqValueSource outerInstance, TermFreqValueSource @this, Terms terms)
                 : base(@this)
             {
                 this.outerInstance = outerInstance;
@@ -101,9 +101,9 @@ namespace Lucene.Net.Queries.Function.ValueSources
 
             private class DocsEnumAnonymousInnerClassHelper : DocsEnum
             {
-                private readonly IntDocValuesAnonymousInnerClassHelper outerInstance;
+                private readonly Int32DocValuesAnonymousInnerClassHelper outerInstance;
 
-                public DocsEnumAnonymousInnerClassHelper(IntDocValuesAnonymousInnerClassHelper outerInstance)
+                public DocsEnumAnonymousInnerClassHelper(Int32DocValuesAnonymousInnerClassHelper outerInstance)
                 {
                     this.outerInstance = outerInstance;
                 }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/883ad7f4/src/Lucene.Net.Queries/Function/ValueSources/TotalTermFreqValueSource.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/TotalTermFreqValueSource.cs b/src/Lucene.Net.Queries/Function/ValueSources/TotalTermFreqValueSource.cs
index 86511b7..e008090 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/TotalTermFreqValueSource.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/TotalTermFreqValueSource.cs
@@ -77,16 +77,16 @@ namespace Lucene.Net.Queries.Function.ValueSources
                 }
             }
             var ttf = totalTermFreq;
-            context[this] = new LongDocValuesAnonymousInnerClassHelper(this, this, ttf);
+            context[this] = new Int64DocValuesAnonymousInnerClassHelper(this, this, ttf);
         }
 
-        private class LongDocValuesAnonymousInnerClassHelper : LongDocValues
+        private class Int64DocValuesAnonymousInnerClassHelper : Int64DocValues
         {
             private readonly TotalTermFreqValueSource outerInstance;
 
             private readonly long ttf;
 
-            public LongDocValuesAnonymousInnerClassHelper(TotalTermFreqValueSource outerInstance, TotalTermFreqValueSource @this, long ttf)
+            public Int64DocValuesAnonymousInnerClassHelper(TotalTermFreqValueSource outerInstance, TotalTermFreqValueSource @this, long ttf)
                 : base(@this)
             {
                 this.outerInstance = outerInstance;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/883ad7f4/src/Lucene.Net.Queries/Mlt/MoreLikeThis.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Mlt/MoreLikeThis.cs b/src/Lucene.Net.Queries/Mlt/MoreLikeThis.cs
index f3bfb1c..9ab7dc9 100644
--- a/src/Lucene.Net.Queries/Mlt/MoreLikeThis.cs
+++ b/src/Lucene.Net.Queries/Mlt/MoreLikeThis.cs
@@ -420,9 +420,9 @@ namespace Lucene.Net.Queries.Mlt
         /// <summary>
         /// Create a <see cref="T:Util.PriorityQueue{object[]}"/> from a word-&gt;tf map.
         /// </summary>
-        /// <param name="words"> a map of words keyed on the word(<see cref="string"/>) with <see cref="Int"/> objects as the values. </param>
+        /// <param name="words"> a map of words keyed on the word(<see cref="string"/>) with <see cref="Int32"/> objects as the values. </param>
         /// <exception cref="IOException"/>
-        private Util.PriorityQueue<object[]> CreateQueue(IDictionary<string, Int> words)
+        private Util.PriorityQueue<object[]> CreateQueue(IDictionary<string, Int32> words)
         {
             // have collected all words in doc and their freqs
             int numDocs = ir.NumDocs;
@@ -500,7 +500,7 @@ namespace Lucene.Net.Queries.Mlt
         /// <exception cref="IOException"/>
         public Util.PriorityQueue<object[]> RetrieveTerms(int docNum)
         {
-            IDictionary<string, Int> termFreqMap = new Dictionary<string, Int>();
+            IDictionary<string, Int32> termFreqMap = new Dictionary<string, Int32>();
             foreach (string fieldName in FieldNames)
             {
                 Fields vectors = ir.GetTermVectors(docNum);
@@ -542,7 +542,7 @@ namespace Lucene.Net.Queries.Mlt
         /// </summary>
         /// <param name="termFreqMap"> a <see cref="T:IDictionary{string, Int}"/> of terms and their frequencies </param>
         /// <param name="vector"> List of terms and their frequencies for a doc/field </param>
-        private void AddTermFrequencies(IDictionary<string, Int> termFreqMap, Terms vector)
+        private void AddTermFrequencies(IDictionary<string, Int32> termFreqMap, Terms vector)
         {
             var termsEnum = vector.GetIterator(null);
             var spare = new CharsRef();
@@ -558,10 +558,10 @@ namespace Lucene.Net.Queries.Mlt
                 var freq = (int)termsEnum.TotalTermFreq;
 
                 // increment frequency
-                Int cnt;
+                Int32 cnt;
                 if (!termFreqMap.TryGetValue(term, out cnt))
                 {
-                    cnt = new Int();
+                    cnt = new Int32();
                     termFreqMap[term] = cnt;
                     cnt.x = freq;
                 }
@@ -578,7 +578,7 @@ namespace Lucene.Net.Queries.Mlt
         /// <param name="r"> a source of text to be tokenized </param>
         /// <param name="termFreqMap"> a <see cref="T:IDictionary{string, Int}"/> of terms and their frequencies </param>
         /// <param name="fieldName"> Used by analyzer for any special per-field analysis </param>
-        private void AddTermFrequencies(TextReader r, IDictionary<string, Int> termFreqMap, string fieldName)
+        private void AddTermFrequencies(TextReader r, IDictionary<string, Int32> termFreqMap, string fieldName)
         {
             if (Analyzer == null)
             {
@@ -605,10 +605,10 @@ namespace Lucene.Net.Queries.Mlt
                     }
 
                     // increment frequency
-                    Int cnt;
+                    Int32 cnt;
                     if (!termFreqMap.TryGetValue(word, out cnt))
                     {
-                        termFreqMap[word] = new Int();
+                        termFreqMap[word] = new Int32();
                     }
                     else
                     {
@@ -668,7 +668,7 @@ namespace Lucene.Net.Queries.Mlt
         /// <seealso cref="RetrieveInterestingTerms"/>
         public Util.PriorityQueue<object[]> RetrieveTerms(TextReader r, string fieldName)
         {
-            IDictionary<string, Int> words = new Dictionary<string, Int>();
+            IDictionary<string, Int32> words = new Dictionary<string, Int32>();
             AddTermFrequencies(r, words, fieldName);
             return CreateQueue(words);
         }
@@ -733,12 +733,14 @@ namespace Lucene.Net.Queries.Mlt
 
         /// <summary>
         /// Use for frequencies and to avoid renewing <see cref="int"/>s.
+        /// <para/>
+        /// NOTE: This was Int in Lucene
         /// </summary>
-        private class Int
+        private class Int32
         {
             internal int x;
 
-            internal Int()
+            internal Int32()
             {
                 x = 1;
             }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/883ad7f4/src/Lucene.Net.Spatial/SpatialStrategy.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Spatial/SpatialStrategy.cs b/src/Lucene.Net.Spatial/SpatialStrategy.cs
index 3bfc929..348ca7e 100644
--- a/src/Lucene.Net.Spatial/SpatialStrategy.cs
+++ b/src/Lucene.Net.Spatial/SpatialStrategy.cs
@@ -158,7 +158,7 @@ namespace Lucene.Net.Spatial
                 m_ctx.MakePoint(bbox.MinX, bbox.MinY), bbox.MaxX, bbox.MaxY);
             double distToEdge = diagonalDist * 0.5;
             float c = (float)distToEdge * 0.1f; //one tenth
-            return new ReciprocalFloatFunction(MakeDistanceValueSource(queryShape.Center, 1.0), 1f, c, c);
+            return new ReciprocalSingleFunction(MakeDistanceValueSource(queryShape.Center, 1.0), 1f, c, c);
         }
 
         public override string ToString()


[24/53] [abbrv] lucenenet git commit: Lucene.Net.Core: Renamed all type-derived classes and interfaces from Short, Int, Long, and Float to match CLR types Int16, Int32, Int64, and Single, respectively.

Posted by ni...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Core/Util/WAH8DocIdSet.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Core/Util/WAH8DocIdSet.cs b/src/Lucene.Net.Core/Util/WAH8DocIdSet.cs
index f6ac44a..46fca06 100644
--- a/src/Lucene.Net.Core/Util/WAH8DocIdSet.cs
+++ b/src/Lucene.Net.Core/Util/WAH8DocIdSet.cs
@@ -25,8 +25,8 @@ namespace Lucene.Net.Util
     using ByteArrayDataInput = Lucene.Net.Store.ByteArrayDataInput;
     using DocIdSet = Lucene.Net.Search.DocIdSet;
     using DocIdSetIterator = Lucene.Net.Search.DocIdSetIterator;
-    using MonotonicAppendingLongBuffer = Lucene.Net.Util.Packed.MonotonicAppendingLongBuffer;
-    using PackedInts = Lucene.Net.Util.Packed.PackedInts;
+    using MonotonicAppendingInt64Buffer = Lucene.Net.Util.Packed.MonotonicAppendingInt64Buffer;
+    using PackedInt32s = Lucene.Net.Util.Packed.PackedInt32s;
 
     /// <summary>
     /// <seealso cref="DocIdSet"/> implementation based on word-aligned hybrid encoding on
@@ -86,7 +86,7 @@ namespace Lucene.Net.Util
         /// Default index interval. </summary>
         public const int DEFAULT_INDEX_INTERVAL = 24;
 
-        private static readonly MonotonicAppendingLongBuffer SINGLE_ZERO_BUFFER = new MonotonicAppendingLongBuffer(1, 64, PackedInts.COMPACT);
+        private static readonly MonotonicAppendingInt64Buffer SINGLE_ZERO_BUFFER = new MonotonicAppendingInt64Buffer(1, 64, PackedInt32s.COMPACT);
         private static WAH8DocIdSet EMPTY = new WAH8DocIdSet(new byte[0], 0, 1, SINGLE_ZERO_BUFFER, SINGLE_ZERO_BUFFER);
 
         static WAH8DocIdSet()
@@ -467,7 +467,7 @@ namespace Lucene.Net.Util
 
                 // Now build the index
                 int valueCount = (numSequences - 1) / indexInterval + 1;
-                MonotonicAppendingLongBuffer indexPositions, indexWordNums;
+                MonotonicAppendingInt64Buffer indexPositions, indexWordNums;
                 if (valueCount <= 1)
                 {
                     indexPositions = indexWordNums = SINGLE_ZERO_BUFFER;
@@ -476,8 +476,8 @@ namespace Lucene.Net.Util
                 {
                     const int pageSize = 128;
                     int initialPageCount = (valueCount + pageSize - 1) / pageSize;
-                    MonotonicAppendingLongBuffer positions = new MonotonicAppendingLongBuffer(initialPageCount, pageSize, PackedInts.COMPACT);
-                    MonotonicAppendingLongBuffer wordNums = new MonotonicAppendingLongBuffer(initialPageCount, pageSize, PackedInts.COMPACT);
+                    MonotonicAppendingInt64Buffer positions = new MonotonicAppendingInt64Buffer(initialPageCount, pageSize, PackedInt32s.COMPACT);
+                    MonotonicAppendingInt64Buffer wordNums = new MonotonicAppendingInt64Buffer(initialPageCount, pageSize, PackedInt32s.COMPACT);
 
                     positions.Add(0L);
                     wordNums.Add(0L);
@@ -586,9 +586,9 @@ namespace Lucene.Net.Util
         private readonly int indexInterval;
 
         // index for advance(int)
-        private readonly MonotonicAppendingLongBuffer positions, wordNums; // wordNums[i] starts at the sequence at positions[i]
+        private readonly MonotonicAppendingInt64Buffer positions, wordNums; // wordNums[i] starts at the sequence at positions[i]
 
-        internal WAH8DocIdSet(byte[] data, int cardinality, int indexInterval, MonotonicAppendingLongBuffer positions, MonotonicAppendingLongBuffer wordNums)
+        internal WAH8DocIdSet(byte[] data, int cardinality, int indexInterval, MonotonicAppendingInt64Buffer positions, MonotonicAppendingInt64Buffer wordNums)
         {
             this.data = data;
             this.cardinality = cardinality;
@@ -651,7 +651,7 @@ namespace Lucene.Net.Util
             internal readonly ByteArrayDataInput @in;
             internal readonly int cardinality;
             internal readonly int indexInterval;
-            internal readonly MonotonicAppendingLongBuffer positions, wordNums;
+            internal readonly MonotonicAppendingInt64Buffer positions, wordNums;
             internal readonly int indexThreshold;
             internal int allOnesLength;
             internal int dirtyLength;
@@ -663,7 +663,7 @@ namespace Lucene.Net.Util
 
             internal int docID;
 
-            internal Iterator(byte[] data, int cardinality, int indexInterval, MonotonicAppendingLongBuffer positions, MonotonicAppendingLongBuffer wordNums)
+            internal Iterator(byte[] data, int cardinality, int indexInterval, MonotonicAppendingInt64Buffer positions, MonotonicAppendingInt64Buffer wordNums)
             {
                 this.@in = new ByteArrayDataInput(data);
                 this.cardinality = cardinality;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Expressions/SimpleBindings.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Expressions/SimpleBindings.cs b/src/Lucene.Net.Expressions/SimpleBindings.cs
index b1f65f0..dd8747e 100644
--- a/src/Lucene.Net.Expressions/SimpleBindings.cs
+++ b/src/Lucene.Net.Expressions/SimpleBindings.cs
@@ -92,17 +92,17 @@ namespace Lucene.Net.Expressions
             {
                 case SortFieldType.INT:
                     {
-                        return new IntFieldSource(field.Field, (FieldCache.IIntParser)field.Parser);
+                        return new IntFieldSource(field.Field, (FieldCache.IInt32Parser)field.Parser);
                     }
 
                 case SortFieldType.LONG:
                     {
-                        return new LongFieldSource(field.Field, (FieldCache.ILongParser)field.Parser);
+                        return new LongFieldSource(field.Field, (FieldCache.IInt64Parser)field.Parser);
                     }
 
                 case SortFieldType.FLOAT:
                     {
-                        return new FloatFieldSource(field.Field, (FieldCache.IFloatParser)field.Parser);
+                        return new FloatFieldSource(field.Field, (FieldCache.ISingleParser)field.Parser);
                     }
 
                 case SortFieldType.DOUBLE:

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Facet/FacetsConfig.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Facet/FacetsConfig.cs b/src/Lucene.Net.Facet/FacetsConfig.cs
index adb1af0..61fe046 100644
--- a/src/Lucene.Net.Facet/FacetsConfig.cs
+++ b/src/Lucene.Net.Facet/FacetsConfig.cs
@@ -36,7 +36,7 @@ namespace Lucene.Net.Facet
     using IIndexableField = Lucene.Net.Index.IIndexableField;
     using IIndexableFieldType = Lucene.Net.Index.IIndexableFieldType;
     using IntAssociationFacetField = Lucene.Net.Facet.Taxonomy.IntAssociationFacetField;
-    using IntsRef = Lucene.Net.Util.IntsRef;
+    using Int32sRef = Lucene.Net.Util.Int32sRef;
     using SortedSetDocValuesFacetField = Lucene.Net.Facet.SortedSet.SortedSetDocValuesFacetField;
     using SortedSetDocValuesField = Lucene.Net.Documents.SortedSetDocValuesField;
     using StringField = Lucene.Net.Documents.StringField;
@@ -411,7 +411,7 @@ namespace Lucene.Net.Facet
                 string indexFieldName = ent.Key;
                 //System.out.println("  indexFieldName=" + indexFieldName + " fields=" + ent.getValue());
 
-                IntsRef ordinals = new IntsRef(32);
+                Int32sRef ordinals = new Int32sRef(32);
                 foreach (FacetField facetField in ent.Value)
                 {
 
@@ -536,7 +536,7 @@ namespace Lucene.Net.Facet
         /// Encodes ordinals into a <see cref="BytesRef"/>; expert: subclass can
         /// override this to change encoding. 
         /// </summary>
-        protected virtual BytesRef DedupAndEncode(IntsRef ordinals)
+        protected virtual BytesRef DedupAndEncode(Int32sRef ordinals)
         {
             Array.Sort(ordinals.Int32s, ordinals.Offset, ordinals.Length);
             byte[] bytes = new byte[5 * ordinals.Length];

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Facet/Range/DoubleRangeFacetCounts.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Facet/Range/DoubleRangeFacetCounts.cs b/src/Lucene.Net.Facet/Range/DoubleRangeFacetCounts.cs
index c37f999..bf9c03e 100644
--- a/src/Lucene.Net.Facet/Range/DoubleRangeFacetCounts.cs
+++ b/src/Lucene.Net.Facet/Range/DoubleRangeFacetCounts.cs
@@ -39,7 +39,7 @@ namespace Lucene.Net.Facet.Range
     ///  distance from the user's location, "&lt; 1 km", "&lt; 2 km",
     ///  etc.).
     /// 
-    ///  <para> If you had indexed your field using <see cref="Documents.FloatDocValuesField"/> 
+    ///  <para> If you had indexed your field using <see cref="Documents.SingleDocValuesField"/> 
     ///  then pass <see cref="Queries.Function.ValueSources.FloatFieldSource"/>
     ///  as the <see cref="ValueSource"/>; if you used 
     ///  <see cref="Documents.DoubleDocValuesField"/> then pass 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Facet/Taxonomy/CachedOrdinalsReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Facet/Taxonomy/CachedOrdinalsReader.cs b/src/Lucene.Net.Facet/Taxonomy/CachedOrdinalsReader.cs
index a3dd984..9e2cbd0 100644
--- a/src/Lucene.Net.Facet/Taxonomy/CachedOrdinalsReader.cs
+++ b/src/Lucene.Net.Facet/Taxonomy/CachedOrdinalsReader.cs
@@ -28,7 +28,7 @@ namespace Lucene.Net.Facet.Taxonomy
     using ArrayUtil = Lucene.Net.Util.ArrayUtil;
     using DocValuesFormat = Lucene.Net.Codecs.DocValuesFormat;
     using AtomicReaderContext = Lucene.Net.Index.AtomicReaderContext;
-    using IntsRef = Lucene.Net.Util.IntsRef;
+    using Int32sRef = Lucene.Net.Util.Int32sRef;
     using RamUsageEstimator = Lucene.Net.Util.RamUsageEstimator;
 
     /// <summary>
@@ -114,7 +114,7 @@ namespace Lucene.Net.Facet.Taxonomy
                 this.cachedOrds = cachedOrds;
             }
 
-            public override void Get(int docID, IntsRef ordinals)
+            public override void Get(int docID, Int32sRef ordinals)
             {
                 ordinals.Int32s = cachedOrds.Ordinals;
                 ordinals.Offset = cachedOrds.Offsets[docID];
@@ -152,7 +152,7 @@ namespace Lucene.Net.Facet.Taxonomy
 
                 // this aggregator is limited to Integer.MAX_VALUE total ordinals.
                 long totOrds = 0;
-                IntsRef values = new IntsRef(32);
+                Int32sRef values = new Int32sRef(32);
                 for (int docID = 0; docID < maxDoc; docID++)
                 {
                     Offsets[docID] = (int)totOrds;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Facet/Taxonomy/Directory/DirectoryTaxonomyWriter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Facet/Taxonomy/Directory/DirectoryTaxonomyWriter.cs b/src/Lucene.Net.Facet/Taxonomy/Directory/DirectoryTaxonomyWriter.cs
index c8fcbd6..283904f 100644
--- a/src/Lucene.Net.Facet/Taxonomy/Directory/DirectoryTaxonomyWriter.cs
+++ b/src/Lucene.Net.Facet/Taxonomy/Directory/DirectoryTaxonomyWriter.cs
@@ -89,7 +89,7 @@ namespace Lucene.Net.Facet.Taxonomy.Directory
         private readonly Directory dir;
         private readonly IndexWriter indexWriter;
         private readonly ITaxonomyWriterCache cache;
-        private readonly AtomicInteger cacheMisses = new AtomicInteger(0);
+        private readonly AtomicInt32 cacheMisses = new AtomicInt32(0);
 
         // Records the taxonomy index epoch, updated on replaceTaxonomy as well.
         private long indexEpoch;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Facet/Taxonomy/DocValuesOrdinalsReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Facet/Taxonomy/DocValuesOrdinalsReader.cs b/src/Lucene.Net.Facet/Taxonomy/DocValuesOrdinalsReader.cs
index 22ac0e5..2652994 100644
--- a/src/Lucene.Net.Facet/Taxonomy/DocValuesOrdinalsReader.cs
+++ b/src/Lucene.Net.Facet/Taxonomy/DocValuesOrdinalsReader.cs
@@ -22,7 +22,7 @@
     using BinaryDocValues = Lucene.Net.Index.BinaryDocValues;
     using BytesRef = Lucene.Net.Util.BytesRef;
     using DocValues = Lucene.Net.Index.DocValues;
-    using IntsRef = Lucene.Net.Util.IntsRef;
+    using Int32sRef = Lucene.Net.Util.Int32sRef;
 
     /// <summary>
     /// Decodes ordinals previously indexed into a <see cref="BinaryDocValues"/> field
@@ -72,7 +72,7 @@
                 this.values = values;
             }
 
-            public override void Get(int docID, IntsRef ordinals)
+            public override void Get(int docID, Int32sRef ordinals)
             {
                 BytesRef bytes = new BytesRef();
                 values.Get(docID, bytes);
@@ -91,7 +91,7 @@
         /// <summary>
         /// Subclass &amp; override if you change the encoding.
         /// </summary>
-        protected virtual void Decode(BytesRef buf, IntsRef ordinals)
+        protected virtual void Decode(BytesRef buf, Int32sRef ordinals)
         {
 
             // grow the buffer up front, even if by a large number of values (buf.length)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Facet/Taxonomy/OrdinalsReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Facet/Taxonomy/OrdinalsReader.cs b/src/Lucene.Net.Facet/Taxonomy/OrdinalsReader.cs
index 3223b6a..2dd18d1 100644
--- a/src/Lucene.Net.Facet/Taxonomy/OrdinalsReader.cs
+++ b/src/Lucene.Net.Facet/Taxonomy/OrdinalsReader.cs
@@ -18,7 +18,7 @@
      */
 
     using AtomicReaderContext = Lucene.Net.Index.AtomicReaderContext;
-    using IntsRef = Lucene.Net.Util.IntsRef;
+    using Int32sRef = Lucene.Net.Util.Int32sRef;
 
     /// <summary>
     /// Provides per-document ordinals. 
@@ -31,10 +31,10 @@
         public abstract class OrdinalsSegmentReader
         {
             /// <summary>
-            /// Get the ordinals for this document. The <paramref name="ordinals"/>.<see cref="IntsRef.Offset"/>
+            /// Get the ordinals for this document. The <paramref name="ordinals"/>.<see cref="Int32sRef.Offset"/>
             /// must always be 0! 
             /// </summary>
-            public abstract void Get(int doc, IntsRef ordinals);
+            public abstract void Get(int doc, Int32sRef ordinals);
 
             /// <summary>
             /// Default constructor. 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Facet/Taxonomy/TaxonomyFacetCounts.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Facet/Taxonomy/TaxonomyFacetCounts.cs b/src/Lucene.Net.Facet/Taxonomy/TaxonomyFacetCounts.cs
index 3c5ce9e..181cc45 100644
--- a/src/Lucene.Net.Facet/Taxonomy/TaxonomyFacetCounts.cs
+++ b/src/Lucene.Net.Facet/Taxonomy/TaxonomyFacetCounts.cs
@@ -21,7 +21,7 @@ namespace Lucene.Net.Facet.Taxonomy
 
     using BinaryDocValues = Lucene.Net.Index.BinaryDocValues;
     using DocIdSetIterator = Lucene.Net.Search.DocIdSetIterator;
-    using IntsRef = Lucene.Net.Util.IntsRef;
+    using Int32sRef = Lucene.Net.Util.Int32sRef;
     using MatchingDocs = FacetsCollector.MatchingDocs;
 
     /// <summary>
@@ -48,7 +48,7 @@ namespace Lucene.Net.Facet.Taxonomy
 
         private void Count(IList<FacetsCollector.MatchingDocs> matchingDocs)
         {
-            IntsRef scratch = new IntsRef();
+            Int32sRef scratch = new Int32sRef();
             foreach (FacetsCollector.MatchingDocs hits in matchingDocs)
             {
                 OrdinalsReader.OrdinalsSegmentReader ords = ordinalsReader.GetReader(hits.Context);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Facet/Taxonomy/TaxonomyFacetSumValueSource.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Facet/Taxonomy/TaxonomyFacetSumValueSource.cs b/src/Lucene.Net.Facet/Taxonomy/TaxonomyFacetSumValueSource.cs
index ae5c251..b2c6473 100644
--- a/src/Lucene.Net.Facet/Taxonomy/TaxonomyFacetSumValueSource.cs
+++ b/src/Lucene.Net.Facet/Taxonomy/TaxonomyFacetSumValueSource.cs
@@ -27,7 +27,7 @@ namespace Lucene.Net.Facet.Taxonomy
     using DocIdSetIterator = Lucene.Net.Search.DocIdSetIterator;
     using DoubleDocValues = Lucene.Net.Queries.Function.DocValues.DoubleDocValues;
     using FunctionValues = Lucene.Net.Queries.Function.FunctionValues;
-    using IntsRef = Lucene.Net.Util.IntsRef;
+    using Int32sRef = Lucene.Net.Util.Int32sRef;
     using MatchingDocs = FacetsCollector.MatchingDocs;
     using Scorer = Lucene.Net.Search.Scorer;
     using ValueSource = Lucene.Net.Queries.Function.ValueSource;
@@ -123,7 +123,7 @@ namespace Lucene.Net.Facet.Taxonomy
             {
                 context["scorer"] = scorer;
             }
-            IntsRef scratch = new IntsRef();
+            Int32sRef scratch = new Int32sRef();
             foreach (MatchingDocs hits in matchingDocs)
             {
                 OrdinalsReader.OrdinalsSegmentReader ords = ordinalsReader.GetReader(hits.Context);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Facet/Taxonomy/TaxonomyReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Facet/Taxonomy/TaxonomyReader.cs b/src/Lucene.Net.Facet/Taxonomy/TaxonomyReader.cs
index b02d5f2..dc3cf84 100644
--- a/src/Lucene.Net.Facet/Taxonomy/TaxonomyReader.cs
+++ b/src/Lucene.Net.Facet/Taxonomy/TaxonomyReader.cs
@@ -144,7 +144,7 @@ namespace Lucene.Net.Facet.Taxonomy
         private volatile bool closed = false;
 
         // set refCount to 1 at start
-        private readonly AtomicInteger refCount = new AtomicInteger(1);
+        private readonly AtomicInt32 refCount = new AtomicInt32(1);
 
         /// <summary>
         /// performs the actual task of closing the resources that are used by the

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Grouping/Term/TermAllGroupHeadsCollector.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Grouping/Term/TermAllGroupHeadsCollector.cs b/src/Lucene.Net.Grouping/Term/TermAllGroupHeadsCollector.cs
index e3c68dc..bd2c079 100644
--- a/src/Lucene.Net.Grouping/Term/TermAllGroupHeadsCollector.cs
+++ b/src/Lucene.Net.Grouping/Term/TermAllGroupHeadsCollector.cs
@@ -269,7 +269,7 @@ namespace Lucene.Net.Search.Grouping.Terms
     /// </summary>
     internal class OrdScoreAllGroupHeadsCollector : TermAllGroupHeadsCollector<OrdScoreAllGroupHeadsCollector.GroupHead>
     {
-        private readonly SentinelIntSet ordSet;
+        private readonly SentinelInt32Set ordSet;
         private readonly IList<GroupHead> collectedGroups;
         private readonly SortField[] fields;
 
@@ -280,7 +280,7 @@ namespace Lucene.Net.Search.Grouping.Terms
         internal OrdScoreAllGroupHeadsCollector(string groupField, Sort sortWithinGroup, int initialSize)
             : base(groupField, sortWithinGroup.GetSort().Length)
         {
-            ordSet = new SentinelIntSet(initialSize, -2);
+            ordSet = new SentinelInt32Set(initialSize, -2);
             collectedGroups = new List<GroupHead>(initialSize);
 
             SortField[] sortFields = sortWithinGroup.GetSort();
@@ -500,7 +500,7 @@ namespace Lucene.Net.Search.Grouping.Terms
     /// </summary>
     internal class OrdAllGroupHeadsCollector : TermAllGroupHeadsCollector<OrdAllGroupHeadsCollector.GroupHead>
     {
-        private readonly SentinelIntSet ordSet;
+        private readonly SentinelInt32Set ordSet;
         private readonly IList<GroupHead> collectedGroups;
         private readonly SortField[] fields;
 
@@ -510,7 +510,7 @@ namespace Lucene.Net.Search.Grouping.Terms
         internal OrdAllGroupHeadsCollector(string groupField, Sort sortWithinGroup, int initialSize)
                     : base(groupField, sortWithinGroup.GetSort().Length)
         {
-            ordSet = new SentinelIntSet(initialSize, -2);
+            ordSet = new SentinelInt32Set(initialSize, -2);
             collectedGroups = new List<GroupHead>(initialSize);
 
             SortField[] sortFields = sortWithinGroup.GetSort();
@@ -688,7 +688,7 @@ namespace Lucene.Net.Search.Grouping.Terms
     /// </summary>
     internal class ScoreAllGroupHeadsCollector : TermAllGroupHeadsCollector<ScoreAllGroupHeadsCollector.GroupHead>
     {
-        private readonly SentinelIntSet ordSet;
+        private readonly SentinelInt32Set ordSet;
         private readonly IList<GroupHead> collectedGroups;
         private readonly SortField[] fields;
 
@@ -698,7 +698,7 @@ namespace Lucene.Net.Search.Grouping.Terms
         internal ScoreAllGroupHeadsCollector(string groupField, Sort sortWithinGroup, int initialSize)
                     : base(groupField, sortWithinGroup.GetSort().Length)
         {
-            ordSet = new SentinelIntSet(initialSize, -2);
+            ordSet = new SentinelInt32Set(initialSize, -2);
             collectedGroups = new List<GroupHead>(initialSize);
 
             SortField[] sortFields = sortWithinGroup.GetSort();

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Grouping/Term/TermAllGroupsCollector.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Grouping/Term/TermAllGroupsCollector.cs b/src/Lucene.Net.Grouping/Term/TermAllGroupsCollector.cs
index d8506ce..1391f3d 100644
--- a/src/Lucene.Net.Grouping/Term/TermAllGroupsCollector.cs
+++ b/src/Lucene.Net.Grouping/Term/TermAllGroupsCollector.cs
@@ -42,7 +42,7 @@ namespace Lucene.Net.Search.Grouping.Terms
         private static readonly int DEFAULT_INITIAL_SIZE = 128;
 
         private readonly String groupField;
-        private readonly SentinelIntSet ordSet;
+        private readonly SentinelInt32Set ordSet;
         private readonly IList<BytesRef> groups;
 
         private SortedDocValues index;
@@ -60,7 +60,7 @@ namespace Lucene.Net.Search.Grouping.Terms
         /// </param>
         public TermAllGroupsCollector(string groupField, int initialSize)
         {
-            ordSet = new SentinelIntSet(initialSize, -2);
+            ordSet = new SentinelInt32Set(initialSize, -2);
             groups = new List<BytesRef>(initialSize);
             this.groupField = groupField;
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Grouping/Term/TermDistinctValuesCollector.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Grouping/Term/TermDistinctValuesCollector.cs b/src/Lucene.Net.Grouping/Term/TermDistinctValuesCollector.cs
index fd186cb..3e0fc8f 100644
--- a/src/Lucene.Net.Grouping/Term/TermDistinctValuesCollector.cs
+++ b/src/Lucene.Net.Grouping/Term/TermDistinctValuesCollector.cs
@@ -35,7 +35,7 @@ namespace Lucene.Net.Search.Grouping.Terms
         private readonly string groupField;
         private readonly string countField;
         private readonly List<GroupCount> groups;
-        private readonly SentinelIntSet ordSet;
+        private readonly SentinelInt32Set ordSet;
         private readonly GroupCount[] groupCounts;
 
         private SortedDocValues groupFieldTermIndex;
@@ -57,7 +57,7 @@ namespace Lucene.Net.Search.Grouping.Terms
             {
                 this.groups.Add(new GroupCount(group.GroupValue));
             }
-            ordSet = new SentinelIntSet(groupCount, -2);
+            ordSet = new SentinelInt32Set(groupCount, -2);
             groupCounts = new GroupCount[ordSet.Keys.Length];
         }
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Grouping/Term/TermGroupFacetCollector.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Grouping/Term/TermGroupFacetCollector.cs b/src/Lucene.Net.Grouping/Term/TermGroupFacetCollector.cs
index 03ac2fd..f1382b6 100644
--- a/src/Lucene.Net.Grouping/Term/TermGroupFacetCollector.cs
+++ b/src/Lucene.Net.Grouping/Term/TermGroupFacetCollector.cs
@@ -31,7 +31,7 @@ namespace Lucene.Net.Search.Grouping.Terms
     public abstract class TermGroupFacetCollector : AbstractGroupFacetCollector
     {
         internal readonly List<GroupedFacetHit> groupedFacetHits;
-        internal readonly SentinelIntSet segmentGroupedFacetHits;
+        internal readonly SentinelInt32Set segmentGroupedFacetHits;
 
         internal SortedDocValues groupFieldTermsIndex;
 
@@ -69,7 +69,7 @@ namespace Lucene.Net.Search.Grouping.Terms
             : base(groupField, facetField, facetPrefix)
         {
             groupedFacetHits = new List<GroupedFacetHit>(initialSize);
-            segmentGroupedFacetHits = new SentinelIntSet(initialSize, int.MinValue);
+            segmentGroupedFacetHits = new SentinelInt32Set(initialSize, int.MinValue);
         }
 
         /// <summary>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Grouping/Term/TermSecondPassGroupingCollector.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Grouping/Term/TermSecondPassGroupingCollector.cs b/src/Lucene.Net.Grouping/Term/TermSecondPassGroupingCollector.cs
index a0924a6..8dcb462 100644
--- a/src/Lucene.Net.Grouping/Term/TermSecondPassGroupingCollector.cs
+++ b/src/Lucene.Net.Grouping/Term/TermSecondPassGroupingCollector.cs
@@ -30,7 +30,7 @@ namespace Lucene.Net.Search.Grouping.Terms
     /// </summary>
     public class TermSecondPassGroupingCollector : AbstractSecondPassGroupingCollector<BytesRef>
     {
-        private readonly SentinelIntSet ordSet;
+        private readonly SentinelInt32Set ordSet;
         private SortedDocValues index;
         private readonly string groupField;
 
@@ -38,7 +38,7 @@ namespace Lucene.Net.Search.Grouping.Terms
                                                int maxDocsPerGroup, bool getScores, bool getMaxScores, bool fillSortFields)
                   : base(groups, groupSort, withinGroupSort, maxDocsPerGroup, getScores, getMaxScores, fillSortFields)
         {
-            ordSet = new SentinelIntSet(m_groupMap.Count, -2);
+            ordSet = new SentinelInt32Set(m_groupMap.Count, -2);
             this.groupField = groupField;
             m_groupDocs = /*(SearchGroupDocs<BytesRef>[])*/ new AbstractSecondPassGroupingCollector.SearchGroupDocs<BytesRef>[ordSet.Keys.Length];
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Memory/MemoryIndex.MemoryIndexReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Memory/MemoryIndex.MemoryIndexReader.cs b/src/Lucene.Net.Memory/MemoryIndex.MemoryIndexReader.cs
index 2be3ad6..636925f 100644
--- a/src/Lucene.Net.Memory/MemoryIndex.MemoryIndexReader.cs
+++ b/src/Lucene.Net.Memory/MemoryIndex.MemoryIndexReader.cs
@@ -476,7 +476,7 @@ namespace Lucene.Net.Index.Memory
                 internal bool hasNext;
                 internal IBits liveDocs;
                 internal int doc = -1;
-                internal IntBlockPool.SliceReader sliceReader;
+                internal Int32BlockPool.SliceReader sliceReader;
                 internal int freq_Renamed;
                 internal int startOffset_Renamed;
                 internal int endOffset_Renamed;
@@ -484,7 +484,7 @@ namespace Lucene.Net.Index.Memory
                 public MemoryDocsAndPositionsEnum(MemoryIndex.MemoryIndexReader outerInstance)
                 {
                     this.outerInstance = outerInstance;
-                    this.sliceReader = new IntBlockPool.SliceReader(outerInstance.outerInstance.intBlockPool);
+                    this.sliceReader = new Int32BlockPool.SliceReader(outerInstance.outerInstance.intBlockPool);
                 }
 
                 public virtual DocsAndPositionsEnum Reset(IBits liveDocs, int start, int end, int freq)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Memory/MemoryIndex.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Memory/MemoryIndex.cs b/src/Lucene.Net.Memory/MemoryIndex.cs
index 2923214..1d46b1b 100644
--- a/src/Lucene.Net.Memory/MemoryIndex.cs
+++ b/src/Lucene.Net.Memory/MemoryIndex.cs
@@ -174,9 +174,9 @@ namespace Lucene.Net.Index.Memory
         private readonly bool storeOffsets;
 
         private readonly ByteBlockPool byteBlockPool;
-        private readonly IntBlockPool intBlockPool;
+        private readonly Int32BlockPool intBlockPool;
         //  private final IntBlockPool.SliceReader postingsReader;
-        private readonly IntBlockPool.SliceWriter postingsWriter;
+        private readonly Int32BlockPool.SliceWriter postingsWriter;
 
         private Dictionary<string, FieldInfo> fieldInfos = new Dictionary<string, FieldInfo>();
 
@@ -215,11 +215,11 @@ namespace Lucene.Net.Index.Memory
             this.storeOffsets = storeOffsets;
             this.bytesUsed = Counter.NewCounter();
             int maxBufferedByteBlocks = (int)((maxReusedBytes / 2) / ByteBlockPool.BYTE_BLOCK_SIZE);
-            int maxBufferedIntBlocks = (int)((maxReusedBytes - (maxBufferedByteBlocks * ByteBlockPool.BYTE_BLOCK_SIZE)) / (IntBlockPool.INT_BLOCK_SIZE * RamUsageEstimator.NUM_BYTES_INT));
-            Debug.Assert((maxBufferedByteBlocks * ByteBlockPool.BYTE_BLOCK_SIZE) + (maxBufferedIntBlocks * IntBlockPool.INT_BLOCK_SIZE * RamUsageEstimator.NUM_BYTES_INT) <= maxReusedBytes);
+            int maxBufferedIntBlocks = (int)((maxReusedBytes - (maxBufferedByteBlocks * ByteBlockPool.BYTE_BLOCK_SIZE)) / (Int32BlockPool.INT_BLOCK_SIZE * RamUsageEstimator.NUM_BYTES_INT));
+            Debug.Assert((maxBufferedByteBlocks * ByteBlockPool.BYTE_BLOCK_SIZE) + (maxBufferedIntBlocks * Int32BlockPool.INT_BLOCK_SIZE * RamUsageEstimator.NUM_BYTES_INT) <= maxReusedBytes);
             byteBlockPool = new ByteBlockPool(new RecyclingByteBlockAllocator(ByteBlockPool.BYTE_BLOCK_SIZE, maxBufferedByteBlocks, bytesUsed));
-            intBlockPool = new IntBlockPool(new RecyclingIntBlockAllocator(IntBlockPool.INT_BLOCK_SIZE, maxBufferedIntBlocks, bytesUsed));
-            postingsWriter = new IntBlockPool.SliceWriter(intBlockPool);
+            intBlockPool = new Int32BlockPool(new RecyclingInt32BlockAllocator(Int32BlockPool.INT_BLOCK_SIZE, maxBufferedIntBlocks, bytesUsed));
+            postingsWriter = new Int32BlockPool.SliceWriter(intBlockPool);
         }
 
         /// <summary>
@@ -656,7 +656,7 @@ namespace Lucene.Net.Index.Memory
                 result.Append(fieldName + ":\n");
                 SliceByteStartArray sliceArray = info.sliceArray;
                 int numPositions = 0;
-                IntBlockPool.SliceReader postingsReader = new IntBlockPool.SliceReader(intBlockPool);
+                Int32BlockPool.SliceReader postingsReader = new Int32BlockPool.SliceReader(intBlockPool);
                 for (int j = 0; j < info.terms.Count; j++)
                 {
                     int ord = info.sortedTerms[j];

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Misc/Index/Sorter/Sorter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Misc/Index/Sorter/Sorter.cs b/src/Lucene.Net.Misc/Index/Sorter/Sorter.cs
index f0be656..8b48091 100644
--- a/src/Lucene.Net.Misc/Index/Sorter/Sorter.cs
+++ b/src/Lucene.Net.Misc/Index/Sorter/Sorter.cs
@@ -189,7 +189,7 @@ namespace Lucene.Net.Index.Sorter
             // The reason why we use MonotonicAppendingLongBuffer here is that it
             // wastes very little memory if the index is in random order but can save
             // a lot of memory if the index is already "almost" sorted
-            MonotonicAppendingLongBuffer newToOld = new MonotonicAppendingLongBuffer();
+            MonotonicAppendingInt64Buffer newToOld = new MonotonicAppendingInt64Buffer();
             for (int i = 0; i < maxDoc; ++i)
             {
                 newToOld.Add(docs[i]);
@@ -201,7 +201,7 @@ namespace Lucene.Net.Index.Sorter
                 docs[(int)newToOld.Get(i)] = i;
             } // docs is now the oldToNew mapping
 
-            MonotonicAppendingLongBuffer oldToNew = new MonotonicAppendingLongBuffer();
+            MonotonicAppendingInt64Buffer oldToNew = new MonotonicAppendingInt64Buffer();
             for (int i = 0; i < maxDoc; ++i)
             {
                 oldToNew.Add(docs[i]);
@@ -214,10 +214,10 @@ namespace Lucene.Net.Index.Sorter
         private class DocMapAnonymousInnerClassHelper : Sorter.DocMap
         {
             private int maxDoc;
-            private MonotonicAppendingLongBuffer newToOld;
-            private MonotonicAppendingLongBuffer oldToNew;
+            private MonotonicAppendingInt64Buffer newToOld;
+            private MonotonicAppendingInt64Buffer oldToNew;
 
-            public DocMapAnonymousInnerClassHelper(int maxDoc, MonotonicAppendingLongBuffer newToOld, MonotonicAppendingLongBuffer oldToNew)
+            public DocMapAnonymousInnerClassHelper(int maxDoc, MonotonicAppendingInt64Buffer newToOld, MonotonicAppendingInt64Buffer oldToNew)
             {
                 this.maxDoc = maxDoc;
                 this.newToOld = newToOld;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Misc/Index/Sorter/SortingMergePolicy.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Misc/Index/Sorter/SortingMergePolicy.cs b/src/Lucene.Net.Misc/Index/Sorter/SortingMergePolicy.cs
index 168be09..e46647b 100644
--- a/src/Lucene.Net.Misc/Index/Sorter/SortingMergePolicy.cs
+++ b/src/Lucene.Net.Misc/Index/Sorter/SortingMergePolicy.cs
@@ -103,9 +103,9 @@ namespace Lucene.Net.Index.Sorter
                 }
             }
 
-            internal virtual MonotonicAppendingLongBuffer GetDeletes(IList<AtomicReader> readers)
+            internal virtual MonotonicAppendingInt64Buffer GetDeletes(IList<AtomicReader> readers)
             {
-                MonotonicAppendingLongBuffer deletes = new MonotonicAppendingLongBuffer();
+                MonotonicAppendingInt64Buffer deletes = new MonotonicAppendingInt64Buffer();
                 int deleteCount = 0;
                 foreach (AtomicReader reader in readers)
                 {
@@ -138,7 +138,7 @@ namespace Lucene.Net.Index.Sorter
                     return base.GetDocMap(mergeState);
                 }
                 Debug.Assert(mergeState.DocMaps.Length == 1); // we returned a singleton reader
-                MonotonicAppendingLongBuffer deletes = GetDeletes(unsortedReaders);
+                MonotonicAppendingInt64Buffer deletes = GetDeletes(unsortedReaders);
                 return new DocMapAnonymousInnerClassHelper(this, mergeState, deletes);
             }
 
@@ -147,9 +147,9 @@ namespace Lucene.Net.Index.Sorter
                 private readonly SortingOneMerge outerInstance;
 
                 private MergeState mergeState;
-                private MonotonicAppendingLongBuffer deletes;
+                private MonotonicAppendingInt64Buffer deletes;
 
-                public DocMapAnonymousInnerClassHelper(SortingOneMerge outerInstance, MergeState mergeState, MonotonicAppendingLongBuffer deletes)
+                public DocMapAnonymousInnerClassHelper(SortingOneMerge outerInstance, MergeState mergeState, MonotonicAppendingInt64Buffer deletes)
                 {
                     this.outerInstance = outerInstance;
                     this.mergeState = mergeState;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Misc/Util/Fst/ListOfOutputs.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Misc/Util/Fst/ListOfOutputs.cs b/src/Lucene.Net.Misc/Util/Fst/ListOfOutputs.cs
index bf5a057..5bc303b 100644
--- a/src/Lucene.Net.Misc/Util/Fst/ListOfOutputs.cs
+++ b/src/Lucene.Net.Misc/Util/Fst/ListOfOutputs.cs
@@ -28,7 +28,7 @@ namespace Lucene.Net.Util.Fst
     /// more of its output values.  You can use this when a single
     /// input may need to map to more than one output,
     /// maintaining order: pass the same input with a different
-    /// output by calling <see cref="Builder{T}.Add(IntsRef,T)"/> multiple
+    /// output by calling <see cref="Builder{T}.Add(Int32sRef,T)"/> multiple
     /// times.  The builder will then combine the outputs using
     /// the <see cref="Outputs{T}.Merge(T,T)"/> method.
     /// 
@@ -40,7 +40,7 @@ namespace Lucene.Net.Util.Fst
     /// <para>NOTE: the only way to create multiple outputs is to
     /// add the same input to the FST multiple times in a row.  This is
     /// how the FST maps a single input to multiple outputs (e.g. you
-    /// cannot pass a List&lt;Object&gt; to <see cref="Builder{T}.Add(IntsRef, T)"/>).  If
+    /// cannot pass a List&lt;Object&gt; to <see cref="Builder{T}.Add(Int32sRef, T)"/>).  If
     /// your outputs are longs, and you need at most 2, then use
     /// <see cref="UpToTwoPositiveIntOutputs"/> instead since it stores
     /// the outputs more compactly (by stealing a bit from each

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Misc/Util/Fst/UpToTwoPositiveIntOutputs.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Misc/Util/Fst/UpToTwoPositiveIntOutputs.cs b/src/Lucene.Net.Misc/Util/Fst/UpToTwoPositiveIntOutputs.cs
index c4db55a..0a21fb2 100644
--- a/src/Lucene.Net.Misc/Util/Fst/UpToTwoPositiveIntOutputs.cs
+++ b/src/Lucene.Net.Misc/Util/Fst/UpToTwoPositiveIntOutputs.cs
@@ -34,7 +34,7 @@ namespace Lucene.Net.Util.Fst
     /// <para>NOTE: the only way to create a TwoLongs output is to
     /// add the same input to the FST twice in a row.  This is
     /// how the FST maps a single input to two outputs (e.g. you
-    /// cannot pass a <see cref="TwoLongs"/> to <see cref="Builder{T}.Add(IntsRef, T)"/>.  If you
+    /// cannot pass a <see cref="TwoLongs"/> to <see cref="Builder{T}.Add(Int32sRef, T)"/>.  If you
     /// need more than two then use <see cref="ListOfOutputs{T}"/>, but if
     /// you only have at most 2 then this implementation will
     /// require fewer bytes as it steals one bit from each long

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Queries/Function/DocValues/FloatDocValues.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/DocValues/FloatDocValues.cs b/src/Lucene.Net.Queries/Function/DocValues/FloatDocValues.cs
index 6b0d93d..4991266 100644
--- a/src/Lucene.Net.Queries/Function/DocValues/FloatDocValues.cs
+++ b/src/Lucene.Net.Queries/Function/DocValues/FloatDocValues.cs
@@ -99,10 +99,10 @@ namespace Lucene.Net.Queries.Function.DocValues
             public ValueFillerAnonymousInnerClassHelper(FloatDocValues outerInstance)
             {
                 this.outerInstance = outerInstance;
-                mval = new MutableValueFloat();
+                mval = new MutableValueSingle();
             }
 
-            private readonly MutableValueFloat mval;
+            private readonly MutableValueSingle mval;
 
             public override MutableValue Value
             {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Queries/Function/DocValues/IntDocValues.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/DocValues/IntDocValues.cs b/src/Lucene.Net.Queries/Function/DocValues/IntDocValues.cs
index 1b78344..2173e8c 100644
--- a/src/Lucene.Net.Queries/Function/DocValues/IntDocValues.cs
+++ b/src/Lucene.Net.Queries/Function/DocValues/IntDocValues.cs
@@ -162,10 +162,10 @@ namespace Lucene.Net.Queries.Function.DocValues
             public ValueFillerAnonymousInnerClassHelper(IntDocValues outerInstance)
             {
                 this.outerInstance = outerInstance;
-                mval = new MutableValueInt();
+                mval = new MutableValueInt32();
             }
 
-            private readonly MutableValueInt mval;
+            private readonly MutableValueInt32 mval;
 
             public override MutableValue Value
             {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Queries/Function/DocValues/LongDocValues.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/DocValues/LongDocValues.cs b/src/Lucene.Net.Queries/Function/DocValues/LongDocValues.cs
index 851db41..afc059e 100644
--- a/src/Lucene.Net.Queries/Function/DocValues/LongDocValues.cs
+++ b/src/Lucene.Net.Queries/Function/DocValues/LongDocValues.cs
@@ -172,10 +172,10 @@ namespace Lucene.Net.Queries.Function.DocValues
             public ValueFillerAnonymousInnerClassHelper(LongDocValues outerInstance)
             {
                 this.outerInstance = outerInstance;
-                mval = new MutableValueLong();
+                mval = new MutableValueInt64();
             }
 
-            private readonly MutableValueLong mval;
+            private readonly MutableValueInt64 mval;
 
             public override MutableValue Value
             {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Queries/Function/FunctionValues.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/FunctionValues.cs b/src/Lucene.Net.Queries/Function/FunctionValues.cs
index d2f4063..9f2e296 100644
--- a/src/Lucene.Net.Queries/Function/FunctionValues.cs
+++ b/src/Lucene.Net.Queries/Function/FunctionValues.cs
@@ -167,10 +167,10 @@ namespace Lucene.Net.Queries.Function
             public ValueFillerAnonymousInnerClassHelper(FunctionValues outerInstance)
             {
                 this.outerInstance = outerInstance;
-                mval = new MutableValueFloat();
+                mval = new MutableValueSingle();
             }
 
-            private readonly MutableValueFloat mval;
+            private readonly MutableValueSingle mval;
 
             public override MutableValue Value
             {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Queries/Function/ValueSources/EnumFieldSource.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/EnumFieldSource.cs b/src/Lucene.Net.Queries/Function/ValueSources/EnumFieldSource.cs
index 747c0b4..7092e78 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/EnumFieldSource.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/EnumFieldSource.cs
@@ -36,11 +36,11 @@ namespace Lucene.Net.Queries.Function.ValueSources
     {
         private const int DEFAULT_VALUE = -1;
 
-        private readonly FieldCache.IIntParser parser;
+        private readonly FieldCache.IInt32Parser parser;
         private readonly IDictionary<int?, string> enumIntToStringMap;
         private readonly IDictionary<string, int?> enumStringToIntMap;
 
-        public EnumFieldSource(string field, FieldCache.IIntParser parser, IDictionary<int?, string> enumIntToStringMap, IDictionary<string, int?> enumStringToIntMap)
+        public EnumFieldSource(string field, FieldCache.IInt32Parser parser, IDictionary<int?, string> enumIntToStringMap, IDictionary<string, int?> enumStringToIntMap)
             : base(field)
         {
             this.parser = parser;
@@ -133,19 +133,19 @@ namespace Lucene.Net.Queries.Function.ValueSources
         {
             private readonly EnumFieldSource outerInstance;
 
-            private readonly FieldCache.Ints arr;
+            private readonly FieldCache.Int32s arr;
             private readonly IBits valid;
 
-            public IntDocValuesAnonymousInnerClassHelper(EnumFieldSource outerInstance, EnumFieldSource @this, FieldCache.Ints arr, IBits valid)
+            public IntDocValuesAnonymousInnerClassHelper(EnumFieldSource outerInstance, EnumFieldSource @this, FieldCache.Int32s arr, IBits valid)
                 : base(@this)
             {
                 this.outerInstance = outerInstance;
                 this.arr = arr;
                 this.valid = valid;
-                val = new MutableValueInt();
+                val = new MutableValueInt32();
             }
 
-            private readonly MutableValueInt val;
+            private readonly MutableValueInt32 val;
 
             /// <summary>
             /// NOTE: This was floatVal() in Lucene
@@ -271,10 +271,10 @@ namespace Lucene.Net.Queries.Function.ValueSources
                 public ValueFillerAnonymousInnerClassHelper(IntDocValuesAnonymousInnerClassHelper outerInstance)
                 {
                     this.outerInstance = outerInstance;
-                    mval = new MutableValueInt();
+                    mval = new MutableValueInt32();
                 }
 
-                private readonly MutableValueInt mval;
+                private readonly MutableValueInt32 mval;
 
                 public override MutableValue Value
                 {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Queries/Function/ValueSources/FloatFieldSource.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/FloatFieldSource.cs b/src/Lucene.Net.Queries/Function/ValueSources/FloatFieldSource.cs
index 7a14135..ec0732c 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/FloatFieldSource.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/FloatFieldSource.cs
@@ -30,14 +30,14 @@ namespace Lucene.Net.Queries.Function.ValueSources
     /// </summary>
     public class FloatFieldSource : FieldCacheSource
     {
-        protected readonly FieldCache.IFloatParser m_parser;
+        protected readonly FieldCache.ISingleParser m_parser;
 
         public FloatFieldSource(string field)
             : this(field, null)
         {
         }
 
-        public FloatFieldSource(string field, FieldCache.IFloatParser parser)
+        public FloatFieldSource(string field, FieldCache.ISingleParser parser)
             : base(field)
         {
             this.m_parser = parser;
@@ -57,10 +57,10 @@ namespace Lucene.Net.Queries.Function.ValueSources
 
         private class FloatDocValuesAnonymousInnerClassHelper : FloatDocValues
         {
-            private readonly FieldCache.Floats arr;
+            private readonly FieldCache.Singles arr;
             private readonly IBits valid;
 
-            public FloatDocValuesAnonymousInnerClassHelper(FloatFieldSource @this, FieldCache.Floats arr, IBits valid)
+            public FloatDocValuesAnonymousInnerClassHelper(FloatFieldSource @this, FieldCache.Singles arr, IBits valid)
                 : base(@this)
             {
                 this.arr = arr;
@@ -97,10 +97,10 @@ namespace Lucene.Net.Queries.Function.ValueSources
                 public ValueFillerAnonymousInnerClassHelper(FloatDocValuesAnonymousInnerClassHelper outerInstance)
                 {
                     this.outerInstance = outerInstance;
-                    mval = new MutableValueFloat();
+                    mval = new MutableValueSingle();
                 }
 
-                private readonly MutableValueFloat mval;
+                private readonly MutableValueSingle mval;
 
                 public override MutableValue Value
                 {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Queries/Function/ValueSources/IntFieldSource.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/IntFieldSource.cs b/src/Lucene.Net.Queries/Function/ValueSources/IntFieldSource.cs
index 0d81135..136f22a 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/IntFieldSource.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/IntFieldSource.cs
@@ -31,14 +31,14 @@ namespace Lucene.Net.Queries.Function.ValueSources
     /// </summary>
     public class IntFieldSource : FieldCacheSource
     {
-        private readonly FieldCache.IIntParser parser;
+        private readonly FieldCache.IInt32Parser parser;
 
         public IntFieldSource(string field)
             : this(field, null)
         {
         }
 
-        public IntFieldSource(string field, FieldCache.IIntParser parser)
+        public IntFieldSource(string field, FieldCache.IInt32Parser parser)
             : base(field)
         {
             this.parser = parser;
@@ -51,7 +51,7 @@ namespace Lucene.Net.Queries.Function.ValueSources
 
         public override FunctionValues GetValues(IDictionary context, AtomicReaderContext readerContext)
         {
-            FieldCache.Ints arr = m_cache.GetInt32s(readerContext.AtomicReader, m_field, parser, true);
+            FieldCache.Int32s arr = m_cache.GetInt32s(readerContext.AtomicReader, m_field, parser, true);
             IBits valid = m_cache.GetDocsWithField(readerContext.AtomicReader, m_field);
 
             return new IntDocValuesAnonymousInnerClassHelper(this, this, arr, valid);
@@ -61,19 +61,19 @@ namespace Lucene.Net.Queries.Function.ValueSources
         {
             private readonly IntFieldSource outerInstance;
 
-            private readonly FieldCache.Ints arr;
+            private readonly FieldCache.Int32s arr;
             private readonly IBits valid;
 
-            public IntDocValuesAnonymousInnerClassHelper(IntFieldSource outerInstance, IntFieldSource @this, FieldCache.Ints arr, IBits valid)
+            public IntDocValuesAnonymousInnerClassHelper(IntFieldSource outerInstance, IntFieldSource @this, FieldCache.Int32s arr, IBits valid)
                 : base(@this)
             {
                 this.outerInstance = outerInstance;
                 this.arr = arr;
                 this.valid = valid;
-                val = new MutableValueInt();
+                val = new MutableValueInt32();
             }
 
-            private readonly MutableValueInt val;
+            private readonly MutableValueInt32 val;
 
             /// <summary>
             /// NOTE: This was floatVal() in Lucene
@@ -136,10 +136,10 @@ namespace Lucene.Net.Queries.Function.ValueSources
                 public ValueFillerAnonymousInnerClassHelper(IntDocValuesAnonymousInnerClassHelper outerInstance)
                 {
                     this.outerInstance = outerInstance;
-                    mval = new MutableValueInt();
+                    mval = new MutableValueInt32();
                 }
 
-                private readonly MutableValueInt mval;
+                private readonly MutableValueInt32 mval;
 
                 public override MutableValue Value
                 {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Queries/Function/ValueSources/JoinDocFreqValueSource.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/JoinDocFreqValueSource.cs b/src/Lucene.Net.Queries/Function/ValueSources/JoinDocFreqValueSource.cs
index a9ce522..5a8d6e8 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/JoinDocFreqValueSource.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/JoinDocFreqValueSource.cs
@@ -49,7 +49,7 @@ namespace Lucene.Net.Queries.Function.ValueSources
 
         public override FunctionValues GetValues(IDictionary context, AtomicReaderContext readerContext)
         {
-            BinaryDocValues terms = m_cache.GetTerms(readerContext.AtomicReader, m_field, false, PackedInts.FAST);
+            BinaryDocValues terms = m_cache.GetTerms(readerContext.AtomicReader, m_field, false, PackedInt32s.FAST);
             IndexReader top = ReaderUtil.GetTopLevelContext(readerContext).Reader;
             Terms t = MultiFields.GetTerms(top, m_qfield);
             TermsEnum termsEnum = t == null ? TermsEnum.EMPTY : t.GetIterator(null);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Queries/Function/ValueSources/LongFieldSource.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/LongFieldSource.cs b/src/Lucene.Net.Queries/Function/ValueSources/LongFieldSource.cs
index fa0ad17..fffa459 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/LongFieldSource.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/LongFieldSource.cs
@@ -31,14 +31,14 @@ namespace Lucene.Net.Queries.Function.ValueSources
     /// </summary>
     public class LongFieldSource : FieldCacheSource
     {
-        protected readonly FieldCache.ILongParser m_parser;
+        protected readonly FieldCache.IInt64Parser m_parser;
 
         public LongFieldSource(string field)
             : this(field, null)
         {
         }
 
-        public LongFieldSource(string field, FieldCache.ILongParser parser)
+        public LongFieldSource(string field, FieldCache.IInt64Parser parser)
             : base(field)
         {
             this.m_parser = parser;
@@ -84,10 +84,10 @@ namespace Lucene.Net.Queries.Function.ValueSources
         {
             private readonly LongFieldSource outerInstance;
 
-            private readonly FieldCache.Longs arr;
+            private readonly FieldCache.Int64s arr;
             private readonly IBits valid;
 
-            public LongDocValuesAnonymousInnerClassHelper(LongFieldSource outerInstance, LongFieldSource @this, FieldCache.Longs arr, IBits valid)
+            public LongDocValuesAnonymousInnerClassHelper(LongFieldSource outerInstance, LongFieldSource @this, FieldCache.Int64s arr, IBits valid)
                 : base(@this)
             {
                 this.outerInstance = outerInstance;
@@ -141,7 +141,7 @@ namespace Lucene.Net.Queries.Function.ValueSources
                     mval = outerInstance.outerInstance.NewMutableValueInt64();
                 }
 
-                private readonly MutableValueLong mval;
+                private readonly MutableValueInt64 mval;
 
                 public override MutableValue Value
                 {
@@ -162,9 +162,9 @@ namespace Lucene.Net.Queries.Function.ValueSources
         /// <summary>
         /// NOTE: This was longToString() in Lucene
         /// </summary>
-        protected virtual MutableValueLong NewMutableValueInt64()
+        protected virtual MutableValueInt64 NewMutableValueInt64()
         {
-            return new MutableValueLong();
+            return new MutableValueInt64();
         }
 
         public override bool Equals(object o)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Queries/Function/ValueSources/OrdFieldSource.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/OrdFieldSource.cs b/src/Lucene.Net.Queries/Function/ValueSources/OrdFieldSource.cs
index 967045f..ef50b28 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/OrdFieldSource.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/OrdFieldSource.cs
@@ -121,10 +121,10 @@ namespace Lucene.Net.Queries.Function.ValueSources
                 public ValueFillerAnonymousInnerClassHelper(IntDocValuesAnonymousInnerClassHelper outerInstance)
                 {
                     this.outerInstance = outerInstance;
-                    mval = new MutableValueInt();
+                    mval = new MutableValueInt32();
                 }
 
-                private readonly MutableValueInt mval;
+                private readonly MutableValueInt32 mval;
 
                 public override MutableValue Value
                 {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Queries/Function/ValueSources/QueryValueSource.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/QueryValueSource.cs b/src/Lucene.Net.Queries/Function/ValueSources/QueryValueSource.cs
index b11a93c..7eedfab 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/QueryValueSource.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/QueryValueSource.cs
@@ -253,10 +253,10 @@ namespace Lucene.Net.Queries.Function.ValueSources
             public ValueFillerAnonymousInnerClassHelper(QueryDocValues outerInstance)
             {
                 this.outerInstance = outerInstance;
-                mval = new MutableValueFloat();
+                mval = new MutableValueSingle();
             }
 
-            private readonly MutableValueFloat mval;
+            private readonly MutableValueSingle mval;
 
             public override MutableValue Value
             {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Queries/Function/ValueSources/ShortFieldSource.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Queries/Function/ValueSources/ShortFieldSource.cs b/src/Lucene.Net.Queries/Function/ValueSources/ShortFieldSource.cs
index a1ef324..d8b8708 100644
--- a/src/Lucene.Net.Queries/Function/ValueSources/ShortFieldSource.cs
+++ b/src/Lucene.Net.Queries/Function/ValueSources/ShortFieldSource.cs
@@ -30,14 +30,14 @@ namespace Lucene.Net.Queries.Function.ValueSources
     [Obsolete]
     public class ShortFieldSource : FieldCacheSource
     {
-        private readonly FieldCache.IShortParser parser;
+        private readonly FieldCache.IInt16Parser parser;
 
         public ShortFieldSource(string field)
             : this(field, null)
         {
         }
 
-        public ShortFieldSource(string field, FieldCache.IShortParser parser)
+        public ShortFieldSource(string field, FieldCache.IInt16Parser parser)
             : base(field)
         {
             this.parser = parser;
@@ -57,9 +57,9 @@ namespace Lucene.Net.Queries.Function.ValueSources
         private class FunctionValuesAnonymousInnerClassHelper : FunctionValues
         {
             private readonly ShortFieldSource outerInstance;
-            private readonly FieldCache.Shorts arr;
+            private readonly FieldCache.Int16s arr;
 
-            public FunctionValuesAnonymousInnerClassHelper(ShortFieldSource outerInstance, FieldCache.Shorts arr)
+            public FunctionValuesAnonymousInnerClassHelper(ShortFieldSource outerInstance, FieldCache.Int16s arr)
             {
                 this.outerInstance = outerInstance;
                 this.arr = arr;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Sandbox/Queries/SlowFuzzyTermsEnum.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Sandbox/Queries/SlowFuzzyTermsEnum.cs b/src/Lucene.Net.Sandbox/Queries/SlowFuzzyTermsEnum.cs
index ef44345..50cfaf7 100644
--- a/src/Lucene.Net.Sandbox/Queries/SlowFuzzyTermsEnum.cs
+++ b/src/Lucene.Net.Sandbox/Queries/SlowFuzzyTermsEnum.cs
@@ -103,7 +103,7 @@ namespace Lucene.Net.Sandbox.Queries
 
             private readonly BytesRef prefixBytesRef;
             /// <summary>used for unicode conversion from BytesRef byte[] to int[]</summary>
-            private readonly IntsRef utf32 = new IntsRef(20);
+            private readonly Int32sRef utf32 = new Int32sRef(20);
 
             /// <summary>
             /// <para>

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Spatial/Prefix/ContainsPrefixTreeFilter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Spatial/Prefix/ContainsPrefixTreeFilter.cs b/src/Lucene.Net.Spatial/Prefix/ContainsPrefixTreeFilter.cs
index 7cfa526..c8a80f6 100644
--- a/src/Lucene.Net.Spatial/Prefix/ContainsPrefixTreeFilter.cs
+++ b/src/Lucene.Net.Spatial/Prefix/ContainsPrefixTreeFilter.cs
@@ -216,12 +216,12 @@ namespace Lucene.Net.Spatial.Prefix
         /// </remarks>
         private class SmallDocSet : DocIdSet, IBits
         {
-            private readonly SentinelIntSet intSet;
+            private readonly SentinelInt32Set intSet;
             private int maxInt = 0;
 
             public SmallDocSet(int size)
             {
-                intSet = new SentinelIntSet(size, -1);
+                intSet = new SentinelInt32Set(size, -1);
             }
 
             public virtual bool Get(int index)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Suggest/Spell/LuceneLevenshteinDistance.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Suggest/Spell/LuceneLevenshteinDistance.cs b/src/Lucene.Net.Suggest/Spell/LuceneLevenshteinDistance.cs
index 3ced995..b9f7e41 100644
--- a/src/Lucene.Net.Suggest/Spell/LuceneLevenshteinDistance.cs
+++ b/src/Lucene.Net.Suggest/Spell/LuceneLevenshteinDistance.cs
@@ -52,8 +52,8 @@ namespace Lucene.Net.Search.Spell
 
         public float GetDistance(string target, string other)
         {
-            IntsRef targetPoints;
-            IntsRef otherPoints;
+            Int32sRef targetPoints;
+            Int32sRef otherPoints;
             int n;
             int[][] d; // cost array
 
@@ -124,9 +124,9 @@ namespace Lucene.Net.Search.Spell
         /// <summary>
         /// NOTE: This was toIntsRef() in Lucene
         /// </summary>
-        private static IntsRef ToInt32sRef(string s)
+        private static Int32sRef ToInt32sRef(string s)
         {
-            var @ref = new IntsRef(s.Length); // worst case
+            var @ref = new Int32sRef(s.Length); // worst case
             int utf16Len = s.Length;
             for (int i = 0, cp = 0; i < utf16Len; i += Character.CharCount(cp))
             {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Suggest/Suggest/Analyzing/AnalyzingSuggester.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Suggest/Suggest/Analyzing/AnalyzingSuggester.cs b/src/Lucene.Net.Suggest/Suggest/Analyzing/AnalyzingSuggester.cs
index be3d918..4aa7dc7 100644
--- a/src/Lucene.Net.Suggest/Suggest/Analyzing/AnalyzingSuggester.cs
+++ b/src/Lucene.Net.Suggest/Suggest/Analyzing/AnalyzingSuggester.cs
@@ -419,11 +419,11 @@ namespace Lucene.Net.Search.Suggest.Analyzing
 
                 while ((surfaceForm = iterator.Next()) != null)
                 {
-                    ISet<IntsRef> paths = ToFiniteStrings(surfaceForm, ts2a);
+                    ISet<Int32sRef> paths = ToFiniteStrings(surfaceForm, ts2a);
 
                     maxAnalyzedPathsForOneInput = Math.Max(maxAnalyzedPathsForOneInput, paths.Count);
 
-                    foreach (IntsRef path in paths)
+                    foreach (Int32sRef path in paths)
                     {
 
                         Util.Fst.Util.ToBytesRef(path, scratch);
@@ -503,7 +503,7 @@ namespace Lucene.Net.Search.Suggest.Analyzing
 
                 reader = new OfflineSorter.ByteSequencesReader(tempSorted);
 
-                var outputs = new PairOutputs<long?, BytesRef>(PositiveIntOutputs.Singleton,
+                var outputs = new PairOutputs<long?, BytesRef>(PositiveInt32Outputs.Singleton,
                     ByteSequenceOutputs.Singleton);
                 var builder = new Builder<PairOutputs<long?, BytesRef>.Pair>(FST.INPUT_TYPE.BYTE1, outputs);
 
@@ -511,7 +511,7 @@ namespace Lucene.Net.Search.Suggest.Analyzing
                 BytesRef previousAnalyzed = null;
                 BytesRef analyzed = new BytesRef();
                 BytesRef surface = new BytesRef();
-                IntsRef scratchInts = new IntsRef();
+                Int32sRef scratchInts = new Int32sRef();
                 var input = new ByteArrayDataInput();
 
                 // Used to remove duplicate surface forms (but we
@@ -641,7 +641,7 @@ namespace Lucene.Net.Search.Suggest.Analyzing
         public override bool Load(DataInput input)
         {
             count = input.ReadVInt64();
-            this.fst = new FST<PairOutputs<long?, BytesRef>.Pair>(input, new PairOutputs<long?, BytesRef>(PositiveIntOutputs.Singleton, ByteSequenceOutputs.Singleton));
+            this.fst = new FST<PairOutputs<long?, BytesRef>.Pair>(input, new PairOutputs<long?, BytesRef>(PositiveInt32Outputs.Singleton, ByteSequenceOutputs.Singleton));
             maxAnalyzedPathsForOneInput = input.ReadVInt32();
             hasPayloads = input.ReadByte() == 1;
             return true;
@@ -896,7 +896,7 @@ namespace Lucene.Net.Search.Suggest.Analyzing
 
             private readonly HashSet<BytesRef> seen;
 
-            protected override bool AcceptResult(IntsRef input, PairOutputs<long?, BytesRef>.Pair output)
+            protected override bool AcceptResult(Int32sRef input, PairOutputs<long?, BytesRef>.Pair output)
             {
 
                 // Dedup: when the input analyzes to a graph we
@@ -946,7 +946,7 @@ namespace Lucene.Net.Search.Suggest.Analyzing
             return prefixPaths;
         }
 
-        internal ISet<IntsRef> ToFiniteStrings(BytesRef surfaceForm, TokenStreamToAutomaton ts2a)
+        internal ISet<Int32sRef> ToFiniteStrings(BytesRef surfaceForm, TokenStreamToAutomaton ts2a)
         {
             // Analyze surface form:
             Automaton automaton = null;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Suggest/Suggest/Analyzing/FSTUtil.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Suggest/Suggest/Analyzing/FSTUtil.cs b/src/Lucene.Net.Suggest/Suggest/Analyzing/FSTUtil.cs
index 9770af5..fad4a9c 100644
--- a/src/Lucene.Net.Suggest/Suggest/Analyzing/FSTUtil.cs
+++ b/src/Lucene.Net.Suggest/Suggest/Analyzing/FSTUtil.cs
@@ -54,11 +54,11 @@ namespace Lucene.Net.Search.Suggest.Analyzing
 
             /// <summary>
             /// Input of the path so far: </summary>
-            public IntsRef Input { get; private set; }
+            public Int32sRef Input { get; private set; }
 
             /// <summary>
             /// Sole constructor. </summary>
-            public Path(State state, FST.Arc<T> fstNode, T output, IntsRef input)
+            public Path(State state, FST.Arc<T> fstNode, T output, Int32sRef input)
             {
                 this.State = state;
                 this.FstNode = fstNode;
@@ -76,7 +76,7 @@ namespace Lucene.Net.Search.Suggest.Analyzing
             Debug.Assert(a.IsDeterministic);
             IList<Path<T>> queue = new List<Path<T>>();
             List<Path<T>> endNodes = new List<Path<T>>();
-            queue.Add(new Path<T>(a.GetInitialState(), fst.GetFirstArc(new FST.Arc<T>()), fst.Outputs.NoOutput, new IntsRef()));
+            queue.Add(new Path<T>(a.GetInitialState(), fst.GetFirstArc(new FST.Arc<T>()), fst.Outputs.NoOutput, new Int32sRef()));
 
             FST.Arc<T> scratchArc = new FST.Arc<T>();
             FST.BytesReader fstReader = fst.GetBytesReader();
@@ -93,7 +93,7 @@ namespace Lucene.Net.Search.Suggest.Analyzing
                     continue;
                 }
 
-                IntsRef currentInput = path.Input;
+                Int32sRef currentInput = path.Input;
                 foreach (Transition t in path.State.GetTransitions())
                 {
                     int min = t.Min;
@@ -103,7 +103,7 @@ namespace Lucene.Net.Search.Suggest.Analyzing
                         FST.Arc<T> nextArc = fst.FindTargetArc(t.Min, path.FstNode, scratchArc, fstReader);
                         if (nextArc != null)
                         {
-                            IntsRef newInput = new IntsRef(currentInput.Length + 1);
+                            Int32sRef newInput = new Int32sRef(currentInput.Length + 1);
                             newInput.CopyInt32s(currentInput);
                             newInput.Int32s[currentInput.Length] = t.Min;
                             newInput.Length = currentInput.Length + 1;
@@ -126,7 +126,7 @@ namespace Lucene.Net.Search.Suggest.Analyzing
                         {
                             Debug.Assert(nextArc.Label <= max);
                             Debug.Assert(nextArc.Label >= min, nextArc.Label + " " + min);
-                            IntsRef newInput = new IntsRef(currentInput.Length + 1);
+                            Int32sRef newInput = new Int32sRef(currentInput.Length + 1);
                             newInput.CopyInt32s(currentInput);
                             newInput.Int32s[currentInput.Length] = nextArc.Label;
                             newInput.Length = currentInput.Length + 1;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Suggest/Suggest/Analyzing/FreeTextSuggester.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Suggest/Suggest/Analyzing/FreeTextSuggester.cs b/src/Lucene.Net.Suggest/Suggest/Analyzing/FreeTextSuggester.cs
index 2336710..f7624c0 100644
--- a/src/Lucene.Net.Suggest/Suggest/Analyzing/FreeTextSuggester.cs
+++ b/src/Lucene.Net.Suggest/Suggest/Analyzing/FreeTextSuggester.cs
@@ -370,10 +370,10 @@ namespace Lucene.Net.Search.Suggest.Analyzing
                     // Move all ngrams into an FST:
                     TermsEnum termsEnum = terms.GetIterator(null);
 
-                    Outputs<long?> outputs = PositiveIntOutputs.Singleton;
+                    Outputs<long?> outputs = PositiveInt32Outputs.Singleton;
                     Builder<long?> builder = new Builder<long?>(FST.INPUT_TYPE.BYTE1, outputs);
 
-                    IntsRef scratchInts = new IntsRef();
+                    Int32sRef scratchInts = new Int32sRef();
                     while (true)
                     {
                         BytesRef term = termsEnum.Next();
@@ -478,7 +478,7 @@ namespace Lucene.Net.Search.Suggest.Analyzing
             }
             totTokens = input.ReadVInt64();
 
-            fst = new FST<long?>(input, PositiveIntOutputs.Singleton);
+            fst = new FST<long?>(input, PositiveInt32Outputs.Singleton);
 
             return true;
         }
@@ -676,7 +676,7 @@ namespace Lucene.Net.Search.Suggest.Analyzing
                         if (token.Bytes[token.Offset + i] == separator)
                         {
                             BytesRef context = new BytesRef(token.Bytes, token.Offset, i);
-                            long? output = Lucene.Net.Util.Fst.Util.Get(fst, Lucene.Net.Util.Fst.Util.ToInt32sRef(context, new IntsRef()));
+                            long? output = Lucene.Net.Util.Fst.Util.Get(fst, Lucene.Net.Util.Fst.Util.ToInt32sRef(context, new Int32sRef()));
                             Debug.Assert(output != null);
                             contextCount = DecodeWeight(output);
                             lastTokenFragment = new BytesRef(token.Bytes, token.Offset + i + 1, token.Length - i - 1);
@@ -718,7 +718,7 @@ namespace Lucene.Net.Search.Suggest.Analyzing
 
                         // since this search is initialized with a single start node 
                         // it is okay to start with an empty input path here
-                        searcher.AddStartPaths(arc, prefixOutput, true, new IntsRef());
+                        searcher.AddStartPaths(arc, prefixOutput, true, new Int32sRef());
 
                         completions = searcher.Search();
                         Debug.Assert(completions.IsComplete);
@@ -828,7 +828,7 @@ namespace Lucene.Net.Search.Suggest.Analyzing
                 }
             }
 
-            protected override bool AcceptResult(IntsRef input, long? output)
+            protected override bool AcceptResult(Int32sRef input, long? output)
             {
                 Util.Fst.Util.ToBytesRef(input, scratchBytes);
                 finalLastToken.Grow(finalLastToken.Length + scratchBytes.Length);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Suggest/Suggest/Analyzing/FuzzySuggester.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Suggest/Suggest/Analyzing/FuzzySuggester.cs b/src/Lucene.Net.Suggest/Suggest/Analyzing/FuzzySuggester.cs
index 9600293..6f7e589 100644
--- a/src/Lucene.Net.Suggest/Suggest/Analyzing/FuzzySuggester.cs
+++ b/src/Lucene.Net.Suggest/Suggest/Analyzing/FuzzySuggester.cs
@@ -226,7 +226,7 @@ namespace Lucene.Net.Search.Suggest.Analyzing
             var @ref = SpecialOperations.GetFiniteStrings(automaton, -1);
             Automaton[] subs = new Automaton[@ref.Count];
             int upto = 0;
-            foreach (IntsRef path in @ref)
+            foreach (Int32sRef path in @ref)
             {
                 if (path.Length <= nonFuzzyPrefix || path.Length < minFuzzyLength)
                 {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Suggest/Suggest/Fst/FSTCompletionBuilder.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Suggest/Suggest/Fst/FSTCompletionBuilder.cs b/src/Lucene.Net.Suggest/Suggest/Fst/FSTCompletionBuilder.cs
index ae68e3f..13f46e4 100644
--- a/src/Lucene.Net.Suggest/Suggest/Fst/FSTCompletionBuilder.cs
+++ b/src/Lucene.Net.Suggest/Suggest/Fst/FSTCompletionBuilder.cs
@@ -249,11 +249,11 @@ namespace Lucene.Net.Search.Suggest.Fst
             // Build the automaton.
             Outputs<object> outputs = NoOutputs.Singleton;
             object empty = outputs.NoOutput;
-            Builder<object> builder = new Builder<object>(FST.INPUT_TYPE.BYTE1, 0, 0, true, true, shareMaxTailLength, outputs, null, false, PackedInts.DEFAULT, true, 15);
+            Builder<object> builder = new Builder<object>(FST.INPUT_TYPE.BYTE1, 0, 0, true, true, shareMaxTailLength, outputs, null, false, PackedInt32s.DEFAULT, true, 15);
 
             BytesRef scratch = new BytesRef();
             BytesRef entry;
-            IntsRef scratchIntsRef = new IntsRef();
+            Int32sRef scratchIntsRef = new Int32sRef();
             int count = 0;
             IBytesRefIterator iter = sorter.GetEnumerator();
             while ((entry = iter.Next()) != null)

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.Suggest/Suggest/Fst/WFSTCompletionLookup.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Suggest/Suggest/Fst/WFSTCompletionLookup.cs b/src/Lucene.Net.Suggest/Suggest/Fst/WFSTCompletionLookup.cs
index 0b4a408..5b56f6c 100644
--- a/src/Lucene.Net.Suggest/Suggest/Fst/WFSTCompletionLookup.cs
+++ b/src/Lucene.Net.Suggest/Suggest/Fst/WFSTCompletionLookup.cs
@@ -89,9 +89,9 @@ namespace Lucene.Net.Search.Suggest.Fst
             count = 0;
             var scratch = new BytesRef();
             IInputIterator iter = new WFSTInputIterator(this, iterator);
-            var scratchInts = new IntsRef();
+            var scratchInts = new Int32sRef();
             BytesRef previous = null;
-            var outputs = PositiveIntOutputs.Singleton;
+            var outputs = PositiveInt32Outputs.Singleton;
             var builder = new Builder<long?>(FST.INPUT_TYPE.BYTE1, outputs);
             while ((scratch = iter.Next()) != null)
             {
@@ -128,7 +128,7 @@ namespace Lucene.Net.Search.Suggest.Fst
         public override bool Load(DataInput input)
         {
             count = input.ReadVInt64();
-            this.fst = new FST<long?>(input, PositiveIntOutputs.Singleton);
+            this.fst = new FST<long?>(input, PositiveInt32Outputs.Singleton);
             return true;
         }
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.TestFramework/Codecs/asserting/AssertingDocValuesFormat.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.TestFramework/Codecs/asserting/AssertingDocValuesFormat.cs b/src/Lucene.Net.TestFramework/Codecs/asserting/AssertingDocValuesFormat.cs
index 1a79e83..5db7ad7 100644
--- a/src/Lucene.Net.TestFramework/Codecs/asserting/AssertingDocValuesFormat.cs
+++ b/src/Lucene.Net.TestFramework/Codecs/asserting/AssertingDocValuesFormat.cs
@@ -11,7 +11,7 @@ namespace Lucene.Net.Codecs.asserting
     using DocValuesType = Lucene.Net.Index.DocValuesType;
     using FieldInfo = Lucene.Net.Index.FieldInfo;
     using FixedBitSet = Lucene.Net.Util.FixedBitSet;
-    using LongBitSet = Lucene.Net.Util.LongBitSet;
+    using Int64BitSet = Lucene.Net.Util.Int64BitSet;
 
     /*
          * Licensed to the Apache Software Foundation (ASF) under one or more
@@ -157,7 +157,7 @@ namespace Lucene.Net.Codecs.asserting
 
                 int docCount = 0;
                 long ordCount = 0;
-                LongBitSet seenOrds = new LongBitSet(valueCount);
+                Int64BitSet seenOrds = new Int64BitSet(valueCount);
                 IEnumerator<long?> ordIterator = ords.GetEnumerator();
                 foreach (long? v in docToOrdCount)
                 {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.TestFramework/Codecs/compressing/FastCompressingCodec.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.TestFramework/Codecs/compressing/FastCompressingCodec.cs b/src/Lucene.Net.TestFramework/Codecs/compressing/FastCompressingCodec.cs
index 2c7b6d1..4025f4b 100644
--- a/src/Lucene.Net.TestFramework/Codecs/compressing/FastCompressingCodec.cs
+++ b/src/Lucene.Net.TestFramework/Codecs/compressing/FastCompressingCodec.cs
@@ -1,7 +1,7 @@
 namespace Lucene.Net.Codecs.Compressing
 {
     using Lucene42NormsFormat = Lucene.Net.Codecs.Lucene42.Lucene42NormsFormat;
-    using PackedInts = Lucene.Net.Util.Packed.PackedInts;
+    using PackedInt32s = Lucene.Net.Util.Packed.PackedInt32s;
 
     /*
      * Licensed to the Apache Software Foundation (ASF) under one or more
@@ -40,7 +40,7 @@ namespace Lucene.Net.Codecs.Compressing
 
         public override NormsFormat NormsFormat
         {
-            get { return new Lucene42NormsFormat(PackedInts.FAST); }
+            get { return new Lucene42NormsFormat(PackedInt32s.FAST); }
         }
     }
 }
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.TestFramework/Codecs/compressing/FastDecompressionCompressingCodec.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.TestFramework/Codecs/compressing/FastDecompressionCompressingCodec.cs b/src/Lucene.Net.TestFramework/Codecs/compressing/FastDecompressionCompressingCodec.cs
index 929444f..3fa5e57 100644
--- a/src/Lucene.Net.TestFramework/Codecs/compressing/FastDecompressionCompressingCodec.cs
+++ b/src/Lucene.Net.TestFramework/Codecs/compressing/FastDecompressionCompressingCodec.cs
@@ -1,7 +1,7 @@
 namespace Lucene.Net.Codecs.Compressing
 {
     using Lucene42NormsFormat = Lucene.Net.Codecs.Lucene42.Lucene42NormsFormat;
-    using PackedInts = Lucene.Net.Util.Packed.PackedInts;
+    using PackedInt32s = Lucene.Net.Util.Packed.PackedInt32s;
 
     /*
      * Licensed to the Apache Software Foundation (ASF) under one or more
@@ -40,7 +40,7 @@ namespace Lucene.Net.Codecs.Compressing
 
         public override NormsFormat NormsFormat
         {
-            get { return new Lucene42NormsFormat(PackedInts.DEFAULT); }
+            get { return new Lucene42NormsFormat(PackedInt32s.DEFAULT); }
         }
     }
 }
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.TestFramework/Codecs/compressing/HighCompressionCompressingCodec.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.TestFramework/Codecs/compressing/HighCompressionCompressingCodec.cs b/src/Lucene.Net.TestFramework/Codecs/compressing/HighCompressionCompressingCodec.cs
index 8aa4309..12984d8 100644
--- a/src/Lucene.Net.TestFramework/Codecs/compressing/HighCompressionCompressingCodec.cs
+++ b/src/Lucene.Net.TestFramework/Codecs/compressing/HighCompressionCompressingCodec.cs
@@ -1,7 +1,7 @@
 namespace Lucene.Net.Codecs.Compressing
 {
     using Lucene42NormsFormat = Lucene.Net.Codecs.Lucene42.Lucene42NormsFormat;
-    using PackedInts = Lucene.Net.Util.Packed.PackedInts;
+    using PackedInt32s = Lucene.Net.Util.Packed.PackedInt32s;
 
     /*
      * Licensed to the Apache Software Foundation (ASF) under one or more
@@ -40,7 +40,7 @@ namespace Lucene.Net.Codecs.Compressing
 
         public override NormsFormat NormsFormat
         {
-            get { return new Lucene42NormsFormat(PackedInts.COMPACT); }
+            get { return new Lucene42NormsFormat(PackedInt32s.COMPACT); }
         }
     }
 }
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/8b7f4185/src/Lucene.Net.TestFramework/Codecs/lucene40/Lucene40DocValuesWriter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.TestFramework/Codecs/lucene40/Lucene40DocValuesWriter.cs b/src/Lucene.Net.TestFramework/Codecs/lucene40/Lucene40DocValuesWriter.cs
index 4dcf590..42856fc 100644
--- a/src/Lucene.Net.TestFramework/Codecs/lucene40/Lucene40DocValuesWriter.cs
+++ b/src/Lucene.Net.TestFramework/Codecs/lucene40/Lucene40DocValuesWriter.cs
@@ -31,7 +31,7 @@ namespace Lucene.Net.Codecs.Lucene40
          */
 
     using LegacyDocValuesType = Lucene.Net.Codecs.Lucene40.Lucene40FieldInfosReader.LegacyDocValuesType;
-    using PackedInts = Lucene.Net.Util.Packed.PackedInts;
+    using PackedInt32s = Lucene.Net.Util.Packed.PackedInt32s;
     using SegmentWriteState = Lucene.Net.Index.SegmentWriteState;
 
 #pragma warning disable 612, 618
@@ -67,17 +67,17 @@ namespace Lucene.Net.Codecs.Lucene40
             bool success = false;
             try
             {
-                if (minValue >= sbyte.MinValue && maxValue <= sbyte.MaxValue && PackedInts.BitsRequired(maxValue - minValue) > 4)
+                if (minValue >= sbyte.MinValue && maxValue <= sbyte.MaxValue && PackedInt32s.BitsRequired(maxValue - minValue) > 4)
                 {
                     // fits in a byte[], would be more than 4bpv, just write byte[]
                     AddBytesField(field, data, values);
                 }
-                else if (minValue >= short.MinValue && maxValue <= short.MaxValue && PackedInts.BitsRequired(maxValue - minValue) > 8)
+                else if (minValue >= short.MinValue && maxValue <= short.MaxValue && PackedInt32s.BitsRequired(maxValue - minValue) > 8)
                 {
                     // fits in a short[], would be more than 8bpv, just write short[]
                     AddShortsField(field, data, values);
                 }
-                else if (minValue >= int.MinValue && maxValue <= int.MaxValue && PackedInts.BitsRequired(maxValue - minValue) > 16)
+                else if (minValue >= int.MinValue && maxValue <= int.MaxValue && PackedInt32s.BitsRequired(maxValue - minValue) > 16)
                 {
                     // fits in a int[], would be more than 16bpv, just write int[]
                     AddIntsField(field, data, values);
@@ -157,7 +157,7 @@ namespace Lucene.Net.Codecs.Lucene40
                 output.WriteByte((byte)Lucene40DocValuesFormat.VAR_INTS_PACKED);
                 output.WriteInt64(minValue);
                 output.WriteInt64(0 - minValue); // default value (representation of 0)
-                PackedInts.Writer writer = PackedInts.GetWriter(output, State.SegmentInfo.DocCount, PackedInts.BitsRequired(delta), PackedInts.DEFAULT);
+                PackedInt32s.Writer writer = PackedInt32s.GetWriter(output, State.SegmentInfo.DocCount, PackedInt32s.BitsRequired(delta), PackedInt32s.DEFAULT);
                 foreach (long? n in values)
                 {
                     long v = n == null ? 0 : (long)n;
@@ -341,7 +341,7 @@ namespace Lucene.Net.Codecs.Lucene40
             int maxDoc = State.SegmentInfo.DocCount;
             Debug.Assert(maxDoc != int.MaxValue); // unsupported by the 4.0 impl
 
-            PackedInts.Writer w = PackedInts.GetWriter(index, maxDoc + 1, PackedInts.BitsRequired(maxAddress), PackedInts.DEFAULT);
+            PackedInt32s.Writer w = PackedInt32s.GetWriter(index, maxDoc + 1, PackedInt32s.BitsRequired(maxAddress), PackedInt32s.DEFAULT);
             long currentPosition = 0;
             foreach (BytesRef v in values)
             {
@@ -384,7 +384,7 @@ namespace Lucene.Net.Codecs.Lucene40
             Debug.Assert(valueCount > 0);
             index.WriteInt32(valueCount);
             int maxDoc = State.SegmentInfo.DocCount;
-            PackedInts.Writer w = PackedInts.GetWriter(index, maxDoc, PackedInts.BitsRequired(valueCount - 1), PackedInts.DEFAULT);
+            PackedInt32s.Writer w = PackedInt32s.GetWriter(index, maxDoc, PackedInt32s.BitsRequired(valueCount - 1), PackedInt32s.DEFAULT);
 
             BytesRef brefDummy;
             foreach (BytesRef v in values)
@@ -433,7 +433,7 @@ namespace Lucene.Net.Codecs.Lucene40
             long totalBytes = data.FilePointer - startPosition;
             index.WriteInt64(totalBytes);
             int maxDoc = State.SegmentInfo.DocCount;
-            PackedInts.Writer w = PackedInts.GetWriter(index, maxDoc, PackedInts.BitsRequired(currentAddress), PackedInts.DEFAULT);
+            PackedInt32s.Writer w = PackedInt32s.GetWriter(index, maxDoc, PackedInt32s.BitsRequired(currentAddress), PackedInt32s.DEFAULT);
 
             foreach (BytesRef v in values)
             {
@@ -552,7 +552,7 @@ namespace Lucene.Net.Codecs.Lucene40
             index.WriteInt32(valueCount);
             int maxDoc = State.SegmentInfo.DocCount;
             Debug.Assert(valueCount > 0);
-            PackedInts.Writer w = PackedInts.GetWriter(index, maxDoc, PackedInts.BitsRequired(valueCount - 1), PackedInts.DEFAULT);
+            PackedInt32s.Writer w = PackedInt32s.GetWriter(index, maxDoc, PackedInt32s.BitsRequired(valueCount - 1), PackedInt32s.DEFAULT);
             foreach (long n in docToOrd)
             {
                 w.Add((long)n);
@@ -586,7 +586,7 @@ namespace Lucene.Net.Codecs.Lucene40
 
             Debug.Assert(valueCount != int.MaxValue); // unsupported by the 4.0 impl
 
-            PackedInts.Writer w = PackedInts.GetWriter(index, valueCount + 1, PackedInts.BitsRequired(maxAddress), PackedInts.DEFAULT);
+            PackedInt32s.Writer w = PackedInt32s.GetWriter(index, valueCount + 1, PackedInt32s.BitsRequired(maxAddress), PackedInt32s.DEFAULT);
             long currentPosition = 0;
             foreach (BytesRef v in values)
             {
@@ -602,7 +602,7 @@ namespace Lucene.Net.Codecs.Lucene40
 
             int maxDoc = State.SegmentInfo.DocCount;
             Debug.Assert(valueCount > 0);
-            PackedInts.Writer ords = PackedInts.GetWriter(index, maxDoc, PackedInts.BitsRequired(valueCount - 1), PackedInts.DEFAULT);
+            PackedInt32s.Writer ords = PackedInt32s.GetWriter(index, maxDoc, PackedInt32s.BitsRequired(valueCount - 1), PackedInt32s.DEFAULT);
             foreach (long n in docToOrd)
             {
                 ords.Add((long)n);


[41/53] [abbrv] lucenenet git commit: SWEEP: Renamed constant and enum value names from Short, Int, Long, and Float to match CLR types Int16, Int32, Int64, and Single, respectively.

Posted by ni...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Tests.Misc/Index/Sorter/IndexSortingTest.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests.Misc/Index/Sorter/IndexSortingTest.cs b/src/Lucene.Net.Tests.Misc/Index/Sorter/IndexSortingTest.cs
index 16dfb54..455d9ef 100644
--- a/src/Lucene.Net.Tests.Misc/Index/Sorter/IndexSortingTest.cs
+++ b/src/Lucene.Net.Tests.Misc/Index/Sorter/IndexSortingTest.cs
@@ -29,7 +29,7 @@ namespace Lucene.Net.Index.Sorter
     {
         private static readonly Sort[] SORT = new Sort[]
         {
-            new Sort(new SortField(NUMERIC_DV_FIELD, SortFieldType.LONG)),
+            new Sort(new SortField(NUMERIC_DV_FIELD, SortFieldType.INT64)),
             new Sort(new SortField(null, SortFieldType.DOC, true))
         };
 
@@ -58,7 +58,7 @@ namespace Lucene.Net.Index.Sorter
                 values.Sort();
                 if (Random().nextBoolean())
                 {
-                    sorter = new Sort(new SortField(NUMERIC_DV_FIELD, SortFieldType.LONG, true)); // descending
+                    sorter = new Sort(new SortField(NUMERIC_DV_FIELD, SortFieldType.INT64, true)); // descending
                     values.Reverse();
                 }
             }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Tests.Misc/Index/Sorter/SortingAtomicReaderTest.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests.Misc/Index/Sorter/SortingAtomicReaderTest.cs b/src/Lucene.Net.Tests.Misc/Index/Sorter/SortingAtomicReaderTest.cs
index 0ea86f8..b296091 100644
--- a/src/Lucene.Net.Tests.Misc/Index/Sorter/SortingAtomicReaderTest.cs
+++ b/src/Lucene.Net.Tests.Misc/Index/Sorter/SortingAtomicReaderTest.cs
@@ -30,7 +30,7 @@ namespace Lucene.Net.Index.Sorter
         {
 
             // sort the index by id (as integer, in NUMERIC_DV_FIELD)
-            Sort sort = new Sort(new SortField(NUMERIC_DV_FIELD, SortFieldType.INT));
+            Sort sort = new Sort(new SortField(NUMERIC_DV_FIELD, SortFieldType.INT32));
             Sorter.DocMap docMap = new Sorter(sort).Sort(reader);
 
             // Sorter.compute also sorts the values

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Tests.Misc/Index/Sorter/TestBlockJoinSorter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests.Misc/Index/Sorter/TestBlockJoinSorter.cs b/src/Lucene.Net.Tests.Misc/Index/Sorter/TestBlockJoinSorter.cs
index 8665017..5608827 100644
--- a/src/Lucene.Net.Tests.Misc/Index/Sorter/TestBlockJoinSorter.cs
+++ b/src/Lucene.Net.Tests.Misc/Index/Sorter/TestBlockJoinSorter.cs
@@ -71,8 +71,8 @@ namespace Lucene.Net.Index.Sorter
 
             NumericDocValues childValues = reader.GetNumericDocValues("child_val");
 
-            Sort parentSort = new Sort(new SortField("parent_val", SortFieldType.LONG));
-            Sort childSort = new Sort(new SortField("child_val", SortFieldType.LONG));
+            Sort parentSort = new Sort(new SortField("parent_val", SortFieldType.INT64));
+            Sort childSort = new Sort(new SortField("child_val", SortFieldType.INT64));
 
             Sort sort = new Sort(new SortField("custom", new BlockJoinComparerSource(parentsFilter, parentSort, childSort)));
             Sorter sorter = new Sorter(sort);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Tests.Misc/Index/Sorter/TestEarlyTermination.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests.Misc/Index/Sorter/TestEarlyTermination.cs b/src/Lucene.Net.Tests.Misc/Index/Sorter/TestEarlyTermination.cs
index 0c1ef35..077d200 100644
--- a/src/Lucene.Net.Tests.Misc/Index/Sorter/TestEarlyTermination.cs
+++ b/src/Lucene.Net.Tests.Misc/Index/Sorter/TestEarlyTermination.cs
@@ -39,7 +39,7 @@ namespace Lucene.Net.Index.Sorter
         public override void SetUp()
         {
             base.SetUp();
-            sort = new Sort(new SortField("ndv1", SortFieldType.LONG));
+            sort = new Sort(new SortField("ndv1", SortFieldType.INT64));
         }
 
         private Document RandomDocument()
@@ -96,7 +96,7 @@ namespace Lucene.Net.Index.Sorter
         {
             CreateRandomIndexes(5);
             int numHits = TestUtil.NextInt(Random(), 1, numDocs / 10);
-            Sort sort = new Sort(new SortField("ndv1", SortFieldType.LONG, false));
+            Sort sort = new Sort(new SortField("ndv1", SortFieldType.INT64, false));
             bool fillFields = Random().nextBoolean();
             bool trackDocScores = Random().nextBoolean();
             bool trackMaxScore = Random().nextBoolean();
@@ -123,7 +123,7 @@ namespace Lucene.Net.Index.Sorter
             // different sorter than the one specified in the ctor.
             CreateRandomIndexes(5);
             int numHits = TestUtil.NextInt(Random(), 1, numDocs / 10);
-            Sort sort = new Sort(new SortField("ndv2", SortFieldType.LONG, false));
+            Sort sort = new Sort(new SortField("ndv2", SortFieldType.INT64, false));
             bool fillFields = Random().nextBoolean();
             bool trackDocScores = Random().nextBoolean();
             bool trackMaxScore = Random().nextBoolean();
@@ -137,7 +137,7 @@ namespace Lucene.Net.Index.Sorter
             {
                 TermQuery query = new TermQuery(new Term("s", RandomInts.RandomFrom(Random(), terms)));
                 searcher.Search(query, collector1);
-                Sort different = new Sort(new SortField("ndv2", SortFieldType.LONG));
+                Sort different = new Sort(new SortField("ndv2", SortFieldType.INT64));
                 searcher.Search(query, new EarlyTerminatingSortingCollectorHelper(collector2, different, numHits));
 
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Tests.Misc/Index/Sorter/TestSortingMergePolicy.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests.Misc/Index/Sorter/TestSortingMergePolicy.cs b/src/Lucene.Net.Tests.Misc/Index/Sorter/TestSortingMergePolicy.cs
index c2597f6..f429546 100644
--- a/src/Lucene.Net.Tests.Misc/Index/Sorter/TestSortingMergePolicy.cs
+++ b/src/Lucene.Net.Tests.Misc/Index/Sorter/TestSortingMergePolicy.cs
@@ -39,7 +39,7 @@ namespace Lucene.Net.Index.Sorter
         public override void SetUp()
         {
             base.SetUp();
-            sort = new Sort(new SortField("ndv", SortFieldType.LONG));
+            sort = new Sort(new SortField("ndv", SortFieldType.INT64));
             CreateRandomIndexes();
         }
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Tests.QueryParser/Flexible/Standard/TestNumericQueryParser.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests.QueryParser/Flexible/Standard/TestNumericQueryParser.cs b/src/Lucene.Net.Tests.QueryParser/Flexible/Standard/TestNumericQueryParser.cs
index 779e943..2d48c3e 100644
--- a/src/Lucene.Net.Tests.QueryParser/Flexible/Standard/TestNumericQueryParser.cs
+++ b/src/Lucene.Net.Tests.QueryParser/Flexible/Standard/TestNumericQueryParser.cs
@@ -166,9 +166,9 @@ namespace Lucene.Net.QueryParsers.Flexible.Standard
             while ((randomInt = Convert.ToInt32(NormalizeNumber(Math.Abs(Random().nextInt())))) == 0)
                 ;
 
-            randomNumberMap.Put(NumericType.LONG.ToString(), randomLong);
-            randomNumberMap.Put(NumericType.INT.ToString(), randomInt);
-            randomNumberMap.Put(NumericType.FLOAT.ToString(), randomFloat);
+            randomNumberMap.Put(NumericType.INT64.ToString(), randomLong);
+            randomNumberMap.Put(NumericType.INT32.ToString(), randomInt);
+            randomNumberMap.Put(NumericType.SINGLE.ToString(), randomFloat);
             randomNumberMap.Put(NumericType.DOUBLE.ToString(), randomDouble);
             randomNumberMap.Put(DATE_FIELD_NAME, randomDate);
 
@@ -199,13 +199,13 @@ namespace Lucene.Net.QueryParsers.Flexible.Standard
 
                 switch (type)
                 {
-                    case NumericType.INT:
+                    case NumericType.INT32:
                         field = new Int32Field(type.ToString(), 0, ft2);
                         break;
-                    case NumericType.FLOAT:
+                    case NumericType.SINGLE:
                         field = new SingleField(type.ToString(), 0.0f, ft2);
                         break;
-                    case NumericType.LONG:
+                    case NumericType.INT64:
                         field = new Int64Field(type.ToString(), 0L, ft2);
                         break;
                     case NumericType.DOUBLE:
@@ -221,7 +221,7 @@ namespace Lucene.Net.QueryParsers.Flexible.Standard
             }
 
             numericConfigMap.Put(DATE_FIELD_NAME, new NumericConfig(PRECISION_STEP,
-                DATE_FORMAT, NumericType.LONG));
+                DATE_FORMAT, NumericType.INT64));
             FieldType ft = new FieldType(Int64Field.TYPE_NOT_STORED);
             ft.IsStored = (true);
             ft.NumericPrecisionStep = (PRECISION_STEP);
@@ -260,7 +260,7 @@ namespace Lucene.Net.QueryParsers.Flexible.Standard
                     /*Number*/
                     object number = RANDOM_NUMBER_MAP[fieldName];
 
-                    if (NumericType.LONG.ToString().equals(fieldName)
+                    if (NumericType.INT64.ToString().equals(fieldName)
                         || DATE_FIELD_NAME.equals(fieldName))
                     {
                         number = -Convert.ToInt64(number);
@@ -271,12 +271,12 @@ namespace Lucene.Net.QueryParsers.Flexible.Standard
                         number = -Convert.ToDouble(number);
 
                     }
-                    else if (NumericType.FLOAT.ToString().equals(fieldName))
+                    else if (NumericType.SINGLE.ToString().equals(fieldName))
                     {
                         number = -Convert.ToSingle(number);
 
                     }
-                    else if (NumericType.INT.ToString().equals(fieldName))
+                    else if (NumericType.INT32.ToString().equals(fieldName))
                     {
                         number = -Convert.ToInt32(number);
 
@@ -306,16 +306,16 @@ namespace Lucene.Net.QueryParsers.Flexible.Standard
             numericFieldMap[NumericType.DOUBLE.ToString()].SetDoubleValue(Convert.ToDouble(
                 number));
 
-            number = GetNumberType(numberType, NumericType.INT.ToString());
-            numericFieldMap[NumericType.INT.ToString()].SetInt32Value(Convert.ToInt32(
+            number = GetNumberType(numberType, NumericType.INT32.ToString());
+            numericFieldMap[NumericType.INT32.ToString()].SetInt32Value(Convert.ToInt32(
                 number));
 
-            number = GetNumberType(numberType, NumericType.LONG.ToString());
-            numericFieldMap[NumericType.LONG.ToString()].SetInt64Value(Convert.ToInt64(
+            number = GetNumberType(numberType, NumericType.INT64.ToString());
+            numericFieldMap[NumericType.INT64.ToString()].SetInt64Value(Convert.ToInt64(
                 number));
 
-            number = GetNumberType(numberType, NumericType.FLOAT.ToString());
-            numericFieldMap[NumericType.FLOAT.ToString()].SetSingleValue(Convert.ToSingle(
+            number = GetNumberType(numberType, NumericType.SINGLE.ToString());
+            numericFieldMap[NumericType.SINGLE.ToString()].SetSingleValue(Convert.ToSingle(
                 number));
 
             number = GetNumberType(numberType, DATE_FIELD_NAME);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Tests.Spatial/SpatialExample.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests.Spatial/SpatialExample.cs b/src/Lucene.Net.Tests.Spatial/SpatialExample.cs
index bc1fa67..162c577 100644
--- a/src/Lucene.Net.Tests.Spatial/SpatialExample.cs
+++ b/src/Lucene.Net.Tests.Spatial/SpatialExample.cs
@@ -133,7 +133,7 @@ namespace Lucene.Net.Spatial
         {
             IndexReader indexReader = DirectoryReader.Open(directory);
             IndexSearcher indexSearcher = new IndexSearcher(indexReader);
-            Sort idSort = new Sort(new SortField("id", SortFieldType.INT));
+            Sort idSort = new Sort(new SortField("id", SortFieldType.INT32));
 
             //--Filter by circle (<= distance from a point)
             {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Tests/core/Index/TestDocumentsWriterDeleteQueue.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Index/TestDocumentsWriterDeleteQueue.cs b/src/Lucene.Net.Tests/core/Index/TestDocumentsWriterDeleteQueue.cs
index b238062..b8de01b 100644
--- a/src/Lucene.Net.Tests/core/Index/TestDocumentsWriterDeleteQueue.cs
+++ b/src/Lucene.Net.Tests/core/Index/TestDocumentsWriterDeleteQueue.cs
@@ -238,7 +238,7 @@ namespace Lucene.Net.Index
                 DeleteSlice slice = updateThread.Slice;
                 queue.UpdateSlice(slice);
                 BufferedUpdates deletes = updateThread.Deletes;
-                slice.Apply(deletes, BufferedUpdates.MAX_INT);
+                slice.Apply(deletes, BufferedUpdates.MAX_INT32);
                 assertEquals(uniqueValues, new HashSet<Term>(deletes.terms.Keys));
             }
             queue.TryApplyGlobalSlice();
@@ -294,7 +294,7 @@ namespace Lucene.Net.Index
                     Term term = new Term("id", Ids[i].ToString());
                     Queue.Add(term, Slice);
                     Assert.IsTrue(Slice.IsTailItem(term));
-                    Slice.Apply(Deletes, BufferedUpdates.MAX_INT);
+                    Slice.Apply(Deletes, BufferedUpdates.MAX_INT32);
                 }
             }
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Tests/core/Index/TestIntBlockPool.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Index/TestIntBlockPool.cs b/src/Lucene.Net.Tests/core/Index/TestIntBlockPool.cs
index b74d541..98fc2d2 100644
--- a/src/Lucene.Net.Tests/core/Index/TestIntBlockPool.cs
+++ b/src/Lucene.Net.Tests/core/Index/TestIntBlockPool.cs
@@ -65,7 +65,7 @@ namespace Lucene.Net.Index
                 else
                 {
                     pool.Reset(true, true);
-                    Assert.AreEqual(Int32BlockPool.INT_BLOCK_SIZE * RamUsageEstimator.NUM_BYTES_INT, bytesUsed.Get());
+                    Assert.AreEqual(Int32BlockPool.INT32_BLOCK_SIZE * RamUsageEstimator.NUM_BYTES_INT32, bytesUsed.Get());
                 }
             }
         }
@@ -122,7 +122,7 @@ namespace Lucene.Net.Index
                 else
                 {
                     pool.Reset(true, true);
-                    Assert.AreEqual(Int32BlockPool.INT_BLOCK_SIZE * RamUsageEstimator.NUM_BYTES_INT, bytesUsed.Get());
+                    Assert.AreEqual(Int32BlockPool.INT32_BLOCK_SIZE * RamUsageEstimator.NUM_BYTES_INT32, bytesUsed.Get());
                 }
             }
         }
@@ -132,7 +132,7 @@ namespace Lucene.Net.Index
             internal readonly Counter BytesUsed;
 
             public ByteTrackingAllocator(Counter bytesUsed)
-                : this(Int32BlockPool.INT_BLOCK_SIZE, bytesUsed)
+                : this(Int32BlockPool.INT32_BLOCK_SIZE, bytesUsed)
             {
             }
 
@@ -144,13 +144,13 @@ namespace Lucene.Net.Index
 
             public override int[] GetInt32Block()
             {
-                BytesUsed.AddAndGet(m_blockSize * RamUsageEstimator.NUM_BYTES_INT);
+                BytesUsed.AddAndGet(m_blockSize * RamUsageEstimator.NUM_BYTES_INT32);
                 return new int[m_blockSize];
             }
 
             public override void RecycleInt32Blocks(int[][] blocks, int start, int end)
             {
-                BytesUsed.AddAndGet(-((end - start) * m_blockSize * RamUsageEstimator.NUM_BYTES_INT));
+                BytesUsed.AddAndGet(-((end - start) * m_blockSize * RamUsageEstimator.NUM_BYTES_INT32));
             }
         }
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Tests/core/Search/TestFieldCache.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Search/TestFieldCache.cs b/src/Lucene.Net.Tests/core/Search/TestFieldCache.cs
index 918a693..d98b8b5 100644
--- a/src/Lucene.Net.Tests/core/Search/TestFieldCache.cs
+++ b/src/Lucene.Net.Tests/core/Search/TestFieldCache.cs
@@ -211,7 +211,7 @@ namespace Lucene.Net.Search
 
             FieldCache.Int64s longs = cache.GetInt64s(Reader, "theLong", Random().NextBoolean());
             Assert.AreSame(longs, cache.GetInt64s(Reader, "theLong", Random().NextBoolean()), "Second request to cache return same array");
-            Assert.AreSame(longs, cache.GetInt64s(Reader, "theLong", FieldCache.DEFAULT_LONG_PARSER, Random().NextBoolean()), "Second request with explicit parser return same array");
+            Assert.AreSame(longs, cache.GetInt64s(Reader, "theLong", FieldCache.DEFAULT_INT64_PARSER, Random().NextBoolean()), "Second request with explicit parser return same array");
             for (int i = 0; i < NUM_DOCS; i++)
             {
                 Assert.IsTrue(longs.Get(i) == (long.MaxValue - i), longs.Get(i) + " does not equal: " + (long.MaxValue - i) + " i=" + i);
@@ -228,7 +228,7 @@ namespace Lucene.Net.Search
 
             FieldCache.Int16s shorts = cache.GetInt16s(Reader, "theShort", Random().NextBoolean());
             Assert.AreSame(shorts, cache.GetInt16s(Reader, "theShort", Random().NextBoolean()), "Second request to cache return same array");
-            Assert.AreSame(shorts, cache.GetInt16s(Reader, "theShort", FieldCache.DEFAULT_SHORT_PARSER, Random().NextBoolean()), "Second request with explicit parser return same array");
+            Assert.AreSame(shorts, cache.GetInt16s(Reader, "theShort", FieldCache.DEFAULT_INT16_PARSER, Random().NextBoolean()), "Second request with explicit parser return same array");
             for (int i = 0; i < NUM_DOCS; i++)
             {
                 Assert.IsTrue(shorts.Get(i) == (short)(short.MaxValue - i), shorts.Get(i) + " does not equal: " + (short.MaxValue - i));
@@ -237,7 +237,7 @@ namespace Lucene.Net.Search
 
             FieldCache.Int32s ints = cache.GetInt32s(Reader, "theInt", Random().NextBoolean());
             Assert.AreSame(ints, cache.GetInt32s(Reader, "theInt", Random().NextBoolean()), "Second request to cache return same array");
-            Assert.AreSame(ints, cache.GetInt32s(Reader, "theInt", FieldCache.DEFAULT_INT_PARSER, Random().NextBoolean()), "Second request with explicit parser return same array");
+            Assert.AreSame(ints, cache.GetInt32s(Reader, "theInt", FieldCache.DEFAULT_INT32_PARSER, Random().NextBoolean()), "Second request with explicit parser return same array");
             for (int i = 0; i < NUM_DOCS; i++)
             {
                 Assert.IsTrue(ints.Get(i) == (int.MaxValue - i), ints.Get(i) + " does not equal: " + (int.MaxValue - i));
@@ -245,7 +245,7 @@ namespace Lucene.Net.Search
 
             FieldCache.Singles floats = cache.GetSingles(Reader, "theFloat", Random().NextBoolean());
             Assert.AreSame(floats, cache.GetSingles(Reader, "theFloat", Random().NextBoolean()), "Second request to cache return same array");
-            Assert.AreSame(floats, cache.GetSingles(Reader, "theFloat", FieldCache.DEFAULT_FLOAT_PARSER, Random().NextBoolean()), "Second request with explicit parser return same array");
+            Assert.AreSame(floats, cache.GetSingles(Reader, "theFloat", FieldCache.DEFAULT_SINGLE_PARSER, Random().NextBoolean()), "Second request with explicit parser return same array");
             for (int i = 0; i < NUM_DOCS; i++)
             {
                 Assert.IsTrue(floats.Get(i) == (float.MaxValue - i), floats.Get(i) + " does not equal: " + (float.MaxValue - i));

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Tests/core/Search/TestNumericRangeQuery32.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Search/TestNumericRangeQuery32.cs b/src/Lucene.Net.Tests/core/Search/TestNumericRangeQuery32.cs
index 5236870..776286a 100644
--- a/src/Lucene.Net.Tests/core/Search/TestNumericRangeQuery32.cs
+++ b/src/Lucene.Net.Tests/core/Search/TestNumericRangeQuery32.cs
@@ -413,7 +413,7 @@ namespace Lucene.Net.Search
                     lower = upper;
                     upper = a;
                 }
-                BytesRef lowerBytes = new BytesRef(NumericUtils.BUF_SIZE_INT), upperBytes = new BytesRef(NumericUtils.BUF_SIZE_INT);
+                BytesRef lowerBytes = new BytesRef(NumericUtils.BUF_SIZE_INT32), upperBytes = new BytesRef(NumericUtils.BUF_SIZE_INT32);
                 NumericUtils.Int32ToPrefixCodedBytes(lower, 0, lowerBytes);
                 NumericUtils.Int32ToPrefixCodedBytes(upper, 0, upperBytes);
 
@@ -644,7 +644,7 @@ namespace Lucene.Net.Search
                     upper = a;
                 }
                 Query tq = NumericRangeQuery.NewInt32Range(field, precisionStep, lower, upper, true, true);
-                TopDocs topDocs = Searcher.Search(tq, null, NoDocs, new Sort(new SortField(field, SortFieldType.INT, true)));
+                TopDocs topDocs = Searcher.Search(tq, null, NoDocs, new Sort(new SortField(field, SortFieldType.INT32, true)));
                 if (topDocs.TotalHits == 0)
                 {
                     continue;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Tests/core/Search/TestNumericRangeQuery64.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Search/TestNumericRangeQuery64.cs b/src/Lucene.Net.Tests/core/Search/TestNumericRangeQuery64.cs
index 97da973..c5c39c9 100644
--- a/src/Lucene.Net.Tests/core/Search/TestNumericRangeQuery64.cs
+++ b/src/Lucene.Net.Tests/core/Search/TestNumericRangeQuery64.cs
@@ -440,7 +440,7 @@ namespace Lucene.Net.Search
                     lower = upper;
                     upper = a;
                 }
-                BytesRef lowerBytes = new BytesRef(NumericUtils.BUF_SIZE_LONG), upperBytes = new BytesRef(NumericUtils.BUF_SIZE_LONG);
+                BytesRef lowerBytes = new BytesRef(NumericUtils.BUF_SIZE_INT64), upperBytes = new BytesRef(NumericUtils.BUF_SIZE_INT64);
                 NumericUtils.Int64ToPrefixCodedBytes(lower, 0, lowerBytes);
                 NumericUtils.Int64ToPrefixCodedBytes(upper, 0, upperBytes);
 
@@ -689,7 +689,7 @@ namespace Lucene.Net.Search
                     upper = a;
                 }
                 Query tq = NumericRangeQuery.NewInt64Range(field, precisionStep, lower, upper, true, true);
-                TopDocs topDocs = Searcher.Search(tq, null, NoDocs, new Sort(new SortField(field, SortFieldType.LONG, true)));
+                TopDocs topDocs = Searcher.Search(tq, null, NoDocs, new Sort(new SortField(field, SortFieldType.INT64, true)));
                 if (topDocs.TotalHits == 0)
                 {
                     continue;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Tests/core/Search/TestSearchAfter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Search/TestSearchAfter.cs b/src/Lucene.Net.Tests/core/Search/TestSearchAfter.cs
index c4635b1..0ed76bf 100644
--- a/src/Lucene.Net.Tests/core/Search/TestSearchAfter.cs
+++ b/src/Lucene.Net.Tests/core/Search/TestSearchAfter.cs
@@ -70,21 +70,21 @@ namespace Lucene.Net.Search
             AllSortFields = new List<SortField>(Arrays.AsList(new SortField[] {
 #pragma warning disable 612,618
                 new SortField("byte", SortFieldType.BYTE, false),
-                new SortField("short", SortFieldType.SHORT, false),
+                new SortField("short", SortFieldType.INT16, false),
 #pragma warning restore 612,618
-                new SortField("int", SortFieldType.INT, false),
-                new SortField("long", SortFieldType.LONG, false),
-                new SortField("float", SortFieldType.FLOAT, false),
+                new SortField("int", SortFieldType.INT32, false),
+                new SortField("long", SortFieldType.INT64, false),
+                new SortField("float", SortFieldType.SINGLE, false),
                 new SortField("double", SortFieldType.DOUBLE, false),
                 new SortField("bytes", SortFieldType.STRING, false),
                 new SortField("bytesval", SortFieldType.STRING_VAL, false),
 #pragma warning disable 612,618
                 new SortField("byte", SortFieldType.BYTE, true),
-                new SortField("short", SortFieldType.SHORT, true),
+                new SortField("short", SortFieldType.INT16, true),
 #pragma warning restore 612,618
-                new SortField("int", SortFieldType.INT, true),
-                new SortField("long", SortFieldType.LONG, true),
-                new SortField("float", SortFieldType.FLOAT, true),
+                new SortField("int", SortFieldType.INT32, true),
+                new SortField("long", SortFieldType.INT64, true),
+                new SortField("float", SortFieldType.SINGLE, true),
                 new SortField("double", SortFieldType.DOUBLE, true),
                 new SortField("bytes", SortFieldType.STRING, true),
                 new SortField("bytesval", SortFieldType.STRING_VAL, true),
@@ -94,7 +94,7 @@ namespace Lucene.Net.Search
 
             if (SupportsDocValues)
             {
-                AllSortFields.AddRange(Arrays.AsList(new SortField[] { new SortField("intdocvalues", SortFieldType.INT, false), new SortField("floatdocvalues", SortFieldType.FLOAT, false), new SortField("sortedbytesdocvalues", SortFieldType.STRING, false), new SortField("sortedbytesdocvaluesval", SortFieldType.STRING_VAL, false), new SortField("straightbytesdocvalues", SortFieldType.STRING_VAL, false), new SortField("intdocvalues", SortFieldType.INT, true), new SortField("floatdocvalues", SortFieldType.FLOAT, true), new SortField("sortedbytesdocvalues", SortFieldType.STRING, true), new SortField("sortedbytesdocvaluesval", SortFieldType.STRING_VAL, true), new SortField("straightbytesdocvalues", SortFieldType.STRING_VAL, true) }));
+                AllSortFields.AddRange(Arrays.AsList(new SortField[] { new SortField("intdocvalues", SortFieldType.INT32, false), new SortField("floatdocvalues", SortFieldType.SINGLE, false), new SortField("sortedbytesdocvalues", SortFieldType.STRING, false), new SortField("sortedbytesdocvaluesval", SortFieldType.STRING_VAL, false), new SortField("straightbytesdocvalues", SortFieldType.STRING_VAL, false), new SortField("intdocvalues", SortFieldType.INT32, true), new SortField("floatdocvalues", SortFieldType.SINGLE, true), new SortField("sortedbytesdocvalues", SortFieldType.STRING, true), new SortField("sortedbytesdocvaluesval", SortFieldType.STRING_VAL, true), new SortField("straightbytesdocvalues", SortFieldType.STRING_VAL, true) }));
             }
 
             // Also test missing first / last for the "string" sorts:
@@ -117,21 +117,21 @@ namespace Lucene.Net.Search
             for (int i = 0; i < limit; i++)
             {
                 SortField sf = AllSortFields[i];
-                if (sf.Type == SortFieldType.INT)
+                if (sf.Type == SortFieldType.INT32)
                 {
-                    SortField sf2 = new SortField(sf.Field, SortFieldType.INT, sf.IsReverse);
+                    SortField sf2 = new SortField(sf.Field, SortFieldType.INT32, sf.IsReverse);
                     sf2.MissingValue = Random().Next();
                     AllSortFields.Add(sf2);
                 }
-                else if (sf.Type == SortFieldType.LONG)
+                else if (sf.Type == SortFieldType.INT64)
                 {
-                    SortField sf2 = new SortField(sf.Field, SortFieldType.LONG, sf.IsReverse);
+                    SortField sf2 = new SortField(sf.Field, SortFieldType.INT64, sf.IsReverse);
                     sf2.MissingValue = Random().NextLong();
                     AllSortFields.Add(sf2);
                 }
-                else if (sf.Type == SortFieldType.FLOAT)
+                else if (sf.Type == SortFieldType.SINGLE)
                 {
-                    SortField sf2 = new SortField(sf.Field, SortFieldType.FLOAT, sf.IsReverse);
+                    SortField sf2 = new SortField(sf.Field, SortFieldType.SINGLE, sf.IsReverse);
                     sf2.MissingValue = (float)Random().NextDouble();
                     AllSortFields.Add(sf2);
                 }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Tests/core/Search/TestShardSearching.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Search/TestShardSearching.cs b/src/Lucene.Net.Tests/core/Search/TestShardSearching.cs
index f59144e..5fb1dc9 100644
--- a/src/Lucene.Net.Tests/core/Search/TestShardSearching.cs
+++ b/src/Lucene.Net.Tests/core/Search/TestShardSearching.cs
@@ -262,7 +262,7 @@ namespace Lucene.Net.Search
                                 }
                                 else if (what == 2)
                                 {
-                                    sort = new Sort(new SortField[] { new SortField("docid", SortFieldType.INT, Random().NextBoolean()) });
+                                    sort = new Sort(new SortField[] { new SortField("docid", SortFieldType.INT32, Random().NextBoolean()) });
                                 }
                                 else
                                 {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Tests/core/Search/TestSort.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Search/TestSort.cs b/src/Lucene.Net.Tests/core/Search/TestSort.cs
index 9d09ed2..27e9f25 100644
--- a/src/Lucene.Net.Tests/core/Search/TestSort.cs
+++ b/src/Lucene.Net.Tests/core/Search/TestSort.cs
@@ -693,7 +693,7 @@ namespace Lucene.Net.Search
 
             IndexSearcher searcher = NewSearcher(ir);
 #pragma warning disable 612, 618
-            Sort sort = new Sort(new SortField("value", SortFieldType.SHORT));
+            Sort sort = new Sort(new SortField("value", SortFieldType.INT16));
 #pragma warning restore 612, 618
 
             TopDocs td = searcher.Search(new MatchAllDocsQuery(), 10, sort);
@@ -727,7 +727,7 @@ namespace Lucene.Net.Search
 
             IndexSearcher searcher = NewSearcher(ir);
 #pragma warning disable 612, 618
-            Sort sort = new Sort(new SortField("value", SortFieldType.SHORT));
+            Sort sort = new Sort(new SortField("value", SortFieldType.INT16));
 #pragma warning restore 612, 618
 
             TopDocs td = searcher.Search(new MatchAllDocsQuery(), 10, sort);
@@ -761,7 +761,7 @@ namespace Lucene.Net.Search
 
             IndexSearcher searcher = NewSearcher(ir);
 #pragma warning disable 612, 618
-            SortField sortField = new SortField("value", SortFieldType.SHORT);
+            SortField sortField = new SortField("value", SortFieldType.INT16);
 #pragma warning restore 612, 618
             sortField.MissingValue = short.MaxValue;
             Sort sort = new Sort(sortField);
@@ -798,7 +798,7 @@ namespace Lucene.Net.Search
 
             IndexSearcher searcher = NewSearcher(ir);
 #pragma warning disable 612, 618
-            Sort sort = new Sort(new SortField("value", SortFieldType.SHORT, true));
+            Sort sort = new Sort(new SortField("value", SortFieldType.INT16, true));
 #pragma warning restore 612, 618
 
             TopDocs td = searcher.Search(new MatchAllDocsQuery(), 10, sort);
@@ -832,7 +832,7 @@ namespace Lucene.Net.Search
             writer.Dispose();
 
             IndexSearcher searcher = NewSearcher(ir);
-            Sort sort = new Sort(new SortField("value", SortFieldType.INT));
+            Sort sort = new Sort(new SortField("value", SortFieldType.INT32));
 
             TopDocs td = searcher.Search(new MatchAllDocsQuery(), 10, sort);
             Assert.AreEqual(3, td.TotalHits);
@@ -864,7 +864,7 @@ namespace Lucene.Net.Search
             writer.Dispose();
 
             IndexSearcher searcher = NewSearcher(ir);
-            Sort sort = new Sort(new SortField("value", SortFieldType.INT));
+            Sort sort = new Sort(new SortField("value", SortFieldType.INT32));
 
             TopDocs td = searcher.Search(new MatchAllDocsQuery(), 10, sort);
             Assert.AreEqual(3, td.TotalHits);
@@ -896,7 +896,7 @@ namespace Lucene.Net.Search
             writer.Dispose();
 
             IndexSearcher searcher = NewSearcher(ir);
-            SortField sortField = new SortField("value", SortFieldType.INT);
+            SortField sortField = new SortField("value", SortFieldType.INT32);
             sortField.MissingValue = int.MaxValue;
             Sort sort = new Sort(sortField);
 
@@ -931,7 +931,7 @@ namespace Lucene.Net.Search
             writer.Dispose();
 
             IndexSearcher searcher = NewSearcher(ir);
-            Sort sort = new Sort(new SortField("value", SortFieldType.INT, true));
+            Sort sort = new Sort(new SortField("value", SortFieldType.INT32, true));
 
             TopDocs td = searcher.Search(new MatchAllDocsQuery(), 10, sort);
             Assert.AreEqual(3, td.TotalHits);
@@ -964,7 +964,7 @@ namespace Lucene.Net.Search
             writer.Dispose();
 
             IndexSearcher searcher = NewSearcher(ir);
-            Sort sort = new Sort(new SortField("value", SortFieldType.LONG));
+            Sort sort = new Sort(new SortField("value", SortFieldType.INT64));
 
             TopDocs td = searcher.Search(new MatchAllDocsQuery(), 10, sort);
             Assert.AreEqual(3, td.TotalHits);
@@ -996,7 +996,7 @@ namespace Lucene.Net.Search
             writer.Dispose();
 
             IndexSearcher searcher = NewSearcher(ir);
-            Sort sort = new Sort(new SortField("value", SortFieldType.LONG));
+            Sort sort = new Sort(new SortField("value", SortFieldType.INT64));
 
             TopDocs td = searcher.Search(new MatchAllDocsQuery(), 10, sort);
             Assert.AreEqual(3, td.TotalHits);
@@ -1028,7 +1028,7 @@ namespace Lucene.Net.Search
             writer.Dispose();
 
             IndexSearcher searcher = NewSearcher(ir);
-            SortField sortField = new SortField("value", SortFieldType.LONG);
+            SortField sortField = new SortField("value", SortFieldType.INT64);
             sortField.MissingValue = long.MaxValue;
             Sort sort = new Sort(sortField);
 
@@ -1063,7 +1063,7 @@ namespace Lucene.Net.Search
             writer.Dispose();
 
             IndexSearcher searcher = NewSearcher(ir);
-            Sort sort = new Sort(new SortField("value", SortFieldType.LONG, true));
+            Sort sort = new Sort(new SortField("value", SortFieldType.INT64, true));
 
             TopDocs td = searcher.Search(new MatchAllDocsQuery(), 10, sort);
             Assert.AreEqual(3, td.TotalHits);
@@ -1096,7 +1096,7 @@ namespace Lucene.Net.Search
             writer.Dispose();
 
             IndexSearcher searcher = NewSearcher(ir);
-            Sort sort = new Sort(new SortField("value", SortFieldType.FLOAT));
+            Sort sort = new Sort(new SortField("value", SortFieldType.SINGLE));
 
             TopDocs td = searcher.Search(new MatchAllDocsQuery(), 10, sort);
             Assert.AreEqual(3, td.TotalHits);
@@ -1128,7 +1128,7 @@ namespace Lucene.Net.Search
             writer.Dispose();
 
             IndexSearcher searcher = NewSearcher(ir);
-            Sort sort = new Sort(new SortField("value", SortFieldType.FLOAT));
+            Sort sort = new Sort(new SortField("value", SortFieldType.SINGLE));
 
             TopDocs td = searcher.Search(new MatchAllDocsQuery(), 10, sort);
             Assert.AreEqual(3, td.TotalHits);
@@ -1160,7 +1160,7 @@ namespace Lucene.Net.Search
             writer.Dispose();
 
             IndexSearcher searcher = NewSearcher(ir);
-            SortField sortField = new SortField("value", SortFieldType.FLOAT);
+            SortField sortField = new SortField("value", SortFieldType.SINGLE);
             sortField.MissingValue = float.MaxValue;
             Sort sort = new Sort(sortField);
 
@@ -1195,7 +1195,7 @@ namespace Lucene.Net.Search
             writer.Dispose();
 
             IndexSearcher searcher = NewSearcher(ir);
-            Sort sort = new Sort(new SortField("value", SortFieldType.FLOAT, true));
+            Sort sort = new Sort(new SortField("value", SortFieldType.SINGLE, true));
 
             TopDocs td = searcher.Search(new MatchAllDocsQuery(), 10, sort);
             Assert.AreEqual(3, td.TotalHits);
@@ -1470,8 +1470,8 @@ namespace Lucene.Net.Search
             float maxScore = s.Search(q, 10).MaxScore;
             Assert.AreEqual(maxScore, s.Search(q, null, 3, Sort.INDEXORDER, Random().NextBoolean(), true).MaxScore, 0.0);
             Assert.AreEqual(maxScore, s.Search(q, null, 3, Sort.RELEVANCE, Random().NextBoolean(), true).MaxScore, 0.0);
-            Assert.AreEqual(maxScore, s.Search(q, null, 3, new Sort(new SortField[] { new SortField("id", SortFieldType.INT, false) }), Random().NextBoolean(), true).MaxScore, 0.0);
-            Assert.AreEqual(maxScore, s.Search(q, null, 3, new Sort(new SortField[] { new SortField("id", SortFieldType.INT, true) }), Random().NextBoolean(), true).MaxScore, 0.0);
+            Assert.AreEqual(maxScore, s.Search(q, null, 3, new Sort(new SortField[] { new SortField("id", SortFieldType.INT32, false) }), Random().NextBoolean(), true).MaxScore, 0.0);
+            Assert.AreEqual(maxScore, s.Search(q, null, 3, new Sort(new SortField[] { new SortField("id", SortFieldType.INT32, true) }), Random().NextBoolean(), true).MaxScore, 0.0);
             r.Dispose();
             d.Dispose();
         }
@@ -1492,7 +1492,7 @@ namespace Lucene.Net.Search
             td = empty.Search(query, null, 10, sort, true, true);
             Assert.AreEqual(0, td.TotalHits);
 
-            sort.SetSort(new SortField("int", SortFieldType.INT), SortField.FIELD_DOC);
+            sort.SetSort(new SortField("int", SortFieldType.INT32), SortField.FIELD_DOC);
             td = empty.Search(query, null, 10, sort, true, true);
             Assert.AreEqual(0, td.TotalHits);
 
@@ -1504,7 +1504,7 @@ namespace Lucene.Net.Search
             td = empty.Search(query, null, 10, sort, true, true);
             Assert.AreEqual(0, td.TotalHits);
 
-            sort.SetSort(new SortField("float", SortFieldType.FLOAT), new SortField("string", SortFieldType.STRING));
+            sort.SetSort(new SortField("float", SortFieldType.SINGLE), new SortField("string", SortFieldType.STRING));
             td = empty.Search(query, null, 10, sort, true, true);
             Assert.AreEqual(0, td.TotalHits);
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Tests/core/Search/TestSortDocValues.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Search/TestSortDocValues.cs b/src/Lucene.Net.Tests/core/Search/TestSortDocValues.cs
index 7f58afb..fcf39ae 100644
--- a/src/Lucene.Net.Tests/core/Search/TestSortDocValues.cs
+++ b/src/Lucene.Net.Tests/core/Search/TestSortDocValues.cs
@@ -351,7 +351,7 @@ namespace Lucene.Net.Search
 
             IndexSearcher searcher = NewSearcher(ir);
 #pragma warning disable 612, 618
-            Sort sort = new Sort(new SortField("value", SortFieldType.SHORT));
+            Sort sort = new Sort(new SortField("value", SortFieldType.INT16));
 #pragma warning restore 612, 618
 
             TopDocs td = searcher.Search(new MatchAllDocsQuery(), 10, sort);
@@ -390,7 +390,7 @@ namespace Lucene.Net.Search
 
             IndexSearcher searcher = NewSearcher(ir);
 #pragma warning disable 612, 618
-            Sort sort = new Sort(new SortField("value", SortFieldType.SHORT, true));
+            Sort sort = new Sort(new SortField("value", SortFieldType.INT16, true));
 #pragma warning restore 612, 618
 
             TopDocs td = searcher.Search(new MatchAllDocsQuery(), 10, sort);
@@ -428,7 +428,7 @@ namespace Lucene.Net.Search
             writer.Dispose();
 
             IndexSearcher searcher = NewSearcher(ir);
-            Sort sort = new Sort(new SortField("value", SortFieldType.INT));
+            Sort sort = new Sort(new SortField("value", SortFieldType.INT32));
 
             TopDocs td = searcher.Search(new MatchAllDocsQuery(), 10, sort);
             Assert.AreEqual(3, td.TotalHits);
@@ -465,7 +465,7 @@ namespace Lucene.Net.Search
             writer.Dispose();
 
             IndexSearcher searcher = NewSearcher(ir);
-            Sort sort = new Sort(new SortField("value", SortFieldType.INT, true));
+            Sort sort = new Sort(new SortField("value", SortFieldType.INT32, true));
 
             TopDocs td = searcher.Search(new MatchAllDocsQuery(), 10, sort);
             Assert.AreEqual(3, td.TotalHits);
@@ -500,7 +500,7 @@ namespace Lucene.Net.Search
             writer.Dispose();
 
             IndexSearcher searcher = NewSearcher(ir);
-            Sort sort = new Sort(new SortField("value", SortFieldType.INT));
+            Sort sort = new Sort(new SortField("value", SortFieldType.INT32));
 
             TopDocs td = searcher.Search(new MatchAllDocsQuery(), 10, sort);
             Assert.AreEqual(3, td.TotalHits);
@@ -534,7 +534,7 @@ namespace Lucene.Net.Search
             writer.Dispose();
 
             IndexSearcher searcher = NewSearcher(ir);
-            SortField sortField = new SortField("value", SortFieldType.INT);
+            SortField sortField = new SortField("value", SortFieldType.INT32);
             sortField.MissingValue = int.MaxValue;
             Sort sort = new Sort(sortField);
 
@@ -572,7 +572,7 @@ namespace Lucene.Net.Search
             writer.Dispose();
 
             IndexSearcher searcher = NewSearcher(ir);
-            Sort sort = new Sort(new SortField("value", SortFieldType.LONG));
+            Sort sort = new Sort(new SortField("value", SortFieldType.INT64));
 
             TopDocs td = searcher.Search(new MatchAllDocsQuery(), 10, sort);
             Assert.AreEqual(3, td.TotalHits);
@@ -609,7 +609,7 @@ namespace Lucene.Net.Search
             writer.Dispose();
 
             IndexSearcher searcher = NewSearcher(ir);
-            Sort sort = new Sort(new SortField("value", SortFieldType.LONG, true));
+            Sort sort = new Sort(new SortField("value", SortFieldType.INT64, true));
 
             TopDocs td = searcher.Search(new MatchAllDocsQuery(), 10, sort);
             Assert.AreEqual(3, td.TotalHits);
@@ -644,7 +644,7 @@ namespace Lucene.Net.Search
             writer.Dispose();
 
             IndexSearcher searcher = NewSearcher(ir);
-            Sort sort = new Sort(new SortField("value", SortFieldType.LONG));
+            Sort sort = new Sort(new SortField("value", SortFieldType.INT64));
 
             TopDocs td = searcher.Search(new MatchAllDocsQuery(), 10, sort);
             Assert.AreEqual(3, td.TotalHits);
@@ -678,7 +678,7 @@ namespace Lucene.Net.Search
             writer.Dispose();
 
             IndexSearcher searcher = NewSearcher(ir);
-            SortField sortField = new SortField("value", SortFieldType.LONG);
+            SortField sortField = new SortField("value", SortFieldType.INT64);
             sortField.MissingValue = long.MaxValue;
             Sort sort = new Sort(sortField);
 
@@ -716,7 +716,7 @@ namespace Lucene.Net.Search
             writer.Dispose();
 
             IndexSearcher searcher = NewSearcher(ir);
-            Sort sort = new Sort(new SortField("value", SortFieldType.FLOAT));
+            Sort sort = new Sort(new SortField("value", SortFieldType.SINGLE));
 
             TopDocs td = searcher.Search(new MatchAllDocsQuery(), 10, sort);
             Assert.AreEqual(3, td.TotalHits);
@@ -753,7 +753,7 @@ namespace Lucene.Net.Search
             writer.Dispose();
 
             IndexSearcher searcher = NewSearcher(ir);
-            Sort sort = new Sort(new SortField("value", SortFieldType.FLOAT, true));
+            Sort sort = new Sort(new SortField("value", SortFieldType.SINGLE, true));
 
             TopDocs td = searcher.Search(new MatchAllDocsQuery(), 10, sort);
             Assert.AreEqual(3, td.TotalHits);
@@ -788,7 +788,7 @@ namespace Lucene.Net.Search
             writer.Dispose();
 
             IndexSearcher searcher = NewSearcher(ir);
-            Sort sort = new Sort(new SortField("value", SortFieldType.FLOAT));
+            Sort sort = new Sort(new SortField("value", SortFieldType.SINGLE));
 
             TopDocs td = searcher.Search(new MatchAllDocsQuery(), 10, sort);
             Assert.AreEqual(3, td.TotalHits);
@@ -822,7 +822,7 @@ namespace Lucene.Net.Search
             writer.Dispose();
 
             IndexSearcher searcher = NewSearcher(ir);
-            SortField sortField = new SortField("value", SortFieldType.FLOAT);
+            SortField sortField = new SortField("value", SortFieldType.SINGLE);
             sortField.MissingValue = float.MaxValue;
             Sort sort = new Sort(sortField);
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Tests/core/Search/TestSortRescorer.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Search/TestSortRescorer.cs b/src/Lucene.Net.Tests/core/Search/TestSortRescorer.cs
index d2a0a33..2ebc16c 100644
--- a/src/Lucene.Net.Tests/core/Search/TestSortRescorer.cs
+++ b/src/Lucene.Net.Tests/core/Search/TestSortRescorer.cs
@@ -98,7 +98,7 @@ namespace Lucene.Net.Search
             Assert.AreEqual("2", r.Document(hits.ScoreDocs[2].Doc).Get("id"));
 
             // Now, rescore:
-            Sort sort = new Sort(new SortField("popularity", SortFieldType.INT, true));
+            Sort sort = new Sort(new SortField("popularity", SortFieldType.INT32, true));
             Rescorer rescorer = new SortRescorer(sort);
             hits = rescorer.Rescore(Searcher, hits, 10);
             Assert.AreEqual(3, hits.TotalHits);
@@ -150,7 +150,7 @@ namespace Lucene.Net.Search
 
             TopDocs hits = s.Search(new TermQuery(new Term("field", "a")), numHits);
 
-            Rescorer rescorer = new SortRescorer(new Sort(new SortField("num", SortFieldType.INT, reverse)));
+            Rescorer rescorer = new SortRescorer(new Sort(new SortField("num", SortFieldType.INT32, reverse)));
             TopDocs hits2 = rescorer.Rescore(s, hits, numHits);
 
             int[] expected = new int[numHits];

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Tests/core/Search/TestTopDocsMerge.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Search/TestTopDocsMerge.cs b/src/Lucene.Net.Tests/core/Search/TestTopDocsMerge.cs
index b454cd2..a3391de 100644
--- a/src/Lucene.Net.Tests/core/Search/TestTopDocsMerge.cs
+++ b/src/Lucene.Net.Tests/core/Search/TestTopDocsMerge.cs
@@ -182,10 +182,10 @@ namespace Lucene.Net.Search
             IList<SortField> sortFields = new List<SortField>();
             sortFields.Add(new SortField("string", SortFieldType.STRING, true));
             sortFields.Add(new SortField("string", SortFieldType.STRING, false));
-            sortFields.Add(new SortField("int", SortFieldType.INT, true));
-            sortFields.Add(new SortField("int", SortFieldType.INT, false));
-            sortFields.Add(new SortField("float", SortFieldType.FLOAT, true));
-            sortFields.Add(new SortField("float", SortFieldType.FLOAT, false));
+            sortFields.Add(new SortField("int", SortFieldType.INT32, true));
+            sortFields.Add(new SortField("int", SortFieldType.INT32, false));
+            sortFields.Add(new SortField("float", SortFieldType.SINGLE, true));
+            sortFields.Add(new SortField("float", SortFieldType.SINGLE, false));
             sortFields.Add(new SortField(null, SortFieldType.SCORE, true));
             sortFields.Add(new SortField(null, SortFieldType.SCORE, false));
             sortFields.Add(new SortField(null, SortFieldType.DOC, true));

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Tests/core/TestSearch.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/TestSearch.cs b/src/Lucene.Net.Tests/core/TestSearch.cs
index c91c558..262b595 100644
--- a/src/Lucene.Net.Tests/core/TestSearch.cs
+++ b/src/Lucene.Net.Tests/core/TestSearch.cs
@@ -141,7 +141,7 @@ namespace Lucene.Net
 
             ScoreDoc[] hits = null;
 
-            Sort sort = new Sort(SortField.FIELD_SCORE, new SortField("id", SortFieldType.INT));
+            Sort sort = new Sort(SortField.FIELD_SCORE, new SortField("id", SortFieldType.INT32));
 
             foreach (Query query in BuildQueries())
             {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Tests/core/TestSearchForDuplicates.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/TestSearchForDuplicates.cs b/src/Lucene.Net.Tests/core/TestSearchForDuplicates.cs
index 5e373b9..6ea65fb 100644
--- a/src/Lucene.Net.Tests/core/TestSearchForDuplicates.cs
+++ b/src/Lucene.Net.Tests/core/TestSearchForDuplicates.cs
@@ -104,7 +104,7 @@ namespace Lucene.Net
                 Console.WriteLine("TEST: search query=" + query);
             }
 
-            Sort sort = new Sort(SortField.FIELD_SCORE, new SortField(ID_FIELD, SortFieldType.INT));
+            Sort sort = new Sort(SortField.FIELD_SCORE, new SortField(ID_FIELD, SortFieldType.INT32));
 
             ScoreDoc[] hits = searcher.Search(query, null, MAX_DOCS, sort).ScoreDocs;
             PrintHits(@out, hits, searcher);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Tests/core/Util/TestFieldCacheSanityChecker.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Util/TestFieldCacheSanityChecker.cs b/src/Lucene.Net.Tests/core/Util/TestFieldCacheSanityChecker.cs
index 8773d2b..25ed72c 100644
--- a/src/Lucene.Net.Tests/core/Util/TestFieldCacheSanityChecker.cs
+++ b/src/Lucene.Net.Tests/core/Util/TestFieldCacheSanityChecker.cs
@@ -126,7 +126,7 @@ namespace Lucene.Net.Util
             cache.GetDoubles(ReaderB, "theDouble", FieldCache.DEFAULT_DOUBLE_PARSER, false);
 
             cache.GetInt32s(ReaderX, "theInt", false);
-            cache.GetInt32s(ReaderX, "theInt", FieldCache.DEFAULT_INT_PARSER, false);
+            cache.GetInt32s(ReaderX, "theInt", FieldCache.DEFAULT_INT32_PARSER, false);
 
             // // //
 
@@ -147,7 +147,7 @@ namespace Lucene.Net.Util
             IFieldCache cache = FieldCache.DEFAULT;
             cache.PurgeAllCaches();
 
-            cache.GetInt32s(ReaderX, "theInt", FieldCache.DEFAULT_INT_PARSER, false);
+            cache.GetInt32s(ReaderX, "theInt", FieldCache.DEFAULT_INT32_PARSER, false);
             cache.GetTerms(ReaderX, "theInt", false);
 #pragma warning disable 612, 618
             cache.GetBytes(ReaderX, "theByte", false);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Tests/core/Util/TestIntsRef.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Util/TestIntsRef.cs b/src/Lucene.Net.Tests/core/Util/TestIntsRef.cs
index 4ed5c73..053a9b4 100644
--- a/src/Lucene.Net.Tests/core/Util/TestIntsRef.cs
+++ b/src/Lucene.Net.Tests/core/Util/TestIntsRef.cs
@@ -26,7 +26,7 @@ namespace Lucene.Net.Util
         public virtual void TestEmpty()
         {
             Int32sRef i = new Int32sRef();
-            Assert.AreEqual(Int32sRef.EMPTY_INTS, i.Int32s);
+            Assert.AreEqual(Int32sRef.EMPTY_INT32S, i.Int32s);
             Assert.AreEqual(0, i.Offset);
             Assert.AreEqual(0, i.Length);
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/73cb5b22/src/Lucene.Net.Tests/core/Util/TestNumericUtils.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests/core/Util/TestNumericUtils.cs b/src/Lucene.Net.Tests/core/Util/TestNumericUtils.cs
index 5c3de83..ea13443 100644
--- a/src/Lucene.Net.Tests/core/Util/TestNumericUtils.cs
+++ b/src/Lucene.Net.Tests/core/Util/TestNumericUtils.cs
@@ -31,7 +31,7 @@ namespace Lucene.Net.Util
         public virtual void TestLongConversionAndOrdering()
         {
             // generate a series of encoded longs, each numerical one bigger than the one before
-            BytesRef last = null, act = new BytesRef(NumericUtils.BUF_SIZE_LONG);
+            BytesRef last = null, act = new BytesRef(NumericUtils.BUF_SIZE_INT64);
             for (long l = -100000L; l < 100000L; l++)
             {
                 NumericUtils.Int64ToPrefixCodedBytes(l, 0, act);
@@ -45,7 +45,7 @@ namespace Lucene.Net.Util
                 Assert.AreEqual(l, NumericUtils.PrefixCodedToInt64(act), "forward and back conversion should generate same long");
                 // next step
                 last = act;
-                act = new BytesRef(NumericUtils.BUF_SIZE_LONG);
+                act = new BytesRef(NumericUtils.BUF_SIZE_INT64);
             }
         }
 
@@ -53,7 +53,7 @@ namespace Lucene.Net.Util
         public virtual void TestIntConversionAndOrdering()
         {
             // generate a series of encoded ints, each numerical one bigger than the one before
-            BytesRef last = null, act = new BytesRef(NumericUtils.BUF_SIZE_INT);
+            BytesRef last = null, act = new BytesRef(NumericUtils.BUF_SIZE_INT32);
             for (int i = -100000; i < 100000; i++)
             {
                 NumericUtils.Int32ToPrefixCodedBytes(i, 0, act);
@@ -67,7 +67,7 @@ namespace Lucene.Net.Util
                 Assert.AreEqual(i, NumericUtils.PrefixCodedToInt32(act), "forward and back conversion should generate same int");
                 // next step
                 last = act;
-                act = new BytesRef(NumericUtils.BUF_SIZE_INT);
+                act = new BytesRef(NumericUtils.BUF_SIZE_INT32);
             }
         }
 
@@ -79,7 +79,7 @@ namespace Lucene.Net.Util
 
             for (int i = 0; i < vals.Length; i++)
             {
-                prefixVals[i] = new BytesRef(NumericUtils.BUF_SIZE_LONG);
+                prefixVals[i] = new BytesRef(NumericUtils.BUF_SIZE_INT64);
                 NumericUtils.Int64ToPrefixCodedBytes(vals[i], 0, prefixVals[i]);
 
                 // check forward and back conversion
@@ -106,7 +106,7 @@ namespace Lucene.Net.Util
             }
 
             // check the prefix encoding, lower precision should have the difference to original value equal to the lower removed bits
-            BytesRef @ref = new BytesRef(NumericUtils.BUF_SIZE_LONG);
+            BytesRef @ref = new BytesRef(NumericUtils.BUF_SIZE_INT64);
             for (int i = 0; i < vals.Length; i++)
             {
                 for (int j = 0; j < 64; j++)
@@ -127,7 +127,7 @@ namespace Lucene.Net.Util
 
             for (int i = 0; i < vals.Length; i++)
             {
-                prefixVals[i] = new BytesRef(NumericUtils.BUF_SIZE_INT);
+                prefixVals[i] = new BytesRef(NumericUtils.BUF_SIZE_INT32);
                 NumericUtils.Int32ToPrefixCodedBytes(vals[i], 0, prefixVals[i]);
 
                 // check forward and back conversion
@@ -154,7 +154,7 @@ namespace Lucene.Net.Util
             }
 
             // check the prefix encoding, lower precision should have the difference to original value equal to the lower removed bits
-            BytesRef @ref = new BytesRef(NumericUtils.BUF_SIZE_LONG);
+            BytesRef @ref = new BytesRef(NumericUtils.BUF_SIZE_INT64);
             for (int i = 0; i < vals.Length; i++)
             {
                 for (int j = 0; j < 32; j++)


[04/53] [abbrv] lucenenet git commit: Lucene.Net.Core: Renamed all type-derived properties and methods from Short, Int, Long, and Float to match CLR types Int16, Int32, Int64, and Single, respectively.

Posted by ni...@apache.org.
http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Suggest/Suggest/Analyzing/FSTUtil.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Suggest/Suggest/Analyzing/FSTUtil.cs b/src/Lucene.Net.Suggest/Suggest/Analyzing/FSTUtil.cs
index da8ce9d..9770af5 100644
--- a/src/Lucene.Net.Suggest/Suggest/Analyzing/FSTUtil.cs
+++ b/src/Lucene.Net.Suggest/Suggest/Analyzing/FSTUtil.cs
@@ -104,8 +104,8 @@ namespace Lucene.Net.Search.Suggest.Analyzing
                         if (nextArc != null)
                         {
                             IntsRef newInput = new IntsRef(currentInput.Length + 1);
-                            newInput.CopyInts(currentInput);
-                            newInput.Ints[currentInput.Length] = t.Min;
+                            newInput.CopyInt32s(currentInput);
+                            newInput.Int32s[currentInput.Length] = t.Min;
                             newInput.Length = currentInput.Length + 1;
                             queue.Add(new Path<T>(t.Dest, new FST.Arc<T>()
                               .CopyFrom(nextArc), fst.Outputs.Add(path.Output, nextArc.Output), newInput));
@@ -127,8 +127,8 @@ namespace Lucene.Net.Search.Suggest.Analyzing
                             Debug.Assert(nextArc.Label <= max);
                             Debug.Assert(nextArc.Label >= min, nextArc.Label + " " + min);
                             IntsRef newInput = new IntsRef(currentInput.Length + 1);
-                            newInput.CopyInts(currentInput);
-                            newInput.Ints[currentInput.Length] = nextArc.Label;
+                            newInput.CopyInt32s(currentInput);
+                            newInput.Int32s[currentInput.Length] = nextArc.Label;
                             newInput.Length = currentInput.Length + 1;
                             queue.Add(new Path<T>(t.Dest, new FST.Arc<T>()
                               .CopyFrom(nextArc), fst.Outputs.Add(path.Output, nextArc.Output), newInput));

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Suggest/Suggest/Analyzing/FreeTextSuggester.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Suggest/Suggest/Analyzing/FreeTextSuggester.cs b/src/Lucene.Net.Suggest/Suggest/Analyzing/FreeTextSuggester.cs
index 0a29651..2336710 100644
--- a/src/Lucene.Net.Suggest/Suggest/Analyzing/FreeTextSuggester.cs
+++ b/src/Lucene.Net.Suggest/Suggest/Analyzing/FreeTextSuggester.cs
@@ -213,12 +213,12 @@ namespace Lucene.Net.Search.Suggest.Analyzing
                 readerB.Reset(b.Bytes, b.Offset, b.Length);
 
                 // By token:
-                scratchA.Length = (ushort)readerA.ReadShort();
+                scratchA.Length = (ushort)readerA.ReadInt16();
                 scratchA.Bytes = a.Bytes;
                 scratchA.Offset = readerA.Position;
 
                 scratchB.Bytes = b.Bytes;
-                scratchB.Length = (ushort)readerB.ReadShort();
+                scratchB.Length = (ushort)readerB.ReadInt16();
                 scratchB.Offset = readerB.Position;
 
                 int cmp = scratchA.CompareTo(scratchB);
@@ -391,7 +391,7 @@ namespace Lucene.Net.Search.Suggest.Analyzing
                             totTokens += termsEnum.TotalTermFreq;
                         }
 
-                        builder.Add(Lucene.Net.Util.Fst.Util.ToIntsRef(term, scratchInts), EncodeWeight(termsEnum.TotalTermFreq));
+                        builder.Add(Lucene.Net.Util.Fst.Util.ToInt32sRef(term, scratchInts), EncodeWeight(termsEnum.TotalTermFreq));
                     }
 
                     fst = builder.Finish();
@@ -454,10 +454,10 @@ namespace Lucene.Net.Search.Suggest.Analyzing
         public override bool Store(DataOutput output)
         {
             CodecUtil.WriteHeader(output, CODEC_NAME, VERSION_CURRENT);
-            output.WriteVLong(count);
+            output.WriteVInt64(count);
             output.WriteByte(separator);
-            output.WriteVInt(grams);
-            output.WriteVLong(totTokens);
+            output.WriteVInt32(grams);
+            output.WriteVInt64(totTokens);
             fst.Save(output);
             return true;
         }
@@ -465,18 +465,18 @@ namespace Lucene.Net.Search.Suggest.Analyzing
         public override bool Load(DataInput input)
         {
             CodecUtil.CheckHeader(input, CODEC_NAME, VERSION_START, VERSION_START);
-            count = input.ReadVLong();
+            count = input.ReadVInt64();
             var separatorOrig = (sbyte)input.ReadByte();
             if (separatorOrig != separator)
             {
                 throw new InvalidOperationException("separator=" + separator + " is incorrect: original model was built with separator=" + separatorOrig);
             }
-            int gramsOrig = input.ReadVInt();
+            int gramsOrig = input.ReadVInt32();
             if (gramsOrig != grams)
             {
                 throw new InvalidOperationException("grams=" + grams + " is incorrect: original model was built with grams=" + gramsOrig);
             }
-            totTokens = input.ReadVLong();
+            totTokens = input.ReadVInt64();
 
             fst = new FST<long?>(input, PositiveIntOutputs.Singleton);
 
@@ -676,7 +676,7 @@ namespace Lucene.Net.Search.Suggest.Analyzing
                         if (token.Bytes[token.Offset + i] == separator)
                         {
                             BytesRef context = new BytesRef(token.Bytes, token.Offset, i);
-                            long? output = Lucene.Net.Util.Fst.Util.Get(fst, Lucene.Net.Util.Fst.Util.ToIntsRef(context, new IntsRef()));
+                            long? output = Lucene.Net.Util.Fst.Util.Get(fst, Lucene.Net.Util.Fst.Util.ToInt32sRef(context, new IntsRef()));
                             Debug.Assert(output != null);
                             contextCount = DecodeWeight(output);
                             lastTokenFragment = new BytesRef(token.Bytes, token.Offset + i + 1, token.Length - i - 1);

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Suggest/Suggest/Analyzing/FuzzySuggester.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Suggest/Suggest/Analyzing/FuzzySuggester.cs b/src/Lucene.Net.Suggest/Suggest/Analyzing/FuzzySuggester.cs
index 5f202fb..9600293 100644
--- a/src/Lucene.Net.Suggest/Suggest/Analyzing/FuzzySuggester.cs
+++ b/src/Lucene.Net.Suggest/Suggest/Analyzing/FuzzySuggester.cs
@@ -230,14 +230,14 @@ namespace Lucene.Net.Search.Suggest.Analyzing
             {
                 if (path.Length <= nonFuzzyPrefix || path.Length < minFuzzyLength)
                 {
-                    subs[upto] = BasicAutomata.MakeString(path.Ints, path.Offset, path.Length);
+                    subs[upto] = BasicAutomata.MakeString(path.Int32s, path.Offset, path.Length);
                     upto++;
                 }
                 else
                 {
-                    Automaton prefix = BasicAutomata.MakeString(path.Ints, path.Offset, nonFuzzyPrefix);
+                    Automaton prefix = BasicAutomata.MakeString(path.Int32s, path.Offset, nonFuzzyPrefix);
                     int[] ints = new int[path.Length - nonFuzzyPrefix];
-                    Array.Copy(path.Ints, path.Offset + nonFuzzyPrefix, ints, 0, ints.Length);
+                    Array.Copy(path.Int32s, path.Offset + nonFuzzyPrefix, ints, 0, ints.Length);
                     // TODO: maybe add alphaMin to LevenshteinAutomata,
                     // and pass 1 instead of 0?  We probably don't want
                     // to allow the trailing dedup bytes to be

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Suggest/Suggest/Fst/FSTCompletionBuilder.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Suggest/Suggest/Fst/FSTCompletionBuilder.cs b/src/Lucene.Net.Suggest/Suggest/Fst/FSTCompletionBuilder.cs
index 7bac69c..ae68e3f 100644
--- a/src/Lucene.Net.Suggest/Suggest/Fst/FSTCompletionBuilder.cs
+++ b/src/Lucene.Net.Suggest/Suggest/Fst/FSTCompletionBuilder.cs
@@ -261,7 +261,7 @@ namespace Lucene.Net.Search.Suggest.Fst
                 count++;
                 if (scratch.CompareTo(entry) != 0)
                 {
-                    builder.Add(Util.Fst.Util.ToIntsRef(entry, scratchIntsRef), empty);
+                    builder.Add(Util.Fst.Util.ToInt32sRef(entry, scratchIntsRef), empty);
                     scratch.CopyBytes(entry);
                 }
             }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Suggest/Suggest/Fst/FSTCompletionLookup.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Suggest/Suggest/Fst/FSTCompletionLookup.cs b/src/Lucene.Net.Suggest/Suggest/Fst/FSTCompletionLookup.cs
index 7d30394..5dcce06 100644
--- a/src/Lucene.Net.Suggest/Suggest/Fst/FSTCompletionLookup.cs
+++ b/src/Lucene.Net.Suggest/Suggest/Fst/FSTCompletionLookup.cs
@@ -169,7 +169,7 @@ namespace Lucene.Net.Search.Suggest.Fst
                     }
 
                     output.Reset(buffer);
-                    output.WriteInt(EncodeWeight(iterator.Weight));
+                    output.WriteInt32(EncodeWeight(iterator.Weight));
                     output.WriteBytes(spare.Bytes, spare.Offset, spare.Length);
                     writer.Write(buffer, 0, output.Position);
                 }
@@ -192,7 +192,7 @@ namespace Lucene.Net.Search.Suggest.Fst
                 while (reader.Read(tmp1))
                 {
                     input.Reset(tmp1.Bytes);
-                    int currentScore = input.ReadInt();
+                    int currentScore = input.ReadInt32();
 
                     int bucket;
                     if (line > 0 && currentScore == previousScore)
@@ -290,7 +290,7 @@ namespace Lucene.Net.Search.Suggest.Fst
         {
             lock (this)
             {
-                output.WriteVLong(count);
+                output.WriteVInt64(count);
                 if (this.normalCompletion == null || normalCompletion.FST == null)
                 {
                     return false;
@@ -304,7 +304,7 @@ namespace Lucene.Net.Search.Suggest.Fst
         {
             lock (this)
             {
-                count = input.ReadVLong();
+                count = input.ReadVInt64();
                 this.higherWeightsCompletion = new FSTCompletion(new FST<object>(input, NoOutputs.Singleton));
                 this.normalCompletion = new FSTCompletion(higherWeightsCompletion.FST, false, exactMatchFirst);
                 return true;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Suggest/Suggest/Fst/WFSTCompletionLookup.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Suggest/Suggest/Fst/WFSTCompletionLookup.cs b/src/Lucene.Net.Suggest/Suggest/Fst/WFSTCompletionLookup.cs
index 72e0bef..0b4a408 100644
--- a/src/Lucene.Net.Suggest/Suggest/Fst/WFSTCompletionLookup.cs
+++ b/src/Lucene.Net.Suggest/Suggest/Fst/WFSTCompletionLookup.cs
@@ -106,7 +106,7 @@ namespace Lucene.Net.Search.Suggest.Fst
                     continue; // for duplicate suggestions, the best weight is actually
                     // added
                 }
-                Lucene.Net.Util.Fst.Util.ToIntsRef(scratch, scratchInts);
+                Lucene.Net.Util.Fst.Util.ToInt32sRef(scratch, scratchInts);
                 builder.Add(scratchInts, cost);
                 previous.CopyBytes(scratch);
                 count++;
@@ -116,7 +116,7 @@ namespace Lucene.Net.Search.Suggest.Fst
 
         public override bool Store(DataOutput output)
         {
-            output.WriteVLong(count);
+            output.WriteVInt64(count);
             if (fst == null)
             {
                 return false;
@@ -127,7 +127,7 @@ namespace Lucene.Net.Search.Suggest.Fst
 
         public override bool Load(DataInput input)
         {
-            count = input.ReadVLong();
+            count = input.ReadVInt64();
             this.fst = new FST<long?>(input, PositiveIntOutputs.Singleton);
             return true;
         }
@@ -303,7 +303,7 @@ namespace Lucene.Net.Search.Suggest.Fst
                 }
                 output.Reset(buffer);
                 output.WriteBytes(spare.Bytes, spare.Offset, spare.Length);
-                output.WriteInt(EncodeWeight(weight));
+                output.WriteInt32(EncodeWeight(weight));
                 writer.Write(buffer, 0, output.Position);
             }
 
@@ -312,7 +312,7 @@ namespace Lucene.Net.Search.Suggest.Fst
                 scratch.Length -= 4; // int
                 // skip suggestion:
                 tmpInput.Reset(scratch.Bytes, scratch.Offset + scratch.Length, 4);
-                return tmpInput.ReadInt();
+                return tmpInput.ReadInt32();
             }
         }
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Suggest/Suggest/Jaspell/JaspellLookup.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Suggest/Suggest/Jaspell/JaspellLookup.cs b/src/Lucene.Net.Suggest/Suggest/Jaspell/JaspellLookup.cs
index f91503d..f32b5d0 100644
--- a/src/Lucene.Net.Suggest/Suggest/Jaspell/JaspellLookup.cs
+++ b/src/Lucene.Net.Suggest/Suggest/Jaspell/JaspellLookup.cs
@@ -166,7 +166,7 @@ namespace Lucene.Net.Search.Suggest.Jaspell
             sbyte mask = (sbyte)@in.ReadByte();
             if ((mask & HAS_VALUE) != 0)
             {
-                node.data = Convert.ToInt64(@in.ReadLong());
+                node.data = Convert.ToInt64(@in.ReadInt64());
             }
             if ((mask & LO_KID) != 0)
             {
@@ -215,7 +215,7 @@ namespace Lucene.Net.Search.Suggest.Jaspell
             @out.WriteByte((byte)mask);
             if (node.data != null)
             {
-                @out.WriteLong((long)(node.data));
+                @out.WriteInt64((long)(node.data));
             }
             WriteRecursively(@out, node.relatives[JaspellTernarySearchTrie.TSTNode.LOKID]);
             WriteRecursively(@out, node.relatives[JaspellTernarySearchTrie.TSTNode.EQKID]);
@@ -224,7 +224,7 @@ namespace Lucene.Net.Search.Suggest.Jaspell
 
         public override bool Store(DataOutput output)
         {
-            output.WriteVLong(count);
+            output.WriteVInt64(count);
             JaspellTernarySearchTrie.TSTNode root = trie.Root;
             if (root == null) // empty tree
             {
@@ -236,7 +236,7 @@ namespace Lucene.Net.Search.Suggest.Jaspell
 
         public override bool Load(DataInput input)
         {
-            count = input.ReadVLong();
+            count = input.ReadVInt64();
             var root = new JaspellTernarySearchTrie.TSTNode(trie, '\0', null);
             ReadRecursively(input, root);
             trie.Root = root;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Suggest/Suggest/SortedInputIterator.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Suggest/Suggest/SortedInputIterator.cs b/src/Lucene.Net.Suggest/Suggest/SortedInputIterator.cs
index b9e7c31..f1016ac 100644
--- a/src/Lucene.Net.Suggest/Suggest/SortedInputIterator.cs
+++ b/src/Lucene.Net.Suggest/Suggest/SortedInputIterator.cs
@@ -292,16 +292,16 @@ namespace Lucene.Net.Search.Suggest
                 foreach (BytesRef ctx in contexts)
                 {
                     output.WriteBytes(ctx.Bytes, ctx.Offset, ctx.Length);
-                    output.WriteShort((short)ctx.Length);
+                    output.WriteInt16((short)ctx.Length);
                 }
-                output.WriteShort((short)contexts.Count());
+                output.WriteInt16((short)contexts.Count());
             }
             if (hasPayloads)
             {
                 output.WriteBytes(payload.Bytes, payload.Offset, payload.Length);
-                output.WriteShort((short)payload.Length);
+                output.WriteInt16((short)payload.Length);
             }
-            output.WriteLong(weight);
+            output.WriteInt64(weight);
             writer.Write(buffer, 0, output.Position);
         }
 
@@ -312,7 +312,7 @@ namespace Lucene.Net.Search.Suggest
             tmpInput.Reset(scratch.Bytes);
             tmpInput.SkipBytes(scratch.Length - 8); // suggestion
             scratch.Length -= 8; // long
-            return tmpInput.ReadLong();
+            return tmpInput.ReadInt64();
         }
 
         /// <summary>
@@ -321,14 +321,14 @@ namespace Lucene.Net.Search.Suggest
         {
             tmpInput.Reset(scratch.Bytes);
             tmpInput.SkipBytes(scratch.Length - 2); //skip to context set size
-            ushort ctxSetSize = (ushort)tmpInput.ReadShort();
+            ushort ctxSetSize = (ushort)tmpInput.ReadInt16();
             scratch.Length -= 2;
 
             var contextSet = new HashSet<BytesRef>();
             for (ushort i = 0; i < ctxSetSize; i++)
             {
                 tmpInput.Position = scratch.Length - 2;
-                ushort curContextLength = (ushort)tmpInput.ReadShort();
+                ushort curContextLength = (ushort)tmpInput.ReadInt16();
                 scratch.Length -= 2;
                 tmpInput.Position = scratch.Length - curContextLength;
                 BytesRef contextSpare = new BytesRef(curContextLength);
@@ -353,7 +353,7 @@ namespace Lucene.Net.Search.Suggest
         {
             tmpInput.Reset(scratch.Bytes);
             tmpInput.SkipBytes(scratch.Length - 2); // skip to payload size
-            ushort payloadLength = (ushort)tmpInput.ReadShort(); // read payload size
+            ushort payloadLength = (ushort)tmpInput.ReadInt16(); // read payload size
             tmpInput.Position = scratch.Length - 2 - payloadLength; // setPosition to start of payload
             BytesRef payloadScratch = new BytesRef(payloadLength);
             tmpInput.ReadBytes(payloadScratch.Bytes, 0, payloadLength); // read payload

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Suggest/Suggest/SortedTermFreqIteratorWrapper.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Suggest/Suggest/SortedTermFreqIteratorWrapper.cs b/src/Lucene.Net.Suggest/Suggest/SortedTermFreqIteratorWrapper.cs
index f171bb6..f808890 100644
--- a/src/Lucene.Net.Suggest/Suggest/SortedTermFreqIteratorWrapper.cs
+++ b/src/Lucene.Net.Suggest/Suggest/SortedTermFreqIteratorWrapper.cs
@@ -213,7 +213,7 @@ namespace Lucene.Net.Search.Suggest
             }
             output.Reset(buffer);
             output.WriteBytes(spare.Bytes, spare.Offset, spare.Length);
-            output.WriteLong(weight);
+            output.WriteInt64(weight);
             writer.Write(buffer, 0, output.Position);
         }
 
@@ -224,7 +224,7 @@ namespace Lucene.Net.Search.Suggest
             tmpInput.Reset(scratch.Bytes);
             tmpInput.SkipBytes(scratch.Length - 8); // suggestion
             scratch.Length -= 8; // long
-            return tmpInput.ReadLong();
+            return tmpInput.ReadInt64();
         }
     }
 }
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Suggest/Suggest/Tst/TSTLookup.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Suggest/Suggest/Tst/TSTLookup.cs b/src/Lucene.Net.Suggest/Suggest/Tst/TSTLookup.cs
index 362b5e8..61a13a3 100644
--- a/src/Lucene.Net.Suggest/Suggest/Tst/TSTLookup.cs
+++ b/src/Lucene.Net.Suggest/Suggest/Tst/TSTLookup.cs
@@ -185,7 +185,7 @@ namespace Lucene.Net.Search.Suggest.Tst
             }
             if ((mask & HAS_VALUE) != 0)
             {
-                node.val = Convert.ToInt64(@in.ReadLong());
+                node.val = Convert.ToInt64(@in.ReadInt64());
             }
             if ((mask & LO_KID) != 0)
             {
@@ -238,7 +238,7 @@ namespace Lucene.Net.Search.Suggest.Tst
             }
             if (node.val != null)
             {
-                @out.WriteLong((long)node.val);
+                @out.WriteInt64((long)node.val);
             }
             // recurse and write kids
             if (node.loKid != null)
@@ -259,7 +259,7 @@ namespace Lucene.Net.Search.Suggest.Tst
         {
             lock (this)
             {
-                output.WriteVLong(count);
+                output.WriteVInt64(count);
                 WriteRecursively(output, root);
                 return true;
             }
@@ -269,7 +269,7 @@ namespace Lucene.Net.Search.Suggest.Tst
         {
             lock (this)
             {
-                count = input.ReadVLong();
+                count = input.ReadVInt64();
                 root = new TernaryTreeNode();
                 ReadRecursively(input, root);
                 return true;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.TestFramework/Codecs/MockIntBlock/MockFixedIntBlockPostingsFormat.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.TestFramework/Codecs/MockIntBlock/MockFixedIntBlockPostingsFormat.cs b/src/Lucene.Net.TestFramework/Codecs/MockIntBlock/MockFixedIntBlockPostingsFormat.cs
index 224a385..7a3fc76 100644
--- a/src/Lucene.Net.TestFramework/Codecs/MockIntBlock/MockFixedIntBlockPostingsFormat.cs
+++ b/src/Lucene.Net.TestFramework/Codecs/MockIntBlock/MockFixedIntBlockPostingsFormat.cs
@@ -106,7 +106,7 @@ namespace Lucene.Net.Codecs.IntBlock
                     {
                         for (int i = 0; i < buffer.Length; i++)
                         {
-                            buffer[i] = @in.ReadVInt();
+                            buffer[i] = @in.ReadVInt32();
                         }
                     }
                 }
@@ -144,7 +144,7 @@ namespace Lucene.Net.Codecs.IntBlock
             {
                 for (int i = 0; i < m_buffer.Length; i++)
                 {
-                    m_output.WriteVInt(m_buffer[i]);
+                    m_output.WriteVInt32(m_buffer[i]);
                 }
             }
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.TestFramework/Codecs/MockIntBlock/MockVariableIntBlockPostingsFormat.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.TestFramework/Codecs/MockIntBlock/MockVariableIntBlockPostingsFormat.cs b/src/Lucene.Net.TestFramework/Codecs/MockIntBlock/MockVariableIntBlockPostingsFormat.cs
index ba69c73..99878b0 100644
--- a/src/Lucene.Net.TestFramework/Codecs/MockIntBlock/MockVariableIntBlockPostingsFormat.cs
+++ b/src/Lucene.Net.TestFramework/Codecs/MockIntBlock/MockVariableIntBlockPostingsFormat.cs
@@ -68,7 +68,7 @@ namespace Lucene.Net.Codecs.IntBlock
             public override IntIndexInput OpenInput(Directory dir, string fileName, IOContext context)
             {
                 IndexInput input = dir.OpenInput(fileName, context);
-                int baseBlockSize = input.ReadInt();
+                int baseBlockSize = input.ReadInt32();
                 return new VariableIntBlockIndexInputAnonymousHelper(input, baseBlockSize);
             }
 
@@ -105,12 +105,12 @@ namespace Lucene.Net.Codecs.IntBlock
 
                     public int ReadBlock()
                     {
-                        buffer[0] = input.ReadVInt();
+                        buffer[0] = input.ReadVInt32();
                         int count = buffer[0] <= 3 ? baseBlockSize - 1 : 2 * baseBlockSize - 1;
                         Debug.Assert(buffer.Length >= count, "buffer.length=" + buffer.Length + " count=" + count);
                         for (int i = 0; i < count; i++)
                         {
-                            buffer[i + 1] = input.ReadVInt();
+                            buffer[i + 1] = input.ReadVInt32();
                         }
                         return 1 + count;
                     }
@@ -123,7 +123,7 @@ namespace Lucene.Net.Codecs.IntBlock
                 bool success = false;
                 try
                 {
-                    output.WriteInt(baseBlockSize);
+                    output.WriteInt32(baseBlockSize);
                     VariableIntBlockIndexOutput ret = new VariableIntBlockIndexOutputAnonymousHelper(output, 2 * baseBlockSize);
                     success = true;
                     return ret;
@@ -164,7 +164,7 @@ namespace Lucene.Net.Codecs.IntBlock
                 {
                     for (int i = 0; i < flushAt; i++)
                     {
-                        m_output.WriteVInt(buffer[i]);
+                        m_output.WriteVInt32(buffer[i]);
                     }
                     buffer[0] = buffer[flushAt];
                     pendingCount = 1;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.TestFramework/Codecs/MockSep/MockSingleIntIndexInput.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.TestFramework/Codecs/MockSep/MockSingleIntIndexInput.cs b/src/Lucene.Net.TestFramework/Codecs/MockSep/MockSingleIntIndexInput.cs
index d5affba..e949505 100644
--- a/src/Lucene.Net.TestFramework/Codecs/MockSep/MockSingleIntIndexInput.cs
+++ b/src/Lucene.Net.TestFramework/Codecs/MockSep/MockSingleIntIndexInput.cs
@@ -67,7 +67,7 @@ namespace Lucene.Net.Codecs.MockSep
             public override int Next()
             {
                 //System.out.println("msii.next() fp=" + in.getFilePointer() + " vs " + in.length());
-                return @in.ReadVInt();
+                return @in.ReadVInt32();
             }
         }
 
@@ -79,11 +79,11 @@ namespace Lucene.Net.Codecs.MockSep
             {
                 if (absolute)
                 {
-                    fp = indexIn.ReadVLong();
+                    fp = indexIn.ReadVInt64();
                 }
                 else
                 {
-                    fp += indexIn.ReadVLong();
+                    fp += indexIn.ReadVInt64();
                 }
             }
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.TestFramework/Codecs/MockSep/MockSingleIntIndexOutput.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.TestFramework/Codecs/MockSep/MockSingleIntIndexOutput.cs b/src/Lucene.Net.TestFramework/Codecs/MockSep/MockSingleIntIndexOutput.cs
index 13b0996..47d6a29 100644
--- a/src/Lucene.Net.TestFramework/Codecs/MockSep/MockSingleIntIndexOutput.cs
+++ b/src/Lucene.Net.TestFramework/Codecs/MockSep/MockSingleIntIndexOutput.cs
@@ -37,7 +37,7 @@ namespace Lucene.Net.Codecs.MockSep
 
         public override void Write(int v)
         {
-            @out.WriteVInt(v);
+            @out.WriteVInt32(v);
         }
 
         public override AbstractIndex GetIndex()
@@ -84,11 +84,11 @@ namespace Lucene.Net.Codecs.MockSep
             {
                 if (absolute)
                 {
-                    indexOut.WriteVLong(fp);
+                    indexOut.WriteVInt64(fp);
                 }
                 else
                 {
-                    indexOut.WriteVLong(fp - lastFP);
+                    indexOut.WriteVInt64(fp - lastFP);
                 }
                 lastFP = fp;
             }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.TestFramework/Codecs/lucene3x/PreFlexRWFieldInfosReader.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.TestFramework/Codecs/lucene3x/PreFlexRWFieldInfosReader.cs b/src/Lucene.Net.TestFramework/Codecs/lucene3x/PreFlexRWFieldInfosReader.cs
index c014da6..458951e 100644
--- a/src/Lucene.Net.TestFramework/Codecs/lucene3x/PreFlexRWFieldInfosReader.cs
+++ b/src/Lucene.Net.TestFramework/Codecs/lucene3x/PreFlexRWFieldInfosReader.cs
@@ -47,7 +47,7 @@ namespace Lucene.Net.Codecs.Lucene3x
 
             try
             {
-                int format = input.ReadVInt();
+                int format = input.ReadVInt32();
 
                 if (format > FORMAT_MINIMUM)
                 {
@@ -58,13 +58,13 @@ namespace Lucene.Net.Codecs.Lucene3x
                     throw new IndexFormatTooNewException(input, format, FORMAT_MINIMUM, PreFlexRWFieldInfosWriter.FORMAT_CURRENT);
                 }
 
-                int size = input.ReadVInt(); //read in the size
+                int size = input.ReadVInt32(); //read in the size
                 FieldInfo[] infos = new FieldInfo[size];
 
                 for (int i = 0; i < size; i++)
                 {
                     string name = input.ReadString();
-                    int fieldNumber = format == PreFlexRWFieldInfosWriter.FORMAT_PREFLEX_RW ? input.ReadInt() : i;
+                    int fieldNumber = format == PreFlexRWFieldInfosWriter.FORMAT_PREFLEX_RW ? input.ReadInt32() : i;
                     byte bits = input.ReadByte();
                     bool isIndexed = (bits & PreFlexRWFieldInfosWriter.IS_INDEXED) != 0;
                     bool storeTermVector = (bits & PreFlexRWFieldInfosWriter.STORE_TERMVECTOR) != 0;

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.TestFramework/Codecs/lucene3x/PreFlexRWFieldInfosWriter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.TestFramework/Codecs/lucene3x/PreFlexRWFieldInfosWriter.cs b/src/Lucene.Net.TestFramework/Codecs/lucene3x/PreFlexRWFieldInfosWriter.cs
index b70f86b..e0fef49 100644
--- a/src/Lucene.Net.TestFramework/Codecs/lucene3x/PreFlexRWFieldInfosWriter.cs
+++ b/src/Lucene.Net.TestFramework/Codecs/lucene3x/PreFlexRWFieldInfosWriter.cs
@@ -66,8 +66,8 @@ namespace Lucene.Net.Codecs.Lucene3x
             bool success = false;
             try
             {
-                output.WriteVInt(FORMAT_PREFLEX_RW);
-                output.WriteVInt(infos.Count);
+                output.WriteVInt32(FORMAT_PREFLEX_RW);
+                output.WriteVInt32(infos.Count);
                 foreach (FieldInfo fi in infos)
                 {
                     sbyte bits = 0x0;
@@ -102,7 +102,7 @@ namespace Lucene.Net.Codecs.Lucene3x
                      * to stabelize the field numbers across segments so the
                      * FI ordinal is not necessarily equivalent to the field number
                      */
-                    output.WriteInt(fi.Number);
+                    output.WriteInt32(fi.Number);
                     output.WriteByte((byte)bits);
                     if (fi.IsIndexed && !fi.OmitsNorms)
                     {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.TestFramework/Codecs/lucene3x/PreFlexRWFieldsWriter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.TestFramework/Codecs/lucene3x/PreFlexRWFieldsWriter.cs b/src/Lucene.Net.TestFramework/Codecs/lucene3x/PreFlexRWFieldsWriter.cs
index 4e22cf5..b0c8174 100644
--- a/src/Lucene.Net.TestFramework/Codecs/lucene3x/PreFlexRWFieldsWriter.cs
+++ b/src/Lucene.Net.TestFramework/Codecs/lucene3x/PreFlexRWFieldsWriter.cs
@@ -171,19 +171,19 @@ namespace Lucene.Net.Codecs.Lucene3x
 
                     if (OuterInstance.OmitTF)
                     {
-                        OuterInstance.OuterInstance.FreqOut.WriteVInt(delta);
+                        OuterInstance.OuterInstance.FreqOut.WriteVInt32(delta);
                     }
                     else
                     {
                         int code = delta << 1;
                         if (termDocFreq == 1)
                         {
-                            OuterInstance.OuterInstance.FreqOut.WriteVInt(code | 1);
+                            OuterInstance.OuterInstance.FreqOut.WriteVInt32(code | 1);
                         }
                         else
                         {
-                            OuterInstance.OuterInstance.FreqOut.WriteVInt(code);
-                            OuterInstance.OuterInstance.FreqOut.WriteVInt(termDocFreq);
+                            OuterInstance.OuterInstance.FreqOut.WriteVInt32(code);
+                            OuterInstance.OuterInstance.FreqOut.WriteVInt32(termDocFreq);
                         }
                     }
                     LastPosition = 0;
@@ -205,12 +205,12 @@ namespace Lucene.Net.Codecs.Lucene3x
                         {
                             //System.out.println("        write payload len=" + payloadLength);
                             LastPayloadLength = payloadLength;
-                            OuterInstance.OuterInstance.ProxOut.WriteVInt((delta << 1) | 1);
-                            OuterInstance.OuterInstance.ProxOut.WriteVInt(payloadLength);
+                            OuterInstance.OuterInstance.ProxOut.WriteVInt32((delta << 1) | 1);
+                            OuterInstance.OuterInstance.ProxOut.WriteVInt32(payloadLength);
                         }
                         else
                         {
-                            OuterInstance.OuterInstance.ProxOut.WriteVInt(delta << 1);
+                            OuterInstance.OuterInstance.ProxOut.WriteVInt32(delta << 1);
                         }
                         if (payloadLength > 0)
                         {
@@ -219,7 +219,7 @@ namespace Lucene.Net.Codecs.Lucene3x
                     }
                     else
                     {
-                        OuterInstance.OuterInstance.ProxOut.WriteVInt(delta);
+                        OuterInstance.OuterInstance.ProxOut.WriteVInt32(delta);
                     }
                 }
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.TestFramework/Codecs/lucene3x/PreFlexRWSkipListWriter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.TestFramework/Codecs/lucene3x/PreFlexRWSkipListWriter.cs b/src/Lucene.Net.TestFramework/Codecs/lucene3x/PreFlexRWSkipListWriter.cs
index c3aff4f..0ce2d24 100644
--- a/src/Lucene.Net.TestFramework/Codecs/lucene3x/PreFlexRWSkipListWriter.cs
+++ b/src/Lucene.Net.TestFramework/Codecs/lucene3x/PreFlexRWSkipListWriter.cs
@@ -109,25 +109,25 @@ namespace Lucene.Net.Codecs.Lucene3x
                 {
                     // the current payload length equals the length at the previous skip point,
                     // so we don't store the length again
-                    skipBuffer.WriteVInt(delta * 2);
+                    skipBuffer.WriteVInt32(delta * 2);
                 }
                 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 * 2 + 1);
-                    skipBuffer.WriteVInt(CurPayloadLength);
+                    skipBuffer.WriteVInt32(delta * 2 + 1);
+                    skipBuffer.WriteVInt32(CurPayloadLength);
                     LastSkipPayloadLength[level] = CurPayloadLength;
                 }
             }
             else
             {
                 // current field does not store payloads
-                skipBuffer.WriteVInt(CurDoc - LastSkipDoc[level]);
+                skipBuffer.WriteVInt32(CurDoc - LastSkipDoc[level]);
             }
 
-            skipBuffer.WriteVInt((int)(CurFreqPointer - LastSkipFreqPointer[level]));
-            skipBuffer.WriteVInt((int)(CurProxPointer - LastSkipProxPointer[level]));
+            skipBuffer.WriteVInt32((int)(CurFreqPointer - LastSkipFreqPointer[level]));
+            skipBuffer.WriteVInt32((int)(CurProxPointer - LastSkipProxPointer[level]));
 
             LastSkipDoc[level] = CurDoc;
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.TestFramework/Codecs/lucene3x/PreFlexRWStoredFieldsWriter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.TestFramework/Codecs/lucene3x/PreFlexRWStoredFieldsWriter.cs b/src/Lucene.Net.TestFramework/Codecs/lucene3x/PreFlexRWStoredFieldsWriter.cs
index fb38f4a..628564a 100644
--- a/src/Lucene.Net.TestFramework/Codecs/lucene3x/PreFlexRWStoredFieldsWriter.cs
+++ b/src/Lucene.Net.TestFramework/Codecs/lucene3x/PreFlexRWStoredFieldsWriter.cs
@@ -53,8 +53,8 @@ namespace Lucene.Net.Codecs.Lucene3x
                 FieldsStream = directory.CreateOutput(IndexFileNames.SegmentFileName(segment, "", Lucene3xStoredFieldsReader.FIELDS_EXTENSION), context);
                 IndexStream = directory.CreateOutput(IndexFileNames.SegmentFileName(segment, "", Lucene3xStoredFieldsReader.FIELDS_INDEX_EXTENSION), context);
 
-                FieldsStream.WriteInt(Lucene3xStoredFieldsReader.FORMAT_CURRENT);
-                IndexStream.WriteInt(Lucene3xStoredFieldsReader.FORMAT_CURRENT);
+                FieldsStream.WriteInt32(Lucene3xStoredFieldsReader.FORMAT_CURRENT);
+                IndexStream.WriteInt32(Lucene3xStoredFieldsReader.FORMAT_CURRENT);
 
                 success = true;
             }
@@ -73,8 +73,8 @@ namespace Lucene.Net.Codecs.Lucene3x
         // in the correct fields format.
         public override void StartDocument(int numStoredFields)
         {
-            IndexStream.WriteLong(FieldsStream.FilePointer);
-            FieldsStream.WriteVInt(numStoredFields);
+            IndexStream.WriteInt64(FieldsStream.FilePointer);
+            FieldsStream.WriteVInt32(numStoredFields);
         }
 
         protected override void Dispose(bool disposing)
@@ -108,7 +108,7 @@ namespace Lucene.Net.Codecs.Lucene3x
 
         public override void WriteField(FieldInfo info, IIndexableField field)
         {
-            FieldsStream.WriteVInt(info.Number);
+            FieldsStream.WriteVInt32(info.Number);
             int bits = 0;
             BytesRef bytes;
             string @string;
@@ -165,7 +165,7 @@ namespace Lucene.Net.Codecs.Lucene3x
 
             if (bytes != null)
             {
-                FieldsStream.WriteVInt(bytes.Length);
+                FieldsStream.WriteVInt32(bytes.Length);
                 FieldsStream.WriteBytes(bytes.Bytes, bytes.Offset, bytes.Length);
             }
             else if (@string != null)
@@ -176,19 +176,19 @@ namespace Lucene.Net.Codecs.Lucene3x
             {
                 if (number is sbyte? || number is short? || number is int?)
                 {
-                    FieldsStream.WriteInt((int)number);
+                    FieldsStream.WriteInt32((int)number);
                 }
                 else if (number is long?)
                 {
-                    FieldsStream.WriteLong((long)number);
+                    FieldsStream.WriteInt64((long)number);
                 }
                 else if (number is float?)
                 {
-                    FieldsStream.WriteInt(Number.FloatToIntBits((float)number));
+                    FieldsStream.WriteInt32(Number.SingleToInt32Bits((float)number));
                 }
                 else if (number is double?)
                 {
-                    FieldsStream.WriteLong(BitConverter.DoubleToInt64Bits((double)number));
+                    FieldsStream.WriteInt64(BitConverter.DoubleToInt64Bits((double)number));
                 }
                 else
                 {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.TestFramework/Codecs/lucene3x/PreFlexRWTermVectorsWriter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.TestFramework/Codecs/lucene3x/PreFlexRWTermVectorsWriter.cs b/src/Lucene.Net.TestFramework/Codecs/lucene3x/PreFlexRWTermVectorsWriter.cs
index d074af2..db3e4c3 100644
--- a/src/Lucene.Net.TestFramework/Codecs/lucene3x/PreFlexRWTermVectorsWriter.cs
+++ b/src/Lucene.Net.TestFramework/Codecs/lucene3x/PreFlexRWTermVectorsWriter.cs
@@ -49,11 +49,11 @@ namespace Lucene.Net.Codecs.Lucene3x
             {
                 // Open files for TermVector storage
                 Tvx = directory.CreateOutput(IndexFileNames.SegmentFileName(segment, "", Lucene3xTermVectorsReader.VECTORS_INDEX_EXTENSION), context);
-                Tvx.WriteInt(Lucene3xTermVectorsReader.FORMAT_CURRENT);
+                Tvx.WriteInt32(Lucene3xTermVectorsReader.FORMAT_CURRENT);
                 Tvd = directory.CreateOutput(IndexFileNames.SegmentFileName(segment, "", Lucene3xTermVectorsReader.VECTORS_DOCUMENTS_EXTENSION), context);
-                Tvd.WriteInt(Lucene3xTermVectorsReader.FORMAT_CURRENT);
+                Tvd.WriteInt32(Lucene3xTermVectorsReader.FORMAT_CURRENT);
                 Tvf = directory.CreateOutput(IndexFileNames.SegmentFileName(segment, "", Lucene3xTermVectorsReader.VECTORS_FIELDS_EXTENSION), context);
-                Tvf.WriteInt(Lucene3xTermVectorsReader.FORMAT_CURRENT);
+                Tvf.WriteInt32(Lucene3xTermVectorsReader.FORMAT_CURRENT);
                 success = true;
             }
             finally
@@ -69,9 +69,9 @@ namespace Lucene.Net.Codecs.Lucene3x
         {
             LastFieldName = null;
             this.NumVectorFields = numVectorFields;
-            Tvx.WriteLong(Tvd.FilePointer);
-            Tvx.WriteLong(Tvf.FilePointer);
-            Tvd.WriteVInt(numVectorFields);
+            Tvx.WriteInt64(Tvd.FilePointer);
+            Tvx.WriteInt64(Tvf.FilePointer);
+            Tvd.WriteVInt32(numVectorFields);
             FieldCount = 0;
             Fps = ArrayUtil.Grow(Fps, numVectorFields);
         }
@@ -93,8 +93,8 @@ namespace Lucene.Net.Codecs.Lucene3x
             this.Offsets = offsets;
             LastTerm.Length = 0;
             Fps[FieldCount++] = Tvf.FilePointer;
-            Tvd.WriteVInt(info.Number);
-            Tvf.WriteVInt(numTerms);
+            Tvd.WriteVInt32(info.Number);
+            Tvf.WriteVInt32(numTerms);
             sbyte bits = 0x0;
             if (positions)
             {
@@ -113,7 +113,7 @@ namespace Lucene.Net.Codecs.Lucene3x
                 // this is crazy because the file format is crazy!
                 for (int i = 1; i < FieldCount; i++)
                 {
-                    Tvd.WriteVLong(Fps[i] - Fps[i - 1]);
+                    Tvd.WriteVInt64(Fps[i] - Fps[i - 1]);
                 }
             }
         }
@@ -134,10 +134,10 @@ namespace Lucene.Net.Codecs.Lucene3x
         {
             int prefix = StringHelper.BytesDifference(LastTerm, term);
             int suffix = term.Length - prefix;
-            Tvf.WriteVInt(prefix);
-            Tvf.WriteVInt(suffix);
+            Tvf.WriteVInt32(prefix);
+            Tvf.WriteVInt32(suffix);
             Tvf.WriteBytes(term.Bytes, term.Offset + prefix, suffix);
-            Tvf.WriteVInt(freq);
+            Tvf.WriteVInt32(freq);
             LastTerm.CopyBytes(term);
             LastPosition = LastOffset = 0;
 
@@ -160,7 +160,7 @@ namespace Lucene.Net.Codecs.Lucene3x
             if (Positions && Offsets)
             {
                 // write position delta
-                Tvf.WriteVInt(position - LastPosition);
+                Tvf.WriteVInt32(position - LastPosition);
                 LastPosition = position;
 
                 // buffer offsets
@@ -173,8 +173,8 @@ namespace Lucene.Net.Codecs.Lucene3x
                 {
                     for (int i = 0; i < OffsetIndex; i++)
                     {
-                        Tvf.WriteVInt(OffsetStartBuffer[i] - LastOffset);
-                        Tvf.WriteVInt(OffsetEndBuffer[i] - OffsetStartBuffer[i]);
+                        Tvf.WriteVInt32(OffsetStartBuffer[i] - LastOffset);
+                        Tvf.WriteVInt32(OffsetEndBuffer[i] - OffsetStartBuffer[i]);
                         LastOffset = OffsetEndBuffer[i];
                     }
                 }
@@ -182,14 +182,14 @@ namespace Lucene.Net.Codecs.Lucene3x
             else if (Positions)
             {
                 // write position delta
-                Tvf.WriteVInt(position - LastPosition);
+                Tvf.WriteVInt32(position - LastPosition);
                 LastPosition = position;
             }
             else if (Offsets)
             {
                 // write offset deltas
-                Tvf.WriteVInt(startOffset - LastOffset);
-                Tvf.WriteVInt(endOffset - startOffset);
+                Tvf.WriteVInt32(startOffset - LastOffset);
+                Tvf.WriteVInt32(endOffset - startOffset);
                 LastOffset = endOffset;
             }
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.TestFramework/Codecs/lucene3x/TermInfosWriter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.TestFramework/Codecs/lucene3x/TermInfosWriter.cs b/src/Lucene.Net.TestFramework/Codecs/lucene3x/TermInfosWriter.cs
index 79e59f9..fd7c05d 100644
--- a/src/Lucene.Net.TestFramework/Codecs/lucene3x/TermInfosWriter.cs
+++ b/src/Lucene.Net.TestFramework/Codecs/lucene3x/TermInfosWriter.cs
@@ -136,11 +136,11 @@ namespace Lucene.Net.Codecs.Lucene3x
             bool success = false;
             try
             {
-                Output.WriteInt(FORMAT_CURRENT); // write format
-                Output.WriteLong(0); // leave space for size
-                Output.WriteInt(IndexInterval); // write indexInterval
-                Output.WriteInt(SkipInterval); // write skipInterval
-                Output.WriteInt(MaxSkipLevels); // write maxSkipLevels
+                Output.WriteInt32(FORMAT_CURRENT); // write format
+                Output.WriteInt64(0); // leave space for size
+                Output.WriteInt32(IndexInterval); // write indexInterval
+                Output.WriteInt32(SkipInterval); // write skipInterval
+                Output.WriteInt32(MaxSkipLevels); // write maxSkipLevels
                 Debug.Assert(InitUTF16Results());
                 success = true;
             }
@@ -260,18 +260,18 @@ namespace Lucene.Net.Codecs.Lucene3x
             }
             WriteTerm(fieldNumber, term); // write term
 
-            Output.WriteVInt(ti.DocFreq); // write doc freq
-            Output.WriteVLong(ti.FreqPointer - LastTi.FreqPointer); // write pointers
-            Output.WriteVLong(ti.ProxPointer - LastTi.ProxPointer);
+            Output.WriteVInt32(ti.DocFreq); // write doc freq
+            Output.WriteVInt64(ti.FreqPointer - LastTi.FreqPointer); // write pointers
+            Output.WriteVInt64(ti.ProxPointer - LastTi.ProxPointer);
 
             if (ti.DocFreq >= SkipInterval)
             {
-                Output.WriteVInt(ti.SkipOffset);
+                Output.WriteVInt32(ti.SkipOffset);
             }
 
             if (IsIndex)
             {
-                Output.WriteVLong(Other.Output.FilePointer - LastIndexPointer);
+                Output.WriteVInt64(Other.Output.FilePointer - LastIndexPointer);
                 LastIndexPointer = Other.Output.FilePointer; // write pointer
             }
 
@@ -298,10 +298,10 @@ namespace Lucene.Net.Codecs.Lucene3x
             }
 
             int length = term.Length - start;
-            Output.WriteVInt(start); // write shared prefix length
-            Output.WriteVInt(length); // write delta length
+            Output.WriteVInt32(start); // write shared prefix length
+            Output.WriteVInt32(length); // write delta length
             Output.WriteBytes(term.Bytes, start + term.Offset, length); // write delta bytes
-            Output.WriteVInt(fieldNumber); // write field num
+            Output.WriteVInt32(fieldNumber); // write field num
             LastTerm.CopyBytes(term);
         }
 
@@ -312,7 +312,7 @@ namespace Lucene.Net.Codecs.Lucene3x
             try
             {
                 Output.Seek(4); // write size after format
-                Output.WriteLong(Size);
+                Output.WriteInt64(Size);
             }
             finally
             {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.TestFramework/Codecs/lucene40/Lucene40DocValuesWriter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.TestFramework/Codecs/lucene40/Lucene40DocValuesWriter.cs b/src/Lucene.Net.TestFramework/Codecs/lucene40/Lucene40DocValuesWriter.cs
index fff5fa6..4dcf590 100644
--- a/src/Lucene.Net.TestFramework/Codecs/lucene40/Lucene40DocValuesWriter.cs
+++ b/src/Lucene.Net.TestFramework/Codecs/lucene40/Lucene40DocValuesWriter.cs
@@ -105,7 +105,7 @@ namespace Lucene.Net.Codecs.Lucene40
         {
             field.PutAttribute(LegacyKey, LegacyDocValuesType.FIXED_INTS_8.Name);
             CodecUtil.WriteHeader(output, Lucene40DocValuesFormat.INTS_CODEC_NAME, Lucene40DocValuesFormat.INTS_VERSION_CURRENT);
-            output.WriteInt(1); // size
+            output.WriteInt32(1); // size
             foreach (long? n in values)
             {
                 output.WriteByte(n == null ? (byte)0 : (byte)n);
@@ -116,10 +116,10 @@ namespace Lucene.Net.Codecs.Lucene40
         {
             field.PutAttribute(LegacyKey, LegacyDocValuesType.FIXED_INTS_16.Name);
             CodecUtil.WriteHeader(output, Lucene40DocValuesFormat.INTS_CODEC_NAME, Lucene40DocValuesFormat.INTS_VERSION_CURRENT);
-            output.WriteInt(2); // size
+            output.WriteInt32(2); // size
             foreach (long? n in values)
             {
-                output.WriteShort(n == null ? (short)0 : (short)n);
+                output.WriteInt16(n == null ? (short)0 : (short)n);
             }
         }
 
@@ -127,10 +127,10 @@ namespace Lucene.Net.Codecs.Lucene40
         {
             field.PutAttribute(LegacyKey, LegacyDocValuesType.FIXED_INTS_32.Name);
             CodecUtil.WriteHeader(output, Lucene40DocValuesFormat.INTS_CODEC_NAME, Lucene40DocValuesFormat.INTS_VERSION_CURRENT);
-            output.WriteInt(4); // size
+            output.WriteInt32(4); // size
             foreach (long? n in values)
             {
-                output.WriteInt(n == null ? 0 : (int)n);
+                output.WriteInt32(n == null ? 0 : (int)n);
             }
         }
 
@@ -148,15 +148,15 @@ namespace Lucene.Net.Codecs.Lucene40
                 output.WriteByte((byte)Lucene40DocValuesFormat.VAR_INTS_FIXED_64);
                 foreach (long? n in values)
                 {
-                    output.WriteLong(n == null ? 0 : n.Value);
+                    output.WriteInt64(n == null ? 0 : n.Value);
                 }
             }
             else
             {
                 // writes packed ints
                 output.WriteByte((byte)Lucene40DocValuesFormat.VAR_INTS_PACKED);
-                output.WriteLong(minValue);
-                output.WriteLong(0 - minValue); // default value (representation of 0)
+                output.WriteInt64(minValue);
+                output.WriteInt64(0 - minValue); // default value (representation of 0)
                 PackedInts.Writer writer = PackedInts.GetWriter(output, State.SegmentInfo.DocCount, PackedInts.BitsRequired(delta), PackedInts.DEFAULT);
                 foreach (long? n in values)
                 {
@@ -302,7 +302,7 @@ namespace Lucene.Net.Codecs.Lucene40
 
             CodecUtil.WriteHeader(output, Lucene40DocValuesFormat.BYTES_FIXED_STRAIGHT_CODEC_NAME, Lucene40DocValuesFormat.BYTES_FIXED_STRAIGHT_VERSION_CURRENT);
 
-            output.WriteInt(length);
+            output.WriteInt32(length);
             foreach (BytesRef v in values)
             {
                 if (v != null)
@@ -336,7 +336,7 @@ namespace Lucene.Net.Codecs.Lucene40
             /* addresses */
 
             long maxAddress = data.FilePointer - startPos;
-            index.WriteVLong(maxAddress);
+            index.WriteVInt64(maxAddress);
 
             int maxDoc = State.SegmentInfo.DocCount;
             Debug.Assert(maxDoc != int.MaxValue); // unsupported by the 4.0 impl
@@ -373,7 +373,7 @@ namespace Lucene.Net.Codecs.Lucene40
             }
 
             /* values */
-            data.WriteInt(length);
+            data.WriteInt32(length);
             foreach (BytesRef v in dictionary)
             {
                 data.WriteBytes(v.Bytes, v.Offset, v.Length);
@@ -382,7 +382,7 @@ namespace Lucene.Net.Codecs.Lucene40
             /* ordinals */
             int valueCount = dictionary.Count;
             Debug.Assert(valueCount > 0);
-            index.WriteInt(valueCount);
+            index.WriteInt32(valueCount);
             int maxDoc = State.SegmentInfo.DocCount;
             PackedInts.Writer w = PackedInts.GetWriter(index, maxDoc, PackedInts.BitsRequired(valueCount - 1), PackedInts.DEFAULT);
 
@@ -431,7 +431,7 @@ namespace Lucene.Net.Codecs.Lucene40
 
             /* ordinals */
             long totalBytes = data.FilePointer - startPosition;
-            index.WriteLong(totalBytes);
+            index.WriteInt64(totalBytes);
             int maxDoc = State.SegmentInfo.DocCount;
             PackedInts.Writer w = PackedInts.GetWriter(index, maxDoc, PackedInts.BitsRequired(currentAddress), PackedInts.DEFAULT);
 
@@ -539,7 +539,7 @@ namespace Lucene.Net.Codecs.Lucene40
 
             /* values */
 
-            data.WriteInt(length);
+            data.WriteInt32(length);
             int valueCount = 0;
             foreach (BytesRef v in values)
             {
@@ -549,7 +549,7 @@ namespace Lucene.Net.Codecs.Lucene40
 
             /* ordinals */
 
-            index.WriteInt(valueCount);
+            index.WriteInt32(valueCount);
             int maxDoc = State.SegmentInfo.DocCount;
             Debug.Assert(valueCount > 0);
             PackedInts.Writer w = PackedInts.GetWriter(index, maxDoc, PackedInts.BitsRequired(valueCount - 1), PackedInts.DEFAULT);
@@ -582,7 +582,7 @@ namespace Lucene.Net.Codecs.Lucene40
             /* addresses */
 
             long maxAddress = data.FilePointer - startPos;
-            index.WriteLong(maxAddress);
+            index.WriteInt64(maxAddress);
 
             Debug.Assert(valueCount != int.MaxValue); // unsupported by the 4.0 impl
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.TestFramework/Codecs/lucene40/Lucene40FieldInfosWriter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.TestFramework/Codecs/lucene40/Lucene40FieldInfosWriter.cs b/src/Lucene.Net.TestFramework/Codecs/lucene40/Lucene40FieldInfosWriter.cs
index 765c175..688e365 100644
--- a/src/Lucene.Net.TestFramework/Codecs/lucene40/Lucene40FieldInfosWriter.cs
+++ b/src/Lucene.Net.TestFramework/Codecs/lucene40/Lucene40FieldInfosWriter.cs
@@ -54,7 +54,7 @@ namespace Lucene.Net.Codecs.Lucene40
             try
             {
                 CodecUtil.WriteHeader(output, Lucene40FieldInfosFormat.CODEC_NAME, Lucene40FieldInfosFormat.FORMAT_CURRENT);
-                output.WriteVInt(infos.Count);
+                output.WriteVInt32(infos.Count);
                 foreach (FieldInfo fi in infos)
                 {
                     IndexOptions? indexOptions = fi.IndexOptions;
@@ -89,7 +89,7 @@ namespace Lucene.Net.Codecs.Lucene40
                         }
                     }
                     output.WriteString(fi.Name);
-                    output.WriteVInt(fi.Number);
+                    output.WriteVInt32(fi.Number);
                     output.WriteByte((byte)bits);
 
                     // pack the DV types in one byte

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.TestFramework/Codecs/lucene40/Lucene40PostingsWriter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.TestFramework/Codecs/lucene40/Lucene40PostingsWriter.cs b/src/Lucene.Net.TestFramework/Codecs/lucene40/Lucene40PostingsWriter.cs
index 45620ae..11e2dc0 100644
--- a/src/Lucene.Net.TestFramework/Codecs/lucene40/Lucene40PostingsWriter.cs
+++ b/src/Lucene.Net.TestFramework/Codecs/lucene40/Lucene40PostingsWriter.cs
@@ -152,9 +152,9 @@ namespace Lucene.Net.Codecs.Lucene40
         public override void Init(IndexOutput termsOut)
         {
             CodecUtil.WriteHeader(termsOut, Lucene40PostingsReader.TERMS_CODEC, Lucene40PostingsReader.VERSION_CURRENT);
-            termsOut.WriteInt(SkipInterval); // write skipInterval
-            termsOut.WriteInt(MaxSkipLevels); // write maxSkipLevels
-            termsOut.WriteInt(SkipMinimum); // write skipMinimum
+            termsOut.WriteInt32(SkipInterval); // write skipInterval
+            termsOut.WriteInt32(MaxSkipLevels); // write maxSkipLevels
+            termsOut.WriteInt32(SkipMinimum); // write skipMinimum
         }
 
         public override BlockTermState NewTermState()
@@ -225,16 +225,16 @@ namespace Lucene.Net.Codecs.Lucene40
             LastDocID = docID;
             if (IndexOptions == Index.IndexOptions.DOCS_ONLY)
             {
-                FreqOut.WriteVInt(delta);
+                FreqOut.WriteVInt32(delta);
             }
             else if (1 == termDocFreq)
             {
-                FreqOut.WriteVInt((delta << 1) | 1);
+                FreqOut.WriteVInt32((delta << 1) | 1);
             }
             else
             {
-                FreqOut.WriteVInt(delta << 1);
-                FreqOut.WriteVInt(termDocFreq);
+                FreqOut.WriteVInt32(delta << 1);
+                FreqOut.WriteVInt32(termDocFreq);
             }
 
             LastPosition = 0;
@@ -264,17 +264,17 @@ namespace Lucene.Net.Codecs.Lucene40
                 if (payloadLength != LastPayloadLength)
                 {
                     LastPayloadLength = payloadLength;
-                    ProxOut.WriteVInt((delta << 1) | 1);
-                    ProxOut.WriteVInt(payloadLength);
+                    ProxOut.WriteVInt32((delta << 1) | 1);
+                    ProxOut.WriteVInt32(payloadLength);
                 }
                 else
                 {
-                    ProxOut.WriteVInt(delta << 1);
+                    ProxOut.WriteVInt32(delta << 1);
                 }
             }
             else
             {
-                ProxOut.WriteVInt(delta);
+                ProxOut.WriteVInt32(delta);
             }
 
             if (StoreOffsets)
@@ -286,12 +286,12 @@ namespace Lucene.Net.Codecs.Lucene40
                 Debug.Assert(offsetDelta >= 0 && offsetLength >= 0, "startOffset=" + startOffset + ",lastOffset=" + LastOffset + ",endOffset=" + endOffset);
                 if (offsetLength != LastOffsetLength)
                 {
-                    ProxOut.WriteVInt(offsetDelta << 1 | 1);
-                    ProxOut.WriteVInt(offsetLength);
+                    ProxOut.WriteVInt32(offsetDelta << 1 | 1);
+                    ProxOut.WriteVInt32(offsetLength);
                 }
                 else
                 {
-                    ProxOut.WriteVInt(offsetDelta << 1);
+                    ProxOut.WriteVInt32(offsetDelta << 1);
                 }
                 LastOffset = startOffset;
                 LastOffsetLength = offsetLength;
@@ -346,15 +346,15 @@ namespace Lucene.Net.Codecs.Lucene40
             {
                 LastState = EmptyState;
             }
-            @out.WriteVLong(state.FreqStart - LastState.FreqStart);
+            @out.WriteVInt64(state.FreqStart - LastState.FreqStart);
             if (state.SkipOffset != -1)
             {
                 Debug.Assert(state.SkipOffset > 0);
-                @out.WriteVLong(state.SkipOffset);
+                @out.WriteVInt64(state.SkipOffset);
             }
             if (IndexOptions >= Index.IndexOptions.DOCS_AND_FREQS_AND_POSITIONS)
             {
-                @out.WriteVLong(state.ProxStart - LastState.ProxStart);
+                @out.WriteVInt64(state.ProxStart - LastState.ProxStart);
             }
             LastState = state;
         }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.TestFramework/Codecs/lucene40/Lucene40SkipListWriter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.TestFramework/Codecs/lucene40/Lucene40SkipListWriter.cs b/src/Lucene.Net.TestFramework/Codecs/lucene40/Lucene40SkipListWriter.cs
index 06f9514..aa8e52e 100644
--- a/src/Lucene.Net.TestFramework/Codecs/lucene40/Lucene40SkipListWriter.cs
+++ b/src/Lucene.Net.TestFramework/Codecs/lucene40/Lucene40SkipListWriter.cs
@@ -130,22 +130,22 @@ namespace Lucene.Net.Codecs.Lucene40
                 {
                     // the current payload/offset lengths equals the lengths at the previous skip point,
                     // so we don't store the lengths again
-                    skipBuffer.WriteVInt(delta << 1);
+                    skipBuffer.WriteVInt32(delta << 1);
                 }
                 else
                 {
                     // the payload and/or offset length is different from the previous one. We shift the DocSkip,
                     // set the lowest bit and store the current payload and/or offset lengths as VInts.
-                    skipBuffer.WriteVInt(delta << 1 | 1);
+                    skipBuffer.WriteVInt32(delta << 1 | 1);
 
                     if (CurStorePayloads)
                     {
-                        skipBuffer.WriteVInt(CurPayloadLength);
+                        skipBuffer.WriteVInt32(CurPayloadLength);
                         LastSkipPayloadLength[level] = CurPayloadLength;
                     }
                     if (CurStoreOffsets)
                     {
-                        skipBuffer.WriteVInt(CurOffsetLength);
+                        skipBuffer.WriteVInt32(CurOffsetLength);
                         LastSkipOffsetLength[level] = CurOffsetLength;
                     }
                 }
@@ -153,11 +153,11 @@ namespace Lucene.Net.Codecs.Lucene40
             else
             {
                 // current field does not store payloads or offsets
-                skipBuffer.WriteVInt(delta);
+                skipBuffer.WriteVInt32(delta);
             }
 
-            skipBuffer.WriteVInt((int)(CurFreqPointer - LastSkipFreqPointer[level]));
-            skipBuffer.WriteVInt((int)(CurProxPointer - LastSkipProxPointer[level]));
+            skipBuffer.WriteVInt32((int)(CurFreqPointer - LastSkipFreqPointer[level]));
+            skipBuffer.WriteVInt32((int)(CurProxPointer - LastSkipProxPointer[level]));
 
             LastSkipDoc[level] = CurDoc;
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.TestFramework/Codecs/lucene42/Lucene42DocValuesConsumer.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.TestFramework/Codecs/lucene42/Lucene42DocValuesConsumer.cs b/src/Lucene.Net.TestFramework/Codecs/lucene42/Lucene42DocValuesConsumer.cs
index d894074..678d381 100644
--- a/src/Lucene.Net.TestFramework/Codecs/lucene42/Lucene42DocValuesConsumer.cs
+++ b/src/Lucene.Net.TestFramework/Codecs/lucene42/Lucene42DocValuesConsumer.cs
@@ -87,9 +87,9 @@ namespace Lucene.Net.Codecs.Lucene42
 
         internal virtual void AddNumericField(FieldInfo field, IEnumerable<long?> values, bool optimizeStorage)
         {
-            Meta.WriteVInt(field.Number);
+            Meta.WriteVInt32(field.Number);
             Meta.WriteByte((byte)Lucene42DocValuesProducer.NUMBER);
-            Meta.WriteLong(Data.FilePointer);
+            Meta.WriteInt64(Data.FilePointer);
             long minValue = long.MaxValue;
             long maxValue = long.MinValue;
             long gcd = 0;
@@ -157,16 +157,16 @@ namespace Lucene.Net.Codecs.Lucene42
                     Meta.WriteByte((byte)Lucene42DocValuesProducer.TABLE_COMPRESSED); // table-compressed
                     long[] decode = uniqueValues.ToArray(/*new long?[uniqueValues.Count]*/);
                     var encode = new Dictionary<long, int>();
-                    Data.WriteVInt(decode.Length);
+                    Data.WriteVInt32(decode.Length);
                     for (int i = 0; i < decode.Length; i++)
                     {
-                        Data.WriteLong(decode[i]);
+                        Data.WriteInt64(decode[i]);
                         encode[decode[i]] = i;
                     }
 
-                    Meta.WriteVInt(PackedInts.VERSION_CURRENT);
-                    Data.WriteVInt(formatAndBits.Format.Id);
-                    Data.WriteVInt(formatAndBits.BitsPerValue);
+                    Meta.WriteVInt32(PackedInts.VERSION_CURRENT);
+                    Data.WriteVInt32(formatAndBits.Format.Id);
+                    Data.WriteVInt32(formatAndBits.BitsPerValue);
 
                     PackedInts.Writer writer = PackedInts.GetWriterNoHeader(Data, formatAndBits.Format, MaxDoc, formatAndBits.BitsPerValue, PackedInts.DEFAULT_BUFFER_SIZE);
                     foreach (long? nv in values)
@@ -179,10 +179,10 @@ namespace Lucene.Net.Codecs.Lucene42
             else if (gcd != 0 && gcd != 1)
             {
                 Meta.WriteByte((byte)Lucene42DocValuesProducer.GCD_COMPRESSED);
-                Meta.WriteVInt(PackedInts.VERSION_CURRENT);
-                Data.WriteLong(minValue);
-                Data.WriteLong(gcd);
-                Data.WriteVInt(Lucene42DocValuesProducer.BLOCK_SIZE);
+                Meta.WriteVInt32(PackedInts.VERSION_CURRENT);
+                Data.WriteInt64(minValue);
+                Data.WriteInt64(gcd);
+                Data.WriteVInt32(Lucene42DocValuesProducer.BLOCK_SIZE);
 
                 BlockPackedWriter writer = new BlockPackedWriter(Data, Lucene42DocValuesProducer.BLOCK_SIZE);
                 foreach (long? nv in values)
@@ -196,8 +196,8 @@ namespace Lucene.Net.Codecs.Lucene42
             {
                 Meta.WriteByte((byte)Lucene42DocValuesProducer.DELTA_COMPRESSED); // delta-compressed
 
-                Meta.WriteVInt(PackedInts.VERSION_CURRENT);
-                Data.WriteVInt(Lucene42DocValuesProducer.BLOCK_SIZE);
+                Meta.WriteVInt32(PackedInts.VERSION_CURRENT);
+                Data.WriteVInt32(Lucene42DocValuesProducer.BLOCK_SIZE);
 
                 BlockPackedWriter writer = new BlockPackedWriter(Data, Lucene42DocValuesProducer.BLOCK_SIZE);
                 foreach (long? nv in values)
@@ -217,7 +217,7 @@ namespace Lucene.Net.Codecs.Lucene42
                 {
                     if (Meta != null)
                     {
-                        Meta.WriteVInt(-1); // write EOF marker
+                        Meta.WriteVInt32(-1); // write EOF marker
                     }
                     success = true;
                 }
@@ -238,7 +238,7 @@ namespace Lucene.Net.Codecs.Lucene42
         public override void AddBinaryField(FieldInfo field, IEnumerable<BytesRef> values)
         {
             // write the byte[] data
-            Meta.WriteVInt(field.Number);
+            Meta.WriteVInt32(field.Number);
             Meta.WriteByte((byte)Lucene42DocValuesProducer.BYTES);
             int minLength = int.MaxValue;
             int maxLength = int.MinValue;
@@ -257,17 +257,17 @@ namespace Lucene.Net.Codecs.Lucene42
                     Data.WriteBytes(v.Bytes, v.Offset, v.Length);
                 }
             }
-            Meta.WriteLong(startFP);
-            Meta.WriteLong(Data.FilePointer - startFP);
-            Meta.WriteVInt(minLength);
-            Meta.WriteVInt(maxLength);
+            Meta.WriteInt64(startFP);
+            Meta.WriteInt64(Data.FilePointer - startFP);
+            Meta.WriteVInt32(minLength);
+            Meta.WriteVInt32(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(Lucene42DocValuesProducer.BLOCK_SIZE);
+                Meta.WriteVInt32(PackedInts.VERSION_CURRENT);
+                Meta.WriteVInt32(Lucene42DocValuesProducer.BLOCK_SIZE);
 
                 MonotonicBlockPackedWriter writer = new MonotonicBlockPackedWriter(Data, Lucene42DocValuesProducer.BLOCK_SIZE);
                 long addr = 0;
@@ -285,16 +285,16 @@ namespace Lucene.Net.Codecs.Lucene42
 
         private void WriteFST(FieldInfo field, IEnumerable<BytesRef> values)
         {
-            Meta.WriteVInt(field.Number);
+            Meta.WriteVInt32(field.Number);
             Meta.WriteByte((byte)Lucene42DocValuesProducer.FST);
-            Meta.WriteLong(Data.FilePointer);
+            Meta.WriteInt64(Data.FilePointer);
             PositiveIntOutputs outputs = PositiveIntOutputs.Singleton;
             Builder<long?> builder = new Builder<long?>(INPUT_TYPE.BYTE1, outputs);
             IntsRef scratch = new IntsRef();
             long ord = 0;
             foreach (BytesRef v in values)
             {
-                builder.Add(Util.ToIntsRef(v, scratch), ord);
+                builder.Add(Util.ToInt32sRef(v, scratch), ord);
                 ord++;
             }
 
@@ -303,7 +303,7 @@ namespace Lucene.Net.Codecs.Lucene42
             {
                 fst.Save(Data);
             }
-            Meta.WriteVLong(ord);
+            Meta.WriteVInt64(ord);
         }
 
         public override void AddSortedField(FieldInfo field, IEnumerable<BytesRef> values, IEnumerable<long?> docToOrd)
@@ -450,7 +450,7 @@ namespace Lucene.Net.Codecs.Lucene42
                 {
                     Ords.MoveNext();
                     long ord = Ords.Current.Value;
-                    @out.WriteVLong(ord - lastOrd);
+                    @out.WriteVInt64(ord - lastOrd);
                     lastOrd = ord;
                 }
             }

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.TestFramework/Codecs/lucene42/Lucene42FieldInfosWriter.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.TestFramework/Codecs/lucene42/Lucene42FieldInfosWriter.cs b/src/Lucene.Net.TestFramework/Codecs/lucene42/Lucene42FieldInfosWriter.cs
index e27c61d..acdae7b 100644
--- a/src/Lucene.Net.TestFramework/Codecs/lucene42/Lucene42FieldInfosWriter.cs
+++ b/src/Lucene.Net.TestFramework/Codecs/lucene42/Lucene42FieldInfosWriter.cs
@@ -53,7 +53,7 @@ namespace Lucene.Net.Codecs.Lucene42
             try
             {
                 CodecUtil.WriteHeader(output, Lucene42FieldInfosFormat.CODEC_NAME, Lucene42FieldInfosFormat.FORMAT_CURRENT);
-                output.WriteVInt(infos.Count);
+                output.WriteVInt32(infos.Count);
                 foreach (FieldInfo fi in infos)
                 {
                     IndexOptions? indexOptions = fi.IndexOptions;
@@ -88,7 +88,7 @@ namespace Lucene.Net.Codecs.Lucene42
                         }
                     }
                     output.WriteString(fi.Name);
-                    output.WriteVInt(fi.Number);
+                    output.WriteVInt32(fi.Number);
                     output.WriteByte((byte)bits);
 
                     // pack the DV types in one byte

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.TestFramework/Codecs/ramonly/RAMOnlyPostingsFormat.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.TestFramework/Codecs/ramonly/RAMOnlyPostingsFormat.cs b/src/Lucene.Net.TestFramework/Codecs/ramonly/RAMOnlyPostingsFormat.cs
index 01180d3..7cfddf4 100644
--- a/src/Lucene.Net.TestFramework/Codecs/ramonly/RAMOnlyPostingsFormat.cs
+++ b/src/Lucene.Net.TestFramework/Codecs/ramonly/RAMOnlyPostingsFormat.cs
@@ -672,7 +672,7 @@ namespace Lucene.Net.Codecs.ramonly
             try
             {
                 CodecUtil.WriteHeader(@out, RAM_ONLY_NAME, VERSION_LATEST);
-                @out.WriteVInt(id);
+                @out.WriteVInt32(id);
                 success = true;
             }
             finally
@@ -707,7 +707,7 @@ namespace Lucene.Net.Codecs.ramonly
             try
             {
                 CodecUtil.CheckHeader(@in, RAM_ONLY_NAME, VERSION_START, VERSION_LATEST);
-                id = @in.ReadVInt();
+                id = @in.ReadVInt32();
                 success = true;
             }
             finally

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.TestFramework/Index/BaseDocValuesFormatTestCase.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.TestFramework/Index/BaseDocValuesFormatTestCase.cs b/src/Lucene.Net.TestFramework/Index/BaseDocValuesFormatTestCase.cs
index 5263e05..accdbbe 100644
--- a/src/Lucene.Net.TestFramework/Index/BaseDocValuesFormatTestCase.cs
+++ b/src/Lucene.Net.TestFramework/Index/BaseDocValuesFormatTestCase.cs
@@ -147,7 +147,7 @@ namespace Lucene.Net.Index
                 Assert.AreEqual(text, hitDoc.Get("fieldname"));
                 Debug.Assert(ireader.Leaves.Count == 1);
                 NumericDocValues dv = ((AtomicReader)((AtomicReader)ireader.Leaves[0].Reader)).GetNumericDocValues("dv");
-                Assert.AreEqual(Number.FloatToIntBits(5.7f), dv.Get(hits.ScoreDocs[i].Doc));
+                Assert.AreEqual(Number.SingleToInt32Bits(5.7f), dv.Get(hits.ScoreDocs[i].Doc));
             }
 
             ireader.Dispose();

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.TestFramework/Index/BaseStoredFieldsFormatTestCase.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.TestFramework/Index/BaseStoredFieldsFormatTestCase.cs b/src/Lucene.Net.TestFramework/Index/BaseStoredFieldsFormatTestCase.cs
index c13021f..d7a414e 100644
--- a/src/Lucene.Net.TestFramework/Index/BaseStoredFieldsFormatTestCase.cs
+++ b/src/Lucene.Net.TestFramework/Index/BaseStoredFieldsFormatTestCase.cs
@@ -334,7 +334,7 @@ namespace Lucene.Net.Index
             foreach (AtomicReaderContext ctx in r.Leaves)
             {
                 AtomicReader sub = (AtomicReader)ctx.Reader;
-                FieldCache.Ints ids = FieldCache.DEFAULT.GetInts(sub, "id", false);
+                FieldCache.Ints ids = FieldCache.DEFAULT.GetInt32s(sub, "id", false);
                 for (int docID = 0; docID < sub.NumDocs; docID++)
                 {
                     Document doc = sub.Document(docID);
@@ -632,7 +632,7 @@ namespace Lucene.Net.Index
             {
                 int min = Random().Next(data.Length);
                 int max = min + Random().Next(20);
-                iw.DeleteDocuments(NumericRangeQuery.NewIntRange("id", min, max, true, false));
+                iw.DeleteDocuments(NumericRangeQuery.NewInt32Range("id", min, max, true, false));
             }
 
             iw.ForceMerge(2); // force merges with deletions

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.TestFramework/Store/MockIndexInputWrapper.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.TestFramework/Store/MockIndexInputWrapper.cs b/src/Lucene.Net.TestFramework/Store/MockIndexInputWrapper.cs
index 830f143..b6e7a95 100644
--- a/src/Lucene.Net.TestFramework/Store/MockIndexInputWrapper.cs
+++ b/src/Lucene.Net.TestFramework/Store/MockIndexInputWrapper.cs
@@ -139,22 +139,31 @@ namespace Lucene.Net.Store
             @delegate.ReadBytes(b, offset, len, useBuffer);
         }
 
-        public override short ReadShort()
+        /// <summary>
+        /// NOTE: this was readShort() in Lucene
+        /// </summary>
+        public override short ReadInt16()
         {
             EnsureOpen();
-            return @delegate.ReadShort();
+            return @delegate.ReadInt16();
         }
 
-        public override int ReadInt()
+        /// <summary>
+        /// NOTE: this was readInt() in Lucene
+        /// </summary>
+        public override int ReadInt32()
         {
             EnsureOpen();
-            return @delegate.ReadInt();
+            return @delegate.ReadInt32();
         }
 
-        public override long ReadLong()
+        /// <summary>
+        /// NOTE: this was readLong() in Lucene
+        /// </summary>
+        public override long ReadInt64()
         {
             EnsureOpen();
-            return @delegate.ReadLong();
+            return @delegate.ReadInt64();
         }
 
         public override string ReadString()
@@ -169,16 +178,22 @@ namespace Lucene.Net.Store
             return @delegate.ReadStringStringMap();
         }
 
-        public override int ReadVInt()
+        /// <summary>
+        /// NOTE: this was readVInt() in Lucene
+        /// </summary>
+        public override int ReadVInt32()
         {
             EnsureOpen();
-            return @delegate.ReadVInt();
+            return @delegate.ReadVInt32();
         }
 
-        public override long ReadVLong()
+        /// <summary>
+        /// NOTE: this was readVLong() in Lucene
+        /// </summary>
+        public override long ReadVInt64()
         {
             EnsureOpen();
-            return @delegate.ReadVLong();
+            return @delegate.ReadVInt64();
         }
 
         public override string ToString()

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.TestFramework/Util/automaton/AutomatonTestUtil.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.TestFramework/Util/automaton/AutomatonTestUtil.cs b/src/Lucene.Net.TestFramework/Util/automaton/AutomatonTestUtil.cs
index c060fd1..2c0e1f9 100644
--- a/src/Lucene.Net.TestFramework/Util/automaton/AutomatonTestUtil.cs
+++ b/src/Lucene.Net.TestFramework/Util/automaton/AutomatonTestUtil.cs
@@ -361,7 +361,7 @@ namespace Lucene.Net.Util.Automaton
                     }
                 }
 
-                return ArrayUtil.ToIntArray(soFar);
+                return ArrayUtil.ToInt32Array(soFar);
             }
         }
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.TestFramework/Util/fst/FSTTester.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.TestFramework/Util/fst/FSTTester.cs b/src/Lucene.Net.TestFramework/Util/fst/FSTTester.cs
index 40b79d2..7889b94 100644
--- a/src/Lucene.Net.TestFramework/Util/fst/FSTTester.cs
+++ b/src/Lucene.Net.TestFramework/Util/fst/FSTTester.cs
@@ -74,7 +74,7 @@ namespace Lucene.Net.Util.Fst
             else
             {
                 // utf32
-                return UnicodeUtil.NewString(term.Ints, term.Offset, term.Length) + " " + term;
+                return UnicodeUtil.NewString(term.Int32s, term.Offset, term.Length) + " " + term;
             }
         }
 
@@ -83,7 +83,7 @@ namespace Lucene.Net.Util.Fst
             BytesRef br = new BytesRef(ir.Length);
             for (int i = 0; i < ir.Length; i++)
             {
-                int x = ir.Ints[ir.Offset + i];
+                int x = ir.Int32s[ir.Offset + i];
                 Debug.Assert(x >= 0 && x <= 255);
                 br.Bytes[i] = (byte)x;
             }
@@ -150,12 +150,12 @@ namespace Lucene.Net.Util.Fst
             int intIdx = 0;
             while (charIdx < charLength)
             {
-                if (intIdx == ir.Ints.Length)
+                if (intIdx == ir.Int32s.Length)
                 {
                     ir.Grow(intIdx + 1);
                 }
                 int utf32 = Character.CodePointAt(s, charIdx);
-                ir.Ints[intIdx] = utf32;
+                ir.Int32s[intIdx] = utf32;
                 charIdx += Character.CharCount(utf32);
                 intIdx++;
             }
@@ -165,13 +165,13 @@ namespace Lucene.Net.Util.Fst
 
         internal static IntsRef ToIntsRef(BytesRef br, IntsRef ir)
         {
-            if (br.Length > ir.Ints.Length)
+            if (br.Length > ir.Int32s.Length)
             {
                 ir.Grow(br.Length);
             }
             for (int i = 0; i < br.Length; i++)
             {
-                ir.Ints[i] = br.Bytes[br.Offset + i] & 0xFF;
+                ir.Int32s[i] = br.Bytes[br.Offset + i] & 0xFF;
             }
             ir.Length = br.Length;
             return ir;
@@ -232,7 +232,7 @@ namespace Lucene.Net.Util.Fst
                 }
                 else
                 {
-                    label = term.Ints[term.Offset + i];
+                    label = term.Int32s[term.Offset + i];
                 }
                 // System.out.println("   loop i=" + i + " label=" + label + " output=" + fst.Outputs.outputToString(output) + " curArc: target=" + arc.target + " isFinal?=" + arc.isFinal());
                 if (fst.FindTargetArc(label, arc, arc, fstReader) == null)
@@ -294,11 +294,11 @@ namespace Lucene.Net.Util.Fst
                     break;
                 }
 
-                if (@in.Ints.Length == @in.Length)
+                if (@in.Int32s.Length == @in.Length)
                 {
                     @in.Grow(1 + @in.Length);
                 }
-                @in.Ints[@in.Length++] = arc.Label;
+                @in.Int32s[@in.Length++] = arc.Label;
             }
 
             return output;
@@ -824,7 +824,7 @@ namespace Lucene.Net.Util.Fst
             IntsRef scratch = new IntsRef(10);
             foreach (InputOutput<T> pair in Pairs)
             {
-                scratch.CopyInts(pair.Input);
+                scratch.CopyInt32s(pair.Input);
                 for (int idx = 0; idx <= pair.Input.Length; idx++)
                 {
                     scratch.Length = idx;
@@ -893,7 +893,7 @@ namespace Lucene.Net.Util.Fst
                     {
                         // consult our parent
                         scratch.Length = prefix.Length - 1;
-                        Array.Copy(prefix.Ints, prefix.Offset, scratch.Ints, 0, scratch.Length);
+                        Array.Copy(prefix.Int32s, prefix.Offset, scratch.Int32s, 0, scratch.Length);
                         CountMinOutput<T> cmo2 = prefixes.ContainsKey(scratch) ? prefixes[scratch] : null;
                         //System.out.println("    parent count = " + (cmo2 == null ? -1 : cmo2.count));
                         keep = cmo2 != null && ((prune2 > 1 && cmo2.Count >= prune2) || (prune2 == 1 && (cmo2.Count >= 2 || prefix.Length <= 1)));
@@ -917,7 +917,7 @@ namespace Lucene.Net.Util.Fst
                 {
                     // clear isLeaf for all ancestors
                     //System.out.println("    keep");
-                    scratch.CopyInts(prefix);
+                    scratch.CopyInt32s(prefix);
                     scratch.Length--;
                     while (scratch.Length >= 0)
                     {

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Tests.Analysis.Common/Analysis/Core/TestTypeTokenFilterFactory.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests.Analysis.Common/Analysis/Core/TestTypeTokenFilterFactory.cs b/src/Lucene.Net.Tests.Analysis.Common/Analysis/Core/TestTypeTokenFilterFactory.cs
index 5a7d81d..abb83e7 100644
--- a/src/Lucene.Net.Tests.Analysis.Common/Analysis/Core/TestTypeTokenFilterFactory.cs
+++ b/src/Lucene.Net.Tests.Analysis.Common/Analysis/Core/TestTypeTokenFilterFactory.cs
@@ -48,7 +48,7 @@ namespace Lucene.Net.Analysis.Core
         {
             TokenFilterFactory factory = TokenFilterFactory("Type", "types", "stoptypes-1.txt, stoptypes-2.txt", "enablePositionIncrements", "true");
             NumericTokenStream input = new NumericTokenStream();
-            input.SetIntValue(123); // LUCENENET TODO: Shouldn't this be a property setter?
+            input.SetInt32Value(123); // LUCENENET TODO: Shouldn't this be a property setter?
             factory.Create(input);
         }
 
@@ -57,7 +57,7 @@ namespace Lucene.Net.Analysis.Core
         {
             TokenFilterFactory factory = TokenFilterFactory("Type", "types", "stoptypes-1.txt, stoptypes-2.txt", "enablePositionIncrements", "true", "useWhitelist", "true");
             NumericTokenStream input = new NumericTokenStream();
-            input.SetIntValue(123);
+            input.SetInt32Value(123);
             factory.Create(input);
         }
 

http://git-wip-us.apache.org/repos/asf/lucenenet/blob/f7432173/src/Lucene.Net.Tests.Analysis.Common/Analysis/Hunspell/TestDictionary.cs
----------------------------------------------------------------------
diff --git a/src/Lucene.Net.Tests.Analysis.Common/Analysis/Hunspell/TestDictionary.cs b/src/Lucene.Net.Tests.Analysis.Common/Analysis/Hunspell/TestDictionary.cs
index bd9dfa4..ec404cf 100644
--- a/src/Lucene.Net.Tests.Analysis.Common/Analysis/Hunspell/TestDictionary.cs
+++ b/src/Lucene.Net.Tests.Analysis.Common/Analysis/Hunspell/TestDictionary.cs
@@ -45,14 +45,14 @@ namespace Lucene.Net.Analysis.Hunspell
                     assertEquals(1, ordList.Length);
 
                     BytesRef @ref = new BytesRef();
-                    dictionary.flagLookup.Get(ordList.Ints[0], @ref);
+                    dictionary.flagLookup.Get(ordList.Int32s[0], @ref);
                     char[] flags = Dictionary.DecodeFlags(@ref);
                     assertEquals(1, flags.Length);
 
                     ordList = dictionary.LookupWord(new char[] { 'l', 'u', 'c', 'e', 'n' }, 0, 5);
                     assertNotNull(ordList);
                     assertEquals(1, ordList.Length);
-                    dictionary.flagLookup.Get(ordList.Ints[0], @ref);
+                    dictionary.flagLookup.Get(ordList.Int32s[0], @ref);
                     flags = Dictionary.DecodeFlags(@ref);
                     assertEquals(1, flags.Length);
                 }
@@ -72,7 +72,7 @@ namespace Lucene.Net.Analysis.Hunspell
                     assertEquals(1, dictionary.LookupPrefix(new char[] { 's' }, 0, 1).Length);
                     IntsRef ordList = dictionary.LookupWord(new char[] { 'o', 'l', 'r' }, 0, 3);
                     BytesRef @ref = new BytesRef();
-                    dictionary.flagLookup.Get(ordList.Ints[0], @ref);
+                    dictionary.flagLookup.Get(ordList.Int32s[0], @ref);
                     char[] flags = Dictionary.DecodeFlags(@ref);
                     assertEquals(1, flags.Length);
                 }
@@ -92,7 +92,7 @@ namespace Lucene.Net.Analysis.Hunspell
                     assertEquals(1, dictionary.LookupPrefix(new char[] { 's' }, 0, 1).Length);
                     IntsRef ordList = dictionary.LookupWord(new char[] { 'o', 'l', 'r' }, 0, 3);
                     BytesRef @ref = new BytesRef();
-                    dictionary.flagLookup.Get(ordList.Ints[0], @ref);
+                    dictionary.flagLookup.Get(ordList.Int32s[0], @ref);
                     char[] flags = Dictionary.DecodeFlags(@ref);
                     assertEquals(1, flags.Length);
                 }
@@ -111,7 +111,7 @@ namespace Lucene.Net.Analysis.Hunspell
                     assertEquals(1, dictionary.LookupPrefix(new char[] { 's' }, 0, 1).Length);
                     IntsRef ordList = dictionary.LookupWord(new char[] { 'o', 'l', 'r' }, 0, 3);
                     BytesRef @ref = new BytesRef();
-                    dictionary.flagLookup.Get(ordList.Ints[0], @ref);
+                    dictionary.flagLookup.Get(ordList.Int32s[0], @ref);
                     char[] flags = Dictionary.DecodeFlags(@ref);
                     assertEquals(1, flags.Length);
                 }