You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@tuscany.apache.org by lr...@apache.org on 2007/04/14 01:11:58 UTC

svn commit: r528697 - /incubator/tuscany/java/sca/modules/contribution-impl/src/main/java/org/apache/tuscany/contribution/service/processor/impl/

Author: lresende
Date: Fri Apr 13 16:11:57 2007
New Revision: 528697

URL: http://svn.apache.org/viewvc?view=rev&rev=528697
Log:
Contribution Service refactoring - Part IV

Added:
    incubator/tuscany/java/sca/modules/contribution-impl/src/main/java/org/apache/tuscany/contribution/service/processor/impl/
    incubator/tuscany/java/sca/modules/contribution-impl/src/main/java/org/apache/tuscany/contribution/service/processor/impl/AbstractContributionPackageProcessor.java   (with props)
    incubator/tuscany/java/sca/modules/contribution-impl/src/main/java/org/apache/tuscany/contribution/service/processor/impl/FolderContributionProcessor.java   (with props)
    incubator/tuscany/java/sca/modules/contribution-impl/src/main/java/org/apache/tuscany/contribution/service/processor/impl/InvalidFolderContributionException.java   (with props)
    incubator/tuscany/java/sca/modules/contribution-impl/src/main/java/org/apache/tuscany/contribution/service/processor/impl/InvalidFolderContributionURIException.java   (with props)
    incubator/tuscany/java/sca/modules/contribution-impl/src/main/java/org/apache/tuscany/contribution/service/processor/impl/JarContributionProcessor.java   (with props)

Added: incubator/tuscany/java/sca/modules/contribution-impl/src/main/java/org/apache/tuscany/contribution/service/processor/impl/AbstractContributionPackageProcessor.java
URL: http://svn.apache.org/viewvc/incubator/tuscany/java/sca/modules/contribution-impl/src/main/java/org/apache/tuscany/contribution/service/processor/impl/AbstractContributionPackageProcessor.java?view=auto&rev=528697
==============================================================================
--- incubator/tuscany/java/sca/modules/contribution-impl/src/main/java/org/apache/tuscany/contribution/service/processor/impl/AbstractContributionPackageProcessor.java (added)
+++ incubator/tuscany/java/sca/modules/contribution-impl/src/main/java/org/apache/tuscany/contribution/service/processor/impl/AbstractContributionPackageProcessor.java Fri Apr 13 16:11:57 2007
@@ -0,0 +1,61 @@
+/*
+ * 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.tuscany.contribution.service.processor.impl;
+
+import java.net.MalformedURLException;
+import java.net.URI;
+import java.net.URL;
+
+import org.apache.tuscany.contribution.service.processor.ContributionPackageProcessor;
+import org.apache.tuscany.contribution.service.processor.ContributionPackageProcessorRegistry;
+
+/**
+ * The base class for ContributionPackageProcessor implementations
+ * 
+ * @version $Rev$ $Date$
+ */
+public abstract class AbstractContributionPackageProcessor implements ContributionPackageProcessor {
+    /**
+     * The ContributionProcessorRegistry that this processor should register
+     * with; usually set by injection. This registry may also be used to process
+     * other sub-artifacts.
+     */
+    protected final ContributionPackageProcessorRegistry registry;
+
+    /**
+     * @param registry the registry to set
+     */
+    public AbstractContributionPackageProcessor(ContributionPackageProcessorRegistry registry) {
+        this.registry = registry;
+        this.registry.register(this.getPackageType(), this);
+    }
+
+    public URL getArtifactURL(URL packageSourceURL, URI artifact) throws MalformedURLException {
+        return new URL(packageSourceURL, artifact.toString());
+    }
+
+    /**
+     * Returns the type of package handled by this package processor.
+     * 
+     * @return the type of package handled by this package processor
+     */
+    public abstract String getPackageType();
+
+}

