You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@lucenenet.apache.org by cc...@apache.org on 2012/03/13 21:32:49 UTC

svn commit: r1300340 [4/6] - in /incubator/lucene.net/trunk: branding/logo/ build/vs2010/test/ src/contrib/Analyzers/ src/contrib/Analyzers/Compound/ src/contrib/Analyzers/El/ src/contrib/Analyzers/Fa/ src/contrib/Analyzers/Miscellaneous/ src/contrib/A...

Modified: incubator/lucene.net/trunk/test/contrib/Analyzers/Ru/TestRussianAnalyzer.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/trunk/test/contrib/Analyzers/Ru/TestRussianAnalyzer.cs?rev=1300340&r1=1300339&r2=1300340&view=diff
==============================================================================
--- incubator/lucene.net/trunk/test/contrib/Analyzers/Ru/TestRussianAnalyzer.cs (original)
+++ incubator/lucene.net/trunk/test/contrib/Analyzers/Ru/TestRussianAnalyzer.cs Tue Mar 13 20:32:43 2012
@@ -1,4 +1,25 @@
-using System;
+/*
+ *
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ *
+*/
+
+using System;
 using System.Collections.Generic;
 using System.IO;
 using System.Linq;
@@ -18,13 +39,12 @@ namespace Lucene.Net.Analyzers.Ru
     public class TestRussianAnalyzer : BaseTokenStreamTestCase
     {
         private StreamReader inWords;
-
         private StreamReader sampleUnicode;
 
-        protected void setUp()
-        {
-            base.SetUp();
-        }
+        //protected override void SetUp()
+        //{
+        //    base.SetUp();
+        //}
 
         [Test]
         public void TestUnicode()
@@ -32,7 +52,7 @@ namespace Lucene.Net.Analyzers.Ru
             RussianAnalyzer ra = new RussianAnalyzer(Version.LUCENE_CURRENT);
 
             using (inWords = new StreamReader(@"ru\testUTF8.txt", Encoding.UTF8))
-            using (sampleUnicode = new StreamReader(@"ru\resUTF8.htm", Encoding.UTF8))
+            using (sampleUnicode = new StreamReader(@"ru\resUTF8.txt", Encoding.UTF8))
             {
 
                 TokenStream _in = ra.TokenStream("all", inWords);

Modified: incubator/lucene.net/trunk/test/contrib/Analyzers/Ru/TestRussianStem.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/trunk/test/contrib/Analyzers/Ru/TestRussianStem.cs?rev=1300340&r1=1300339&r2=1300340&view=diff
==============================================================================
--- incubator/lucene.net/trunk/test/contrib/Analyzers/Ru/TestRussianStem.cs (original)
+++ incubator/lucene.net/trunk/test/contrib/Analyzers/Ru/TestRussianStem.cs Tue Mar 13 20:32:43 2012
@@ -1,4 +1,25 @@
-using System;
+/*
+ *
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ *
+*/
+
+using System;
 using System.Collections.Generic;
 using System.IO;
 using System.Linq;
@@ -53,4 +74,4 @@ namespace Lucene.Net.Analyzers.Ru
             }
         }
     }
-}
\ No newline at end of file
+}

Added: incubator/lucene.net/trunk/test/contrib/Analyzers/Ru/resUTF8.txt
URL: http://svn.apache.org/viewvc/incubator/lucene.net/trunk/test/contrib/Analyzers/Ru/resUTF8.txt?rev=1300340&view=auto
==============================================================================
--- incubator/lucene.net/trunk/test/contrib/Analyzers/Ru/resUTF8.txt (added)
+++ incubator/lucene.net/trunk/test/contrib/Analyzers/Ru/resUTF8.txt Tue Mar 13 20:32:43 2012
@@ -0,0 +1 @@
+[вмест][сил][электромагнитн][энерг][имел][представлен][скаж][жрец][древн][египт][знан][хран][тайн][узк][круг][посвящен][всяк][времен][виток][прин][соб][нов][технолог][сам][дел][раскрыва][потаен][знан][прежн][век][говор][нов][информац][станов][доступн][широк][круг][пользовател][тех][случа][сознан][обществ][гото
 в][восприня][воспользова]

