You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@archiva.apache.org by ol...@apache.org on 2012/04/06 23:33:46 UTC

svn commit: r1310599 [1/4] - in /archiva/redback/redback-components/trunk: plexus-expression-evaluator/src/main/java/org/codehaus/plexus/evaluator/ plexus-expression-evaluator/src/main/java/org/codehaus/plexus/evaluator/sources/ plexus-expression-evalu...

Author: olamy
Date: Fri Apr  6 21:33:42 2012
New Revision: 1310599

URL: http://svn.apache.org/viewvc?rev=1310599&view=rev
Log:
fix license headers

Modified:
    archiva/redback/redback-components/trunk/plexus-expression-evaluator/src/main/java/org/codehaus/plexus/evaluator/DefaultExpressionEvaluator.java
    archiva/redback/redback-components/trunk/plexus-expression-evaluator/src/main/java/org/codehaus/plexus/evaluator/EvaluatorException.java
    archiva/redback/redback-components/trunk/plexus-expression-evaluator/src/main/java/org/codehaus/plexus/evaluator/ExpressionEvaluator.java
    archiva/redback/redback-components/trunk/plexus-expression-evaluator/src/main/java/org/codehaus/plexus/evaluator/ExpressionSource.java
    archiva/redback/redback-components/trunk/plexus-expression-evaluator/src/main/java/org/codehaus/plexus/evaluator/sources/PropertiesExpressionSource.java
    archiva/redback/redback-components/trunk/plexus-expression-evaluator/src/main/java/org/codehaus/plexus/evaluator/sources/SystemPropertyExpressionSource.java
    archiva/redback/redback-components/trunk/plexus-expression-evaluator/src/test/java/org/codehaus/plexus/evaluator/sources/DefaultExpressionEvaluatorTest.java
    archiva/redback/redback-components/trunk/plexus-jabber/src/main/java/org/codehaus/plexus/jabber/DefaultJabberClient.java
    archiva/redback/redback-components/trunk/plexus-jabber/src/main/java/org/codehaus/plexus/jabber/JabberClient.java
    archiva/redback/redback-components/trunk/plexus-jabber/src/main/java/org/codehaus/plexus/jabber/JabberClientException.java
    archiva/redback/redback-components/trunk/plexus-msn/src/main/java/org/codehaus/plexus/msn/DefaultMsnClient.java
    archiva/redback/redback-components/trunk/plexus-msn/src/main/java/org/codehaus/plexus/msn/MsnClient.java
    archiva/redback/redback-components/trunk/plexus-msn/src/main/java/org/codehaus/plexus/msn/MsnException.java
    archiva/redback/redback-components/trunk/plexus-spring/src/main/java/org/codehaus/plexus/component/configurator/ComponentConfigurationException.java
    archiva/redback/redback-components/trunk/plexus-spring/src/main/java/org/codehaus/plexus/configuration/xml/XmlPlexusConfiguration.java
    archiva/redback/redback-components/trunk/plexus-spring/src/main/java/org/codehaus/plexus/logging/BaseLoggerManager.java
    archiva/redback/redback-components/trunk/plexus-spring/src/main/java/org/codehaus/plexus/logging/console/ConsoleLogger.java
    archiva/redback/redback-components/trunk/plexus-spring/src/main/java/org/codehaus/plexus/logging/console/ConsoleLoggerManager.java
    archiva/redback/redback-components/trunk/plexus-spring/src/main/java/org/codehaus/plexus/spring/PlexusRuntimeBeanReference.java
    archiva/redback/redback-components/trunk/plexus-spring/src/main/java/org/codehaus/plexus/spring/PlexusServletContextPropertyPlaceholderConfigurer.java
    archiva/redback/redback-components/trunk/plexus-spring/src/main/java/org/codehaus/plexus/spring/Struts2PlexusInSpringObjectFactory.java
    archiva/redback/redback-components/trunk/plexus-spring/src/main/java/org/codehaus/plexus/spring/Xpp3DomPlexusConfiguration.java
    archiva/redback/redback-components/trunk/plexus-spring/src/main/java/org/codehaus/plexus/spring/editors/MapPropertyEditor.java
    archiva/redback/redback-components/trunk/plexus-spring/src/test/java/org/codehaus/plexus/spring/AbstractConfigurablePlexusBean.java
    archiva/redback/redback-components/trunk/plexus-spring/src/test/java/org/codehaus/plexus/spring/ComplexPlexusBean.java
    archiva/redback/redback-components/trunk/plexus-spring/src/test/java/org/codehaus/plexus/spring/ConfigPlexusBean.java
    archiva/redback/redback-components/trunk/plexus-spring/src/test/java/org/codehaus/plexus/spring/ConfigurablePlexusBean.java
    archiva/redback/redback-components/trunk/plexus-spring/src/test/java/org/codehaus/plexus/spring/ConfigurableTreePlexusBeanTest.java
    archiva/redback/redback-components/trunk/plexus-spring/src/test/java/org/codehaus/plexus/spring/DefaultWine.java
    archiva/redback/redback-components/trunk/plexus-spring/src/test/java/org/codehaus/plexus/spring/PlexusBean.java
    archiva/redback/redback-components/trunk/plexus-spring/src/test/java/org/codehaus/plexus/spring/PlexusBeanImpl.java
    archiva/redback/redback-components/trunk/plexus-spring/src/test/java/org/codehaus/plexus/spring/PropertiesPlexusBean.java
    archiva/redback/redback-components/trunk/plexus-spring/src/test/java/org/codehaus/plexus/spring/SaumurWine.java
    archiva/redback/redback-components/trunk/plexus-spring/src/test/java/org/codehaus/plexus/spring/TestPlexusSpringBean.java
    archiva/redback/redback-components/trunk/plexus-xmlrpc/src/main/java/org/codehaus/plexus/xmlrpc/Client.java
    archiva/redback/redback-components/trunk/plexus-xmlrpc/src/main/java/org/codehaus/plexus/xmlrpc/DefaultXmlRpcComponent.java
    archiva/redback/redback-components/trunk/plexus-xmlrpc/src/main/java/org/codehaus/plexus/xmlrpc/DefaultXmlRpcServer.java
    archiva/redback/redback-components/trunk/plexus-xmlrpc/src/main/java/org/codehaus/plexus/xmlrpc/Handler.java
    archiva/redback/redback-components/trunk/plexus-xmlrpc/src/main/java/org/codehaus/plexus/xmlrpc/XmlRpcComponent.java
    archiva/redback/redback-components/trunk/plexus-xmlrpc/src/main/java/org/codehaus/plexus/xmlrpc/XmlRpcMessageListener.java
    archiva/redback/redback-components/trunk/plexus-xmlrpc/src/main/java/org/codehaus/plexus/xmlrpc/XmlRpcServer.java
    archiva/redback/redback-components/trunk/plexus-xmlrpc/src/test/java/org/codehaus/plexus/xmlrpc/DefaultPokerComponent.java
    archiva/redback/redback-components/trunk/plexus-xmlrpc/src/test/java/org/codehaus/plexus/xmlrpc/DefaultXmlRpcComponentTest.java
    archiva/redback/redback-components/trunk/plexus-xmlrpc/src/test/java/org/codehaus/plexus/xmlrpc/PokerComponent.java
    archiva/redback/redback-components/trunk/spring-apacheds/src/main/java/org/codehaus/redback/components/apacheds/ApacheDs.java
    archiva/redback/redback-components/trunk/spring-apacheds/src/main/java/org/codehaus/redback/components/apacheds/DefaultApacheDs.java
    archiva/redback/redback-components/trunk/spring-apacheds/src/main/java/org/codehaus/redback/components/apacheds/Partition.java
    archiva/redback/redback-components/trunk/spring-apacheds/src/test/java/org/codehaus/redback/components/apacheds/ApacheDsTest.java
    archiva/redback/redback-components/trunk/spring-cache/spring-cache-api/src/main/java/org/codehaus/plexus/cache/AbstractCacheStatistics.java
    archiva/redback/redback-components/trunk/spring-cache/spring-cache-api/src/main/java/org/codehaus/plexus/cache/Cache.java
    archiva/redback/redback-components/trunk/spring-cache/spring-cache-api/src/main/java/org/codehaus/plexus/cache/CacheException.java
    archiva/redback/redback-components/trunk/spring-cache/spring-cache-api/src/main/java/org/codehaus/plexus/cache/CacheHints.java
    archiva/redback/redback-components/trunk/spring-cache/spring-cache-api/src/main/java/org/codehaus/plexus/cache/CacheStatistics.java
    archiva/redback/redback-components/trunk/spring-cache/spring-cache-api/src/main/java/org/codehaus/plexus/cache/CacheableWrapper.java
    archiva/redback/redback-components/trunk/spring-cache/spring-cache-api/src/main/java/org/codehaus/plexus/cache/builder/CacheBuilder.java
    archiva/redback/redback-components/trunk/spring-cache/spring-cache-api/src/main/java/org/codehaus/plexus/cache/builder/DefaultCacheBuilder.java
    archiva/redback/redback-components/trunk/spring-cache/spring-cache-api/src/main/java/org/codehaus/plexus/cache/factory/CacheCreator.java
    archiva/redback/redback-components/trunk/spring-cache/spring-cache-api/src/main/java/org/codehaus/plexus/cache/factory/CacheFactory.java
    archiva/redback/redback-components/trunk/spring-cache/spring-cache-api/src/main/java/org/codehaus/plexus/cache/impl/NoCacheCache.java
    archiva/redback/redback-components/trunk/spring-cache/spring-cache-providers/spring-cache-ehcache/src/main/java/org/codehaus/plexus/cache/ehcache/EhcacheCache.java
    archiva/redback/redback-components/trunk/spring-cache/spring-cache-providers/spring-cache-ehcache/src/main/java/org/codehaus/plexus/cache/ehcache/EhcacheCreator.java
    archiva/redback/redback-components/trunk/spring-cache/spring-cache-providers/spring-cache-hashmap/src/main/java/org/codehaus/plexus/cache/hashmap/HashMapCache.java
    archiva/redback/redback-components/trunk/spring-cache/spring-cache-providers/spring-cache-hashmap/src/main/java/org/codehaus/plexus/cache/hashmap/HashMapCacheCreator.java
    archiva/redback/redback-components/trunk/spring-cache/spring-cache-providers/spring-cache-oscache/src/main/java/org/codehaus/plexus/cache/oscache/OsCacheCache.java
    archiva/redback/redback-components/trunk/spring-cache/spring-cache-providers/spring-cache-oscache/src/main/java/org/codehaus/plexus/cache/oscache/OsCacheCreator.java
    archiva/redback/redback-components/trunk/spring-cache/spring-cache-providers/spring-cache-oscache/src/main/java/org/codehaus/plexus/cache/oscache/OsCacheStatistics.java
    archiva/redback/redback-components/trunk/spring-cache/spring-cache-test/src/main/java/org/codehaus/plexus/cache/test/AbstractCacheTestCase.java
    archiva/redback/redback-components/trunk/spring-cache/spring-cache-test/src/main/java/org/codehaus/plexus/cache/test/EnglishNumberFormat.java
    archiva/redback/redback-components/trunk/spring-cache/spring-cache-test/src/main/java/org/codehaus/plexus/cache/test/examples/wine/AbstractTestWineService.java
    archiva/redback/redback-components/trunk/spring-cache/spring-cache-test/src/main/java/org/codehaus/plexus/cache/test/examples/wine/DefaultWineService.java
    archiva/redback/redback-components/trunk/spring-cache/spring-cache-test/src/main/java/org/codehaus/plexus/cache/test/examples/wine/MockWineDao.java
    archiva/redback/redback-components/trunk/spring-cache/spring-cache-test/src/main/java/org/codehaus/plexus/cache/test/examples/wine/Wine.java
    archiva/redback/redback-components/trunk/spring-cache/spring-cache-test/src/main/java/org/codehaus/plexus/cache/test/examples/wine/WineDao.java
    archiva/redback/redback-components/trunk/spring-cache/spring-cache-test/src/main/java/org/codehaus/plexus/cache/test/examples/wine/WineService.java
    archiva/redback/redback-components/trunk/spring-cache/spring-cache-test/src/test/java/org/codehaus/plexus/cache/test/EnglishNumberFormatTest.java
    archiva/redback/redback-components/trunk/spring-jdo2/src/main/java/org/codehaus/plexus/jdo/AbstractConfigurableJdoFactory.java
    archiva/redback/redback-components/trunk/spring-jdo2/src/main/java/org/codehaus/plexus/jdo/ConfigurableJdoFactory.java
    archiva/redback/redback-components/trunk/spring-jdo2/src/main/java/org/codehaus/plexus/jdo/DataSourceConfigurableJdoFactory.java
    archiva/redback/redback-components/trunk/spring-jdo2/src/main/java/org/codehaus/plexus/jdo/DefaultConfigurableJdoFactory.java
    archiva/redback/redback-components/trunk/spring-jdo2/src/main/java/org/codehaus/plexus/jdo/DefaultJdoFactory.java
    archiva/redback/redback-components/trunk/spring-jdo2/src/main/java/org/codehaus/plexus/jdo/JdoFactory.java
    archiva/redback/redback-components/trunk/spring-jdo2/src/main/java/org/codehaus/plexus/jdo/PlexusJdoUtils.java
    archiva/redback/redback-components/trunk/spring-jdo2/src/main/java/org/codehaus/plexus/jdo/PlexusObjectNotFoundException.java
    archiva/redback/redback-components/trunk/spring-jdo2/src/main/java/org/codehaus/plexus/jdo/PlexusStoreException.java
    archiva/redback/redback-components/trunk/spring-jdo2/src/test/java/org/codehaus/plexus/jdo/Basic.java
    archiva/redback/redback-components/trunk/spring-jdo2/src/test/java/org/codehaus/plexus/jdo/Child.java
    archiva/redback/redback-components/trunk/spring-jdo2/src/test/java/org/codehaus/plexus/jdo/DefaultConfigurableJdoFactoryTest.java
    archiva/redback/redback-components/trunk/spring-jdo2/src/test/java/org/codehaus/plexus/jdo/DefaultJdoFactoryTest.java
    archiva/redback/redback-components/trunk/spring-jdo2/src/test/java/org/codehaus/plexus/jdo/Parent.java
    archiva/redback/redback-components/trunk/spring-jdo2/src/test/java/org/codehaus/plexus/jdo/PlexusJdoUtilsTest.java
    archiva/redback/redback-components/trunk/spring-jdo2/src/test/mdo/testobjects.xml
    archiva/redback/redback-components/trunk/spring-quartz/src/main/java/org/codehaus/redback/components/scheduler/AbstractJob.java
    archiva/redback/redback-components/trunk/spring-quartz/src/main/java/org/codehaus/redback/components/scheduler/CronExpressionValidator.java
    archiva/redback/redback-components/trunk/spring-quartz/src/main/java/org/codehaus/redback/components/scheduler/DefaultJobListener.java
    archiva/redback/redback-components/trunk/spring-quartz/src/main/java/org/codehaus/redback/components/scheduler/DefaultScheduler.java
    archiva/redback/redback-components/trunk/spring-quartz/src/main/java/org/codehaus/redback/components/scheduler/Scheduler.java
    archiva/redback/redback-components/trunk/spring-quartz/src/main/java/org/codehaus/redback/components/scheduler/configuration/SchedulerConfiguration.java
    archiva/redback/redback-components/trunk/spring-quartz/src/test/java/org/codehaus/redback/components/scheduler/CronExpressionValidatorTest.java
    archiva/redback/redback-components/trunk/spring-quartz/src/test/java/org/codehaus/redback/components/scheduler/JobOne.java
    archiva/redback/redback-components/trunk/spring-quartz/src/test/java/org/codehaus/redback/components/scheduler/SchedulerTest.java
    archiva/redback/redback-components/trunk/spring-registry/spring-registry-api/src/main/java/org/codehaus/plexus/registry/Registry.java
    archiva/redback/redback-components/trunk/spring-registry/spring-registry-api/src/main/java/org/codehaus/plexus/registry/RegistryException.java
    archiva/redback/redback-components/trunk/spring-registry/spring-registry-api/src/main/java/org/codehaus/plexus/registry/RegistryListener.java
    archiva/redback/redback-components/trunk/spring-registry/spring-registry-commons/src/main/java/org/codehaus/redback/components/registry/commons/CommonsConfigurationRegistry.java
    archiva/redback/redback-components/trunk/spring-registry/spring-registry-commons/src/main/java/org/codehaus/redback/components/registry/commons/ConfigurationListenerDelegate.java
    archiva/redback/redback-components/trunk/spring-registry/spring-registry-commons/src/test/java/org/codehaus/redback/components/registry/AbstractRegistryTest.java
    archiva/redback/redback-components/trunk/spring-registry/spring-registry-commons/src/test/java/org/codehaus/redback/components/registry/CommonsConfigurationRegistryTest.java
    archiva/redback/redback-components/trunk/spring-registry/spring-registry-commons/src/test/java/org/codehaus/redback/components/registry/Component.java
    archiva/redback/redback-components/trunk/spring-registry/spring-registry-commons/src/test/java/org/codehaus/redback/components/registry/DefaultComponent.java
    archiva/redback/redback-components/trunk/spring-registry/spring-registry-commons/src/test/java/org/codehaus/redback/components/registry/Nested.java
    archiva/redback/redback-components/trunk/spring-taskqueue/src/main/java/org/codehaus/plexus/taskqueue/DefaultTaskQueue.java
    archiva/redback/redback-components/trunk/spring-taskqueue/src/main/java/org/codehaus/plexus/taskqueue/Task.java
    archiva/redback/redback-components/trunk/spring-taskqueue/src/main/java/org/codehaus/plexus/taskqueue/TaskEntryEvaluator.java
    archiva/redback/redback-components/trunk/spring-taskqueue/src/main/java/org/codehaus/plexus/taskqueue/TaskExitEvaluator.java
    archiva/redback/redback-components/trunk/spring-taskqueue/src/main/java/org/codehaus/plexus/taskqueue/TaskQueue.java
    archiva/redback/redback-components/trunk/spring-taskqueue/src/main/java/org/codehaus/plexus/taskqueue/TaskQueueException.java
    archiva/redback/redback-components/trunk/spring-taskqueue/src/main/java/org/codehaus/plexus/taskqueue/TaskViabilityEvaluator.java
    archiva/redback/redback-components/trunk/spring-taskqueue/src/main/java/org/codehaus/plexus/taskqueue/execution/TaskExecutionException.java
    archiva/redback/redback-components/trunk/spring-taskqueue/src/main/java/org/codehaus/plexus/taskqueue/execution/TaskExecutor.java
    archiva/redback/redback-components/trunk/spring-taskqueue/src/main/java/org/codehaus/plexus/taskqueue/execution/TaskQueueExecutor.java
    archiva/redback/redback-components/trunk/spring-taskqueue/src/main/java/org/codehaus/plexus/taskqueue/execution/ThreadedTaskQueueExecutor.java
    archiva/redback/redback-components/trunk/spring-utils/src/main/java/org/codehaus/redback/components/springutils/CachingByTypeBeanFactory.java
    archiva/redback/redback-components/trunk/spring-utils/src/main/java/org/codehaus/redback/components/springutils/CachingWebApplicationContext.java
    archiva/redback/redback-components/trunk/spring-utils/src/main/java/org/codehaus/redback/components/springutils/ComponentContainer.java
    archiva/redback/redback-components/trunk/spring-utils/src/main/java/org/codehaus/redback/components/springutils/plexusshim/PlexusShimComponent.java

