You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@maven.apache.org by og...@apache.org on 2009/02/03 18:44:34 UTC

svn commit: r740358 - in /maven/mercury/trunk/mercury-it: ./ src/test/java/org/apache/maven/mercury/repository/tests/ src/test/nexus/ src/test/resources/ src/test/resources/META-INF/ src/test/resources/org/apache/maven/mercury/repository/ src/test/reso...

Author: ogusakov
Date: Tue Feb  3 17:44:33 2009
New Revision: 740358

URL: http://svn.apache.org/viewvc?rev=740358&view=rev
Log:
[MERCURY-77] - got rid of nexus, all tests are now run against jetty + webdav servlet

Added:
    maven/mercury/trunk/mercury-it/src/test/java/org/apache/maven/mercury/repository/tests/DavServerTest.java   (with props)
    maven/mercury/trunk/mercury-it/src/test/java/org/apache/maven/mercury/repository/tests/RemoteRepositoryWriterM2Test.java   (with props)
    maven/mercury/trunk/mercury-it/src/test/java/org/apache/maven/mercury/repository/tests/WebDavServer.java   (with props)
    maven/mercury/trunk/mercury-it/src/test/resources/org/apache/maven/mercury/repository/
    maven/mercury/trunk/mercury-it/src/test/resources/org/apache/maven/mercury/repository/tests/
    maven/mercury/trunk/mercury-it/src/test/resources/org/apache/maven/mercury/repository/tests/DavServerTest.xml   (with props)
    maven/mercury/trunk/mercury-it/src/test/resources/org/apache/maven/mercury/repository/tests/RemoteRepositoryWriterM2Test.xml   (with props)
Removed:
    maven/mercury/trunk/mercury-it/src/test/java/org/apache/maven/mercury/repository/tests/Nexus.java
    maven/mercury/trunk/mercury-it/src/test/java/org/apache/maven/mercury/repository/tests/RemoteRepositoryWriterM2NexusTest.java
    maven/mercury/trunk/mercury-it/src/test/nexus/
    maven/mercury/trunk/mercury-it/src/test/resources/META-INF/
    maven/mercury/trunk/mercury-it/src/test/resources/test.properties
Modified:
    maven/mercury/trunk/mercury-it/pom.xml
    maven/mercury/trunk/mercury-it/src/test/java/org/apache/maven/mercury/repository/tests/AbstractRepositoryWriterM2Test.java

Modified: maven/mercury/trunk/mercury-it/pom.xml
URL: http://svn.apache.org/viewvc/maven/mercury/trunk/mercury-it/pom.xml?rev=740358&r1=740357&r2=740358&view=diff
==============================================================================
--- maven/mercury/trunk/mercury-it/pom.xml (original)
+++ maven/mercury/trunk/mercury-it/pom.xml Tue Feb  3 17:44:33 2009
@@ -35,6 +35,8 @@
     <maven.version>3.0-SNAPSHOT</maven.version>
     <spice.model.builder.version>1.2</spice.model.builder.version>
     
+    <plexus.webdav.version>1.0-SNAPSHOT</plexus.webdav.version>
+    
     <nexus.version>1.0.1</nexus.version>
     <nexus.client.version>1.1-M1</nexus.client.version>
 
@@ -170,35 +172,9 @@
     </dependency>
 
     <dependency>
-      <groupId>org.sonatype.appbooter</groupId>
-      <artifactId>plexus-forked-app-booter</artifactId>
-    </dependency>
-  
-    <dependency>
-      <groupId>org.sonatype.nexus</groupId>
-      <artifactId>nexus-rest-api</artifactId>
-        <version>${nexus.client.version}</version>
-      <exclusions>
-        <exclusion>
-          <groupId>org.codehaus.plexus</groupId>
-          <artifactId>plexus-component-api</artifactId>
-        </exclusion>
-      </exclusions>
-    </dependency>
-
-    <dependency>
-      <groupId>org.sonatype.nexus</groupId>
-      <artifactId>nexus-rest-client-java</artifactId>
-        <version>${nexus.client.version}</version>
-    </dependency>
-  
-    <dependency>
-      <groupId>org.sonatype.nexus</groupId>
-      <artifactId>nexus-webapp</artifactId>
-      <version>${nexus.version}</version>
-      <classifier>bundle</classifier>
-      <type>zip</type>
-      <scope>provided</scope>
+      <groupId>org.sonatype.spice</groupId>
+      <artifactId>plexus-webdav</artifactId>
+      <version>${plexus.webdav.version}</version>
     </dependency>
 
     <dependency>

