You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@lucenenet.apache.org by pn...@apache.org on 2011/05/07 08:22:27 UTC

[Lucene.Net] svn commit: r1100459 [2/6] - in /incubator/lucene.net/branches/Lucene.Net_2_9_4g: ./ src/core/ src/core/Analysis/ src/core/Analysis/Standard/ src/core/Analysis/Tokenattributes/ src/core/Document/ src/core/Index/ src/core/QueryParser/ src/core/Search/ s...

Modified: incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Index/ParallelReader.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Index/ParallelReader.cs?rev=1100459&r1=1100458&r2=1100459&view=diff
==============================================================================
--- incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Index/ParallelReader.cs (original)
+++ incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Index/ParallelReader.cs Sat May  7 06:22:20 2011
@@ -50,7 +50,7 @@ namespace Lucene.Net.Index
         private List<bool> decrefOnClose = new List<bool>(); // remember which subreaders to decRef on close
 		internal bool incRefReaders = false;
 		private System.Collections.SortedList fieldToReader = new System.Collections.SortedList();
-        private SupportClass.Dictionary<IndexReader, ICollection<String>> readerToFields = new SupportClass.Dictionary<IndexReader, ICollection<string>>();
+        private Support.Dictionary<IndexReader, ICollection<String>> readerToFields = new Support.Dictionary<IndexReader, ICollection<string>>();
         private List<IndexReader> storedFieldReaders = new List<IndexReader>();
 		
 		private int maxDoc;

Modified: incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Index/PositionBasedTermVectorMapper.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Index/PositionBasedTermVectorMapper.cs?rev=1100459&r1=1100458&r2=1100459&view=diff
==============================================================================
--- incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Index/PositionBasedTermVectorMapper.cs (original)
+++ incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Index/PositionBasedTermVectorMapper.cs Sat May  7 06:22:20 2011
@@ -27,11 +27,11 @@ namespace Lucene.Net.Index
 	/// </summary>
 	public class PositionBasedTermVectorMapper:TermVectorMapper
 	{
-		private SupportClass.Dictionary<String, SupportClass.Dictionary<int,TVPositionInfo>> fieldToTerms;
+		private Support.Dictionary<String, Support.Dictionary<int,TVPositionInfo>> fieldToTerms;
 		
 		private System.String currentField;
 		/// <summary> A Map of Integer and TVPositionInfo</summary>
-		private SupportClass.Dictionary<int,TVPositionInfo> currentPositions;
+		private Support.Dictionary<int,TVPositionInfo> currentPositions;
 		private bool storeOffsets;
 		
 		
@@ -99,10 +99,10 @@ namespace Lucene.Net.Index
 			{
 				//ignoring offsets
 			}
-            fieldToTerms = new SupportClass.Dictionary<string, SupportClass.Dictionary<int, TVPositionInfo>>(numTerms);
+            fieldToTerms = new Support.Dictionary<string, Support.Dictionary<int, TVPositionInfo>>(numTerms);
 			this.storeOffsets = storeOffsets;
 			currentField = field;
-            currentPositions = new SupportClass.Dictionary<int, TVPositionInfo>();
+            currentPositions = new Support.Dictionary<int, TVPositionInfo>();
 			fieldToTerms[currentField] = currentPositions;
 		}
 		
@@ -111,7 +111,7 @@ namespace Lucene.Net.Index
 		/// </summary>
 		/// <returns> A map between field names and a Map.  The sub-Map key is the position as the integer, the value is {@link Lucene.Net.Index.PositionBasedTermVectorMapper.TVPositionInfo}.
 		/// </returns>
-        public virtual SupportClass.Dictionary<String, SupportClass.Dictionary<int, TVPositionInfo>> GetFieldToTerms()
+        public virtual Support.Dictionary<String, Support.Dictionary<int, TVPositionInfo>> GetFieldToTerms()
 		{
 			return fieldToTerms;
 		}

Modified: incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Index/ReusableStringReader.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Index/ReusableStringReader.cs?rev=1100459&r1=1100458&r2=1100459&view=diff
==============================================================================
--- incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Index/ReusableStringReader.cs (original)
+++ incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Index/ReusableStringReader.cs Sat May  7 06:22:20 2011
@@ -43,7 +43,7 @@ namespace Lucene.Net.Index
         {
             if (left > len)
             {
-                SupportClass.TextSupport.GetCharsFromString(s, upto, upto + len, c, off);
+                Support.TextSupport.GetCharsFromString(s, upto, upto + len, c, off);
                 upto += len;
                 left -= len;
                 return len;
@@ -55,7 +55,7 @@ namespace Lucene.Net.Index
             }
             else
             {
-                SupportClass.TextSupport.GetCharsFromString(s, upto, upto + left, c, off);
+                Support.TextSupport.GetCharsFromString(s, upto, upto + left, c, off);
                 int r = left;
                 left = 0;
                 upto = s.Length;

Modified: incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Index/SegmentInfos.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Index/SegmentInfos.cs?rev=1100459&r1=1100458&r2=1100459&view=diff
==============================================================================
--- incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Index/SegmentInfos.cs (original)
+++ incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Index/SegmentInfos.cs Sat May  7 06:22:20 2011
@@ -225,7 +225,7 @@ namespace Lucene.Net.Index
 			}
 			else if (fileName.StartsWith(IndexFileNames.SEGMENTS))
 			{
-				return SupportClass.Number.ToInt64(fileName.Substring(1 + IndexFileNames.SEGMENTS.Length));
+				return Support.Number.ToInt64(fileName.Substring(1 + IndexFileNames.SEGMENTS.Length));
 			}
 			else
 			{
@@ -564,7 +564,7 @@ namespace Lucene.Net.Index
 		{
 			if (infoStream != null)
 			{
-				infoStream.WriteLine("SIS [" + SupportClass.ThreadClass.Current().Name + "]: " + message);
+				infoStream.WriteLine("SIS [" + Support.ThreadClass.Current().Name + "]: " + message);
 			}
 		}
 		
@@ -704,7 +704,7 @@ namespace Lucene.Net.Index
 							{
 								// In 3.0 we will change this to throw
 								// InterruptedException instead
-								SupportClass.ThreadClass.Current().Interrupt();
+								Support.ThreadClass.Current().Interrupt();
 								throw new System.SystemException(ie.Message, ie);
 							}
 						}
@@ -926,7 +926,7 @@ namespace Lucene.Net.Index
 				SegmentInfo info = Info(i);
 				if (info.dir == dir)
 				{
-					SupportClass.CollectionsHelper.AddAllIfNotContains(files, Info(i).Files());
+					Support.CollectionsHelper.AddAllIfNotContains(files, Info(i).Files());
 				}
 			}
 			return files.Keys;

Modified: incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Index/SegmentReader.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Index/SegmentReader.cs?rev=1100459&r1=1100458&r2=1100459&view=diff
==============================================================================
--- incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Index/SegmentReader.cs (original)
+++ incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Index/SegmentReader.cs Sat May  7 06:22:20 2011
@@ -769,7 +769,7 @@ namespace Lucene.Net.Index
 			}
 		}
 
-        internal SupportClass.Dictionary<string, Norm> norms = new SupportClass.Dictionary<string, Norm>();
+        internal Support.Dictionary<string, Norm> norms = new Support.Dictionary<string, Norm>();
 		
 		/// <summary>The class which implements SegmentReader. </summary>
 		// @deprecated (LUCENE-1677)
@@ -1021,7 +1021,7 @@ namespace Lucene.Net.Index
 					}
 					
 					clone.SetDisableFakeNorms(GetDisableFakeNorms());
-                    clone.norms = new SupportClass.Dictionary<string, Norm>();
+                    clone.norms = new Support.Dictionary<string, Norm>();
 					
 					// Clone norms
 					for (int i = 0; i < fieldNormsChanged.Length; i++)