Modified: archiva/redback/redback-components/trunk/plexus-expression-evaluator/src/main/java/org/codehaus/plexus/evaluator/DefaultExpressionEvaluator.java
URL: http://svn.apache.org/viewvc/archiva/redback/redback-components/trunk/plexus-expression-evaluator/src/main/java/org/codehaus/plexus/evaluator/DefaultExpressionEvaluator.java?rev=1310599&r1=1310598&r2=1310599&view=diff
==============================================================================
--- archiva/redback/redback-components/trunk/plexus-expression-evaluator/src/main/java/org/codehaus/plexus/evaluator/DefaultExpressionEvaluator.java (original)
+++ archiva/redback/redback-components/trunk/plexus-expression-evaluator/src/main/java/org/codehaus/plexus/evaluator/DefaultExpressionEvaluator.java Fri Apr  6 21:33:42 2012
@@ -1,5 +1,24 @@
 package org.codehaus.plexus.evaluator;
 
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *  http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+
 import org.codehaus.plexus.util.StringUtils;
 
 import java.util.ArrayList;

Modified: archiva/redback/redback-components/trunk/plexus-expression-evaluator/src/main/java/org/codehaus/plexus/evaluator/EvaluatorException.java
URL: http://svn.apache.org/viewvc/archiva/redback/redback-components/trunk/plexus-expression-evaluator/src/main/java/org/codehaus/plexus/evaluator/EvaluatorException.java?rev=1310599&r1=1310598&r2=1310599&view=diff
==============================================================================
--- archiva/redback/redback-components/trunk/plexus-expression-evaluator/src/main/java/org/codehaus/plexus/evaluator/EvaluatorException.java (original)
+++ archiva/redback/redback-components/trunk/plexus-expression-evaluator/src/main/java/org/codehaus/plexus/evaluator/EvaluatorException.java Fri Apr  6 21:33:42 2012
@@ -1,19 +1,22 @@
 package org.codehaus.plexus.evaluator;
 
 /*
- * Copyright 2001-2006 The Codehaus.
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *  http://www.apache.org/licenses/LICENSE-2.0
  *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 
 /**

Modified: archiva/redback/redback-components/trunk/plexus-expression-evaluator/src/main/java/org/codehaus/plexus/evaluator/ExpressionEvaluator.java
URL: http://svn.apache.org/viewvc/archiva/redback/redback-components/trunk/plexus-expression-evaluator/src/main/java/org/codehaus/plexus/evaluator/ExpressionEvaluator.java?rev=1310599&r1=1310598&r2=1310599&view=diff
==============================================================================
--- archiva/redback/redback-components/trunk/plexus-expression-evaluator/src/main/java/org/codehaus/plexus/evaluator/ExpressionEvaluator.java (original)
+++ archiva/redback/redback-components/trunk/plexus-expression-evaluator/src/main/java/org/codehaus/plexus/evaluator/ExpressionEvaluator.java Fri Apr  6 21:33:42 2012
@@ -1,19 +1,22 @@
 package org.codehaus.plexus.evaluator;
 
 /*
- * Copyright 2001-2006 The Codehaus.
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *  http://www.apache.org/licenses/LICENSE-2.0
  *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 
 import java.util.List;

Modified: archiva/redback/redback-components/trunk/plexus-expression-evaluator/src/main/java/org/codehaus/plexus/evaluator/ExpressionSource.java
URL: http://svn.apache.org/viewvc/archiva/redback/redback-components/trunk/plexus-expression-evaluator/src/main/java/org/codehaus/plexus/evaluator/ExpressionSource.java?rev=1310599&r1=1310598&r2=1310599&view=diff
==============================================================================
--- archiva/redback/redback-components/trunk/plexus-expression-evaluator/src/main/java/org/codehaus/plexus/evaluator/ExpressionSource.java (original)
+++ archiva/redback/redback-components/trunk/plexus-expression-evaluator/src/main/java/org/codehaus/plexus/evaluator/ExpressionSource.java Fri Apr  6 21:33:42 2012
@@ -1,19 +1,22 @@
 package org.codehaus.plexus.evaluator;
 
 /*
- * Copyright 2001-2006 The Codehaus.
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *  http://www.apache.org/licenses/LICENSE-2.0
  *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 
 /**
@@ -30,5 +33,5 @@ public interface ExpressionSource
      * @param expression the expression to attempt to get a value for.
      * @return the value for the expression, or null if no value found.
      */