Propchange: incubator/tuscany/java/sca/modules/contribution-impl/src/main/java/org/apache/tuscany/contribution/service/processor/impl/AbstractContributionPackageProcessor.java
------------------------------------------------------------------------------
    svn:eol-style = native

Added: incubator/tuscany/java/sca/modules/contribution-impl/src/main/java/org/apache/tuscany/contribution/service/processor/impl/FolderContributionProcessor.java
URL: http://svn.apache.org/viewvc/incubator/tuscany/java/sca/modules/contribution-impl/src/main/java/org/apache/tuscany/contribution/service/processor/impl/FolderContributionProcessor.java?view=auto&rev=528697
==============================================================================
--- incubator/tuscany/java/sca/modules/contribution-impl/src/main/java/org/apache/tuscany/contribution/service/processor/impl/FolderContributionProcessor.java (added)
+++ incubator/tuscany/java/sca/modules/contribution-impl/src/main/java/org/apache/tuscany/contribution/service/processor/impl/FolderContributionProcessor.java Fri Apr 13 16:11:57 2007
@@ -0,0 +1,110 @@
+/*
+ * 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.tuscany.contribution.service.processor.impl;
+
+import java.io.File;
+import java.io.IOException;
+import java.io.InputStream;
+import java.net.MalformedURLException;
+import java.net.URI;
+import java.net.URISyntaxException;
+import java.net.URL;
+import java.util.ArrayList;
+import java.util.List;
+
+import org.apache.tuscany.contribution.ContentType;
+import org.apache.tuscany.contribution.service.ContributionException;
+import org.apache.tuscany.contribution.service.processor.ContributionPackageProcessor;
+import org.apache.tuscany.contribution.service.processor.ContributionPackageProcessorRegistry;
+import org.apache.tuscany.contribution.service.util.FileHelper;
+
+public class FolderContributionProcessor extends AbstractContributionPackageProcessor implements
+    ContributionPackageProcessor {
+    /**
+     * Package-type that this package processor can handle
+     */
+    public static final String PACKAGE_TYPE = ContentType.FOLDER;
+
+    public FolderContributionProcessor(ContributionPackageProcessorRegistry registry) {
+        super(registry);
+    }
+
+    public String getPackageType() {
+        return PACKAGE_TYPE;
+    }
+
+    /**
+     * Recursively traverse a root directory
+     * 
+     * @param fileList
+     * @param file
+     * @throws IOException
+     */
+    private void traverse(List<URI> fileList, File file, File root) throws IOException {
+        if (file.isFile()) {
+            fileList.add(root.toURI().relativize(file.toURI()));
+        } else if (file.isDirectory()) {
+            // FIXME: Maybe we should externalize it as a property
+            // Regular expression to exclude .xxx files
+            File[] files = file.listFiles(FileHelper.getFileFilter("[^\u002e].*", true));
+            for (int i = 0; i < files.length; i++) {
+                traverse(fileList, files[i], root);
+            }
+        }
+    }
+    
+    public URL getArtifactURL(URL sourceURL, URI artifact) throws MalformedURLException {
+        return new URL(sourceURL, artifact.toString());
+    }
+
+    /**
+     * Get a list of files from the directory
+     * 
+     * @return
+     * @throws IOException
+     */
+    public List<URI> getArtifacts(URL packageSourceURL, InputStream inputStream) throws ContributionException,
+        IOException {
+        if (packageSourceURL == null) {
+            throw new IllegalArgumentException("Invalid null package source URL.");
+        }
+
+        List<URI> artifacts = new ArrayList<URI>();
+
+        // Assume the root is a jar file
+        File rootFolder;
+
+        try {
+            rootFolder = new File(packageSourceURL.toURI());
+            if (rootFolder.isDirectory()) {
+                if (!rootFolder.exists()) {
+                    throw new InvalidFolderContributionException(rootFolder.getAbsolutePath());
+                }
+
+                this.traverse(artifacts, rootFolder, rootFolder);
+            }
+
+        } catch (URISyntaxException e) {
+            throw new InvalidFolderContributionURIException(packageSourceURL.toExternalForm(), e);
+        }
+
+        return artifacts;
+    }
+}

