You are viewing a plain text version of this content. The canonical link for it is here.
Posted to droids-commits@incubator.apache.org by to...@apache.org on 2012/12/18 08:41:41 UTC

svn commit: r1423322 [2/2] - in /incubator/droids/branches/0.2.x-cleanup: ./ droids-core/ droids-core/src/main/java/org/apache/droids/core/ droids-core/src/main/java/org/apache/droids/delay/ droids-core/src/main/java/org/apache/droids/exception/ droids...

Modified: incubator/droids/branches/0.2.x-cleanup/droids-core/src/main/java/org/apache/droids/handle/ReportHandler.java
URL: http://svn.apache.org/viewvc/incubator/droids/branches/0.2.x-cleanup/droids-core/src/main/java/org/apache/droids/handle/ReportHandler.java?rev=1423322&r1=1423321&r2=1423322&view=diff
==============================================================================
--- incubator/droids/branches/0.2.x-cleanup/droids-core/src/main/java/org/apache/droids/handle/ReportHandler.java (original)
+++ incubator/droids/branches/0.2.x-cleanup/droids-core/src/main/java/org/apache/droids/handle/ReportHandler.java Tue Dec 18 08:41:30 2012
@@ -28,30 +28,28 @@ import org.apache.droids.core.Handler;
 import org.apache.droids.core.Task;
 
 /**
- * 
- * Simple handler that writes the handled URIs to a Set. 
+ * Simple handler that writes the handled URIs to a Set.
  * Useful for retrieving all visited URIs.
- *
  */
 public class ReportHandler implements Handler {
 
-  private static Set<String> report;
-  
-  static {
-    report = Collections.synchronizedSet(new HashSet<String>());
-  }
-  
-  @Override
-  public void handle(Task task) throws IOException,
-      DroidsException {
-    report.add(task.getURI().toString());
-  }
-  
-  public static Set<String> getReport() {
-    return report;
-  }
-
-  public static void recycle() {
-    report.clear();
-  }
+    private static Set<String> report;
+
+    static {
+        report = Collections.synchronizedSet(new HashSet<String>());
+    }
+
+    @Override
+    public void handle(Task task) throws IOException,
+            DroidsException {
+        report.add(task.getURI().toString());
+    }
+
+    public static Set<String> getReport() {
+        return report;
+    }
+
+    public static void recycle() {
+        report.clear();
+    }
 }

Modified: incubator/droids/branches/0.2.x-cleanup/droids-core/src/main/java/org/apache/droids/handle/SaveContentHandlerStrategy.java
URL: http://svn.apache.org/viewvc/incubator/droids/branches/0.2.x-cleanup/droids-core/src/main/java/org/apache/droids/handle/SaveContentHandlerStrategy.java?rev=1423322&r1=1423321&r2=1423322&view=diff
==============================================================================
--- incubator/droids/branches/0.2.x-cleanup/droids-core/src/main/java/org/apache/droids/handle/SaveContentHandlerStrategy.java (original)
+++ incubator/droids/branches/0.2.x-cleanup/droids-core/src/main/java/org/apache/droids/handle/SaveContentHandlerStrategy.java Tue Dec 18 08:41:30 2012
@@ -29,7 +29,8 @@ public interface SaveContentHandlerStrat
 
     /**
      * Calculate the filepath to use for {@link URI} and {@link ContentEntity}.
-     * @param uri the uri
+     *
+     * @param uri    the uri
      * @param entity the entity
      * @return the filepath
      */

Modified: incubator/droids/branches/0.2.x-cleanup/droids-core/src/main/java/org/apache/droids/handle/SaveHandler.java
URL: http://svn.apache.org/viewvc/incubator/droids/branches/0.2.x-cleanup/droids-core/src/main/java/org/apache/droids/handle/SaveHandler.java?rev=1423322&r1=1423321&r2=1423322&view=diff
==============================================================================
--- incubator/droids/branches/0.2.x-cleanup/droids-core/src/main/java/org/apache/droids/handle/SaveHandler.java (original)
+++ incubator/droids/branches/0.2.x-cleanup/droids-core/src/main/java/org/apache/droids/handle/SaveHandler.java Tue Dec 18 08:41:30 2012
@@ -36,117 +36,104 @@ import org.slf4j.LoggerFactory;
 
 /**
  * Handler which is writing the stream to the file system.
- * <p>
+ * <p/>
  * Before using make sure you have set the {@link SaveContentHandlerStrategy}.
- * 
+ *
  * @version 1.0
- * 
  */
 public class SaveHandler extends WriterHandler implements Handler {
 
-	private final Logger log = LoggerFactory.getLogger(SaveHandler.class);
+    private final Logger log = LoggerFactory.getLogger(SaveHandler.class);
 
-	private URI uri;
+    private URI uri;
 
-	private SaveContentHandlerStrategy saveContentHandlerStrategy;
+    private SaveContentHandlerStrategy saveContentHandlerStrategy;
 
-	public SaveHandler() {
-		super();
-	}
-
-	/**
-	 * Handle saving content.
-	 * 
-	 * @param task the task to handle
-	 *
-	 * @throws IOException on file error
+    public SaveHandler() {
+        super();
+    }
+
+    /**
+     * Handle saving content.
+     *
+     * @param task the task to handle
+     * @throws IOException     on file error
      * @throws DroidsException on content entity error
-	 */
-	@Override
-	public void handle(Task task) throws IOException, DroidsException {
-		this.uri = task.getURI();
+     */
+    @Override
+    public void handle(Task task) throws IOException, DroidsException {
+        this.uri = task.getURI();
         InputStream instream;
         if (task.getContentEntity().getValue(ContentEntity.CONTENT) instanceof InputStream) {
-            instream = (InputStream)task.getContentEntity().getValue(ContentEntity.CONTENT);
+            instream = (InputStream) task.getContentEntity().getValue(ContentEntity.CONTENT);
         } else
             throw new InvalidTaskException("no inputstream available");
-		try {
+        try {
             String path = saveContentHandlerStrategy.calculateFilePath(uri, task);
-			writeOutput(path, instream);
-		} finally {
-			instream.close();
-		}
-	}
-
-	/**
-	 * Write the output.
-	 * 
-	 * @param path
-	 *            the path to write to
-	 * @param stream
-	 *            the stream
-	 * @throws IOException
-	 *             on error
-	 */
-	private void writeOutput(String path, InputStream stream)
-			throws IOException {
-		if (!uri.getPath().endsWith("/")) {
-			log.info("Trying to save " + uri + " to " + path);
-			File cache = new File(path);
-			FileUtil.createFile(cache);
-
-			writeContentToFile(stream, cache);
-		}
-	}
-
-	/**
-	 * Write contents to a file.
-	 * 
-	 * @param stream
-	 *            the stream
-	 * @param cache
-	 *            the file
-	 * @throws FileNotFoundException
-	 *             on file not found
-	 * @throws IOException
-	 *             on error
-	 */
-	private void writeContentToFile(InputStream stream, File cache)
-			throws IOException {
-		OutputStream output = null;
-		final int bufferSize = 8192;
-		byte[] buffer = new byte[bufferSize];
-		int length = -1;
-		try {
-			output = new BufferedOutputStream(new FileOutputStream(cache));
-			while ((length = stream.read(buffer)) > -1) {
-				output.write(buffer, 0, length);
-			}
-		} finally {
-			if (null != output) {
-				output.flush();
-				output.close();
-			}
-		}
-	}
-
-	/**
-	 * 
-	 * @return the {@link SaveContentHandlerStrategy}.
-	 * 
-	 */
-	public SaveContentHandlerStrategy getSaveContentHandlerStrategy() {
-		return saveContentHandlerStrategy;
-	}
-
-	/**
-	 * 
-	 * @param saveContentHandlerStrategy
-	 *            the {@link SaveContentHandlerStrategy} to set.
-	 */
-	public void setSaveContentHandlerStrategy(
-			SaveContentHandlerStrategy saveContentHandlerStrategy) {
-		this.saveContentHandlerStrategy = saveContentHandlerStrategy;
-	}
+            writeOutput(path, instream);
+        } finally {
+            instream.close();
+        }
+    }
+
+    /**
+     * Write the output.
+     *
+     * @param path   the path to write to
+     * @param stream the stream
+     * @throws IOException on error
+     */
+    private void writeOutput(String path, InputStream stream)
+            throws IOException {
+        if (!uri.getPath().endsWith("/")) {
+            log.info("Trying to save " + uri + " to " + path);
+            File cache = new File(path);
+            FileUtil.createFile(cache);
+
+            writeContentToFile(stream, cache);
+        }
+    }
+
+    /**
+     * Write contents to a file.
+     *
+     * @param stream the stream
+     * @param cache  the file
+     * @throws FileNotFoundException on file not found
+     * @throws IOException           on error
+     */
+    private void writeContentToFile(InputStream stream, File cache)
+            throws IOException {
+        OutputStream output = null;
+        final int bufferSize = 8192;
+        byte[] buffer = new byte[bufferSize];
+        int length = -1;
+        try {
+            output = new BufferedOutputStream(new FileOutputStream(cache));
+            while ((length = stream.read(buffer)) > -1) {
+                output.write(buffer, 0, length);
+            }
+        } finally {
+            if (null != output) {
+                output.flush();
+                output.close();
+            }
+        }
+    }
+
+    /**
+     * @return the {@link SaveContentHandlerStrategy}.
+     */
+    public SaveContentHandlerStrategy getSaveContentHandlerStrategy() {
+        return saveContentHandlerStrategy;
+    }
+
+    /**
+     * @param saveContentHandlerStrategy the {@link SaveContentHandlerStrategy} to set.
+     */
+    public void setSaveContentHandlerStrategy(
+            SaveContentHandlerStrategy saveContentHandlerStrategy) {
+        this.saveContentHandlerStrategy = saveContentHandlerStrategy;
+    }
 
 }