Modified: maven/mercury/trunk/mercury-it/src/test/java/org/apache/maven/mercury/repository/tests/AbstractRepositoryWriterM2Test.java
URL: http://svn.apache.org/viewvc/maven/mercury/trunk/mercury-it/src/test/java/org/apache/maven/mercury/repository/tests/AbstractRepositoryWriterM2Test.java?rev=740358&r1=740357&r2=740358&view=diff
==============================================================================
--- maven/mercury/trunk/mercury-it/src/test/java/org/apache/maven/mercury/repository/tests/AbstractRepositoryWriterM2Test.java (original)
+++ maven/mercury/trunk/mercury-it/src/test/java/org/apache/maven/mercury/repository/tests/AbstractRepositoryWriterM2Test.java Tue Feb  3 17:44:33 2009
@@ -54,8 +54,6 @@
 public abstract class AbstractRepositoryWriterM2Test
 extends PlexusTestCase
 {
-  private static final IMercuryLogger _log = MercuryLoggerManager.getLogger( AbstractRepositoryWriterM2Test.class ); 
-  
   Repository repo;
   
   File targetDirectory; 
@@ -128,7 +126,7 @@
     FileUtil.writeRawData( getClass().getResourceAsStream( "/maven-core-2.0.9.jar" ), artifactBinary );
     binarySize = artifactBinary.length();
 
-    _log.info( "Binary size is "+binarySize+" bytes" );
+    System.out.println( "Binary size is "+binarySize+" bytes" );
 
     artifactPom = File.createTempFile( "test-repo-writer", "pom" );
     FileUtil.writeRawData( getClass().getResourceAsStream( "/maven-core-2.0.9.pom" ), artifactPom );
@@ -136,7 +134,6 @@
     pomBytes = FileUtil.readRawData( artifactPom );
   }
   
-  
   @Override
   protected void tearDown()
   throws Exception

