You are viewing a plain text version of this content. The canonical link for it is here.
Posted to jetspeed-dev@portals.apache.org by wo...@apache.org on 2011/03/29 05:12:31 UTC

svn commit: r1086467 [1/2] - in /portals/jetspeed-2/portal/trunk/components/jetspeed-search: ./ src/main/java/org/apache/jetspeed/search/ src/main/java/org/apache/jetspeed/search/lucene/ src/main/java/org/apache/jetspeed/search/solr/ src/test/java/org/...

Author: woonsan
Date: Tue Mar 29 03:12:30 2011
New Revision: 1086467

URL: http://svn.apache.org/viewvc?rev=1086467&view=rev
Log:
JS2-1246: Adding solr search engine impl with embedded test env
TODO: Fix unit test

Added:
    portals/jetspeed-2/portal/trunk/components/jetspeed-search/src/main/java/org/apache/jetspeed/search/SearchResultsImpl.java
      - copied, changed from r1086461, portals/jetspeed-2/portal/trunk/components/jetspeed-search/src/main/java/org/apache/jetspeed/search/lucene/SearchResultsImpl.java
    portals/jetspeed-2/portal/trunk/components/jetspeed-search/src/main/java/org/apache/jetspeed/search/solr/
    portals/jetspeed-2/portal/trunk/components/jetspeed-search/src/main/java/org/apache/jetspeed/search/solr/SolrSearchEngineImpl.java
    portals/jetspeed-2/portal/trunk/components/jetspeed-search/src/test/java/org/apache/jetspeed/search/solr/
    portals/jetspeed-2/portal/trunk/components/jetspeed-search/src/test/java/org/apache/jetspeed/search/solr/TestSolrPortletRegistrySearch.java
    portals/jetspeed-2/portal/trunk/components/jetspeed-search/src/test/resources/conf/
    portals/jetspeed-2/portal/trunk/components/jetspeed-search/src/test/resources/conf/admin-extra.html
    portals/jetspeed-2/portal/trunk/components/jetspeed-search/src/test/resources/conf/elevate.xml
    portals/jetspeed-2/portal/trunk/components/jetspeed-search/src/test/resources/conf/mapping-ISOLatin1Accent.txt
    portals/jetspeed-2/portal/trunk/components/jetspeed-search/src/test/resources/conf/protwords.txt
    portals/jetspeed-2/portal/trunk/components/jetspeed-search/src/test/resources/conf/schema.xml
    portals/jetspeed-2/portal/trunk/components/jetspeed-search/src/test/resources/conf/scripts.conf
    portals/jetspeed-2/portal/trunk/components/jetspeed-search/src/test/resources/conf/solrconfig.xml
    portals/jetspeed-2/portal/trunk/components/jetspeed-search/src/test/resources/conf/spellings.txt
    portals/jetspeed-2/portal/trunk/components/jetspeed-search/src/test/resources/conf/stopwords.txt
    portals/jetspeed-2/portal/trunk/components/jetspeed-search/src/test/resources/conf/synonyms.txt
    portals/jetspeed-2/portal/trunk/components/jetspeed-search/src/test/resources/conf/xslt/
    portals/jetspeed-2/portal/trunk/components/jetspeed-search/src/test/resources/conf/xslt/example.xsl
    portals/jetspeed-2/portal/trunk/components/jetspeed-search/src/test/resources/conf/xslt/example_atom.xsl
    portals/jetspeed-2/portal/trunk/components/jetspeed-search/src/test/resources/conf/xslt/example_rss.xsl
    portals/jetspeed-2/portal/trunk/components/jetspeed-search/src/test/resources/conf/xslt/luke.xsl
Removed:
    portals/jetspeed-2/portal/trunk/components/jetspeed-search/src/main/java/org/apache/jetspeed/search/lucene/SearchResultsImpl.java
Modified:
    portals/jetspeed-2/portal/trunk/components/jetspeed-search/pom.xml
    portals/jetspeed-2/portal/trunk/components/jetspeed-search/src/main/java/org/apache/jetspeed/search/lucene/SearchEngineImpl.java

Modified: portals/jetspeed-2/portal/trunk/components/jetspeed-search/pom.xml
URL: http://svn.apache.org/viewvc/portals/jetspeed-2/portal/trunk/components/jetspeed-search/pom.xml?rev=1086467&r1=1086466&r2=1086467&view=diff
==============================================================================
--- portals/jetspeed-2/portal/trunk/components/jetspeed-search/pom.xml (original)
+++ portals/jetspeed-2/portal/trunk/components/jetspeed-search/pom.xml Tue Mar 29 03:12:30 2011
@@ -97,4 +97,18 @@
     
   </dependencies>
 
+  <build>
+    <plugins>
+      <plugin>
+        <groupId>org.apache.maven.plugins</groupId>
+        <artifactId>maven-surefire-plugin</artifactId>
+        <configuration>
+          <excludes>
+            <exclude>**/TestSolrPortletRegistrySearch.java</exclude>
+          </excludes>
+        </configuration>
+      </plugin>
+    </plugins>
+  </build>
+
 </project>

Copied: portals/jetspeed-2/portal/trunk/components/jetspeed-search/src/main/java/org/apache/jetspeed/search/SearchResultsImpl.java (from r1086461, portals/jetspeed-2/portal/trunk/components/jetspeed-search/src/main/java/org/apache/jetspeed/search/lucene/SearchResultsImpl.java)
URL: http://svn.apache.org/viewvc/portals/jetspeed-2/portal/trunk/components/jetspeed-search/src/main/java/org/apache/jetspeed/search/SearchResultsImpl.java?p2=portals/jetspeed-2/portal/trunk/components/jetspeed-search/src/main/java/org/apache/jetspeed/search/SearchResultsImpl.java&p1=portals/jetspeed-2/portal/trunk/components/jetspeed-search/src/main/java/org/apache/jetspeed/search/lucene/SearchResultsImpl.java&r1=1086461&r2=1086467&rev=1086467&view=diff
==============================================================================
--- portals/jetspeed-2/portal/trunk/components/jetspeed-search/src/main/java/org/apache/jetspeed/search/lucene/SearchResultsImpl.java (original)
+++ portals/jetspeed-2/portal/trunk/components/jetspeed-search/src/main/java/org/apache/jetspeed/search/SearchResultsImpl.java Tue Mar 29 03:12:30 2011
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.jetspeed.search.lucene;
+package org.apache.jetspeed.search;
 
 import java.util.Iterator;
 import java.util.List;

Modified: portals/jetspeed-2/portal/trunk/components/jetspeed-search/src/main/java/org/apache/jetspeed/search/lucene/SearchEngineImpl.java
URL: http://svn.apache.org/viewvc/portals/jetspeed-2/portal/trunk/components/jetspeed-search/src/main/java/org/apache/jetspeed/search/lucene/SearchEngineImpl.java?rev=1086467&r1=1086466&r2=1086467&view=diff
==============================================================================
--- portals/jetspeed-2/portal/trunk/components/jetspeed-search/src/main/java/org/apache/jetspeed/search/lucene/SearchEngineImpl.java (original)
+++ portals/jetspeed-2/portal/trunk/components/jetspeed-search/src/main/java/org/apache/jetspeed/search/lucene/SearchEngineImpl.java Tue Mar 29 03:12:30 2011
@@ -36,6 +36,7 @@ import org.apache.jetspeed.search.Object
 import org.apache.jetspeed.search.ParsedObject;
 import org.apache.jetspeed.search.SearchEngine;
 import org.apache.jetspeed.search.SearchResults;
+import org.apache.jetspeed.search.SearchResultsImpl;
 import org.apache.lucene.analysis.Analyzer;
 import org.apache.lucene.analysis.standard.StandardAnalyzer;
 import org.apache.lucene.document.Document;