-    public String getExpressionValue( String expression );
+    String getExpressionValue( String expression );
 }

Modified: archiva/redback/redback-components/trunk/plexus-expression-evaluator/src/main/java/org/codehaus/plexus/evaluator/sources/PropertiesExpressionSource.java
URL: http://svn.apache.org/viewvc/archiva/redback/redback-components/trunk/plexus-expression-evaluator/src/main/java/org/codehaus/plexus/evaluator/sources/PropertiesExpressionSource.java?rev=1310599&r1=1310598&r2=1310599&view=diff
==============================================================================
--- archiva/redback/redback-components/trunk/plexus-expression-evaluator/src/main/java/org/codehaus/plexus/evaluator/sources/PropertiesExpressionSource.java (original)
+++ archiva/redback/redback-components/trunk/plexus-expression-evaluator/src/main/java/org/codehaus/plexus/evaluator/sources/PropertiesExpressionSource.java Fri Apr  6 21:33:42 2012
@@ -1,19 +1,22 @@
 package org.codehaus.plexus.evaluator.sources;
 
 /*
- * Copyright 2001-2006 The Codehaus.
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *  http://www.apache.org/licenses/LICENSE-2.0
  *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 
 import org.codehaus.plexus.evaluator.ExpressionSource;

Modified: archiva/redback/redback-components/trunk/plexus-expression-evaluator/src/main/java/org/codehaus/plexus/evaluator/sources/SystemPropertyExpressionSource.java
URL: http://svn.apache.org/viewvc/archiva/redback/redback-components/trunk/plexus-expression-evaluator/src/main/java/org/codehaus/plexus/evaluator/sources/SystemPropertyExpressionSource.java?rev=1310599&r1=1310598&r2=1310599&view=diff
==============================================================================
--- archiva/redback/redback-components/trunk/plexus-expression-evaluator/src/main/java/org/codehaus/plexus/evaluator/sources/SystemPropertyExpressionSource.java (original)
+++ archiva/redback/redback-components/trunk/plexus-expression-evaluator/src/main/java/org/codehaus/plexus/evaluator/sources/SystemPropertyExpressionSource.java Fri Apr  6 21:33:42 2012
@@ -1,5 +1,24 @@
 package org.codehaus.plexus.evaluator.sources;
 
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *  http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+
 import org.codehaus.plexus.evaluator.ExpressionSource;
 
 /**

Modified: archiva/redback/redback-components/trunk/plexus-expression-evaluator/src/test/java/org/codehaus/plexus/evaluator/sources/DefaultExpressionEvaluatorTest.java
URL: http://svn.apache.org/viewvc/archiva/redback/redback-components/trunk/plexus-expression-evaluator/src/test/java/org/codehaus/plexus/evaluator/sources/DefaultExpressionEvaluatorTest.java?rev=1310599&r1=1310598&r2=1310599&view=diff
==============================================================================
--- archiva/redback/redback-components/trunk/plexus-expression-evaluator/src/test/java/org/codehaus/plexus/evaluator/sources/DefaultExpressionEvaluatorTest.java (original)
+++ archiva/redback/redback-components/trunk/plexus-expression-evaluator/src/test/java/org/codehaus/plexus/evaluator/sources/DefaultExpressionEvaluatorTest.java Fri Apr  6 21:33:42 2012
@@ -1,19 +1,22 @@
 package org.codehaus.plexus.evaluator.sources;
 
 /*
- * Copyright 2001-2006 The Codehaus.
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *  http://www.apache.org/licenses/LICENSE-2.0
  *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 
 import org.codehaus.plexus.PlexusTestCase;

Modified: archiva/redback/redback-components/trunk/plexus-jabber/src/main/java/org/codehaus/plexus/jabber/DefaultJabberClient.java
URL: http://svn.apache.org/viewvc/archiva/redback/redback-components/trunk/plexus-jabber/src/main/java/org/codehaus/plexus/jabber/DefaultJabberClient.java?rev=1310599&r1=1310598&r2=1310599&view=diff
==============================================================================
--- archiva/redback/redback-components/trunk/plexus-jabber/src/main/java/org/codehaus/plexus/jabber/DefaultJabberClient.java (original)
+++ archiva/redback/redback-components/trunk/plexus-jabber/src/main/java/org/codehaus/plexus/jabber/DefaultJabberClient.java Fri Apr  6 21:33:42 2012
@@ -1,5 +1,24 @@
 package org.codehaus.plexus.jabber;
 
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *  http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+
 import org.codehaus.plexus.logging.AbstractLogEnabled;
 import org.jivesoftware.smack.SSLXMPPConnection;
 import org.jivesoftware.smack.XMPPConnection;

Modified: archiva/redback/redback-components/trunk/plexus-jabber/src/main/java/org/codehaus/plexus/jabber/JabberClient.java
URL: http://svn.apache.org/viewvc/archiva/redback/redback-components/trunk/plexus-jabber/src/main/java/org/codehaus/plexus/jabber/JabberClient.java?rev=1310599&r1=1310598&r2=1310599&view=diff
==============================================================================
--- archiva/redback/redback-components/trunk/plexus-jabber/src/main/java/org/codehaus/plexus/jabber/JabberClient.java (original)
+++ archiva/redback/redback-components/trunk/plexus-jabber/src/main/java/org/codehaus/plexus/jabber/JabberClient.java Fri Apr  6 21:33:42 2012
@@ -1,5 +1,24 @@
 package org.codehaus.plexus.jabber;
 
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *  http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+
 /**
  * @author <a href="mailto:evenisse@codehaus.org">Emmanuel Venisse</a>
  * @version $Id$

Modified: archiva/redback/redback-components/trunk/plexus-jabber/src/main/java/org/codehaus/plexus/jabber/JabberClientException.java
URL: http://svn.apache.org/viewvc/archiva/redback/redback-components/trunk/plexus-jabber/src/main/java/org/codehaus/plexus/jabber/JabberClientException.java?rev=1310599&r1=1310598&r2=1310599&view=diff
==============================================================================
--- archiva/redback/redback-components/trunk/plexus-jabber/src/main/java/org/codehaus/plexus/jabber/JabberClientException.java (original)
+++ archiva/redback/redback-components/trunk/plexus-jabber/src/main/java/org/codehaus/plexus/jabber/JabberClientException.java Fri Apr  6 21:33:42 2012
@@ -1,5 +1,24 @@
 package org.codehaus.plexus.jabber;
 
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *  http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+
 /**
  * @author <a href="mailto:evenisse@codehaus.org">Emmanuel Venisse</a>
  * @version $Id$

Modified: archiva/redback/redback-components/trunk/plexus-msn/src/main/java/org/codehaus/plexus/msn/DefaultMsnClient.java
URL: http://svn.apache.org/viewvc/archiva/redback/redback-components/trunk/plexus-msn/src/main/java/org/codehaus/plexus/msn/DefaultMsnClient.java?rev=1310599&r1=1310598&r2=1310599&view=diff
==============================================================================
--- archiva/redback/redback-components/trunk/plexus-msn/src/main/java/org/codehaus/plexus/msn/DefaultMsnClient.java (original)
+++ archiva/redback/redback-components/trunk/plexus-msn/src/main/java/org/codehaus/plexus/msn/DefaultMsnClient.java Fri Apr  6 21:33:42 2012
@@ -1,5 +1,24 @@
 package org.codehaus.plexus.msn;
 
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *  http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+
 import org.codehaus.plexus.logging.AbstractLogEnabled;
 import org.codehaus.plexus.logging.Logger;
 

Modified: archiva/redback/redback-components/trunk/plexus-msn/src/main/java/org/codehaus/plexus/msn/MsnClient.java
URL: http://svn.apache.org/viewvc/archiva/redback/redback-components/trunk/plexus-msn/src/main/java/org/codehaus/plexus/msn/MsnClient.java?rev=1310599&r1=1310598&r2=1310599&view=diff
==============================================================================
--- archiva/redback/redback-components/trunk/plexus-msn/src/main/java/org/codehaus/plexus/msn/MsnClient.java (original)
+++ archiva/redback/redback-components/trunk/plexus-msn/src/main/java/org/codehaus/plexus/msn/MsnClient.java Fri Apr  6 21:33:42 2012
@@ -1,5 +1,24 @@
 package org.codehaus.plexus.msn;
 
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *  http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+
 /**
  * @author <a href="mailto:evenisse@codehaus.org">Emmanuel Venisse</a>
  * @version $Id$

Modified: archiva/redback/redback-components/trunk/plexus-msn/src/main/java/org/codehaus/plexus/msn/MsnException.java
URL: http://svn.apache.org/viewvc/archiva/redback/redback-components/trunk/plexus-msn/src/main/java/org/codehaus/plexus/msn/MsnException.java?rev=1310599&r1=1310598&r2=1310599&view=diff
==============================================================================
--- archiva/redback/redback-components/trunk/plexus-msn/src/main/java/org/codehaus/plexus/msn/MsnException.java (original)
+++ archiva/redback/redback-components/trunk/plexus-msn/src/main/java/org/codehaus/plexus/msn/MsnException.java Fri Apr  6 21:33:42 2012
@@ -1,5 +1,24 @@
 package org.codehaus.plexus.msn;
 
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *  http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+
 /**
  * @author <a href="mailto:evenisse@codehaus.org">Emmanuel Venisse</a>
  * @version $Id$

Modified: archiva/redback/redback-components/trunk/plexus-spring/src/main/java/org/codehaus/plexus/component/configurator/ComponentConfigurationException.java
URL: http://svn.apache.org/viewvc/archiva/redback/redback-components/trunk/plexus-spring/src/main/java/org/codehaus/plexus/component/configurator/ComponentConfigurationException.java?rev=1310599&r1=1310598&r2=1310599&view=diff
==============================================================================
--- archiva/redback/redback-components/trunk/plexus-spring/src/main/java/org/codehaus/plexus/component/configurator/ComponentConfigurationException.java (original)
+++ archiva/redback/redback-components/trunk/plexus-spring/src/main/java/org/codehaus/plexus/component/configurator/ComponentConfigurationException.java Fri Apr  6 21:33:42 2012
@@ -1,5 +1,24 @@
 package org.codehaus.plexus.component.configurator;
 
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *  http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+
 import org.codehaus.plexus.configuration.PlexusConfiguration;
 
 /**

Modified: archiva/redback/redback-components/trunk/plexus-spring/src/main/java/org/codehaus/plexus/configuration/xml/XmlPlexusConfiguration.java
URL: http://svn.apache.org/viewvc/archiva/redback/redback-components/trunk/plexus-spring/src/main/java/org/codehaus/plexus/configuration/xml/XmlPlexusConfiguration.java?rev=1310599&r1=1310598&r2=1310599&view=diff
==============================================================================
--- archiva/redback/redback-components/trunk/plexus-spring/src/main/java/org/codehaus/plexus/configuration/xml/XmlPlexusConfiguration.java (original)
+++ archiva/redback/redback-components/trunk/plexus-spring/src/main/java/org/codehaus/plexus/configuration/xml/XmlPlexusConfiguration.java Fri Apr  6 21:33:42 2012
@@ -1,21 +1,23 @@
 package org.codehaus.plexus.configuration.xml;
 
 /*
- * Copyright 2001-2006 Codehaus Foundation.
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *  http://www.apache.org/licenses/LICENSE-2.0
  *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
-
 import org.codehaus.plexus.configuration.PlexusConfiguration;
 import org.codehaus.plexus.util.xml.Xpp3Dom;
 

Modified: archiva/redback/redback-components/trunk/plexus-spring/src/main/java/org/codehaus/plexus/logging/BaseLoggerManager.java
URL: http://svn.apache.org/viewvc/archiva/redback/redback-components/trunk/plexus-spring/src/main/java/org/codehaus/plexus/logging/BaseLoggerManager.java?rev=1310599&r1=1310598&r2=1310599&view=diff
==============================================================================
--- archiva/redback/redback-components/trunk/plexus-spring/src/main/java/org/codehaus/plexus/logging/BaseLoggerManager.java (original)
+++ archiva/redback/redback-components/trunk/plexus-spring/src/main/java/org/codehaus/plexus/logging/BaseLoggerManager.java Fri Apr  6 21:33:42 2012
@@ -1,19 +1,22 @@
 package org.codehaus.plexus.logging;
 
 /*
- * Copyright 2001-2006 Codehaus Foundation.
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *  http://www.apache.org/licenses/LICENSE-2.0
  *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 
 import org.codehaus.plexus.personality.plexus.lifecycle.phase.Initializable;

Modified: archiva/redback/redback-components/trunk/plexus-spring/src/main/java/org/codehaus/plexus/logging/console/ConsoleLogger.java
URL: http://svn.apache.org/viewvc/archiva/redback/redback-components/trunk/plexus-spring/src/main/java/org/codehaus/plexus/logging/console/ConsoleLogger.java?rev=1310599&r1=1310598&r2=1310599&view=diff
==============================================================================
--- archiva/redback/redback-components/trunk/plexus-spring/src/main/java/org/codehaus/plexus/logging/console/ConsoleLogger.java (original)
+++ archiva/redback/redback-components/trunk/plexus-spring/src/main/java/org/codehaus/plexus/logging/console/ConsoleLogger.java Fri Apr  6 21:33:42 2012
@@ -1,19 +1,22 @@
 package org.codehaus.plexus.logging.console;
 
 /*
- * Copyright 2001-2006 Codehaus Foundation.
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *  http://www.apache.org/licenses/LICENSE-2.0
  *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 
 import org.codehaus.plexus.logging.AbstractLogger;

Modified: archiva/redback/redback-components/trunk/plexus-spring/src/main/java/org/codehaus/plexus/logging/console/ConsoleLoggerManager.java
URL: http://svn.apache.org/viewvc/archiva/redback/redback-components/trunk/plexus-spring/src/main/java/org/codehaus/plexus/logging/console/ConsoleLoggerManager.java?rev=1310599&r1=1310598&r2=1310599&view=diff
==============================================================================
--- archiva/redback/redback-components/trunk/plexus-spring/src/main/java/org/codehaus/plexus/logging/console/ConsoleLoggerManager.java (original)
+++ archiva/redback/redback-components/trunk/plexus-spring/src/main/java/org/codehaus/plexus/logging/console/ConsoleLoggerManager.java Fri Apr  6 21:33:42 2012
@@ -1,19 +1,22 @@
 package org.codehaus.plexus.logging.console;
 
 /*
- * Copyright 2001-2006 Codehaus Foundation.
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ *  http://www.apache.org/licenses/LICENSE-2.0
  *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 
 import org.codehaus.plexus.logging.AbstractLoggerManager;

Modified: archiva/redback/redback-components/trunk/plexus-spring/src/main/java/org/codehaus/plexus/spring/PlexusRuntimeBeanReference.java
URL: http://svn.apache.org/viewvc/archiva/redback/redback-components/trunk/plexus-spring/src/main/java/org/codehaus/plexus/spring/PlexusRuntimeBeanReference.java?rev=1310599&r1=1310598&r2=1310599&view=diff
==============================================================================
--- archiva/redback/redback-components/trunk/plexus-spring/src/main/java/org/codehaus/plexus/spring/PlexusRuntimeBeanReference.java (original)
+++ archiva/redback/redback-components/trunk/plexus-spring/src/main/java/org/codehaus/plexus/spring/PlexusRuntimeBeanReference.java Fri Apr  6 21:33:42 2012
@@ -1,3 +1,5 @@
+package org.codehaus.plexus.spring;
+
 /*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
@@ -7,7 +9,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *  http://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
@@ -16,7 +18,6 @@
  * specific language governing permissions and limitations
  * under the License.
  */