Added: maven/mercury/trunk/mercury-it/src/test/java/org/apache/maven/mercury/repository/tests/DavServerTest.java
URL: http://svn.apache.org/viewvc/maven/mercury/trunk/mercury-it/src/test/java/org/apache/maven/mercury/repository/tests/DavServerTest.java?rev=740358&view=auto
==============================================================================
--- maven/mercury/trunk/mercury-it/src/test/java/org/apache/maven/mercury/repository/tests/DavServerTest.java (added)
+++ maven/mercury/trunk/mercury-it/src/test/java/org/apache/maven/mercury/repository/tests/DavServerTest.java Tue Feb  3 17:44:33 2009
@@ -0,0 +1,165 @@
+/*
+Licensed to the Apache Software Foundation (ASF) under one
+or more contributor license agreements.  See the NOTICE file
+distributed with this work for additional information
+regarding copyright ownership.  The ASF licenses this file
+to you under the Apache License, Version 2.0 (the
+"License"); you may not use this file except in compliance
+with the License.  You may obtain a copy of the License at
+
+    http://www.apache.org/licenses/LICENSE-2.0
+
+Unless required by applicable law or agreed to in writing,
+software distributed under the License is distributed on an
+"AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+KIND, either express or implied.  See the License for the
+specific language governing permissions and limitations
+under the License.
+*/
+
+package org.apache.maven.mercury.repository.tests;
+
+import java.io.File;
+import java.net.URL;
+import java.util.ArrayList;
+import java.util.List;
+
+import org.apache.maven.mercury.MavenDependencyProcessor;
+import org.apache.maven.mercury.artifact.Artifact;
+import org.apache.maven.mercury.artifact.ArtifactBasicMetadata;
+import org.apache.maven.mercury.artifact.DefaultArtifact;
+import org.apache.maven.mercury.repository.api.ArtifactResults;
+import org.apache.maven.mercury.repository.api.RepositoryReader;
+import org.apache.maven.mercury.repository.api.RepositoryWriter;
+import org.apache.maven.mercury.repository.remote.m2.RemoteRepositoryM2;
+import org.apache.maven.mercury.transport.api.Credentials;
+import org.apache.maven.mercury.transport.api.Server;
+import org.apache.maven.mercury.util.FileUtil;
+import org.codehaus.plexus.PlexusTestCase;
+
+/**
+ *
+ *
+ * @author Oleg Gusakov
+ * @version $Id$
+ *
+ */
+public class DavServerTest
+extends PlexusTestCase
+{
+    static final String _davContext = "/webdav";
+    
+    static final String _user = "foo";
+    
+    static final String _pass = "bar";
+    
+    WebDavServer _dav;
+    
+    File _base;
+    
+    RemoteRepositoryM2 _davRepo;
+
+    //---------------------------------------------------------------------------------------------
+    protected void setUp()
+    throws Exception
+    {
+        super.setUp();
+        
+        _base = new File( "./target", _davContext );
+        
+        FileUtil.delete( _base );
+        
+        _base.mkdirs();
+        
+        _dav = new WebDavServer( 0, _base, _davContext, getContainer(), 9, "mercury-test" );
+        
+        _dav.start();
+        
+        Credentials user = new Credentials(_user,_pass);
+        
+        Server server = new Server("dav", new URL("http://localhost:"+_dav.getPort()+_davContext), false, false, user );
+        
+        System.out.println("URL: "+server.getURL() );
+        
+        _davRepo = new RemoteRepositoryM2( server, new MavenDependencyProcessor() );
+    }
+    //---------------------------------------------------------------------------------------------
+    protected void tearDown()
+    throws Exception
+    {
+        super.tearDown();
+        
+        if( _dav != null )
+        {
+            _dav.stop();
+            _dav.destroy();
+            _dav = null;
+        }  
+    }
+    //---------------------------------------------------------------------------------------------
+    public void testDavWrite()
+    throws Exception
+    {
+        File jar = new File("./target/test.jar");
+        FileUtil.writeRawData( jar, "test-jar" );
+
+        File pom = new File("./target/test.pom");
+        FileUtil.writeRawData( pom, "test-pom" );
+
+        DefaultArtifact da = new DefaultArtifact( new ArtifactBasicMetadata("a:test:1.0") );
+        da.setFile( jar );
+        da.setPomBlob( FileUtil.readRawData( pom ) );
+
+        List<Artifact> al = new ArrayList<Artifact>( 8 );
+        al.add( da );
+
+        RepositoryWriter rw = _davRepo.getWriter();
+
+        rw.writeArtifacts( al );
+
+        File davJar = new File( _base, "a/test/1.0/test-1.0.jar" );
+
+        assertTrue( davJar.exists() );
+        
+        assertEquals( jar.length(), davJar.length() );
+    }
+    //---------------------------------------------------------------------------------------------
+    public void testDavRead()
+    throws Exception
+    {
+        testDavWrite();
+        
+        ArtifactBasicMetadata bmd = new ArtifactBasicMetadata("a:test:1.0");
+        
+        List<ArtifactBasicMetadata> query = new ArrayList<ArtifactBasicMetadata>( 1 );
+
+        query.add( bmd );
+        
+        RepositoryReader rr = _davRepo.getReader();
+        
+        ArtifactResults res = rr.readArtifacts( query );
+        
+        assertNotNull( res );
+        
+        assertFalse( res.hasExceptions() );
+        
+        assertTrue( res.hasResults() );
+        
+        List<Artifact> al = res.getResults( bmd );
+        
+        assertNotNull( al );
+        
+        assertFalse( al.isEmpty() );
+        
+        Artifact a = al.get( 0 );
+
+        assertNotNull( a );
+
+        assertNotNull( a.getFile() );
+
+        assertTrue( a.getFile().exists() );
+
+        assertEquals( "test-pom".length(), a.getFile().length() );
+    }
+    //---------------------------------------------------------------------------------------------
+}