Added: portals/jetspeed-2/portal/trunk/components/jetspeed-search/src/main/java/org/apache/jetspeed/search/solr/SolrSearchEngineImpl.java
URL: http://svn.apache.org/viewvc/portals/jetspeed-2/portal/trunk/components/jetspeed-search/src/main/java/org/apache/jetspeed/search/solr/SolrSearchEngineImpl.java?rev=1086467&view=auto
==============================================================================
--- portals/jetspeed-2/portal/trunk/components/jetspeed-search/src/main/java/org/apache/jetspeed/search/solr/SolrSearchEngineImpl.java (added)
+++ portals/jetspeed-2/portal/trunk/components/jetspeed-search/src/main/java/org/apache/jetspeed/search/solr/SolrSearchEngineImpl.java Tue Mar 29 03:12:30 2011
@@ -0,0 +1,520 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ * 
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ * 
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package org.apache.jetspeed.search.solr;
+
+import java.io.IOException;
+import java.net.URL;
+import java.util.ArrayList;
+import java.util.Collection;
+import java.util.HashMap;
+import java.util.Iterator;
+import java.util.List;
+import java.util.Map;
+import java.util.Set;
+
+import org.apache.commons.collections.MultiMap;
+import org.apache.commons.collections.map.MultiValueMap;
+import org.apache.commons.lang.StringUtils;
+import org.apache.jetspeed.search.BaseParsedObject;
+import org.apache.jetspeed.search.HandlerFactory;
+import org.apache.jetspeed.search.ObjectHandler;
+import org.apache.jetspeed.search.ParsedObject;
+import org.apache.jetspeed.search.SearchEngine;
+import org.apache.jetspeed.search.SearchResults;
+import org.apache.jetspeed.search.SearchResultsImpl;
+import org.apache.solr.client.solrj.SolrQuery;
+import org.apache.solr.client.solrj.SolrServer;
+import org.apache.solr.client.solrj.response.QueryResponse;
+import org.apache.solr.client.solrj.response.UpdateResponse;
+import org.apache.solr.common.SolrDocument;
+import org.apache.solr.common.SolrDocumentList;
+import org.apache.solr.common.SolrInputDocument;
+import org.apache.solr.common.SolrInputField;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
+
+/**
+ * @version $Id: SolrSearchEngineImpl.java 1086464 2011-03-29 02:08:39Z woonsan $
+ */
+public class SolrSearchEngineImpl implements SearchEngine
+{
+    private final static Logger log = LoggerFactory.getLogger(SolrSearchEngineImpl.class);
+
+    private SolrServer server;
+    private boolean optimizeAfterUpdate = true;
+    private HandlerFactory handlerFactory;
+    
+    public SolrSearchEngineImpl(SolrServer server, boolean optimzeAfterUpdate, HandlerFactory handlerFactory)
+    {
+        this.server = server;
+        this.optimizeAfterUpdate = optimzeAfterUpdate;
+        this.handlerFactory = handlerFactory;
+    }
+    
+    /* (non-Javadoc)
+     * @see org.apache.jetspeed.search.SearchEnging#add(java.lang.Object)
+     */
+    public boolean add(Object o)
+    {
+        Collection c = new ArrayList(1);
+        c.add(o);
+
+        return add(c);
+    }
+
+    /* (non-Javadoc)
+     * @see org.apache.jetspeed.search.SearchEnging#add(java.util.Collection)
+     */
+    public boolean add(Collection objects)
+    {
+        return removeIfExistsAndAdd(objects);
+    }
+
+    /* (non-Javadoc)
+     * @see org.apache.jetspeed.search.SearchEnging#remove(java.lang.Object)
+     */
+    public boolean remove(Object o)
+    {
+        Collection c = new ArrayList(1);
+        c.add(o);
+
+        return remove(c);
+    }
+
+    /* (non-Javadoc)
+     * @see org.apache.jetspeed.search.SearchEnging#remove(java.util.Collection)
+     */
+    public synchronized boolean remove(Collection objects)
+    {
+        int deleteCount = 0;
+        
+        try 
+        {
+            Iterator it = objects.iterator();
+            while (it.hasNext()) 
+            {
+                Object o = it.next();
+                // Look up appropriate handler
+                ObjectHandler handler = handlerFactory.getHandler(o);
+
+                // Parse the object
+                ParsedObject parsedObject = handler.parseObject(o);
+
+                if (parsedObject.getKey() != null)
+                {
+                    String queryString = new StringBuilder(40).append(ParsedObject.FIELDNAME_KEY).append(':').append(parsedObject.getKey()).toString();
+                    // Remove the document from search index
+                    UpdateResponse rsp = server.deleteByQuery(queryString);
+                    deleteCount += rsp.getResponse().size();
+                }
+            }
+            
+            if (deleteCount > 0 && optimizeAfterUpdate)
+            {
+                server.optimize();
+            }
+        }
+        catch (Exception e)
+        {
+            log.error("Exception during removing documents in the search index.", e);
+        }
+
+        return deleteCount > 0;
+    }
+
+    /* (non-Javadoc)
+     * @see org.apache.jetspeed.search.SearchEnging#update(java.lang.Object)
+     */
+    public boolean update(Object o)
+    {
+        Collection c = new ArrayList(1);
+        c.add(o);
+        
+        return update(c);
+    }
+
+    /* (non-Javadoc)
+     * @see org.apache.jetspeed.search.SearchEnging#update(java.util.Collection)
+     */
+    public boolean update(Collection objects)
+    {
+        return removeIfExistsAndAdd(objects);
+    }
+
+    /* (non-Javadoc)
+     * @see org.apache.jetspeed.search.SearchEngine#search(java.lang.String)
+     */
+    public SearchResults search(String queryString)
+    {
+        return search(queryString, ParsedObject.FIELDNAME_SYNTHETIC);
+    }
+    
+    /* (non-Javadoc)
+     * @see org.apache.jetspeed.search.SearchEngine#search(java.lang.String, java.lang.String)
+     */
+    public SearchResults search(String queryString, String defaultFieldName)
+    {
+        return search(queryString, defaultFieldName, 0);
+    }
+    
+    /* (non-Javadoc)
+     * @see org.apache.jetspeed.search.SearchEngine#search(java.lang.String, java.lang.String, int)
+     */
+    public SearchResults search(String queryString, String defaultFieldName, int topHitsCount)
+    {
+        SearchResults results = null;
+        
+        try
+        {
+            SolrQuery query = new SolrQuery();
+            query.setQuery(queryString);
+            QueryResponse rsp = server.query(query);
+            SolrDocumentList docList = rsp.getResults();
+            List<ParsedObject> resultList = new ArrayList<ParsedObject>();
+            
+            for (SolrDocument doc : docList)
+            {
+                ParsedObject result = new BaseParsedObject();
+                
+                addFieldsToParsedObject(doc, result);
+                
+                Object type = doc.getFieldValue(ParsedObject.FIELDNAME_TYPE);
+                if(type != null)
+                {
+                    result.setType(type.toString());
+                }
+                
+                Object key = doc.getFieldValue(ParsedObject.FIELDNAME_KEY);
+                if(key != null)
+                {
+                    result.setKey(key.toString());
+                }
+                
+                Object description = doc.getFieldValue(ParsedObject.FIELDNAME_DESCRIPTION);
+                if(description != null)
+                {
+                    result.setDescription(description.toString());
+                }
+                
+                Object title = doc.getFieldValue(ParsedObject.FIELDNAME_TITLE);
+                if(title != null)
+                {
+                    result.setTitle(title.toString());
+                }
+                
+                Object content = doc.getFieldValue(ParsedObject.FIELDNAME_CONTENT);
+                if(content != null)
+                {
+                    result.setContent(content.toString());
+                }
+                
+                Object language = doc.getFieldValue(ParsedObject.FIELDNAME_LANGUAGE);
+                if (language != null)
+                {
+                    result.setLanguage(language.toString());
+                }
+                
+                Object classname = doc.getFieldValue(ParsedObject.FIELDNAME_CLASSNAME);
+                if (classname != null)
+                {
+                    result.setClassName(classname.toString());
+                }
+                
+                Object url = doc.getFieldValue(ParsedObject.FIELDNAME_URL);
+                if (url != null)
+                {
+                    result.setURL(new URL(url.toString()));
+                }
+                
+                Collection<Object> keywords = doc.getFieldValues(ParsedObject.FIELDNAME_KEYWORDS);
+                if(keywords != null)
+                {
+                    String[] keywordArray = new String[keywords.size()];
+                    int index = 0;
+                    
+                    for (Object keyword : keywords)
+                    {
+                        keywordArray[index++] = keyword.toString();
+                    }
+                    
+                    result.setKeywords(keywordArray);
+                }
+                
+                resultList.add(result);
+            }
+            
+            results = new SearchResultsImpl(resultList);
+        }
+        catch (Exception e)
+        {
+            log.error("Failed to search. ", e);
+        }
+        
+        return (results != null ? results : new SearchResultsImpl(new ArrayList<ParsedObject>()));
+    }
+
+    public boolean optimize()
+    {
+        try
+        {
+            server.optimize();
+            return true;
+        }
+        catch (Exception e)
+        {
+            if (log.isDebugEnabled()) {
+                log.error("Error while trying to optimize index. " + e, e);
+            } else {
+                log.error("Error while trying to optimize index. {}", e.toString());
+            }
+        }
+        
+        return false;
+    }
+    
+    private synchronized boolean removeIfExistsAndAdd(Collection objects)
+    {
+        try
+        {
+            Collection<SolrInputDocument> docs = new ArrayList<SolrInputDocument>();
+            
+            Iterator it = objects.iterator();
+            
+            while (it.hasNext()) 
+            {
+                Object o = it.next();
+                // Look up appropriate handler
+                ObjectHandler handler = null;
+                try
+                {
+                    handler = handlerFactory.getHandler(o);
+                }
+                catch (Exception e)
+                {
+                    log.error("Failed to create hanlder for object " + o.getClass().getName());
+                    continue;
+                }
+    
+                // Parse the object
+                ParsedObject parsedObject = handler.parseObject(o);
+                
+                String key = parsedObject.getKey();
+                // if there's an existing one with the same key, then remove it first.
+                if (parsedObject.getKey() != null)
+                {
+                    SolrQuery query = new SolrQuery();
+                    String queryString = new StringBuilder(40).append(ParsedObject.FIELDNAME_KEY).append(':').append(key).toString();
+                    query.setQuery(ParsedObject.FIELDNAME_KEY + ":" + key);
+                    QueryResponse rsp = server.query(query);
+                    
+                    if (rsp.getResults().size() > 0)
+                    {
+                        server.deleteByQuery(queryString);
+                    }
+                }
+                
+                String type = parsedObject.getType();
+                String title = parsedObject.getTitle();
+                String description = parsedObject.getDescription();
+                String content = parsedObject.getContent();
+                String language = parsedObject.getLanguage();
+                URL url = parsedObject.getURL();
+                String className = parsedObject.getClassName();
+                
+                // Create document
+                SolrInputDocument doc = new SolrInputDocument();
+                
+                // Populate document from the parsed object
+                if (key != null)
+                {
+                    doc.addField(ParsedObject.FIELDNAME_KEY, key, 1.0f);
+                }
+                if (type != null)
+                {
+                    doc.addField(ParsedObject.FIELDNAME_TYPE, type, 1.0f);
+                }
+                if (title != null)
+                {
+                    doc.addField(ParsedObject.FIELDNAME_TITLE, title, 1.0f);
+                }
+                if (description != null)
+                {
+                    doc.addField(ParsedObject.FIELDNAME_DESCRIPTION, description, 1.0f);
+                }
+                if (content != null)
+                {
+                    doc.addField(ParsedObject.FIELDNAME_CONTENT, content, 1.0f);
+                }
+                if (language != null)
+                {
+                    doc.addField(ParsedObject.FIELDNAME_LANGUAGE, language, 1.0f);
+                }
+                if (url != null)
+                {
+                    String urlString = url.toString();
+                    doc.addField(ParsedObject.FIELDNAME_URL, urlString, 1.0f);
+                }
+                if (className != null)
+                {
+                    doc.addField(ParsedObject.FIELDNAME_CLASSNAME, className, 1.0f);
+                }
+                
+                String[] keywordArray = parsedObject.getKeywords();
+                if(keywordArray != null)
+                {
+                    for(int i=0; i<keywordArray.length; ++i)
+                    {
+                        String keyword = keywordArray[i];
+                        doc.addField(ParsedObject.FIELDNAME_KEYWORDS, keyword, 1.0f);
+                    }
+                }
+    
+                Map keywords = parsedObject.getKeywordsMap();
+                addFieldsToDocument(doc, keywords);
+                
+                Map fields = parsedObject.getFields();
+                addFieldsToDocument(doc, fields);
+                
+                List<String> syntheticField = new ArrayList<String>();
+                for (Map.Entry<String, SolrInputField> entry : doc.entrySet())
+                {
+                    SolrInputField field = entry.getValue();
+                    Object value = field.getFirstValue();
+                    
+                    if (value != null)
+                    {
+                        syntheticField.add(value.toString());
+                    }
+                }
+                
+                doc.addField(ParsedObject.FIELDNAME_SYNTHETIC, StringUtils.join(syntheticField, ' '), 1.0f);
+
+                docs.add(doc);
+            }
+            
+            if (objects.size() > 0 && optimizeAfterUpdate)
+            {
+                server.add(docs);
+                server.commit();
+                
+                try
+                {
+                    server.optimize();
+                }
+                catch (IOException e)
+                {
+                    log.error("Error while trying to optimize index.", e);
+                }
+            }
+        }
+        catch (Exception e)
+        {
+            log.error("Error while writing index.", e);
+            return false;
+        }
+        
+        return true;
+    }
+
+    private void addFieldsToDocument(SolrInputDocument doc, Map fields)
+    {
+        if(fields != null)
+        {
+            Iterator keyIter = fields.keySet().iterator();
+            while(keyIter.hasNext())
+            {
+                Object key = keyIter.next();
+                if(key != null)
+                {
+                    Object values = fields.get(key);
+                    if(values != null)
+                    {
+                        if(values instanceof Collection)
+                        {
+                            Iterator valueIter = ((Collection)values).iterator();
+                            while(valueIter.hasNext())
+                            {
+                                Object value = valueIter.next();
+                                if(value != null)
+                                {
+                                    doc.addField(key.toString(), value.toString(), 1.0f);
+                                }
+                            }
+                        }
+                        else
+                        {
+                            doc.addField(key.toString(), values.toString(), 1.0f);
+                        }
+                    }
+                }
+            } 
+        }
+    }
+
+    private void addFieldsToParsedObject(SolrDocument doc, ParsedObject o)
+    {
+        try
+        {
+            MultiMap multiKeywords = new MultiValueMap();
+            MultiMap multiFields = new MultiValueMap();
+            HashMap fieldMap = new HashMap();
+            
+            Object classNameField = doc.getFieldValue(ParsedObject.FIELDNAME_CLASSNAME);
+            
+            if(classNameField != null)
+            {
+                String className = classNameField.toString();
+                o.setClassName(className);
+                ObjectHandler handler = handlerFactory.getHandler(className);
+                
+                Set fields = handler.getFields();
+                addFieldsToMap(doc, fields, multiFields);
+                addFieldsToMap(doc, fields, fieldMap);
+                
+                Set keywords = handler.getKeywords();
+                addFieldsToMap(doc, keywords, multiKeywords);
+            }
+            
+            o.setKeywordsMap(multiKeywords);
+            o.setFields(multiFields);
+            o.setFields(fieldMap);
+        }
+        catch (Exception e)
+        {
+            log.error("Error trying to add fields to parsed object.", e);
+        }
+    }
+
+    private void addFieldsToMap(SolrDocument doc, Set fieldNames, Map fields)
+    {
+        Iterator fieldIter = fieldNames.iterator();
+        while(fieldIter.hasNext())
+        {
+            String fieldName = (String)fieldIter.next();
+            Collection<Object> values = doc.getFieldValues(fieldName);
+            
+            if (values != null)
+            {
+                for (Object value : values)
+                {
+                    fields.put(fieldName, value.toString());
+                }
+            }
+        }
+    }
+
+}