-package org.codehaus.plexus.spring;
 
 import org.springframework.beans.factory.config.RuntimeBeanReference;
 

Modified: archiva/redback/redback-components/trunk/plexus-spring/src/main/java/org/codehaus/plexus/spring/PlexusServletContextPropertyPlaceholderConfigurer.java
URL: http://svn.apache.org/viewvc/archiva/redback/redback-components/trunk/plexus-spring/src/main/java/org/codehaus/plexus/spring/PlexusServletContextPropertyPlaceholderConfigurer.java?rev=1310599&r1=1310598&r2=1310599&view=diff
==============================================================================
--- archiva/redback/redback-components/trunk/plexus-spring/src/main/java/org/codehaus/plexus/spring/PlexusServletContextPropertyPlaceholderConfigurer.java (original)
+++ archiva/redback/redback-components/trunk/plexus-spring/src/main/java/org/codehaus/plexus/spring/PlexusServletContextPropertyPlaceholderConfigurer.java Fri Apr  6 21:33:42 2012
@@ -1,18 +1,23 @@
+package org.codehaus.plexus.spring;
+
 /*
- * Licensed to the Apache Software Foundation (ASF) under one or more contributor license
- * agreements. See the NOTICE file distributed with this work for additional information regarding
- * copyright ownership. The ASF licenses this file to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance with the License. You may obtain a
- * copy of the License at
- * 
- * http://www.apache.org/licenses/LICENSE-2.0
- * 
- * Unless required by applicable law or agreed to in writing, software distributed under the License
- * is distributed on an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express
- * or implied. See the License for the specific language governing permissions and limitations under
- * the License.
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *  http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
-package org.codehaus.plexus.spring;
 
 import java.io.File;
 import java.io.IOException;

Modified: archiva/redback/redback-components/trunk/plexus-spring/src/main/java/org/codehaus/plexus/spring/Struts2PlexusInSpringObjectFactory.java
URL: http://svn.apache.org/viewvc/archiva/redback/redback-components/trunk/plexus-spring/src/main/java/org/codehaus/plexus/spring/Struts2PlexusInSpringObjectFactory.java?rev=1310599&r1=1310598&r2=1310599&view=diff
==============================================================================
--- archiva/redback/redback-components/trunk/plexus-spring/src/main/java/org/codehaus/plexus/spring/Struts2PlexusInSpringObjectFactory.java (original)
+++ archiva/redback/redback-components/trunk/plexus-spring/src/main/java/org/codehaus/plexus/spring/Struts2PlexusInSpringObjectFactory.java Fri Apr  6 21:33:42 2012
@@ -1,17 +1,22 @@
 package org.codehaus.plexus.spring;
 
 /*
-  ~ Licensed under the Apache License, Version 2.0 (the "License");
-  ~ you may not use this file except in compliance with the License.
-  ~ You may obtain a copy of the License at
-  ~
-  ~      http://www.apache.org/licenses/LICENSE-2.0
-  ~
-  ~ Unless required by applicable law or agreed to in writing, software
-  ~ distributed under the License is distributed on an "AS IS" BASIS,
-  ~ WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-  ~ See the License for the specific language governing permissions and
-  ~ limitations under the License.
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *  http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 
 import java.util.Map;

Modified: archiva/redback/redback-components/trunk/plexus-spring/src/main/java/org/codehaus/plexus/spring/Xpp3DomPlexusConfiguration.java
URL: http://svn.apache.org/viewvc/archiva/redback/redback-components/trunk/plexus-spring/src/main/java/org/codehaus/plexus/spring/Xpp3DomPlexusConfiguration.java?rev=1310599&r1=1310598&r2=1310599&view=diff
==============================================================================
--- archiva/redback/redback-components/trunk/plexus-spring/src/main/java/org/codehaus/plexus/spring/Xpp3DomPlexusConfiguration.java (original)
+++ archiva/redback/redback-components/trunk/plexus-spring/src/main/java/org/codehaus/plexus/spring/Xpp3DomPlexusConfiguration.java Fri Apr  6 21:33:42 2012
@@ -1,3 +1,5 @@
+package org.codehaus.plexus.spring;
+
 /*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
@@ -7,7 +9,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *  http://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
@@ -16,7 +18,6 @@
  * specific language governing permissions and limitations
  * under the License.
  */