Propchange: maven/mercury/trunk/mercury-it/src/test/java/org/apache/maven/mercury/repository/tests/DavServerTest.java
------------------------------------------------------------------------------
    svn:mergeinfo = 

Added: maven/mercury/trunk/mercury-it/src/test/java/org/apache/maven/mercury/repository/tests/RemoteRepositoryWriterM2Test.java
URL: http://svn.apache.org/viewvc/maven/mercury/trunk/mercury-it/src/test/java/org/apache/maven/mercury/repository/tests/RemoteRepositoryWriterM2Test.java?rev=740358&view=auto
==============================================================================
--- maven/mercury/trunk/mercury-it/src/test/java/org/apache/maven/mercury/repository/tests/RemoteRepositoryWriterM2Test.java (added)
+++ maven/mercury/trunk/mercury-it/src/test/java/org/apache/maven/mercury/repository/tests/RemoteRepositoryWriterM2Test.java Tue Feb  3 17:44:33 2009
@@ -0,0 +1,161 @@
+/**
+ *  Licensed to the Apache Software Foundation (ASF) under one
+ *  or more contributor license agreements.  See the NOTICE file
+ *  distributed with this work for additional information
+ *  regarding copyright ownership.  The ASF licenses this file
+ *  to you under the Apache License, Version 2.0 (the
+ *  "License"); you may not use this file except in compliance
+ *  with the License.  You may obtain a copy of the License at
+ * 
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ * 
+ *  Unless required by applicable law or agreed to in writing,
+ *  software distributed under the License is distributed on an
+ *  "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ *  KIND, either express or implied.  See the License for the
+ *  specific language governing permissions and limitations
+ *  under the License.
+ */
+package org.apache.maven.mercury.repository.tests;
+
+import java.io.File;
+import java.net.URL;
+import java.util.ArrayList;
+import java.util.HashSet;
+
+import org.apache.maven.mercury.MavenDependencyProcessor;
+import org.apache.maven.mercury.artifact.ArtifactBasicMetadata;
+import org.apache.maven.mercury.crypto.api.StreamVerifierAttributes;
+import org.apache.maven.mercury.crypto.api.StreamVerifierFactory;
+import org.apache.maven.mercury.crypto.pgp.PgpStreamVerifierFactory;
+import org.apache.maven.mercury.crypto.sha.SHA1VerifierFactory;
+import org.apache.maven.mercury.repository.local.m2.MetadataProcessorMock;
+import org.apache.maven.mercury.repository.remote.m2.RemoteRepositoryM2;
+import org.apache.maven.mercury.transport.api.Credentials;
+import org.apache.maven.mercury.transport.api.Server;
+import org.apache.maven.mercury.util.FileUtil;
+
+/**
+ *
+ *
+ * @author Oleg Gusakov
+ * @version $Id$
+ *
+ */
+public class RemoteRepositoryWriterM2Test
+extends AbstractRepositoryWriterM2Test
+{
+    static final String _davContext = "/webdav";
+
+    static final String _user = "foo";
+
+    static final String _pass = "bar";
+
+    WebDavServer _dav;
+
+    RemoteRepositoryM2 _davRepo;
+
+  String _basePath = "./target/webdav";
+
+  //------------------------------------------------------------------------------
+  @Override
+  void setReleases()
+  throws Exception
+  {
+  }
+  //------------------------------------------------------------------------------
+  @Override
+  void setSnapshots()
+  throws Exception
+  {
+  }
+  //---------------------------------------------------------------------------------------------
+  protected void startDavServer( String basePath, String baseHint )
+  throws Exception
+  {
+      targetDirectory = new File( basePath );
+
+      FileUtil.delete( targetDirectory );
+
+      targetDirectory.mkdirs();
+      
+      _dav = new WebDavServer( 0, targetDirectory, _davContext, getContainer(), 9, baseHint );
+      
+      _dav.start();
+      
+      Credentials user = new Credentials(_user,_pass);
+      
+      server = new Server("dav", new URL("http://localhost:"+_dav.getPort()+_davContext), false, false, user );
+      
+System.out.println("Server: "+server.getURL() + " ==> " + basePath );
+      
+      mdProcessor = new MetadataProcessorMock();
+      
+      repo = new RemoteRepositoryM2( server, mdProcessor );
+      
+      // verifiers
+      factories = new HashSet<StreamVerifierFactory>();       
+      factories.add( 
+          new PgpStreamVerifierFactory(
+                  new StreamVerifierAttributes( PgpStreamVerifierFactory.DEFAULT_EXTENSION, false, false )
+                  , getClass().getResourceAsStream( secretKeyFile )
+                  , keyId
+                  , secretKeyPass
+                                      )
+                    );
+      factories.add( new SHA1VerifierFactory(false,false) );
+      server.setWriterStreamVerifierFactories(factories);
+        
+      reader = repo.getReader();
+      writer = repo.getWriter();
+      
+  }
+  //---------------------------------------------------------------------------------------------
+  protected void stopDavServer()
+  throws Exception
+  {
+      if( _dav != null )
+      {
+          _dav.stop();
+          _dav.destroy();
+          _dav = null;
+      }  
+  }
+  //------------------------------------------------------------------------------
+  @Override
+  protected void setUp()
+  throws Exception
+  {
+    super.setUp();
+
+    query = new ArrayList<ArtifactBasicMetadata>();
+
+    startDavServer( _basePath, "mercury-test"  );
+  }
+  //-------------------------------------------------------------------------
+  @Override
+  protected void tearDown()
+  throws Exception
+  {
+    super.tearDown();
+    
+    stopDavServer();
+  }
+  //-------------------------------------------------------------------------
+  @Override
+  public void testWriteContentionMultipleArtifacts()
+      throws Exception
+  {
+    System.out.println("Mutliple Artifacts contention does not apply to remote repo client");
+  }
+  
+  @Override
+  public void testWriteContentionSingleArtifact()
+      throws Exception
+  {
+    System.out.println("Single Artifacts contention does not apply to remote repo client");
+  }
+  
+  //-------------------------------------------------------------------------
+  //-------------------------------------------------------------------------
+}

