You are viewing a plain text version of this content. The canonical link for it is here.
Posted to cvs@avalon.apache.org by je...@apache.org on 2001/12/11 10:53:39 UTC

cvs commit: jakarta-avalon-excalibur/src/test/org/apache/avalon/excalibur/property/test PropertyUtilTestCase.java

jefft       01/12/11 01:53:39

  Modified:    .        build.xml
               src/java/org/apache/avalon/excalibur/cli
                        AbstractParserControl.java CLArgsParser.java
                        CLOption.java CLOptionDescriptor.java CLUtil.java
                        ParserControl.java Token.java
               src/java/org/apache/avalon/excalibur/collections
                        ArrayEnumeration.java ArrayStack.java
                        BinaryHeap.java CircularBuffer.java
                        IteratorEnumeration.java ListUtils.java
                        PriorityQueue.java SynchronizedPriorityQueue.java
               src/java/org/apache/avalon/excalibur/component
                        ComponentHandler.java DefaultComponentFactory.java
                        DefaultComponentHandler.java
                        DefaultComponentManager.java
                        DefaultComponentPool.java
                        DefaultComponentPoolController.java
                        DefaultComponentSelector.java
                        DefaultRoleManager.java
                        ExcaliburComponentManager.java
                        ExcaliburComponentSelector.java
                        PoolableComponentHandler.java RoleManageable.java
                        RoleManager.java ThreadSafeComponentHandler.java
               src/java/org/apache/avalon/excalibur/concurrent
                        ConditionalEvent.java DijkstraSemaphore.java
                        DjikstraSemaphore.java Lock.java Mutex.java
                        ReadWriteLock.java Semaphore.java Sync.java
                        ThreadBarrier.java
               src/java/org/apache/avalon/excalibur/datasource
                        AbstractJdbcConnection.java
                        DataSourceComponent.java InformixDataSource.java
                        J2eeDataSource.java Jdbc3Connection.java
                        JdbcConnection.java JdbcConnectionFactory.java
                        JdbcConnectionPool.java JdbcDataSource.java
                        NoAvailableConnectionException.java
                        NoValidConnectionException.java
               src/java/org/apache/avalon/excalibur/i18n
                        ResourceManager.java Resources.java
               src/java/org/apache/avalon/excalibur/io AndFileFilter.java
                        ClassLoaderObjectInputStream.java
                        DirectoryFileFilter.java EndianUtil.java
                        ExtensionFileFilter.java FileUtil.java IOUtil.java
                        InvertedFileFilter.java OrFileFilter.java
                        PrefixFileFilter.java SwappedDataInputStream.java
               src/java/org/apache/avalon/excalibur/logger
                        DefaultLogKitManager.java
                        DefaultLogTargetFactoryManager.java
                        DefaultLogTargetManager.java LogKitManageable.java
                        LogKitManager.java LogTargetFactory.java
                        LogTargetFactoryManageable.java
                        LogTargetFactoryManager.java LogTargetManager.java
               src/java/org/apache/avalon/excalibur/logger/factory
                        AbstractTargetFactory.java
                        AsyncLogTargetFactory.java FileTargetFactory.java
                        JDBCTargetFactory.java
                        PriorityFilterTargetFactory.java
                        ServletTargetFactory.java StreamTargetFactory.java
               src/java/org/apache/avalon/excalibur/monitor
                        ActiveMonitor.java FileResource.java
                        Modifiable.java Monitor.java PassiveMonitor.java
                        Resource.java ResourceOutputStream.java
                        ResourceWriter.java StreamResource.java
               src/java/org/apache/avalon/excalibur/naming
                        AbstractContext.java AbstractLocalContext.java
                        AbstractNamespace.java
                        AbstractNamingEnumeration.java
                        AbstractURLContext.java ArrayNamingEnumeration.java
                        DefaultNameParser.java DefaultNamespace.java
                        Namespace.java NamingProvider.java
                        RemoteContext.java StandardNamespace.java
               src/java/org/apache/avalon/excalibur/naming/memory
                        MemoryContext.java MemoryInitialContextFactory.java
                        MemoryNamingEnumeration.java
               src/java/org/apache/avalon/excalibur/naming/rmi
                        RMIInitialContextFactory.java
                        RMINamingProvider.java
               src/java/org/apache/avalon/excalibur/naming/rmi/server
                        Main.java RMINamingProviderImpl.java
               src/java/org/apache/avalon/excalibur/pool AbstractPool.java
                        DefaultObjectFactory.java DefaultPool.java
                        DefaultPoolController.java
                        HardResourceLimitingPool.java ObjectFactory.java
                        Pool.java PoolController.java Poolable.java
                        Recyclable.java Resizable.java
                        SingleThreadedPool.java
                        SoftResourceLimitingPool.java
               src/java/org/apache/avalon/excalibur/property
                        PropertyException.java PropertyUtil.java
               src/java/org/apache/avalon/excalibur/proxy DynamicProxy.java
               src/java/org/apache/avalon/excalibur/testcase
                        CascadingAssertionFailedError.java
                        ExcaliburTestCase.java
               src/java/org/apache/avalon/excalibur/xml/xpath
                        JaxenProcessorImpl.java XPathProcessor.java
                        XPathProcessorImpl.java
               src/scratchpad/org/apache/avalon/excalibur/cache
                        AbstractCache.java AbstractCacheStore.java
                        Cache.java CacheEvent.java CacheListener.java
                        CacheStore.java CacheValidator.java
                        DefaultCache.java FIFOCachePolicy.java
                        LRUCache.java LRUCachePolicy.java
                        ListCachePolicy.java MemoryCacheStore.java
                        ReplacementPolicy.java TimeoutValidator.java
               src/scratchpad/org/apache/avalon/excalibur/cache/test
                        LRUCacheTestCase.java TimeoutValidatorTestCase.java
               src/scratchpad/org/apache/avalon/excalibur/catalog
                        Catalog.java CatalogEntityResolver.java
                        CatalogEntry.java CatalogReader.java
                        InvalidCatalogEntryException.java
                        InvalidCatalogEntryTypeException.java
                        NoXMLParserException.java
                        NotXMLCatalogException.java
                        UnknownCatalogFormatException.java
                        XMLCatalogReader.java
               src/scratchpad/org/apache/avalon/excalibur/container
                        AbstractContainer.java Container.java
                        ContainerException.java Entry.java Info.java
                        Locator.java State.java
               src/scratchpad/org/apache/avalon/excalibur/extension
                        DefaultPackageRepository.java Extension.java
                        OptionalPackage.java PackageManager.java
                        PackageRepository.java
                        UnsatisfiedExtensionException.java
               src/scratchpad/org/apache/avalon/excalibur/extension/test
                        ExtensionTestCase.java
                        PackageRepositoryTestCase.java
               src/scratchpad/org/apache/avalon/excalibur/i18n
                        AbstractBundle.java Bundle.java BundleInfo.java
                        BundleInfoMapper.java BundleLoader.java
                        BundleMatcher.java BundleSelector.java
                        DefaultBundleLoader.java DefaultBundleMatcher.java
                        DefaultMapper.java DirectoryMapper.java
                        FlatXmlBundle.java XmlBundle.java
               src/scratchpad/org/apache/avalon/excalibur/i18n/test
                        AbstractBundleTestCase.java
                        DefaultBundleLoaderTestCase.java
                        DefaultBundleMatcherTestCase.java
                        XmlBundleTestCase.java
               src/scratchpad/org/apache/avalon/excalibur/i18n/util
                        ResourceCheck.java
               src/scratchpad/org/apache/avalon/excalibur/lang
                        DefaultThreadContextPolicy.java Layer.java
                        LayeredThreadContext.java ThreadContext.java
                        ThreadContextAccessor.java ThreadContextPolicy.java
               src/scratchpad/org/apache/avalon/excalibur/pipeline
                        DefaultPipeline.java Pipeline.java
                        ProcessorPipeline.java ProcessorStage.java
                        Stage.java
               src/scratchpad/org/apache/avalon/excalibur/source
                        ModifiableSource.java Source.java
                        SourceFactory.java SourceParameters.java
                        SourceResolver.java SourceResolverImpl.java
                        SourceUtil.java URLSource.java
               src/scratchpad/org/apache/avalon/excalibur/thread
                        ThreadControl.java ThreadPool.java
               src/scratchpad/org/apache/avalon/excalibur/thread/impl
                        DefaultThreadControl.java DefaultThreadPool.java
                        ExecutableRunnable.java WorkerThread.java
               src/scratchpad/org/apache/avalon/excalibur/util Circuit.java
                        CircularDependencyException.java
                        ComponentStateValidator.java DeweyDecimal.java
                        StackIntrospector.java StringUtil.java
               src/scratchpad/org/apache/avalon/excalibur/util/test
                        ComponentTestCase.java DeweyDecimalTestCase.java
                        FullLifecycleComponent.java StringUtilTestCase.java
               src/scratchpad/org/apache/avalon/excalibur/vfs
                        DefaultVFileSystem.java.old
                        DirectoryVFileAccessor.java VFile.java
                        VFileAccessor.java VFileFilter.java
                        VFileSystem.java ZipVFileAccessor.java
               src/scratchpad/org/apache/avalon/excalibur/xml
                        AbstractXMLConsumer.java ContentHandlerWrapper.java
                        JaxpParser.java Parser.java XMLConsumer.java
                        XMLFragment.java XMLizable.java XercesParser.java
               src/test/org/apache/avalon/excalibur/cli/test
                        ClutilTestCase.java
               src/test/org/apache/avalon/excalibur/collections/test
                        BinaryHeapTestCase.java
               src/test/org/apache/avalon/excalibur/concurrent/test
                        ReadWriteLockTestCase.java
               src/test/org/apache/avalon/excalibur/datasource/test
                        DataSourceTestCase.java
               src/test/org/apache/avalon/excalibur/i18n/test
                        ResourceManagerTestCase.java
               src/test/org/apache/avalon/excalibur/io/test
                        FileUtilTestCase.java IOUtilTestCase.java
               src/test/org/apache/avalon/excalibur/logger/test
                        LogKitManagementTest.java
                        LogKitManagementTestCase.java TestComponent.java
                        TestComponentImpl.java
               src/test/org/apache/avalon/excalibur/monitor/test
                        MonitorTestCase.java
               src/test/org/apache/avalon/excalibur/naming/memory/test
                        MemoryContextTestCase.java
               src/test/org/apache/avalon/excalibur/naming/rmi/test
                        RMIContextTestCase.java
               src/test/org/apache/avalon/excalibur/naming/test
                        AbstractContextTestCase.java
               src/test/org/apache/avalon/excalibur/pool/test
                        PoolProfile.java
               src/test/org/apache/avalon/excalibur/property/test
                        PropertyUtilTestCase.java
  Added:       .        LICENSE.txt README.txt
               lib      README.txt
  Removed:     .        LICENSE README
               lib      README
  Log:
  - Give LICENSE and README a .txt suffix, for the benefit of Windows users.
  
  Revision  Changes    Path
  1.80      +4 -4      jakarta-avalon-excalibur/build.xml
  
  Index: build.xml
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/build.xml,v
  retrieving revision 1.79
  retrieving revision 1.80
  diff -u -r1.79 -r1.80
  --- build.xml	2001/11/21 21:26:53	1.79
  +++ build.xml	2001/12/11 09:53:26	1.80
  @@ -560,8 +560,8 @@
   
       <copy todir="${dist.dir}">
         <fileset dir=".">
  -        <include name="README"/>
  -        <include name="LICENSE"/>
  +        <include name="README.txt"/>
  +		<include name="LICENSE.txt"/>
           <include name="KEYS"/>
         </fileset>
       </copy>
  @@ -666,8 +666,8 @@
   
       <copy todir="${src.dist.dir}">
         <fileset dir=".">
  -        <include name="README"/>
  -        <include name="LICENSE"/>
  +        <include name="README.txt"/>
  +        <include name="LICENSE.txt"/>
           <include name="build.bat"/>
           <include name="build.sh"/>
           <include name="build.xml"/>
  
  
  
  1.1                  jakarta-avalon-excalibur/LICENSE.txt
  
  Index: LICENSE.txt
  ===================================================================
  /*
  
   ============================================================================
                     The Apache Software License, Version 1.1
   ============================================================================
   
   Copyright (C) @year@ The Apache Software Foundation. All rights reserved.
   
   Redistribution and use in source and binary forms, with or without modifica-
   tion, are permitted provided that the following conditions are met:
   
   1. Redistributions of  source code must  retain the above copyright  notice,
      this list of conditions and the following disclaimer.
   
   2. Redistributions in binary form must reproduce the above copyright notice,
      this list of conditions and the following disclaimer in the documentation
      and/or other materials provided with the distribution.
   
   3. The end-user documentation included with the redistribution, if any, must
      include  the following  acknowledgment:  "This product includes  software
      developed  by the  Apache Software Foundation  (http://www.apache.org/)."
      Alternately, this  acknowledgment may  appear in the software itself,  if
      and wherever such third-party acknowledgments normally appear.
   
   4. The names "Jakarta", "Avalon", "Excalibur" and "Apache Software Foundation"  
      must not be used to endorse or promote products derived from this  software 
      without  prior written permission. For written permission, please contact 
      apache@apache.org.
   
   5. Products  derived from this software may not  be called "Apache", nor may
      "Apache" appear  in their name,  without prior written permission  of the
      Apache Software Foundation.
   
   THIS SOFTWARE IS PROVIDED ``AS IS'' AND ANY EXPRESSED OR IMPLIED WARRANTIES,
   INCLUDING, BUT NOT LIMITED TO, THE IMPLIED WARRANTIES OF MERCHANTABILITY AND
   FITNESS  FOR A PARTICULAR  PURPOSE ARE  DISCLAIMED.  IN NO  EVENT SHALL  THE
   APACHE SOFTWARE  FOUNDATION  OR ITS CONTRIBUTORS  BE LIABLE FOR  ANY DIRECT,
   INDIRECT, INCIDENTAL, SPECIAL,  EXEMPLARY, OR CONSEQUENTIAL  DAMAGES (INCLU-
   DING, BUT NOT LIMITED TO, PROCUREMENT  OF SUBSTITUTE GOODS OR SERVICES; LOSS
   OF USE, DATA, OR  PROFITS; OR BUSINESS  INTERRUPTION)  HOWEVER CAUSED AND ON
   ANY  THEORY OF LIABILITY,  WHETHER  IN CONTRACT,  STRICT LIABILITY,  OR TORT
   (INCLUDING  NEGLIGENCE OR  OTHERWISE) ARISING IN  ANY WAY OUT OF THE  USE OF
   THIS SOFTWARE, EVEN IF ADVISED OF THE POSSIBILITY OF SUCH DAMAGE.
   
   This software  consists of voluntary contributions made  by many individuals
   on  behalf of the Apache Software  Foundation and was  originally created by
   Stefano Mazzocchi  <st...@apache.org>. For more  information on the Apache 
   Software Foundation, please see <http://www.apache.org/>.
   
  */
  
  
  
  1.1                  jakarta-avalon-excalibur/README.txt
  
  Index: README.txt
  ===================================================================
  
                                  E X C A L I B U R
  
    What is it?
    -----------
  
    Excalibur is a collection of often-needed reusable components. It includes tools for
    threading, pooling, datasources, CLI option parsing and more.
  
    Where is it?
    ------------
  
    http://jakarta.apache.org/avalon
  
    Requirements
    ------------
  
    -JDK1.2 or above
    -To build from CVS you must set JAVA_HOME to the jdk dir (eg:/usr/bin/jdk1.2 or
     c:\jdk1.3)
    -To build Informix drivers you need version 2.2 of the JDBC driver
    -To build J2EE client for connections you need JNDI and the JDBC extensions
  
    Does it pass it's internal tests?
    ---------------------------------
  
    You can browse the results of our unit testing in the filesystem.  If this is
    a distribution, the results should be in docs/test.  Point your browser at the
    index.html file and browse away.  If you want to generate the tests and run them
    for yourself, you need to check this project out from CVS and the "jakarta-avalon"
    project (which has the libraries to build everything).  After that, you can type
    "./build.sh test" for UNIX or "build test" for Windows.
  
  
  1.1                  jakarta-avalon-excalibur/lib/README.txt
  
  Index: README.txt
  ===================================================================
  Place any third party jars here.
  
  You can find the latest Jaxen at:
  http://sourceforge.net/project/showfiles.php?group_id=31447
  
  
  
  1.5       +1 -1      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/cli/AbstractParserControl.java
  
  Index: AbstractParserControl.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/cli/AbstractParserControl.java,v
  retrieving revision 1.4
  retrieving revision 1.5
  diff -u -r1.4 -r1.5
  --- AbstractParserControl.java	2001/11/19 12:08:46	1.4
  +++ AbstractParserControl.java	2001/12/11 09:53:26	1.5
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.cli;
   
  
  
  
  1.9       +1 -1      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/cli/CLArgsParser.java
  
  Index: CLArgsParser.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/cli/CLArgsParser.java,v
  retrieving revision 1.8
  retrieving revision 1.9
  diff -u -r1.8 -r1.9
  --- CLArgsParser.java	2001/11/19 12:08:46	1.8
  +++ CLArgsParser.java	2001/12/11 09:53:26	1.9
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.cli;
   
  
  
  
  1.5       +1 -1      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/cli/CLOption.java
  
  Index: CLOption.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/cli/CLOption.java,v
  retrieving revision 1.4
  retrieving revision 1.5
  diff -u -r1.4 -r1.5
  --- CLOption.java	2001/11/19 12:08:46	1.4
  +++ CLOption.java	2001/12/11 09:53:26	1.5
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.cli;
   
  
  
  
  1.6       +1 -1      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/cli/CLOptionDescriptor.java
  
  Index: CLOptionDescriptor.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/cli/CLOptionDescriptor.java,v
  retrieving revision 1.5
  retrieving revision 1.6
  diff -u -r1.5 -r1.6
  --- CLOptionDescriptor.java	2001/11/19 12:08:46	1.5
  +++ CLOptionDescriptor.java	2001/12/11 09:53:26	1.6
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.cli;
   
  
  
  
  1.7       +1 -1      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/cli/CLUtil.java
  
  Index: CLUtil.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/cli/CLUtil.java,v
  retrieving revision 1.6
  retrieving revision 1.7
  diff -u -r1.6 -r1.7
  --- CLUtil.java	2001/11/19 12:08:46	1.6
  +++ CLUtil.java	2001/12/11 09:53:26	1.7
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.cli;
   
  
  
  
  1.4       +1 -1      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/cli/ParserControl.java
  
  Index: ParserControl.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/cli/ParserControl.java,v
  retrieving revision 1.3
  retrieving revision 1.4
  diff -u -r1.3 -r1.4
  --- ParserControl.java	2001/11/19 12:08:46	1.3
  +++ ParserControl.java	2001/12/11 09:53:26	1.4
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.cli;
   
  
  
  
  1.4       +1 -1      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/cli/Token.java
  
  Index: Token.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/cli/Token.java,v
  retrieving revision 1.3
  retrieving revision 1.4
  diff -u -r1.3 -r1.4
  --- Token.java	2001/11/19 12:08:46	1.3
  +++ Token.java	2001/12/11 09:53:26	1.4
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.cli;
   
  
  
  
  1.4       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/collections/ArrayEnumeration.java
  
  Index: ArrayEnumeration.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/collections/ArrayEnumeration.java,v
  retrieving revision 1.3
  retrieving revision 1.4
  diff -u -r1.3 -r1.4
  --- ArrayEnumeration.java	2001/11/19 12:08:46	1.3
  +++ ArrayEnumeration.java	2001/12/11 09:53:26	1.4
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.collections;
   
  @@ -15,7 +15,7 @@
    * Enumeration wrapper for array.
    *
    * @author <a href="mailto:peter@apache.org">Peter Donald</a>
  - * @version CVS $Revision: 1.3 $ $Date: 2001/11/19 12:08:46 $
  + * @version CVS $Revision: 1.4 $ $Date: 2001/12/11 09:53:26 $
    * @since 4.0
    */
   public final class ArrayEnumeration
  
  
  
  1.4       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/collections/ArrayStack.java
  
  Index: ArrayStack.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/collections/ArrayStack.java,v
  retrieving revision 1.3
  retrieving revision 1.4
  diff -u -r1.3 -r1.4
  --- ArrayStack.java	2001/11/19 12:08:46	1.3
  +++ ArrayStack.java	2001/12/11 09:53:26	1.4
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.collections;
   
  @@ -14,7 +14,7 @@
    * Unsynchronized stakc.
    *
    * @author <a href="mailto:peter@apache.org">Peter Donald</a>
  - * @version CVS $Revision: 1.3 $ $Date: 2001/11/19 12:08:46 $
  + * @version CVS $Revision: 1.4 $ $Date: 2001/12/11 09:53:26 $
    * @since 4.0
    */
   public class ArrayStack
  
  
  
  1.7       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/collections/BinaryHeap.java
  
  Index: BinaryHeap.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/collections/BinaryHeap.java,v
  retrieving revision 1.6
  retrieving revision 1.7
  diff -u -r1.6 -r1.7
  --- BinaryHeap.java	2001/11/27 11:29:42	1.6
  +++ BinaryHeap.java	2001/12/11 09:53:26	1.7
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.collections;
   
  @@ -18,7 +18,7 @@
    * @author <a href="mailto:peter@apache.org">Peter Donald</a>
    * @author <a href="mailto:ram.chidambaram@telus.com">Ram Chidambaram</a>
    * @author <a href="mailto:stansburyc@earthlink.net">Chad Stansbury</a>
  - * @version CVS $Revision: 1.6 $ $Date: 2001/11/27 11:29:42 $
  + * @version CVS $Revision: 1.7 $ $Date: 2001/12/11 09:53:26 $
    * @since 4.0
    */
   public final class BinaryHeap
  
  
  
  1.3       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/collections/CircularBuffer.java
  
  Index: CircularBuffer.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/collections/CircularBuffer.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- CircularBuffer.java	2001/08/07 10:57:04	1.2
  +++ CircularBuffer.java	2001/12/11 09:53:27	1.3
  @@ -3,14 +3,14 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.collections;
   
   /**
    *
    * @author  Federico Barbieri <fe...@apache.org>
  - * @version CVS $Revision: 1.2 $ $Date: 2001/08/07 10:57:04 $
  + * @version CVS $Revision: 1.3 $ $Date: 2001/12/11 09:53:27 $
    * @since 4.0
    */
   public class CircularBuffer
  
  
  
  1.4       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/collections/IteratorEnumeration.java
  
  Index: IteratorEnumeration.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/collections/IteratorEnumeration.java,v
  retrieving revision 1.3
  retrieving revision 1.4
  diff -u -r1.3 -r1.4
  --- IteratorEnumeration.java	2001/11/19 12:08:46	1.3
  +++ IteratorEnumeration.java	2001/12/11 09:53:27	1.4
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.collections;
   
  @@ -14,7 +14,7 @@
    * Enumeration wrapper for iterator.
    *
    * @author <a href="mailto:peter@apache.org">Peter Donald</a>
  - * @version CVS $Revision: 1.3 $ $Date: 2001/11/19 12:08:46 $
  + * @version CVS $Revision: 1.4 $ $Date: 2001/12/11 09:53:27 $
    * @since 4.0
    */
   public final class IteratorEnumeration
  
  
  
  1.5       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/collections/ListUtils.java
  
  Index: ListUtils.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/collections/ListUtils.java,v
  retrieving revision 1.4
  retrieving revision 1.5
  diff -u -r1.4 -r1.5
  --- ListUtils.java	2001/11/19 12:08:46	1.4
  +++ ListUtils.java	2001/12/11 09:53:27	1.5
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.collections;
   
  @@ -16,7 +16,7 @@
    *
    * @author  <a href="mailto:fede@apache.org">Federico Barbieri</a>
    * @author  <a href="mailto:peter@apache.org">Peter Donald</a>
  - * @version CVS $Revision: 1.4 $ $Date: 2001/11/19 12:08:46 $
  + * @version CVS $Revision: 1.5 $ $Date: 2001/12/11 09:53:27 $
    * @since 4.0
    */
   public class ListUtils
  
  
  
  1.5       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/collections/PriorityQueue.java
  
  Index: PriorityQueue.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/collections/PriorityQueue.java,v
  retrieving revision 1.4
  retrieving revision 1.5
  diff -u -r1.4 -r1.5
  --- PriorityQueue.java	2001/11/19 12:08:46	1.4
  +++ PriorityQueue.java	2001/12/11 09:53:27	1.5
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.collections;
   
  @@ -14,7 +14,7 @@
    * This interface does not dictate whether it is min or max heap.
    *
    * @author <a href="mailto:peter@apache.org">Peter Donald</a>
  - * @version CVS $Revision: 1.4 $ $Date: 2001/11/19 12:08:46 $
  + * @version CVS $Revision: 1.5 $ $Date: 2001/12/11 09:53:27 $
    * @since 4.0
    */
   public interface PriorityQueue
  
  
  
  1.5       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/collections/SynchronizedPriorityQueue.java
  
  Index: SynchronizedPriorityQueue.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/collections/SynchronizedPriorityQueue.java,v
  retrieving revision 1.4
  retrieving revision 1.5
  diff -u -r1.4 -r1.5
  --- SynchronizedPriorityQueue.java	2001/11/13 09:39:02	1.4
  +++ SynchronizedPriorityQueue.java	2001/12/11 09:53:27	1.5
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.collections;
   
  @@ -15,7 +15,7 @@
    * defined in the PriorityQueue interface.
    *
    * @author <a href="mailto:ram.chidambaram@telus.com">Ram Chidambaram</a>
  - * @version CVS $Revision: 1.4 $ $Date: 2001/11/13 09:39:02 $
  + * @version CVS $Revision: 1.5 $ $Date: 2001/12/11 09:53:27 $
    * @since 4.0
    */
   public final class SynchronizedPriorityQueue
  
  
  
  1.4       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/component/ComponentHandler.java
  
  Index: ComponentHandler.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/component/ComponentHandler.java,v
  retrieving revision 1.3
  retrieving revision 1.4
  diff -u -r1.3 -r1.4
  --- ComponentHandler.java	2001/08/25 14:52:59	1.3
  +++ ComponentHandler.java	2001/12/11 09:53:27	1.4
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.component;
   
  @@ -24,7 +24,7 @@
    * of the ComponentHandler that you need.
    *
    * @author <a href="mailto:bloritsch@apache.org">Berin Loritsch</a>
  - * @version CVS $Revision: 1.3 $ $Date: 2001/08/25 14:52:59 $
  + * @version CVS $Revision: 1.4 $ $Date: 2001/12/11 09:53:27 $
    * @since 4.0
    */
   public abstract class ComponentHandler extends AbstractLoggable
  
  
  
  1.10      +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/component/DefaultComponentFactory.java
  
  Index: DefaultComponentFactory.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/component/DefaultComponentFactory.java,v
  retrieving revision 1.9
  retrieving revision 1.10
  diff -u -r1.9 -r1.10
  --- DefaultComponentFactory.java	2001/11/01 14:25:57	1.9
  +++ DefaultComponentFactory.java	2001/12/11 09:53:27	1.10
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.component;
   
  @@ -32,7 +32,7 @@
    *
    * @author <a href="mailto:bloritsch@apache.org">Berin Loritsch</a>
    * @author <a href="mailto:paul@luminas.co.uk">Paul Russell</a>
  - * @version CVS $Revision: 1.9 $ $Date: 2001/11/01 14:25:57 $
  + * @version CVS $Revision: 1.10 $ $Date: 2001/12/11 09:53:27 $
    * @since 4.0
    */
   public class DefaultComponentFactory
  
  
  
  1.7       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/component/DefaultComponentHandler.java
  
  Index: DefaultComponentHandler.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/component/DefaultComponentHandler.java,v
  retrieving revision 1.6
  retrieving revision 1.7
  diff -u -r1.6 -r1.7
  --- DefaultComponentHandler.java	2001/11/01 14:25:57	1.6
  +++ DefaultComponentHandler.java	2001/12/11 09:53:27	1.7
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.component;
   
  @@ -21,7 +21,7 @@
    * and destroyed correctly.
    *
    * @author <a href="mailto:bloritsch@apache.org">Berin Loritsch</a>
  - * @version CVS $Revision: 1.6 $ $Date: 2001/11/01 14:25:57 $
  + * @version CVS $Revision: 1.7 $ $Date: 2001/12/11 09:53:27 $
    * @since 4.0
    */
   class DefaultComponentHandler
  
  
  
  1.3       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/component/DefaultComponentManager.java
  
  Index: DefaultComponentManager.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/component/DefaultComponentManager.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- DefaultComponentManager.java	2001/08/07 10:57:05	1.2
  +++ DefaultComponentManager.java	2001/12/11 09:53:27	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included  with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.component;
   
  @@ -12,7 +12,7 @@
    *
    * @author <a href="mailto:bloritsch@apache.org">Berin Loritsch</a>
    * @author <a href="mailto:paul@luminas.co.uk">Paul Russell</a>
  - * @version CVS $Revision: 1.2 $ $Date: 2001/08/07 10:57:05 $
  + * @version CVS $Revision: 1.3 $ $Date: 2001/12/11 09:53:27 $
    * @since 4.0
    * @deprecated  Please use <code>ExcaliburComponentManager</code> instead
    */
  
  
  
  1.3       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/component/DefaultComponentPool.java
  
  Index: DefaultComponentPool.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/component/DefaultComponentPool.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- DefaultComponentPool.java	2001/08/07 10:57:05	1.2
  +++ DefaultComponentPool.java	2001/12/11 09:53:27	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included  with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.component;
   
  @@ -22,7 +22,7 @@
    *
    * @author <a href="mailto:bloritsch@apache.org">Berin Loritsch</a>
    * @author <a href="mailto:Giacomo.Pati@pwr.ch">Giacomo Pati</a>
  - * @version CVS $Revision: 1.2 $ $Date: 2001/08/07 10:57:05 $
  + * @version CVS $Revision: 1.3 $ $Date: 2001/12/11 09:53:27 $
    * @since 4.0
    */
   public class DefaultComponentPool
  
  
  
  1.4       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/component/DefaultComponentPoolController.java
  
  Index: DefaultComponentPoolController.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/component/DefaultComponentPoolController.java,v
  retrieving revision 1.3
  retrieving revision 1.4
  diff -u -r1.3 -r1.4
  --- DefaultComponentPoolController.java	2001/08/07 10:57:05	1.3
  +++ DefaultComponentPoolController.java	2001/12/11 09:53:27	1.4
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included  with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.component;
   
  @@ -16,7 +16,7 @@
    *
    * @author <a href="mailto:Giacomo.Pati@pwr.ch">Giacomo Pati</a>
    * @author <a href="mailto:bloritsch@apache.org">Berin Loritsch</a>
  - * @version CVS $Revision: 1.3 $ $Date: 2001/08/07 10:57:05 $
  + * @version CVS $Revision: 1.4 $ $Date: 2001/12/11 09:53:27 $
    * @since 4.0
    */
   public class DefaultComponentPoolController
  
  
  
  1.3       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/component/DefaultComponentSelector.java
  
  Index: DefaultComponentSelector.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/component/DefaultComponentSelector.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- DefaultComponentSelector.java	2001/08/07 10:57:05	1.2
  +++ DefaultComponentSelector.java	2001/12/11 09:53:27	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included  with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.component;
   
  @@ -12,7 +12,7 @@
    *
    * @author <a href="mailto:bloritsch@apache.org">Berin Loritsch</a>
    * @author <a href="mailto:paul@luminas.co.uk">Paul Russell</a>
  - * @version CVS $Revision: 1.2 $ $Date: 2001/08/07 10:57:05 $
  + * @version CVS $Revision: 1.3 $ $Date: 2001/12/11 09:53:27 $
    * @since 4.0
    * @deprecated use <code>ExcaliburComponentSelector</code> instead.
    */
  
  
  
  1.6       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/component/DefaultRoleManager.java
  
  Index: DefaultRoleManager.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/component/DefaultRoleManager.java,v
  retrieving revision 1.5
  retrieving revision 1.6
  diff -u -r1.5 -r1.6
  --- DefaultRoleManager.java	2001/11/02 11:37:16	1.5
  +++ DefaultRoleManager.java	2001/12/11 09:53:27	1.6
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included  with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.component;
   
  @@ -22,7 +22,7 @@
    * @author <a href="mailto:bloritsch@apache.org">Berin Loritsch</a>
    * @author <a href="mailto:ricardo@apache.org">Ricardo Rocha</a>
    * @author <a href="mailto:giacomo@apache.org">Giacomo Pati</a>
  - * @version CVS $Revision: 1.5 $ $Date: 2001/11/02 11:37:16 $
  + * @version CVS $Revision: 1.6 $ $Date: 2001/12/11 09:53:27 $
    * @since 4.0
    */
   public class DefaultRoleManager
  
  
  
  1.12      +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/component/ExcaliburComponentManager.java
  
  Index: ExcaliburComponentManager.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/component/ExcaliburComponentManager.java,v
  retrieving revision 1.11
  retrieving revision 1.12
  diff -u -r1.11 -r1.12
  --- ExcaliburComponentManager.java	2001/10/31 22:06:08	1.11
  +++ ExcaliburComponentManager.java	2001/12/11 09:53:27	1.12
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included  with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.component;
   
  @@ -33,7 +33,7 @@
    *
    * @author <a href="mailto:bloritsch@apache.org">Berin Loritsch</a>
    * @author <a href="mailto:paul@luminas.co.uk">Paul Russell</a>
  - * @version CVS $Revision: 1.11 $ $Date: 2001/10/31 22:06:08 $
  + * @version CVS $Revision: 1.12 $ $Date: 2001/12/11 09:53:27 $
    * @since 4.0
    */
   public class ExcaliburComponentManager
  
  
  
  1.9       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/component/ExcaliburComponentSelector.java
  
  Index: ExcaliburComponentSelector.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/component/ExcaliburComponentSelector.java,v
  retrieving revision 1.8
  retrieving revision 1.9
  diff -u -r1.8 -r1.9
  --- ExcaliburComponentSelector.java	2001/10/25 15:57:37	1.8
  +++ ExcaliburComponentSelector.java	2001/12/11 09:53:27	1.9
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included  with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.component;
   
  @@ -35,7 +35,7 @@
    *
    * @author <a href="mailto:bloritsch@apache.org">Berin Loritsch</a>
    * @author <a href="mailto:paul@luminas.co.uk">Paul Russell</a>
  - * @version CVS $Revision: 1.8 $ $Date: 2001/10/25 15:57:37 $
  + * @version CVS $Revision: 1.9 $ $Date: 2001/12/11 09:53:27 $
    * @since 4.0
    */
   public class ExcaliburComponentSelector
  
  
  
  1.7       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/component/PoolableComponentHandler.java
  
  Index: PoolableComponentHandler.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/component/PoolableComponentHandler.java,v
  retrieving revision 1.6
  retrieving revision 1.7
  diff -u -r1.6 -r1.7
  --- PoolableComponentHandler.java	2001/11/01 14:25:57	1.6
  +++ PoolableComponentHandler.java	2001/12/11 09:53:27	1.7
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.component;
   
  @@ -21,7 +21,7 @@
    * and destroyed correctly.
    *
    * @author <a href="mailto:bloritsch@apache.org">Berin Loritsch</a>
  - * @version CVS $Revision: 1.6 $ $Date: 2001/11/01 14:25:57 $
  + * @version CVS $Revision: 1.7 $ $Date: 2001/12/11 09:53:27 $
    * @since 4.0
    */
   public class PoolableComponentHandler extends ComponentHandler {
  
  
  
  1.3       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/component/RoleManageable.java
  
  Index: RoleManageable.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/component/RoleManageable.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- RoleManageable.java	2001/08/07 10:57:05	1.2
  +++ RoleManageable.java	2001/12/11 09:53:27	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included  with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.component;
   
  @@ -12,7 +12,7 @@
    * Components.
    *
    * @author <a href="mailto:bloritsch@apache.org">Berin Loritsch</a>
  - * @version CVS $Revision: 1.2 $ $Date: 2001/08/07 10:57:05 $
  + * @version CVS $Revision: 1.3 $ $Date: 2001/12/11 09:53:27 $
    * @since 4.0
    */
   public interface RoleManageable
  
  
  
  1.4       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/component/RoleManager.java
  
  Index: RoleManager.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/component/RoleManager.java,v
  retrieving revision 1.3
  retrieving revision 1.4
  diff -u -r1.3 -r1.4
  --- RoleManager.java	2001/10/28 00:48:11	1.3
  +++ RoleManager.java	2001/12/11 09:53:27	1.4
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included  with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.component;
   
  @@ -14,7 +14,7 @@
    * @author <a href="mailto:bloritsch@apache.org">Berin Loritsch</a>
    * @author <a href="mailto:ricardo@apache.org">Ricardo Rocha</a>
    * @author <a href="mailto:giacomo@apache.org">Giacomo Pati</a>
  - * @version CVS $Revision: 1.3 $ $Date: 2001/10/28 00:48:11 $
  + * @version CVS $Revision: 1.4 $ $Date: 2001/12/11 09:53:27 $
    * @since 4.0
    */
   public interface RoleManager
  
  
  
  1.8       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/component/ThreadSafeComponentHandler.java
  
  Index: ThreadSafeComponentHandler.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/component/ThreadSafeComponentHandler.java,v
  retrieving revision 1.7
  retrieving revision 1.8
  diff -u -r1.7 -r1.8
  --- ThreadSafeComponentHandler.java	2001/11/09 08:10:06	1.7
  +++ ThreadSafeComponentHandler.java	2001/12/11 09:53:27	1.8
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.component;
   
  @@ -21,7 +21,7 @@
    * and destroyed correctly.
    *
    * @author <a href="mailto:bloritsch@apache.org">Berin Loritsch</a>
  - * @version CVS $Revision: 1.7 $ $Date: 2001/11/09 08:10:06 $
  + * @version CVS $Revision: 1.8 $ $Date: 2001/12/11 09:53:27 $
    * @since 4.0
    */
   public class ThreadSafeComponentHandler extends ComponentHandler {
  
  
  
  1.3       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/concurrent/ConditionalEvent.java
  
  Index: ConditionalEvent.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/concurrent/ConditionalEvent.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- ConditionalEvent.java	2001/08/07 10:57:06	1.2
  +++ ConditionalEvent.java	2001/12/11 09:53:27	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.concurrent;
   
  @@ -17,7 +17,7 @@
    * or signalAll() was called).
    *
    * @author <a href="mailto:kranga@sapient.com">Karthik Rangaraju</a>
  - * @version CVS $Revision: 1.2 $ $Date: 2001/08/07 10:57:06 $
  + * @version CVS $Revision: 1.3 $ $Date: 2001/12/11 09:53:27 $
    * @since 4.0
    */
   public class ConditionalEvent
  
  
  
  1.2       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/concurrent/DijkstraSemaphore.java
  
  Index: DijkstraSemaphore.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/concurrent/DijkstraSemaphore.java,v
  retrieving revision 1.1
  retrieving revision 1.2
  diff -u -r1.1 -r1.2
  --- DijkstraSemaphore.java	2001/11/16 10:13:09	1.1
  +++ DijkstraSemaphore.java	2001/12/11 09:53:27	1.2
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.concurrent;
   
  @@ -15,7 +15,7 @@
    * calls release() thus increasing the count.
    *
    * @author <a href="mailto:kranga@sapient.com">Karthik Rangaraju</a>
  - * @version CVS $Revision: 1.1 $ $Date: 2001/11/16 10:13:09 $
  + * @version CVS $Revision: 1.2 $ $Date: 2001/12/11 09:53:27 $
    * @since 4.0
    */
   public class DijkstraSemaphore
  
  
  
  1.4       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/concurrent/DjikstraSemaphore.java
  
  Index: DjikstraSemaphore.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/concurrent/DjikstraSemaphore.java,v
  retrieving revision 1.3
  retrieving revision 1.4
  diff -u -r1.3 -r1.4
  --- DjikstraSemaphore.java	2001/11/16 10:13:09	1.3
  +++ DjikstraSemaphore.java	2001/12/11 09:53:27	1.4
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.concurrent;
   
  @@ -15,7 +15,7 @@
    * calls release() thus increasing the count.
    *
    * @author <a href="mailto:kranga@sapient.com">Karthik Rangaraju</a>
  - * @version CVS $Revision: 1.3 $ $Date: 2001/11/16 10:13:09 $
  + * @version CVS $Revision: 1.4 $ $Date: 2001/12/11 09:53:27 $
    * @since 4.0
    * @deprecated Replaced by by {@link DijkstraSemaphore}.
    */
  
  
  
  1.3       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/concurrent/Lock.java
  
  Index: Lock.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/concurrent/Lock.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- Lock.java	2001/08/07 10:57:06	1.2
  +++ Lock.java	2001/12/11 09:53:28	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.concurrent;
   
  @@ -12,7 +12,7 @@
    *
    * @author <a href="mailto:fede@apache.org">Federico Barbieri</a>
    * @author <a href="mailto:bloritsch@apache.org">Berin Loritsch</a>
  - * @version CVS $Revision: 1.2 $ $Date: 2001/08/07 10:57:06 $
  + * @version CVS $Revision: 1.3 $ $Date: 2001/12/11 09:53:28 $
    * @since 4.0
    */
   public class Lock
  
  
  
  1.3       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/concurrent/Mutex.java
  
  Index: Mutex.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/concurrent/Mutex.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- Mutex.java	2001/08/07 10:57:06	1.2
  +++ Mutex.java	2001/12/11 09:53:28	1.3
  @@ -3,13 +3,13 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.concurrent;
   
   /**
    *
  - * @version CVS $Revision: 1.2 $ $Date: 2001/08/07 10:57:06 $
  + * @version CVS $Revision: 1.3 $ $Date: 2001/12/11 09:53:28 $
    * @since 4.0
    */
   
  
  
  
  1.7       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/concurrent/ReadWriteLock.java
  
  Index: ReadWriteLock.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/concurrent/ReadWriteLock.java,v
  retrieving revision 1.6
  retrieving revision 1.7
  diff -u -r1.6 -r1.7
  --- ReadWriteLock.java	2001/10/31 14:33:16	1.6
  +++ ReadWriteLock.java	2001/12/11 09:53:28	1.7
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.concurrent;
   
  @@ -19,7 +19,7 @@
    * will take priority over those trying to get a read lock.
    *
    * @author <a href="mailto:leo.sutic@inspireinfrastructure.com">Leo Sutic</a>
  - * @version CVS $Revision: 1.6 $ $Date: 2001/10/31 14:33:16 $
  + * @version CVS $Revision: 1.7 $ $Date: 2001/12/11 09:53:28 $
    * @since 4.0
    */
   public class ReadWriteLock
  
  
  
  1.4       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/concurrent/Semaphore.java
  
  Index: Semaphore.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/concurrent/Semaphore.java,v
  retrieving revision 1.3
  retrieving revision 1.4
  diff -u -r1.3 -r1.4
  --- Semaphore.java	2001/08/10 17:12:52	1.3
  +++ Semaphore.java	2001/12/11 09:53:28	1.4
  @@ -3,13 +3,13 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.concurrent;
   
   /**
    *
  - * @version CVS $Revision: 1.3 $ $Date: 2001/08/10 17:12:52 $
  + * @version CVS $Revision: 1.4 $ $Date: 2001/12/11 09:53:28 $
    * @since 4.0
    */
   
  
  
  
  1.4       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/concurrent/Sync.java
  
  Index: Sync.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/concurrent/Sync.java,v
  retrieving revision 1.3
  retrieving revision 1.4
  diff -u -r1.3 -r1.4
  --- Sync.java	2001/11/19 12:08:46	1.3
  +++ Sync.java	2001/12/11 09:53:28	1.4
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.concurrent;
   
  @@ -11,7 +11,7 @@
    * The interface to synchronization objects.
    *
    * @author <a href="mailto:peter@apache.org">Peter Donald</a>
  - * @version CVS $Revision: 1.3 $ $Date: 2001/11/19 12:08:46 $
  + * @version CVS $Revision: 1.4 $ $Date: 2001/12/11 09:53:28 $
    * @since 4.0
    */
   public interface Sync
  
  
  
  1.3       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/concurrent/ThreadBarrier.java
  
  Index: ThreadBarrier.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/concurrent/ThreadBarrier.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- ThreadBarrier.java	2001/08/07 10:57:06	1.2
  +++ ThreadBarrier.java	2001/12/11 09:53:28	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.concurrent;
   
  @@ -14,7 +14,7 @@
    * of providing mutual exclusion to shared resources
    *
    * @author <a href="mailto:kranga@sapient.com">Karthik Rangaraju</a>
  - * @version CVS $Revision: 1.2 $ $Date: 2001/08/07 10:57:06 $
  + * @version CVS $Revision: 1.3 $ $Date: 2001/12/11 09:53:28 $
    * @since 4.0
    */
   public class ThreadBarrier
  
  
  
  1.3       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/datasource/AbstractJdbcConnection.java
  
  Index: AbstractJdbcConnection.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/datasource/AbstractJdbcConnection.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- AbstractJdbcConnection.java	2001/11/05 14:07:31	1.2
  +++ AbstractJdbcConnection.java	2001/12/11 09:53:28	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.datasource;
   
  @@ -29,7 +29,7 @@
    * total number of Connection objects that are created.
    *
    * @author <a href="mailto:bloritsch@apache.org">Berin Loritsch</a>
  - * @version CVS $Revision: 1.2 $ $Date: 2001/11/05 14:07:31 $
  + * @version CVS $Revision: 1.3 $ $Date: 2001/12/11 09:53:28 $
    * @since 4.1
    */
   public abstract class AbstractJdbcConnection
  
  
  
  1.4       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/datasource/DataSourceComponent.java
  
  Index: DataSourceComponent.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/datasource/DataSourceComponent.java,v
  retrieving revision 1.3
  retrieving revision 1.4
  diff -u -r1.3 -r1.4
  --- DataSourceComponent.java	2001/11/02 18:58:45	1.3
  +++ DataSourceComponent.java	2001/12/11 09:53:28	1.4
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.datasource;
   
  @@ -17,7 +17,7 @@
    * The standard interface for DataSources in Avalon.
    *
    * @author <a href="mailto:bloritsch@apache.org">Berin Loritsch</a>
  - * @version CVS $Revision: 1.3 $ $Date: 2001/11/02 18:58:45 $
  + * @version CVS $Revision: 1.4 $ $Date: 2001/12/11 09:53:28 $
    * @since 4.0
    */
   public interface DataSourceComponent
  
  
  
  1.6       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/datasource/InformixDataSource.java
  
  Index: InformixDataSource.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/datasource/InformixDataSource.java,v
  retrieving revision 1.5
  retrieving revision 1.6
  diff -u -r1.5 -r1.6
  --- InformixDataSource.java	2001/11/23 01:43:24	1.5
  +++ InformixDataSource.java	2001/12/11 09:53:28	1.6
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.datasource;
   
  @@ -45,7 +45,7 @@
    * DataSource requires the Avalon Cadastre package because it uses the MemoryContext.
    *
    * @author <a href="mailto:bloritsch@apache.org">Berin Loritsch</a>
  - * @version CVS $Revision: 1.5 $ $Date: 2001/11/23 01:43:24 $
  + * @version CVS $Revision: 1.6 $ $Date: 2001/12/11 09:53:28 $
    * @since 4.0
    */
   public class InformixDataSource
  
  
  
  1.5       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/datasource/J2eeDataSource.java
  
  Index: J2eeDataSource.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/datasource/J2eeDataSource.java,v
  retrieving revision 1.4
  retrieving revision 1.5
  diff -u -r1.4 -r1.5
  --- J2eeDataSource.java	2001/11/23 01:43:24	1.4
  +++ J2eeDataSource.java	2001/12/11 09:53:28	1.5
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.datasource;
   
  @@ -25,7 +25,7 @@
    * J2EE container pools the datasources properly.
    *
    * @author <a href="mailto:bloritsch@apache.org">Berin Loritsch</a>
  - * @version CVS $Revision: 1.4 $ $Date: 2001/11/23 01:43:24 $
  + * @version CVS $Revision: 1.5 $ $Date: 2001/12/11 09:53:28 $
    * @since 4.0
    */
   public class J2eeDataSource
  
  
  
  1.9       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/datasource/Jdbc3Connection.java
  
  Index: Jdbc3Connection.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/datasource/Jdbc3Connection.java,v
  retrieving revision 1.8
  retrieving revision 1.9
  diff -u -r1.8 -r1.9
  --- Jdbc3Connection.java	2001/11/05 13:45:27	1.8
  +++ Jdbc3Connection.java	2001/12/11 09:53:28	1.9
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.datasource;
   
  @@ -26,7 +26,7 @@
    * total number of Connection objects that are created.
    *
    * @author <a href="mailto:bloritsch@apache.org">Berin Loritsch</a>
  - * @version CVS $Revision: 1.8 $ $Date: 2001/11/05 13:45:27 $
  + * @version CVS $Revision: 1.9 $ $Date: 2001/12/11 09:53:28 $
    * @since 4.0
    */
   public class Jdbc3Connection
  
  
  
  1.3       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/datasource/JdbcConnection.java
  
  Index: JdbcConnection.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/datasource/JdbcConnection.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- JdbcConnection.java	2001/11/05 14:07:31	1.2
  +++ JdbcConnection.java	2001/12/11 09:53:28	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.datasource;
   
  @@ -25,7 +25,7 @@
    * total number of Connection objects that are created.
    *
    * @author <a href="mailto:bloritsch@apache.org">Berin Loritsch</a>
  - * @version CVS $Revision: 1.2 $ $Date: 2001/11/05 14:07:31 $
  + * @version CVS $Revision: 1.3 $ $Date: 2001/12/11 09:53:28 $
    * @since 4.0
    */
   public class JdbcConnection
  
  
  
  1.8       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/datasource/JdbcConnectionFactory.java
  
  Index: JdbcConnectionFactory.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/datasource/JdbcConnectionFactory.java,v
  retrieving revision 1.7
  retrieving revision 1.8
  diff -u -r1.7 -r1.8
  --- JdbcConnectionFactory.java	2001/11/05 13:45:27	1.7
  +++ JdbcConnectionFactory.java	2001/12/11 09:53:28	1.8
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.datasource;
   
  @@ -18,7 +18,7 @@
    * The Factory implementation for JdbcConnections.
    *
    * @author <a href="mailto:bloritsch@apache.org">Berin Loritsch</a>
  - * @version CVS $Revision: 1.7 $ $Date: 2001/11/05 13:45:27 $
  + * @version CVS $Revision: 1.8 $ $Date: 2001/12/11 09:53:28 $
    * @since 4.0
    */
   public class JdbcConnectionFactory extends AbstractLogEnabled implements ObjectFactory
  
  
  
  1.13      +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/datasource/JdbcConnectionPool.java
  
  Index: JdbcConnectionPool.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/datasource/JdbcConnectionPool.java,v
  retrieving revision 1.12
  retrieving revision 1.13
  diff -u -r1.12 -r1.13
  --- JdbcConnectionPool.java	2001/12/03 21:57:42	1.12
  +++ JdbcConnectionPool.java	2001/12/11 09:53:28	1.13
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.datasource;
   
  @@ -21,7 +21,7 @@
    * thread to manage the number of SQL Connections.
    *
    * @author <a href="mailto:bloritsch@apache.org">Berin Loritsch</a>
  - * @version CVS $Revision: 1.12 $ $Date: 2001/12/03 21:57:42 $
  + * @version CVS $Revision: 1.13 $ $Date: 2001/12/11 09:53:28 $
    * @since 4.0
    */
   public class JdbcConnectionPool
  
  
  
  1.13      +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/datasource/JdbcDataSource.java
  
  Index: JdbcDataSource.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/datasource/JdbcDataSource.java,v
  retrieving revision 1.12
  retrieving revision 1.13
  diff -u -r1.12 -r1.13
  --- JdbcDataSource.java	2001/11/23 01:43:24	1.12
  +++ JdbcDataSource.java	2001/12/11 09:53:28	1.13
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.datasource;
   
  @@ -35,7 +35,7 @@
    * </pre>
    *
    * @author <a href="mailto:bloritsch@apache.org">Berin Loritsch</a>
  - * @version CVS $Revision: 1.12 $ $Date: 2001/11/23 01:43:24 $
  + * @version CVS $Revision: 1.13 $ $Date: 2001/12/11 09:53:28 $
    * @since 4.0
    */
   public class JdbcDataSource
  
  
  
  1.3       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/datasource/NoAvailableConnectionException.java
  
  Index: NoAvailableConnectionException.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/datasource/NoAvailableConnectionException.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- NoAvailableConnectionException.java	2001/11/19 12:08:47	1.2
  +++ NoAvailableConnectionException.java	2001/12/11 09:53:28	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.datasource;
   
  @@ -15,7 +15,7 @@
    * in the pool.
    *
    * @author <a href="mailto:bloritsch@apache.org">Berin Loritsch</a>
  - * @version CVS $Revision: 1.2 $ $Date: 2001/11/19 12:08:47 $
  + * @version CVS $Revision: 1.3 $ $Date: 2001/12/11 09:53:28 $
    * @since 4.1
    */
   public class NoAvailableConnectionException extends SQLException {
  
  
  
  1.3       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/datasource/NoValidConnectionException.java
  
  Index: NoValidConnectionException.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/datasource/NoValidConnectionException.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- NoValidConnectionException.java	2001/11/19 12:08:47	1.2
  +++ NoValidConnectionException.java	2001/12/11 09:53:28	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.datasource;
   
  @@ -14,7 +14,7 @@
    * in the ClassLoader.
    *
    * @author <a href="mailto:bloritsch@apache.org">Berin Loritsch</a>
  - * @version CVS $Revision: 1.2 $ $Date: 2001/11/19 12:08:47 $
  + * @version CVS $Revision: 1.3 $ $Date: 2001/12/11 09:53:28 $
    * @since 4.1
    */
   public class NoValidConnectionException extends SQLException {
  
  
  
  1.9       +1 -1      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/i18n/ResourceManager.java
  
  Index: ResourceManager.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/i18n/ResourceManager.java,v
  retrieving revision 1.8
  retrieving revision 1.9
  diff -u -r1.8 -r1.9
  --- ResourceManager.java	2001/11/19 12:08:47	1.8
  +++ ResourceManager.java	2001/12/11 09:53:28	1.9
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.i18n;
   
  
  
  
  1.10      +1 -1      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/i18n/Resources.java
  
  Index: Resources.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/i18n/Resources.java,v
  retrieving revision 1.9
  retrieving revision 1.10
  diff -u -r1.9 -r1.10
  --- Resources.java	2001/11/19 12:08:47	1.9
  +++ Resources.java	2001/12/11 09:53:28	1.10
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.i18n;
   
  
  
  
  1.4       +1 -1      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/io/AndFileFilter.java
  
  Index: AndFileFilter.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/io/AndFileFilter.java,v
  retrieving revision 1.3
  retrieving revision 1.4
  diff -u -r1.3 -r1.4
  --- AndFileFilter.java	2001/08/07 10:57:08	1.3
  +++ AndFileFilter.java	2001/12/11 09:53:29	1.4
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.io;
   
  
  
  
  1.2       +1 -1      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/io/ClassLoaderObjectInputStream.java
  
  Index: ClassLoaderObjectInputStream.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/io/ClassLoaderObjectInputStream.java,v
  retrieving revision 1.1
  retrieving revision 1.2
  diff -u -r1.1 -r1.2
  --- ClassLoaderObjectInputStream.java	2001/09/01 13:29:12	1.1
  +++ ClassLoaderObjectInputStream.java	2001/12/11 09:53:29	1.2
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.io;
   
  
  
  
  1.5       +1 -1      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/io/DirectoryFileFilter.java
  
  Index: DirectoryFileFilter.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/io/DirectoryFileFilter.java,v
  retrieving revision 1.4
  retrieving revision 1.5
  diff -u -r1.4 -r1.5
  --- DirectoryFileFilter.java	2001/11/19 12:08:47	1.4
  +++ DirectoryFileFilter.java	2001/12/11 09:53:29	1.5
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.io;
   
  
  
  
  1.4       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/io/EndianUtil.java
  
  Index: EndianUtil.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/io/EndianUtil.java,v
  retrieving revision 1.3
  retrieving revision 1.4
  diff -u -r1.3 -r1.4
  --- EndianUtil.java	2001/11/19 12:08:47	1.3
  +++ EndianUtil.java	2001/12/11 09:53:29	1.4
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.io;
   
  @@ -16,7 +16,7 @@
    * Utility code for dealing with different endian systems.
    *
    * @author <a href="mailto:peter@apache.org">Peter Donald</a>
  - * @version CVS $Revision: 1.3 $ $Date: 2001/11/19 12:08:47 $
  + * @version CVS $Revision: 1.4 $ $Date: 2001/12/11 09:53:29 $
    * @since 4.0
    */
   public final class EndianUtil
  
  
  
  1.5       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/io/ExtensionFileFilter.java
  
  Index: ExtensionFileFilter.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/io/ExtensionFileFilter.java,v
  retrieving revision 1.4
  retrieving revision 1.5
  diff -u -r1.4 -r1.5
  --- ExtensionFileFilter.java	2001/11/19 12:08:47	1.4
  +++ ExtensionFileFilter.java	2001/12/11 09:53:29	1.5
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.io;
   
  @@ -29,7 +29,7 @@
    * @author  Federico Barbieri <fe...@apache.org>
    * @author Serge Knystautas <se...@lokitech.com>
    * @author <a href="mailto:peter@apache.org">Peter Donald</a>
  - * @version CVS $Revision: 1.4 $ $Date: 2001/11/19 12:08:47 $
  + * @version CVS $Revision: 1.5 $ $Date: 2001/12/11 09:53:29 $
    * @since 4.0
    */
   public class ExtensionFileFilter
  
  
  
  1.16      +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/io/FileUtil.java
  
  Index: FileUtil.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/io/FileUtil.java,v
  retrieving revision 1.15
  retrieving revision 1.16
  diff -u -r1.15 -r1.16
  --- FileUtil.java	2001/11/19 12:08:47	1.15
  +++ FileUtil.java	2001/12/11 09:53:29	1.16
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.io;
   
  @@ -43,7 +43,7 @@
    *
    * @author <a href="mailto:peter@apache.org">Peter Donald</a>
    * @author <a href="mailto:jefft@apache.org">Jeff Turner</a>
  - * @version CVS $Revision: 1.15 $ $Date: 2001/11/19 12:08:47 $
  + * @version CVS $Revision: 1.16 $ $Date: 2001/12/11 09:53:29 $
    * @since 4.0
    */
   public final class FileUtil
  
  
  
  1.8       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/io/IOUtil.java
  
  Index: IOUtil.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/io/IOUtil.java,v
  retrieving revision 1.7
  retrieving revision 1.8
  diff -u -r1.7 -r1.8
  --- IOUtil.java	2001/11/19 12:08:47	1.7
  +++ IOUtil.java	2001/12/11 09:53:29	1.8
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.io;
   
  @@ -70,7 +70,7 @@
    *
    * @author <a href="mailto:peter@apache.org">Peter Donald</a>
    * @author <a href="mailto:jefft@apache.org">Jeff Turner</a>
  - * @version CVS $Revision: 1.7 $ $Date: 2001/11/19 12:08:47 $
  + * @version CVS $Revision: 1.8 $ $Date: 2001/12/11 09:53:29 $
    * @since 4.0
    */
   
  
  
  
  1.4       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/io/InvertedFileFilter.java
  
  Index: InvertedFileFilter.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/io/InvertedFileFilter.java,v
  retrieving revision 1.3
  retrieving revision 1.4
  diff -u -r1.3 -r1.4
  --- InvertedFileFilter.java	2001/08/07 10:57:08	1.3
  +++ InvertedFileFilter.java	2001/12/11 09:53:29	1.4
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.io;
   
  @@ -34,7 +34,7 @@
    * </pre>
    *
    * @author Harmeet Bedi <ha...@kodemuse.com>
  - * @version CVS $Revision: 1.3 $ $Date: 2001/08/07 10:57:08 $
  + * @version CVS $Revision: 1.4 $ $Date: 2001/12/11 09:53:29 $
    * @since 4.0
    */
   public class InvertedFileFilter
  
  
  
  1.4       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/io/OrFileFilter.java
  
  Index: OrFileFilter.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/io/OrFileFilter.java,v
  retrieving revision 1.3
  retrieving revision 1.4
  diff -u -r1.3 -r1.4
  --- OrFileFilter.java	2001/08/07 10:57:08	1.3
  +++ OrFileFilter.java	2001/12/11 09:53:29	1.4
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.io;
   
  @@ -30,7 +30,7 @@
    * </pre>
    *
    * @author Harmeet Bedi <ha...@kodemuse.com>
  - * @version CVS $Revision: 1.3 $ $Date: 2001/08/07 10:57:08 $
  + * @version CVS $Revision: 1.4 $ $Date: 2001/12/11 09:53:29 $
    * @since 4.0
    */
   public class OrFileFilter
  
  
  
  1.5       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/io/PrefixFileFilter.java
  
  Index: PrefixFileFilter.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/io/PrefixFileFilter.java,v
  retrieving revision 1.4
  retrieving revision 1.5
  diff -u -r1.4 -r1.5
  --- PrefixFileFilter.java	2001/11/19 12:08:47	1.4
  +++ PrefixFileFilter.java	2001/12/11 09:53:29	1.5
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.io;
   
  @@ -29,7 +29,7 @@
    * @author  Federico Barbieri <fe...@apache.org>
    * @author Serge Knystautas <se...@lokitech.com>
    * @author <a href="mailto:peter@apache.org">Peter Donald</a>
  - * @version CVS $Revision: 1.4 $ $Date: 2001/11/19 12:08:47 $
  + * @version CVS $Revision: 1.5 $ $Date: 2001/12/11 09:53:29 $
    * @since 4.0
    */
   public class PrefixFileFilter
  
  
  
  1.4       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/io/SwappedDataInputStream.java
  
  Index: SwappedDataInputStream.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/io/SwappedDataInputStream.java,v
  retrieving revision 1.3
  retrieving revision 1.4
  diff -u -r1.3 -r1.4
  --- SwappedDataInputStream.java	2001/11/19 12:08:47	1.3
  +++ SwappedDataInputStream.java	2001/12/11 09:53:29	1.4
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.io;
   
  @@ -16,7 +16,7 @@
    * DataInput for systems relying on little endian data formats.
    *
    * @author <a href="mailto:peter@apache.org">Peter Donald</a>
  - * @version CVS $Revision: 1.3 $ $Date: 2001/11/19 12:08:47 $
  + * @version CVS $Revision: 1.4 $ $Date: 2001/12/11 09:53:29 $
    * @since 4.0
    */
   public class SwappedDataInputStream
  
  
  
  1.10      +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/logger/DefaultLogKitManager.java
  
  Index: DefaultLogKitManager.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/logger/DefaultLogKitManager.java,v
  retrieving revision 1.9
  retrieving revision 1.10
  diff -u -r1.9 -r1.10
  --- DefaultLogKitManager.java	2001/11/19 02:34:52	1.9
  +++ DefaultLogKitManager.java	2001/12/11 09:53:29	1.10
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included  with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.logger;
   
  @@ -29,7 +29,7 @@
    * from a configuration file.
    *
    * @author <a href="mailto:giacomo@apache,org">Giacomo Pati</a>
  - * @version CVS $Revision: 1.9 $ $Date: 2001/11/19 02:34:52 $
  + * @version CVS $Revision: 1.10 $ $Date: 2001/12/11 09:53:29 $
    * @since 4.0
    */
   public class DefaultLogKitManager
  
  
  
  1.5       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/logger/DefaultLogTargetFactoryManager.java
  
  Index: DefaultLogTargetFactoryManager.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/logger/DefaultLogTargetFactoryManager.java,v
  retrieving revision 1.4
  retrieving revision 1.5
  diff -u -r1.4 -r1.5
  --- DefaultLogTargetFactoryManager.java	2001/12/03 09:24:23	1.4
  +++ DefaultLogTargetFactoryManager.java	2001/12/11 09:53:29	1.5
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included  with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.logger;
   
  @@ -23,7 +23,7 @@
    * from a configuration file.
    *
    * @author <a href="mailto:giacomo@apache,org">Giacomo Pati</a>
  - * @version CVS $Revision: 1.4 $ $Date: 2001/12/03 09:24:23 $
  + * @version CVS $Revision: 1.5 $ $Date: 2001/12/11 09:53:29 $
    * @since 4.0
    */
   public class DefaultLogTargetFactoryManager
  
  
  
  1.4       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/logger/DefaultLogTargetManager.java
  
  Index: DefaultLogTargetManager.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/logger/DefaultLogTargetManager.java,v
  retrieving revision 1.3
  retrieving revision 1.4
  diff -u -r1.3 -r1.4
  --- DefaultLogTargetManager.java	2001/11/19 02:15:39	1.3
  +++ DefaultLogTargetManager.java	2001/12/11 09:53:29	1.4
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included  with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.logger;
   
  @@ -23,7 +23,7 @@
    * from a configuration file.
    *
    * @author <a href="mailto:giacomo@apache,org">Giacomo Pati</a>
  - * @version CVS $Revision: 1.3 $ $Date: 2001/11/19 02:15:39 $
  + * @version CVS $Revision: 1.4 $ $Date: 2001/12/11 09:53:29 $
    * @since 4.0
    */
   public class DefaultLogTargetManager
  
  
  
  1.2       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/logger/LogKitManageable.java
  
  Index: LogKitManageable.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/logger/LogKitManageable.java,v
  retrieving revision 1.1
  retrieving revision 1.2
  diff -u -r1.1 -r1.2
  --- LogKitManageable.java	2001/08/25 15:05:15	1.1
  +++ LogKitManageable.java	2001/12/11 09:53:29	1.2
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included  with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.logger;
   
  @@ -12,7 +12,7 @@
    * Components.
    *
    * @author <a href="mailto:giacomo@apache,org">Giacomo Pati</a>
  - * @version CVS $Revision: 1.1 $ $Date: 2001/08/25 15:05:15 $
  + * @version CVS $Revision: 1.2 $ $Date: 2001/12/11 09:53:29 $
    * @since 4.0
    */
   public interface LogKitManageable
  
  
  
  1.3       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/logger/LogKitManager.java
  
  Index: LogKitManager.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/logger/LogKitManager.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- LogKitManager.java	2001/09/26 11:39:55	1.2
  +++ LogKitManager.java	2001/12/11 09:53:29	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included  with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.logger;
   
  @@ -14,7 +14,7 @@
    * LogKitManager Interface.
    *
    * @author <a href="mailto:giacomo@apache,org">Giacomo Pati</a>
  - * @version CVS $Revision: 1.2 $ $Date: 2001/09/26 11:39:55 $
  + * @version CVS $Revision: 1.3 $ $Date: 2001/12/11 09:53:29 $
    */
   public interface LogKitManager
   {
  
  
  
  1.2       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/logger/LogTargetFactory.java
  
  Index: LogTargetFactory.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/logger/LogTargetFactory.java,v
  retrieving revision 1.1
  retrieving revision 1.2
  diff -u -r1.1 -r1.2
  --- LogTargetFactory.java	2001/08/25 15:05:15	1.1
  +++ LogTargetFactory.java	2001/12/11 09:53:29	1.2
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included  with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.logger;
   
  @@ -16,7 +16,7 @@
    * LogTargetFactory Interface.
    *
    * @author <a href="mailto:giacomo@apache,org">Giacomo Pati</a>
  - * @version CVS $Revision: 1.1 $ $Date: 2001/08/25 15:05:15 $
  + * @version CVS $Revision: 1.2 $ $Date: 2001/12/11 09:53:29 $
    * @since 4.0
    */
   public interface LogTargetFactory
  
  
  
  1.2       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/logger/LogTargetFactoryManageable.java
  
  Index: LogTargetFactoryManageable.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/logger/LogTargetFactoryManageable.java,v
  retrieving revision 1.1
  retrieving revision 1.2
  diff -u -r1.1 -r1.2
  --- LogTargetFactoryManageable.java	2001/08/25 15:05:15	1.1
  +++ LogTargetFactoryManageable.java	2001/12/11 09:53:29	1.2
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included  with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.logger;
   
  @@ -12,7 +12,7 @@
    * for child Components.
    *
    * @author <a href="mailto:giacomo@apache,org">Giacomo Pati</a>
  - * @version CVS $Revision: 1.1 $ $Date: 2001/08/25 15:05:15 $
  + * @version CVS $Revision: 1.2 $ $Date: 2001/12/11 09:53:29 $
    * @since 4.0
    */
   public interface LogTargetFactoryManageable
  
  
  
  1.2       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/logger/LogTargetFactoryManager.java
  
  Index: LogTargetFactoryManager.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/logger/LogTargetFactoryManager.java,v
  retrieving revision 1.1
  retrieving revision 1.2
  diff -u -r1.1 -r1.2
  --- LogTargetFactoryManager.java	2001/08/25 15:05:15	1.1
  +++ LogTargetFactoryManager.java	2001/12/11 09:53:29	1.2
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included  with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.logger;
   
  @@ -11,7 +11,7 @@
    * LogTargetFactoryManager Interface.
    *
    * @author <a href="mailto:giacomo@apache,org">Giacomo Pati</a>
  - * @version CVS $Revision: 1.1 $ $Date: 2001/08/25 15:05:15 $
  + * @version CVS $Revision: 1.2 $ $Date: 2001/12/11 09:53:29 $
    * @since 4.0
    */
   public interface LogTargetFactoryManager
  
  
  
  1.2       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/logger/LogTargetManager.java
  
  Index: LogTargetManager.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/logger/LogTargetManager.java,v
  retrieving revision 1.1
  retrieving revision 1.2
  diff -u -r1.1 -r1.2
  --- LogTargetManager.java	2001/08/25 15:12:55	1.1
  +++ LogTargetManager.java	2001/12/11 09:53:29	1.2
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included  with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.logger;
   
  @@ -13,7 +13,7 @@
    * LogTargetManager Interface.
    *
    * @author <a href="mailto:giacomo@apache,org">Giacomo Pati</a>
  - * @version CVS $Revision: 1.1 $ $Date: 2001/08/25 15:12:55 $
  + * @version CVS $Revision: 1.2 $ $Date: 2001/12/11 09:53:29 $
    * @since 4.0
    */
   public interface LogTargetManager
  
  
  
  1.3       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/logger/factory/AbstractTargetFactory.java
  
  Index: AbstractTargetFactory.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/logger/factory/AbstractTargetFactory.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- AbstractTargetFactory.java	2001/11/19 02:15:39	1.2
  +++ AbstractTargetFactory.java	2001/12/11 09:53:30	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included  with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.logger.factory;
   
  @@ -25,7 +25,7 @@
    * This factory implements basic functionality for LogTargetFactories
    *
    * @author <a href="mailto:giacomo@apache,org">Giacomo Pati</a>
  - * @version CVS $Revision: 1.2 $ $Date: 2001/11/19 02:15:39 $
  + * @version CVS $Revision: 1.3 $ $Date: 2001/12/11 09:53:30 $
    * @since 4.0
    */
   public abstract class AbstractTargetFactory 
  
  
  
  1.3       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/logger/factory/AsyncLogTargetFactory.java
  
  Index: AsyncLogTargetFactory.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/logger/factory/AsyncLogTargetFactory.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- AsyncLogTargetFactory.java	2001/09/01 17:09:18	1.2
  +++ AsyncLogTargetFactory.java	2001/12/11 09:53:30	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included  with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.logger.factory;
   
  @@ -47,7 +47,7 @@
    * </p>
    *
    * @author <a href="mailto:giacomo@apache,org">Giacomo Pati</a>
  - * @version CVS $Revision: 1.2 $ $Date: 2001/09/01 17:09:18 $
  + * @version CVS $Revision: 1.3 $ $Date: 2001/12/11 09:53:30 $
    * @since 4.0
    */
   public final class AsyncLogTargetFactory
  
  
  
  1.6       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/logger/factory/FileTargetFactory.java
  
  Index: FileTargetFactory.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/logger/factory/FileTargetFactory.java,v
  retrieving revision 1.5
  retrieving revision 1.6
  diff -u -r1.5 -r1.6
  --- FileTargetFactory.java	2001/08/29 14:38:16	1.5
  +++ FileTargetFactory.java	2001/12/11 09:53:30	1.6
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included  with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.logger.factory;
   
  @@ -105,7 +105,7 @@
    * </dl>
    *
    * @author <a href="mailto:giacomo@apache,org">Giacomo Pati</a>
  - * @version CVS $Revision: 1.5 $ $Date: 2001/08/29 14:38:16 $
  + * @version CVS $Revision: 1.6 $ $Date: 2001/12/11 09:53:30 $
    * @since 4.0
    */
   public class FileTargetFactory 
  
  
  
  1.5       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/logger/factory/JDBCTargetFactory.java
  
  Index: JDBCTargetFactory.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/logger/factory/JDBCTargetFactory.java,v
  retrieving revision 1.4
  retrieving revision 1.5
  diff -u -r1.4 -r1.5
  --- JDBCTargetFactory.java	2001/09/11 08:53:22	1.4
  +++ JDBCTargetFactory.java	2001/12/11 09:53:30	1.5
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included  with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.logger.factory;
   
  @@ -49,7 +49,7 @@
    * </pre>
    *
    * @author <a href="mailto:mirceatoma@home.com">Mircea Toma</a>;
  - * @version CVS $Revision: 1.4 $ $Date: 2001/09/11 08:53:22 $
  + * @version CVS $Revision: 1.5 $ $Date: 2001/12/11 09:53:30 $
    */
   public class JDBCTargetFactory implements LogTargetFactory
   {
  
  
  
  1.3       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/logger/factory/PriorityFilterTargetFactory.java
  
  Index: PriorityFilterTargetFactory.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/logger/factory/PriorityFilterTargetFactory.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- PriorityFilterTargetFactory.java	2001/09/01 17:09:18	1.2
  +++ PriorityFilterTargetFactory.java	2001/12/11 09:53:30	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included  with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.logger.factory;
   
  @@ -39,7 +39,7 @@
    * </p>
    *
    * @author <a href="mailto:giacomo@apache,org">Giacomo Pati</a>
  - * @version CVS $Revision: 1.2 $ $Date: 2001/09/01 17:09:18 $
  + * @version CVS $Revision: 1.3 $ $Date: 2001/12/11 09:53:30 $
    * @since 4.0
    */
   public final class PriorityFilterTargetFactory
  
  
  
  1.3       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/logger/factory/ServletTargetFactory.java
  
  Index: ServletTargetFactory.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/logger/factory/ServletTargetFactory.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- ServletTargetFactory.java	2001/09/01 17:09:18	1.2
  +++ ServletTargetFactory.java	2001/12/11 09:53:30	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included  with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.logger.factory;
   
  @@ -45,7 +45,7 @@
    * </dl>
    *
    * @author <a href="mailto:giacomo@apache,org">Giacomo Pati</a>
  - * @version CVS $Revision: 1.2 $ $Date: 2001/09/01 17:09:18 $
  + * @version CVS $Revision: 1.3 $ $Date: 2001/12/11 09:53:30 $
    * @since 4.0
    */
   public final class ServletTargetFactory
  
  
  
  1.2       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/logger/factory/StreamTargetFactory.java
  
  Index: StreamTargetFactory.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/logger/factory/StreamTargetFactory.java,v
  retrieving revision 1.1
  retrieving revision 1.2
  diff -u -r1.1 -r1.2
  --- StreamTargetFactory.java	2001/09/27 10:48:53	1.1
  +++ StreamTargetFactory.java	2001/12/11 09:53:30	1.2
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included  with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.logger.factory;
   
  @@ -43,7 +43,7 @@
    * <p>The syntax of "format" is the same as in <code>FileTargetFactory</code>.</p>
    *
    * @author <a href="mailto:sylvain@apache.org">Sylvain Wallez</a>
  - * @version CVS $Revision: 1.1 $ $Date: 2001/09/27 10:48:53 $
  + * @version CVS $Revision: 1.2 $ $Date: 2001/12/11 09:53:30 $
    */
   public class StreamTargetFactory
       extends AbstractTargetFactory 
  
  
  
  1.3       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/monitor/ActiveMonitor.java
  
  Index: ActiveMonitor.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/monitor/ActiveMonitor.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- ActiveMonitor.java	2001/11/19 12:08:47	1.2
  +++ ActiveMonitor.java	2001/12/11 09:53:30	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.monitor;
   
  @@ -38,7 +38,7 @@
    * </pre>
    *
    * @author <a href="mailto:bloritsch@apache.org">Berin Loritsch</a>
  - * @version $Id: ActiveMonitor.java,v 1.2 2001/11/19 12:08:47 donaldp Exp $
  + * @version $Id: ActiveMonitor.java,v 1.3 2001/12/11 09:53:30 jefft Exp $
    */
   public final class ActiveMonitor extends AbstractLoggable
       implements Monitor, Component, Startable, ThreadSafe, Configurable, Runnable
  
  
  
  1.2       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/monitor/FileResource.java
  
  Index: FileResource.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/monitor/FileResource.java,v
  retrieving revision 1.1
  retrieving revision 1.2
  diff -u -r1.1 -r1.2
  --- FileResource.java	2001/09/04 20:33:47	1.1
  +++ FileResource.java	2001/12/11 09:53:30	1.2
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.monitor;
   
  @@ -26,7 +26,7 @@
    * OutputStream has been closed.
    *
    * @author <a href="mailto:bloritsch@apache.org">Berin Loritsch</a>
  - * @version $Id: FileResource.java,v 1.1 2001/09/04 20:33:47 bloritsch Exp $
  + * @version $Id: FileResource.java,v 1.2 2001/12/11 09:53:30 jefft Exp $
    */
   public class FileResource extends StreamResource
   {
  
  
  
  1.3       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/monitor/Modifiable.java
  
  Index: Modifiable.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/monitor/Modifiable.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- Modifiable.java	2001/11/19 12:08:47	1.2
  +++ Modifiable.java	2001/12/11 09:53:30	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.monitor;
   
  @@ -12,7 +12,7 @@
    * resource is modified by an external source.
    *
    * @author <a href="mailto:bloritsch@apache.org">Berin Loritsch</a>
  - * @version $Id: Modifiable.java,v 1.2 2001/11/19 12:08:47 donaldp Exp $
  + * @version $Id: Modifiable.java,v 1.3 2001/12/11 09:53:30 jefft Exp $
    */
   public interface Modifiable
   {
  
  
  
  1.3       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/monitor/Monitor.java
  
  Index: Monitor.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/monitor/Monitor.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- Monitor.java	2001/11/19 12:08:47	1.2
  +++ Monitor.java	2001/12/11 09:53:30	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.monitor;
   
  @@ -13,7 +13,7 @@
    * the ComponentManager.
    *
    * @author <a href="mailto:bloritsch@apache.org">Berin Loritsch</a>
  - * @version $Id: Monitor.java,v 1.2 2001/11/19 12:08:47 donaldp Exp $
  + * @version $Id: Monitor.java,v 1.3 2001/12/11 09:53:30 jefft Exp $
    */
   public interface Monitor
   {
  
  
  
  1.3       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/monitor/PassiveMonitor.java
  
  Index: PassiveMonitor.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/monitor/PassiveMonitor.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- PassiveMonitor.java	2001/11/19 12:08:47	1.2
  +++ PassiveMonitor.java	2001/12/11 09:53:30	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.monitor;
   
  @@ -38,7 +38,7 @@
    * </pre>
    *
    * @author <a href="mailto:bloritsch@apache.org">Berin Loritsch</a>
  - * @version $Id: PassiveMonitor.java,v 1.2 2001/11/19 12:08:47 donaldp Exp $
  + * @version $Id: PassiveMonitor.java,v 1.3 2001/12/11 09:53:30 jefft Exp $
    */
   public final class PassiveMonitor extends AbstractLoggable
       implements Monitor, Component, ThreadSafe, Configurable
  
  
  
  1.2       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/monitor/Resource.java
  
  Index: Resource.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/monitor/Resource.java,v
  retrieving revision 1.1
  retrieving revision 1.2
  diff -u -r1.1 -r1.2
  --- Resource.java	2001/09/04 20:33:47	1.1
  +++ Resource.java	2001/12/11 09:53:30	1.2
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.monitor;
   
  @@ -23,7 +23,7 @@
    * last modified property will be enough.
    *
    * @author <a href="mailto:bloritsch@apache.org">Berin Loritsch</a>
  - * @version $Id: Resource.java,v 1.1 2001/09/04 20:33:47 bloritsch Exp $
  + * @version $Id: Resource.java,v 1.2 2001/12/11 09:53:30 jefft Exp $
    */
   public abstract class Resource implements Modifiable
   {
  
  
  
  1.3       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/monitor/ResourceOutputStream.java
  
  Index: ResourceOutputStream.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/monitor/ResourceOutputStream.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- ResourceOutputStream.java	2001/11/19 12:08:47	1.2
  +++ ResourceOutputStream.java	2001/12/11 09:53:30	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.monitor;
   
  @@ -19,7 +19,7 @@
    * OutputStream has been closed.
    *
    * @author <a href="mailto:bloritsch@apache.org">Berin Loritsch</a>
  - * @version $Id: ResourceOutputStream.java,v 1.2 2001/11/19 12:08:47 donaldp Exp $
  + * @version $Id: ResourceOutputStream.java,v 1.3 2001/12/11 09:53:30 jefft Exp $
    */
   final class ResourceOutputStream extends FilterOutputStream
   {
  
  
  
  1.3       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/monitor/ResourceWriter.java
  
  Index: ResourceWriter.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/monitor/ResourceWriter.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- ResourceWriter.java	2001/11/19 12:08:47	1.2
  +++ ResourceWriter.java	2001/12/11 09:53:30	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.monitor;
   
  @@ -19,7 +19,7 @@
    * OutputStream has been closed.
    *
    * @author <a href="mailto:bloritsch@apache.org">Berin Loritsch</a>
  - * @version $Id: ResourceWriter.java,v 1.2 2001/11/19 12:08:47 donaldp Exp $
  + * @version $Id: ResourceWriter.java,v 1.3 2001/12/11 09:53:30 jefft Exp $
    */
   final class ResourceWriter extends FilterWriter
   {
  
  
  
  1.2       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/monitor/StreamResource.java
  
  Index: StreamResource.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/monitor/StreamResource.java,v
  retrieving revision 1.1
  retrieving revision 1.2
  diff -u -r1.1 -r1.2
  --- StreamResource.java	2001/09/04 20:33:47	1.1
  +++ StreamResource.java	2001/12/11 09:53:30	1.2
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.monitor;
   
  @@ -21,7 +21,7 @@
    * OutputStream has been closed.
    *
    * @author <a href="mailto:bloritsch@apache.org">Berin Loritsch</a>
  - * @version $Id: StreamResource.java,v 1.1 2001/09/04 20:33:47 bloritsch Exp $
  + * @version $Id: StreamResource.java,v 1.2 2001/12/11 09:53:30 jefft Exp $
    */
   public abstract class StreamResource extends Resource
   {
  
  
  
  1.4       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/naming/AbstractContext.java
  
  Index: AbstractContext.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/naming/AbstractContext.java,v
  retrieving revision 1.3
  retrieving revision 1.4
  diff -u -r1.3 -r1.4
  --- AbstractContext.java	2001/11/19 12:08:47	1.3
  +++ AbstractContext.java	2001/12/11 09:53:30	1.4
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.naming;
   
  @@ -16,7 +16,7 @@
    * provide a particular type of Context.
    *
    * @author <a href="mailto:peter@apache.org">Peter Donald</a>
  - * @version $Revision: 1.3 $
  + * @version $Revision: 1.4 $
    */
   public abstract class AbstractContext
       implements Context
  
  
  
  1.6       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/naming/AbstractLocalContext.java
  
  Index: AbstractLocalContext.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/naming/AbstractLocalContext.java,v
  retrieving revision 1.5
  retrieving revision 1.6
  diff -u -r1.5 -r1.6
  --- AbstractLocalContext.java	2001/11/19 12:08:47	1.5
  +++ AbstractLocalContext.java	2001/12/11 09:53:30	1.6
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.naming;
   
  @@ -27,7 +27,7 @@
    * on the same machine.
    *
    * @author <a href="mailto:peter@apache.org">Peter Donald</a>
  - * @version $Revision: 1.5 $
  + * @version $Revision: 1.6 $
    */
   public abstract class AbstractLocalContext
       extends AbstractContext
  
  
  
  1.4       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/naming/AbstractNamespace.java
  
  Index: AbstractNamespace.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/naming/AbstractNamespace.java,v
  retrieving revision 1.3
  retrieving revision 1.4
  diff -u -r1.3 -r1.4
  --- AbstractNamespace.java	2001/11/19 12:08:47	1.3
  +++ AbstractNamespace.java	2001/12/11 09:53:30	1.4
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.naming;
   
  @@ -21,7 +21,7 @@
    * basic facilities for Namespace management.
    *
    * @author <a href="mailto:peter@apache.org">Peter Donald</a>
  - * @version $Revision: 1.3 $
  + * @version $Revision: 1.4 $
    */
   public abstract class AbstractNamespace
       implements Namespace
  
  
  
  1.3       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/naming/AbstractNamingEnumeration.java
  
  Index: AbstractNamingEnumeration.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/naming/AbstractNamingEnumeration.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- AbstractNamingEnumeration.java	2001/11/19 12:08:47	1.2
  +++ AbstractNamingEnumeration.java	2001/12/11 09:53:30	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.naming;
   
  @@ -22,7 +22,7 @@
    * Class for building NamingEnumerations.
    *
    * @author <a href="mailto:peter@apache.org">Peter Donald</a>
  - * @version $Revision: 1.2 $
  + * @version $Revision: 1.3 $
    */
   public abstract class AbstractNamingEnumeration
       implements NamingEnumeration
  
  
  
  1.4       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/naming/AbstractURLContext.java
  
  Index: AbstractURLContext.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/naming/AbstractURLContext.java,v
  retrieving revision 1.3
  retrieving revision 1.4
  diff -u -r1.3 -r1.4
  --- AbstractURLContext.java	2001/11/19 12:08:47	1.3
  +++ AbstractURLContext.java	2001/12/11 09:53:30	1.4
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.naming;
   
  @@ -20,7 +20,7 @@
    * provide a particular type of Context.
    *
    * @author <a href="mailto:peter@apache.org">Peter Donald</a>
  - * @version $Revision: 1.3 $
  + * @version $Revision: 1.4 $
    */
   public abstract class AbstractURLContext
       extends AbstractContext
  
  
  
  1.3       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/naming/ArrayNamingEnumeration.java
  
  Index: ArrayNamingEnumeration.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/naming/ArrayNamingEnumeration.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- ArrayNamingEnumeration.java	2001/11/19 12:08:47	1.2
  +++ ArrayNamingEnumeration.java	2001/12/11 09:53:30	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.naming;
   
  @@ -16,7 +16,7 @@
    * Class for building NamingEnumerations.
    *
    * @author <a href="mailto:peter@apache.org">Peter Donald</a>
  - * @version $Revision: 1.2 $
  + * @version $Revision: 1.3 $
    */
   final class ArrayNamingEnumeration
       extends AbstractNamingEnumeration
  
  
  
  1.2       +1 -1      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/naming/DefaultNameParser.java
  
  Index: DefaultNameParser.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/naming/DefaultNameParser.java,v
  retrieving revision 1.1
  retrieving revision 1.2
  diff -u -r1.1 -r1.2
  --- DefaultNameParser.java	2001/08/08 14:26:28	1.1
  +++ DefaultNameParser.java	2001/12/11 09:53:30	1.2
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.naming;
   
  
  
  
  1.6       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/naming/DefaultNamespace.java
  
  Index: DefaultNamespace.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/naming/DefaultNamespace.java,v
  retrieving revision 1.5
  retrieving revision 1.6
  diff -u -r1.5 -r1.6
  --- DefaultNamespace.java	2001/11/19 12:08:47	1.5
  +++ DefaultNamespace.java	2001/12/11 09:53:30	1.6
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.naming;
   
  @@ -21,7 +21,7 @@
    * This is the default namespace implementation.
    *
    * @author <a href="mailto:peter@apache.org">Peter Donald</a>
  - * @version $Revision: 1.5 $
  + * @version $Revision: 1.6 $
    */
   public class DefaultNamespace
       extends AbstractNamespace
  
  
  
  1.3       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/naming/Namespace.java
  
  Index: Namespace.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/naming/Namespace.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- Namespace.java	2001/11/19 12:08:47	1.2
  +++ Namespace.java	2001/12/11 09:53:30	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.naming;
   
  @@ -19,7 +19,7 @@
    * object factories and state factories.
    *
    * @author <a href="mailto:peter@apache.org">Peter Donald</a>
  - * @version $Revision: 1.2 $
  + * @version $Revision: 1.3 $
    */
   public interface Namespace
       extends ObjectFactory, StateFactory
  
  
  
  1.3       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/naming/NamingProvider.java
  
  Index: NamingProvider.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/naming/NamingProvider.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- NamingProvider.java	2001/11/19 12:08:47	1.2
  +++ NamingProvider.java	2001/12/11 09:53:30	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.naming;
   
  @@ -18,7 +18,7 @@
    * The underlying communication interface for remote contexts.
    *
    * @author <a href="mailto:peter@apache.org">Peter Donald</a>
  - * @version $Revision: 1.2 $
  + * @version $Revision: 1.3 $
    */
   public interface NamingProvider
   {
  
  
  
  1.4       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/naming/RemoteContext.java
  
  Index: RemoteContext.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/naming/RemoteContext.java,v
  retrieving revision 1.3
  retrieving revision 1.4
  diff -u -r1.3 -r1.4
  --- RemoteContext.java	2001/11/19 12:08:47	1.3
  +++ RemoteContext.java	2001/12/11 09:53:30	1.4
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.naming;
   
  @@ -19,7 +19,7 @@
    * Context that hooks up to a remote source.
    *
    * @author <a href="mailto:peter@apache.org">Peter Donald</a>
  - * @version $Revision: 1.3 $
  + * @version $Revision: 1.4 $
    */
   public class RemoteContext
       extends AbstractContext
  
  
  
  1.3       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/naming/StandardNamespace.java
  
  Index: StandardNamespace.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/naming/StandardNamespace.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- StandardNamespace.java	2001/11/19 12:08:47	1.2
  +++ StandardNamespace.java	2001/12/11 09:53:30	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.naming;
   
  @@ -20,7 +20,7 @@
    * Namespace that directly uses NamingManager.
    *
    * @author <a href="mailto:peter@apache.org">Peter Donald</a>
  - * @version $Revision: 1.2 $
  + * @version $Revision: 1.3 $
    */
   public class StandardNamespace
       implements Namespace
  
  
  
  1.4       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/naming/memory/MemoryContext.java
  
  Index: MemoryContext.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/naming/memory/MemoryContext.java,v
  retrieving revision 1.3
  retrieving revision 1.4
  diff -u -r1.3 -r1.4
  --- MemoryContext.java	2001/11/19 12:08:48	1.3
  +++ MemoryContext.java	2001/12/11 09:53:31	1.4
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.naming.memory;
   
  @@ -21,7 +21,7 @@
    * An in memory context implementation.
    *
    * @author <a href="mailto:peter@apache.org">Peter Donald</a>
  - * @version $Revision: 1.3 $
  + * @version $Revision: 1.4 $
    */
   public class MemoryContext
       extends AbstractLocalContext
  
  
  
  1.4       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/naming/memory/MemoryInitialContextFactory.java
  
  Index: MemoryInitialContextFactory.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/naming/memory/MemoryInitialContextFactory.java,v
  retrieving revision 1.3
  retrieving revision 1.4
  diff -u -r1.3 -r1.4
  --- MemoryInitialContextFactory.java	2001/11/19 12:08:48	1.3
  +++ MemoryInitialContextFactory.java	2001/12/11 09:53:31	1.4
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.naming.memory;
   
  @@ -44,7 +44,7 @@
    * </ul>
    *
    * @author <a href="mailto:peter@apache.org">Peter Donald</a>
  - * @version $Revision: 1.3 $
  + * @version $Revision: 1.4 $
    */
   public class MemoryInitialContextFactory
       implements InitialContextFactory
  
  
  
  1.3       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/naming/memory/MemoryNamingEnumeration.java
  
  Index: MemoryNamingEnumeration.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/naming/memory/MemoryNamingEnumeration.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- MemoryNamingEnumeration.java	2001/11/19 12:08:48	1.2
  +++ MemoryNamingEnumeration.java	2001/12/11 09:53:31	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.naming.memory;
   
  @@ -21,7 +21,7 @@
    * Class for building NamingEnumerations.
    *
    * @author <a href="mailto:peter@apache.org">Peter Donald</a>
  - * @version $Revision: 1.2 $
  + * @version $Revision: 1.3 $
    */
   final class MemoryNamingEnumeration
       extends AbstractNamingEnumeration
  
  
  
  1.3       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/naming/rmi/RMIInitialContextFactory.java
  
  Index: RMIInitialContextFactory.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/naming/rmi/RMIInitialContextFactory.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- RMIInitialContextFactory.java	2001/11/19 12:08:48	1.2
  +++ RMIInitialContextFactory.java	2001/12/11 09:53:31	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.naming.rmi;
   
  @@ -27,7 +27,7 @@
    * Initial context factory for memorycontext.
    *
    * @author <a href="mailto:peter@apache.org">Peter Donald</a>
  - * @version $Revision: 1.2 $
  + * @version $Revision: 1.3 $
    */
   public class RMIInitialContextFactory
       implements InitialContextFactory
  
  
  
  1.3       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/naming/rmi/RMINamingProvider.java
  
  Index: RMINamingProvider.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/naming/rmi/RMINamingProvider.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- RMINamingProvider.java	2001/11/19 12:08:48	1.2
  +++ RMINamingProvider.java	2001/12/11 09:53:31	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.naming.rmi;
   
  @@ -14,7 +14,7 @@
    * The underlying communication interface for remote contexts.
    *
    * @author <a href="mailto:peter@apache.org">Peter Donald</a>
  - * @version $Revision: 1.2 $
  + * @version $Revision: 1.3 $
    */
   public interface RMINamingProvider
       extends NamingProvider, Remote
  
  
  
  1.5       +1 -1      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/naming/rmi/server/Main.java
  
  Index: Main.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/naming/rmi/server/Main.java,v
  retrieving revision 1.4
  retrieving revision 1.5
  diff -u -r1.4 -r1.5
  --- Main.java	2001/10/25 16:39:33	1.4
  +++ Main.java	2001/12/11 09:53:31	1.5
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.naming.rmi.server;
   
  
  
  
  1.4       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/naming/rmi/server/RMINamingProviderImpl.java
  
  Index: RMINamingProviderImpl.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/naming/rmi/server/RMINamingProviderImpl.java,v
  retrieving revision 1.3
  retrieving revision 1.4
  diff -u -r1.3 -r1.4
  --- RMINamingProviderImpl.java	2001/11/19 12:08:48	1.3
  +++ RMINamingProviderImpl.java	2001/12/11 09:53:31	1.4
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.naming.rmi.server;
   
  @@ -25,7 +25,7 @@
    * The RMI implementation of provider.
    *
    * @author <a href="mailto:peter@apache.org">Peter Donald</a>
  - * @version $Revision: 1.3 $
  + * @version $Revision: 1.4 $
    */
   public class RMINamingProviderImpl
       implements Serializable, RMINamingProvider
  
  
  
  1.6       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/pool/AbstractPool.java
  
  Index: AbstractPool.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/pool/AbstractPool.java,v
  retrieving revision 1.5
  retrieving revision 1.6
  diff -u -r1.5 -r1.6
  --- AbstractPool.java	2001/11/09 20:28:06	1.5
  +++ AbstractPool.java	2001/12/11 09:53:31	1.6
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.pool;
   
  @@ -20,7 +20,7 @@
    * This is an <code>Pool</code> that caches Poolable objects for reuse.
    *
    * @author <a href="mailto:bloritsch@apache.org">Berin Loritsch</a>
  - * @version CVS $Revision: 1.5 $ $Date: 2001/11/09 20:28:06 $
  + * @version CVS $Revision: 1.6 $ $Date: 2001/12/11 09:53:31 $
    * @since 4.0
    */
   public abstract class AbstractPool
  
  
  
  1.4       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/pool/DefaultObjectFactory.java
  
  Index: DefaultObjectFactory.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/pool/DefaultObjectFactory.java,v
  retrieving revision 1.3
  retrieving revision 1.4
  diff -u -r1.3 -r1.4
  --- DefaultObjectFactory.java	2001/11/19 12:08:48	1.3
  +++ DefaultObjectFactory.java	2001/12/11 09:53:31	1.4
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.pool;
   
  @@ -17,7 +17,7 @@
    * @author <a href="mailto:bloritsch@apache.org">Berin Loritsch</a>
    * @author <a href="mailto:stefano@apache.org">Stefano Mazzocchi</a>
    * @author <a href="mailto:peter@apache.org">Peter Donald</a>
  - * @version CVS $Revision: 1.3 $ $Date: 2001/11/19 12:08:48 $
  + * @version CVS $Revision: 1.4 $ $Date: 2001/12/11 09:53:31 $
    * @since 4.0
    */
   public class DefaultObjectFactory
  
  
  
  1.7       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/pool/DefaultPool.java
  
  Index: DefaultPool.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/pool/DefaultPool.java,v
  retrieving revision 1.6
  retrieving revision 1.7
  diff -u -r1.6 -r1.7
  --- DefaultPool.java	2001/11/19 12:08:48	1.6
  +++ DefaultPool.java	2001/12/11 09:53:31	1.7
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.pool;
   
  @@ -16,7 +16,7 @@
    * @author <a href="mailto:bloritsch@apache.org">Berin Loritsch</a>
    * @author <a href="mailto:stefano@apache.org">Stefano Mazzocchi</a>
    * @author <a href="mailto:peter@apache.org">Peter Donald</a>
  - * @version CVS $Revision: 1.6 $ $Date: 2001/11/19 12:08:48 $
  + * @version CVS $Revision: 1.7 $ $Date: 2001/12/11 09:53:31 $
    * @since 4.0
    */
   public class DefaultPool
  
  
  
  1.3       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/pool/DefaultPoolController.java
  
  Index: DefaultPoolController.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/pool/DefaultPoolController.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- DefaultPoolController.java	2001/08/07 10:57:09	1.2
  +++ DefaultPoolController.java	2001/12/11 09:53:31	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.pool;
   
  @@ -13,7 +13,7 @@
    * instances of a <code>Poolable</code> are created at one time.
    *
    * @author <a href="mailto:bloritsch@apache.org">Berin Loritsch</a>
  - * @version CVS $Revision: 1.2 $ $Date: 2001/08/07 10:57:09 $
  + * @version CVS $Revision: 1.3 $ $Date: 2001/12/11 09:53:31 $
    * @since 4.0
    */
   public class DefaultPoolController
  
  
  
  1.11      +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/pool/HardResourceLimitingPool.java
  
  Index: HardResourceLimitingPool.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/pool/HardResourceLimitingPool.java,v
  retrieving revision 1.10
  retrieving revision 1.11
  diff -u -r1.10 -r1.11
  --- HardResourceLimitingPool.java	2001/11/19 12:08:48	1.10
  +++ HardResourceLimitingPool.java	2001/12/11 09:53:31	1.11
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.pool;
   
  @@ -16,7 +16,7 @@
    * @author <a href="mailto:bloritsch@apache.org">Berin Loritsch</a>
    * @author <a href="mailto:stefano@apache.org">Stefano Mazzocchi</a>
    * @author <a href="mailto:peter@apache.org">Peter Donald</a>
  - * @version CVS $Revision: 1.10 $ $Date: 2001/11/19 12:08:48 $
  + * @version CVS $Revision: 1.11 $ $Date: 2001/12/11 09:53:31 $
    * @since 4.0
    */
   public class HardResourceLimitingPool
  
  
  
  1.4       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/pool/ObjectFactory.java
  
  Index: ObjectFactory.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/pool/ObjectFactory.java,v
  retrieving revision 1.3
  retrieving revision 1.4
  diff -u -r1.3 -r1.4
  --- ObjectFactory.java	2001/11/19 12:08:48	1.3
  +++ ObjectFactory.java	2001/12/11 09:53:32	1.4
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.pool;
   
  @@ -15,7 +15,7 @@
    * @author <a href="mailto:bloritsch@apache.org">Berin Loritsch</a>
    * @author <a href="mailto:stefano@apache.org">Stefano Mazzocchi</a>
    * @author <a href="mailto:peter@apache.org">Peter Donald</a>
  - * @version CVS $Revision: 1.3 $ $Date: 2001/11/19 12:08:48 $
  + * @version CVS $Revision: 1.4 $ $Date: 2001/12/11 09:53:32 $
    * @since 4.0
    */
   public interface ObjectFactory
  
  
  
  1.3       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/pool/Pool.java
  
  Index: Pool.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/pool/Pool.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- Pool.java	2001/08/07 10:57:09	1.2
  +++ Pool.java	2001/12/11 09:53:32	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.pool;
   
  @@ -15,7 +15,7 @@
    * @author <a href="mailto:bloritsch@apache.org">Berin Loritsch</a>
    * @author <a href="mailto:stefano@apache.org">Stefano Mazzocchi</a>
    * @author <a href="mailto:donaldp@mad.scientist.com">Peter Donald</a>
  - * @version CVS $Revision: 1.2 $ $Date: 2001/08/07 10:57:09 $
  + * @version CVS $Revision: 1.3 $ $Date: 2001/12/11 09:53:32 $
    * @since 4.0
    */
   public interface Pool
  
  
  
  1.4       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/pool/PoolController.java
  
  Index: PoolController.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/pool/PoolController.java,v
  retrieving revision 1.3
  retrieving revision 1.4
  diff -u -r1.3 -r1.4
  --- PoolController.java	2001/11/19 12:08:48	1.3
  +++ PoolController.java	2001/12/11 09:53:32	1.4
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.pool;
   
  @@ -16,7 +16,7 @@
    * @author <a href="mailto:stefano@apache.org">Stefano Mazzocchi</a>
    * @author <a href="mailto:peter@apache.org">Peter Donald</a>
    * @author <a href="mailto:bloritsch@apache.org">Berin Loritsch</a>
  - * @version CVS $Revision: 1.3 $ $Date: 2001/11/19 12:08:48 $
  + * @version CVS $Revision: 1.4 $ $Date: 2001/12/11 09:53:32 $
    * @since 4.0
    */
   public interface PoolController
  
  
  
  1.4       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/pool/Poolable.java
  
  Index: Poolable.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/pool/Poolable.java,v
  retrieving revision 1.3
  retrieving revision 1.4
  diff -u -r1.3 -r1.4
  --- Poolable.java	2001/11/19 12:08:48	1.3
  +++ Poolable.java	2001/12/11 09:53:32	1.4
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.pool;
   
  @@ -18,7 +18,7 @@
    * be reassed once we see it in action.
    *
    * @author <a href="mailto:peter@apache.org">Peter Donald</a>
  - * @version CVS $Revision: 1.3 $ $Date: 2001/11/19 12:08:48 $
  + * @version CVS $Revision: 1.4 $ $Date: 2001/12/11 09:53:32 $
    * @since 4.0
    */
   public interface Poolable
  
  
  
  1.5       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/pool/Recyclable.java
  
  Index: Recyclable.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/pool/Recyclable.java,v
  retrieving revision 1.4
  retrieving revision 1.5
  diff -u -r1.4 -r1.5
  --- Recyclable.java	2001/12/07 13:03:57	1.4
  +++ Recyclable.java	2001/12/11 09:53:32	1.5
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.pool;
   
  @@ -25,7 +25,7 @@
    *
    * @author <a href="mailto:stefano@apache.org">Stefano Mazzocchi</a>
    * @author <a href="mailto:peter@apache.org">Peter Donald</a>
  - * @version CVS $Revision: 1.4 $ $Date: 2001/12/07 13:03:57 $
  + * @version CVS $Revision: 1.5 $ $Date: 2001/12/11 09:53:32 $
    * @since 4.0
    */
   public interface Recyclable
  
  
  
  1.3       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/pool/Resizable.java
  
  Index: Resizable.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/pool/Resizable.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- Resizable.java	2001/08/07 10:57:09	1.2
  +++ Resizable.java	2001/12/11 09:53:32	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.pool;
   
  @@ -11,7 +11,7 @@
    * This is the interface for Pools that are not a fixed size.
    *
    * @author <a href="mailto:bloritsch@apache.org">Berin Loritsch</a>
  - * @version CVS $Revision: 1.2 $ $Date: 2001/08/07 10:57:09 $
  + * @version CVS $Revision: 1.3 $ $Date: 2001/12/11 09:53:32 $
    * @since 4.0
    */
   public interface Resizable
  
  
  
  1.6       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/pool/SingleThreadedPool.java
  
  Index: SingleThreadedPool.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/pool/SingleThreadedPool.java,v
  retrieving revision 1.5
  retrieving revision 1.6
  diff -u -r1.5 -r1.6
  --- SingleThreadedPool.java	2001/11/19 12:08:48	1.5
  +++ SingleThreadedPool.java	2001/12/11 09:53:32	1.6
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.pool;
   
  @@ -16,7 +16,7 @@
    * @author <a href="mailto:bloritsch@apache.org">Berin Loritsch</a>
    * @author <a href="mailto:stefano@apache.org">Stefano Mazzocchi</a>
    * @author <a href="mailto:peter@apache.org">Peter Donald</a>
  - * @version CVS $Revision: 1.5 $ $Date: 2001/11/19 12:08:48 $
  + * @version CVS $Revision: 1.6 $ $Date: 2001/12/11 09:53:32 $
    * @since 4.0
    */
   public class SingleThreadedPool
  
  
  
  1.7       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/pool/SoftResourceLimitingPool.java
  
  Index: SoftResourceLimitingPool.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/pool/SoftResourceLimitingPool.java,v
  retrieving revision 1.6
  retrieving revision 1.7
  diff -u -r1.6 -r1.7
  --- SoftResourceLimitingPool.java	2001/08/09 14:30:01	1.6
  +++ SoftResourceLimitingPool.java	2001/12/11 09:53:32	1.7
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.pool;
   
  @@ -11,7 +11,7 @@
    * This is an <code>Pool</code> that caches Poolable objects for reuse.
    *
    * @author <a href="mailto:bloritsch@apache.org">Berin Loritsch</a>
  - * @version CVS $Revision: 1.6 $ $Date: 2001/08/09 14:30:01 $
  + * @version CVS $Revision: 1.7 $ $Date: 2001/12/11 09:53:32 $
    * @since 4.0
    */
   public class SoftResourceLimitingPool
  
  
  
  1.4       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/property/PropertyException.java
  
  Index: PropertyException.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/property/PropertyException.java,v
  retrieving revision 1.3
  retrieving revision 1.4
  diff -u -r1.3 -r1.4
  --- PropertyException.java	2001/11/19 12:08:48	1.3
  +++ PropertyException.java	2001/12/11 09:53:32	1.4
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.property;
   
  @@ -13,7 +13,7 @@
    * Thrown when a property can not be resolved properly.
    *
    * @author <a href="mailto:peter@apache.org">Peter Donald</a>
  - * @version CVS $Revision: 1.3 $ $Date: 2001/11/19 12:08:48 $
  + * @version CVS $Revision: 1.4 $ $Date: 2001/12/11 09:53:32 $
    * @since 4.0
    */
   public class PropertyException
  
  
  
  1.5       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/property/PropertyUtil.java
  
  Index: PropertyUtil.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/property/PropertyUtil.java,v
  retrieving revision 1.4
  retrieving revision 1.5
  diff -u -r1.4 -r1.5
  --- PropertyUtil.java	2001/11/19 12:08:48	1.4
  +++ PropertyUtil.java	2001/12/11 09:53:32	1.5
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.property;
   
  @@ -15,7 +15,7 @@
    * This provides utility methods for properties.
    *
    * @author <a href="mailto:peter@apache.org">Peter Donald</a>
  - * @version CVS $Revision: 1.4 $ $Date: 2001/11/19 12:08:48 $
  + * @version CVS $Revision: 1.5 $ $Date: 2001/12/11 09:53:32 $
    * @since 4.0
    */
   public final class PropertyUtil
  
  
  
  1.5       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/proxy/DynamicProxy.java
  
  Index: DynamicProxy.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/proxy/DynamicProxy.java,v
  retrieving revision 1.4
  retrieving revision 1.5
  diff -u -r1.4 -r1.5
  --- DynamicProxy.java	2001/12/05 21:28:55	1.4
  +++ DynamicProxy.java	2001/12/11 09:53:32	1.5
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.proxy;
   
  @@ -25,7 +25,7 @@
    *
    * @author <a href="mailto:peter@apache.org">Peter Donald</a>
    * @author <a href="mailto:Paul_Hammant@yahoo.com">Paul Hammant</a>
  - * @version CVS $Revision: 1.4 $ $Date: 2001/12/05 21:28:55 $
  + * @version CVS $Revision: 1.5 $ $Date: 2001/12/11 09:53:32 $
    * @since 4.0b5
    */
   public final class DynamicProxy
  
  
  
  1.3       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/testcase/CascadingAssertionFailedError.java
  
  Index: CascadingAssertionFailedError.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/testcase/CascadingAssertionFailedError.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- CascadingAssertionFailedError.java	2001/11/19 12:08:48	1.2
  +++ CascadingAssertionFailedError.java	2001/12/11 09:53:32	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.testcase;
   
  @@ -20,7 +20,7 @@
    * messages from JUnit (The AssertionFailedError hides the underlying cause)
    *
    * @author <a href="mailto:giacomo@apache.org">Giacomo Pati</a>
  - * @version $Id: CascadingAssertionFailedError.java,v 1.2 2001/11/19 12:08:48 donaldp Exp $
  + * @version $Id: CascadingAssertionFailedError.java,v 1.3 2001/12/11 09:53:32 jefft Exp $
    */
   public class CascadingAssertionFailedError extends AssertionFailedError implements CascadingThrowable {
       private final Throwable m_throwable;
  
  
  
  1.15      +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/testcase/ExcaliburTestCase.java
  
  Index: ExcaliburTestCase.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/testcase/ExcaliburTestCase.java,v
  retrieving revision 1.14
  retrieving revision 1.15
  diff -u -r1.14 -r1.15
  --- ExcaliburTestCase.java	2001/11/19 02:15:39	1.14
  +++ ExcaliburTestCase.java	2001/12/11 09:53:32	1.15
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.testcase;
   
  @@ -146,7 +146,7 @@
    * </pre>
    *
    * @author <a href="mailto:giacomo@apache.org">Giacomo Pati</a>
  - * @version $Id: ExcaliburTestCase.java,v 1.14 2001/11/19 02:15:39 colus Exp $
  + * @version $Id: ExcaliburTestCase.java,v 1.15 2001/12/11 09:53:32 jefft Exp $
    */
   public class ExcaliburTestCase
       extends TestCase
  
  
  
  1.4       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/xml/xpath/JaxenProcessorImpl.java
  
  Index: JaxenProcessorImpl.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/xml/xpath/JaxenProcessorImpl.java,v
  retrieving revision 1.3
  retrieving revision 1.4
  diff -u -r1.3 -r1.4
  --- JaxenProcessorImpl.java	2001/10/31 12:48:54	1.3
  +++ JaxenProcessorImpl.java	2001/12/11 09:53:32	1.4
  @@ -3,7 +3,7 @@
    * ------------------------------------------------------------------------- *
    * This software is published under the terms of the Apache Software License *
    * version 1.1, a copy of which has been included  with this distribution in *
  - * the LICENSE file.                                                         *
  + * the LICENSE.txt file.                                                         *
    *****************************************************************************/
   package org.apache.avalon.excalibur.xml.xpath;
   
  @@ -34,7 +34,7 @@
    * </pre>
    *
    * @author <a href="mailto:dims@yahoo.com">Davanum Srinivas</a>
  - * @version CVS $Revision: 1.3 $ $Date: 2001/10/31 12:48:54 $ $Author: jefft $
  + * @version CVS $Revision: 1.4 $ $Date: 2001/12/11 09:53:32 $ $Author: jefft $
    */
   public class JaxenProcessorImpl
     extends AbstractLoggable
  
  
  
  1.5       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/xml/xpath/XPathProcessor.java
  
  Index: XPathProcessor.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/xml/xpath/XPathProcessor.java,v
  retrieving revision 1.4
  retrieving revision 1.5
  diff -u -r1.4 -r1.5
  --- XPathProcessor.java	2001/11/01 15:25:29	1.4
  +++ XPathProcessor.java	2001/12/11 09:53:32	1.5
  @@ -3,7 +3,7 @@
    * ------------------------------------------------------------------------- *
    * This software is published under the terms of the Apache Software License *
    * version 1.1, a copy of which has been included  with this distribution in *
  - * the LICENSE file.                                                         *
  + * the LICENSE.txt file.                                                         *
    *****************************************************************************/
   package org.apache.avalon.excalibur.xml.xpath;
   
  @@ -15,7 +15,7 @@
    * This is the interface of the XPath processor.
    *
    * @author <a href="mailto:dims@yahoo.com">Davanum Srinivas</a>
  - * @version CVS $Revision: 1.4 $ $Date: 2001/11/01 15:25:29 $ $Author: colus $
  + * @version CVS $Revision: 1.5 $ $Date: 2001/12/11 09:53:32 $ $Author: jefft $
    */
   public interface XPathProcessor extends Component
   {
  
  
  
  1.4       +2 -2      jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/xml/xpath/XPathProcessorImpl.java
  
  Index: XPathProcessorImpl.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/java/org/apache/avalon/excalibur/xml/xpath/XPathProcessorImpl.java,v
  retrieving revision 1.3
  retrieving revision 1.4
  diff -u -r1.3 -r1.4
  --- XPathProcessorImpl.java	2001/10/31 12:44:53	1.3
  +++ XPathProcessorImpl.java	2001/12/11 09:53:32	1.4
  @@ -3,7 +3,7 @@
    * ------------------------------------------------------------------------- *
    * This software is published under the terms of the Apache Software License *
    * version 1.1, a copy of which has been included  with this distribution in *
  - * the LICENSE file.                                                         *
  + * the LICENSE.txt file.                                                         *
    *****************************************************************************/
   package org.apache.avalon.excalibur.xml.xpath;
   
  @@ -26,7 +26,7 @@
    * </pre>
    *
    * @author <a href="mailto:dims@yahoo.com">Davanum Srinivas</a>
  - * @version CVS $Revision: 1.3 $ $Date: 2001/10/31 12:44:53 $ $Author: jefft $
  + * @version CVS $Revision: 1.4 $ $Date: 2001/12/11 09:53:32 $ $Author: jefft $
    */
   public class XPathProcessorImpl
     extends AbstractLoggable
  
  
  
  1.4       +1 -1      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/cache/AbstractCache.java
  
  Index: AbstractCache.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/cache/AbstractCache.java,v
  retrieving revision 1.3
  retrieving revision 1.4
  diff -u -r1.3 -r1.4
  --- AbstractCache.java	2001/12/03 01:42:51	1.3
  +++ AbstractCache.java	2001/12/11 09:53:33	1.4
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included  with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.cache;
   
  
  
  
  1.3       +1 -1      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/cache/AbstractCacheStore.java
  
  Index: AbstractCacheStore.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/cache/AbstractCacheStore.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- AbstractCacheStore.java	2001/12/03 01:42:51	1.2
  +++ AbstractCacheStore.java	2001/12/11 09:53:33	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included  with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.cache;
   
  
  
  
  1.4       +1 -1      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/cache/Cache.java
  
  Index: Cache.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/cache/Cache.java,v
  retrieving revision 1.3
  retrieving revision 1.4
  diff -u -r1.3 -r1.4
  --- Cache.java	2001/12/03 01:42:51	1.3
  +++ Cache.java	2001/12/11 09:53:33	1.4
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included  with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.cache;
   
  
  
  
  1.4       +1 -1      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/cache/CacheEvent.java
  
  Index: CacheEvent.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/cache/CacheEvent.java,v
  retrieving revision 1.3
  retrieving revision 1.4
  diff -u -r1.3 -r1.4
  --- CacheEvent.java	2001/12/03 01:42:51	1.3
  +++ CacheEvent.java	2001/12/11 09:53:33	1.4
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included  with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.cache;
   
  
  
  
  1.4       +1 -1      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/cache/CacheListener.java
  
  Index: CacheListener.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/cache/CacheListener.java,v
  retrieving revision 1.3
  retrieving revision 1.4
  diff -u -r1.3 -r1.4
  --- CacheListener.java	2001/12/03 01:42:51	1.3
  +++ CacheListener.java	2001/12/11 09:53:33	1.4
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included  with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.cache;
   
  
  
  
  1.4       +1 -1      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/cache/CacheStore.java
  
  Index: CacheStore.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/cache/CacheStore.java,v
  retrieving revision 1.3
  retrieving revision 1.4
  diff -u -r1.3 -r1.4
  --- CacheStore.java	2001/12/03 01:42:51	1.3
  +++ CacheStore.java	2001/12/11 09:53:33	1.4
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included  with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.cache;
   
  
  
  
  1.3       +1 -1      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/cache/CacheValidator.java
  
  Index: CacheValidator.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/cache/CacheValidator.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- CacheValidator.java	2001/12/03 01:42:51	1.2
  +++ CacheValidator.java	2001/12/11 09:53:33	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included  with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.cache;
   
  
  
  
  1.5       +1 -1      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/cache/DefaultCache.java
  
  Index: DefaultCache.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/cache/DefaultCache.java,v
  retrieving revision 1.4
  retrieving revision 1.5
  diff -u -r1.4 -r1.5
  --- DefaultCache.java	2001/12/03 01:42:51	1.4
  +++ DefaultCache.java	2001/12/11 09:53:33	1.5
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included  with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.cache;
   
  
  
  
  1.3       +1 -1      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/cache/FIFOCachePolicy.java
  
  Index: FIFOCachePolicy.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/cache/FIFOCachePolicy.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- FIFOCachePolicy.java	2001/12/03 01:42:51	1.2
  +++ FIFOCachePolicy.java	2001/12/11 09:53:33	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included  with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.cache;
   
  
  
  
  1.3       +1 -1      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/cache/LRUCache.java
  
  Index: LRUCache.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/cache/LRUCache.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- LRUCache.java	2001/12/03 01:42:51	1.2
  +++ LRUCache.java	2001/12/11 09:53:33	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included  with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.cache;
   
  
  
  
  1.3       +1 -1      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/cache/LRUCachePolicy.java
  
  Index: LRUCachePolicy.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/cache/LRUCachePolicy.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- LRUCachePolicy.java	2001/12/03 01:42:51	1.2
  +++ LRUCachePolicy.java	2001/12/11 09:53:33	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included  with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.cache;
   
  
  
  
  1.3       +1 -1      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/cache/ListCachePolicy.java
  
  Index: ListCachePolicy.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/cache/ListCachePolicy.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- ListCachePolicy.java	2001/12/03 01:42:51	1.2
  +++ ListCachePolicy.java	2001/12/11 09:53:33	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included  with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.cache;
   
  
  
  
  1.4       +1 -1      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/cache/MemoryCacheStore.java
  
  Index: MemoryCacheStore.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/cache/MemoryCacheStore.java,v
  retrieving revision 1.3
  retrieving revision 1.4
  diff -u -r1.3 -r1.4
  --- MemoryCacheStore.java	2001/12/03 01:42:51	1.3
  +++ MemoryCacheStore.java	2001/12/11 09:53:33	1.4
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included  with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.cache;
   
  
  
  
  1.3       +1 -1      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/cache/ReplacementPolicy.java
  
  Index: ReplacementPolicy.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/cache/ReplacementPolicy.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- ReplacementPolicy.java	2001/12/03 01:42:51	1.2
  +++ ReplacementPolicy.java	2001/12/11 09:53:33	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included  with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.cache;
   
  
  
  
  1.2       +1 -1      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/cache/TimeoutValidator.java
  
  Index: TimeoutValidator.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/cache/TimeoutValidator.java,v
  retrieving revision 1.1
  retrieving revision 1.2
  diff -u -r1.1 -r1.2
  --- TimeoutValidator.java	2001/10/28 06:34:51	1.1
  +++ TimeoutValidator.java	2001/12/11 09:53:33	1.2
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included  with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.cache;
   
  
  
  
  1.3       +1 -1      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/cache/test/LRUCacheTestCase.java
  
  Index: LRUCacheTestCase.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/cache/test/LRUCacheTestCase.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- LRUCacheTestCase.java	2001/12/03 01:42:51	1.2
  +++ LRUCacheTestCase.java	2001/12/11 09:53:33	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included  with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.cache.test;
   
  
  
  
  1.2       +1 -1      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/cache/test/TimeoutValidatorTestCase.java
  
  Index: TimeoutValidatorTestCase.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/cache/test/TimeoutValidatorTestCase.java,v
  retrieving revision 1.1
  retrieving revision 1.2
  diff -u -r1.1 -r1.2
  --- TimeoutValidatorTestCase.java	2001/10/28 06:34:51	1.1
  +++ TimeoutValidatorTestCase.java	2001/12/11 09:53:33	1.2
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included  with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.cache.test;
   
  
  
  
  1.3       +1 -1      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/catalog/Catalog.java
  
  Index: Catalog.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/catalog/Catalog.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- Catalog.java	2001/10/25 15:49:41	1.2
  +++ Catalog.java	2001/12/11 09:53:34	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.catalog;
   
  
  
  
  1.2       +1 -1      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/catalog/CatalogEntityResolver.java
  
  Index: CatalogEntityResolver.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/catalog/CatalogEntityResolver.java,v
  retrieving revision 1.1
  retrieving revision 1.2
  diff -u -r1.1 -r1.2
  --- CatalogEntityResolver.java	2001/09/23 13:23:13	1.1
  +++ CatalogEntityResolver.java	2001/12/11 09:53:34	1.2
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.catalog;
   
  
  
  
  1.2       +1 -1      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/catalog/CatalogEntry.java
  
  Index: CatalogEntry.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/catalog/CatalogEntry.java,v
  retrieving revision 1.1
  retrieving revision 1.2
  diff -u -r1.1 -r1.2
  --- CatalogEntry.java	2001/09/23 13:23:13	1.1
  +++ CatalogEntry.java	2001/12/11 09:53:34	1.2
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.catalog;
   
  
  
  
  1.2       +1 -1      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/catalog/CatalogReader.java
  
  Index: CatalogReader.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/catalog/CatalogReader.java,v
  retrieving revision 1.1
  retrieving revision 1.2
  diff -u -r1.1 -r1.2
  --- CatalogReader.java	2001/09/23 13:23:13	1.1
  +++ CatalogReader.java	2001/12/11 09:53:34	1.2
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.catalog;
   
  
  
  
  1.2       +2 -2      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/catalog/InvalidCatalogEntryException.java
  
  Index: InvalidCatalogEntryException.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/catalog/InvalidCatalogEntryException.java,v
  retrieving revision 1.1
  retrieving revision 1.2
  diff -u -r1.1 -r1.2
  --- InvalidCatalogEntryException.java	2001/09/23 13:23:13	1.1
  +++ InvalidCatalogEntryException.java	2001/12/11 09:53:34	1.2
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.catalog;
   
  @@ -13,7 +13,7 @@
    * argument.</p>
    *
    * @author <a href="mailto:nwalsh@arbortext.com">Norman Walsh</a>
  - * @version CVS $Revision: 1.1 $ $Date: 2001/09/23 13:23:13 $
  + * @version CVS $Revision: 1.2 $ $Date: 2001/12/11 09:53:34 $
    */
   public class InvalidCatalogEntryException extends Exception
   {
  
  
  
  1.2       +2 -2      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/catalog/InvalidCatalogEntryTypeException.java
  
  Index: InvalidCatalogEntryTypeException.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/catalog/InvalidCatalogEntryTypeException.java,v
  retrieving revision 1.1
  retrieving revision 1.2
  diff -u -r1.1 -r1.2
  --- InvalidCatalogEntryTypeException.java	2001/09/23 13:23:13	1.1
  +++ InvalidCatalogEntryTypeException.java	2001/12/11 09:53:34	1.2
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.catalog;
   
  @@ -12,7 +12,7 @@
    * instance using an invalid entry type.</p>
    *
    * @author <a href="mailto:nwalsh@arbortext.com">Norman Walsh</a>
  - * @version CVS $Revision: 1.1 $ $Date: 2001/09/23 13:23:13 $
  + * @version CVS $Revision: 1.2 $ $Date: 2001/12/11 09:53:34 $
    */
   public class InvalidCatalogEntryTypeException
       extends Exception
  
  
  
  1.2       +2 -2      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/catalog/NoXMLParserException.java
  
  Index: NoXMLParserException.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/catalog/NoXMLParserException.java,v
  retrieving revision 1.1
  retrieving revision 1.2
  diff -u -r1.1 -r1.2
  --- NoXMLParserException.java	2001/09/23 13:23:13	1.1
  +++ NoXMLParserException.java	2001/12/11 09:53:34	1.2
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.catalog;
   
  @@ -12,7 +12,7 @@
    * Parser class has been provided.</p>
    *
    * @author <a href="mailto:nwalsh@arbortext.com">Norman Walsh</a>
  - * @version CVS $Revision: 1.1 $ $Date: 2001/09/23 13:23:13 $
  + * @version CVS $Revision: 1.2 $ $Date: 2001/12/11 09:53:34 $
    * @see XMLCatalogReader
    * @see XMLCatalogReader#setParserClass
    */
  
  
  
  1.2       +2 -2      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/catalog/NotXMLCatalogException.java
  
  Index: NotXMLCatalogException.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/catalog/NotXMLCatalogException.java,v
  retrieving revision 1.1
  retrieving revision 1.2
  diff -u -r1.1 -r1.2
  --- NotXMLCatalogException.java	2001/09/23 13:23:13	1.1
  +++ NotXMLCatalogException.java	2001/12/11 09:53:34	1.2
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.catalog;
   
  @@ -12,7 +12,7 @@
    * appears not to be XML.</p>
    *
    * @author <a href="mailto:nwalsh@arbortext.com">Norman Walsh</a>
  - * @version CVS $Revision: 1.1 $ $Date: 2001/09/23 13:23:13 $
  + * @version CVS $Revision: 1.2 $ $Date: 2001/12/11 09:53:34 $
    */
   public class NotXMLCatalogException extends Exception
   {
  
  
  
  1.2       +2 -2      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/catalog/UnknownCatalogFormatException.java
  
  Index: UnknownCatalogFormatException.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/catalog/UnknownCatalogFormatException.java,v
  retrieving revision 1.1
  retrieving revision 1.2
  diff -u -r1.1 -r1.2
  --- UnknownCatalogFormatException.java	2001/09/23 13:23:13	1.1
  +++ UnknownCatalogFormatException.java	2001/12/11 09:53:34	1.2
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.catalog;
   
  @@ -12,7 +12,7 @@
    * the catalog file is unrecognized.</p>
    *
    * @author <a href="mailto:nwalsh@arbortext.com">Norman Walsh</a>
  - * @version CVS $Revision: 1.1 $ $Date: 2001/09/23 13:23:13 $
  + * @version CVS $Revision: 1.2 $ $Date: 2001/12/11 09:53:34 $
    */
   public class UnknownCatalogFormatException extends Exception
   {
  
  
  
  1.2       +1 -1      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/catalog/XMLCatalogReader.java
  
  Index: XMLCatalogReader.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/catalog/XMLCatalogReader.java,v
  retrieving revision 1.1
  retrieving revision 1.2
  diff -u -r1.1 -r1.2
  --- XMLCatalogReader.java	2001/09/23 13:23:13	1.1
  +++ XMLCatalogReader.java	2001/12/11 09:53:34	1.2
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.catalog;
   
  
  
  
  1.6       +1 -1      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/container/AbstractContainer.java
  
  Index: AbstractContainer.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/container/AbstractContainer.java,v
  retrieving revision 1.5
  retrieving revision 1.6
  diff -u -r1.5 -r1.6
  --- AbstractContainer.java	2001/11/19 12:09:17	1.5
  +++ AbstractContainer.java	2001/12/11 09:53:34	1.6
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.container;
   
  
  
  
  1.4       +1 -1      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/container/Container.java
  
  Index: Container.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/container/Container.java,v
  retrieving revision 1.3
  retrieving revision 1.4
  diff -u -r1.3 -r1.4
  --- Container.java	2001/11/19 12:09:17	1.3
  +++ Container.java	2001/12/11 09:53:34	1.4
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.container;
   
  
  
  
  1.3       +1 -1      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/container/ContainerException.java
  
  Index: ContainerException.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/container/ContainerException.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- ContainerException.java	2001/11/19 12:09:17	1.2
  +++ ContainerException.java	2001/12/11 09:53:34	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.container;
   
  
  
  
  1.3       +1 -1      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/container/Entry.java
  
  Index: Entry.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/container/Entry.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- Entry.java	2001/11/19 12:09:17	1.2
  +++ Entry.java	2001/12/11 09:53:34	1.3
  @@ -3,7 +3,7 @@
    * 
    * This software is published under the terms of the Apache Software License 
    * version 1.1, a copy of which has been included with this distribution in 
  - * the LICENSE file. 
  + * the LICENSE.txt file. 
    */
   package org.apache.avalon.excalibur.container;
   
  
  
  
  1.3       +1 -1      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/container/Info.java
  
  Index: Info.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/container/Info.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- Info.java	2001/11/19 12:09:17	1.2
  +++ Info.java	2001/12/11 09:53:34	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.container;
   
  
  
  
  1.3       +1 -1      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/container/Locator.java
  
  Index: Locator.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/container/Locator.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- Locator.java	2001/11/19 12:09:17	1.2
  +++ Locator.java	2001/12/11 09:53:34	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.container;
   
  
  
  
  1.4       +1 -1      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/container/State.java
  
  Index: State.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/container/State.java,v
  retrieving revision 1.3
  retrieving revision 1.4
  diff -u -r1.3 -r1.4
  --- State.java	2001/11/19 12:09:17	1.3
  +++ State.java	2001/12/11 09:53:34	1.4
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.container;
   
  
  
  
  1.9       +2 -2      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/extension/DefaultPackageRepository.java
  
  Index: DefaultPackageRepository.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/extension/DefaultPackageRepository.java,v
  retrieving revision 1.8
  retrieving revision 1.9
  diff -u -r1.8 -r1.9
  --- DefaultPackageRepository.java	2001/11/19 12:09:17	1.8
  +++ DefaultPackageRepository.java	2001/12/11 09:53:34	1.9
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.extension;
   
  @@ -23,7 +23,7 @@
    * a path to find the Optional Packages.</p>
    *
    * @author <a href="mailto:peter@apache.org">Peter Donald</a>
  - * @version $Revision: 1.8 $ $Date: 2001/11/19 12:09:17 $
  + * @version $Revision: 1.9 $ $Date: 2001/12/11 09:53:34 $
    * @see OptionalPackage
    * @see PackageRepository
    */
  
  
  
  1.8       +2 -2      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/extension/Extension.java
  
  Index: Extension.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/extension/Extension.java,v
  retrieving revision 1.7
  retrieving revision 1.8
  diff -u -r1.7 -r1.8
  --- Extension.java	2001/11/22 07:52:05	1.7
  +++ Extension.java	2001/12/11 09:53:34	1.8
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.extension;
   
  @@ -30,7 +30,7 @@
    *
    * @author <a href="mailto:craigmcc@apache.org">Craig R. McClanahan</a>
    * @author <a href="mailto:peter@apache.org">Peter Donald</a>
  - * @version $Revision: 1.7 $ $Date: 2001/11/22 07:52:05 $
  + * @version $Revision: 1.8 $ $Date: 2001/12/11 09:53:34 $
    */
   public final class Extension
   {
  
  
  
  1.6       +1 -1      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/extension/OptionalPackage.java
  
  Index: OptionalPackage.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/extension/OptionalPackage.java,v
  retrieving revision 1.5
  retrieving revision 1.6
  diff -u -r1.5 -r1.6
  --- OptionalPackage.java	2001/11/19 12:09:17	1.5
  +++ OptionalPackage.java	2001/12/11 09:53:34	1.6
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.extension;
   
  
  
  
  1.7       +2 -2      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/extension/PackageManager.java
  
  Index: PackageManager.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/extension/PackageManager.java,v
  retrieving revision 1.6
  retrieving revision 1.7
  diff -u -r1.6 -r1.7
  --- PackageManager.java	2001/11/19 12:09:17	1.6
  +++ PackageManager.java	2001/12/11 09:53:34	1.7
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.extension;
   
  @@ -19,7 +19,7 @@
    * directories.
    *
    * @author <a href="mailto:peter@apache.org">Peter Donald</a>
  - * @version $Revision: 1.6 $ $Date: 2001/11/19 12:09:17 $
  + * @version $Revision: 1.7 $ $Date: 2001/12/11 09:53:34 $
    * @see PackageRepository
    */
   public class PackageManager
  
  
  
  1.5       +2 -2      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/extension/PackageRepository.java
  
  Index: PackageRepository.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/extension/PackageRepository.java,v
  retrieving revision 1.4
  retrieving revision 1.5
  diff -u -r1.4 -r1.5
  --- PackageRepository.java	2001/11/19 12:09:17	1.4
  +++ PackageRepository.java	2001/12/11 09:53:34	1.5
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.extension;
   
  @@ -25,7 +25,7 @@
    * <code>guide/extensions/versioning.html</code></p>.
    *
    * @author <a href="mailto:peter@apache.org">Peter Donald</a>
  - * @version $Revision: 1.4 $ $Date: 2001/11/19 12:09:17 $
  + * @version $Revision: 1.5 $ $Date: 2001/12/11 09:53:34 $
    */
   public interface PackageRepository
   {
  
  
  
  1.3       +2 -2      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/extension/UnsatisfiedExtensionException.java
  
  Index: UnsatisfiedExtensionException.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/extension/UnsatisfiedExtensionException.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- UnsatisfiedExtensionException.java	2001/11/19 12:09:17	1.2
  +++ UnsatisfiedExtensionException.java	2001/12/11 09:53:34	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.extension;
   
  @@ -11,7 +11,7 @@
    * Exception indicating an extension was not found in Package Repository.
    *
    * @author <a href="mailto:peter@apache.org">Peter Donald</a>
  - * @version $Revision: 1.2 $ $Date: 2001/11/19 12:09:17 $
  + * @version $Revision: 1.3 $ $Date: 2001/12/11 09:53:34 $
    * @see Extension
    */
   public class UnsatisfiedExtensionException
  
  
  
  1.8       +2 -2      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/extension/test/ExtensionTestCase.java
  
  Index: ExtensionTestCase.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/extension/test/ExtensionTestCase.java,v
  retrieving revision 1.7
  retrieving revision 1.8
  diff -u -r1.7 -r1.8
  --- ExtensionTestCase.java	2001/11/22 07:41:46	1.7
  +++ ExtensionTestCase.java	2001/12/11 09:53:35	1.8
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.extension.test;
   
  @@ -17,7 +17,7 @@
    * TestCases for Extension. 
    *
    * @author <a href="mailto:peter@apache.org">Peter Donald</a>
  - * @version $Revision: 1.7 $ $Date: 2001/11/22 07:41:46 $
  + * @version $Revision: 1.8 $ $Date: 2001/12/11 09:53:35 $
    */
   public class ExtensionTestCase 
       extends TestCase
  
  
  
  1.9       +2 -2      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/extension/test/PackageRepositoryTestCase.java
  
  Index: PackageRepositoryTestCase.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/extension/test/PackageRepositoryTestCase.java,v
  retrieving revision 1.8
  retrieving revision 1.9
  diff -u -r1.8 -r1.9
  --- PackageRepositoryTestCase.java	2001/11/19 12:09:17	1.8
  +++ PackageRepositoryTestCase.java	2001/12/11 09:53:35	1.9
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.extension.test;
   
  @@ -23,7 +23,7 @@
    * TestCases for PackageRepository.
    *
    * @author <a href="mailto:peter@apache.org">Peter Donald</a>
  - * @version $Revision: 1.8 $ $Date: 2001/11/19 12:09:17 $
  + * @version $Revision: 1.9 $ $Date: 2001/12/11 09:53:35 $
    */
   public class PackageRepositoryTestCase
       extends TestCase
  
  
  
  1.7       +1 -1      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/i18n/AbstractBundle.java
  
  Index: AbstractBundle.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/i18n/AbstractBundle.java,v
  retrieving revision 1.6
  retrieving revision 1.7
  diff -u -r1.6 -r1.7
  --- AbstractBundle.java	2001/11/19 12:09:17	1.6
  +++ AbstractBundle.java	2001/12/11 09:53:35	1.7
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.i18n;
   
  
  
  
  1.5       +2 -2      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/i18n/Bundle.java
  
  Index: Bundle.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/i18n/Bundle.java,v
  retrieving revision 1.4
  retrieving revision 1.5
  diff -u -r1.4 -r1.5
  --- Bundle.java	2001/11/05 23:39:36	1.4
  +++ Bundle.java	2001/12/11 09:53:35	1.5
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.i18n;
   
  @@ -14,7 +14,7 @@
    * This is the interface of the ResourceBundle, for used for i18n support.
    *
    * @author <a href="mailto:neeme@apache.org">Neeme Praks</a>
  - * @version CVS $Revision: 1.4 $ $Date: 2001/11/05 23:39:36 $ $Author: donaldp $
  + * @version CVS $Revision: 1.5 $ $Date: 2001/12/11 09:53:35 $ $Author: jefft $
    */
   public interface Bundle
   {
  
  
  
  1.5       +2 -2      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/i18n/BundleInfo.java
  
  Index: BundleInfo.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/i18n/BundleInfo.java,v
  retrieving revision 1.4
  retrieving revision 1.5
  diff -u -r1.4 -r1.5
  --- BundleInfo.java	2001/12/07 13:48:08	1.4
  +++ BundleInfo.java	2001/12/11 09:53:35	1.5
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.i18n;
   
  @@ -19,7 +19,7 @@
    * Used to map locale information to URI space, to find the relevant bundle.
    *
    * @author <a href="mailto:neeme@apache.org">Neeme Praks</a>
  - * @version CVS $Revision: 1.4 $ $Date: 2001/12/07 13:48:08 $ $Author: neeme $
  + * @version CVS $Revision: 1.5 $ $Date: 2001/12/11 09:53:35 $ $Author: jefft $
    */
   public class BundleInfo implements Component, Poolable, Recyclable
   {
  
  
  
  1.4       +2 -2      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/i18n/BundleInfoMapper.java
  
  Index: BundleInfoMapper.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/i18n/BundleInfoMapper.java,v
  retrieving revision 1.3
  retrieving revision 1.4
  diff -u -r1.3 -r1.4
  --- BundleInfoMapper.java	2001/11/05 23:39:36	1.3
  +++ BundleInfoMapper.java	2001/12/11 09:53:35	1.4
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.i18n;
   
  @@ -12,7 +12,7 @@
    * to find the relevant bundle.
    *
    * @author <a href="mailto:neeme@apache.org">Neeme Praks</a>
  - * @version CVS $Revision: 1.3 $ $Date: 2001/11/05 23:39:36 $ $Author: donaldp $
  + * @version CVS $Revision: 1.4 $ $Date: 2001/12/11 09:53:35 $ $Author: jefft $
    */
   public interface BundleInfoMapper
   {
  
  
  
  1.4       +2 -2      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/i18n/BundleLoader.java
  
  Index: BundleLoader.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/i18n/BundleLoader.java,v
  retrieving revision 1.3
  retrieving revision 1.4
  diff -u -r1.3 -r1.4
  --- BundleLoader.java	2001/11/05 23:39:36	1.3
  +++ BundleLoader.java	2001/12/11 09:53:35	1.4
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.i18n;
   
  @@ -13,7 +13,7 @@
    * Used to map locale information to URI space, to find the relevant bundle.
    *
    * @author <a href="mailto:neeme@apache.org">Neeme Praks</a>
  - * @version CVS $Revision: 1.3 $ $Date: 2001/11/05 23:39:36 $ $Author: donaldp $
  + * @version CVS $Revision: 1.4 $ $Date: 2001/12/11 09:53:35 $ $Author: jefft $
    */
   public interface BundleLoader 
       extends Configurable
  
  
  
  1.4       +2 -2      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/i18n/BundleMatcher.java
  
  Index: BundleMatcher.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/i18n/BundleMatcher.java,v
  retrieving revision 1.3
  retrieving revision 1.4
  diff -u -r1.3 -r1.4
  --- BundleMatcher.java	2001/11/05 23:39:36	1.3
  +++ BundleMatcher.java	2001/12/11 09:53:35	1.4
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.i18n;
   
  @@ -14,7 +14,7 @@
    * to find the relevant bundle.
    *
    * @author <a href="mailto:neeme@apache.org">Neeme Praks</a>
  - * @version CVS $Revision: 1.3 $ $Date: 2001/11/05 23:39:36 $ $Author: donaldp $
  + * @version CVS $Revision: 1.4 $ $Date: 2001/12/11 09:53:35 $ $Author: jefft $
    */
   public interface BundleMatcher 
       extends Configurable
  
  
  
  1.7       +2 -2      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/i18n/BundleSelector.java
  
  Index: BundleSelector.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/i18n/BundleSelector.java,v
  retrieving revision 1.6
  retrieving revision 1.7
  diff -u -r1.6 -r1.7
  --- BundleSelector.java	2001/12/07 13:48:08	1.6
  +++ BundleSelector.java	2001/12/11 09:53:35	1.7
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.i18n;
   
  @@ -28,7 +28,7 @@
    *
    * @author <a href="mailto:neeme@one.lv">Neeme Praks</a>
    * @author <a href="mailto:mengelhart@earthtrip.com">Mike Engelhart</a>
  - * @version $Id: BundleSelector.java,v 1.6 2001/12/07 13:48:08 neeme Exp $
  + * @version $Id: BundleSelector.java,v 1.7 2001/12/11 09:53:35 jefft Exp $
    */
   
   public class BundleSelector
  
  
  
  1.5       +2 -2      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/i18n/DefaultBundleLoader.java
  
  Index: DefaultBundleLoader.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/i18n/DefaultBundleLoader.java,v
  retrieving revision 1.4
  retrieving revision 1.5
  diff -u -r1.4 -r1.5
  --- DefaultBundleLoader.java	2001/11/19 12:09:17	1.4
  +++ DefaultBundleLoader.java	2001/12/11 09:53:35	1.5
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.i18n;
   
  @@ -21,7 +21,7 @@
    * Used to map locale information to URI space, to find the relevant bundle.
    *
    * @author <a href="mailto:neeme@apache.org">Neeme Praks</a>
  - * @version CVS $Revision: 1.4 $ $Date: 2001/11/19 12:09:17 $ $Author: donaldp $
  + * @version CVS $Revision: 1.5 $ $Date: 2001/12/11 09:53:35 $ $Author: jefft $
    */
   
   public class DefaultBundleLoader extends AbstractLoggable implements BundleLoader, Composable {
  
  
  
  1.4       +2 -2      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/i18n/DefaultBundleMatcher.java
  
  Index: DefaultBundleMatcher.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/i18n/DefaultBundleMatcher.java,v
  retrieving revision 1.3
  retrieving revision 1.4
  diff -u -r1.3 -r1.4
  --- DefaultBundleMatcher.java	2001/12/07 13:48:08	1.3
  +++ DefaultBundleMatcher.java	2001/12/11 09:53:35	1.4
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.i18n;
   
  @@ -19,7 +19,7 @@
    * to find the relevant bundle.
    *
    * @author <a href="mailto:neeme@apache.org">Neeme Praks</a>
  - * @version CVS $Revision: 1.3 $ $Date: 2001/12/07 13:48:08 $ $Author: neeme $
  + * @version CVS $Revision: 1.4 $ $Date: 2001/12/11 09:53:35 $ $Author: jefft $
    */
   public class DefaultBundleMatcher implements BundleMatcher {
   
  
  
  
  1.5       +2 -2      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/i18n/DefaultMapper.java
  
  Index: DefaultMapper.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/i18n/DefaultMapper.java,v
  retrieving revision 1.4
  retrieving revision 1.5
  diff -u -r1.4 -r1.5
  --- DefaultMapper.java	2001/11/19 12:09:17	1.4
  +++ DefaultMapper.java	2001/12/11 09:53:35	1.5
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.i18n;
   
  @@ -14,7 +14,7 @@
    * file ending with en_US.
    *
    * @author <a href="mailto:neeme@apache.org">Neeme Praks</a>
  - * @version CVS $Revision: 1.4 $ $Date: 2001/11/19 12:09:17 $ $Author: donaldp $
  + * @version CVS $Revision: 1.5 $ $Date: 2001/12/11 09:53:35 $ $Author: jefft $
    */
   
   public class DefaultMapper implements BundleInfoMapper {
  
  
  
  1.5       +2 -2      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/i18n/DirectoryMapper.java
  
  Index: DirectoryMapper.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/i18n/DirectoryMapper.java,v
  retrieving revision 1.4
  retrieving revision 1.5
  diff -u -r1.4 -r1.5
  --- DirectoryMapper.java	2001/11/19 12:09:17	1.4
  +++ DirectoryMapper.java	2001/12/11 09:53:35	1.5
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.i18n;
   
  @@ -14,7 +14,7 @@
    * file ending with en_US.
    *
    * @author <a href="mailto:neeme@apache.org">Neeme Praks</a>
  - * @version CVS $Revision: 1.4 $ $Date: 2001/11/19 12:09:17 $ $Author: donaldp $
  + * @version CVS $Revision: 1.5 $ $Date: 2001/12/11 09:53:35 $ $Author: jefft $
    */
   
   public class DirectoryMapper implements BundleInfoMapper {
  
  
  
  1.2       +2 -2      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/i18n/FlatXmlBundle.java
  
  Index: FlatXmlBundle.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/i18n/FlatXmlBundle.java,v
  retrieving revision 1.1
  retrieving revision 1.2
  diff -u -r1.1 -r1.2
  --- FlatXmlBundle.java	2001/10/30 21:38:56	1.1
  +++ FlatXmlBundle.java	2001/12/11 09:53:35	1.2
  @@ -3,13 +3,13 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.i18n;
   
   /**
    * @author <a href="mailto:neeme@apache.org">Neeme Praks</a>
  - * @version $Id: FlatXmlBundle.java,v 1.1 2001/10/30 21:38:56 neeme Exp $
  + * @version $Id: FlatXmlBundle.java,v 1.2 2001/12/11 09:53:35 jefft Exp $
    */
   public class FlatXmlBundle extends XmlBundle {
   
  
  
  
  1.3       +2 -2      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/i18n/XmlBundle.java
  
  Index: XmlBundle.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/i18n/XmlBundle.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- XmlBundle.java	2001/10/31 19:56:47	1.2
  +++ XmlBundle.java	2001/12/11 09:53:35	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.i18n;
   
  @@ -34,7 +34,7 @@
    * @author <a href="mailto:mengelhart@earthtrip.com">Mike Engelhart</a>
    * @author <a href="mailto:neeme@apache.org">Neeme Praks</a>
    * @author <a href="mailto:oleg@one.lv">Oleg Podolsky</a>
  - * @version $Id: XmlBundle.java,v 1.2 2001/10/31 19:56:47 neeme Exp $
  + * @version $Id: XmlBundle.java,v 1.3 2001/12/11 09:53:35 jefft Exp $
    */
   public class XmlBundle extends AbstractBundle implements Disposable, Composable {
   
  
  
  
  1.8       +2 -2      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/i18n/test/AbstractBundleTestCase.java
  
  Index: AbstractBundleTestCase.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/i18n/test/AbstractBundleTestCase.java,v
  retrieving revision 1.7
  retrieving revision 1.8
  diff -u -r1.7 -r1.8
  --- AbstractBundleTestCase.java	2001/11/02 19:37:48	1.7
  +++ AbstractBundleTestCase.java	2001/12/11 09:53:35	1.8
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.i18n.test;
   
  @@ -15,7 +15,7 @@
   
   /**
    * @author <a href="mailto:neeme@apache.org">Neeme Praks</a>
  - * @version $Id: AbstractBundleTestCase.java,v 1.7 2001/11/02 19:37:48 neeme Exp $
  + * @version $Id: AbstractBundleTestCase.java,v 1.8 2001/12/11 09:53:35 jefft Exp $
    */
   public class AbstractBundleTestCase extends ExcaliburTestCase {
   
  
  
  
  1.5       +2 -2      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/i18n/test/DefaultBundleLoaderTestCase.java
  
  Index: DefaultBundleLoaderTestCase.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/i18n/test/DefaultBundleLoaderTestCase.java,v
  retrieving revision 1.4
  retrieving revision 1.5
  diff -u -r1.4 -r1.5
  --- DefaultBundleLoaderTestCase.java	2001/11/02 19:37:48	1.4
  +++ DefaultBundleLoaderTestCase.java	2001/12/11 09:53:35	1.5
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.i18n.test;
   
  @@ -19,7 +19,7 @@
   
   /**
    * @author <a href="mailto:neeme@apache.org">Neeme Praks</a>
  - * @version $Id: DefaultBundleLoaderTestCase.java,v 1.4 2001/11/02 19:37:48 neeme Exp $
  + * @version $Id: DefaultBundleLoaderTestCase.java,v 1.5 2001/12/11 09:53:35 jefft Exp $
    */
   public class DefaultBundleLoaderTestCase extends ExcaliburTestCase {
   
  
  
  
  1.3       +2 -2      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/i18n/test/DefaultBundleMatcherTestCase.java
  
  Index: DefaultBundleMatcherTestCase.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/i18n/test/DefaultBundleMatcherTestCase.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- DefaultBundleMatcherTestCase.java	2001/12/07 13:48:22	1.2
  +++ DefaultBundleMatcherTestCase.java	2001/12/11 09:53:35	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.i18n.test;
   
  @@ -23,7 +23,7 @@
   
   /**
    * @author <a href="mailto:neeme@apache.org">Neeme Praks</a>
  - * @version $Id: DefaultBundleMatcherTestCase.java,v 1.2 2001/12/07 13:48:22 neeme Exp $
  + * @version $Id: DefaultBundleMatcherTestCase.java,v 1.3 2001/12/11 09:53:35 jefft Exp $
    */
   public class DefaultBundleMatcherTestCase extends TestCase {
   
  
  
  
  1.6       +2 -2      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/i18n/test/XmlBundleTestCase.java
  
  Index: XmlBundleTestCase.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/i18n/test/XmlBundleTestCase.java,v
  retrieving revision 1.5
  retrieving revision 1.6
  diff -u -r1.5 -r1.6
  --- XmlBundleTestCase.java	2001/12/07 13:48:22	1.5
  +++ XmlBundleTestCase.java	2001/12/11 09:53:35	1.6
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.i18n.test;
   
  @@ -17,7 +17,7 @@
   
   /**
    * @author <a href="mailto:neeme@apache.org">Neeme Praks</a>
  - * @version $Id: XmlBundleTestCase.java,v 1.5 2001/12/07 13:48:22 neeme Exp $
  + * @version $Id: XmlBundleTestCase.java,v 1.6 2001/12/11 09:53:35 jefft Exp $
    */
   public class XmlBundleTestCase extends ExcaliburTestCase {
   
  
  
  
  1.4       +2 -2      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/i18n/util/ResourceCheck.java
  
  Index: ResourceCheck.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/i18n/util/ResourceCheck.java,v
  retrieving revision 1.3
  retrieving revision 1.4
  diff -u -r1.3 -r1.4
  --- ResourceCheck.java	2001/11/19 12:09:18	1.3
  +++ ResourceCheck.java	2001/12/11 09:53:35	1.4
  @@ -3,13 +3,13 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.i18n.util;
   
   /**
   @author <a href="mailto:neeme@one.lv">Neeme Praks</a>
  -@version $Id: ResourceCheck.java,v 1.3 2001/11/19 12:09:18 donaldp Exp $
  +@version $Id: ResourceCheck.java,v 1.4 2001/12/11 09:53:35 jefft Exp $
   */
   
   import java.util.*;
  
  
  
  1.4       +1 -1      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/lang/DefaultThreadContextPolicy.java
  
  Index: DefaultThreadContextPolicy.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/lang/DefaultThreadContextPolicy.java,v
  retrieving revision 1.3
  retrieving revision 1.4
  diff -u -r1.3 -r1.4
  --- DefaultThreadContextPolicy.java	2001/11/19 12:09:18	1.3
  +++ DefaultThreadContextPolicy.java	2001/12/11 09:53:36	1.4
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.lang;
   
  
  
  
  1.3       +1 -1      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/lang/Layer.java
  
  Index: Layer.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/lang/Layer.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- Layer.java	2001/11/19 12:09:18	1.2
  +++ Layer.java	2001/12/11 09:53:36	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.lang;
   
  
  
  
  1.4       +1 -1      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/lang/LayeredThreadContext.java
  
  Index: LayeredThreadContext.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/lang/LayeredThreadContext.java,v
  retrieving revision 1.3
  retrieving revision 1.4
  diff -u -r1.3 -r1.4
  --- LayeredThreadContext.java	2001/11/19 12:09:18	1.3
  +++ LayeredThreadContext.java	2001/12/11 09:53:36	1.4
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.lang;
   
  
  
  
  1.6       +1 -1      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/lang/ThreadContext.java
  
  Index: ThreadContext.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/lang/ThreadContext.java,v
  retrieving revision 1.5
  retrieving revision 1.6
  diff -u -r1.5 -r1.6
  --- ThreadContext.java	2001/11/19 12:09:18	1.5
  +++ ThreadContext.java	2001/12/11 09:53:36	1.6
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.lang;
   
  
  
  
  1.3       +1 -1      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/lang/ThreadContextAccessor.java
  
  Index: ThreadContextAccessor.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/lang/ThreadContextAccessor.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- ThreadContextAccessor.java	2001/11/19 12:09:18	1.2
  +++ ThreadContextAccessor.java	2001/12/11 09:53:36	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.lang;
   
  
  
  
  1.3       +1 -1      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/lang/ThreadContextPolicy.java
  
  Index: ThreadContextPolicy.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/lang/ThreadContextPolicy.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- ThreadContextPolicy.java	2001/11/19 12:09:18	1.2
  +++ ThreadContextPolicy.java	2001/12/11 09:53:36	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.lang;
   
  
  
  
  1.3       +1 -1      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/pipeline/DefaultPipeline.java
  
  Index: DefaultPipeline.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/pipeline/DefaultPipeline.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- DefaultPipeline.java	2001/11/19 12:09:18	1.2
  +++ DefaultPipeline.java	2001/12/11 09:53:36	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included  with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.pipeline;
   
  
  
  
  1.3       +1 -1      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/pipeline/Pipeline.java
  
  Index: Pipeline.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/pipeline/Pipeline.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- Pipeline.java	2001/11/19 12:09:18	1.2
  +++ Pipeline.java	2001/12/11 09:53:36	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.pipeline;
   
  
  
  
  1.3       +1 -1      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/pipeline/ProcessorPipeline.java
  
  Index: ProcessorPipeline.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/pipeline/ProcessorPipeline.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- ProcessorPipeline.java	2001/11/19 12:09:18	1.2
  +++ ProcessorPipeline.java	2001/12/11 09:53:36	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.pipeline;
   
  
  
  
  1.3       +1 -1      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/pipeline/ProcessorStage.java
  
  Index: ProcessorStage.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/pipeline/ProcessorStage.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- ProcessorStage.java	2001/11/19 12:09:18	1.2
  +++ ProcessorStage.java	2001/12/11 09:53:36	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.pipeline;
   
  
  
  
  1.3       +1 -1      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/pipeline/Stage.java
  
  Index: Stage.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/pipeline/Stage.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- Stage.java	2001/11/19 12:09:18	1.2
  +++ Stage.java	2001/12/11 09:53:36	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.pipeline;
   
  
  
  
  1.3       +1 -1      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/source/ModifiableSource.java
  
  Index: ModifiableSource.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/source/ModifiableSource.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- ModifiableSource.java	2001/11/13 12:48:45	1.2
  +++ ModifiableSource.java	2001/12/11 09:53:36	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.source;
   
  
  
  
  1.6       +2 -2      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/source/Source.java
  
  Index: Source.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/source/Source.java,v
  retrieving revision 1.5
  retrieving revision 1.6
  diff -u -r1.5 -r1.6
  --- Source.java	2001/11/16 15:14:33	1.5
  +++ Source.java	2001/12/11 09:53:36	1.6
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.source;
   
  @@ -20,7 +20,7 @@
    *
    * @author <a href="mailto:cziegeler@apache.org">Carsten Ziegeler</a>
    * @author <a href="mailto:ovidiu@cup.hp.com">Ovidiu Predescu</a>
  - * @version CVS $Revision: 1.5 $ $Date: 2001/11/16 15:14:33 $
  + * @version CVS $Revision: 1.6 $ $Date: 2001/12/11 09:53:36 $
    */
   public interface Source {
     /**
  
  
  
  1.4       +2 -2      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/source/SourceFactory.java
  
  Index: SourceFactory.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/source/SourceFactory.java,v
  retrieving revision 1.3
  retrieving revision 1.4
  diff -u -r1.3 -r1.4
  --- SourceFactory.java	2001/11/14 07:46:52	1.3
  +++ SourceFactory.java	2001/12/11 09:53:36	1.4
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.source;
   
  @@ -14,7 +14,7 @@
   
   /**
    * @author <a href="mailto:cziegeler@apache.org">Carsten Ziegeler</a>
  - * @version $Id: SourceFactory.java,v 1.3 2001/11/14 07:46:52 cziegeler Exp $
  + * @version $Id: SourceFactory.java,v 1.4 2001/12/11 09:53:36 jefft Exp $
    */
   public interface SourceFactory
   extends Component {
  
  
  
  1.4       +2 -2      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/source/SourceParameters.java
  
  Index: SourceParameters.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/source/SourceParameters.java,v
  retrieving revision 1.3
  retrieving revision 1.4
  diff -u -r1.3 -r1.4
  --- SourceParameters.java	2001/11/22 07:51:13	1.3
  +++ SourceParameters.java	2001/12/11 09:53:36	1.4
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.source;
   
  @@ -17,7 +17,7 @@
    * more than one value for a parameter.
    *
    * @author <a href="mailto:cziegeler@apache.org">Carsten Ziegeler</a>
  - * @version $Id: SourceParameters.java,v 1.3 2001/11/22 07:51:13 cziegeler Exp $
  + * @version $Id: SourceParameters.java,v 1.4 2001/12/11 09:53:36 jefft Exp $
    */
   public final class SourceParameters
   implements Serializable {
  
  
  
  1.6       +2 -2      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/source/SourceResolver.java
  
  Index: SourceResolver.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/source/SourceResolver.java,v
  retrieving revision 1.5
  retrieving revision 1.6
  diff -u -r1.5 -r1.6
  --- SourceResolver.java	2001/11/16 15:13:03	1.5
  +++ SourceResolver.java	2001/12/11 09:53:36	1.6
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.source;
   
  @@ -28,7 +28,7 @@
    * looking up components from a <code>ComponentManager</code>.
    *
    * @author <a href="mailto:cziegeler@apache.org">Carsten Ziegeler</a>
  - * @version CVS $Revision: 1.5 $ $Date: 2001/11/16 15:13:03 $
  + * @version CVS $Revision: 1.6 $ $Date: 2001/12/11 09:53:36 $
    */
   
   public interface SourceResolver
  
  
  
  1.9       +2 -2      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/source/SourceResolverImpl.java
  
  Index: SourceResolverImpl.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/source/SourceResolverImpl.java,v
  retrieving revision 1.8
  retrieving revision 1.9
  diff -u -r1.8 -r1.9
  --- SourceResolverImpl.java	2001/11/22 07:51:13	1.8
  +++ SourceResolverImpl.java	2001/12/11 09:53:36	1.9
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.source;
   
  @@ -45,7 +45,7 @@
    * looking up components from a <code>ComponentManager</code>.
    *
    * @author <a href="mailto:cziegeler@apache.org">Carsten Ziegeler</a>
  - * @version $Id: SourceResolverImpl.java,v 1.8 2001/11/22 07:51:13 cziegeler Exp $
  + * @version $Id: SourceResolverImpl.java,v 1.9 2001/12/11 09:53:36 jefft Exp $
    */
   public class SourceResolverImpl
   extends AbstractLogEnabled
  
  
  
  1.2       +2 -2      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/source/SourceUtil.java
  
  Index: SourceUtil.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/source/SourceUtil.java,v
  retrieving revision 1.1
  retrieving revision 1.2
  diff -u -r1.1 -r1.2
  --- SourceUtil.java	2001/11/22 07:51:13	1.1
  +++ SourceUtil.java	2001/12/11 09:53:36	1.2
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.source;
   
  @@ -17,7 +17,7 @@
    * Utility class for source resolving.
    *
    * @author <a href="mailto:cziegeler@apache.org">Carsten Ziegeler</a>
  - * @version CVS $Revision: 1.1 $ $Date: 2001/11/22 07:51:13 $
  + * @version CVS $Revision: 1.2 $ $Date: 2001/12/11 09:53:36 $
    */
   public final class SourceUtil {
   
  
  
  
  1.7       +2 -2      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/source/URLSource.java
  
  Index: URLSource.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/source/URLSource.java,v
  retrieving revision 1.6
  retrieving revision 1.7
  diff -u -r1.6 -r1.7
  --- URLSource.java	2001/11/22 07:51:13	1.6
  +++ URLSource.java	2001/12/11 09:53:36	1.7
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.source;
   
  @@ -26,7 +26,7 @@
    * Description of a source which is described by an URL.
    *
    * @author <a href="mailto:cziegeler@apache.org">Carsten Ziegeler</a>
  - * @version CVS $Revision: 1.6 $ $Date: 2001/11/22 07:51:13 $
  + * @version CVS $Revision: 1.7 $ $Date: 2001/12/11 09:53:36 $
    */
   
   public final class URLSource implements ModifiableSource, XMLizable {
  
  
  
  1.4       +1 -1      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/thread/ThreadControl.java
  
  Index: ThreadControl.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/thread/ThreadControl.java,v
  retrieving revision 1.3
  retrieving revision 1.4
  diff -u -r1.3 -r1.4
  --- ThreadControl.java	2001/11/19 12:09:18	1.3
  +++ ThreadControl.java	2001/12/11 09:53:36	1.4
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.thread;
   
  
  
  
  1.6       +1 -1      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/thread/ThreadPool.java
  
  Index: ThreadPool.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/thread/ThreadPool.java,v
  retrieving revision 1.5
  retrieving revision 1.6
  diff -u -r1.5 -r1.6
  --- ThreadPool.java	2001/11/19 12:09:18	1.5
  +++ ThreadPool.java	2001/12/11 09:53:36	1.6
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.thread;
   
  
  
  
  1.3       +1 -1      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/thread/impl/DefaultThreadControl.java
  
  Index: DefaultThreadControl.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/thread/impl/DefaultThreadControl.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- DefaultThreadControl.java	2001/11/19 12:09:18	1.2
  +++ DefaultThreadControl.java	2001/12/11 09:53:36	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.thread.impl;
   
  
  
  
  1.7       +1 -1      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/thread/impl/DefaultThreadPool.java
  
  Index: DefaultThreadPool.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/thread/impl/DefaultThreadPool.java,v
  retrieving revision 1.6
  retrieving revision 1.7
  diff -u -r1.6 -r1.7
  --- DefaultThreadPool.java	2001/11/19 12:09:18	1.6
  +++ DefaultThreadPool.java	2001/12/11 09:53:36	1.7
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.thread.impl;
   
  
  
  
  1.3       +1 -1      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/thread/impl/ExecutableRunnable.java
  
  Index: ExecutableRunnable.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/thread/impl/ExecutableRunnable.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- ExecutableRunnable.java	2001/11/19 12:09:18	1.2
  +++ ExecutableRunnable.java	2001/12/11 09:53:36	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.thread.impl;
   
  
  
  
  1.4       +1 -1      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/thread/impl/WorkerThread.java
  
  Index: WorkerThread.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/thread/impl/WorkerThread.java,v
  retrieving revision 1.3
  retrieving revision 1.4
  diff -u -r1.3 -r1.4
  --- WorkerThread.java	2001/11/19 12:09:18	1.3
  +++ WorkerThread.java	2001/12/11 09:53:36	1.4
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.thread.impl;
   
  
  
  
  1.5       +1 -1      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/util/Circuit.java
  
  Index: Circuit.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/util/Circuit.java,v
  retrieving revision 1.4
  retrieving revision 1.5
  diff -u -r1.4 -r1.5
  --- Circuit.java	2001/10/25 17:25:47	1.4
  +++ Circuit.java	2001/12/11 09:53:37	1.5
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.util;
   
  
  
  
  1.5       +1 -1      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/util/CircularDependencyException.java
  
  Index: CircularDependencyException.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/util/CircularDependencyException.java,v
  retrieving revision 1.4
  retrieving revision 1.5
  diff -u -r1.4 -r1.5
  --- CircularDependencyException.java	2001/11/19 12:09:18	1.4
  +++ CircularDependencyException.java	2001/12/11 09:53:37	1.5
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.util;
   
  
  
  
  1.5       +2 -2      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/util/ComponentStateValidator.java
  
  Index: ComponentStateValidator.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/util/ComponentStateValidator.java,v
  retrieving revision 1.4
  retrieving revision 1.5
  diff -u -r1.4 -r1.5
  --- ComponentStateValidator.java	2001/12/03 21:42:37	1.4
  +++ ComponentStateValidator.java	2001/12/11 09:53:37	1.5
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.util;
   
  @@ -24,7 +24,7 @@
    *
    * @author <a href="mailto:bloritsch@apache.org">Berin Loritsch</a>
    * @author <a href="mailto:mike@hihat.net">Michael McKibben</a>
  - * @version CVS $Revision: 1.4 $ $Date: 2001/12/03 21:42:37 $
  + * @version CVS $Revision: 1.5 $ $Date: 2001/12/11 09:53:37 $
    */
   public final class ComponentStateValidator
   {
  
  
  
  1.3       +2 -2      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/util/DeweyDecimal.java
  
  Index: DeweyDecimal.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/util/DeweyDecimal.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- DeweyDecimal.java	2001/11/19 12:09:18	1.2
  +++ DeweyDecimal.java	2001/12/11 09:53:37	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.util;
   
  @@ -17,7 +17,7 @@
    * number must begin with a number.</p>
    *
    * @author <a href="mailto:peter@apache.org">Peter Donald</a>
  - * @version $Revision: 1.2 $ $Date: 2001/11/19 12:09:18 $
  + * @version $Revision: 1.3 $ $Date: 2001/12/11 09:53:37 $
    */
   public final class DeweyDecimal
   {
  
  
  
  1.4       +2 -2      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/util/StackIntrospector.java
  
  Index: StackIntrospector.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/util/StackIntrospector.java,v
  retrieving revision 1.3
  retrieving revision 1.4
  diff -u -r1.3 -r1.4
  --- StackIntrospector.java	2001/11/19 12:09:18	1.3
  +++ StackIntrospector.java	2001/12/11 09:53:37	1.4
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.util;
   
  @@ -17,7 +17,7 @@
    * @author <a href="mailto:sylvain@apache.org">Sylvain Wallez</a>
    * @author <a href="mailto:stuart.roebuck@adolos.com">Stuart Roebuck</a>
    * @author <a href="mailto:peter@apache.org">Peter Donald</a>
  - * @version CVS $Revision: 1.3 $ $Date: 2001/11/19 12:09:18 $
  + * @version CVS $Revision: 1.4 $ $Date: 2001/12/11 09:53:37 $
    */
   public final class StackIntrospector
   {
  
  
  
  1.11      +2 -2      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/util/StringUtil.java
  
  Index: StringUtil.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/util/StringUtil.java,v
  retrieving revision 1.10
  retrieving revision 1.11
  diff -u -r1.10 -r1.11
  --- StringUtil.java	2001/11/19 12:09:18	1.10
  +++ StringUtil.java	2001/12/11 09:53:37	1.11
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.util;
   
  @@ -14,7 +14,7 @@
    * A set of utility operations that work on or create strings.
    *
    * @author <a href="mailto:peter@apache.org">Peter Donald</a>
  - * @version CVS $Revision: 1.10 $ $Date: 2001/11/19 12:09:18 $
  + * @version CVS $Revision: 1.11 $ $Date: 2001/12/11 09:53:37 $
    */
   public final class StringUtil
   {
  
  
  
  1.2       +2 -2      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/util/test/ComponentTestCase.java
  
  Index: ComponentTestCase.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/util/test/ComponentTestCase.java,v
  retrieving revision 1.1
  retrieving revision 1.2
  diff -u -r1.1 -r1.2
  --- ComponentTestCase.java	2001/12/02 15:15:36	1.1
  +++ ComponentTestCase.java	2001/12/11 09:53:37	1.2
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.util.test;
   
  @@ -24,7 +24,7 @@
    * within your own code.
    *
    * @author <a href="bloritsch@apache.org">Berin Loritsch</a>
  - * @version CVS $Revision: 1.1 $ $Date: 2001/12/02 15:15:36 $
  + * @version CVS $Revision: 1.2 $ $Date: 2001/12/11 09:53:37 $
    */
   public final class ComponentTestCase
       extends TestCase
  
  
  
  1.3       +2 -2      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/util/test/DeweyDecimalTestCase.java
  
  Index: DeweyDecimalTestCase.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/util/test/DeweyDecimalTestCase.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- DeweyDecimalTestCase.java	2001/11/19 12:09:19	1.2
  +++ DeweyDecimalTestCase.java	2001/12/11 09:53:37	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.util.test;
   
  @@ -14,7 +14,7 @@
    * TestCases for DeweyDecimal. 
    *
    * @author <a href="mailto:peter@apache.org">Peter Donald</a>
  - * @version $Revision: 1.2 $ $Date: 2001/11/19 12:09:19 $
  + * @version $Revision: 1.3 $ $Date: 2001/12/11 09:53:37 $
    */
   public class DeweyDecimalTestCase 
       extends TestCase
  
  
  
  1.3       +2 -2      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/util/test/FullLifecycleComponent.java
  
  Index: FullLifecycleComponent.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/util/test/FullLifecycleComponent.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- FullLifecycleComponent.java	2001/12/03 21:42:37	1.2
  +++ FullLifecycleComponent.java	2001/12/11 09:53:37	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.util.test;
   
  @@ -32,7 +32,7 @@
    * This test class is used to test the AbstractComponent facilities for you.
    *
    * @author <a href="bloritsch@apache.org">Berin Loritsch</a>
  - * @version CVS $Revision: 1.2 $ $Date: 2001/12/03 21:42:37 $
  + * @version CVS $Revision: 1.3 $ $Date: 2001/12/11 09:53:37 $
    */
   public final class FullLifecycleComponent
       implements LogEnabled, Contextualizable, Parameterizable, Configurable,
  
  
  
  1.5       +1 -1      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/util/test/StringUtilTestCase.java
  
  Index: StringUtilTestCase.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/util/test/StringUtilTestCase.java,v
  retrieving revision 1.4
  retrieving revision 1.5
  diff -u -r1.4 -r1.5
  --- StringUtilTestCase.java	2001/11/19 12:09:19	1.4
  +++ StringUtilTestCase.java	2001/12/11 09:53:37	1.5
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.util.test;
   
  
  
  
  1.3       +1 -1      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/vfs/DefaultVFileSystem.java.old
  
  Index: DefaultVFileSystem.java.old
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/vfs/DefaultVFileSystem.java.old,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- DefaultVFileSystem.java.old	2001/11/19 12:09:19	1.2
  +++ DefaultVFileSystem.java.old	2001/12/11 09:53:37	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.vfs;
   
  
  
  
  1.3       +1 -1      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/vfs/DirectoryVFileAccessor.java
  
  Index: DirectoryVFileAccessor.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/vfs/DirectoryVFileAccessor.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- DirectoryVFileAccessor.java	2001/11/19 12:09:19	1.2
  +++ DirectoryVFileAccessor.java	2001/12/11 09:53:37	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.vfs;
   
  
  
  
  1.3       +1 -1      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/vfs/VFile.java
  
  Index: VFile.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/vfs/VFile.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- VFile.java	2001/11/19 12:09:19	1.2
  +++ VFile.java	2001/12/11 09:53:37	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.vfs;
   
  
  
  
  1.3       +1 -1      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/vfs/VFileAccessor.java
  
  Index: VFileAccessor.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/vfs/VFileAccessor.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- VFileAccessor.java	2001/11/19 12:09:19	1.2
  +++ VFileAccessor.java	2001/12/11 09:53:37	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.vfs;
   
  
  
  
  1.3       +1 -1      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/vfs/VFileFilter.java
  
  Index: VFileFilter.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/vfs/VFileFilter.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- VFileFilter.java	2001/11/19 12:09:19	1.2
  +++ VFileFilter.java	2001/12/11 09:53:37	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.vfs;
   
  
  
  
  1.3       +1 -1      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/vfs/VFileSystem.java
  
  Index: VFileSystem.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/vfs/VFileSystem.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- VFileSystem.java	2001/11/19 12:09:19	1.2
  +++ VFileSystem.java	2001/12/11 09:53:37	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.vfs;
   
  
  
  
  1.3       +1 -1      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/vfs/ZipVFileAccessor.java
  
  Index: ZipVFileAccessor.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/vfs/ZipVFileAccessor.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- ZipVFileAccessor.java	2001/11/19 12:09:19	1.2
  +++ ZipVFileAccessor.java	2001/12/11 09:53:37	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.vfs;
   
  
  
  
  1.4       +2 -2      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/xml/AbstractXMLConsumer.java
  
  Index: AbstractXMLConsumer.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/xml/AbstractXMLConsumer.java,v
  retrieving revision 1.3
  retrieving revision 1.4
  diff -u -r1.3 -r1.4
  --- AbstractXMLConsumer.java	2001/11/22 07:51:13	1.3
  +++ AbstractXMLConsumer.java	2001/12/11 09:53:38	1.4
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.xml;
   
  @@ -18,7 +18,7 @@
    *
    * @author <a href="mailto:fumagalli@exoffice.com">Pierpaolo Fumagalli</a>
    *         (Apache Software Foundation, Exoffice Technologies)
  - * @version CVS $Revision: 1.3 $ $Date: 2001/11/22 07:51:13 $
  + * @version CVS $Revision: 1.4 $ $Date: 2001/12/11 09:53:38 $
    */
   public abstract class AbstractXMLConsumer
   extends AbstractLogEnabled
  
  
  
  1.3       +2 -2      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/xml/ContentHandlerWrapper.java
  
  Index: ContentHandlerWrapper.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/xml/ContentHandlerWrapper.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- ContentHandlerWrapper.java	2001/11/13 12:48:45	1.2
  +++ ContentHandlerWrapper.java	2001/12/11 09:53:38	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.xml;
   
  @@ -22,7 +22,7 @@
    *
    * @author <a href="mailto:dims@yahoo.com">Davanum Srinivas</a>
    *         (Apache Software Foundation, Computer Associates)
  - * @version CVS $Revision: 1.2 $ $Date: 2001/11/13 12:48:45 $
  + * @version CVS $Revision: 1.3 $ $Date: 2001/12/11 09:53:38 $
    */
   public class ContentHandlerWrapper extends AbstractXMLConsumer implements Recyclable {
   
  
  
  
  1.5       +2 -2      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/xml/JaxpParser.java
  
  Index: JaxpParser.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/xml/JaxpParser.java,v
  retrieving revision 1.4
  retrieving revision 1.5
  diff -u -r1.4 -r1.5
  --- JaxpParser.java	2001/11/22 07:51:13	1.4
  +++ JaxpParser.java	2001/12/11 09:53:38	1.5
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.xml;
   
  @@ -26,7 +26,7 @@
    *
    * @author <a href="mailto:bloritsch@apache.org">Berin Loritsch</a>
    * @author <a href="mailto:cziegeler@apache.org">Carsten Ziegeler</a>
  - * @version CVS $Revision: 1.4 $ $Date: 2001/11/22 07:51:13 $
  + * @version CVS $Revision: 1.5 $ $Date: 2001/12/11 09:53:38 $
    */
   public class JaxpParser
   extends AbstractLogEnabled
  
  
  
  1.5       +2 -2      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/xml/Parser.java
  
  Index: Parser.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/xml/Parser.java,v
  retrieving revision 1.4
  retrieving revision 1.5
  diff -u -r1.4 -r1.5
  --- Parser.java	2001/11/14 15:58:03	1.4
  +++ Parser.java	2001/12/11 09:53:38	1.5
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.xml;
   
  @@ -24,7 +24,7 @@
    * the parsed document.
    *
    * @author <a href="mailto:cziegeler@apache.org">Carsten Ziegeler</a>
  - * @version CVS $Revision: 1.4 $ $Date: 2001/11/14 15:58:03 $
  + * @version CVS $Revision: 1.5 $ $Date: 2001/12/11 09:53:38 $
    */
   public interface Parser extends Component {
   
  
  
  
  1.3       +2 -2      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/xml/XMLConsumer.java
  
  Index: XMLConsumer.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/xml/XMLConsumer.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- XMLConsumer.java	2001/11/13 12:48:45	1.2
  +++ XMLConsumer.java	2001/12/11 09:53:38	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.xml;
   
  @@ -19,7 +19,7 @@
    *
    * @author <a href="mailto:fumagalli@exoffice.com">Pierpaolo Fumagalli</a>
    *         (Apache Software Foundation, Exoffice Technologies)
  - * @version CVS $Revision: 1.2 $ $Date: 2001/11/13 12:48:45 $
  + * @version CVS $Revision: 1.3 $ $Date: 2001/12/11 09:53:38 $
    */
   public interface XMLConsumer extends ContentHandler, LexicalHandler {
   }
  
  
  
  1.3       +2 -2      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/xml/XMLFragment.java
  
  Index: XMLFragment.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/xml/XMLFragment.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- XMLFragment.java	2001/11/13 12:48:45	1.2
  +++ XMLFragment.java	2001/12/11 09:53:38	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.xml;
   
  @@ -17,7 +17,7 @@
    *
    * @author <a href="mailto:sylvain.wallez@anyware-tech.com">Sylvain Wallez</a>
    * @author <a href="mailto:ricardo@apache.org">Ricardo Rocha</a> for the original XObject class
  - * @version CVS $Revision: 1.2 $ $Date: 2001/11/13 12:48:45 $
  + * @version CVS $Revision: 1.3 $ $Date: 2001/12/11 09:53:38 $
    */
   
   public interface XMLFragment {
  
  
  
  1.3       +2 -2      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/xml/XMLizable.java
  
  Index: XMLizable.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/xml/XMLizable.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- XMLizable.java	2001/11/13 12:48:45	1.2
  +++ XMLizable.java	2001/12/11 09:53:38	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.xml;
   
  @@ -15,7 +15,7 @@
    * of their current state as SAX events.
    *
    * @author <a href="mailto:sylvain@apache.org">Sylvain Wallez</a>
  - * @version CVS $Revision: 1.2 $ $Date: 2001/11/13 12:48:45 $
  + * @version CVS $Revision: 1.3 $ $Date: 2001/12/11 09:53:38 $
    */
   
   public interface XMLizable {
  
  
  
  1.5       +2 -2      jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/xml/XercesParser.java
  
  Index: XercesParser.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/scratchpad/org/apache/avalon/excalibur/xml/XercesParser.java,v
  retrieving revision 1.4
  retrieving revision 1.5
  diff -u -r1.4 -r1.5
  --- XercesParser.java	2001/11/22 07:51:13	1.4
  +++ XercesParser.java	2001/12/11 09:53:38	1.5
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.xml;
   
  @@ -24,7 +24,7 @@
    *
    * @author <a href="mailto:fumagalli@exoffice.com">Pierpaolo Fumagalli</a>
    *         (Apache Software Foundation, Exoffice Technologies)
  - * @version CVS $Revision: 1.4 $ $Date: 2001/11/22 07:51:13 $
  + * @version CVS $Revision: 1.5 $ $Date: 2001/12/11 09:53:38 $
    */
   public class XercesParser
   extends AbstractLogEnabled
  
  
  
  1.9       +1 -1      jakarta-avalon-excalibur/src/test/org/apache/avalon/excalibur/cli/test/ClutilTestCase.java
  
  Index: ClutilTestCase.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/test/org/apache/avalon/excalibur/cli/test/ClutilTestCase.java,v
  retrieving revision 1.8
  retrieving revision 1.9
  diff -u -r1.8 -r1.9
  --- ClutilTestCase.java	2001/11/19 12:09:39	1.8
  +++ ClutilTestCase.java	2001/12/11 09:53:38	1.9
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.cli.test;
   
  
  
  
  1.4       +1 -1      jakarta-avalon-excalibur/src/test/org/apache/avalon/excalibur/collections/test/BinaryHeapTestCase.java
  
  Index: BinaryHeapTestCase.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/test/org/apache/avalon/excalibur/collections/test/BinaryHeapTestCase.java,v
  retrieving revision 1.3
  retrieving revision 1.4
  diff -u -r1.3 -r1.4
  --- BinaryHeapTestCase.java	2001/12/02 15:18:31	1.3
  +++ BinaryHeapTestCase.java	2001/12/11 09:53:38	1.4
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.collections.test;
   
  
  
  
  1.6       +1 -1      jakarta-avalon-excalibur/src/test/org/apache/avalon/excalibur/concurrent/test/ReadWriteLockTestCase.java
  
  Index: ReadWriteLockTestCase.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/test/org/apache/avalon/excalibur/concurrent/test/ReadWriteLockTestCase.java,v
  retrieving revision 1.5
  retrieving revision 1.6
  diff -u -r1.5 -r1.6
  --- ReadWriteLockTestCase.java	2001/10/31 14:08:28	1.5
  +++ ReadWriteLockTestCase.java	2001/12/11 09:53:38	1.6
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.concurrent.test;
   
  
  
  
  1.8       +1 -1      jakarta-avalon-excalibur/src/test/org/apache/avalon/excalibur/datasource/test/DataSourceTestCase.java
  
  Index: DataSourceTestCase.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/test/org/apache/avalon/excalibur/datasource/test/DataSourceTestCase.java,v
  retrieving revision 1.7
  retrieving revision 1.8
  diff -u -r1.7 -r1.8
  --- DataSourceTestCase.java	2001/09/26 18:24:03	1.7
  +++ DataSourceTestCase.java	2001/12/11 09:53:38	1.8
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.datasource.test;
   
  
  
  
  1.3       +1 -1      jakarta-avalon-excalibur/src/test/org/apache/avalon/excalibur/i18n/test/ResourceManagerTestCase.java
  
  Index: ResourceManagerTestCase.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/test/org/apache/avalon/excalibur/i18n/test/ResourceManagerTestCase.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- ResourceManagerTestCase.java	2001/10/04 12:20:24	1.2
  +++ ResourceManagerTestCase.java	2001/12/11 09:53:38	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.i18n.test;
   
  
  
  
  1.8       +1 -1      jakarta-avalon-excalibur/src/test/org/apache/avalon/excalibur/io/test/FileUtilTestCase.java
  
  Index: FileUtilTestCase.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/test/org/apache/avalon/excalibur/io/test/FileUtilTestCase.java,v
  retrieving revision 1.7
  retrieving revision 1.8
  diff -u -r1.7 -r1.8
  --- FileUtilTestCase.java	2001/11/19 12:09:39	1.7
  +++ FileUtilTestCase.java	2001/12/11 09:53:38	1.8
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.io.test;
   
  
  
  
  1.5       +1 -1      jakarta-avalon-excalibur/src/test/org/apache/avalon/excalibur/io/test/IOUtilTestCase.java
  
  Index: IOUtilTestCase.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/test/org/apache/avalon/excalibur/io/test/IOUtilTestCase.java,v
  retrieving revision 1.4
  retrieving revision 1.5
  diff -u -r1.4 -r1.5
  --- IOUtilTestCase.java	2001/08/03 16:48:08	1.4
  +++ IOUtilTestCase.java	2001/12/11 09:53:38	1.5
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.io.test;
   
  
  
  
  1.5       +2 -2      jakarta-avalon-excalibur/src/test/org/apache/avalon/excalibur/logger/test/LogKitManagementTest.java
  
  Index: LogKitManagementTest.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/test/org/apache/avalon/excalibur/logger/test/LogKitManagementTest.java,v
  retrieving revision 1.4
  retrieving revision 1.5
  diff -u -r1.4 -r1.5
  --- LogKitManagementTest.java	2001/11/19 02:15:39	1.4
  +++ LogKitManagementTest.java	2001/12/11 09:53:39	1.5
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included  with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.logger.test;
   
  @@ -35,7 +35,7 @@
    * LogKitManagementTest.
    *
    * @author <a href="mailto:giacomo@apache,org">Giacomo Pati</a>
  - * @version CVS $Revision: 1.4 $ $Date: 2001/11/19 02:15:39 $
  + * @version CVS $Revision: 1.5 $ $Date: 2001/12/11 09:53:39 $
    */
   public class LogKitManagementTest
   {
  
  
  
  1.7       +2 -2      jakarta-avalon-excalibur/src/test/org/apache/avalon/excalibur/logger/test/LogKitManagementTestCase.java
  
  Index: LogKitManagementTestCase.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/test/org/apache/avalon/excalibur/logger/test/LogKitManagementTestCase.java,v
  retrieving revision 1.6
  retrieving revision 1.7
  diff -u -r1.6 -r1.7
  --- LogKitManagementTestCase.java	2001/11/01 14:25:57	1.6
  +++ LogKitManagementTestCase.java	2001/12/11 09:53:39	1.7
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included  with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.logger.test;
   
  @@ -16,7 +16,7 @@
    * LogKitManagementTest.
    *
    * @author <a href="mailto:giacomo@apache,org">Giacomo Pati</a>
  - * @version CVS $Revision: 1.6 $ $Date: 2001/11/01 14:25:57 $
  + * @version CVS $Revision: 1.7 $ $Date: 2001/12/11 09:53:39 $
    */
   public class LogKitManagementTestCase
       extends ExcaliburTestCase
  
  
  
  1.5       +2 -2      jakarta-avalon-excalibur/src/test/org/apache/avalon/excalibur/logger/test/TestComponent.java
  
  Index: TestComponent.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/test/org/apache/avalon/excalibur/logger/test/TestComponent.java,v
  retrieving revision 1.4
  retrieving revision 1.5
  diff -u -r1.4 -r1.5
  --- TestComponent.java	2001/10/31 21:21:14	1.4
  +++ TestComponent.java	2001/12/11 09:53:39	1.5
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included  with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.logger.test;
   
  @@ -14,7 +14,7 @@
    * TestComponent.
    *
    * @author <a href="mailto:giacomo@apache,org">Giacomo Pati</a>
  - * @version CVS $Revision: 1.4 $ $Date: 2001/10/31 21:21:14 $
  + * @version CVS $Revision: 1.5 $ $Date: 2001/12/11 09:53:39 $
    */
   public interface TestComponent
       extends Component
  
  
  
  1.7       +2 -2      jakarta-avalon-excalibur/src/test/org/apache/avalon/excalibur/logger/test/TestComponentImpl.java
  
  Index: TestComponentImpl.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/test/org/apache/avalon/excalibur/logger/test/TestComponentImpl.java,v
  retrieving revision 1.6
  retrieving revision 1.7
  diff -u -r1.6 -r1.7
  --- TestComponentImpl.java	2001/11/01 14:25:57	1.6
  +++ TestComponentImpl.java	2001/12/11 09:53:39	1.7
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included  with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.logger.test;
   
  @@ -15,7 +15,7 @@
    * TestComponent.
    *
    * @author <a href="mailto:giacomo@apache,org">Giacomo Pati</a>
  - * @version CVS $Revision: 1.6 $ $Date: 2001/11/01 14:25:57 $
  + * @version CVS $Revision: 1.7 $ $Date: 2001/12/11 09:53:39 $
    */
   public class TestComponentImpl
       extends AbstractLogEnabled
  
  
  
  1.6       +2 -2      jakarta-avalon-excalibur/src/test/org/apache/avalon/excalibur/monitor/test/MonitorTestCase.java
  
  Index: MonitorTestCase.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/test/org/apache/avalon/excalibur/monitor/test/MonitorTestCase.java,v
  retrieving revision 1.5
  retrieving revision 1.6
  diff -u -r1.5 -r1.6
  --- MonitorTestCase.java	2001/09/26 14:16:13	1.5
  +++ MonitorTestCase.java	2001/12/11 09:53:39	1.6
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   
   package org.apache.avalon.excalibur.monitor.test;
  @@ -34,7 +34,7 @@
    * Junit TestCase for all the monitors in Excalibur.
    *
    * @author <a href="mailto:bloritsch@apache.org">Berin Loritsch</a>
  - * @version $Id: MonitorTestCase.java,v 1.5 2001/09/26 14:16:13 bloritsch Exp $
  + * @version $Id: MonitorTestCase.java,v 1.6 2001/12/11 09:53:39 jefft Exp $
    */
   public class MonitorTestCase extends ExcaliburTestCase
   {
  
  
  
  1.3       +2 -2      jakarta-avalon-excalibur/src/test/org/apache/avalon/excalibur/naming/memory/test/MemoryContextTestCase.java
  
  Index: MemoryContextTestCase.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/test/org/apache/avalon/excalibur/naming/memory/test/MemoryContextTestCase.java,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- MemoryContextTestCase.java	2001/11/19 12:09:39	1.2
  +++ MemoryContextTestCase.java	2001/12/11 09:53:39	1.3
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.naming.memory.test;
   
  @@ -16,7 +16,7 @@
    * Unit testing for Memory system
    *
    * @author <a href="mailto:peter@apache.org">Peter Donald</a>
  - * @version $Revision: 1.2 $
  + * @version $Revision: 1.3 $
    */
   public class MemoryContextTestCase extends AbstractContextTestCase
   {
  
  
  
  1.4       +2 -2      jakarta-avalon-excalibur/src/test/org/apache/avalon/excalibur/naming/rmi/test/RMIContextTestCase.java
  
  Index: RMIContextTestCase.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/test/org/apache/avalon/excalibur/naming/rmi/test/RMIContextTestCase.java,v
  retrieving revision 1.3
  retrieving revision 1.4
  diff -u -r1.3 -r1.4
  --- RMIContextTestCase.java	2001/11/19 12:09:40	1.3
  +++ RMIContextTestCase.java	2001/12/11 09:53:39	1.4
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.naming.rmi.test;
   
  @@ -18,7 +18,7 @@
    * Unit testing for JNDI system
    *
    * @author <a href="mailto:peter@apache.org">Peter Donald</a>
  - * @version $Revision: 1.3 $
  + * @version $Revision: 1.4 $
    */
   public class RMIContextTestCase
       extends AbstractContextTestCase
  
  
  
  1.4       +2 -2      jakarta-avalon-excalibur/src/test/org/apache/avalon/excalibur/naming/test/AbstractContextTestCase.java
  
  Index: AbstractContextTestCase.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/test/org/apache/avalon/excalibur/naming/test/AbstractContextTestCase.java,v
  retrieving revision 1.3
  retrieving revision 1.4
  diff -u -r1.3 -r1.4
  --- AbstractContextTestCase.java	2001/11/19 12:09:40	1.3
  +++ AbstractContextTestCase.java	2001/12/11 09:53:39	1.4
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.naming.test;
   
  @@ -19,7 +19,7 @@
    * Unit testing for JNDI system
    *
    * @author <a href="mailto:peter@apache.org">Peter Donald</a>
  - * @version $Revision: 1.3 $
  + * @version $Revision: 1.4 $
    */
   public abstract class AbstractContextTestCase
       extends TestCase
  
  
  
  1.13      +1 -1      jakarta-avalon-excalibur/src/test/org/apache/avalon/excalibur/pool/test/PoolProfile.java
  
  Index: PoolProfile.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/test/org/apache/avalon/excalibur/pool/test/PoolProfile.java,v
  retrieving revision 1.12
  retrieving revision 1.13
  diff -u -r1.12 -r1.13
  --- PoolProfile.java	2001/11/19 12:09:40	1.12
  +++ PoolProfile.java	2001/12/11 09:53:39	1.13
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.pool.test;
   
  
  
  
  1.6       +1 -1      jakarta-avalon-excalibur/src/test/org/apache/avalon/excalibur/property/test/PropertyUtilTestCase.java
  
  Index: PropertyUtilTestCase.java
  ===================================================================
  RCS file: /home/cvs/jakarta-avalon-excalibur/src/test/org/apache/avalon/excalibur/property/test/PropertyUtilTestCase.java,v
  retrieving revision 1.5
  retrieving revision 1.6
  diff -u -r1.5 -r1.6
  --- PropertyUtilTestCase.java	2001/11/19 12:09:40	1.5
  +++ PropertyUtilTestCase.java	2001/12/11 09:53:39	1.6
  @@ -3,7 +3,7 @@
    *
    * This software is published under the terms of the Apache Software License
    * version 1.1, a copy of which has been included with this distribution in
  - * the LICENSE file.
  + * the LICENSE.txt file.
    */
   package org.apache.avalon.excalibur.property.test;
   
  
  
  

--
To unsubscribe, e-mail:   <ma...@jakarta.apache.org>
For additional commands, e-mail: <ma...@jakarta.apache.org>