-package org.codehaus.plexus.spring;
 
 import org.codehaus.plexus.configuration.PlexusConfiguration;
 import org.codehaus.plexus.configuration.PlexusConfigurationException;

Modified: archiva/redback/redback-components/trunk/plexus-spring/src/main/java/org/codehaus/plexus/spring/editors/MapPropertyEditor.java
URL: http://svn.apache.org/viewvc/archiva/redback/redback-components/trunk/plexus-spring/src/main/java/org/codehaus/plexus/spring/editors/MapPropertyEditor.java?rev=1310599&r1=1310598&r2=1310599&view=diff
==============================================================================
--- archiva/redback/redback-components/trunk/plexus-spring/src/main/java/org/codehaus/plexus/spring/editors/MapPropertyEditor.java (original)
+++ archiva/redback/redback-components/trunk/plexus-spring/src/main/java/org/codehaus/plexus/spring/editors/MapPropertyEditor.java Fri Apr  6 21:33:42 2012
@@ -1,3 +1,5 @@
+package org.codehaus.plexus.spring.editors;
+
 /*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
@@ -16,7 +18,6 @@
  * specific language governing permissions and limitations
  * under the License.
  */
-package org.codehaus.plexus.spring.editors;
 
 import java.io.StringReader;
 import java.util.Iterator;