Added: portals/jetspeed-2/portal/trunk/components/jetspeed-search/src/test/java/org/apache/jetspeed/search/solr/TestSolrPortletRegistrySearch.java
URL: http://svn.apache.org/viewvc/portals/jetspeed-2/portal/trunk/components/jetspeed-search/src/test/java/org/apache/jetspeed/search/solr/TestSolrPortletRegistrySearch.java?rev=1086467&view=auto
==============================================================================
--- portals/jetspeed-2/portal/trunk/components/jetspeed-search/src/test/java/org/apache/jetspeed/search/solr/TestSolrPortletRegistrySearch.java (added)
+++ portals/jetspeed-2/portal/trunk/components/jetspeed-search/src/test/java/org/apache/jetspeed/search/solr/TestSolrPortletRegistrySearch.java Tue Mar 29 03:12:30 2011
@@ -0,0 +1,258 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ * 
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ * 
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package org.apache.jetspeed.search.solr;
+
+import java.io.File;
+import java.util.Arrays;
+import java.util.HashMap;
+import java.util.Map;
+
+import junit.framework.Test;
+import junit.framework.TestSuite;
+
+import org.apache.commons.collections.MultiHashMap;
+import org.apache.jetspeed.search.AbstractObjectHandler;
+import org.apache.jetspeed.search.BaseParsedObject;
+import org.apache.jetspeed.search.ParsedObject;
+import org.apache.jetspeed.search.SearchEngine;
+import org.apache.jetspeed.search.SearchResults;
+import org.apache.jetspeed.search.handlers.HandlerFactoryImpl;
+import org.apache.jetspeed.test.JetspeedTestCase;
+import org.apache.solr.client.solrj.SolrServer;
+import org.apache.solr.client.solrj.embedded.EmbeddedSolrServer;
+import org.apache.solr.core.CoreContainer;
+
+/**
+ * TestSolrPortletRegistrySearch
+ * @version $Id: TestSolrPortletRegistrySearch.java 1086464 2011-03-29 02:08:39Z woonsan $
+ */
+public class TestSolrPortletRegistrySearch extends JetspeedTestCase
+{
+    private SolrServer server;
+    private SearchEngine searchEngine;
+    
+    public TestSolrPortletRegistrySearch(String name)
+    {
+        super(name);
+    }
+    
+    /**
+     * Start the tests.
+     *
+     * @param args the arguments. Not used
+     */
+    public static void main(String args[]) 
+    {
+        junit.awtui.TestRunner.main( new String[] { TestSolrPortletRegistrySearch.class.getName() } );
+    }
+ 
+    /**
+     * Creates the test suite.
+     *
+     * @return a test suite (<code>TestSuite</code>) that includes all methods
+     *         starting with "test"
+     */
+    public static Test suite() 
+    {
+        // All methods starting with "test" will be executed in the test suite.
+        return new TestSuite( TestSolrPortletRegistrySearch.class );
+    }
+    
+    protected void setUp() throws Exception
+    {
+        super.setUp();
+        HashMap mapping = new HashMap();
+        mapping.put("java.util.HashMap", MapObjectHandler.class.getName());
+        HandlerFactoryImpl hfi = new HandlerFactoryImpl(mapping);
+        
+        File targetDir = new File("target/test-classes");
+        System.setProperty("solr.solr.home", targetDir.getCanonicalPath());
+        CoreContainer.Initializer initializer = new CoreContainer.Initializer();
+        CoreContainer coreContainer = initializer.initialize();
+        server = new EmbeddedSolrServer(coreContainer, "");
+
+        searchEngine = new SolrSearchEngineImpl(server, true, hfi);
+    }
+    
+    protected void tearDown() throws Exception
+    {
+        super.tearDown();
+    }
+    
+    public void testSimpleSearch()
+    {
+        Map<String, String> paDemo = new HashMap<String, String>();
+        paDemo.put("keyPrefix", "PortletApplication::");
+        paDemo.put("description", "demo portlet application");
+        paDemo.put("title", "Demo");
+        paDemo.put("name", "demo");
+        paDemo.put("type", ParsedObject.OBJECT_TYPE_PORTLET_APPLICATION);
+
+        Map<String, String> paRss = new HashMap<String, String>();
+        paRss.put("keyPrefix", "PortletApplication::");
+        paRss.put("description", "rss portlet application");
+        paRss.put("title", "RSS");
+        paRss.put("name", "rss");
+        paRss.put("type", ParsedObject.OBJECT_TYPE_PORTLET_APPLICATION);
+
+        searchEngine.add(paDemo);
+        searchEngine.add(paRss);
+        
+        SearchResults searchResults = searchEngine.search("demo");
+        assertEquals(1, searchResults.size());
+        
+        searchResults = searchEngine.search("rss");
+        assertEquals(1, searchResults.size());
+        
+        searchResults = searchEngine.search("application");
+        assertEquals(2, searchResults.size());
+        
+        // adding one more; the search engine is expected to have duplicate index.
+        searchEngine.add(paDemo);
+        
+        searchResults = searchEngine.search("demo");
+        assertEquals(1, searchResults.size());
+        
+        searchResults = searchEngine.search("application");
+        assertEquals(2, searchResults.size());
+    }
+    
+    public void testPortletSearch()
+    {
+        Map<String, String> paDemo = new HashMap<String, String>();
+        paDemo.put("keyPrefix", "PortletApplication::");
+        paDemo.put("description", "demo portlet application");
+        paDemo.put("title", "Demo");
+        paDemo.put("name", "demo");
+        paDemo.put("type", ParsedObject.OBJECT_TYPE_PORTLET_APPLICATION);
+
+        Map<String, String> helloPortlet = new HashMap<String, String>();
+        helloPortlet.put("keyPrefix", "PortletDefinition::");
+        helloPortlet.put("description", "hello portlet definition");
+        helloPortlet.put("title", "Hello World");
+        helloPortlet.put("name", "hello");
+        helloPortlet.put("type", ParsedObject.OBJECT_TYPE_PORTLET);
+
+        Map<String, String> guessPortlet = new HashMap<String, String>();
+        guessPortlet.put("keyPrefix", "PortletDefinition::");
+        guessPortlet.put("description", "guess portlet definition");
+        guessPortlet.put("title", "Guess - Pick A Number");
+        guessPortlet.put("name", "guess");
+        guessPortlet.put("type", ParsedObject.OBJECT_TYPE_PORTLET);
+
+        searchEngine.add(paDemo);
+        searchEngine.add(Arrays.asList(helloPortlet, guessPortlet));
+        
+        SearchResults searchResults = searchEngine.search("demo");
+        assertEquals(1, searchResults.size());
+        
+        searchResults = searchEngine.search("hello");
+        assertEquals(1, searchResults.size());
+        
+        searchResults = searchEngine.search("guess");
+        assertEquals(1, searchResults.size());
+        
+        searchResults = searchEngine.search("definition");
+        assertEquals(2, searchResults.size());
+    }
+    
+    public void testPortletSearchByRichQuery()
+    {
+        Map<String, String> paDemo = new HashMap<String, String>();
+        paDemo.put("keyPrefix", "PortletApplication::");
+        paDemo.put("description", "demo portlet application");
+        paDemo.put("title", "Demo");
+        paDemo.put("name", "demo");
+        paDemo.put("type", ParsedObject.OBJECT_TYPE_PORTLET_APPLICATION);
+
+        Map<String, String> helloPortlet = new HashMap<String, String>();
+        helloPortlet.put("keyPrefix", "PortletDefinition::");
+        helloPortlet.put("description", "demo hello portlet definition");
+        helloPortlet.put("title", "Hello World");
+        helloPortlet.put("name", "hello");
+        helloPortlet.put("type", ParsedObject.OBJECT_TYPE_PORTLET);
+
+        Map<String, String> guessPortlet = new HashMap<String, String>();
+        guessPortlet.put("keyPrefix", "PortletDefinition::");
+        guessPortlet.put("description", "demo guess portlet definition");
+        guessPortlet.put("title", "Guess - Pick A Number");
+        guessPortlet.put("name", "guess");
+        guessPortlet.put("type", ParsedObject.OBJECT_TYPE_PORTLET);
+
+        searchEngine.add(paDemo);
+        searchEngine.add(Arrays.asList(helloPortlet, guessPortlet));
+        
+        SearchResults searchResults = searchEngine.search("demo");
+        assertEquals(3, searchResults.size());
+
+        String query = ParsedObject.FIELDNAME_TYPE + ":\"" + ParsedObject.OBJECT_TYPE_PORTLET_APPLICATION + "\" AND ( demo )";
+        
+        searchResults = searchEngine.search(query);
+        assertEquals(1, searchResults.size());
+        
+        query = ParsedObject.FIELDNAME_TYPE + ":\"" + ParsedObject.OBJECT_TYPE_PORTLET + "\" " +
+            "AND NOT " + ParsedObject.FIELDNAME_TYPE + ":\"" + ParsedObject.OBJECT_TYPE_PORTLET_APPLICATION + "\" " + 
+            "AND ( demo )";
+        
+        searchResults = searchEngine.search(query);
+        assertEquals(2, searchResults.size());
+
+        query = ParsedObject.FIELDNAME_TYPE + ":\"" + ParsedObject.OBJECT_TYPE_PORTLET + "\" " +
+        "AND NOT " + ParsedObject.FIELDNAME_TYPE + ":\"" + ParsedObject.OBJECT_TYPE_PORTLET_APPLICATION + "\" " + 
+        "AND ( hello )";
+    
+        searchResults = searchEngine.search(query);
+        assertEquals(1, searchResults.size());
+        
+        query = ParsedObject.FIELDNAME_TYPE + ":\"" + ParsedObject.OBJECT_TYPE_PORTLET + "\" " +
+        "AND NOT " + ParsedObject.FIELDNAME_TYPE + ":\"" + ParsedObject.OBJECT_TYPE_PORTLET_APPLICATION + "\" " + 
+        "AND ( guess )";
+    
+        searchResults = searchEngine.search(query);
+        assertEquals(1, searchResults.size());
+    }
+    
+    public static class MapObjectHandler extends AbstractObjectHandler
+    {
+        private String keyPrefix;
+        
+        public ParsedObject parseObject(Object o)
+        {
+            BaseParsedObject result = null;
+            
+            if(o instanceof Map)
+            {
+                result = new BaseParsedObject();
+                Map<String, String> map = (Map<String, String>) o;
+                
+                keyPrefix = map.get("keyPrefix");
+                
+                result.setDescription(map.get("description"));
+                
+                result.setTitle(map.get("title"));
+                result.setKey(keyPrefix + map.get("name"));
+                result.setType(map.get("type"));
+                result.setClassName(map.get("class"));
+                
+                MultiHashMap fieldMap = new MultiHashMap();
+                fieldMap.put(ParsedObject.ID, map.get("name"));
+            }
+            
+            return result;
+        }
+    }
+}