Propchange: incubator/tuscany/java/sca/modules/contribution-impl/src/main/java/org/apache/tuscany/contribution/service/processor/impl/FolderContributionProcessor.java
------------------------------------------------------------------------------
    svn:eol-style = native

Added: incubator/tuscany/java/sca/modules/contribution-impl/src/main/java/org/apache/tuscany/contribution/service/processor/impl/InvalidFolderContributionException.java
URL: http://svn.apache.org/viewvc/incubator/tuscany/java/sca/modules/contribution-impl/src/main/java/org/apache/tuscany/contribution/service/processor/impl/InvalidFolderContributionException.java?view=auto&rev=528697
==============================================================================
--- incubator/tuscany/java/sca/modules/contribution-impl/src/main/java/org/apache/tuscany/contribution/service/processor/impl/InvalidFolderContributionException.java (added)
+++ incubator/tuscany/java/sca/modules/contribution-impl/src/main/java/org/apache/tuscany/contribution/service/processor/impl/InvalidFolderContributionException.java Fri Apr 13 16:11:57 2007
@@ -0,0 +1,41 @@
+/*
+ * 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.tuscany.contribution.service.processor.impl;
+
+import org.apache.tuscany.contribution.service.ContributionException;
+
+/**
+ * Exception that indicates that the supplied XML Document invalid.
+ *
+ */
+public class InvalidFolderContributionException extends ContributionException {
+
+    /**
+     * 
+     */
+    private static final long serialVersionUID = 1564255850052593282L;
+
+    protected InvalidFolderContributionException(String componentDefinitionLocatoin) {
+        super(componentDefinitionLocatoin);
+    }
+    
+    protected InvalidFolderContributionException(String message, Throwable cause) {
+        super(message, cause);
+    }
+}

Propchange: incubator/tuscany/java/sca/modules/contribution-impl/src/main/java/org/apache/tuscany/contribution/service/processor/impl/InvalidFolderContributionException.java
------------------------------------------------------------------------------
    svn:eol-style = native

Added: incubator/tuscany/java/sca/modules/contribution-impl/src/main/java/org/apache/tuscany/contribution/service/processor/impl/InvalidFolderContributionURIException.java
URL: http://svn.apache.org/viewvc/incubator/tuscany/java/sca/modules/contribution-impl/src/main/java/org/apache/tuscany/contribution/service/processor/impl/InvalidFolderContributionURIException.java?view=auto&rev=528697
==============================================================================
--- incubator/tuscany/java/sca/modules/contribution-impl/src/main/java/org/apache/tuscany/contribution/service/processor/impl/InvalidFolderContributionURIException.java (added)
+++ incubator/tuscany/java/sca/modules/contribution-impl/src/main/java/org/apache/tuscany/contribution/service/processor/impl/InvalidFolderContributionURIException.java Fri Apr 13 16:11:57 2007
@@ -0,0 +1,41 @@
+/*
+ * 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.tuscany.contribution.service.processor.impl;
+
+import org.apache.tuscany.contribution.service.ContributionException;
+
+/**
+ * Exception that indicates that the supplied XML Document invalid.
+ *
+ */
+public class InvalidFolderContributionURIException extends ContributionException {
+
+    /**
+     * 
+     */
+    private static final long serialVersionUID = 1564255850052593282L;
+
+    protected InvalidFolderContributionURIException(String componentDefinitionLocatoin) {
+        super(componentDefinitionLocatoin);
+    }
+    
+    protected InvalidFolderContributionURIException(String message, Throwable cause) {
+        super(message, cause);
+    }
+}

Propchange: incubator/tuscany/java/sca/modules/contribution-impl/src/main/java/org/apache/tuscany/contribution/service/processor/impl/InvalidFolderContributionURIException.java
------------------------------------------------------------------------------
    svn:eol-style = native