Modified: incubator/lucene.net/trunk/test/contrib/Analyzers/Shingle/ShingleAnalyzerWrapperTest.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/trunk/test/contrib/Analyzers/Shingle/ShingleAnalyzerWrapperTest.cs?rev=1300340&r1=1300339&r2=1300340&view=diff
==============================================================================
--- incubator/lucene.net/trunk/test/contrib/Analyzers/Shingle/ShingleAnalyzerWrapperTest.cs (original)
+++ incubator/lucene.net/trunk/test/contrib/Analyzers/Shingle/ShingleAnalyzerWrapperTest.cs Tue Mar 13 20:32:43 2012
@@ -82,7 +82,7 @@ namespace Lucene.Net.Analyzers.Shingle
             Assert.AreEqual(ranks.Length, hits.Length);
             for (int i = 0; i < ranks.Length; i++)
             {
-                Assert.AreEqual(ranks[i], hits[i].doc);
+                Assert.AreEqual(ranks[i], hits[i].Doc);
             }
         }
 
@@ -153,7 +153,7 @@ namespace Lucene.Net.Analyzers.Shingle
 
             while (ts.IncrementToken())
             {
-                j += posIncrAtt.GetPositionIncrement();
+                j += posIncrAtt.PositionIncrement;
                 var termText = termAtt.Term();
                 q.Add(new Term("content", termText), j);
             }

Modified: incubator/lucene.net/trunk/test/contrib/Analyzers/Shingle/ShingleFilterTest.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/trunk/test/contrib/Analyzers/Shingle/ShingleFilterTest.cs?rev=1300340&r1=1300339&r2=1300340&view=diff
==============================================================================
--- incubator/lucene.net/trunk/test/contrib/Analyzers/Shingle/ShingleFilterTest.cs (original)
+++ incubator/lucene.net/trunk/test/contrib/Analyzers/Shingle/ShingleFilterTest.cs Tue Mar 13 20:32:43 2012
@@ -303,8 +303,8 @@ namespace Lucene.Net.Analyzers.Shingle
                                          CreateToken("shingles", 33, 39),
                                      };
 
-            TestTokenWithHoles[2].SetPositionIncrement(2);
-            TestTokenWithHoles[3].SetPositionIncrement(2);
+            TestTokenWithHoles[2].PositionIncrement = 2;
+            TestTokenWithHoles[3].PositionIncrement = 2;
         }
 
 
@@ -474,7 +474,7 @@ namespace Lucene.Net.Analyzers.Shingle
                                 "Wrong startOffset for token \"" + termText + "\"");
                 Assert.AreEqual(tokensToCompare[i].EndOffset(), offsetAtt.EndOffset(),
                                 "Wrong endOffset for token \"" + termText + "\"");