@@ -1774,7 +1774,7 @@ namespace Lucene.Net.Index
 			{
 				try
 				{
-					System.String name = SupportClass.AppSettings.Get("Lucene.Net.SegmentReader.class", typeof(SegmentReader).FullName);
+					System.String name = Support.AppSettings.Get("Lucene.Net.SegmentReader.class", typeof(SegmentReader).FullName);
 					IMPL = System.Type.GetType(name);
 				}
 				catch (System.Security.SecurityException se)
@@ -1796,7 +1796,7 @@ namespace Lucene.Net.Index
 			{
 				try
 				{
-					System.String name = SupportClass.AppSettings.Get("Lucene.Net.ReadOnlySegmentReader.class", typeof(ReadOnlySegmentReader).FullName);
+					System.String name = Support.AppSettings.Get("Lucene.Net.ReadOnlySegmentReader.class", typeof(ReadOnlySegmentReader).FullName);
 					READONLY_IMPL = System.Type.GetType(name);
 				}
 				catch (System.Security.SecurityException se)

Modified: incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Index/SegmentTermDocs.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Index/SegmentTermDocs.cs?rev=1100459&r1=1100458&r2=1100459&view=diff
==============================================================================
--- incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Index/SegmentTermDocs.cs (original)
+++ incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Index/SegmentTermDocs.cs Sat May  7 06:22:20 2011
@@ -144,7 +144,7 @@ namespace Lucene.Net.Index
 				}
 				else
 				{
-					doc += SupportClass.Number.URShift(docCode, 1); // shift off low bit
+					doc += Support.Number.URShift(docCode, 1); // shift off low bit
 					if ((docCode & 1) != 0)
 					// if low bit is set
 						freq = 1;
@@ -177,7 +177,7 @@ namespace Lucene.Net.Index
 				{
 					// manually inlined call to next() for speed
 					int docCode = freqStream.ReadVInt();
-					doc += SupportClass.Number.URShift(docCode, 1); // shift off low bit
+					doc += Support.Number.URShift(docCode, 1); // shift off low bit
 					if ((docCode & 1) != 0)
 					// if low bit is set
 						freq = 1;

Modified: incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Index/SegmentTermPositions.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Index/SegmentTermPositions.cs?rev=1100459&r1=1100458&r2=1100459&view=diff
==============================================================================
--- incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Index/SegmentTermPositions.cs (original)
+++ incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Index/SegmentTermPositions.cs Sat May  7 06:22:20 2011
@@ -87,7 +87,7 @@ namespace Lucene.Net.Index
 				{
 					payloadLength = proxStream.ReadVInt();
 				}
-				delta = SupportClass.Number.URShift(delta, 1);
+				delta = Support.Number.URShift(delta, 1);
 				needToLoadPayload = true;
 			}
 			return delta;

Modified: incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Index/SegmentWriteState.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Index/SegmentWriteState.cs?rev=1100459&r1=1100458&r2=1100459&view=diff
==============================================================================
--- incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Index/SegmentWriteState.cs (original)
+++ incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Index/SegmentWriteState.cs Sat May  7 06:22:20 2011
@@ -43,7 +43,7 @@ namespace Lucene.Net.Index
 			this.numDocs = numDocs;
 			this.numDocsInStore = numDocsInStore;
 			this.termIndexInterval = termIndexInterval;
-            flushedFiles = new SupportClass.Set<string>();
+            flushedFiles = new Support.Set<string>();
 		}
 		
 		public virtual System.String SegmentFileName(System.String ext)

Modified: incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Index/TermBuffer.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Index/TermBuffer.cs?rev=1100459&r1=1100458&r2=1100459&view=diff
==============================================================================
--- incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Index/TermBuffer.cs (original)
+++ incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Index/TermBuffer.cs Sat May  7 06:22:20 2011
@@ -111,7 +111,7 @@ namespace Lucene.Net.Index
 			System.String termText = term.Text();
 			int termLen = termText.Length;
 			text.SetLength(termLen);
-			SupportClass.TextSupport.GetCharsFromString(termText, 0, termLen, text.result, 0);
+			Support.TextSupport.GetCharsFromString(termText, 0, termLen, text.result, 0);
 			dirty = true;
 			field = term.Field();
 			this.term = term;

Modified: incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Index/TermInfosReader.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Index/TermInfosReader.cs?rev=1100459&r1=1100458&r2=1100459&view=diff
==============================================================================
--- incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Index/TermInfosReader.cs (original)
+++ incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Index/TermInfosReader.cs Sat May  7 06:22:20 2011
@@ -175,7 +175,7 @@ namespace Lucene.Net.Index
 			
 			while (hi >= lo)
 			{
-				int mid = SupportClass.Number.URShift((lo + hi), 1);
+				int mid = Support.Number.URShift((lo + hi), 1);
 				int delta = term.CompareTo(indexTerms[mid]);
 				if (delta < 0)
 					hi = mid - 1;

Modified: incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Index/TermVectorsTermsWriter.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Index/TermVectorsTermsWriter.cs?rev=1100459&r1=1100458&r2=1100459&view=diff
==============================================================================
--- incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Index/TermVectorsTermsWriter.cs (original)
+++ incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Index/TermVectorsTermsWriter.cs Sat May  7 06:22:20 2011
@@ -59,7 +59,7 @@ namespace Lucene.Net.Index
 				postings[i] = new PostingList();
 		}
 
-        public override void Flush(SupportClass.Dictionary<TermsHashConsumerPerThread, IList<TermsHashConsumerPerField>> threadsAndFields, SegmentWriteState state)
+        public override void Flush(Support.Dictionary<TermsHashConsumerPerThread, IList<TermsHashConsumerPerField>> threadsAndFields, SegmentWriteState state)
 		{
 			lock (this)
 			{

Modified: incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Index/TermsHash.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Index/TermsHash.cs?rev=1100459&r1=1100458&r2=1100459&view=diff
==============================================================================
--- incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Index/TermsHash.cs (original)
+++ incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Index/TermsHash.cs Sat May  7 06:22:20 2011
@@ -122,16 +122,16 @@ namespace Lucene.Net.Index
 			}
 		}
 
-        internal override void Flush(SupportClass.Dictionary<InvertedDocConsumerPerThread, IList<InvertedDocConsumerPerField>> threadsAndFields, SegmentWriteState state)
+        internal override void Flush(Support.Dictionary<InvertedDocConsumerPerThread, IList<InvertedDocConsumerPerField>> threadsAndFields, SegmentWriteState state)
 		{
 			lock (this)
 			{
-                SupportClass.Dictionary<TermsHashConsumerPerThread, IList<TermsHashConsumerPerField>> childThreadsAndFields = new SupportClass.Dictionary<TermsHashConsumerPerThread, IList<TermsHashConsumerPerField>>();
-				SupportClass.Dictionary<InvertedDocConsumerPerThread,IList<InvertedDocConsumerPerField>> nextThreadsAndFields;
+                Support.Dictionary<TermsHashConsumerPerThread, IList<TermsHashConsumerPerField>> childThreadsAndFields = new Support.Dictionary<TermsHashConsumerPerThread, IList<TermsHashConsumerPerField>>();
+				Support.Dictionary<InvertedDocConsumerPerThread,IList<InvertedDocConsumerPerField>> nextThreadsAndFields;
 				
 				if (nextTermsHash != null)
 				{
-                    nextThreadsAndFields = new SupportClass.Dictionary<InvertedDocConsumerPerThread, IList<InvertedDocConsumerPerField>>();
+                    nextThreadsAndFields = new Support.Dictionary<InvertedDocConsumerPerThread, IList<InvertedDocConsumerPerField>>();
 				}
 				else
 					nextThreadsAndFields = null;

Modified: incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Index/TermsHashConsumer.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Index/TermsHashConsumer.cs?rev=1100459&r1=1100458&r2=1100459&view=diff
==============================================================================
--- incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Index/TermsHashConsumer.cs (original)
+++ incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Index/TermsHashConsumer.cs Sat May  7 06:22:20 2011
@@ -26,7 +26,7 @@ namespace Lucene.Net.Index
 		internal abstract int BytesPerPosting();
 		internal abstract void  CreatePostings(RawPostingList[] postings, int start, int count);
 		public abstract TermsHashConsumerPerThread AddThread(TermsHashPerThread perThread);
-        public abstract void Flush(SupportClass.Dictionary<TermsHashConsumerPerThread, IList<TermsHashConsumerPerField>> threadsAndFields, SegmentWriteState state);
+        public abstract void Flush(Support.Dictionary<TermsHashConsumerPerThread, IList<TermsHashConsumerPerField>> threadsAndFields, SegmentWriteState state);
 		public abstract void  Abort();
 		internal abstract void  CloseDocStore(SegmentWriteState state);
 		

Modified: incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Index/TermsHashPerField.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Index/TermsHashPerField.cs?rev=1100459&r1=1100458&r2=1100459&view=diff
==============================================================================
--- incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Index/TermsHashPerField.cs (original)
+++ incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Index/TermsHashPerField.cs Sat May  7 06:22:20 2011
@@ -173,7 +173,7 @@ namespace Lucene.Net.Index
 				return ;
 			}
 			
-			int mid = SupportClass.Number.URShift((lo + hi), 1);
+			int mid = Support.Number.URShift((lo + hi), 1);
 			
 			if (ComparePostings(postings[lo], postings[mid]) > 0)
 			{
@@ -573,7 +573,7 @@ namespace Lucene.Net.Index
 			while ((i & ~ 0x7F) != 0)
 			{
 				WriteByte(stream, (byte) ((i & 0x7f) | 0x80));
-				i = SupportClass.Number.URShift(i, 7);
+				i = Support.Number.URShift(i, 7);
 			}
 			WriteByte(stream, (byte) i);
 		}

Modified: incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Lucene.Net.csproj
URL: http://svn.apache.org/viewvc/incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Lucene.Net.csproj?rev=1100459&r1=1100458&r2=1100459&view=diff
==============================================================================
--- incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Lucene.Net.csproj (original)
+++ incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Lucene.Net.csproj Sat May  7 06:22:20 2011
@@ -867,9 +867,33 @@
       <SubType>Code</SubType>
     </Compile>
     <Compile Include="Store\VerifyingLockFactory.cs" />
-    <Compile Include="SupportClass.cs">
-      <SubType>Code</SubType>
-    </Compile>
+    <Compile Include="Support\AppSettings.cs" />
+    <Compile Include="Support\AttributeImplItem.cs" />
+    <Compile Include="Support\BitSetSupport.cs" />
+    <Compile Include="Support\BuildType.cs" />
+    <Compile Include="Support\Character.cs" />
+    <Compile Include="Support\Checksum.cs" />
+    <Compile Include="Support\CollectionsHelper.cs" />
+    <Compile Include="Support\Compare.cs" />
+    <Compile Include="Support\CRC32.cs" />
+    <Compile Include="Support\Cryptography.cs" />
+    <Compile Include="Support\Dictionary.cs" />
+    <Compile Include="Support\Double.cs" />
+    <Compile Include="Support\EquatableList.cs" />
+    <Compile Include="Support\FileSupport.cs" />
+    <Compile Include="Support\GeneralKeyedCollection.cs" />
+    <Compile Include="Support\IThreadRunnable.cs" />
+    <Compile Include="Support\Number.cs" />
+    <Compile Include="Support\Os.cs" />
+    <Compile Include="Support\Set.cs" />
+    <Compile Include="Support\SharpZipLib.cs" />
+    <Compile Include="Support\Single.cs" />
+    <Compile Include="Support\ICloneable.cs">
+      <SubType>Code</SubType>
+    </Compile>
+    <Compile Include="Support\TextSupport.cs" />
+    <Compile Include="Support\ThreadClass.cs" />
+    <Compile Include="Support\WeakHashTable.cs" />
     <Compile Include="Util\ArrayUtil.cs" />
     <Compile Include="Util\Attribute.cs" />
     <Compile Include="Util\AttributeImpl.cs" />

Modified: incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/QueryParser/ParseException.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/QueryParser/ParseException.cs?rev=1100459&r1=1100458&r2=1100459&view=diff
==============================================================================
--- incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/QueryParser/ParseException.cs (original)
+++ incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/QueryParser/ParseException.cs Sat May  7 06:22:20 2011
@@ -172,7 +172,7 @@ namespace Lucene.Net.QueryParsers
 		public System.String[] tokenImage;
 		
 		/// <summary> The end of line string for this machine.</summary>
-		protected internal System.String eol = SupportClass.AppSettings.Get("line.separator", "\n");
+		protected internal System.String eol = Support.AppSettings.Get("line.separator", "\n");
 		
 		/// <summary> Used to convert raw characters to their escaped version
 		/// when these raw version cannot be used as part of an ASCII

Modified: incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/QueryParser/QueryParser.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/QueryParser/QueryParser.cs?rev=1100459&r1=1100458&r2=1100459&view=diff
==============================================================================
--- incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/QueryParser/QueryParser.cs (original)
+++ incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/QueryParser/QueryParser.cs Sat May  7 06:22:20 2011
@@ -1272,7 +1272,7 @@ namespace Lucene.Net.QueryParsers
 				if (codePointMultiplier > 0)
 				{
 					codePoint += HexToInt(curChar) * codePointMultiplier;
-					codePointMultiplier = SupportClass.Number.URShift(codePointMultiplier, 4);
+					codePointMultiplier = Support.Number.URShift(codePointMultiplier, 4);
 					if (codePointMultiplier == 0)
 					{
 						output[length++] = (char) codePoint;
@@ -1620,7 +1620,7 @@ label_1_brk: ;  // {{Aroush-2.9}} this l
 				float f = (float) 1.0;
 				try
 				{
-					f = (float) SupportClass.Single.Parse(boost.image);
+					f = (float) Support.Single.Parse(boost.image);
 					q.SetBoost(f);
 				}
 				catch (System.Exception ignored)
@@ -1737,7 +1737,7 @@ label_1_brk: ;  // {{Aroush-2.9}} this l
 						float fms = fuzzyMinSim;
 						try
 						{
-							fms = (float) SupportClass.Single.Parse(fuzzySlop.image.Substring(1));
+							fms = (float) Support.Single.Parse(fuzzySlop.image.Substring(1));
 						}
 						catch (System.Exception ignored)
 						{
@@ -1943,7 +1943,7 @@ label_1_brk: ;  // {{Aroush-2.9}} this l
 					{
 						try
 						{
-							s = (int) SupportClass.Single.Parse(fuzzySlop.image.Substring(1));
+							s = (int) Support.Single.Parse(fuzzySlop.image.Substring(1));
 						}
 						catch (System.Exception ignored)
 						{
@@ -1963,7 +1963,7 @@ label_1_brk: ;  // {{Aroush-2.9}} this l
 				float f = (float) 1.0;
 				try
 				{
-					f = (float) SupportClass.Single.Parse(boost.image);
+					f = (float) Support.Single.Parse(boost.image);
 				}
 				catch (System.Exception ignored)
 				{

Modified: incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/BooleanQuery.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/BooleanQuery.cs?rev=1100459&r1=1100458&r2=1100459&view=diff
==============================================================================
--- incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/BooleanQuery.cs (original)
+++ incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/BooleanQuery.cs Sat May  7 06:22:20 2011
@@ -102,7 +102,7 @@ namespace Lucene.Net.Search
 			BooleanQuery.maxClauseCount = maxClauseCount;
 		}
 		
-		private SupportClass.EquatableList<BooleanClause> clauses = new SupportClass.EquatableList<BooleanClause>();
+		private Support.EquatableList<BooleanClause> clauses = new Support.EquatableList<BooleanClause>();
 		private bool disableCoord;
 		
 		/// <summary>Constructs an empty boolean query. </summary>
@@ -585,7 +585,7 @@ namespace Lucene.Net.Search
 		}
 		
 		// inherit javadoc
-		public override void  ExtractTerms(SupportClass.Set<Lucene.Net.Index.Term> terms)
+		public override void  ExtractTerms(Support.Set<Lucene.Net.Index.Term> terms)
 		{
             foreach(BooleanClause clause in clauses)
             {
@@ -596,7 +596,7 @@ namespace Lucene.Net.Search
 		public override System.Object Clone()
 		{
 			BooleanQuery clone = (BooleanQuery) base.Clone();
-			clone.clauses = (SupportClass.EquatableList<BooleanClause>) this.clauses.Clone();
+			clone.clauses = (Support.EquatableList<BooleanClause>) this.clauses.Clone();
 			return clone;
 		}
 		

Modified: incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/CachingWrapperFilter.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/CachingWrapperFilter.cs?rev=1100459&r1=1100458&r2=1100459&view=diff
==============================================================================
--- incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/CachingWrapperFilter.cs (original)
+++ incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/CachingWrapperFilter.cs Sat May  7 06:22:20 2011
@@ -94,7 +94,7 @@ namespace Lucene.Net.Search
 
                     if (cache == null)
                     {
-                        cache = new SupportClass.WeakHashTable();
+                        cache = new Support.WeakHashTable();
                     }
 
                     if (deletesMode == DeletesMode.IGNORE)

Modified: incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/ConstantScoreQuery.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/ConstantScoreQuery.cs?rev=1100459&r1=1100458&r2=1100459&view=diff
==============================================================================
--- incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/ConstantScoreQuery.cs (original)
+++ incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/ConstantScoreQuery.cs Sat May  7 06:22:20 2011
@@ -50,7 +50,7 @@ namespace Lucene.Net.Search
 			return this;
 		}
 		
-		public override void  ExtractTerms(SupportClass.Set<Lucene.Net.Index.Term> terms)
+		public override void  ExtractTerms(Support.Set<Lucene.Net.Index.Term> terms)
 		{
 			// OK to not add any terms when used for MultiSearcher,
 			// but may not be OK for highlighting

Modified: incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/DisjunctionMaxQuery.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/DisjunctionMaxQuery.cs?rev=1100459&r1=1100458&r2=1100459&view=diff
==============================================================================
--- incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/DisjunctionMaxQuery.cs (original)
+++ incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/DisjunctionMaxQuery.cs Sat May  7 06:22:20 2011
@@ -41,7 +41,7 @@ namespace Lucene.Net.Search
 	{
 		
 		/* The subqueries */
-		private SupportClass.EquatableList<Query> disjuncts = new SupportClass.EquatableList<Query>();
+		private Support.EquatableList<Query> disjuncts = new Support.EquatableList<Query>();
 		
 		/* Multiple of the non-max disjunct scores added into our final score.  Non-zero values support tie-breaking. */
 		private float tieBreakerMultiplier = 0.0f;
@@ -259,12 +259,12 @@ namespace Lucene.Net.Search
 		public override System.Object Clone()
 		{
 			DisjunctionMaxQuery clone = (DisjunctionMaxQuery) base.Clone();
-            clone.disjuncts = (SupportClass.EquatableList<Query>) this.disjuncts.Clone();
+            clone.disjuncts = (Support.EquatableList<Query>) this.disjuncts.Clone();
 			return clone;
 		}
 		
 		// inherit javadoc
-		public override void  ExtractTerms(SupportClass.Set<Lucene.Net.Index.Term> terms)
+		public override void  ExtractTerms(Support.Set<Lucene.Net.Index.Term> terms)
 		{
 			for (System.Collections.IEnumerator iter = disjuncts.GetEnumerator(); iter.MoveNext(); )
 			{

Modified: incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/FieldCache.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/FieldCache.cs?rev=1100459&r1=1100458&r2=1100459&view=diff
==============================================================================
--- incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/FieldCache.cs (original)
+++ incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/FieldCache.cs Sat May  7 06:22:20 2011
@@ -56,7 +56,7 @@ namespace Lucene.Net.Search
 			
 			while (low <= high)
 			{
-				int mid = SupportClass.Number.URShift((low + high), 1);
+				int mid = Support.Number.URShift((low + high), 1);
 				int cmp = String.CompareOrdinal(lookup[mid], key);
 				
 				if (cmp < 0)
@@ -250,7 +250,7 @@ namespace Lucene.Net.Search
 		{
             try
             {
-                return SupportClass.Single.Parse(value_Renamed);
+                return Support.Single.Parse(value_Renamed);
             }
             catch (System.OverflowException)
             {
@@ -287,7 +287,7 @@ namespace Lucene.Net.Search
 	{
 		public virtual double ParseDouble(System.String value_Renamed)
 		{
-			return SupportClass.Double.Parse(value_Renamed);
+			return Support.Double.Parse(value_Renamed);
 		}
 		protected internal virtual System.Object ReadResolve()
 		{

Modified: incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/FieldCacheImpl.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/FieldCacheImpl.cs?rev=1100459&r1=1100458&r2=1100459&view=diff
==============================================================================
--- incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/FieldCacheImpl.cs (original)
+++ incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/FieldCacheImpl.cs Sat May  7 06:22:20 2011
@@ -43,7 +43,7 @@ namespace Lucene.Net.Search
 	class FieldCacheImpl : ExtendedFieldCache_old.ExtendedFieldCache
 	{
 		
-		private SupportClass.Dictionary<Type,Cache> caches;
+		private Support.Dictionary<Type,Cache> caches;
 		internal FieldCacheImpl()
 		{
 			Init();
@@ -52,7 +52,7 @@ namespace Lucene.Net.Search
 		{
 			lock (this)
 			{
-                SupportClass.Dictionary<Type, Cache> caches2 = new SupportClass.Dictionary<Type, Cache>();
+                Support.Dictionary<Type, Cache> caches2 = new Support.Dictionary<Type, Cache>();
                 caches2[typeof(sbyte)] = new ByteCache(this);
                 caches2[typeof(short)] = new ShortCache(this);
                 caches2[typeof(int)] = new IntCache(this);
@@ -209,7 +209,7 @@ namespace Lucene.Net.Search
 			
 			internal FieldCache wrapper;
 
-            internal System.Collections.IDictionary readerCache = new SupportClass.WeakHashTable();
+            internal System.Collections.IDictionary readerCache = new Support.WeakHashTable();
 			
 			protected internal abstract System.Object CreateValue(IndexReader reader, Entry key);
 
@@ -982,7 +982,7 @@ namespace Lucene.Net.Search
 							{
 								try
 								{
-                                    SupportClass.Single.Parse(termtext);
+                                    Support.Single.Parse(termtext);
 									ret = wrapper.GetFloats(reader, field);
 								}
 								catch (System.FormatException nfe3)

Modified: incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/FieldCacheRangeFilter.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/FieldCacheRangeFilter.cs?rev=1100459&r1=1100458&r2=1100459&view=diff
==============================================================================
--- incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/FieldCacheRangeFilter.cs (original)
+++ incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/FieldCacheRangeFilter.cs Sat May  7 06:22:20 2011
@@ -753,7 +753,7 @@ namespace Lucene.Net.Search
 		{
 			int h = field.GetHashCode();
 			h ^= ((lowerVal != null)?lowerVal.GetHashCode():550356204);
-			h = (h << 1) | (SupportClass.Number.URShift(h, 31)); // rotate to distinguish lower from upper
+			h = (h << 1) | (Support.Number.URShift(h, 31)); // rotate to distinguish lower from upper
 			h ^= ((upperVal != null)?upperVal.GetHashCode():- 1674416163);
 			h ^= ((parser != null)?parser.GetHashCode():- 1572457324);
 			h ^= (includeLower?1549299360:- 365038026) ^ (includeUpper?1721088258:1948649653);

Modified: incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/FieldComparator.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/FieldComparator.cs?rev=1100459&r1=1100458&r2=1100459&view=diff
==============================================================================
--- incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/FieldComparator.cs (original)
+++ incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/FieldComparator.cs Sat May  7 06:22:20 2011
@@ -953,7 +953,7 @@ namespace Lucene.Net.Search
 			
 			while (low <= high)
 			{
-				int mid = SupportClass.Number.URShift((low + high), 1);
+				int mid = Support.Number.URShift((low + high), 1);
 				System.String midVal = a[mid];
 				int cmp;
 				if (midVal != null)

Modified: incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/FilterManager.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/FilterManager.cs?rev=1100459&r1=1100458&r2=1100459&view=diff
==============================================================================
--- incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/FilterManager.cs (original)
+++ incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/FilterManager.cs Sat May  7 06:22:20 2011
@@ -66,12 +66,12 @@ namespace Lucene.Net.Search
 		/// <summary> Sets up the FilterManager singleton.</summary>
 		protected internal FilterManager()
 		{
-			cache = new SupportClass.Dictionary<int,FilterItem>();
+			cache = new Support.Dictionary<int,FilterItem>();
 			cacheCleanSize = DEFAULT_CACHE_CLEAN_SIZE; // Let the cache get to 100 items
 			cleanSleepTime = DEFAULT_CACHE_SLEEP_TIME; // 10 minutes between cleanings
 			
 			filterCleaner = new FilterCleaner(this);
-			SupportClass.ThreadClass fcThread = new SupportClass.ThreadClass(new System.Threading.ThreadStart(filterCleaner.Run));
+			Support.ThreadClass fcThread = new Support.ThreadClass(new System.Threading.ThreadStart(filterCleaner.Run));
 			// setto be a Daemon so it doesn't have to be stopped
 			fcThread.IsBackground = true;
 			fcThread.Start();
@@ -222,7 +222,7 @@ namespace Lucene.Net.Search
 					}
 					catch (System.Threading.ThreadInterruptedException ie)
 					{
-						SupportClass.ThreadClass.Current().Interrupt();
+						Support.ThreadClass.Current().Interrupt();
 						throw new System.SystemException(ie.Message, ie);
 					}
 				}

Modified: incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/FilteredQuery.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/FilteredQuery.cs?rev=1100459&r1=1100458&r2=1100459&view=diff
==============================================================================
--- incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/FilteredQuery.cs (original)
+++ incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/FilteredQuery.cs Sat May  7 06:22:20 2011
@@ -298,7 +298,7 @@ namespace Lucene.Net.Search
 		}
 		
 		// inherit javadoc
-		public override void  ExtractTerms(SupportClass.Set<Lucene.Net.Index.Term> terms)
+		public override void  ExtractTerms(Support.Set<Lucene.Net.Index.Term> terms)
 		{
 			GetQuery().ExtractTerms(terms);
 		}

Modified: incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/Function/CustomScoreQuery.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/Function/CustomScoreQuery.cs?rev=1100459&r1=1100458&r2=1100459&view=diff
==============================================================================
--- incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/Function/CustomScoreQuery.cs (original)
+++ incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/Function/CustomScoreQuery.cs Sat May  7 06:22:20 2011
@@ -113,7 +113,7 @@ namespace Lucene.Net.Search.Function
         }
 		
 		/*(non-Javadoc) @see Lucene.Net.Search.Query#extractTerms(java.util.Set) */
-		public override void  ExtractTerms(SupportClass.Set<Lucene.Net.Index.Term> terms)
+		public override void  ExtractTerms(Support.Set<Lucene.Net.Index.Term> terms)
 		{
 			subQuery.ExtractTerms(terms);
 			for (int i = 0; i < valSrcQueries.Length; i++)

Modified: incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/Function/ValueSourceQuery.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/Function/ValueSourceQuery.cs?rev=1100459&r1=1100458&r2=1100459&view=diff
==============================================================================
--- incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/Function/ValueSourceQuery.cs (original)
+++ incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/Function/ValueSourceQuery.cs Sat May  7 06:22:20 2011
@@ -60,7 +60,7 @@ namespace Lucene.Net.Search.Function
 		}
 		
 		/*(non-Javadoc) @see Lucene.Net.Search.Query#extractTerms(java.util.Set) */
-		public override void  ExtractTerms(SupportClass.Set<Lucene.Net.Index.Term> terms)
+		public override void  ExtractTerms(Support.Set<Lucene.Net.Index.Term> terms)
 		{
 			// no terms involved here
 		}

Modified: incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/FuzzyQuery.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/FuzzyQuery.cs?rev=1100459&r1=1100458&r2=1100459&view=diff
==============================================================================
--- incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/FuzzyQuery.cs (original)
+++ incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/FuzzyQuery.cs Sat May  7 06:22:20 2011
@@ -202,7 +202,7 @@ namespace Lucene.Net.Search
 			}
 			buffer.Append(term.Text());
 			buffer.Append('~');
-			buffer.Append(SupportClass.Single.ToString(minimumSimilarity));
+			buffer.Append(Support.Single.ToString(minimumSimilarity));
 			buffer.Append(ToStringUtils.Boost(GetBoost()));
 			return buffer.ToString();
 		}

Modified: incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/MatchAllDocsQuery.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/MatchAllDocsQuery.cs?rev=1100459&r1=1100458&r2=1100459&view=diff
==============================================================================
--- incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/MatchAllDocsQuery.cs (original)
+++ incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/MatchAllDocsQuery.cs Sat May  7 06:22:20 2011
@@ -199,7 +199,7 @@ namespace Lucene.Net.Search
 			return new MatchAllDocsWeight(this, searcher);
 		}
 		
-		public override void  ExtractTerms(SupportClass.Set<Lucene.Net.Index.Term> terms)
+		public override void  ExtractTerms(Support.Set<Lucene.Net.Index.Term> terms)
 		{
 		}
 		

Modified: incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/MultiPhraseQuery.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/MultiPhraseQuery.cs?rev=1100459&r1=1100458&r2=1100459&view=diff
==============================================================================
--- incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/MultiPhraseQuery.cs (original)
+++ incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/MultiPhraseQuery.cs Sat May  7 06:22:20 2011
@@ -130,7 +130,7 @@ namespace Lucene.Net.Search
 		}
 		
 		// inherit javadoc
-		public override void  ExtractTerms(SupportClass.Set<Lucene.Net.Index.Term> terms)
+		public override void  ExtractTerms(Support.Set<Lucene.Net.Index.Term> terms)
 		{
             foreach(Term[] arr in termArrays)
 			{
@@ -388,7 +388,7 @@ namespace Lucene.Net.Search
 
             for (int i = 0; i < this.termArrays.Count; i++)
             {
-                if (!SupportClass.Compare.CompareTermArrays((Term[])this.termArrays[i], (Term[])other.termArrays[i]))
+                if (!Support.Compare.CompareTermArrays((Term[])this.termArrays[i], (Term[])other.termArrays[i]))
                 {
                     return false;
                 }

Modified: incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/MultiSearcher.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/MultiSearcher.cs?rev=1100459&r1=1100458&r2=1100459&view=diff
==============================================================================
--- incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/MultiSearcher.cs (original)
+++ incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/MultiSearcher.cs Sat May  7 06:22:20 2011
@@ -395,7 +395,7 @@ namespace Lucene.Net.Search
 			Query rewrittenQuery = Rewrite(original);
 			
 			// step 2
-            SupportClass.Set<Lucene.Net.Index.Term> terms = new SupportClass.Set<Term>();
+            Support.Set<Lucene.Net.Index.Term> terms = new Support.Set<Term>();
 			rewrittenQuery.ExtractTerms(terms);
 			
 			// step3
@@ -416,7 +416,7 @@ namespace Lucene.Net.Search
 				}
 			}
 
-            IDictionary<Term, int> dfMap = new SupportClass.Dictionary<Term, int>();
+            IDictionary<Term, int> dfMap = new Support.Dictionary<Term, int>();
 			for (int i = 0; i < allTermsArray.Length; i++)
 			{
 				dfMap[allTermsArray[i]] = aggregatedDfs[i];

Modified: incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/ParallelMultiSearcher.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/ParallelMultiSearcher.cs?rev=1100459&r1=1100458&r2=1100459&view=diff
==============================================================================
--- incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/ParallelMultiSearcher.cs (original)
+++ incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/ParallelMultiSearcher.cs Sat May  7 06:22:20 2011
@@ -115,7 +115,7 @@ namespace Lucene.Net.Search
 				{
 					// In 3.0 we will change this to throw
 					// InterruptedException instead
-					SupportClass.ThreadClass.Current().Interrupt();
+					Support.ThreadClass.Current().Interrupt();
 					throw new System.SystemException(ie.Message, ie);
 				}
 				System.IO.IOException ioe = msta[i].GetIOException();
@@ -170,7 +170,7 @@ namespace Lucene.Net.Search
 				{
 					// In 3.0 we will change this to throw
 					// InterruptedException instead
-					SupportClass.ThreadClass.Current().Interrupt();
+					Support.ThreadClass.Current().Interrupt();
 					throw new System.SystemException(ie.Message, ie);
 				}
 				System.IO.IOException ioe = msta[i].GetIOException();
@@ -236,7 +236,7 @@ namespace Lucene.Net.Search
 	}
 	
 	/// <summary> A thread subclass for searching a single searchable </summary>
-	class MultiSearcherThread:SupportClass.ThreadClass
+	class MultiSearcherThread:Support.ThreadClass
 	{
 		
 		private Searchable searchable;

Modified: incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/PhraseQuery.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/PhraseQuery.cs?rev=1100459&r1=1100458&r2=1100459&view=diff
==============================================================================
--- incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/PhraseQuery.cs (original)
+++ incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/PhraseQuery.cs Sat May  7 06:22:20 2011
@@ -37,7 +37,7 @@ namespace Lucene.Net.Search
 	{
 		private System.String field;
         private List<Term> terms = new List<Term>();
-        private SupportClass.EquatableList<int> positions = new SupportClass.EquatableList<int>(4);
+        private Support.EquatableList<int> positions = new Support.EquatableList<int>(4);
 		private int maxPosition = 0;
 		private int slop = 0;
 		
@@ -292,7 +292,7 @@ namespace Lucene.Net.Search
 		
 		/// <seealso cref="Lucene.Net.Search.Query.ExtractTerms(java.util.Set)">
 		/// </seealso>
-		public override void  ExtractTerms(SupportClass.Set<Lucene.Net.Index.Term> queryTerms)
+		public override void  ExtractTerms(Support.Set<Lucene.Net.Index.Term> queryTerms)
 		{
             queryTerms.Add(terms);
 			//SupportClass.CollectionsHelper.AddAllIfNotContains(queryTerms, terms);

Modified: incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/Query.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/Query.cs?rev=1100459&r1=1100458&r2=1100459&view=diff
==============================================================================
--- incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/Query.cs (original)
+++ incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/Query.cs Sat May  7 06:22:20 2011
@@ -134,7 +134,7 @@ namespace Lucene.Net.Search
 		/// </summary>
 		public virtual Query Combine(Query[] queries)
 		{
-            SupportClass.Set<Query> uniques = new SupportClass.Set<Query>();
+            Support.Set<Query> uniques = new Support.Set<Query>();
 			for (int i = 0; i < queries.Length; i++)
 			{
 				Query query = queries[i];
@@ -185,7 +185,7 @@ namespace Lucene.Net.Search
 		/// 
 		/// </summary>
 		/// <throws>  UnsupportedOperationException if this query is not yet rewritten </throws>
-		public virtual void  ExtractTerms(SupportClass.Set<Lucene.Net.Index.Term> terms)
+		public virtual void  ExtractTerms(Support.Set<Lucene.Net.Index.Term> terms)
 		{
 			// needs to be implemented by query subclasses
 			throw new System.NotSupportedException();
@@ -200,7 +200,7 @@ namespace Lucene.Net.Search
 		/// </summary>
 		public static Query MergeBooleanQueries(BooleanQuery[] queries)
 		{
-            SupportClass.Set<BooleanClause> allClauses = new SupportClass.Set<BooleanClause>();
+            Support.Set<BooleanClause> allClauses = new Support.Set<BooleanClause>();
 			for (int i = 0; i < queries.Length; i++)
 			{
 				BooleanClause[] clauses = queries[i].GetClauses();

Modified: incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/QueryTermVector.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/QueryTermVector.cs?rev=1100459&r1=1100458&r2=1100459&view=diff
==============================================================================
--- incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/QueryTermVector.cs (original)
+++ incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/QueryTermVector.cs Sat May  7 06:22:20 2011
@@ -84,7 +84,7 @@ namespace Lucene.Net.Search
 			if (queryTerms != null)
 			{
 				System.Array.Sort<string>(queryTerms);
-                SupportClass.Dictionary<string, int?> tmpSet = new SupportClass.Dictionary<string, int?>(queryTerms.Length); 
+                Support.Dictionary<string, int?> tmpSet = new Support.Dictionary<string, int?>(queryTerms.Length); 
 				//filter out duplicates
                 List<String> tmpList = new List<String>(queryTerms.Length);
                 List<int> tmpFreqs = new List<int>(queryTerms.Length);

Modified: incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/SloppyPhraseScorer.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/SloppyPhraseScorer.cs?rev=1100459&r1=1100458&r2=1100459&view=diff
==============================================================================
--- incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/SloppyPhraseScorer.cs (original)
+++ incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/SloppyPhraseScorer.cs Sat May  7 06:22:20 2011
@@ -157,7 +157,7 @@ namespace Lucene.Net.Search
 			{
 				checkedRepeats = true;
 				// check for repeats
-				SupportClass.Dictionary<PhrasePositions, Object> m = null;
+				Support.Dictionary<PhrasePositions, Object> m = null;
 				for (PhrasePositions pp = first; pp != null; pp = pp.next)
 				{
 					int tpPos = pp.position + pp.offset;
@@ -168,7 +168,7 @@ namespace Lucene.Net.Search
 						{
 							if (m == null)
 							{
-                                m = new SupportClass.Dictionary<PhrasePositions, object>();
+                                m = new Support.Dictionary<PhrasePositions, object>();
 							}
 							pp.repeats = true;
 							pp2.repeats = true;

Modified: incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/Sort.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/Sort.cs?rev=1100459&r1=1100458&r2=1100459&view=diff
==============================================================================
--- incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/Sort.cs (original)
+++ incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/Sort.cs Sat May  7 06:22:20 2011
@@ -300,7 +300,7 @@ namespace Lucene.Net.Search
 			// TODO in Java 1.5: switch to Arrays.hashCode().  The 
 			// Java 1.4 workaround below calculates the same hashCode
 			// as Java 1.5's new Arrays.hashCode()
-			return 0x45aaf665 + SupportClass.EquatableList<SortField>.GetHashCode(fields);
+			return 0x45aaf665 + Support.EquatableList<SortField>.GetHashCode(fields);
 		}
 		static Sort()
 		{

Modified: incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/SortField.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/SortField.cs?rev=1100459&r1=1100458&r2=1100459&view=diff
==============================================================================
--- incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/SortField.cs (original)
+++ incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/SortField.cs Sat May  7 06:22:20 2011
@@ -671,7 +671,7 @@ namespace Lucene.Net.Search
                     int tmpI32; long tmpI64; float tmpF;
                     if      (System.Int32.TryParse(termtext, out tmpI32))       ret = SortField.INT;
                     else if (System.Int64.TryParse(termtext, out tmpI64))       ret = SortField.LONG;
-                    else if (SupportClass.Single.TryParse(termtext, out tmpF))  ret = SortField.FLOAT;
+                    else if (Support.Single.TryParse(termtext, out tmpF))  ret = SortField.FLOAT;
                     else ret = SortField.STRING;
 				}
 				else

Modified: incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/Spans/FieldMaskingSpanQuery.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/Spans/FieldMaskingSpanQuery.cs?rev=1100459&r1=1100458&r2=1100459&view=diff
==============================================================================
--- incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/Spans/FieldMaskingSpanQuery.cs (original)
+++ incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/Spans/FieldMaskingSpanQuery.cs Sat May  7 06:22:20 2011
@@ -107,7 +107,7 @@ namespace Lucene.Net.Search.Spans
 			return maskedQuery.GetTerms();
 		}
 		
-		public override void  ExtractTerms(SupportClass.Set<Lucene.Net.Index.Term> terms)
+		public override void  ExtractTerms(Support.Set<Lucene.Net.Index.Term> terms)
 		{
 			maskedQuery.ExtractTerms(terms);
 		}

Modified: incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/Spans/SpanFirstQuery.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/Spans/SpanFirstQuery.cs?rev=1100459&r1=1100458&r2=1100459&view=diff
==============================================================================
--- incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/Spans/SpanFirstQuery.cs (original)
+++ incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/Spans/SpanFirstQuery.cs Sat May  7 06:22:20 2011
@@ -166,7 +166,7 @@ namespace Lucene.Net.Search.Spans
 			return spanFirstQuery;
 		}
 		
-		public override void  ExtractTerms(SupportClass.Set<Lucene.Net.Index.Term> terms)
+		public override void  ExtractTerms(Support.Set<Lucene.Net.Index.Term> terms)
 		{
 			match.ExtractTerms(terms);
 		}
@@ -211,7 +211,7 @@ namespace Lucene.Net.Search.Spans
 		public override int GetHashCode()
 		{
 			int h = match.GetHashCode();
-			h ^= ((h << 8) | (SupportClass.Number.URShift(h, 25))); // reversible
+			h ^= ((h << 8) | (Support.Number.URShift(h, 25))); // reversible
 			h ^= System.Convert.ToInt32(GetBoost()) ^ end;
 			return h;
 		}

Modified: incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/Spans/SpanNearQuery.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/Spans/SpanNearQuery.cs?rev=1100459&r1=1100458&r2=1100459&view=diff
==============================================================================
--- incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/Spans/SpanNearQuery.cs (original)
+++ incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/Spans/SpanNearQuery.cs Sat May  7 06:22:20 2011
@@ -113,7 +113,7 @@ namespace Lucene.Net.Search.Spans
 			return terms;
 		}
 		
-		public override void  ExtractTerms(SupportClass.Set<Lucene.Net.Index.Term> terms)
+		public override void  ExtractTerms(Support.Set<Lucene.Net.Index.Term> terms)
 		{
             foreach (SpanQuery clause in clauses)
             {
@@ -237,7 +237,7 @@ namespace Lucene.Net.Search.Spans
 			// Mix bits before folding in things like boost, since it could cancel the
 			// last element of clauses.  This particular mix also serves to
 			// differentiate SpanNearQuery hashcodes from others.
-			result ^= ((result << 14) | (SupportClass.Number.URShift(result, 19))); // reversible
+			result ^= ((result << 14) | (Support.Number.URShift(result, 19))); // reversible
 			result += System.Convert.ToInt32(GetBoost());
 			result += slop;
 			result ^= (inOrder ? (long) 0x99AFD3BD : 0);

Modified: incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/Spans/SpanNotQuery.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/Spans/SpanNotQuery.cs?rev=1100459&r1=1100458&r2=1100459&view=diff
==============================================================================
--- incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/Spans/SpanNotQuery.cs (original)
+++ incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/Spans/SpanNotQuery.cs Sat May  7 06:22:20 2011
@@ -186,7 +186,7 @@ namespace Lucene.Net.Search.Spans
 			return include.GetTerms();
 		}
 		
-		public override void  ExtractTerms(SupportClass.Set<Lucene.Net.Index.Term> terms)
+		public override void  ExtractTerms(Support.Set<Lucene.Net.Index.Term> terms)
 		{
 			include.ExtractTerms(terms);
 		}
@@ -258,9 +258,9 @@ namespace Lucene.Net.Search.Spans
 		public override int GetHashCode()
 		{
 			int h = include.GetHashCode();
-			h = (h << 1) | (SupportClass.Number.URShift(h, 31)); // rotate left
+			h = (h << 1) | (Support.Number.URShift(h, 31)); // rotate left
 			h ^= exclude.GetHashCode();
-			h = (h << 1) | (SupportClass.Number.URShift(h, 31)); // rotate left
+			h = (h << 1) | (Support.Number.URShift(h, 31)); // rotate left
 			h ^= System.Convert.ToInt32(GetBoost());
 			return h;
 		}

Modified: incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/Spans/SpanOrQuery.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/Spans/SpanOrQuery.cs?rev=1100459&r1=1100458&r2=1100459&view=diff
==============================================================================
--- incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/Spans/SpanOrQuery.cs (original)
+++ incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/Spans/SpanOrQuery.cs Sat May  7 06:22:20 2011
@@ -162,7 +162,7 @@ namespace Lucene.Net.Search.Spans
 				return "spans(" + Enclosing_Instance + ")@" + ((queue == null)?"START":(queue.Size() > 0?(Doc() + ":" + Start() + "-" + End()):"END"));
 			}
 		}
-		private SupportClass.EquatableList<SpanQuery> clauses;
+		private Support.EquatableList<SpanQuery> clauses;
 		private System.String field;
 		
 		/// <summary>Construct a SpanOrQuery merging the provided clauses. </summary>
@@ -170,7 +170,7 @@ namespace Lucene.Net.Search.Spans
 		{
 			
 			// copy clauses array into an ArrayList
-			this.clauses = new SupportClass.EquatableList<SpanQuery>(clauses.Length);
+			this.clauses = new Support.EquatableList<SpanQuery>(clauses.Length);
 			for (int i = 0; i < clauses.Length; i++)
 			{
 				SpanQuery clause = clauses[i];
@@ -214,7 +214,7 @@ namespace Lucene.Net.Search.Spans
 			return terms;
 		}
 		
-		public override void  ExtractTerms(SupportClass.Set<Lucene.Net.Index.Term> terms)
+		public override void  ExtractTerms(Support.Set<Lucene.Net.Index.Term> terms)
 		{
 			System.Collections.IEnumerator i = clauses.GetEnumerator();
 			while (i.MoveNext())
@@ -305,7 +305,7 @@ namespace Lucene.Net.Search.Spans
 		public override int GetHashCode()
 		{
 			int h = clauses.GetHashCode();
-			h ^= ((h << 10) | (SupportClass.Number.URShift(h, 23)));
+			h ^= ((h << 10) | (Support.Number.URShift(h, 23)));
 			h ^= System.Convert.ToInt32(GetBoost());
 			return h;
 		}

Modified: incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/Spans/SpanTermQuery.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/Spans/SpanTermQuery.cs?rev=1100459&r1=1100458&r2=1100459&view=diff
==============================================================================
--- incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/Spans/SpanTermQuery.cs (original)
+++ incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/Spans/SpanTermQuery.cs Sat May  7 06:22:20 2011
@@ -60,7 +60,7 @@ namespace Lucene.Net.Search.Spans
 			terms.Add(term);
 			return terms;
 		}
-		public override void  ExtractTerms(SupportClass.Set<Lucene.Net.Index.Term> terms)
+		public override void  ExtractTerms(Support.Set<Lucene.Net.Index.Term> terms)
 		{
             terms.Add(term);
 		}

Modified: incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/Spans/SpanWeight.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/Spans/SpanWeight.cs?rev=1100459&r1=1100458&r2=1100459&view=diff
==============================================================================
--- incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/Spans/SpanWeight.cs (original)
+++ incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/Spans/SpanWeight.cs Sat May  7 06:22:20 2011
@@ -34,7 +34,7 @@ namespace Lucene.Net.Search.Spans
 		protected internal float queryNorm;
 		protected internal float queryWeight;
 		
-		protected internal SupportClass.Set<Lucene.Net.Index.Term> terms;
+		protected internal Support.Set<Lucene.Net.Index.Term> terms;
 		protected internal SpanQuery query;
 		private IDFExplanation idfExp;
 		
@@ -42,7 +42,7 @@ namespace Lucene.Net.Search.Spans
 		{
 			this.similarity = query.GetSimilarity(searcher);
 			this.query = query;
-            terms = new SupportClass.Set<Lucene.Net.Index.Term>();
+            terms = new Support.Set<Lucene.Net.Index.Term>();
 			query.ExtractTerms(terms);
 			idfExp = similarity.idfExplain(terms.ToArray(), searcher);
 			idf = idfExp.GetIdf();

Modified: incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/TermQuery.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/TermQuery.cs?rev=1100459&r1=1100458&r2=1100459&view=diff
==============================================================================
--- incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/TermQuery.cs (original)
+++ incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/TermQuery.cs Sat May  7 06:22:20 2011
@@ -176,7 +176,7 @@ namespace Lucene.Net.Search
 			return new TermWeight(this, searcher);
 		}
 		
-		public override void  ExtractTerms(SupportClass.Set<Lucene.Net.Index.Term> terms)
+		public override void  ExtractTerms(Support.Set<Lucene.Net.Index.Term> terms)
 		{
             terms.Add(GetTerm());
 		}

Modified: incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/TimeLimitedCollector.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/TimeLimitedCollector.cs?rev=1100459&r1=1100458&r2=1100459&view=diff
==============================================================================
--- incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/TimeLimitedCollector.cs (original)
+++ incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/TimeLimitedCollector.cs Sat May  7 06:22:20 2011
@@ -52,7 +52,7 @@ namespace Lucene.Net.Search
 		
 		private bool greedy;
 		
-		private class TimerThread:SupportClass.ThreadClass
+		private class TimerThread:Support.ThreadClass
 		{
 			
 			// NOTE: we can avoid explicit synchronization here for several reasons:
@@ -89,7 +89,7 @@ namespace Lucene.Net.Search
 					}
 					catch (System.Threading.ThreadInterruptedException ie)
 					{
-						SupportClass.ThreadClass.Current().Interrupt();
+						Support.ThreadClass.Current().Interrupt();
 						throw new System.SystemException(ie.Message, ie);
 					}
 				}

Modified: incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/TimeLimitingCollector.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/TimeLimitingCollector.cs?rev=1100459&r1=1100458&r2=1100459&view=diff
==============================================================================
--- incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/TimeLimitingCollector.cs (original)
+++ incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Search/TimeLimitingCollector.cs Sat May  7 06:22:20 2011
@@ -48,7 +48,7 @@ namespace Lucene.Net.Search
 		
 		private bool greedy;
 		
-		private sealed class TimerThread:SupportClass.ThreadClass
+		private sealed class TimerThread:Support.ThreadClass
 		{
 			
 			// NOTE: we can avoid explicit synchronization here for several reasons:
@@ -85,7 +85,7 @@ namespace Lucene.Net.Search
 					}
 					catch (System.Threading.ThreadInterruptedException ie)
 					{
-						SupportClass.ThreadClass.Current().Interrupt();
+						Support.ThreadClass.Current().Interrupt();
 						throw new System.SystemException(ie.Message, ie);
 					}
 				}

Modified: incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Store/CheckSumIndexInput.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Store/CheckSumIndexInput.cs?rev=1100459&r1=1100458&r2=1100459&view=diff
==============================================================================
--- incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Store/CheckSumIndexInput.cs (original)
+++ incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Store/CheckSumIndexInput.cs Sat May  7 06:22:20 2011
@@ -26,12 +26,12 @@ namespace Lucene.Net.Store
 	public class ChecksumIndexInput:IndexInput
 	{
 		internal IndexInput main;
-		internal SupportClass.Checksum digest;
+		internal Support.Checksum digest;
 		
 		public ChecksumIndexInput(IndexInput main)
 		{
 			this.main = main;
-            digest = new SupportClass.CRC32();
+            digest = new Support.CRC32();
 		}
 		
 		public override byte ReadByte()

Modified: incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Store/CheckSumIndexOutput.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Store/CheckSumIndexOutput.cs?rev=1100459&r1=1100458&r2=1100459&view=diff
==============================================================================
--- incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Store/CheckSumIndexOutput.cs (original)
+++ incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Store/CheckSumIndexOutput.cs Sat May  7 06:22:20 2011
@@ -17,8 +17,8 @@
 
 using System;
 
-using Checksum = SupportClass.Checksum;
-using CRC32 = SupportClass.CRC32;
+using Checksum = Lucene.Net.Support.Checksum;
+using CRC32 = Lucene.Net.Support.CRC32;
 
 namespace Lucene.Net.Store
 {

Modified: incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Store/FSDirectory.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Store/FSDirectory.cs?rev=1100459&r1=1100458&r2=1100459&view=diff
==============================================================================
--- incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Store/FSDirectory.cs (original)
+++ incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Store/FSDirectory.cs Sat May  7 06:22:20 2011
@@ -405,7 +405,7 @@ namespace Lucene.Net.Store
 		{
 			if (directory.Exists)
  			{
- 				System.String[] files = SupportClass.FileSupport.GetLuceneIndexFiles(directory.FullName, IndexFileNameFilter.GetFilter()); // clear old files
+ 				System.String[] files = Support.FileSupport.GetLuceneIndexFiles(directory.FullName, IndexFileNameFilter.GetFilter()); // clear old files
  				if (files == null)
  					throw new System.IO.IOException("cannot read directory " + directory.FullName + ": list() returned null");
  				for (int i = 0; i < files.Length; i++)
@@ -608,7 +608,7 @@ namespace Lucene.Net.Store
 				}
 				else
 				{
-					System.String lockClassName = SupportClass.AppSettings.Get("Lucene.Net.Store.FSDirectoryLockFactoryClass", "");
+					System.String lockClassName = Support.AppSettings.Get("Lucene.Net.Store.FSDirectoryLockFactoryClass", "");
 					
 					if (lockClassName != null && !lockClassName.Equals(""))
 					{
@@ -721,7 +721,7 @@ namespace Lucene.Net.Store
 		public override System.String[] List()
 		{
 			EnsureOpen();
-			return SupportClass.FileSupport.GetLuceneIndexFiles(directory.FullName, IndexFileNameFilter.GetFilter());
+			return Support.FileSupport.GetLuceneIndexFiles(directory.FullName, IndexFileNameFilter.GetFilter());
 		}
 		
 		/// <summary>Lists all files (not subdirectories) in the
@@ -838,7 +838,7 @@ namespace Lucene.Net.Store
 					try
 					{
                         file = new System.IO.FileStream(fullFile.FullName, System.IO.FileMode.OpenOrCreate, System.IO.FileAccess.Write, System.IO.FileShare.ReadWrite);
-                        SupportClass.FileSupport.Sync(file);
+                        Support.FileSupport.Sync(file);
                         success = true;
 					}
 					finally
@@ -860,7 +860,7 @@ namespace Lucene.Net.Store
 					{
 						// In 3.0 we will change this to throw
 						// InterruptedException instead
-						SupportClass.ThreadClass.Current().Interrupt();
+						Support.ThreadClass.Current().Interrupt();
                         throw new System.SystemException(ie.ToString(), ie);
 					}
 				}
@@ -1075,7 +1075,7 @@ namespace Lucene.Net.Store
 			{
 				try
 				{
-					System.String name = SupportClass.AppSettings.Get("Lucene.Net.FSDirectory.class", typeof(SimpleFSDirectory).FullName);
+					System.String name = Support.AppSettings.Get("Lucene.Net.FSDirectory.class", typeof(SimpleFSDirectory).FullName);
 					if (typeof(FSDirectory).FullName.Equals(name))
 					{
 						// FSDirectory will be abstract, so we replace it by the correct class
@@ -1098,7 +1098,7 @@ namespace Lucene.Net.Store
 			{
 				try
 				{
-					DIGESTER = SupportClass.Cryptography.GetHashAlgorithm();
+					DIGESTER = Support.Cryptography.GetHashAlgorithm();
 				}
 				catch (System.Exception e)
 				{

Modified: incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Store/IndexOutput.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Store/IndexOutput.cs?rev=1100459&r1=1100458&r2=1100459&view=diff
==============================================================================
--- incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Store/IndexOutput.cs (original)
+++ incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Store/IndexOutput.cs Sat May  7 06:22:20 2011
@@ -81,7 +81,7 @@ namespace Lucene.Net.Store
 			while ((i & ~ 0x7F) != 0)
 			{
 				WriteByte((byte) ((i & 0x7f) | 0x80));
-				i = SupportClass.Number.URShift(i, 7);
+				i = Support.Number.URShift(i, 7);
 			}
 			WriteByte((byte) i);
 		}
@@ -106,7 +106,7 @@ namespace Lucene.Net.Store
 			while ((i & ~ 0x7F) != 0)
 			{
 				WriteByte((byte) ((i & 0x7f) | 0x80));
-				i = SupportClass.Number.URShift(i, 7);
+				i = Support.Number.URShift(i, 7);
 			}
 			WriteByte((byte) i);
 		}
@@ -150,7 +150,7 @@ namespace Lucene.Net.Store
 				}
 				else
 				{
-					WriteByte((byte) (0xE0 | (SupportClass.Number.URShift(code, 12))));
+					WriteByte((byte) (0xE0 | (Support.Number.URShift(code, 12))));
 					WriteByte((byte) (0x80 | ((code >> 6) & 0x3F)));
 					WriteByte((byte) (0x80 | (code & 0x3F)));
 				}
@@ -184,7 +184,7 @@ namespace Lucene.Net.Store
 				}
 				else
 				{
-					WriteByte((byte) (0xE0 | (SupportClass.Number.URShift(code, 12))));
+					WriteByte((byte) (0xE0 | (Support.Number.URShift(code, 12))));
 					WriteByte((byte) (0x80 | ((code >> 6) & 0x3F)));
 					WriteByte((byte) (0x80 | (code & 0x3F)));
 				}

Modified: incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Store/Lock.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Store/Lock.cs?rev=1100459&r1=1100458&r2=1100459&view=diff
==============================================================================
--- incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Store/Lock.cs (original)
+++ incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Store/Lock.cs Sat May  7 06:22:20 2011
@@ -114,7 +114,7 @@ namespace Lucene.Net.Store
 				{
 					// In 3.0 we will change this to throw
 					// InterruptedException instead
-					SupportClass.ThreadClass.Current().Interrupt();
+					Support.ThreadClass.Current().Interrupt();
 					throw new System.IO.IOException(e.ToString());
 				}
 				locked = Obtain();

Modified: incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Store/NativeFSLockFactory.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Store/NativeFSLockFactory.cs?rev=1100459&r1=1100458&r2=1100459&view=diff
==============================================================================
--- incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Store/NativeFSLockFactory.cs (original)
+++ incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Store/NativeFSLockFactory.cs Sat May  7 06:22:20 2011
@@ -168,7 +168,7 @@ namespace Lucene.Net.Store
 		* one JVM (each with their own NativeFSLockFactory
 		* instance) have set the same lock dir and lock prefix.
 		*/
-        private static SupportClass.Set<string> LOCK_HELD = new SupportClass.Set<string>();
+        private static Support.Set<string> LOCK_HELD = new Support.Set<string>();
 
 		[System.Obsolete("Use the constructor that takes a DirectoryInfo, this will be removed in the 3.0 release")]
 		public NativeFSLock(System.IO.FileInfo lockDir, System.String lockFileName):this(new System.IO.DirectoryInfo(lockDir.FullName), lockFileName)

Modified: incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Store/RAMDirectory.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Store/RAMDirectory.cs?rev=1100459&r1=1100458&r2=1100459&view=diff
==============================================================================
--- incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Store/RAMDirectory.cs (original)
+++ incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Store/RAMDirectory.cs Sat May  7 06:22:20 2011
@@ -33,7 +33,7 @@ namespace Lucene.Net.Store
 		
 		private const long serialVersionUID = 1L;
 
-        internal protected SupportClass.Dictionary<string, RAMFile> fileMap = new SupportClass.Dictionary<string, RAMFile>();
+        internal protected Support.Dictionary<string, RAMFile> fileMap = new Support.Dictionary<string, RAMFile>();
 		internal protected long sizeInBytes = 0;
 		
 		// *****
@@ -187,7 +187,7 @@ namespace Lucene.Net.Store
 				{
 					// In 3.0 we will change this to throw
 					// InterruptedException instead
-					SupportClass.ThreadClass.Current().Interrupt();
+					Support.ThreadClass.Current().Interrupt();
 					throw new System.SystemException(ie.Message, ie);
 				}
 				ts2 = System.DateTime.Now.Ticks;

Modified: incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Store/SingleInstanceLockFactory.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Store/SingleInstanceLockFactory.cs?rev=1100459&r1=1100458&r2=1100459&view=diff
==============================================================================
--- incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Store/SingleInstanceLockFactory.cs (original)
+++ incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Store/SingleInstanceLockFactory.cs Sat May  7 06:22:20 2011
@@ -34,7 +34,7 @@ namespace Lucene.Net.Store
 	public class SingleInstanceLockFactory:LockFactory
 	{
 
-        private SupportClass.Set<string> locks = new SupportClass.Set<string>();
+        private Support.Set<string> locks = new Support.Set<string>();
 		
 		public override Lock MakeLock(System.String lockName)
 		{
@@ -61,9 +61,9 @@ namespace Lucene.Net.Store
 	{
 		
 		internal System.String lockName;
-        private SupportClass.Set<string> locks;
+        private Support.Set<string> locks;
 
-        public SingleInstanceLock(SupportClass.Set<string> locks, System.String lockName)
+        public SingleInstanceLock(Support.Set<string> locks, System.String lockName)
 		{
 			this.locks = locks;
 			this.lockName = lockName;

Added: incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Support/AppSettings.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Support/AppSettings.cs?rev=1100459&view=auto
==============================================================================
--- incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Support/AppSettings.cs (added)
+++ incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Support/AppSettings.cs Sat May  7 06:22:20 2011
@@ -0,0 +1,152 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ * 
+ * http://www.apache.org/licenses/LICENSE-2.0
+ * 
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+namespace Lucene.Net.Support
+{
+    /// <summary>
+    /// 
+    /// </summary>
+    public class AppSettings
+    {
+        static System.Collections.Specialized.ListDictionary settings = new System.Collections.Specialized.ListDictionary();
+
+        /// <summary>
+        /// 
+        /// </summary>
+        /// <param name="key"></param>
+        /// <param name="defValue"></param>
+        public static void Set(System.String key, int defValue)
+        {
+            settings[key] = defValue;
+        }
+
+        /// <summary>
+        /// 
+        /// </summary>
+        /// <param name="key"></param>
+        /// <param name="defValue"></param>
+        public static void Set(System.String key, long defValue)
+        {
+            settings[key] = defValue;
+        }
+
+        /// <summary>
+        /// 
+        /// </summary>
+        /// <param name="Key"></param>
+        /// <param name="Value"></param>
+        public static void Set(System.String key, System.String defValue)
+        {
+            settings[key] = defValue;
+        }
+
+        /// <summary>
+        /// 
+        /// </summary>
+        /// <param name="Key"></param>
+        /// <param name="Value"></param>
+        public static void Set(System.String key, bool defValue)
+        {
+            settings[key] = defValue;
+        }
+
+        /// <summary>
+        /// 
+        /// </summary>
+        /// <param name="key"></param>
+        /// <param name="defValue"></param>
+        /// <returns></returns>
+        public static int Get(System.String key, int defValue)
+        {
+            if (settings[key] != null)
+            {
+                return (int) settings[key];
+            }
+
+            System.String theValue = System.Configuration.ConfigurationManager.AppSettings.Get(key);
+            if (theValue == null)
+            {
+                return defValue;
+            }
+            int retValue = System.Convert.ToInt32(theValue.Trim());
+            settings[key] = retValue;
+            return retValue;
+        }
+
+        /// <summary>
+        /// 
+        /// </summary>
+        /// <param name="key"></param>
+        /// <param name="defValue"></param>
+        /// <returns></returns>
+        public static long Get(System.String key, long defValue)
+        {
+            if (settings[key] != null)
+            {
+                return (long) settings[key];
+            }
+
+            System.String theValue = System.Configuration.ConfigurationManager.AppSettings.Get(key);
+            if (theValue == null)
+            {
+                return defValue;
+            }
+            long retValue = System.Convert.ToInt64(theValue.Trim());
+            settings[key] = retValue;
+            return retValue;
+        }
+
+        /// <summary>
+        /// 
+        /// </summary>
+        /// <param name="key"></param>
+        /// <param name="defValue"></param>
+        /// <returns></returns>
+        public static System.String Get(System.String key, System.String defValue)
+        {
+            if (settings[key] != null)
+            {
+                return (System.String) settings[key];
+            }
+
+            System.String theValue = System.Configuration.ConfigurationManager.AppSettings.Get(key);
+            if (theValue == null)
+            {
+                return defValue;
+            }
+            settings[key] = theValue;
+            return theValue;
+        }
+
+        public static bool Get(System.String key, bool defValue)
+        {
+            if (settings[key] != null)
+            {
+                return (bool)settings[key];
+            }
+
+            System.String theValue = System.Configuration.ConfigurationManager.AppSettings.Get(key);
+            if (theValue == null)
+            {
+                return defValue;
+            }
+            bool retValue = System.Convert.ToBoolean(theValue.Trim());
+            settings[key] = retValue;
+            return retValue;
+        }
+    }
+}
\ No newline at end of file

Added: incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Support/AttributeImplItem.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Support/AttributeImplItem.cs?rev=1100459&view=auto
==============================================================================
--- incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Support/AttributeImplItem.cs (added)
+++ incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Support/AttributeImplItem.cs Sat May  7 06:22:20 2011
@@ -0,0 +1,37 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ * 
+ * http://www.apache.org/licenses/LICENSE-2.0
+ * 
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+using System;
+
+namespace Lucene.Net.Support
+{
+    /// <summary>
+    /// A simple wrapper to allow for the use of the GeneralKeyedCollection.  The
+    /// wrapper is required as there can be several keys for an object depending
+    /// on how many interfaces it implements.
+    /// </summary>
+    internal sealed class AttributeImplItem
+    {
+        internal AttributeImplItem(Type key, Lucene.Net.Util.AttributeImpl value)
+        {
+            this.Key = key;
+            this.Value = value;
+        }
+        internal Type Key;
+        internal Lucene.Net.Util.AttributeImpl Value;
+    }
+}
\ No newline at end of file

Added: incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Support/BitSetSupport.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Support/BitSetSupport.cs?rev=1100459&view=auto
==============================================================================
--- incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Support/BitSetSupport.cs (added)
+++ incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Support/BitSetSupport.cs Sat May  7 06:22:20 2011
@@ -0,0 +1,84 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ * 
+ * http://www.apache.org/licenses/LICENSE-2.0
+ * 
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+namespace Lucene.Net.Support
+{
+    /// <summary>
+    /// This class provides supporting methods of java.util.BitSet
+    /// that are not present in System.Collections.BitArray.
+    /// </summary>
+    public class BitSetSupport
+    {
+        /// <summary>
+        /// Returns the next set bit at or after index, or -1 if no such bit exists.
+        /// </summary>
+        /// <param name="bitArray"></param>
+        /// <param name="index">the index of bit array at which to start checking</param>
+        /// <returns>the next set bit or -1</returns>
+        public static int NextSetBit(System.Collections.BitArray bitArray, int index)
+        {
+            while (index < bitArray.Length)
+            {
+                // if index bit is set, return it
+                // otherwise check next index bit
+                if (bitArray.Get(index))
+                    return index;
+                else
+                    index++;
+            }
+            // if no bits are set at or after index, return -1
+            return -1;
+        }
+
+        /// <summary>
+        /// Returns the next un-set bit at or after index, or -1 if no such bit exists.
+        /// </summary>
+        /// <param name="bitArray"></param>
+        /// <param name="index">the index of bit array at which to start checking</param>
+        /// <returns>the next set bit or -1</returns>
+        public static int NextClearBit(System.Collections.BitArray bitArray, int index)
+        {
+            while (index < bitArray.Length)
+            {
+                // if index bit is not set, return it
+                // otherwise check next index bit
+                if (!bitArray.Get(index))
+                    return index;
+                else
+                    index++;
+            }
+            // if no bits are set at or after index, return -1
+            return -1;
+        }
+
+        /// <summary>
+        /// Returns the number of bits set to true in this BitSet.
+        /// </summary>
+        /// <param name="bits">The BitArray object.</param>
+        /// <returns>The number of bits set to true in this BitSet.</returns>
+        public static int Cardinality(System.Collections.BitArray bits)
+        {
+            int count = 0;
+            for (int i = 0; i < bits.Count; i++)
+            {
+                if (bits[i])
+                    count++;
+            }
+            return count;
+        }
+    }
+}
\ No newline at end of file

Added: incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Support/BuildType.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Support/BuildType.cs?rev=1100459&view=auto
==============================================================================
--- incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Support/BuildType.cs (added)
+++ incubator/lucene.net/branches/Lucene.Net_2_9_4g/src/core/Support/BuildType.cs Sat May  7 06:22:20 2011
@@ -0,0 +1,28 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ * 
+ * http://www.apache.org/licenses/LICENSE-2.0
+ * 
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+namespace Lucene.Net.Support
+{
+    public class BuildType
+    {
+#if DEBUG
+        public static bool Debug = true;
+#else
+        public static bool Debug = false;
+#endif
+    }
+}
\ No newline at end of file