Propchange: maven/mercury/trunk/mercury-it/src/test/java/org/apache/maven/mercury/repository/tests/RemoteRepositoryWriterM2Test.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: maven/mercury/trunk/mercury-it/src/test/java/org/apache/maven/mercury/repository/tests/RemoteRepositoryWriterM2Test.java
------------------------------------------------------------------------------
    svn:keywords = Author Date Id Revision

Added: maven/mercury/trunk/mercury-it/src/test/java/org/apache/maven/mercury/repository/tests/WebDavServer.java
URL: http://svn.apache.org/viewvc/maven/mercury/trunk/mercury-it/src/test/java/org/apache/maven/mercury/repository/tests/WebDavServer.java?rev=740358&view=auto
==============================================================================
--- maven/mercury/trunk/mercury-it/src/test/java/org/apache/maven/mercury/repository/tests/WebDavServer.java (added)
+++ maven/mercury/trunk/mercury-it/src/test/java/org/apache/maven/mercury/repository/tests/WebDavServer.java Tue Feb  3 17:44:33 2009
@@ -0,0 +1,86 @@
+/*
+Licensed to the Apache Software Foundation (ASF) under one
+or more contributor license agreements.  See the NOTICE file
+distributed with this work for additional information
+regarding copyright ownership.  The ASF licenses this file
+to you under the Apache License, Version 2.0 (the
+"License"); you may not use this file except in compliance
+with the License.  You may obtain a copy of the License at
+
+    http://www.apache.org/licenses/LICENSE-2.0
+
+Unless required by applicable law or agreed to in writing,
+software distributed under the License is distributed on an
+"AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+KIND, either express or implied.  See the License for the
+specific language governing permissions and limitations
+under the License.
+*/
+
+package org.apache.maven.mercury.repository.tests;
+
+import java.io.File;
+
+import org.codehaus.plexus.PlexusConstants;
+import org.codehaus.plexus.PlexusContainer;
+import org.mortbay.jetty.Server;
+import org.mortbay.jetty.handler.ContextHandlerCollection;
+import org.mortbay.jetty.handler.DefaultHandler;
+import org.mortbay.jetty.handler.HandlerCollection;
+import org.mortbay.jetty.servlet.Context;
+import org.mortbay.jetty.servlet.ServletHolder;
+import org.sonatype.webdav.WebdavServlet;
+
+/**
+ *
+ *
+ * @author Oleg Gusakov
+ * @version $Id$
+ *
+ */
+public class WebDavServer
+extends Server
+{
+    public WebDavServer( int port
+                         , File base
+                         , String remotePathFragment
+                         , PlexusContainer container
+                         , int debugLevel
+                         , String fileCollectionHint
+                         )
+    throws Exception
+    {
+        super( port );
+
+        if ( !base.exists() )
+        {
+            base.mkdirs();
+        }
+
+        if( ! base.isDirectory() )
+        {
+            throw new IllegalArgumentException( "Specified base is not a directory: " + base.getCanonicalPath() );
+        }
+        
+//        HandlerCollection handlers = new HandlerCollection();
+//        setHandler( handlers );
+//
+//        Context context = new Context( handlers, remotePathFragment );
+//        handlers.addHandler( new DefaultHandler() );
+        
+        
+        ContextHandlerCollection contexts = new ContextHandlerCollection();
+        setHandler(contexts);
+        Context context = new Context(contexts, remotePathFragment, Context.SESSIONS);
+        context.addServlet(new ServletHolder( new WebdavServlet() ), "/*");
+        context.setResourceBase( base.getCanonicalPath() );
+        context.setAttribute( PlexusConstants.PLEXUS_KEY, container );
+        context.setAttribute( "resourceCollectionHint", fileCollectionHint );
+        context.setAttribute( "debug", debugLevel );
+    }
+
+    public int getPort()
+    {
+        return getConnectors()[0].getLocalPort();
+    }
+}