-                Assert.AreEqual(positionIncrements[i], posIncrAtt.GetPositionIncrement(),
+                Assert.AreEqual(positionIncrements[i], posIncrAtt.PositionIncrement,
                                 "Wrong positionIncrement for token \"" + termText + "\"");
                 Assert.AreEqual(types[i], typeAtt.Type(), "Wrong type for token \"" + termText + "\"");
 
@@ -518,7 +518,7 @@ namespace Lucene.Net.Analyzers.Shingle
 
                 _termAtt.SetTermBuffer(t.TermBuffer(), 0, t.TermLength());
                 _offsetAtt.SetOffset(t.StartOffset(), t.EndOffset());
-                _posIncrAtt.SetPositionIncrement(t.GetPositionIncrement());
+                _posIncrAtt.PositionIncrement = t.PositionIncrement;
                 _typeAtt.SetType(TypeAttributeImpl.DEFAULT_TYPE);
 
                 return true;

Modified: incubator/lucene.net/trunk/test/contrib/Analyzers/Shingle/TestShingleMatrixFilter.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/trunk/test/contrib/Analyzers/Shingle/TestShingleMatrixFilter.cs?rev=1300340&r1=1300339&r2=1300340&view=diff
==============================================================================
--- incubator/lucene.net/trunk/test/contrib/Analyzers/Shingle/TestShingleMatrixFilter.cs (original)
+++ incubator/lucene.net/trunk/test/contrib/Analyzers/Shingle/TestShingleMatrixFilter.cs Tue Mar 13 20:32:43 2012
@@ -441,7 +441,7 @@ namespace Lucene.Net.Analyzers.Shingle
         {
             Token token = new Token(startOffset, endOffset);
             token.SetTermBuffer(text);
-            token.SetPositionIncrement(posIncr);
+            token.PositionIncrement = posIncr;
             return token;
         }
 
@@ -459,7 +459,7 @@ namespace Lucene.Net.Analyzers.Shingle
         {
             Token token = new Token(startOffset, endOffset);
             token.SetTermBuffer(text);
-            token.SetPositionIncrement(posIncr);
+            token.PositionIncrement = posIncr;
             ShingleMatrixFilter.DefaultSettingsCodec.SetWeight(token, weight);
             return token;
         }
@@ -468,7 +468,7 @@ namespace Lucene.Net.Analyzers.Shingle
         {
             Token token = new Token(startOffset, endOffset);
             token.SetTermBuffer(text);
-            token.SetPositionIncrement(posIncr);
+            token.PositionIncrement = posIncr;
             ShingleMatrixFilter.DefaultSettingsCodec.SetWeight(token, weight);
             ShingleMatrixFilter.DefaultSettingsCodec.SetTokenPositioner(token, positioner);
             return token;
@@ -494,11 +494,11 @@ namespace Lucene.Net.Analyzers.Shingle
 
             Assert.IsTrue(ts.IncrementToken());
             Assert.AreEqual(text, termAtt.Term());
-            Assert.AreEqual(positionIncrement, posIncrAtt.GetPositionIncrement());
+            Assert.AreEqual(positionIncrement, posIncrAtt.PositionIncrement);
             Assert.AreEqual(boost,
-                            payloadAtt.GetPayload() == null
+                            payloadAtt.Payload == null
                                 ? 1f
-                                : PayloadHelper.DecodeFloat(payloadAtt.GetPayload().GetData()), 0);
+                                : PayloadHelper.DecodeFloat(payloadAtt.Payload.GetData()), 0);
             Assert.AreEqual(startOffset, offsetAtt.StartOffset());
             Assert.AreEqual(endOffset, offsetAtt.EndOffset());
         }
@@ -559,11 +559,11 @@ namespace Lucene.Net.Analyzers.Shingle
                 ClearAttributes();
 
                 _termAtt.SetTermBuffer(prototype.TermBuffer(), 0, prototype.TermLength());
-                _posIncrAtt.SetPositionIncrement(prototype.GetPositionIncrement());
-                _flagsAtt.SetFlags(prototype.GetFlags());
+                _posIncrAtt.PositionIncrement = prototype.PositionIncrement;
+                _flagsAtt.Flags = prototype.Flags;
                 _offsetAtt.SetOffset(prototype.StartOffset(), prototype.EndOffset());
                 _typeAtt.SetType(prototype.Type());
-                _payloadAtt.SetPayload(prototype.GetPayload());
+                _payloadAtt.Payload = prototype.Payload;
 
                 return true;
             }

Modified: incubator/lucene.net/trunk/test/contrib/Analyzers/Sinks/DateRecognizerSinkTokenizerTest.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/trunk/test/contrib/Analyzers/Sinks/DateRecognizerSinkTokenizerTest.cs?rev=1300340&r1=1300339&r2=1300340&view=diff
==============================================================================
--- incubator/lucene.net/trunk/test/contrib/Analyzers/Sinks/DateRecognizerSinkTokenizerTest.cs (original)
+++ incubator/lucene.net/trunk/test/contrib/Analyzers/Sinks/DateRecognizerSinkTokenizerTest.cs Tue Mar 13 20:32:43 2012
@@ -1,4 +1,25 @@
-using System;
+/*
+ *
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ *
+*/
+
+using System;
 using System.Collections.Generic;
 using System.IO;
 using System.Linq;

Modified: incubator/lucene.net/trunk/test/contrib/Analyzers/Sinks/TokenRangeSinkTokenizerTest.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/trunk/test/contrib/Analyzers/Sinks/TokenRangeSinkTokenizerTest.cs?rev=1300340&r1=1300339&r2=1300340&view=diff
==============================================================================
--- incubator/lucene.net/trunk/test/contrib/Analyzers/Sinks/TokenRangeSinkTokenizerTest.cs (original)
+++ incubator/lucene.net/trunk/test/contrib/Analyzers/Sinks/TokenRangeSinkTokenizerTest.cs Tue Mar 13 20:32:43 2012
@@ -1,4 +1,25 @@
-using System;
+/*
+ *
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ *
+*/
+
+using System;
 using System.Collections.Generic;
 using System.IO;
 using System.Linq;