Modified: archiva/redback/redback-components/trunk/plexus-spring/src/test/java/org/codehaus/plexus/spring/AbstractConfigurablePlexusBean.java
URL: http://svn.apache.org/viewvc/archiva/redback/redback-components/trunk/plexus-spring/src/test/java/org/codehaus/plexus/spring/AbstractConfigurablePlexusBean.java?rev=1310599&r1=1310598&r2=1310599&view=diff
==============================================================================
--- archiva/redback/redback-components/trunk/plexus-spring/src/test/java/org/codehaus/plexus/spring/AbstractConfigurablePlexusBean.java (original)
+++ archiva/redback/redback-components/trunk/plexus-spring/src/test/java/org/codehaus/plexus/spring/AbstractConfigurablePlexusBean.java Fri Apr  6 21:33:42 2012
@@ -1,3 +1,5 @@
+package org.codehaus.plexus.spring;
+
 /*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
@@ -7,7 +9,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *  http://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
@@ -16,7 +18,6 @@
  * specific language governing permissions and limitations
  * under the License.
  */
-package org.codehaus.plexus.spring;
 
 import java.util.List;
 

Modified: archiva/redback/redback-components/trunk/plexus-spring/src/test/java/org/codehaus/plexus/spring/ComplexPlexusBean.java
URL: http://svn.apache.org/viewvc/archiva/redback/redback-components/trunk/plexus-spring/src/test/java/org/codehaus/plexus/spring/ComplexPlexusBean.java?rev=1310599&r1=1310598&r2=1310599&view=diff
==============================================================================
--- archiva/redback/redback-components/trunk/plexus-spring/src/test/java/org/codehaus/plexus/spring/ComplexPlexusBean.java (original)
+++ archiva/redback/redback-components/trunk/plexus-spring/src/test/java/org/codehaus/plexus/spring/ComplexPlexusBean.java Fri Apr  6 21:33:42 2012
@@ -1,8 +1,5 @@
 package org.codehaus.plexus.spring;
 
-import java.util.List;
-import java.util.Map;
-
 /*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
@@ -22,6 +19,10 @@ import java.util.Map;
  * under the License.
  */
 
+import java.util.List;
+import java.util.Map;
+
+
 /**
  * A typical plexus component implementation
  *

Modified: archiva/redback/redback-components/trunk/plexus-spring/src/test/java/org/codehaus/plexus/spring/ConfigPlexusBean.java
URL: http://svn.apache.org/viewvc/archiva/redback/redback-components/trunk/plexus-spring/src/test/java/org/codehaus/plexus/spring/ConfigPlexusBean.java?rev=1310599&r1=1310598&r2=1310599&view=diff
==============================================================================
--- archiva/redback/redback-components/trunk/plexus-spring/src/test/java/org/codehaus/plexus/spring/ConfigPlexusBean.java (original)
+++ archiva/redback/redback-components/trunk/plexus-spring/src/test/java/org/codehaus/plexus/spring/ConfigPlexusBean.java Fri Apr  6 21:33:42 2012
@@ -1,7 +1,5 @@
 package org.codehaus.plexus.spring;
 
-import org.codehaus.plexus.configuration.PlexusConfiguration;
-
 /*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
@@ -21,6 +19,9 @@ import org.codehaus.plexus.configuration
  * under the License.
  */
 
+import org.codehaus.plexus.configuration.PlexusConfiguration;
+
+
 /**
  * A typical plexus component implementation
  *
@@ -36,5 +37,4 @@ public class ConfigPlexusBean
     }
 
 
-
 }

Modified: archiva/redback/redback-components/trunk/plexus-spring/src/test/java/org/codehaus/plexus/spring/ConfigurablePlexusBean.java
URL: http://svn.apache.org/viewvc/archiva/redback/redback-components/trunk/plexus-spring/src/test/java/org/codehaus/plexus/spring/ConfigurablePlexusBean.java?rev=1310599&r1=1310598&r2=1310599&view=diff
==============================================================================
--- archiva/redback/redback-components/trunk/plexus-spring/src/test/java/org/codehaus/plexus/spring/ConfigurablePlexusBean.java (original)
+++ archiva/redback/redback-components/trunk/plexus-spring/src/test/java/org/codehaus/plexus/spring/ConfigurablePlexusBean.java Fri Apr  6 21:33:42 2012
@@ -1,3 +1,5 @@
+package org.codehaus.plexus.spring;
+
 /*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
@@ -16,7 +18,6 @@
  * specific language governing permissions and limitations
  * under the License.
  */