Propchange: maven/mercury/trunk/mercury-it/src/test/java/org/apache/maven/mercury/repository/tests/WebDavServer.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: maven/mercury/trunk/mercury-it/src/test/java/org/apache/maven/mercury/repository/tests/WebDavServer.java
------------------------------------------------------------------------------
    svn:keywords = Author Date Id Revision

Added: maven/mercury/trunk/mercury-it/src/test/resources/org/apache/maven/mercury/repository/tests/DavServerTest.xml
URL: http://svn.apache.org/viewvc/maven/mercury/trunk/mercury-it/src/test/resources/org/apache/maven/mercury/repository/tests/DavServerTest.xml?rev=740358&view=auto
==============================================================================
--- maven/mercury/trunk/mercury-it/src/test/resources/org/apache/maven/mercury/repository/tests/DavServerTest.xml (added)
+++ maven/mercury/trunk/mercury-it/src/test/resources/org/apache/maven/mercury/repository/tests/DavServerTest.xml Tue Feb  3 17:44:33 2009
@@ -0,0 +1,55 @@
+<component-set>
+  <components>
+
+    <component>
+      <role>org.sonatype.webdav.security.Authentication</role>
+      <role-hint>properties</role-hint>
+      <implementation>org.sonatype.webdav.security.PropertiesAuthentication</implementation>
+      <configuration>
+        <properties>
+          <property>
+            <name>foo</name>
+            <value>bar</value>
+          </property>
+        </properties>
+      </configuration>
+    </component>
+
+    <component>
+      <role>org.sonatype.webdav.security.Authorization</role>
+      <role-hint>properties</role-hint>
+      <implementation>org.sonatype.webdav.security.PropertiesAuthorization</implementation>
+      <configuration>
+        <properties>
+          <property>
+            <name>foo</name>
+            <value>admin,repository.read,repository.write</value>
+          </property>
+        </properties>
+      </configuration>
+    </component>
+    
+    <component>
+      <role>org.sonatype.webdav.ResourceCollection</role>
+      <role-hint>mercury-test</role-hint>
+      <implementation>org.sonatype.webdav.FileResourceCollection</implementation>
+      <description></description>
+      <isolated-realm>false</isolated-realm>
+      <configuration>
+        <root-path>./target/webdav</root-path>
+      </configuration>
+    </component>
+
+    <component>
+      <role>org.sonatype.webdav.ResourceCollection</role>
+      <role-hint>mercury-test-2</role-hint>
+      <implementation>org.sonatype.webdav.FileResourceCollection</implementation>
+      <description></description>
+      <isolated-realm>false</isolated-realm>
+      <configuration>
+        <root-path>./target/webdav2</root-path>
+      </configuration>
+    </component>
+        
+  </components>
+</component-set>