Added: portals/jetspeed-2/portal/trunk/components/jetspeed-search/src/test/resources/conf/admin-extra.html
URL: http://svn.apache.org/viewvc/portals/jetspeed-2/portal/trunk/components/jetspeed-search/src/test/resources/conf/admin-extra.html?rev=1086467&view=auto
==============================================================================
--- portals/jetspeed-2/portal/trunk/components/jetspeed-search/src/test/resources/conf/admin-extra.html (added)
+++ portals/jetspeed-2/portal/trunk/components/jetspeed-search/src/test/resources/conf/admin-extra.html Tue Mar 29 03:12:30 2011
@@ -0,0 +1,31 @@
+<!--
+ 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.
+-->
+
+<!-- The content of this page will be statically included into the top
+of the admin page.  Uncomment this as an example to see there the content
+will show up.
+
+<hr>
+<i>This line will appear before the first table</i>
+<tr>
+<td colspan="2">
+This row will be appended to the end of the first table
+</td>
+</tr>
+<hr>
+
+-->

Added: portals/jetspeed-2/portal/trunk/components/jetspeed-search/src/test/resources/conf/elevate.xml
URL: http://svn.apache.org/viewvc/portals/jetspeed-2/portal/trunk/components/jetspeed-search/src/test/resources/conf/elevate.xml?rev=1086467&view=auto
==============================================================================
--- portals/jetspeed-2/portal/trunk/components/jetspeed-search/src/test/resources/conf/elevate.xml (added)
+++ portals/jetspeed-2/portal/trunk/components/jetspeed-search/src/test/resources/conf/elevate.xml Tue Mar 29 03:12:30 2011
@@ -0,0 +1,36 @@
+<?xml version="1.0" encoding="UTF-8" ?>
+<!--
+ Licensed to the Apache Software Foundation (ASF) under one or more
+ contributor license agreements.  See the NOTICE file distributed with
+ this work for additional information regarding copyright ownership.
+ The ASF licenses this file to You under the Apache License, Version 2.0
+ (the "License"); you may not use this file except in compliance with
+ the License.  You may obtain a copy of the License at
+
+     http://www.apache.org/licenses/LICENSE-2.0
+
+ Unless required by applicable law or agreed to in writing, software
+ distributed under the License is distributed on an "AS IS" BASIS,
+ WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ See the License for the specific language governing permissions and
+ limitations under the License.
+-->
+
+<!-- If this file is found in the config directory, it will only be
+     loaded once at startup.  If it is found in Solr's data
+     directory, it will be re-loaded every commit.
+-->
+
+<elevate>
+ <query text="foo bar">
+  <doc id="1" />
+  <doc id="2" />
+  <doc id="3" />
+ </query>
+ 
+ <query text="ipod">
+   <doc id="MA147LL/A" />  <!-- put the actual ipod at the top -->
+   <doc id="IW-02" exclude="true" /> <!-- exclude this cable -->
+ </query>
+ 
+</elevate>