-package org.codehaus.plexus.spring;
 
 import java.util.ArrayList;
 import java.util.Collections;

Modified: archiva/redback/redback-components/trunk/plexus-spring/src/test/java/org/codehaus/plexus/spring/ConfigurableTreePlexusBeanTest.java
URL: http://svn.apache.org/viewvc/archiva/redback/redback-components/trunk/plexus-spring/src/test/java/org/codehaus/plexus/spring/ConfigurableTreePlexusBeanTest.java?rev=1310599&r1=1310598&r2=1310599&view=diff
==============================================================================
--- archiva/redback/redback-components/trunk/plexus-spring/src/test/java/org/codehaus/plexus/spring/ConfigurableTreePlexusBeanTest.java (original)
+++ archiva/redback/redback-components/trunk/plexus-spring/src/test/java/org/codehaus/plexus/spring/ConfigurableTreePlexusBeanTest.java Fri Apr  6 21:33:42 2012
@@ -1,18 +1,23 @@
+package org.codehaus.plexus.spring;
+
 /*
- * Licensed to the Apache Software Foundation (ASF) under one or more contributor license
- * agreements. See the NOTICE file distributed with this work for additional information regarding
- * copyright ownership. The ASF licenses this file to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance with the License. You may obtain a
- * copy of the License at
- * 
- * http://www.apache.org/licenses/LICENSE-2.0
- * 
- * Unless required by applicable law or agreed to in writing, software distributed under the License
- * is distributed on an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express
- * or implied. See the License for the specific language governing permissions and limitations under
- * the License.
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *  http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
-package org.codehaus.plexus.spring;
 
 import junit.framework.TestCase;
 

Modified: archiva/redback/redback-components/trunk/plexus-spring/src/test/java/org/codehaus/plexus/spring/DefaultWine.java
URL: http://svn.apache.org/viewvc/archiva/redback/redback-components/trunk/plexus-spring/src/test/java/org/codehaus/plexus/spring/DefaultWine.java?rev=1310599&r1=1310598&r2=1310599&view=diff
==============================================================================
--- archiva/redback/redback-components/trunk/plexus-spring/src/test/java/org/codehaus/plexus/spring/DefaultWine.java (original)
+++ archiva/redback/redback-components/trunk/plexus-spring/src/test/java/org/codehaus/plexus/spring/DefaultWine.java Fri Apr  6 21:33:42 2012
@@ -1,3 +1,5 @@
+package org.codehaus.plexus.spring;
+
 /*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
@@ -7,7 +9,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *  http://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
@@ -16,7 +18,6 @@
  * specific language governing permissions and limitations
  * under the License.
  */
-package org.codehaus.plexus.spring;
 
 /**
  * @author <a href="mailto:olamy at codehaus.org">olamy</a>

Modified: archiva/redback/redback-components/trunk/plexus-spring/src/test/java/org/codehaus/plexus/spring/PlexusBean.java
URL: http://svn.apache.org/viewvc/archiva/redback/redback-components/trunk/plexus-spring/src/test/java/org/codehaus/plexus/spring/PlexusBean.java?rev=1310599&r1=1310598&r2=1310599&view=diff
==============================================================================
--- archiva/redback/redback-components/trunk/plexus-spring/src/test/java/org/codehaus/plexus/spring/PlexusBean.java (original)
+++ archiva/redback/redback-components/trunk/plexus-spring/src/test/java/org/codehaus/plexus/spring/PlexusBean.java Fri Apr  6 21:33:42 2012
@@ -1,11 +1,5 @@
 package org.codehaus.plexus.spring;
 
-import java.util.List;
-import java.util.Set;
-
-import org.codehaus.plexus.context.Context;
-import org.codehaus.plexus.logging.Logger;
-
 /*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
@@ -25,6 +19,14 @@ import org.codehaus.plexus.logging.Logge
  * under the License.
  */
 
+import java.util.List;
+import java.util.Set;
+
+import org.codehaus.plexus.context.Context;
+import org.codehaus.plexus.logging.Logger;
+
+
+
 /**
  * A plexus component interface
  *

Modified: archiva/redback/redback-components/trunk/plexus-spring/src/test/java/org/codehaus/plexus/spring/PlexusBeanImpl.java
URL: http://svn.apache.org/viewvc/archiva/redback/redback-components/trunk/plexus-spring/src/test/java/org/codehaus/plexus/spring/PlexusBeanImpl.java?rev=1310599&r1=1310598&r2=1310599&view=diff
==============================================================================
--- archiva/redback/redback-components/trunk/plexus-spring/src/test/java/org/codehaus/plexus/spring/PlexusBeanImpl.java (original)
+++ archiva/redback/redback-components/trunk/plexus-spring/src/test/java/org/codehaus/plexus/spring/PlexusBeanImpl.java Fri Apr  6 21:33:42 2012
@@ -1,17 +1,5 @@
 package org.codehaus.plexus.spring;
 
-import java.util.List;
-import java.util.Set;
-
-import org.codehaus.plexus.context.Context;
-import org.codehaus.plexus.context.ContextException;
-import org.codehaus.plexus.logging.AbstractLogEnabled;
-import org.codehaus.plexus.logging.Logger;
-import org.codehaus.plexus.personality.plexus.lifecycle.phase.Contextualizable;
-import org.codehaus.plexus.personality.plexus.lifecycle.phase.Disposable;
-import org.codehaus.plexus.personality.plexus.lifecycle.phase.Initializable;
-import org.codehaus.plexus.personality.plexus.lifecycle.phase.InitializationException;
-
 /*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
@@ -31,6 +19,19 @@ import org.codehaus.plexus.personality.p
  * under the License.
  */
 
+import org.codehaus.plexus.context.Context;
+import org.codehaus.plexus.context.ContextException;
+import org.codehaus.plexus.logging.AbstractLogEnabled;
+import org.codehaus.plexus.logging.Logger;
+import org.codehaus.plexus.personality.plexus.lifecycle.phase.Contextualizable;
+import org.codehaus.plexus.personality.plexus.lifecycle.phase.Disposable;
+import org.codehaus.plexus.personality.plexus.lifecycle.phase.Initializable;
+import org.codehaus.plexus.personality.plexus.lifecycle.phase.InitializationException;
+
+import java.util.List;
+import java.util.Set;
+
+
 /**
  * A typical plexus component implementation
  *
@@ -82,6 +83,7 @@ public class PlexusBeanImpl
 
     /**
      * {@inheritDoc}
+     *
      * @see org.codehaus.plexus.personality.plexus.lifecycle.phase.Contextualizable#contextualize(org.codehaus.plexus.context.Context)
      */
     public void contextualize( Context context )

Modified: archiva/redback/redback-components/trunk/plexus-spring/src/test/java/org/codehaus/plexus/spring/PropertiesPlexusBean.java
URL: http://svn.apache.org/viewvc/archiva/redback/redback-components/trunk/plexus-spring/src/test/java/org/codehaus/plexus/spring/PropertiesPlexusBean.java?rev=1310599&r1=1310598&r2=1310599&view=diff
==============================================================================
--- archiva/redback/redback-components/trunk/plexus-spring/src/test/java/org/codehaus/plexus/spring/PropertiesPlexusBean.java (original)
+++ archiva/redback/redback-components/trunk/plexus-spring/src/test/java/org/codehaus/plexus/spring/PropertiesPlexusBean.java Fri Apr  6 21:33:42 2012
@@ -1,8 +1,5 @@
 package org.codehaus.plexus.spring;
 
-import java.util.Map;
-import java.util.Properties;
-
 /*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
@@ -22,6 +19,10 @@ import java.util.Properties;
  * under the License.
  */
 