Propchange: maven/mercury/trunk/mercury-it/src/test/resources/org/apache/maven/mercury/repository/tests/DavServerTest.xml
------------------------------------------------------------------------------
    svn:mergeinfo = 

Added: maven/mercury/trunk/mercury-it/src/test/resources/org/apache/maven/mercury/repository/tests/RemoteRepositoryWriterM2Test.xml
URL: http://svn.apache.org/viewvc/maven/mercury/trunk/mercury-it/src/test/resources/org/apache/maven/mercury/repository/tests/RemoteRepositoryWriterM2Test.xml?rev=740358&view=auto
==============================================================================
--- maven/mercury/trunk/mercury-it/src/test/resources/org/apache/maven/mercury/repository/tests/RemoteRepositoryWriterM2Test.xml (added)
+++ maven/mercury/trunk/mercury-it/src/test/resources/org/apache/maven/mercury/repository/tests/RemoteRepositoryWriterM2Test.xml Tue Feb  3 17:44:33 2009
@@ -0,0 +1,44 @@
+<component-set>
+  <components>
+
+    <component>
+      <role>org.sonatype.webdav.security.Authentication</role>
+      <role-hint>properties</role-hint>
+      <implementation>org.sonatype.webdav.security.PropertiesAuthentication</implementation>
+      <configuration>
+        <properties>
+          <property>
+            <name>foo</name>
+            <value>bar</value>
+          </property>
+        </properties>
+      </configuration>
+    </component>
+
+    <component>
+      <role>org.sonatype.webdav.security.Authorization</role>
+      <role-hint>properties</role-hint>
+      <implementation>org.sonatype.webdav.security.PropertiesAuthorization</implementation>
+      <configuration>
+        <properties>
+          <property>
+            <name>foo</name>
+            <value>admin,repository.read,repository.write</value>
+          </property>
+        </properties>
+      </configuration>
+    </component>
+    
+    <component>
+      <role>org.sonatype.webdav.ResourceCollection</role>
+      <role-hint>mercury-test</role-hint>
+      <implementation>org.sonatype.webdav.FileResourceCollection</implementation>
+      <description></description>
+      <isolated-realm>false</isolated-realm>
+      <configuration>
+        <root-path>./target/webdav</root-path>
+      </configuration>
+    </component>
+        
+  </components>
+</component-set>

Propchange: maven/mercury/trunk/mercury-it/src/test/resources/org/apache/maven/mercury/repository/tests/RemoteRepositoryWriterM2Test.xml
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: maven/mercury/trunk/mercury-it/src/test/resources/org/apache/maven/mercury/repository/tests/RemoteRepositoryWriterM2Test.xml
------------------------------------------------------------------------------
    svn:keywords = Author Date Id Revision