Added: portals/jetspeed-2/portal/trunk/components/jetspeed-search/src/test/resources/conf/mapping-ISOLatin1Accent.txt
URL: http://svn.apache.org/viewvc/portals/jetspeed-2/portal/trunk/components/jetspeed-search/src/test/resources/conf/mapping-ISOLatin1Accent.txt?rev=1086467&view=auto
==============================================================================
--- portals/jetspeed-2/portal/trunk/components/jetspeed-search/src/test/resources/conf/mapping-ISOLatin1Accent.txt (added)
+++ portals/jetspeed-2/portal/trunk/components/jetspeed-search/src/test/resources/conf/mapping-ISOLatin1Accent.txt Tue Mar 29 03:12:30 2011
@@ -0,0 +1,246 @@
+# 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.
+
+# Syntax:
+#   "source" => "target"
+#     "source".length() > 0 (source cannot be empty.)
+#     "target".length() >= 0 (target can be empty.)
+
+# example:
+#   "À" => "A"
+#   "\u00C0" => "A"
+#   "\u00C0" => "\u0041"
+#   "ß" => "ss"
+#   "\t" => " "
+#   "\n" => ""
+
+# À => A
+"\u00C0" => "A"
+
+# Á => A
+"\u00C1" => "A"
+
+# Â => A
+"\u00C2" => "A"
+
+# Ã => A
+"\u00C3" => "A"
+
+# Ä => A
+"\u00C4" => "A"
+
+# Å => A
+"\u00C5" => "A"
+
+# Æ => AE
+"\u00C6" => "AE"
+
+# Ç => C
+"\u00C7" => "C"
+
+# È => E
+"\u00C8" => "E"
+
+# É => E
+"\u00C9" => "E"
+
+# Ê => E
+"\u00CA" => "E"
+
+# Ë => E
+"\u00CB" => "E"
+
+# Ì => I
+"\u00CC" => "I"
+
+# Í => I
+"\u00CD" => "I"
+
+# Î => I
+"\u00CE" => "I"
+
+# Ï => I
+"\u00CF" => "I"
+
+# IJ => IJ
+"\u0132" => "IJ"
+
+# Ð => D
+"\u00D0" => "D"
+
+# Ñ => N
+"\u00D1" => "N"
+
+# Ò => O
+"\u00D2" => "O"
+
+# Ó => O
+"\u00D3" => "O"
+
+# Ô => O
+"\u00D4" => "O"
+
+# Õ => O
+"\u00D5" => "O"
+
+# Ö => O
+"\u00D6" => "O"
+
+# Ø => O
+"\u00D8" => "O"
+
+# Π=> OE
+"\u0152" => "OE"
+
+# Þ
+"\u00DE" => "TH"
+
+# Ù => U
+"\u00D9" => "U"
+
+# Ú => U
+"\u00DA" => "U"
+
+# Û => U
+"\u00DB" => "U"
+
+# Ü => U
+"\u00DC" => "U"
+
+# Ý => Y
+"\u00DD" => "Y"
+
+# Ÿ => Y
+"\u0178" => "Y"
+
+# à => a
+"\u00E0" => "a"
+
+# á => a
+"\u00E1" => "a"
+
+# â => a
+"\u00E2" => "a"
+
+# ã => a
+"\u00E3" => "a"
+
+# ä => a
+"\u00E4" => "a"
+
+# å => a
+"\u00E5" => "a"
+
+# æ => ae
+"\u00E6" => "ae"
+
+# ç => c
+"\u00E7" => "c"
+
+# è => e
+"\u00E8" => "e"
+
+# é => e
+"\u00E9" => "e"
+
+# ê => e
+"\u00EA" => "e"
+
+# ë => e
+"\u00EB" => "e"
+
+# ì => i
+"\u00EC" => "i"
+
+# í => i
+"\u00ED" => "i"
+
+# î => i
+"\u00EE" => "i"
+
+# ï => i
+"\u00EF" => "i"
+
+# ij => ij
+"\u0133" => "ij"
+
+# ð => d
+"\u00F0" => "d"
+
+# ñ => n
+"\u00F1" => "n"
+
+# ò => o
+"\u00F2" => "o"
+
+# ó => o
+"\u00F3" => "o"
+
+# ô => o
+"\u00F4" => "o"
+
+# õ => o
+"\u00F5" => "o"
+
+# ö => o
+"\u00F6" => "o"
+
+# ø => o
+"\u00F8" => "o"
+
+# œ => oe
+"\u0153" => "oe"
+
+# ß => ss
+"\u00DF" => "ss"
+
+# þ => th
+"\u00FE" => "th"
+
+# ù => u
+"\u00F9" => "u"
+
+# ú => u
+"\u00FA" => "u"
+
+# û => u
+"\u00FB" => "u"
+
+# ü => u
+"\u00FC" => "u"
+
+# ý => y
+"\u00FD" => "y"
+
+# ÿ => y
+"\u00FF" => "y"
+
+# ff => ff
+"\uFB00" => "ff"
+
+# fi => fi
+"\uFB01" => "fi"
+
+# fl => fl
+"\uFB02" => "fl"
+
+# ffi => ffi
+"\uFB03" => "ffi"
+
+# ffl => ffl
+"\uFB04" => "ffl"
+
+# ſt => ft
+"\uFB05" => "ft"
+
+# st => st
+"\uFB06" => "st"

Added: portals/jetspeed-2/portal/trunk/components/jetspeed-search/src/test/resources/conf/protwords.txt
URL: http://svn.apache.org/viewvc/portals/jetspeed-2/portal/trunk/components/jetspeed-search/src/test/resources/conf/protwords.txt?rev=1086467&view=auto
==============================================================================
--- portals/jetspeed-2/portal/trunk/components/jetspeed-search/src/test/resources/conf/protwords.txt (added)
+++ portals/jetspeed-2/portal/trunk/components/jetspeed-search/src/test/resources/conf/protwords.txt Tue Mar 29 03:12:30 2011
@@ -0,0 +1,21 @@
+# 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.
+
+#-----------------------------------------------------------------------
+# Use a protected word file to protect against the stemmer reducing two
+# unrelated words to the same base word.
+
+# Some non-words that normally won't be encountered,
+# just to test that they won't be stemmed.
+dontstems
+zwhacky
+