+import java.util.Map;
+import java.util.Properties;
+
+
 /**
  * A typical plexus component implementation
  *
@@ -30,7 +31,7 @@ import java.util.Properties;
 public class PropertiesPlexusBean
 {
     private Properties properties;
-    
+
     private Map<?, ?> map;
 
     public Properties getProperties()

Modified: archiva/redback/redback-components/trunk/plexus-spring/src/test/java/org/codehaus/plexus/spring/SaumurWine.java
URL: http://svn.apache.org/viewvc/archiva/redback/redback-components/trunk/plexus-spring/src/test/java/org/codehaus/plexus/spring/SaumurWine.java?rev=1310599&r1=1310598&r2=1310599&view=diff
==============================================================================
--- archiva/redback/redback-components/trunk/plexus-spring/src/test/java/org/codehaus/plexus/spring/SaumurWine.java (original)
+++ archiva/redback/redback-components/trunk/plexus-spring/src/test/java/org/codehaus/plexus/spring/SaumurWine.java Fri Apr  6 21:33:42 2012
@@ -1,3 +1,5 @@
+package org.codehaus.plexus.spring;
+
 /*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
@@ -7,7 +9,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *  http://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
@@ -16,7 +18,6 @@
  * specific language governing permissions and limitations
  * under the License.
  */
-package org.codehaus.plexus.spring;
 
 /**
  * @author <a href="mailto:olamy at codehaus.org">olamy</a>

Modified: archiva/redback/redback-components/trunk/plexus-spring/src/test/java/org/codehaus/plexus/spring/TestPlexusSpringBean.java
URL: http://svn.apache.org/viewvc/archiva/redback/redback-components/trunk/plexus-spring/src/test/java/org/codehaus/plexus/spring/TestPlexusSpringBean.java?rev=1310599&r1=1310598&r2=1310599&view=diff
==============================================================================
--- archiva/redback/redback-components/trunk/plexus-spring/src/test/java/org/codehaus/plexus/spring/TestPlexusSpringBean.java (original)
+++ archiva/redback/redback-components/trunk/plexus-spring/src/test/java/org/codehaus/plexus/spring/TestPlexusSpringBean.java Fri Apr  6 21:33:42 2012
@@ -1,3 +1,5 @@
+package org.codehaus.plexus.spring;
+
 /*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
@@ -7,7 +9,7 @@
  * "License"); you may not use this file except in compliance
  * with the License.  You may obtain a copy of the License at
  *
- *   http://www.apache.org/licenses/LICENSE-2.0
+ *  http://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
@@ -16,7 +18,6 @@
  * specific language governing permissions and limitations
  * under the License.
  */
-package org.codehaus.plexus.spring;
 
 import org.codehaus.plexus.registry.Registry;
 import org.slf4j.Logger;

Modified: archiva/redback/redback-components/trunk/plexus-xmlrpc/src/main/java/org/codehaus/plexus/xmlrpc/Client.java
URL: http://svn.apache.org/viewvc/archiva/redback/redback-components/trunk/plexus-xmlrpc/src/main/java/org/codehaus/plexus/xmlrpc/Client.java?rev=1310599&r1=1310598&r2=1310599&view=diff
==============================================================================
--- archiva/redback/redback-components/trunk/plexus-xmlrpc/src/main/java/org/codehaus/plexus/xmlrpc/Client.java (original)
+++ archiva/redback/redback-components/trunk/plexus-xmlrpc/src/main/java/org/codehaus/plexus/xmlrpc/Client.java Fri Apr  6 21:33:42 2012
@@ -1,29 +1,23 @@
 package org.codehaus.plexus.xmlrpc;
 
 /*
- * The MIT License
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Copyright (c) 2004, The Codehaus
+ *  http://www.apache.org/licenses/LICENSE-2.0
  *
- * Permission is hereby granted, free of charge, to any person obtaining a copy of
- * this software and associated documentation files (the "Software"), to deal in
- * the Software without restriction, including without limitation the rights to
- * use, copy, modify, merge, publish, distribute, sublicense, and/or sell copies
- * of the Software, and to permit persons to whom the Software is furnished to do
- * so, subject to the following conditions:
- *
- * The above copyright notice and this permission notice shall be included in all
- * copies or substantial portions of the Software.
- *
- * THE SOFTWARE IS PROVIDED "AS IS", WITHOUT WARRANTY OF ANY KIND, EXPRESS OR
- * IMPLIED, INCLUDING BUT NOT LIMITED TO THE WARRANTIES OF MERCHANTABILITY,
- * FITNESS FOR A PARTICULAR PURPOSE AND NONINFRINGEMENT. IN NO EVENT SHALL THE
- * AUTHORS OR COPYRIGHT HOLDERS BE LIABLE FOR ANY CLAIM, DAMAGES OR OTHER
- * LIABILITY, WHETHER IN AN ACTION OF CONTRACT, TORT OR OTHERWISE, ARISING FROM,
- * OUT OF OR IN CONNECTION WITH THE SOFTWARE OR THE USE OR OTHER DEALINGS IN THE
- * SOFTWARE.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
-
 import org.codehaus.plexus.configuration.PlexusConfigurationException;
 import org.codehaus.plexus.util.StringUtils;
 import org.codehaus.plexus.personality.plexus.lifecycle.phase.InitializationException;

Modified: archiva/redback/redback-components/trunk/plexus-xmlrpc/src/main/java/org/codehaus/plexus/xmlrpc/DefaultXmlRpcComponent.java
URL: http://svn.apache.org/viewvc/archiva/redback/redback-components/trunk/plexus-xmlrpc/src/main/java/org/codehaus/plexus/xmlrpc/DefaultXmlRpcComponent.java?rev=1310599&r1=1310598&r2=1310599&view=diff
==============================================================================
--- archiva/redback/redback-components/trunk/plexus-xmlrpc/src/main/java/org/codehaus/plexus/xmlrpc/DefaultXmlRpcComponent.java (original)
+++ archiva/redback/redback-components/trunk/plexus-xmlrpc/src/main/java/org/codehaus/plexus/xmlrpc/DefaultXmlRpcComponent.java Fri Apr  6 21:33:42 2012
@@ -1,83 +1,22 @@
 package org.codehaus.plexus.xmlrpc;
 
 /*
- * The MIT License
- *
- * Copyright (c) 2004, The Codehaus
- *
- * Permission is hereby granted, free of charge, to any person obtaining a copy of
- * this software and associated documentation files (the "Software"), to deal in
- * the Software without restriction, including without limitation the rights to
- * use, copy, modify, merge, publish, distribute, sublicense, and/or sell copies
- * of the Software, and to permit persons to whom the Software is furnished to do
- * so, subject to the following conditions:
- *
- * The above copyright notice and this permission notice shall be included in all
- * copies or substantial portions of the Software.
- *
- * THE SOFTWARE IS PROVIDED "AS IS", WITHOUT WARRANTY OF ANY KIND, EXPRESS OR
- * IMPLIED, INCLUDING BUT NOT LIMITED TO THE WARRANTIES OF MERCHANTABILITY,
- * FITNESS FOR A PARTICULAR PURPOSE AND NONINFRINGEMENT. IN NO EVENT SHALL THE
- * AUTHORS OR COPYRIGHT HOLDERS BE LIABLE FOR ANY CLAIM, DAMAGES OR OTHER
- * LIABILITY, WHETHER IN AN ACTION OF CONTRACT, TORT OR OTHERWISE, ARISING FROM,
- * OUT OF OR IN CONNECTION WITH THE SOFTWARE OR THE USE OR OTHER DEALINGS IN THE
- * SOFTWARE.
- */
-
-/* ----------------------------------------------------------------------------
- * The Apache Software License, Version 1.1
- *
- * Copyright (c) 2000-2002 The Apache Software Foundation.  All rights
- * reserved.
- *
- * Redistribution and use in source and binary forms, with or without
- * modification, 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 acknowlegement:
- *       "This product includes software developed by the
- *        Apache Software Foundation (http://www.apache.org/)."
- *    Alternately, this acknowlegement may appear in the software itself,
- *    if and wherever such third-party acknowlegements normally appear.
- *
- * 4. The names "The Jakarta Project", "Plexus", 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 names without prior written
- *    permission of the Apache Group.
- *
- * 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 (INCLUDING, 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.  For more
- * information on the Apache Software Foundation, please see
- * <http://www.apache.org/>.
- *
- * ----------------------------------------------------------------------------
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *  http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 
 import java.io.IOException;