@@ -38,4 +59,4 @@ namespace Lucene.Net.Analyzers.Sinks
             Assert.True(sinkCount == 2, "rangeToks Size: " + sinkCount + " is not: " + 2);
         }
     }
-}
\ No newline at end of file
+}

Modified: incubator/lucene.net/trunk/test/contrib/Analyzers/Sinks/TokenTypeSinkTokenizerTest.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/trunk/test/contrib/Analyzers/Sinks/TokenTypeSinkTokenizerTest.cs?rev=1300340&r1=1300339&r2=1300340&view=diff
==============================================================================
--- incubator/lucene.net/trunk/test/contrib/Analyzers/Sinks/TokenTypeSinkTokenizerTest.cs (original)
+++ incubator/lucene.net/trunk/test/contrib/Analyzers/Sinks/TokenTypeSinkTokenizerTest.cs Tue Mar 13 20:32:43 2012
@@ -1,4 +1,25 @@
-using System;
+/*
+ *
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ *
+*/
+
+using System;
 using System.Collections.Generic;
 using System.IO;
 using System.Linq;
@@ -75,4 +96,4 @@ namespace Lucene.Net.Analyzers.Sinks
             }
         }
     }
-}
\ No newline at end of file
+}

Modified: incubator/lucene.net/trunk/test/contrib/Analyzers/Th/TestThaiAnalyzer.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/trunk/test/contrib/Analyzers/Th/TestThaiAnalyzer.cs?rev=1300340&r1=1300339&r2=1300340&view=diff
==============================================================================
--- incubator/lucene.net/trunk/test/contrib/Analyzers/Th/TestThaiAnalyzer.cs (original)
+++ incubator/lucene.net/trunk/test/contrib/Analyzers/Th/TestThaiAnalyzer.cs Tue Mar 13 20:32:43 2012
@@ -1,4 +1,25 @@
-using System;
+/*
+ *
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ *
+*/
+
+using System;
 using System.Collections.Generic;
 using System.Linq;
 using System.Text;

Modified: incubator/lucene.net/trunk/test/contrib/Core/Analysis/Ext/Analysis.Ext.Test.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/trunk/test/contrib/Core/Analysis/Ext/Analysis.Ext.Test.cs?rev=1300340&r1=1300339&r2=1300340&view=diff
==============================================================================
Files incubator/lucene.net/trunk/test/contrib/Core/Analysis/Ext/Analysis.Ext.Test.cs (original) and incubator/lucene.net/trunk/test/contrib/Core/Analysis/Ext/Analysis.Ext.Test.cs Tue Mar 13 20:32:43 2012 differ

Modified: incubator/lucene.net/trunk/test/contrib/Core/Index/SegmentsGenCommitTest.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/trunk/test/contrib/Core/Index/SegmentsGenCommitTest.cs?rev=1300340&r1=1300339&r2=1300340&view=diff
==============================================================================
--- incubator/lucene.net/trunk/test/contrib/Core/Index/SegmentsGenCommitTest.cs (original)
+++ incubator/lucene.net/trunk/test/contrib/Core/Index/SegmentsGenCommitTest.cs Tue Mar 13 20:32:43 2012
@@ -78,13 +78,13 @@ namespace Lucene.Net.Test.Index
         {
             // check the generation in the directory
             IndexReader reader = IndexReader.Open(this.directory, true);
-            IndexCommit commit = reader.GetIndexCommit();
+            IndexCommit commit = reader.IndexCommit;
 
             // create a SegmentsGenCommit
             SegmentsGenCommit sgCommit = new SegmentsGenCommit(this.directory);
 
-            Assert.AreEqual(commit.GetGeneration(), sgCommit.GetGeneration());
-            Assert.AreEqual(commit.GetSegmentsFileName(), sgCommit.GetSegmentsFileName());
+            Assert.AreEqual(commit.Generation, sgCommit.Generation);
+            Assert.AreEqual(commit.SegmentsFileName, sgCommit.SegmentsFileName);
         }
 
         [Test]