Added: incubator/tuscany/java/sca/modules/contribution-impl/src/main/java/org/apache/tuscany/contribution/service/processor/impl/JarContributionProcessor.java
URL: http://svn.apache.org/viewvc/incubator/tuscany/java/sca/modules/contribution-impl/src/main/java/org/apache/tuscany/contribution/service/processor/impl/JarContributionProcessor.java?view=auto&rev=528697
==============================================================================
--- incubator/tuscany/java/sca/modules/contribution-impl/src/main/java/org/apache/tuscany/contribution/service/processor/impl/JarContributionProcessor.java (added)
+++ incubator/tuscany/java/sca/modules/contribution-impl/src/main/java/org/apache/tuscany/contribution/service/processor/impl/JarContributionProcessor.java Fri Apr 13 16:11:57 2007
@@ -0,0 +1,95 @@
+/*
+ * 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.tuscany.contribution.service.processor.impl;
+
+import java.io.IOException;
+import java.io.InputStream;
+import java.net.MalformedURLException;
+import java.net.URI;
+import java.net.URL;
+import java.util.ArrayList;
+import java.util.List;
+import java.util.jar.JarEntry;
+import java.util.jar.JarInputStream;
+
+import org.apache.tuscany.contribution.ContentType;
+import org.apache.tuscany.contribution.service.ContributionException;
+import org.apache.tuscany.contribution.service.processor.ContributionPackageProcessor;
+import org.apache.tuscany.contribution.service.processor.ContributionPackageProcessorRegistry;
+
+public class JarContributionProcessor extends AbstractContributionPackageProcessor implements
+    ContributionPackageProcessor {
+    /**
+     * Package-type that this package processor can handle
+     */
+    public static final String PACKAGE_TYPE = ContentType.JAR;
+
+    public JarContributionProcessor(ContributionPackageProcessorRegistry registry) {
+        super(registry);
+    }
+
+    public String getPackageType() {
+        return PACKAGE_TYPE;
+    }
+
+    public URL getArtifactURL(URL sourceURL, URI artifact) throws MalformedURLException {
+        if (sourceURL.toString().startsWith("jar:")) {
+            return new URL(sourceURL, artifact.toString());
+        } else {
+            return new URL("jar:" + sourceURL.toExternalForm() + "!/" + artifact);
+        }
+    }
+
+    public List<URI> getArtifacts(URL packageSourceURL, InputStream inputStream) throws ContributionException,
+        IOException {
+        if (packageSourceURL == null) {
+            throw new IllegalArgumentException("Invalid null package source URL.");
+        }
+
+        if (inputStream == null) {
+            throw new IllegalArgumentException("Invalid null source inputstream.");
+        }
+
+        List<URI> artifacts = new ArrayList<URI>();
+
+        // Assume the root is a jar file
+        JarInputStream jar = new JarInputStream(inputStream);
+        try {
+            while (true) {
+                JarEntry entry = jar.getNextJarEntry();
+                if (entry == null) {
+                    // EOF
+                    break;
+                }
+                if (entry.isDirectory()) {
+                    continue;
+                }
+
+                // FIXME: Maybe we should externalize the filter as a property
+                if (!entry.getName().startsWith(".")) {
+                    artifacts.add(URI.create(entry.getName()));
+                }
+            }
+        } finally {
+            jar.close();
+        }
+        return artifacts;
+    }
+}

Propchange: incubator/tuscany/java/sca/modules/contribution-impl/src/main/java/org/apache/tuscany/contribution/service/processor/impl/JarContributionProcessor.java
------------------------------------------------------------------------------
    svn:eol-style = native



---------------------------------------------------------------------
To unsubscribe, e-mail: tuscany-commits-unsubscribe@ws.apache.org
For additional commands, e-mail: tuscany-commits-help@ws.apache.org