Modified: incubator/droids/branches/0.2.x-cleanup/droids-core/src/main/java/org/apache/droids/handle/WriterHandler.java
URL: http://svn.apache.org/viewvc/incubator/droids/branches/0.2.x-cleanup/droids-core/src/main/java/org/apache/droids/handle/WriterHandler.java?rev=1423322&r1=1423321&r2=1423322&view=diff
==============================================================================
--- incubator/droids/branches/0.2.x-cleanup/droids-core/src/main/java/org/apache/droids/handle/WriterHandler.java (original)
+++ incubator/droids/branches/0.2.x-cleanup/droids-core/src/main/java/org/apache/droids/handle/WriterHandler.java Tue Dec 18 08:41:30 2012
@@ -23,30 +23,27 @@ import java.io.Writer;
 /**
  * Wrapper that allows you to pipe a stream from a reader to a writer via a
  * buffer
- * 
+ *
  * @version 1.0
- * 
  */
 public class WriterHandler {
 
-  private static final int BUFFER_SIZE = 1024;
+    private static final int BUFFER_SIZE = 1024;
 
-  /**
-   * Pipes everything from the reader to the writer via a buffer
-   * 
-   * @param reader
-   *                the underlying read to read from
-   * @param writer
-   *                the destination writer
-   * @throws IOException
-   */
-  protected static void pipe(Reader reader, Writer writer) throws IOException {
-    char[] buf = new char[BUFFER_SIZE];
-    int read = 0;
-    while ((read = reader.read(buf)) >= 0) {
-      writer.write(buf, 0, read);
+    /**
+     * Pipes everything from the reader to the writer via a buffer
+     *
+     * @param reader the underlying read to read from
+     * @param writer the destination writer
+     * @throws IOException
+     */
+    protected static void pipe(Reader reader, Writer writer) throws IOException {
+        char[] buf = new char[BUFFER_SIZE];
+        int read = 0;
+        while ((read = reader.read(buf)) >= 0) {
+            writer.write(buf, 0, read);
+        }
+        writer.flush();
     }
-    writer.flush();
-  }
 
 }

Modified: incubator/droids/branches/0.2.x-cleanup/droids-core/src/main/java/org/apache/droids/helper/factories/HandlerFactory.java
URL: http://svn.apache.org/viewvc/incubator/droids/branches/0.2.x-cleanup/droids-core/src/main/java/org/apache/droids/helper/factories/HandlerFactory.java?rev=1423322&r1=1423321&r2=1423322&view=diff
==============================================================================
--- incubator/droids/branches/0.2.x-cleanup/droids-core/src/main/java/org/apache/droids/helper/factories/HandlerFactory.java (original)
+++ incubator/droids/branches/0.2.x-cleanup/droids-core/src/main/java/org/apache/droids/helper/factories/HandlerFactory.java Tue Dec 18 08:41:30 2012
@@ -26,9 +26,8 @@ import org.apache.droids.core.Task;
 
 /**
  * Factory that will traverse all registered handler and execute them.
- * 
+ *
  * @version 1.0
- * 
  */
 public class HandlerFactory {
     private Set<Handler> handlers;
@@ -41,17 +40,17 @@ public class HandlerFactory {
         handlers.add(handler);
     }
 
-  /**
-   * Will traverse all registered handler and execute them. If we encounter a
-   * problem we directly return false and leave.
-   * 
-   * @param task the task to handle
-   */
-  public void handle(Task task)
-      throws DroidsException, IOException {
-    for (Handler handler : handlers) {
-      handler.handle(task);
+    /**
+     * Will traverse all registered handler and execute them. If we encounter a
+     * problem we directly return false and leave.
+     *
+     * @param task the task to handle
+     */
+    public void handle(Task task)
+            throws DroidsException, IOException {
+        for (Handler handler : handlers) {
+            handler.handle(task);
+        }
     }
-  }
 
 }

Modified: incubator/droids/branches/0.2.x-cleanup/droids-core/src/main/java/org/apache/droids/monitor/SimpleWorkMonitor.java
URL: http://svn.apache.org/viewvc/incubator/droids/branches/0.2.x-cleanup/droids-core/src/main/java/org/apache/droids/monitor/SimpleWorkMonitor.java?rev=1423322&r1=1423321&r2=1423322&view=diff
==============================================================================
--- incubator/droids/branches/0.2.x-cleanup/droids-core/src/main/java/org/apache/droids/monitor/SimpleWorkMonitor.java (original)
+++ incubator/droids/branches/0.2.x-cleanup/droids-core/src/main/java/org/apache/droids/monitor/SimpleWorkMonitor.java Tue Dec 18 08:41:30 2012
@@ -24,30 +24,28 @@ import org.apache.droids.core.Task;
 import org.apache.droids.core.Worker;
 
 /**
- * A simple 
+ * A simple
  */
 public class SimpleWorkMonitor<T extends Task> implements WorkMonitor<T> {
-  
-  Map<T,WorkBean<T>> working = new ConcurrentHashMap<T, WorkBean<T>>();
-  
-  @Override
-  public void beforeExecute(T task, Worker<T> worker) {
-    WorkBean<T> bean = new WorkBean<T>( task, worker );
-    working.put( task, bean );
-  }
-
-  @Override
-  public void afterExecute(T task, Worker<T> worker, Exception ex) {
-    working.remove( task );
-  }
-  
-  public Collection<WorkBean<T>> getRunningTasks()
-  {
-    return working.values();
-  }
-  
-  public WorkBean<T> getWorkBean( T task )
-  {
-    return working.get( task );
-  }
+
+    Map<T, WorkBean<T>> working = new ConcurrentHashMap<T, WorkBean<T>>();
+
+    @Override
+    public void beforeExecute(T task, Worker<T> worker) {
+        WorkBean<T> bean = new WorkBean<T>(task, worker);
+        working.put(task, bean);
+    }
+
+    @Override
+    public void afterExecute(T task, Worker<T> worker, Exception ex) {
+        working.remove(task);
+    }
+
+    public Collection<WorkBean<T>> getRunningTasks() {
+        return working.values();
+    }
+
+    public WorkBean<T> getWorkBean(T task) {
+        return working.get(task);
+    }
 }

Modified: incubator/droids/branches/0.2.x-cleanup/droids-core/src/main/java/org/apache/droids/monitor/WorkBean.java
URL: http://svn.apache.org/viewvc/incubator/droids/branches/0.2.x-cleanup/droids-core/src/main/java/org/apache/droids/monitor/WorkBean.java?rev=1423322&r1=1423321&r2=1423322&view=diff
==============================================================================
--- incubator/droids/branches/0.2.x-cleanup/droids-core/src/main/java/org/apache/droids/monitor/WorkBean.java (original)
+++ incubator/droids/branches/0.2.x-cleanup/droids-core/src/main/java/org/apache/droids/monitor/WorkBean.java Tue Dec 18 08:41:30 2012
@@ -22,36 +22,35 @@ import org.apache.droids.core.Task;
 import org.apache.droids.core.Worker;
 
 /**
- * A simple 
+ * A simple
  */
 public class WorkBean<T extends Task> {
 
-  Date startTime;
+    Date startTime;
 
-  T task;
-  Worker<T> worker;
-  Exception exception;
-  
-  public WorkBean( T task, Worker<T> w )
-  {
-    this.startTime = new Date();
-    this.task = task;
-    this.worker = w;
-  }
-
-  public Date getStartTime() {
-    return startTime;
-  }
-
-  public T getTask() {
-    return task;
-  }
-
-  public Worker<T> getWorker() {
-    return worker;
-  }
-
-  public Exception getException() {
-    return exception;
-  }
+    T task;
+    Worker<T> worker;
+    Exception exception;
+
+    public WorkBean(T task, Worker<T> w) {
+        this.startTime = new Date();
+        this.task = task;
+        this.worker = w;
+    }
+
+    public Date getStartTime() {
+        return startTime;
+    }
+
+    public T getTask() {
+        return task;
+    }
+
+    public Worker<T> getWorker() {
+        return worker;
+    }
+
+    public Exception getException() {
+        return exception;
+    }
 }

Modified: incubator/droids/branches/0.2.x-cleanup/droids-core/src/main/java/org/apache/droids/monitor/WorkMonitor.java
URL: http://svn.apache.org/viewvc/incubator/droids/branches/0.2.x-cleanup/droids-core/src/main/java/org/apache/droids/monitor/WorkMonitor.java?rev=1423322&r1=1423321&r2=1423322&view=diff
==============================================================================
--- incubator/droids/branches/0.2.x-cleanup/droids-core/src/main/java/org/apache/droids/monitor/WorkMonitor.java (original)
+++ incubator/droids/branches/0.2.x-cleanup/droids-core/src/main/java/org/apache/droids/monitor/WorkMonitor.java Tue Dec 18 08:41:30 2012
@@ -25,21 +25,21 @@ import org.apache.droids.core.Worker;
  * @param <T>
  */
 public interface WorkMonitor<T extends Task> {
-  
-  /**
-   * Monitor the task before the execution.
-   * 
-   * @param task
-   * @param worker
-   */
-  void beforeExecute( final T task, final Worker<T> worker );
-  
-  /**
-   * Monitor the task after the execution.
-   * 
-   * @param task
-   * @param worker
-   * @param ex
-   */
-  void afterExecute( final T task, final Worker<T> worker, Exception ex );
+
+    /**
+     * Monitor the task before the execution.
+     *
+     * @param task
+     * @param worker
+     */
+    void beforeExecute(final T task, final Worker<T> worker);
+
+    /**
+     * Monitor the task after the execution.
+     *
+     * @param task
+     * @param worker
+     * @param ex
+     */
+    void afterExecute(final T task, final Worker<T> worker, Exception ex);
 }

Modified: incubator/droids/branches/0.2.x-cleanup/droids-core/src/main/java/org/apache/droids/parse/Parser.java
URL: http://svn.apache.org/viewvc/incubator/droids/branches/0.2.x-cleanup/droids-core/src/main/java/org/apache/droids/parse/Parser.java?rev=1423322&r1=1423321&r2=1423322&view=diff
==============================================================================
--- incubator/droids/branches/0.2.x-cleanup/droids-core/src/main/java/org/apache/droids/parse/Parser.java (original)
+++ incubator/droids/branches/0.2.x-cleanup/droids-core/src/main/java/org/apache/droids/parse/Parser.java Tue Dec 18 08:41:30 2012
@@ -23,17 +23,15 @@ import org.apache.droids.core.Task;
 
 /**
  * Simple parser that is only forcing to return a parse object.
- * 
+ *
  * @version 1.0
- * 
  */
 public interface Parser {
-  /**
-   * Creates the parse for some content.
-   * 
-   * @param task
-   *                the task that correspond to the stream
-   * @return the parse object
-   */
-  public void parse(Task task) throws DroidsException, IOException;
+    /**
+     * Creates the parse for some content.
+     *
+     * @param task the task that correspond to the stream
+     * @return the parse object
+     */
+    public void parse(Task task) throws DroidsException, IOException;
 }

Modified: incubator/droids/branches/0.2.x-cleanup/droids-core/src/main/java/org/apache/droids/util/FileUtil.java
URL: http://svn.apache.org/viewvc/incubator/droids/branches/0.2.x-cleanup/droids-core/src/main/java/org/apache/droids/util/FileUtil.java?rev=1423322&r1=1423321&r2=1423322&view=diff
==============================================================================
--- incubator/droids/branches/0.2.x-cleanup/droids-core/src/main/java/org/apache/droids/util/FileUtil.java (original)
+++ incubator/droids/branches/0.2.x-cleanup/droids-core/src/main/java/org/apache/droids/util/FileUtil.java Tue Dec 18 08:41:30 2012
@@ -20,26 +20,26 @@ import java.io.File;
 import java.io.IOException;
 
 /**
- * This is an utility class for file related operations. 
+ * This is an utility class for file related operations.
  */
 public final class FileUtil {
 
-  private FileUtil() {
-    throw new AssertionError();
-  }
+    private FileUtil() {
+        throw new AssertionError();
+    }
 
-  public static void createFile(File cache) throws IOException {
-    if (!cache.isDirectory() && !cache.getAbsolutePath().endsWith("/")) {
-      try {
-        cache.createNewFile();
-      } catch (IOException e) {
-        // if we cannot create a file that means that the parent path
-        // does not exists
-        final File path = new File(cache.getParent());
-        path.mkdirs();
-        cache.createNewFile();
-      }
+    public static void createFile(File cache) throws IOException {
+        if (!cache.isDirectory() && !cache.getAbsolutePath().endsWith("/")) {
+            try {
+                cache.createNewFile();
+            } catch (IOException e) {
+                // if we cannot create a file that means that the parent path
+                // does not exists
+                final File path = new File(cache.getParent());
+                path.mkdirs();
+                cache.createNewFile();
+            }
+        }
     }
-  }
 
 }

Modified: incubator/droids/branches/0.2.x-cleanup/droids-core/src/site/site.xml
URL: http://svn.apache.org/viewvc/incubator/droids/branches/0.2.x-cleanup/droids-core/src/site/site.xml?rev=1423322&r1=1423321&r2=1423322&view=diff
==============================================================================
--- incubator/droids/branches/0.2.x-cleanup/droids-core/src/site/site.xml (original)
+++ incubator/droids/branches/0.2.x-cleanup/droids-core/src/site/site.xml Tue Dec 18 08:41:30 2012
@@ -16,14 +16,14 @@
  limitations under the License.
 -->
 <project xmlns="http://maven.apache.org/DECORATION/1.0.0"
-    xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-    xsi:schemaLocation="http://maven.apache.org/DECORATION/1.0.0 http://maven.apache.org/xsd/decoration-1.0.0.xsd">
-  <body>
-    <menu ref="parent" />
-    
-    <menu name="JavaDocs"> 
-      <item name="JavaDocs" href="apidocs/index.html"/>
-      <item name="Test JavaDocs" href="testapidocs/index.html"/>
-    </menu>
-  </body>
+         xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+         xsi:schemaLocation="http://maven.apache.org/DECORATION/1.0.0 http://maven.apache.org/xsd/decoration-1.0.0.xsd">
+    <body>
+        <menu ref="parent"/>
+
+        <menu name="JavaDocs">
+            <item name="JavaDocs" href="apidocs/index.html"/>
+            <item name="Test JavaDocs" href="testapidocs/index.html"/>
+        </menu>
+    </body>
 </project>
\ No newline at end of file

Modified: incubator/droids/branches/0.2.x-cleanup/droids-core/src/test/java/org/apache/droids/core/SimpleTask.java
URL: http://svn.apache.org/viewvc/incubator/droids/branches/0.2.x-cleanup/droids-core/src/test/java/org/apache/droids/core/SimpleTask.java?rev=1423322&r1=1423321&r2=1423322&view=diff
==============================================================================
--- incubator/droids/branches/0.2.x-cleanup/droids-core/src/test/java/org/apache/droids/core/SimpleTask.java (original)
+++ incubator/droids/branches/0.2.x-cleanup/droids-core/src/test/java/org/apache/droids/core/SimpleTask.java Tue Dec 18 08:41:30 2012
@@ -6,19 +6,19 @@ import java.net.URI;
 import java.util.Date;
 
 public class SimpleTask implements Task {
-	private URI uri;
-	private int depth;
-	private boolean aborted;
+    private URI uri;
+    private int depth;
+    private boolean aborted;
     private ContentEntity contentEntity;
-	
-	private static final long serialVersionUID = 2506491803180939447L;
 
-	public SimpleTask(URI uri, int depth) {
-		this.uri = uri;
-		this.depth = depth;
-		this.aborted = false;
+    private static final long serialVersionUID = 2506491803180939447L;
+
+    public SimpleTask(URI uri, int depth) {
+        this.uri = uri;
+        this.depth = depth;
+        this.aborted = false;
         this.contentEntity = new ContentEntity();
-	}
+    }
 
     @Override
     public ContentEntity getContentEntity() {
@@ -26,28 +26,28 @@ public class SimpleTask implements Task 
     }
 
     @Override
-	public URI getURI() {
-		return uri;
-	}
-
-	@Override
-	public int getDepth() {
-		return depth;
-	}
-
-	@Override
-	public Date getTaskDate() {
-		return new Date();
-	}
-
-	@Override
-	public void abort() {
-		this.aborted = true;
-	}
-
-	@Override
-	public boolean isAborted() {
-		return this.aborted;
-	}
+    public URI getURI() {
+        return uri;
+    }
+
+    @Override
+    public int getDepth() {
+        return depth;
+    }
+
+    @Override
+    public Date getTaskDate() {
+        return new Date();
+    }
+
+    @Override
+    public void abort() {
+        this.aborted = true;
+    }
+
+    @Override
+    public boolean isAborted() {
+        return this.aborted;
+    }
 
 }

Modified: incubator/droids/branches/0.2.x-cleanup/droids-core/src/test/java/org/apache/droids/core/TestSimpleQueue.java
URL: http://svn.apache.org/viewvc/incubator/droids/branches/0.2.x-cleanup/droids-core/src/test/java/org/apache/droids/core/TestSimpleQueue.java?rev=1423322&r1=1423321&r2=1423322&view=diff
==============================================================================
--- incubator/droids/branches/0.2.x-cleanup/droids-core/src/test/java/org/apache/droids/core/TestSimpleQueue.java (original)
+++ incubator/droids/branches/0.2.x-cleanup/droids-core/src/test/java/org/apache/droids/core/TestSimpleQueue.java Tue Dec 18 08:41:30 2012
@@ -26,30 +26,30 @@ import org.junit.Test;
 
 public class TestSimpleQueue {
 
-	MaxDepthTaskFilter<SimpleTask> filter;
+    MaxDepthTaskFilter<SimpleTask> filter;
 
-	@Before
-	public final void initialize() {
-		filter = new MaxDepthTaskFilter<SimpleTask>();
-		filter.setMaxDepth(5);
-	}
-
-	@Test
-	public void whenTaskBelowMaxDepthIsValidated_thenTaskIsValid() throws Exception {
-		final SimpleTask task = new SimpleTask(new URI("http://www.example.com"), 3);
-		Assert.assertNotNull(filter.filter(task));
-	}
-
-	@Test
-	public void whenTaskEqualToMaxDepthIsValidated_thenTaskIsValid() throws Exception {
-		final SimpleTask task = new SimpleTask(new URI("http://www.example.com"), 5);
-		Assert.assertNotNull(filter.filter(task));
-	}
-
-	@Test
-	public void whenTaskOverMaxDepthIsValidated_thenTaskIsNotValid() throws Exception {
-		final SimpleTask task = new SimpleTask(new URI("http://www.example.com"), 7);
-		Assert.assertNull(filter.filter(task));
-	}
+    @Before
+    public final void initialize() {
+        filter = new MaxDepthTaskFilter<SimpleTask>();
+        filter.setMaxDepth(5);
+    }
+
+    @Test
+    public void whenTaskBelowMaxDepthIsValidated_thenTaskIsValid() throws Exception {
+        final SimpleTask task = new SimpleTask(new URI("http://www.example.com"), 3);
+        Assert.assertNotNull(filter.filter(task));
+    }
+
+    @Test
+    public void whenTaskEqualToMaxDepthIsValidated_thenTaskIsValid() throws Exception {
+        final SimpleTask task = new SimpleTask(new URI("http://www.example.com"), 5);
+        Assert.assertNotNull(filter.filter(task));
+    }
+
+    @Test
+    public void whenTaskOverMaxDepthIsValidated_thenTaskIsNotValid() throws Exception {
+        final SimpleTask task = new SimpleTask(new URI("http://www.example.com"), 7);
+        Assert.assertNull(filter.filter(task));
+    }
 
 }

Modified: incubator/droids/branches/0.2.x-cleanup/droids-core/src/test/java/org/apache/droids/core/TestSimpleTaskQueueWithHistory.java
URL: http://svn.apache.org/viewvc/incubator/droids/branches/0.2.x-cleanup/droids-core/src/test/java/org/apache/droids/core/TestSimpleTaskQueueWithHistory.java?rev=1423322&r1=1423321&r2=1423322&view=diff
==============================================================================
--- incubator/droids/branches/0.2.x-cleanup/droids-core/src/test/java/org/apache/droids/core/TestSimpleTaskQueueWithHistory.java (original)
+++ incubator/droids/branches/0.2.x-cleanup/droids-core/src/test/java/org/apache/droids/core/TestSimpleTaskQueueWithHistory.java Tue Dec 18 08:41:30 2012
@@ -30,59 +30,56 @@ import org.apache.droids.core.SimpleTask
 import org.apache.droids.core.Task;
 import org.junit.Test;
 
-public class TestSimpleTaskQueueWithHistory
-{
-  @Test
-  public void testOffer() throws Exception
-  {
-    Queue<Task> queue;
-    URI	uri;
-    Task task;
-
-    queue = new SimpleTaskQueueWithHistory<Task>();
-    Assert.assertEquals(0, queue.size());
-    uri = new URI("http://www.example.com");
-    Assert.assertNotNull(uri);
-    task = new SimpleTask(uri, 1);
-    Assert.assertNotNull(task);
-    queue.offer(task);
-    Assert.assertEquals(1, queue.size());
-    queue.offer(task);
-    Assert.assertEquals(1, queue.size());
-    queue.poll();
-    Assert.assertEquals(0, queue.size());
-    queue.offer(task);
-    Assert.assertEquals(0, queue.size());
-  }
-  
-  @Test
-  public void testAddAll() throws URISyntaxException 
-  {
-	  Collection<Task> links = new LinkedList<Task>();
-	  links.add(new SimpleTask(new URI("http://www.example.com"), 0));
-	  links.add(new SimpleTask(new URI("http://www.example.com/1"), 1));
-	  links.add(new SimpleTask(new URI("http://www.example.com/2"), 1));
-	  links.add(new SimpleTask(new URI("http://www.example.com/3"), 1));
-	  links.add(new SimpleTask(new URI("http://www.example.com/4"), 1));
-	  
-	  Queue<Task> queue = new SimpleTaskQueueWithHistory<Task>();
-	  assertEquals(0, queue.size());
-	  queue.addAll(links);
-	  assertEquals(5, queue.size());
-	  
-	  links.add(new SimpleTask(new URI("http://www.example.com/1"), 1));
-	  links.add(new SimpleTask(new URI("http://www.example.com/5"), 1));
-	  links.add(new SimpleTask(new URI("http://www.example.com/2"), 1));
-
-	  queue.addAll(links);
-	  assertEquals(6, queue.size());
-	  
-	  queue.poll();
+public class TestSimpleTaskQueueWithHistory {
+    @Test
+    public void testOffer() throws Exception {
+        Queue<Task> queue;
+        URI uri;
+        Task task;
+
+        queue = new SimpleTaskQueueWithHistory<Task>();
+        Assert.assertEquals(0, queue.size());
+        uri = new URI("http://www.example.com");
+        Assert.assertNotNull(uri);
+        task = new SimpleTask(uri, 1);
+        Assert.assertNotNull(task);
+        queue.offer(task);
+        Assert.assertEquals(1, queue.size());
+        queue.offer(task);
+        Assert.assertEquals(1, queue.size());
+        queue.poll();
+        Assert.assertEquals(0, queue.size());
+        queue.offer(task);
+        Assert.assertEquals(0, queue.size());
+    }
+
+    @Test
+    public void testAddAll() throws URISyntaxException {
+        Collection<Task> links = new LinkedList<Task>();
+        links.add(new SimpleTask(new URI("http://www.example.com"), 0));
+        links.add(new SimpleTask(new URI("http://www.example.com/1"), 1));
+        links.add(new SimpleTask(new URI("http://www.example.com/2"), 1));
+        links.add(new SimpleTask(new URI("http://www.example.com/3"), 1));
+        links.add(new SimpleTask(new URI("http://www.example.com/4"), 1));
+
+        Queue<Task> queue = new SimpleTaskQueueWithHistory<Task>();
+        assertEquals(0, queue.size());
+        queue.addAll(links);
+        assertEquals(5, queue.size());
+
+        links.add(new SimpleTask(new URI("http://www.example.com/1"), 1));
+        links.add(new SimpleTask(new URI("http://www.example.com/5"), 1));
+        links.add(new SimpleTask(new URI("http://www.example.com/2"), 1));
+
+        queue.addAll(links);
+        assertEquals(6, queue.size());
 
-	  assertEquals(5, queue.size());
+        queue.poll();
 
-	  queue.addAll(links);
-	  assertEquals(5, queue.size());
+        assertEquals(5, queue.size());
 
-  }
+        queue.addAll(links);
+        assertEquals(5, queue.size());
+
+    }
 }

Modified: incubator/droids/branches/0.2.x-cleanup/droids-core/src/test/java/org/apache/droids/delay/TestDelay.java
URL: http://svn.apache.org/viewvc/incubator/droids/branches/0.2.x-cleanup/droids-core/src/test/java/org/apache/droids/delay/TestDelay.java?rev=1423322&r1=1423321&r2=1423322&view=diff
==============================================================================
--- incubator/droids/branches/0.2.x-cleanup/droids-core/src/test/java/org/apache/droids/delay/TestDelay.java (original)
+++ incubator/droids/branches/0.2.x-cleanup/droids-core/src/test/java/org/apache/droids/delay/TestDelay.java Tue Dec 18 08:41:30 2012
@@ -20,43 +20,42 @@ import org.junit.Test;
 
 import junit.framework.Assert;
 
-public class TestDelay
-{
+public class TestDelay {
 
-  @Test
-  public void testTimers()
-  {
-    int i=0;
-    int min = 10;
-    int spread = 100;
-    RandomDelayTimer timer = new RandomDelayTimer( min, spread );
-    for( i=0; i<100; i++ ) {
-      long delay = timer.getDelayMillis();
-      Assert.assertTrue( delay >= min );
-      Assert.assertTrue( delay < (min+spread) );
-    }
-    min = 300; spread = 20;
-    timer.setDelaySpread( spread );
-    timer.setMinimumDelay( min );
-    for( i=0; i<100; i++ ) {
-      long delay = timer.getDelayMillis();
-      Assert.assertTrue( delay >= min );
-      Assert.assertTrue( delay < (min+spread) );
-    }
-    
-    timer = new GaussianRandomDelayTimer( min, spread );
-    for( i=0; i<100; i++ ) {
-      long delay = timer.getDelayMillis();
-      Assert.assertTrue( "DELAY:"+delay, delay >= min );
-      Assert.assertTrue( "DELAY:"+delay, delay < (min+(spread*4)) );
+    @Test
+    public void testTimers() {
+        int i = 0;
+        int min = 10;
+        int spread = 100;
+        RandomDelayTimer timer = new RandomDelayTimer(min, spread);
+        for (i = 0; i < 100; i++) {
+            long delay = timer.getDelayMillis();
+            Assert.assertTrue(delay >= min);
+            Assert.assertTrue(delay < (min + spread));
+        }
+        min = 300;
+        spread = 20;
+        timer.setDelaySpread(spread);
+        timer.setMinimumDelay(min);
+        for (i = 0; i < 100; i++) {
+            long delay = timer.getDelayMillis();
+            Assert.assertTrue(delay >= min);
+            Assert.assertTrue(delay < (min + spread));
+        }
+
+        timer = new GaussianRandomDelayTimer(min, spread);
+        for (i = 0; i < 100; i++) {
+            long delay = timer.getDelayMillis();
+            Assert.assertTrue("DELAY:" + delay, delay >= min);
+            Assert.assertTrue("DELAY:" + delay, delay < (min + (spread * 4)));
+        }
+
+        DelayTimer t = new SimpleDelayTimer(1000);
+        Assert.assertTrue(1000 == t.getDelayMillis());
+
+        // default timers all have time zero
+        Assert.assertEquals(0, new SimpleDelayTimer().getDelayMillis());
+        Assert.assertEquals(0, new RandomDelayTimer().getDelayMillis());
+        Assert.assertEquals(0, new GaussianRandomDelayTimer().getDelayMillis());
     }
-    
-    DelayTimer t = new SimpleDelayTimer( 1000 );
-    Assert.assertTrue( 1000 == t.getDelayMillis() );
-    
-    // default timers all have time zero
-    Assert.assertEquals( 0, new SimpleDelayTimer().getDelayMillis() );
-    Assert.assertEquals( 0, new RandomDelayTimer().getDelayMillis() );
-    Assert.assertEquals( 0, new GaussianRandomDelayTimer().getDelayMillis() );
-  }
 }

Modified: incubator/droids/branches/0.2.x-cleanup/droids-walker/pom.xml
URL: http://svn.apache.org/viewvc/incubator/droids/branches/0.2.x-cleanup/droids-walker/pom.xml?rev=1423322&r1=1423321&r2=1423322&view=diff
==============================================================================
--- incubator/droids/branches/0.2.x-cleanup/droids-walker/pom.xml (original)
+++ incubator/droids/branches/0.2.x-cleanup/droids-walker/pom.xml Tue Dec 18 08:41:30 2012
@@ -1,35 +1,36 @@
 <?xml version="1.0"?>
-<project xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd" xmlns="http://maven.apache.org/POM/4.0.0"
-    xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance">
-  <modelVersion>4.0.0</modelVersion>
-  <packaging>jar</packaging>
+<project xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd"
+         xmlns="http://maven.apache.org/POM/4.0.0"
+         xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance">
+    <modelVersion>4.0.0</modelVersion>
+    <packaging>jar</packaging>
 
-  <parent>
-    <groupId>org.apache.droids</groupId>
-    <artifactId>droids</artifactId>
-    <version>0.3.0-incubating-SNAPSHOT</version>
-  </parent>
+    <parent>
+        <groupId>org.apache.droids</groupId>
+        <artifactId>droids</artifactId>
+        <version>0.3.0-incubating-SNAPSHOT</version>
+    </parent>
 
-  <artifactId>droids-walker</artifactId>
-  <name>APACHE DROIDS WALKER</name>
+    <artifactId>droids-walker</artifactId>
+    <name>APACHE DROIDS WALKER</name>
 
-  <dependencies>
-    <dependency>
-      <groupId>org.apache.droids</groupId>
-      <artifactId>droids-core</artifactId>
-      <version>${project.version}</version>
-    </dependency>
-    <dependency>
-      <groupId>junit</groupId>
-      <artifactId>junit</artifactId>
-      <version>${junit.version}</version>
-      <scope>test</scope>
-    </dependency>
-    <dependency>
-      <groupId>ch.qos.logback</groupId>
-      <artifactId>logback-classic</artifactId>
-      <version>${logback.version}</version>
-      <scope>test</scope>
-    </dependency>
-  </dependencies>
+    <dependencies>
+        <dependency>
+            <groupId>org.apache.droids</groupId>
+            <artifactId>droids-core</artifactId>
+            <version>${project.version}</version>
+        </dependency>
+        <dependency>
+            <groupId>junit</groupId>
+            <artifactId>junit</artifactId>
+            <version>${junit.version}</version>
+            <scope>test</scope>
+        </dependency>
+        <dependency>
+            <groupId>ch.qos.logback</groupId>
+            <artifactId>logback-classic</artifactId>
+            <version>${logback.version}</version>
+            <scope>test</scope>
+        </dependency>
+    </dependencies>
 </project>

Modified: incubator/droids/branches/0.2.x-cleanup/droids-walker/src/main/java/org/apache/droids/protocol/file/FileProtocol.java
URL: http://svn.apache.org/viewvc/incubator/droids/branches/0.2.x-cleanup/droids-walker/src/main/java/org/apache/droids/protocol/file/FileProtocol.java?rev=1423322&r1=1423321&r2=1423322&view=diff
==============================================================================
--- incubator/droids/branches/0.2.x-cleanup/droids-walker/src/main/java/org/apache/droids/protocol/file/FileProtocol.java (original)
+++ incubator/droids/branches/0.2.x-cleanup/droids-walker/src/main/java/org/apache/droids/protocol/file/FileProtocol.java Tue Dec 18 08:41:30 2012
@@ -27,12 +27,10 @@ import org.apache.droids.core.Task;
 import org.apache.droids.walker.FileTask;
 
 /**
- * 
  * Protocol implementation for system-independent
  * file and directory pathnames based on java.io.File.
- * 
+ *
  * @version 1.0
- * 
  */
 public class FileProtocol implements Protocol {
 
@@ -42,30 +40,30 @@ public class FileProtocol implements Pro
     }
 
     @Override
-  public boolean isAllowed(URI uri) {
-    File file = new File(extractLocation(uri));
-    return file.canRead();
-  }
-
-  @Override
-  public Task load(URI uri) throws IOException {
-    File file = new File(extractLocation(uri));
-    return new FileTask(file);
-  }
-
-  /**
-   * Removes the scheme from the URI to get the pathname of the file.
-   * 
-   * @param uri The URI of the file
-   * @return	The pathname of the file
-   */
-  private String extractLocation(URI uri) {
-    String location = uri.toString();
-    final int start = location.indexOf("://");
-    if(start>-1){
-      location = location.substring(start+3);
+    public boolean isAllowed(URI uri) {
+        File file = new File(extractLocation(uri));
+        return file.canRead();
     }
-    return location;
-  }
-  
+
+    @Override
+    public Task load(URI uri) throws IOException {
+        File file = new File(extractLocation(uri));
+        return new FileTask(file);
+    }
+
+    /**
+     * Removes the scheme from the URI to get the pathname of the file.
+     *
+     * @param uri The URI of the file
+     * @return The pathname of the file
+     */
+    private String extractLocation(URI uri) {
+        String location = uri.toString();
+        final int start = location.indexOf("://");
+        if (start > -1) {
+            location = location.substring(start + 3);
+        }
+        return location;
+    }
+
 }

Modified: incubator/droids/branches/0.2.x-cleanup/droids-walker/src/main/java/org/apache/droids/walker/FileTask.java
URL: http://svn.apache.org/viewvc/incubator/droids/branches/0.2.x-cleanup/droids-walker/src/main/java/org/apache/droids/walker/FileTask.java?rev=1423322&r1=1423321&r2=1423322&view=diff
==============================================================================
--- incubator/droids/branches/0.2.x-cleanup/droids-walker/src/main/java/org/apache/droids/walker/FileTask.java (original)
+++ incubator/droids/branches/0.2.x-cleanup/droids-walker/src/main/java/org/apache/droids/walker/FileTask.java Tue Dec 18 08:41:30 2012
@@ -28,64 +28,64 @@ import org.apache.droids.core.ContentEnt
 import org.apache.droids.core.Task;
 
 public class FileTask implements Task {
-	private static final long serialVersionUID = 122177113684842951L;
+    private static final long serialVersionUID = 122177113684842951L;
 
     private ContentEntity contentEntity;
-	private final Date started;
-	private final int depth;
-	private final File file;
-	private boolean aborted = false;
+    private final Date started;
+    private final int depth;
+    private final File file;
+    private boolean aborted = false;
 
     public FileTask(File file) {
-		this.file = file;
-		this.depth = 0;
-		this.started = new Date();
+        this.file = file;
+        this.depth = 0;
+        this.started = new Date();
         this.contentEntity = new ContentEntity();
-	}
+    }
 
-	public FileTask(File file, int depth) {
-		this.file = file;
-		this.depth = depth;
-		this.started = new Date();
+    public FileTask(File file, int depth) {
+        this.file = file;
+        this.depth = depth;
+        this.started = new Date();
         this.contentEntity = new ContentEntity();
-	}
+    }
 
     @Override
     public ContentEntity getContentEntity() {
         return contentEntity;
     }
 
-	@Override
-	public URI getURI() {
-		return file.toURI();
-	}
-
-	@Override
-	public Date getTaskDate() {
-		return started;
-	}
-
-	@Override
-	public int getDepth() {
-		return depth;
-	}
-
-	public File getFile() {
-		return file;
-	}
-
-	@Override
-	public String toString() {
-		return "Task[" + depth + "][" + file.getAbsolutePath() + "]";
-	}
-
-	@Override
-	public void abort() {
-		aborted = true;
-	}
-
-	@Override
-	public boolean isAborted() {
-		return aborted;
-	}
+    @Override
+    public URI getURI() {
+        return file.toURI();
+    }
+
+    @Override
+    public Date getTaskDate() {
+        return started;
+    }
+
+    @Override
+    public int getDepth() {
+        return depth;
+    }
+
+    public File getFile() {
+        return file;
+    }
+
+    @Override
+    public String toString() {
+        return "Task[" + depth + "][" + file.getAbsolutePath() + "]";
+    }
+
+    @Override
+    public void abort() {
+        aborted = true;
+    }
+
+    @Override
+    public boolean isAborted() {
+        return aborted;
+    }
 }
\ No newline at end of file

Modified: incubator/droids/branches/0.2.x-cleanup/droids-walker/src/main/java/org/apache/droids/walker/WalkingDroid.java
URL: http://svn.apache.org/viewvc/incubator/droids/branches/0.2.x-cleanup/droids-walker/src/main/java/org/apache/droids/walker/WalkingDroid.java?rev=1423322&r1=1423321&r2=1423322&view=diff
==============================================================================
--- incubator/droids/branches/0.2.x-cleanup/droids-walker/src/main/java/org/apache/droids/walker/WalkingDroid.java (original)
+++ incubator/droids/branches/0.2.x-cleanup/droids-walker/src/main/java/org/apache/droids/walker/WalkingDroid.java Tue Dec 18 08:41:30 2012
@@ -21,9 +21,9 @@ import java.util.Collection;
 
 import org.apache.droids.core.Droid;
 
-public interface WalkingDroid extends Droid<FileTask>
-{
-  public void setInitialFiles(Collection<File> initialFiles);
-  public FileWorker getNewWorker();
+public interface WalkingDroid extends Droid<FileTask> {
+    public void setInitialFiles(Collection<File> initialFiles);
+
+    public FileWorker getNewWorker();
 }
 

Modified: incubator/droids/branches/0.2.x-cleanup/droids-walker/src/test/java/org/apache/droids/walker/WalkingDroidTest.java
URL: http://svn.apache.org/viewvc/incubator/droids/branches/0.2.x-cleanup/droids-walker/src/test/java/org/apache/droids/walker/WalkingDroidTest.java?rev=1423322&r1=1423321&r2=1423322&view=diff
==============================================================================
--- incubator/droids/branches/0.2.x-cleanup/droids-walker/src/test/java/org/apache/droids/walker/WalkingDroidTest.java (original)
+++ incubator/droids/branches/0.2.x-cleanup/droids-walker/src/test/java/org/apache/droids/walker/WalkingDroidTest.java Tue Dec 18 08:41:30 2012
@@ -6,6 +6,7 @@ import org.apache.droids.filter.RegexURL
 import org.apache.droids.handle.SysoutHandler;
 import org.apache.droids.parse.FileNameParser;
 import org.junit.Test;
+
 import static org.junit.Assert.assertEquals;
 
 import java.io.File;
@@ -15,21 +16,21 @@ import java.util.Queue;
 
 public class WalkingDroidTest {
 
-	@Test
-	public void testWalkingDroid() throws NullPointerException {
-		Queue<FileTask> queue = new LinkedList<FileTask>();
-		TaskMaster<FileTask> taskMaster = new SequentialTaskMaster<FileTask>();
+    @Test
+    public void testWalkingDroid() throws NullPointerException {
+        Queue<FileTask> queue = new LinkedList<FileTask>();
+        TaskMaster<FileTask> taskMaster = new SequentialTaskMaster<FileTask>();
 
-		Collection<File> initialFiles = new LinkedList<File>();
+        Collection<File> initialFiles = new LinkedList<File>();
 
-	    initialFiles.add(new File(this.getClass().getClassLoader().getResource("docs").getFile()));
+        initialFiles.add(new File(this.getClass().getClassLoader().getResource("docs").getFile()));
 
-		SimpleWalkingDroid droid = new SimpleWalkingDroid(queue, taskMaster);
-		droid.setInitialFiles(initialFiles);
+        SimpleWalkingDroid droid = new SimpleWalkingDroid(queue, taskMaster);
+        droid.setInitialFiles(initialFiles);
         droid.addParsers(new FileNameParser());
         droid.addHandlers(new SysoutHandler());
 
-		droid.start();
+        droid.start();
 
         assertEquals(19, taskMaster.getCompletedTasks());
     }

Modified: incubator/droids/branches/0.2.x-cleanup/droids-walker/src/test/resources/logback.xml
URL: http://svn.apache.org/viewvc/incubator/droids/branches/0.2.x-cleanup/droids-walker/src/test/resources/logback.xml?rev=1423322&r1=1423321&r2=1423322&view=diff
==============================================================================
--- incubator/droids/branches/0.2.x-cleanup/droids-walker/src/test/resources/logback.xml (original)
+++ incubator/droids/branches/0.2.x-cleanup/droids-walker/src/test/resources/logback.xml Tue Dec 18 08:41:30 2012
@@ -12,6 +12,6 @@
 
 
     <root level="error">
-        <appender-ref ref="STDOUT" />
+        <appender-ref ref="STDOUT"/>
     </root>
 </configuration>
\ No newline at end of file

Modified: incubator/droids/branches/0.2.x-cleanup/pom.xml
URL: http://svn.apache.org/viewvc/incubator/droids/branches/0.2.x-cleanup/pom.xml?rev=1423322&r1=1423321&r2=1423322&view=diff
==============================================================================
--- incubator/droids/branches/0.2.x-cleanup/pom.xml (original)
+++ incubator/droids/branches/0.2.x-cleanup/pom.xml Tue Dec 18 08:41:30 2012
@@ -14,348 +14,351 @@
    WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
    See the License for the specific language governing permissions and
    limitations under the License.
---><project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/maven-v4_0_0.xsd">
+-->
+<project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+         xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/maven-v4_0_0.xsd">
+
+    <modelVersion>4.0.0</modelVersion>
+    <parent>
+        <groupId>org.apache</groupId>
+        <artifactId>apache</artifactId>
+        <version>10</version>
+    </parent>
+    <groupId>org.apache.droids</groupId>
+    <artifactId>droids</artifactId>
+    <version>0.3.0-incubating-SNAPSHOT</version>
+    <name>Apache Droids</name>
+    <inceptionYear>2007</inceptionYear>
+    <description>
+        Apache Droids - an intelligent robot framework
+    </description>
+    <url>http://incubator.apache.org/droids/</url>
+    <packaging>pom</packaging>
+
+    <licenses>
+        <license>
+            <name>Apache License</name>
+            <url>http://www.apache.org/licenses/LICENSE-2.0.html</url>
+            <distribution>repo</distribution>
+        </license>
+    </licenses>
+
+    <scm>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/incubator/droids/trunk/</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/incubator/droids/trunk/</developerConnection>
+        <url>http://svn.apache.org/repos/asf/incubator/droids/trunk/</url>
+    </scm>
+    <issueManagement>
+        <system>jira</system>
+        <url>http://issues.apache.org/jira/browse/DROIDS</url>
+    </issueManagement>
+
+    <mailingLists>
+        <mailingList>
+            <name>Droids Development List</name>
+            <post>droids-dev@incubator.apache.org</post>
+            <subscribe>droids-dev-subscribe@incubator.apache.org</subscribe>
+            <unsubscribe>droids-dev-unsubscribe@incubator.apache.org</unsubscribe>
+            <archive>http://mail-archives.apache.org/mod_mbox/incubator-droids-dev/</archive>
+        </mailingList>
+        <mailingList>
+            <name>Droids Commits List</name>
+            <post>droids-commits@incubator.apache.org</post>
+            <subscribe>droids-commits-subscribe@incubator.apache.org</subscribe>
+            <unsubscribe>droids-commits-unsubscribe@incubator.apache.org</unsubscribe>
+            <archive>http://mail-archives.apache.org/mod_mbox/incubator-droids-commits/</archive>
+        </mailingList>
+    </mailingLists>
+
+    <distributionManagement>
+        <repository>
+            <id>apache.releases.https</id>
+            <name>Apache Release Distribution Repository</name>
+            <url>https://repository.apache.org/service/local/staging/deploy/maven2</url>
+        </repository>
+        <snapshotRepository>
+            <id>apache.snapshots.https</id>
+            <name>${distMgmtSnapshotsName}</name>
+            <url>${distMgmtSnapshotsUrl}</url>
+        </snapshotRepository>
+        <site>
+            <id>apache.droids.site</id>
+            <name>Apache Droids Site Location</name>
+            <url>target/staging</url>
+        </site>
+    </distributionManagement>
+
+    <developers>
+        <developer>
+            <name>Bertil Chapuis</name>
+            <id>bchapuis</id>
+            <email>bchapuis -at- apache.org</email>
+            <roles>
+                <role>Committer</role>
+            </roles>
+            <timezone/>
+        </developer>
+        <developer>
+            <name>Grant Ingersoll</name>
+            <id>gsingers</id>
+            <email>gsingers -at- apache.org</email>
+            <roles>
+                <role>Committer</role>
+                <role>PMC</role>
+            </roles>
+            <timezone/>
+        </developer>
+        <developer>
+            <name>Javier Puerto</name>
+            <id>javier</id>
+            <email>javier -at- apache.org</email>
+            <roles>
+                <role>Committer</role>
+            </roles>
+            <timezone/>
+        </developer>
+        <developer>
+            <name>Ma Ming Fai</name>
+            <id>mingfai</id>
+            <email>mingfai -at- apache.org</email>
+            <roles>
+                <role>Committer</role>
+            </roles>
+            <timezone/>
+        </developer>
+        <developer>
+            <name>Oleg Kalnichevski</name>
+            <id>olegk</id>
+            <email>olegk -at- apache.org</email>
+            <roles>
+                <role>Committer</role>
+                <role>PMC</role>
+            </roles>
+            <timezone/>
+        </developer>
+        <developer>
+            <name>Richard Frovarp</name>
+            <id>rfrovarp</id>
+            <email>rfrovarp -at- apache.org</email>
+            <roles>
+                <role>Committer</role>
+                <role>PMC</role>
+            </roles>
+            <timezone/>
+        </developer>
+        <developer>
+            <name>Ryan McKinley</name>
+            <id>ryan</id>
+            <email>ryan -at- apache.org</email>
+            <roles>
+                <role>Committer</role>
+            </roles>
+            <timezone/>
+        </developer>
+        <developer>
+            <name>Thorsten Scherler</name>
+            <id>thorsten</id>
+            <email>thorsten -at- apache.org</email>
+            <roles>
+                <role>Committer</role>
+                <role>PMC</role>
+            </roles>
+            <timezone/>
+        </developer>
+        <developer>
+            <name>Tobias Rübner</name>
+            <id>tobr</id>
+            <email>tobr -at- apache.org</email>
+            <roles>
+                <role>Committer</role>
+            </roles>
+            <timezone/>
+        </developer>
+    </developers>
+
+    <properties>
+        <maven.compile.source>1.6</maven.compile.source>
+        <maven.compile.target>1.6</maven.compile.target>
+        <maven.compile.optimize>true</maven.compile.optimize>
+        <maven.compile.deprecation>true</maven.compile.deprecation>
+        <commons-io.version>2.1</commons-io.version>
+        <httpclient.version>4.2</httpclient.version>
+        <nekohtml.version>1.9.15</nekohtml.version>
+        <slf4j.version>1.6.4</slf4j.version>
+        <logback.version>1.0.7</logback.version>
+        <junit.version>4.10</junit.version>
+    </properties>
 
-  <modelVersion>4.0.0</modelVersion>
-  <parent>
-    <groupId>org.apache</groupId>
-    <artifactId>apache</artifactId>
-    <version>10</version>
-  </parent>
-  <groupId>org.apache.droids</groupId>
-  <artifactId>droids</artifactId>
-  <version>0.3.0-incubating-SNAPSHOT</version>
-  <name>Apache Droids</name>
-  <inceptionYear>2007</inceptionYear>
-  <description>
-   Apache Droids - an intelligent robot framework
-  </description>
-  <url>http://incubator.apache.org/droids/</url>
-  <packaging>pom</packaging>
-
-  <licenses>
-    <license>
-      <name>Apache License</name>
-      <url>http://www.apache.org/licenses/LICENSE-2.0.html</url>
-      <distribution>repo</distribution>
-    </license>
-  </licenses>
-
-  <scm>
-    <connection>scm:svn:http://svn.apache.org/repos/asf/incubator/droids/trunk/</connection>
-    <developerConnection>scm:svn:https://svn.apache.org/repos/asf/incubator/droids/trunk/</developerConnection>
-    <url>http://svn.apache.org/repos/asf/incubator/droids/trunk/</url>
-  </scm>
-  <issueManagement>
-    <system>jira</system>
-    <url>http://issues.apache.org/jira/browse/DROIDS</url>
-  </issueManagement>
-
-  <mailingLists>
-    <mailingList>
-      <name>Droids Development List</name>
-      <post>droids-dev@incubator.apache.org</post>
-      <subscribe>droids-dev-subscribe@incubator.apache.org</subscribe>
-      <unsubscribe>droids-dev-unsubscribe@incubator.apache.org</unsubscribe>
-      <archive>http://mail-archives.apache.org/mod_mbox/incubator-droids-dev/</archive>
-    </mailingList>
-    <mailingList>
-      <name>Droids Commits List</name>
-      <post>droids-commits@incubator.apache.org</post>
-      <subscribe>droids-commits-subscribe@incubator.apache.org</subscribe>
-      <unsubscribe>droids-commits-unsubscribe@incubator.apache.org</unsubscribe>
-      <archive>http://mail-archives.apache.org/mod_mbox/incubator-droids-commits/</archive>
-    </mailingList>
-  </mailingLists>
-
-	<distributionManagement>
-    <repository>
-      <id>apache.releases.https</id>
-      <name>Apache Release Distribution Repository</name>
-      <url>https://repository.apache.org/service/local/staging/deploy/maven2</url>
-    </repository>
-    <snapshotRepository>
-      <id>apache.snapshots.https</id>
-      <name>${distMgmtSnapshotsName}</name>
-      <url>${distMgmtSnapshotsUrl}</url>
-    </snapshotRepository>
-		<site>
-			<id>apache.droids.site</id>
-			<name>Apache Droids Site Location</name>
-			<url>target/staging</url>
-		</site>
-  </distributionManagement>
-
-  <developers>
-    <developer>
-      <name>Bertil Chapuis</name>
-      <id>bchapuis</id>
-      <email>bchapuis -at- apache.org</email>
-      <roles>
-        <role>Committer</role>
-      </roles>
-      <timezone/>
-    </developer>
-    <developer>
-      <name>Grant Ingersoll</name>
-      <id>gsingers</id>
-      <email>gsingers -at- apache.org</email>
-      <roles>
-        <role>Committer</role>
-        <role>PMC</role>
-      </roles>
-      <timezone/>
-    </developer>
-    <developer>
-      <name>Javier Puerto</name>
-      <id>javier</id>
-      <email>javier -at- apache.org</email>
-      <roles>
-        <role>Committer</role>
-      </roles>
-      <timezone/>
-    </developer>
-    <developer>
-      <name>Ma Ming Fai</name>
-      <id>mingfai</id>
-      <email>mingfai -at- apache.org</email>
-      <roles>
-        <role>Committer</role>
-      </roles>
-      <timezone/>
-    </developer>
-    <developer>
-      <name>Oleg Kalnichevski</name>
-      <id>olegk</id>
-      <email>olegk -at- apache.org</email>
-      <roles>
-        <role>Committer</role>
-        <role>PMC</role>
-      </roles>
-      <timezone/>
-    </developer>
-    <developer>
-      <name>Richard Frovarp</name>
-      <id>rfrovarp</id>
-      <email>rfrovarp -at- apache.org</email>
-      <roles>
-        <role>Committer</role>
-        <role>PMC</role>
-      </roles>
-      <timezone/>
-    </developer>
-    <developer>
-      <name>Ryan McKinley</name>
-      <id>ryan</id>
-      <email>ryan -at- apache.org</email>
-      <roles>
-        <role>Committer</role>
-      </roles>
-      <timezone/>
-    </developer>
-    <developer>
-      <name>Thorsten Scherler</name>
-      <id>thorsten</id>
-      <email>thorsten -at- apache.org</email>
-      <roles>
-        <role>Committer</role>
-        <role>PMC</role>
-      </roles>
-      <timezone/>
-    </developer>    
-    <developer>
-      <name>Tobias Rübner</name>
-      <id>tobr</id>
-      <email>tobr -at- apache.org</email>
-      <roles>
-        <role>Committer</role>
-      </roles>
-      <timezone/>
-    </developer>
-  </developers>
-
-  <properties>
-    <maven.compile.source>1.6</maven.compile.source>
-    <maven.compile.target>1.6</maven.compile.target>
-    <maven.compile.optimize>true</maven.compile.optimize>
-    <maven.compile.deprecation>true</maven.compile.deprecation>
-    <commons-io.version>2.1</commons-io.version>
-    <httpclient.version>4.2</httpclient.version>
-    <nekohtml.version>1.9.15</nekohtml.version>
-    <slf4j.version>1.6.4</slf4j.version>
-    <logback.version>1.0.7</logback.version>
-    <junit.version>4.10</junit.version>
-  </properties>
-
-  <build>
-    <plugins>
-      <plugin>
-        <groupId>org.apache.maven.plugins</groupId>
-        <artifactId>maven-compiler-plugin</artifactId>
-        <configuration>
-          <source>${maven.compile.source}</source>
-          <target>${maven.compile.target}</target>
-          <optimize>${maven.compile.optimize}</optimize>
-          <showDeprecations>${maven.compile.deprecation}</showDeprecations>
-        </configuration>
-      </plugin>
-      <plugin>
-        <groupId>org.apache.maven.plugins</groupId>
-        <artifactId>maven-eclipse-plugin</artifactId>
-        <configuration>
-          <downloadSources>true</downloadSources>
-        </configuration>
-        <version>2.8</version>
-      </plugin>
-      <plugin>
-        <groupId>org.apache.maven.plugins</groupId>
-        <artifactId>maven-surefire-plugin</artifactId>
-        <inherited>true</inherited>
-      </plugin>
-      <plugin>
-        <groupId>org.codehaus.mojo</groupId>
-        <artifactId>surefire-report-maven-plugin</artifactId>
-        <inherited>true</inherited>
-        <version>2.0-beta-1</version>
-      </plugin>
-
-      <plugin>
-         <!-- Add SVN Revision To A JAR Manifest
-            - http://maven.apache.org/plugin-developers/cookbook/add-svn-revision-to-manifest.html
-           -->
-        <groupId>org.codehaus.mojo</groupId>
-        <artifactId>buildnumber-maven-plugin</artifactId>
-        <version>1.0</version>
-        <executions>
-          <execution>
-            <phase>validate</phase>
-            <goals>
-              <goal>create</goal>
-            </goals>
-          </execution>
-        </executions>
-        <configuration>
-          <doCheck>false</doCheck>
-          <doUpdate>false</doUpdate>
-        </configuration>
-      </plugin>
-
-      <plugin>
-        <groupId>org.apache.maven.plugins</groupId>
-        <artifactId>maven-jar-plugin</artifactId>
-        <configuration>
-          <archive>
-            <addMavenDescriptor>false</addMavenDescriptor>
-            <manifestEntries>
-              <Specification-Title>Apache ${project.name}</Specification-Title>
-              <Specification-Version>${project.version}</Specification-Version>
-              <Specification-Vendor>The Apache Software Foundation</Specification-Vendor>
-              <Implementation-Title>${project.name}</Implementation-Title>
-              <Implementation-Version>${project.version} ${buildNumber} - ${user.name}</Implementation-Version>
-              <Implementation-Vendor>The Apache Software Foundation</Implementation-Vendor>
-              <SCM-Revision>${buildNumber}</SCM-Revision>
-              <SCM-url>${project.scm.url}</SCM-url>
-            </manifestEntries>
-          </archive>
-        </configuration>
-      </plugin>
-
-    </plugins>
-  </build>
-
-  <!-- apache gpg profile -->
-  <profiles>
-    <profile>
-      <id>release-sign-artifacts</id>
-      <activation>
-        <property>
-          <name>performRelease</name>
-          <value>true</value>
-        </property>
-      </activation>
-      <build>
+    <build>
         <plugins>
-          <plugin>
-            <groupId>org.apache.maven.plugins</groupId>
-            <artifactId>maven-gpg-plugin</artifactId>
-            <version>1.4</version>
-            <executions>
-              <execution>
-                <id>sign-artifacts</id>
-                <phase>verify</phase>
-                <goals>
-                  <goal>sign</goal>
-                </goals>
-              </execution>
-            </executions>
-          </plugin>
+            <plugin>
+                <groupId>org.apache.maven.plugins</groupId>
+                <artifactId>maven-compiler-plugin</artifactId>
+                <configuration>
+                    <source>${maven.compile.source}</source>
+                    <target>${maven.compile.target}</target>
+                    <optimize>${maven.compile.optimize}</optimize>
+                    <showDeprecations>${maven.compile.deprecation}</showDeprecations>
+                </configuration>
+            </plugin>
+            <plugin>
+                <groupId>org.apache.maven.plugins</groupId>
+                <artifactId>maven-eclipse-plugin</artifactId>
+                <configuration>
+                    <downloadSources>true</downloadSources>
+                </configuration>
+                <version>2.8</version>
+            </plugin>
+            <plugin>
+                <groupId>org.apache.maven.plugins</groupId>
+                <artifactId>maven-surefire-plugin</artifactId>
+                <inherited>true</inherited>
+            </plugin>
+            <plugin>
+                <groupId>org.codehaus.mojo</groupId>
+                <artifactId>surefire-report-maven-plugin</artifactId>
+                <inherited>true</inherited>
+                <version>2.0-beta-1</version>
+            </plugin>
+
+            <plugin>
+                <!-- Add SVN Revision To A JAR Manifest
+                   - http://maven.apache.org/plugin-developers/cookbook/add-svn-revision-to-manifest.html
+                  -->
+                <groupId>org.codehaus.mojo</groupId>
+                <artifactId>buildnumber-maven-plugin</artifactId>
+                <version>1.0</version>
+                <executions>
+                    <execution>
+                        <phase>validate</phase>
+                        <goals>
+                            <goal>create</goal>
+                        </goals>
+                    </execution>
+                </executions>
+                <configuration>
+                    <doCheck>false</doCheck>
+                    <doUpdate>false</doUpdate>
+                </configuration>
+            </plugin>
+
+            <plugin>
+                <groupId>org.apache.maven.plugins</groupId>
+                <artifactId>maven-jar-plugin</artifactId>
+                <configuration>
+                    <archive>
+                        <addMavenDescriptor>false</addMavenDescriptor>
+                        <manifestEntries>
+                            <Specification-Title>Apache ${project.name}</Specification-Title>
+                            <Specification-Version>${project.version}</Specification-Version>
+                            <Specification-Vendor>The Apache Software Foundation</Specification-Vendor>
+                            <Implementation-Title>${project.name}</Implementation-Title>
+                            <Implementation-Version>${project.version} ${buildNumber} - ${user.name}
+                            </Implementation-Version>
+                            <Implementation-Vendor>The Apache Software Foundation</Implementation-Vendor>
+                            <SCM-Revision>${buildNumber}</SCM-Revision>
+                            <SCM-url>${project.scm.url}</SCM-url>
+                        </manifestEntries>
+                    </archive>
+                </configuration>
+            </plugin>
+
+        </plugins>
+    </build>
+
+    <!-- apache gpg profile -->
+    <profiles>
+        <profile>
+            <id>release-sign-artifacts</id>
+            <activation>
+                <property>
+                    <name>performRelease</name>
+                    <value>true</value>
+                </property>
+            </activation>
+            <build>
+                <plugins>
+                    <plugin>
+                        <groupId>org.apache.maven.plugins</groupId>
+                        <artifactId>maven-gpg-plugin</artifactId>
+                        <version>1.4</version>
+                        <executions>
+                            <execution>
+                                <id>sign-artifacts</id>
+                                <phase>verify</phase>
+                                <goals>
+                                    <goal>sign</goal>
+                                </goals>
+                            </execution>
+                        </executions>
+                    </plugin>
+                </plugins>
+            </build>
+        </profile>
+    </profiles>
+
+    <reporting>
+        <plugins>
+            <plugin>
+                <inherited>true</inherited>
+                <groupId>org.apache.maven.plugins</groupId>
+                <artifactId>maven-project-info-reports-plugin</artifactId>
+                <version>2.4</version>
+                <reportSets>
+                    <reportSet>
+                        <reports>
+                            <report>index</report>
+                            <report>project-team</report>
+                            <report>license</report>
+                            <report>mailing-list</report>
+                            <report>issue-tracking</report>
+                            <report>scm</report>
+                        </reports>
+                    </reportSet>
+                </reportSets>
+            </plugin>
+            <plugin>
+                <inherited>true</inherited>
+                <groupId>org.apache.maven.plugins</groupId>
+                <artifactId>maven-javadoc-plugin</artifactId>
+                <version>2.8</version>
+            </plugin>
         </plugins>
-      </build>
-    </profile>
-  </profiles>
-
-  <reporting>
-    <plugins>
-      <plugin>
-        <inherited>true</inherited>
-        <groupId>org.apache.maven.plugins</groupId>
-        <artifactId>maven-project-info-reports-plugin</artifactId>
-        <version>2.4</version>
-        <reportSets>
-          <reportSet>
-            <reports>
-              <report>index</report>
-              <report>project-team</report>
-              <report>license</report>
-              <report>mailing-list</report>
-              <report>issue-tracking</report>
-              <report>scm</report>
-            </reports>
-          </reportSet>
-        </reportSets>
-      </plugin>
-      <plugin>
-        <inherited>true</inherited>
-        <groupId>org.apache.maven.plugins</groupId>
-        <artifactId>maven-javadoc-plugin</artifactId>
-        <version>2.8</version>
-      </plugin>
-    </plugins>
-  </reporting>
-
-  <repositories>
-    <repository>
-      <id>org.apache.people</id>
-      <name>Apache Snapshot Repository</name>
-      <url>http://repository.apache.org/snapshots</url>
-      <snapshots>
-        <enabled>true</enabled>
-      </snapshots>
-      <releases>
-        <enabled>true</enabled>
-      </releases>
-    </repository>
-  </repositories>
-
-  <!-- DROIDS-70 / INFRA-2368 -->
-<!--  <distributionManagement>
-      <snapshotRepository>
-        <id>org.apache.people</id>
-        <name>Snapshot Repository</name>
-        <url>scp://people.apache.org/www/people.apache.org/repo/m2-snapshot-repository</url>
-      </snapshotRepository>
-  </distributionManagement>-->
-
-
-  <modules>
-    <module>droids-core</module>
-    <module>droids-norobots</module>
-    <!--module>droids-spring</module>
-    <module>droids-solr</module>
-    <module>droids-tika</module>
-    <module>droids-examples</module>
-    <module>droids-crawler</module-->
-    <module>droids-walker</module>
-  </modules>
+    </reporting>
+
+    <repositories>
+        <repository>
+            <id>org.apache.people</id>
+            <name>Apache Snapshot Repository</name>
+            <url>http://repository.apache.org/snapshots</url>
+            <snapshots>
+                <enabled>true</enabled>
+            </snapshots>
+            <releases>
+                <enabled>true</enabled>
+            </releases>
+        </repository>
+    </repositories>
+
+    <!-- DROIDS-70 / INFRA-2368 -->
+    <!--  <distributionManagement>
+          <snapshotRepository>
+            <id>org.apache.people</id>
+            <name>Snapshot Repository</name>
+            <url>scp://people.apache.org/www/people.apache.org/repo/m2-snapshot-repository</url>
+          </snapshotRepository>
+      </distributionManagement>-->
+
+
+    <modules>
+        <module>droids-core</module>
+        <module>droids-norobots</module>
+        <!--module>droids-spring</module>
+        <module>droids-solr</module>
+        <module>droids-tika</module>
+        <module>droids-examples</module>
+        <module>droids-crawler</module-->
+        <module>droids-walker</module>
+    </modules>
 
 </project>
\ No newline at end of file

Modified: incubator/droids/branches/0.2.x-cleanup/src/site/resources/css/site.css
URL: http://svn.apache.org/viewvc/incubator/droids/branches/0.2.x-cleanup/src/site/resources/css/site.css?rev=1423322&r1=1423321&r2=1423322&view=diff
==============================================================================
--- incubator/droids/branches/0.2.x-cleanup/src/site/resources/css/site.css (original)
+++ incubator/droids/branches/0.2.x-cleanup/src/site/resources/css/site.css Tue Dec 18 08:41:30 2012
@@ -18,9 +18,9 @@
  */
 
 .droidsFooter {
-	margin-top: 6px;
+    margin-top: 6px;
 }
 
 .droidsFooter p {
-	margin-bottom: 0px;
+    margin-bottom: 0px;
 }

Modified: incubator/droids/branches/0.2.x-cleanup/src/site/site.xml
URL: http://svn.apache.org/viewvc/incubator/droids/branches/0.2.x-cleanup/src/site/site.xml?rev=1423322&r1=1423321&r2=1423322&view=diff
==============================================================================
--- incubator/droids/branches/0.2.x-cleanup/src/site/site.xml (original)
+++ incubator/droids/branches/0.2.x-cleanup/src/site/site.xml Tue Dec 18 08:41:30 2012
@@ -10,61 +10,72 @@
 	OF ANY KIND, either express or implied. See the License for the specific 
 	language governing permissions and limitations under the License. -->
 <project name="Apache Droids">
-	<skin>
-		<groupId>org.apache.maven.skins</groupId>
-		<artifactId>maven-fluido-skin</artifactId>
-		<version>1.3.0</version>
-	</skin>
-	<bannerLeft>
-		<name>Apache Droids</name>
-		<src>images/droids-logo.png</src>
-		<href>https://incubator.apache.org/droids/</href>
-	</bannerLeft>
-	<bannerRight>
-		<name>Apache Incubator</name>
-		<src>images/apache-egg-logo.png</src>
-		<href>https://incubator.apache.org/</href>
-	</bannerRight>
-	<body>
-		<links>
-			<item name="Apache" href="http://www.apache.org/" />
-      <item name="Apache Incubator" href="https://incubator.apache.org/" />
-		</links>
-		<menu name="Apache Droids">
-			<item name="Overview" href="index.html" />
-      <item name="News" href="news.html" />
-      <item name="Features" href="features.html" />
-      <item name="Download" href="download.html" />
-			<item name="Team" href="team-list.html" />
-			<item name="Get Involved" href="get-involved.html" />
-		</menu>
-		<menu name="Documentation">
-			<item name="Install" href="install.html" />
-			<item name="Getting started" href="getting-started.html" />
-			<item name="Wiki (old)" href="https://cwiki.apache.org/confluence/display/DROIDS/Index" />
-		</menu>
-		<menu name="Resources">
-			<item name="Issue Tracking" href="issue-tracking.html" />
-			<item name="Mailing Lists" href="mail-lists.html" />
-			<item name="Source Repository" href="source-repository.html" />
-      <item name="Javadoc" href="apidocs/index.html" />
-		</menu>
-    <menu ref="modules" />
-		<menu name="ASF links">
-      <item name="Apache Software Foundation" href="http://www.apache.org/" />
-      <item name="License" href="http://www.apache.org/licenses/LICENSE-2.0" />
-      <item name="Thanks" href="http://www.apache.org/foundation/thanks.html" />
-      <item name="Become a Sponsor" href="http://www.apache.org/foundation/sponsorship.html" />
-    </menu>
+    <skin>
+        <groupId>org.apache.maven.skins</groupId>
+        <artifactId>maven-fluido-skin</artifactId>
+        <version>1.3.0</version>
+    </skin>
+    <bannerLeft>
+        <name>Apache Droids</name>
+        <src>images/droids-logo.png</src>
+        <href>https://incubator.apache.org/droids/</href>
+    </bannerLeft>
+    <bannerRight>
+        <name>Apache Incubator</name>
+        <src>images/apache-egg-logo.png</src>
+        <href>https://incubator.apache.org/</href>
+    </bannerRight>
+    <body>
+        <links>
+            <item name="Apache" href="http://www.apache.org/"/>
+            <item name="Apache Incubator" href="https://incubator.apache.org/"/>
+        </links>
+        <menu name="Apache Droids">
+            <item name="Overview" href="index.html"/>
+            <item name="News" href="news.html"/>
+            <item name="Features" href="features.html"/>
+            <item name="Download" href="download.html"/>
+            <item name="Team" href="team-list.html"/>
+            <item name="Get Involved" href="get-involved.html"/>
+        </menu>
+        <menu name="Documentation">
+            <item name="Install" href="install.html"/>
+            <item name="Getting started" href="getting-started.html"/>
+            <item name="Wiki (old)" href="https://cwiki.apache.org/confluence/display/DROIDS/Index"/>
+        </menu>
+        <menu name="Resources">
+            <item name="Issue Tracking" href="issue-tracking.html"/>
+            <item name="Mailing Lists" href="mail-lists.html"/>
+            <item name="Source Repository" href="source-repository.html"/>
+            <item name="Javadoc" href="apidocs/index.html"/>
+        </menu>
+        <menu ref="modules"/>
+        <menu name="ASF links">
+            <item name="Apache Software Foundation" href="http://www.apache.org/"/>
+            <item name="License" href="http://www.apache.org/licenses/LICENSE-2.0"/>
+            <item name="Thanks" href="http://www.apache.org/foundation/thanks.html"/>
+            <item name="Become a Sponsor" href="http://www.apache.org/foundation/sponsorship.html"/>
+        </menu>
 
-    <footer><div class="row span16 droidsFooter"><p>Apache Droids is an effort undergoing incubation at The Apache Software
-Foundation (ASF), sponsored by Apache Lucene PMC.</p>
-<p>Incubation is required of all newly accepted projects until a further review
-indicates that the infrastructure, communications, and decision making process
-have stabilized in a manner consistent with other successful ASF projects.</p>
-<p>While incubation status is not necessarily a reflection of the completeness
-or stability of the code, it does indicate that the project has yet to be
-fully endorsed by the ASF.</p></div>
-<div class="row span16 droidsFooter"><p>Apache and the Apache feather logos are trademarks of The Apache Software Foundation. Other names appearing on the site may be trademarks of their respective owners.</p></div></footer>
-	</body>
+        <footer>
+            <div class="row span16 droidsFooter">
+                <p>Apache Droids is an effort undergoing incubation at The Apache Software
+                    Foundation (ASF), sponsored by Apache Lucene PMC.
+                </p>
+                <p>Incubation is required of all newly accepted projects until a further review
+                    indicates that the infrastructure, communications, and decision making process
+                    have stabilized in a manner consistent with other successful ASF projects.
+                </p>
+                <p>While incubation status is not necessarily a reflection of the completeness
+                    or stability of the code, it does indicate that the project has yet to be
+                    fully endorsed by the ASF.
+                </p>
+            </div>
+            <div class="row span16 droidsFooter">
+                <p>Apache and the Apache feather logos are trademarks of The Apache Software Foundation. Other names
+                    appearing on the site may be trademarks of their respective owners.
+                </p>
+            </div>
+        </footer>
+    </body>
 </project>