@@ -92,12 +92,12 @@ namespace Lucene.Net.Test.Index
         {
             SegmentsGenCommit sgCommit = new SegmentsGenCommit(this.directory);
             IndexWriter writer = new IndexWriter(this.directory, new WhitespaceAnalyzer(), null, IndexWriter.MaxFieldLength.UNLIMITED, sgCommit);
-            Assert.AreEqual(10, writer.MaxDoc());
+            Assert.AreEqual(10, writer.MaxDoc);
             IndexReader reader = writer.GetReader();
 
-            IndexCommit commit = reader.GetIndexCommit();
-            Assert.AreEqual(commit.GetGeneration(), sgCommit.GetGeneration());
-            Assert.AreEqual(commit.GetSegmentsFileName(), sgCommit.GetSegmentsFileName());
+            IndexCommit commit = reader.IndexCommit;
+            Assert.AreEqual(commit.Generation, sgCommit.Generation);
+            Assert.AreEqual(commit.SegmentsFileName, sgCommit.SegmentsFileName);
         }
     }
 }

Modified: incubator/lucene.net/trunk/test/contrib/Core/Util/Cache/SegmentCacheTest.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/trunk/test/contrib/Core/Util/Cache/SegmentCacheTest.cs?rev=1300340&r1=1300339&r2=1300340&view=diff
==============================================================================
--- incubator/lucene.net/trunk/test/contrib/Core/Util/Cache/SegmentCacheTest.cs (original)
+++ incubator/lucene.net/trunk/test/contrib/Core/Util/Cache/SegmentCacheTest.cs Tue Mar 13 20:32:43 2012
@@ -116,7 +116,7 @@ namespace Lucene.Net.Test.Util.Cache
             // add items to the existing index
             this.AddItemsToIndex(this.directory);
             IndexReader newReader = IndexReader.Open(this.directory, true);
-            Assert.AreEqual(20, newReader.NumDocs());
+            Assert.AreEqual(20, newReader.NumDocs);
 
             // test the cache, the old item from the class reader should still be there
             t = MockCache.Instance.Get(newReader, "Cached");

Modified: incubator/lucene.net/trunk/test/contrib/FastVectorHighlighter/AbstractTestCase.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/trunk/test/contrib/FastVectorHighlighter/AbstractTestCase.cs?rev=1300340&r1=1300339&r2=1300340&view=diff
==============================================================================
--- incubator/lucene.net/trunk/test/contrib/FastVectorHighlighter/AbstractTestCase.cs (original)
+++ incubator/lucene.net/trunk/test/contrib/FastVectorHighlighter/AbstractTestCase.cs Tue Mar 13 20:32:43 2012
@@ -110,7 +110,7 @@ namespace Lucene.Net.Search.Vectorhighli
         protected Query Tq(float boost, String field, String text)
         {
             Query query = new TermQuery(new Term(field, text));
-            query.SetBoost(boost);
+            query.Boost = boost;
             return query;
         }
 
@@ -151,8 +151,8 @@ namespace Lucene.Net.Search.Vectorhighli
             {
                 query.Add(new Term(field, text));
             }
-            query.SetBoost(boost);
-            query.SetSlop(slop);
+            query.Boost = boost;
+            query.Slop = slop;
             return query;
         }
 

Modified: incubator/lucene.net/trunk/test/contrib/FastVectorHighlighter/IndexTimeSynonymTest.cs
URL: http://svn.apache.org/viewvc/incubator/lucene.net/trunk/test/contrib/FastVectorHighlighter/IndexTimeSynonymTest.cs?rev=1300340&r1=1300339&r2=1300340&view=diff
==============================================================================
--- incubator/lucene.net/trunk/test/contrib/FastVectorHighlighter/IndexTimeSynonymTest.cs (original)
+++ incubator/lucene.net/trunk/test/contrib/FastVectorHighlighter/IndexTimeSynonymTest.cs Tue Mar 13 20:32:43 2012
@@ -331,7 +331,7 @@ namespace Lucene.Net.Search.Vectorhighli
         public static Token t(String text, int startOffset, int endOffset, int positionIncrement)
         {
             Token token = new Token(text, startOffset, endOffset);
-            token.SetPositionIncrement(positionIncrement);
+            token.PositionIncrement = positionIncrement;
             return token;
         }