Added: portals/jetspeed-2/portal/trunk/components/jetspeed-search/src/test/resources/conf/schema.xml
URL: http://svn.apache.org/viewvc/portals/jetspeed-2/portal/trunk/components/jetspeed-search/src/test/resources/conf/schema.xml?rev=1086467&view=auto
==============================================================================
--- portals/jetspeed-2/portal/trunk/components/jetspeed-search/src/test/resources/conf/schema.xml (added)
+++ portals/jetspeed-2/portal/trunk/components/jetspeed-search/src/test/resources/conf/schema.xml Tue Mar 29 03:12:30 2011
@@ -0,0 +1,569 @@
+<?xml version="1.0" encoding="UTF-8" ?>
+<!--
+ Licensed to the Apache Software Foundation (ASF) under one or more
+ contributor license agreements.  See the NOTICE file distributed with
+ this work for additional information regarding copyright ownership.
+ The ASF licenses this file to You under the Apache License, Version 2.0
+ (the "License"); you may not use this file except in compliance with
+ the License.  You may obtain a copy of the License at
+
+     http://www.apache.org/licenses/LICENSE-2.0
+
+ Unless required by applicable law or agreed to in writing, software
+ distributed under the License is distributed on an "AS IS" BASIS,
+ WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ See the License for the specific language governing permissions and
+ limitations under the License.
+-->
+
+<!--  
+ This is the Solr schema file. This file should be named "schema.xml" and
+ should be in the conf directory under the solr home
+ (i.e. ./solr/conf/schema.xml by default) 
+ or located where the classloader for the Solr webapp can find it.
+
+ This example schema is the recommended starting point for users.
+ It should be kept correct and concise, usable out-of-the-box.
+
+ For more information, on how to customize this file, please see
+ http://wiki.apache.org/solr/SchemaXml
+
+ PERFORMANCE NOTE: this schema includes many optional features and should not
+ be used for benchmarking.  To improve performance one could
+  - set stored="false" for all fields possible (esp large fields) when you
+    only need to search on the field but don't need to return the original
+    value.
+  - set indexed="false" if you don't need to search on the field, but only
+    return the field as a result of searching on other indexed fields.
+  - remove all unneeded copyField statements
+  - for best index size and searching performance, set "index" to false
+    for all general text fields, use copyField to copy them to the
+    catchall "text" field, and use that for searching.
+  - For maximum indexing performance, use the StreamingUpdateSolrServer
+    java client.
+  - Remember to run the JVM in server mode, and use a higher logging level
+    that avoids logging every request
+-->
+
+<schema name="example" version="1.2">
+  <!-- attribute "name" is the name of this schema and is only used for display purposes.
+       Applications should change this to reflect the nature of the search collection.
+       version="1.2" is Solr's version number for the schema syntax and semantics.  It should
+       not normally be changed by applications.
+       1.0: multiValued attribute did not exist, all fields are multiValued by nature
+       1.1: multiValued attribute introduced, false by default 
+       1.2: omitTermFreqAndPositions attribute introduced, true by default except for text fields.
+     -->
+
+  <types>
+    <!-- field type definitions. The "name" attribute is
+       just a label to be used by field definitions.  The "class"
+       attribute and any other attributes determine the real
+       behavior of the fieldType.
+         Class names starting with "solr" refer to java classes in the
+       org.apache.solr.analysis package.
+    -->
+
+    <!-- The StrField type is not analyzed, but indexed/stored verbatim.  
+       - StrField and TextField support an optional compressThreshold which
+       limits compression (if enabled in the derived fields) to values which
+       exceed a certain size (in characters).
+    -->
+    <fieldType name="string" class="solr.StrField" sortMissingLast="true" omitNorms="true"/>
+
+    <!-- boolean type: "true" or "false" -->
+    <fieldType name="boolean" class="solr.BoolField" sortMissingLast="true" omitNorms="true"/>
+    <!--Binary data type. The data should be sent/retrieved in as Base64 encoded Strings -->
+    <fieldtype name="binary" class="solr.BinaryField"/>
+
+    <!-- The optional sortMissingLast and sortMissingFirst attributes are
+         currently supported on types that are sorted internally as strings.
+	       This includes "string","boolean","sint","slong","sfloat","sdouble","pdate"
+       - If sortMissingLast="true", then a sort on this field will cause documents
+         without the field to come after documents with the field,
+         regardless of the requested sort order (asc or desc).
+       - If sortMissingFirst="true", then a sort on this field will cause documents
+         without the field to come before documents with the field,
+         regardless of the requested sort order.
+       - If sortMissingLast="false" and sortMissingFirst="false" (the default),
+         then default lucene sorting will be used which places docs without the
+         field first in an ascending sort and last in a descending sort.
+    -->    
+
+    <!--
+      Default numeric field types. For faster range queries, consider the tint/tfloat/tlong/tdouble types.
+    -->
+    <fieldType name="int" class="solr.TrieIntField" precisionStep="0" omitNorms="true" positionIncrementGap="0"/>
+    <fieldType name="float" class="solr.TrieFloatField" precisionStep="0" omitNorms="true" positionIncrementGap="0"/>
+    <fieldType name="long" class="solr.TrieLongField" precisionStep="0" omitNorms="true" positionIncrementGap="0"/>
+    <fieldType name="double" class="solr.TrieDoubleField" precisionStep="0" omitNorms="true" positionIncrementGap="0"/>
+
+    <!--
+     Numeric field types that index each value at various levels of precision
+     to accelerate range queries when the number of values between the range
+     endpoints is large. See the javadoc for NumericRangeQuery for internal
+     implementation details.
+
+     Smaller precisionStep values (specified in bits) will lead to more tokens
+     indexed per value, slightly larger index size, and faster range queries.
+     A precisionStep of 0 disables indexing at different precision levels.
+    -->
+    <fieldType name="tint" class="solr.TrieIntField" precisionStep="8" omitNorms="true" positionIncrementGap="0"/>
+    <fieldType name="tfloat" class="solr.TrieFloatField" precisionStep="8" omitNorms="true" positionIncrementGap="0"/>
+    <fieldType name="tlong" class="solr.TrieLongField" precisionStep="8" omitNorms="true" positionIncrementGap="0"/>
+    <fieldType name="tdouble" class="solr.TrieDoubleField" precisionStep="8" omitNorms="true" positionIncrementGap="0"/>
+
+    <!-- The format for this date field is of the form 1995-12-31T23:59:59Z, and
+         is a more restricted form of the canonical representation of dateTime
+         http://www.w3.org/TR/xmlschema-2/#dateTime    
+         The trailing "Z" designates UTC time and is mandatory.
+         Optional fractional seconds are allowed: 1995-12-31T23:59:59.999Z
+         All other components are mandatory.
+
+         Expressions can also be used to denote calculations that should be
+         performed relative to "NOW" to determine the value, ie...
+
+               NOW/HOUR
+                  ... Round to the start of the current hour
+               NOW-1DAY
+                  ... Exactly 1 day prior to now
+               NOW/DAY+6MONTHS+3DAYS
+                  ... 6 months and 3 days in the future from the start of
+                      the current day
+                      
+         Consult the DateField javadocs for more information.
+
+         Note: For faster range queries, consider the tdate type
+      -->
+    <fieldType name="date" class="solr.TrieDateField" omitNorms="true" precisionStep="0" positionIncrementGap="0"/>
+
+    <!-- A Trie based date field for faster date range queries and date faceting. -->
+    <fieldType name="tdate" class="solr.TrieDateField" omitNorms="true" precisionStep="6" positionIncrementGap="0"/>
+
+
+    <!--
+      Note:
+      These should only be used for compatibility with existing indexes (created with older Solr versions)
+      or if "sortMissingFirst" or "sortMissingLast" functionality is needed. Use Trie based fields instead.
+
+      Plain numeric field types that store and index the text
+      value verbatim (and hence don't support range queries, since the
+      lexicographic ordering isn't equal to the numeric ordering)
+    -->
+    <fieldType name="pint" class="solr.IntField" omitNorms="true"/>
+    <fieldType name="plong" class="solr.LongField" omitNorms="true"/>
+    <fieldType name="pfloat" class="solr.FloatField" omitNorms="true"/>
+    <fieldType name="pdouble" class="solr.DoubleField" omitNorms="true"/>
+    <fieldType name="pdate" class="solr.DateField" sortMissingLast="true" omitNorms="true"/>
+
+
+    <!--
+      Note:
+      These should only be used for compatibility with existing indexes (created with older Solr versions)
+      or if "sortMissingFirst" or "sortMissingLast" functionality is needed. Use Trie based fields instead.
+
+      Numeric field types that manipulate the value into
+      a string value that isn't human-readable in its internal form,
+      but with a lexicographic ordering the same as the numeric ordering,
+      so that range queries work correctly.
+    -->
+    <fieldType name="sint" class="solr.SortableIntField" sortMissingLast="true" omitNorms="true"/>
+    <fieldType name="slong" class="solr.SortableLongField" sortMissingLast="true" omitNorms="true"/>
+    <fieldType name="sfloat" class="solr.SortableFloatField" sortMissingLast="true" omitNorms="true"/>
+    <fieldType name="sdouble" class="solr.SortableDoubleField" sortMissingLast="true" omitNorms="true"/>
+
+
+    <!-- The "RandomSortField" is not used to store or search any
+         data.  You can declare fields of this type it in your schema
+         to generate pseudo-random orderings of your docs for sorting 
+         purposes.  The ordering is generated based on the field name 
+         and the version of the index, As long as the index version
+         remains unchanged, and the same field name is reused,
+         the ordering of the docs will be consistent.  
+         If you want different psuedo-random orderings of documents,
+         for the same version of the index, use a dynamicField and
+         change the name
+     -->
+    <fieldType name="random" class="solr.RandomSortField" indexed="true" />
+
+    <!-- solr.TextField allows the specification of custom text analyzers
+         specified as a tokenizer and a list of token filters. Different
+         analyzers may be specified for indexing and querying.
+
+         The optional positionIncrementGap puts space between multiple fields of
+         this type on the same document, with the purpose of preventing false phrase
+         matching across fields.
+
+         For more info on customizing your analyzer chain, please see
+         http://wiki.apache.org/solr/AnalyzersTokenizersTokenFilters
+     -->
+
+    <!-- One can also specify an existing Analyzer class that has a
+         default constructor via the class attribute on the analyzer element
+    <fieldType name="text_greek" class="solr.TextField">
+      <analyzer class="org.apache.lucene.analysis.el.GreekAnalyzer"/>
+    </fieldType>
+    -->
+
+    <!-- A text field that only splits on whitespace for exact matching of words -->
+    <fieldType name="text_ws" class="solr.TextField" positionIncrementGap="100">
+      <analyzer>
+        <tokenizer class="solr.WhitespaceTokenizerFactory"/>
+      </analyzer>
+    </fieldType>
+
+    <!-- A text field that uses WordDelimiterFilter to enable splitting and matching of
+        words on case-change, alpha numeric boundaries, and non-alphanumeric chars,
+        so that a query of "wifi" or "wi fi" could match a document containing "Wi-Fi".
+        Synonyms and stopwords are customized by external files, and stemming is enabled.
+        -->
+    <fieldType name="text" class="solr.TextField" positionIncrementGap="100">
+      <analyzer type="index">
+        <tokenizer class="solr.WhitespaceTokenizerFactory"/>
+        <!-- in this example, we will only use synonyms at query time
+        <filter class="solr.SynonymFilterFactory" synonyms="index_synonyms.txt" ignoreCase="true" expand="false"/>
+        -->
+        <!-- Case insensitive stop word removal.
+          add enablePositionIncrements=true in both the index and query
+          analyzers to leave a 'gap' for more accurate phrase queries.
+        -->
+        <filter class="solr.StopFilterFactory"
+                ignoreCase="true"
+                words="stopwords.txt"
+                enablePositionIncrements="true"
+                />
+        <filter class="solr.WordDelimiterFilterFactory" generateWordParts="1" generateNumberParts="1" catenateWords="1" catenateNumbers="1" catenateAll="0" splitOnCaseChange="1"/>
+        <filter class="solr.LowerCaseFilterFactory"/>
+        <filter class="solr.SnowballPorterFilterFactory" language="English" protected="protwords.txt"/>
+      </analyzer>
+      <analyzer type="query">
+        <tokenizer class="solr.WhitespaceTokenizerFactory"/>
+        <filter class="solr.SynonymFilterFactory" synonyms="synonyms.txt" ignoreCase="true" expand="true"/>
+        <filter class="solr.StopFilterFactory"
+                ignoreCase="true"
+                words="stopwords.txt"
+                enablePositionIncrements="true"
+                />
+        <filter class="solr.WordDelimiterFilterFactory" generateWordParts="1" generateNumberParts="1" catenateWords="0" catenateNumbers="0" catenateAll="0" splitOnCaseChange="1"/>
+        <filter class="solr.LowerCaseFilterFactory"/>
+        <filter class="solr.SnowballPorterFilterFactory" language="English" protected="protwords.txt"/>
+      </analyzer>
+    </fieldType>
+
+
+    <!-- Less flexible matching, but less false matches.  Probably not ideal for product names,
+         but may be good for SKUs.  Can insert dashes in the wrong place and still match. -->
+    <fieldType name="textTight" class="solr.TextField" positionIncrementGap="100" >
+      <analyzer>
+        <tokenizer class="solr.WhitespaceTokenizerFactory"/>
+        <filter class="solr.SynonymFilterFactory" synonyms="synonyms.txt" ignoreCase="true" expand="false"/>
+        <filter class="solr.StopFilterFactory" ignoreCase="true" words="stopwords.txt"/>
+        <filter class="solr.WordDelimiterFilterFactory" generateWordParts="0" generateNumberParts="0" catenateWords="1" catenateNumbers="1" catenateAll="0"/>
+        <filter class="solr.LowerCaseFilterFactory"/>
+        <filter class="solr.SnowballPorterFilterFactory" language="English" protected="protwords.txt"/>
+        <!-- this filter can remove any duplicate tokens that appear at the same position - sometimes
+             possible with WordDelimiterFilter in conjuncton with stemming. -->
+        <filter class="solr.RemoveDuplicatesTokenFilterFactory"/>
+      </analyzer>
+    </fieldType>
+
+
+    <!-- A general unstemmed text field - good if one does not know the language of the field -->
+    <fieldType name="textgen" class="solr.TextField" positionIncrementGap="100">
+      <analyzer type="index">
+        <tokenizer class="solr.WhitespaceTokenizerFactory"/>
+        <filter class="solr.StopFilterFactory" ignoreCase="true" words="stopwords.txt" enablePositionIncrements="true" />
+        <filter class="solr.WordDelimiterFilterFactory" generateWordParts="1" generateNumberParts="1" catenateWords="1" catenateNumbers="1" catenateAll="0" splitOnCaseChange="0"/>
+        <filter class="solr.LowerCaseFilterFactory"/>
+      </analyzer>
+      <analyzer type="query">
+        <tokenizer class="solr.WhitespaceTokenizerFactory"/>
+        <filter class="solr.SynonymFilterFactory" synonyms="synonyms.txt" ignoreCase="true" expand="true"/>
+        <filter class="solr.StopFilterFactory"
+                ignoreCase="true"
+                words="stopwords.txt"
+                enablePositionIncrements="true"
+                />
+        <filter class="solr.WordDelimiterFilterFactory" generateWordParts="1" generateNumberParts="1" catenateWords="0" catenateNumbers="0" catenateAll="0" splitOnCaseChange="0"/>
+        <filter class="solr.LowerCaseFilterFactory"/>
+      </analyzer>
+    </fieldType>
+
+
+    <!-- A general unstemmed text field that indexes tokens normally and also
+         reversed (via ReversedWildcardFilterFactory), to enable more efficient 
+	 leading wildcard queries. -->
+    <fieldType name="text_rev" class="solr.TextField" positionIncrementGap="100">
+      <analyzer type="index">
+        <tokenizer class="solr.WhitespaceTokenizerFactory"/>
+        <filter class="solr.StopFilterFactory" ignoreCase="true" words="stopwords.txt" enablePositionIncrements="true" />
+        <filter class="solr.WordDelimiterFilterFactory" generateWordParts="1" generateNumberParts="1" catenateWords="1" catenateNumbers="1" catenateAll="0" splitOnCaseChange="0"/>
+        <filter class="solr.LowerCaseFilterFactory"/>
+        <filter class="solr.ReversedWildcardFilterFactory" withOriginal="true"
+           maxPosAsterisk="3" maxPosQuestion="2" maxFractionAsterisk="0.33"/>
+      </analyzer>
+      <analyzer type="query">
+        <tokenizer class="solr.WhitespaceTokenizerFactory"/>
+        <filter class="solr.SynonymFilterFactory" synonyms="synonyms.txt" ignoreCase="true" expand="true"/>
+        <filter class="solr.StopFilterFactory"
+                ignoreCase="true"
+                words="stopwords.txt"
+                enablePositionIncrements="true"
+                />
+        <filter class="solr.WordDelimiterFilterFactory" generateWordParts="1" generateNumberParts="1" catenateWords="0" catenateNumbers="0" catenateAll="0" splitOnCaseChange="0"/>
+        <filter class="solr.LowerCaseFilterFactory"/>
+      </analyzer>
+    </fieldType>
+
+    <!-- charFilter + WhitespaceTokenizer  -->
+    <!--
+    <fieldType name="textCharNorm" class="solr.TextField" positionIncrementGap="100" >
+      <analyzer>
+        <charFilter class="solr.MappingCharFilterFactory" mapping="mapping-ISOLatin1Accent.txt"/>
+        <tokenizer class="solr.WhitespaceTokenizerFactory"/>
+      </analyzer>
+    </fieldType>
+    -->
+
+    <!-- This is an example of using the KeywordTokenizer along
+         With various TokenFilterFactories to produce a sortable field
+         that does not include some properties of the source text
+      -->
+    <fieldType name="alphaOnlySort" class="solr.TextField" sortMissingLast="true" omitNorms="true">
+      <analyzer>
+        <!-- KeywordTokenizer does no actual tokenizing, so the entire
+             input string is preserved as a single token
+          -->
+        <tokenizer class="solr.KeywordTokenizerFactory"/>
+        <!-- The LowerCase TokenFilter does what you expect, which can be
+             when you want your sorting to be case insensitive
+          -->
+        <filter class="solr.LowerCaseFilterFactory" />
+        <!-- The TrimFilter removes any leading or trailing whitespace -->
+        <filter class="solr.TrimFilterFactory" />
+        <!-- The PatternReplaceFilter gives you the flexibility to use
+             Java Regular expression to replace any sequence of characters
+             matching a pattern with an arbitrary replacement string, 
+             which may include back references to portions of the original
+             string matched by the pattern.
+             
+             See the Java Regular Expression documentation for more
+             information on pattern and replacement string syntax.
+             
+             http://java.sun.com/j2se/1.5.0/docs/api/java/util/regex/package-summary.html
+          -->
+        <filter class="solr.PatternReplaceFilterFactory"
+                pattern="([^a-z])" replacement="" replace="all"
+        />
+      </analyzer>
+    </fieldType>
+    
+    <fieldtype name="phonetic" stored="false" indexed="true" class="solr.TextField" >
+      <analyzer>
+        <tokenizer class="solr.StandardTokenizerFactory"/>
+        <filter class="solr.DoubleMetaphoneFilterFactory" inject="false"/>
+      </analyzer>
+    </fieldtype>
+
+    <fieldtype name="payloads" stored="false" indexed="true" class="solr.TextField" >
+      <analyzer>
+        <tokenizer class="solr.WhitespaceTokenizerFactory"/>
+        <!--
+        The DelimitedPayloadTokenFilter can put payloads on tokens... for example,
+        a token of "foo|1.4"  would be indexed as "foo" with a payload of 1.4f
+        Attributes of the DelimitedPayloadTokenFilterFactory : 
+         "delimiter" - a one character delimiter. Default is | (pipe)
+	 "encoder" - how to encode the following value into a playload
+	    float -> org.apache.lucene.analysis.payloads.FloatEncoder,
+	    integer -> o.a.l.a.p.IntegerEncoder
+	    identity -> o.a.l.a.p.IdentityEncoder
+            Fully Qualified class name implementing PayloadEncoder, Encoder must have a no arg constructor.
+         -->
+        <filter class="solr.DelimitedPayloadTokenFilterFactory" encoder="float"/>
+      </analyzer>
+    </fieldtype>
+
+    <!-- lowercases the entire field value, keeping it as a single token.  -->
+    <fieldType name="lowercase" class="solr.TextField" positionIncrementGap="100">
+      <analyzer>
+        <tokenizer class="solr.KeywordTokenizerFactory"/>
+        <filter class="solr.LowerCaseFilterFactory" />
+      </analyzer>
+    </fieldType>
+
+
+    <!-- since fields of this type are by default not stored or indexed,
+         any data added to them will be ignored outright.  --> 
+    <fieldtype name="ignored" stored="false" indexed="false" multiValued="true" class="solr.StrField" /> 
+
+ </types>
+
+
+ <fields>
+   <!-- Valid attributes for fields:
+     name: mandatory - the name for the field
+     type: mandatory - the name of a previously defined type from the 
+       <types> section
+     indexed: true if this field should be indexed (searchable or sortable)
+     stored: true if this field should be retrievable
+     compressed: [false] if this field should be stored using gzip compression
+       (this will only apply if the field type is compressable; among
+       the standard field types, only TextField and StrField are)
+     multiValued: true if this field may contain multiple values per document
+     omitNorms: (expert) set to true to omit the norms associated with
+       this field (this disables length normalization and index-time
+       boosting for the field, and saves some memory).  Only full-text
+       fields or fields that need an index-time boost need norms.
+     termVectors: [false] set to true to store the term vector for a
+       given field.
+       When using MoreLikeThis, fields used for similarity should be
+       stored for best performance.
+     termPositions: Store position information with the term vector.  
+       This will increase storage costs.
+     termOffsets: Store offset information with the term vector. This 
+       will increase storage costs.
+     default: a value that should be used if no value is specified
+       when adding a document.
+   -->
+
+   <field name="id" type="string" indexed="true" stored="true" required="true" /> 
+   <field name="sku" type="textTight" indexed="true" stored="true" omitNorms="true"/>
+   <field name="name" type="textgen" indexed="true" stored="true"/>
+   <field name="alphaNameSort" type="alphaOnlySort" indexed="true" stored="false"/>
+   <field name="manu" type="textgen" indexed="true" stored="true" omitNorms="true"/>
+   <field name="cat" type="text_ws" indexed="true" stored="true" multiValued="true" omitNorms="true" />
+   <field name="features" type="text" indexed="true" stored="true" multiValued="true"/>
+   <field name="includes" type="text" indexed="true" stored="true" termVectors="true" termPositions="true" termOffsets="true" />
+
+   <field name="weight" type="float" indexed="true" stored="true"/>
+   <field name="price"  type="float" indexed="true" stored="true"/>
+   <field name="popularity" type="int" indexed="true" stored="true" />
+   <field name="inStock" type="boolean" indexed="true" stored="true" />
+
+
+   <!-- Common metadata fields, named specifically to match up with
+     SolrCell metadata when parsing rich documents such as Word, PDF.
+     Some fields are multiValued only because Tika currently may return
+     multiple values for them.
+   -->
+   <field name="title" type="text" indexed="true" stored="true" multiValued="true"/>
+   <field name="subject" type="text" indexed="true" stored="true"/>
+   <field name="description" type="text" indexed="true" stored="true"/>
+   <field name="comments" type="text" indexed="true" stored="true"/>
+   <field name="author" type="textgen" indexed="true" stored="true"/>
+   <field name="keywords" type="textgen" indexed="true" stored="true"/>
+   <field name="category" type="textgen" indexed="true" stored="true"/>
+   <field name="content_type" type="string" indexed="true" stored="true" multiValued="true"/>
+   <field name="last_modified" type="date" indexed="true" stored="true"/>
+   <field name="links" type="string" indexed="true" stored="true" multiValued="true"/>
+
+
+   <!-- catchall field, containing all other searchable text fields (implemented
+        via copyField further on in this schema  -->
+   <field name="text" type="text" indexed="true" stored="false" multiValued="true"/>
+
+   <!-- catchall text field that indexes tokens both normally and in reverse for efficient
+        leading wildcard queries. -->
+   <field name="text_rev" type="text_rev" indexed="true" stored="false" multiValued="true"/>
+
+   <!-- non-tokenized version of manufacturer to make it easier to sort or group
+        results by manufacturer.  copied from "manu" via copyField -->
+   <field name="manu_exact" type="string" indexed="true" stored="false"/>
+
+   <field name="payloads" type="payloads" indexed="true" stored="true"/>
+
+   <!-- Uncommenting the following will create a "timestamp" field using
+        a default value of "NOW" to indicate when each document was indexed.
+     -->
+   <!--
+   <field name="timestamp" type="date" indexed="true" stored="true" default="NOW" multiValued="false"/>
+     -->
+   
+
+   <!-- Dynamic field definitions.  If a field name is not found, dynamicFields
+        will be used if the name matches any of the patterns.
+        RESTRICTION: the glob-like pattern in the name attribute must have
+        a "*" only at the start or the end.
+        EXAMPLE:  name="*_i" will match any field ending in _i (like myid_i, z_i)
+        Longer patterns will be matched first.  if equal size patterns
+        both match, the first appearing in the schema will be used.  -->
+   <dynamicField name="*_i"  type="int"    indexed="true"  stored="true"/>
+   <dynamicField name="*_s"  type="string"  indexed="true"  stored="true"/>
+   <dynamicField name="*_l"  type="long"   indexed="true"  stored="true"/>
+   <dynamicField name="*_t"  type="text"    indexed="true"  stored="true"/>
+   <dynamicField name="*_b"  type="boolean" indexed="true"  stored="true"/>
+   <dynamicField name="*_f"  type="float"  indexed="true"  stored="true"/>
+   <dynamicField name="*_d"  type="double" indexed="true"  stored="true"/>
+   <dynamicField name="*_dt" type="date"    indexed="true"  stored="true"/>
+
+   <!-- some trie-coded dynamic fields for faster range queries -->
+   <dynamicField name="*_ti" type="tint"    indexed="true"  stored="true"/>
+   <dynamicField name="*_tl" type="tlong"   indexed="true"  stored="true"/>
+   <dynamicField name="*_tf" type="tfloat"  indexed="true"  stored="true"/>
+   <dynamicField name="*_td" type="tdouble" indexed="true"  stored="true"/>
+   <dynamicField name="*_tdt" type="tdate"  indexed="true"  stored="true"/>
+
+   <dynamicField name="*_pi"  type="pint"    indexed="true"  stored="true"/>
+
+   <dynamicField name="ignored_*" type="ignored" multiValued="true"/>
+   <dynamicField name="attr_*" type="textgen" indexed="true" stored="true" multiValued="true"/>
+
+   <dynamicField name="random_*" type="random" />
+
+   <!-- uncomment the following to ignore any fields that don't already match an existing 
+        field name or dynamic field, rather than reporting them as an error. 
+        alternately, change the type="ignored" to some other type e.g. "text" if you want 
+        unknown fields indexed and/or stored by default --> 
+   <!--dynamicField name="*" type="ignored" multiValued="true" /-->
+   
+ </fields>
+
+ <!-- Field to use to determine and enforce document uniqueness. 
+      Unless this field is marked with required="false", it will be a required field
+   -->
+ <uniqueKey>id</uniqueKey>
+
+ <!-- field for the QueryParser to use when an explicit fieldname is absent -->
+ <defaultSearchField>text</defaultSearchField>
+
+ <!-- SolrQueryParser configuration: defaultOperator="AND|OR" -->
+ <solrQueryParser defaultOperator="OR"/>
+
+  <!-- copyField commands copy one field to another at the time a document
+        is added to the index.  It's used either to index the same field differently,
+        or to add multiple fields to the same field for easier/faster searching.  -->
+
+   <copyField source="cat" dest="text"/>
+   <copyField source="name" dest="text"/>
+   <copyField source="manu" dest="text"/>
+   <copyField source="features" dest="text"/>
+   <copyField source="includes" dest="text"/>
+   <copyField source="manu" dest="manu_exact"/>
+	
+   <!-- Above, multiple source fields are copied to the [text] field. 
+	  Another way to map multiple source fields to the same 
+	  destination field is to use the dynamic field syntax. 
+	  copyField also supports a maxChars to copy setting.  -->
+	   
+   <!-- <copyField source="*_t" dest="text" maxChars="3000"/> -->
+
+   <!-- copy name to alphaNameSort, a field designed for sorting by name -->
+   <!-- <copyField source="name" dest="alphaNameSort"/> -->
+ 
+
+ <!-- Similarity is the scoring routine for each document vs. a query.
+      A custom similarity may be specified here, but the default is fine
+      for most applications.  -->
+ <!-- <similarity class="org.apache.lucene.search.DefaultSimilarity"/> -->
+ <!-- ... OR ...
+      Specify a SimilarityFactory class name implementation
+      allowing parameters to be used.
+ -->
+ <!--
+ <similarity class="com.example.solr.CustomSimilarityFactory">
+   <str name="paramkey">param value</str>
+ </similarity>
+ -->
+
+
+</schema>

Added: portals/jetspeed-2/portal/trunk/components/jetspeed-search/src/test/resources/conf/scripts.conf
URL: http://svn.apache.org/viewvc/portals/jetspeed-2/portal/trunk/components/jetspeed-search/src/test/resources/conf/scripts.conf?rev=1086467&view=auto
==============================================================================
--- portals/jetspeed-2/portal/trunk/components/jetspeed-search/src/test/resources/conf/scripts.conf (added)
+++ portals/jetspeed-2/portal/trunk/components/jetspeed-search/src/test/resources/conf/scripts.conf Tue Mar 29 03:12:30 2011
@@ -0,0 +1,24 @@
+# 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.
+
+user=
+solr_hostname=localhost
+solr_port=8983
+rsyncd_port=18983
+data_dir=
+webapp_name=solr
+master_host=
+master_data_dir=
+master_status_dir=



---------------------------------------------------------------------
To unsubscribe, e-mail: jetspeed-dev-unsubscribe@portals.apache.org
For additional commands, e-mail: jetspeed-dev-help@portals.apache.org