You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@camel.apache.org by da...@apache.org on 2015/09/13 17:40:43 UTC

camel git commit: CAMEL-9094 Can't use custom FTPParser on OSGI. This closes #610.

Repository: camel
Updated Branches:
  refs/heads/master 15fd04d35 -> 1300aa625


CAMEL-9094 Can't use custom FTPParser on OSGI. This closes #610.


Project: http://git-wip-us.apache.org/repos/asf/camel/repo
Commit: http://git-wip-us.apache.org/repos/asf/camel/commit/1300aa62
Tree: http://git-wip-us.apache.org/repos/asf/camel/tree/1300aa62
Diff: http://git-wip-us.apache.org/repos/asf/camel/diff/1300aa62

Branch: refs/heads/master
Commit: 1300aa62594464f4067fda986085de4e4f1612f5
Parents: 15fd04d
Author: cunningt <tc...@redhat.com>
Authored: Fri Sep 11 16:12:17 2015 -0400
Committer: Claus Ibsen <da...@apache.org>
Committed: Sun Sep 13 17:05:02 2015 +0200

----------------------------------------------------------------------
 .../component/file/remote/FtpEndpoint.java      |  18 +-
 .../file/remote/OsgiParserFactory.java          | 173 +++++++++++++++++++
 2 files changed, 189 insertions(+), 2 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/camel/blob/1300aa62/components/camel-ftp/src/main/java/org/apache/camel/component/file/remote/FtpEndpoint.java
----------------------------------------------------------------------
diff --git a/components/camel-ftp/src/main/java/org/apache/camel/component/file/remote/FtpEndpoint.java b/components/camel-ftp/src/main/java/org/apache/camel/component/file/remote/FtpEndpoint.java
index 15ea641..330c260 100644
--- a/components/camel-ftp/src/main/java/org/apache/camel/component/file/remote/FtpEndpoint.java
+++ b/components/camel-ftp/src/main/java/org/apache/camel/component/file/remote/FtpEndpoint.java
@@ -25,8 +25,10 @@ import org.apache.camel.Processor;
 import org.apache.camel.component.file.GenericFileConfiguration;
 import org.apache.camel.component.file.GenericFileProducer;
 import org.apache.camel.component.file.remote.RemoteFileConfiguration.PathSeparator;
+import org.apache.camel.spi.ClassResolver;
 import org.apache.camel.spi.UriEndpoint;
 import org.apache.camel.spi.UriParam;
+import org.apache.camel.util.PlatformHelper;
 import org.apache.commons.net.ftp.FTPClient;
 import org.apache.commons.net.ftp.FTPClientConfig;
 import org.apache.commons.net.ftp.FTPFile;
@@ -37,7 +39,6 @@ import org.apache.commons.net.ftp.FTPFile;
 @UriEndpoint(scheme = "ftp", extendsScheme = "file", title = "FTP",
         syntax = "ftp:host:port/directoryName", consumerClass = FtpConsumer.class, label = "file")
 public class FtpEndpoint<T extends FTPFile> extends RemoteFileEndpoint<FTPFile> {
-
     protected FTPClient ftpClient;
     protected FTPClientConfig ftpClientConfig;
     protected Map<String, Object> ftpClientParameters;
@@ -143,7 +144,20 @@ public class FtpEndpoint<T extends FTPFile> extends RemoteFileEndpoint<FTPFile>
     }
 
     protected FTPClient createFtpClient() throws Exception {
-        return new FTPClient();
+        FTPClient client = new FTPClient();
+        // If we're in an OSGI environment, set the parser factory to
+        // OsgiParserFactory, because commons-net uses Class.forName in their
+        // default ParserFactory
+        if (isOsgi()) {
+            ClassResolver cr = getCamelContext().getClassResolver();
+            OsgiParserFactory opf = new OsgiParserFactory(cr);
+            client.setParserFactory(opf);
+        }
+        return client;
+    }
+
+    private boolean isOsgi() {
+        return PlatformHelper.isOsgiContext(getCamelContext());
     }
 
     @Override

http://git-wip-us.apache.org/repos/asf/camel/blob/1300aa62/components/camel-ftp/src/main/java/org/apache/camel/component/file/remote/OsgiParserFactory.java
----------------------------------------------------------------------
diff --git a/components/camel-ftp/src/main/java/org/apache/camel/component/file/remote/OsgiParserFactory.java b/components/camel-ftp/src/main/java/org/apache/camel/component/file/remote/OsgiParserFactory.java
new file mode 100644
index 0000000..6eaf87d
--- /dev/null
+++ b/components/camel-ftp/src/main/java/org/apache/camel/component/file/remote/OsgiParserFactory.java
@@ -0,0 +1,173 @@
+/**
+ * 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.camel.component.file.remote;
+
+import java.util.Locale;
+import java.util.regex.Pattern;
+
+import org.apache.camel.spi.ClassResolver;
+
+import org.apache.commons.net.ftp.Configurable;
+import org.apache.commons.net.ftp.FTPClientConfig;
+import org.apache.commons.net.ftp.FTPFileEntryParser;
+import org.apache.commons.net.ftp.parser.CompositeFileEntryParser;
+import org.apache.commons.net.ftp.parser.DefaultFTPFileEntryParserFactory;
+import org.apache.commons.net.ftp.parser.MVSFTPEntryParser;
+import org.apache.commons.net.ftp.parser.MacOsPeterFTPEntryParser;
+import org.apache.commons.net.ftp.parser.NTFTPEntryParser;
+import org.apache.commons.net.ftp.parser.NetwareFTPEntryParser;
+import org.apache.commons.net.ftp.parser.OS2FTPEntryParser;
+import org.apache.commons.net.ftp.parser.OS400FTPEntryParser;
+import org.apache.commons.net.ftp.parser.ParserInitializationException;
+import org.apache.commons.net.ftp.parser.UnixFTPEntryParser;
+import org.apache.commons.net.ftp.parser.VMSVersioningFTPEntryParser;
+
+/**
+ * OsgiParserFactory
+ * 
+ * commons-net DefaultFTPFileEntryParserFactory uses Class.forName, and fails
+ * to load custom ParserFactories in OSGI.   This class is an alternative ParserFactory
+ * that can be used when Camel is used in an OSGI environment.
+ */
+public class OsgiParserFactory extends DefaultFTPFileEntryParserFactory {
+    // Match a plain Java Identifier
+    private static final String JAVA_IDENTIFIER = "\\p{javaJavaIdentifierStart}(\\p{javaJavaIdentifierPart})*";
+    // Match a qualified name, e.g. a.b.c.Name - but don't allow the default package as that would allow "VMS"/"UNIX" etc.
+    private static final String JAVA_QUALIFIED_NAME = "(" + JAVA_IDENTIFIER + "\\.)+" + JAVA_IDENTIFIER;
+    // Create the pattern, as it will be reused many times
+    private static final Pattern JAVA_QUALIFIED_NAME_PATTERN = Pattern.compile(JAVA_QUALIFIED_NAME);
+
+    private ClassResolver ocr;
+    
+    public OsgiParserFactory(ClassResolver ocr) {
+        super();
+        this.ocr = ocr;
+    }
+    
+    /**
+     * setClassResolver sets a class resolver which can be used instead of
+     * Class.forName for class resolution.
+     * @param ocr Class Resolver
+     */
+    public void setClassResolver(ClassResolver ocr) {
+        ocr = ocr;
+    }
+    
+    @Override
+    public FTPFileEntryParser createFileEntryParser(String key) {
+        if (key == null) {
+            throw new ParserInitializationException("Parser key cannot be null");
+        }
+        return createFileEntryParser(key, null);
+    }
+
+    @Override
+    public FTPFileEntryParser createFileEntryParser(FTPClientConfig config)
+        throws ParserInitializationException {
+        String key = config.getServerSystemKey();
+        return createFileEntryParser(key, config);
+    }
+    
+    private FTPFileEntryParser createFileEntryParser(String key, FTPClientConfig config) {
+        FTPFileEntryParser parser = null;
+    
+        // Is the key a possible class name?
+        if (JAVA_QUALIFIED_NAME_PATTERN.matcher(key).matches()) {
+            Class<?> parserClass = ocr.resolveClass(key);
+            try {
+                parser = (FTPFileEntryParser) parserClass.newInstance();
+            } catch (ClassCastException e) {
+                throw new ParserInitializationException(parserClass.getName()
+                    + " does not implement the interface "
+                    + "org.apache.commons.net.ftp.FTPFileEntryParser.", e);
+            } catch (Exception e) {
+                throw new ParserInitializationException("Error initializing parser", e);
+            } catch (ExceptionInInitializerError e) {
+                throw new ParserInitializationException("Error initializing parser", e);
+            }
+        }
+        if (parser == null) {
+            String ukey = key.toUpperCase(Locale.ENGLISH);
+            if (ukey.indexOf("UNIX") >= 0) {
+                parser = new UnixFTPEntryParser(config);
+            } else if (ukey.indexOf("VMS") >= 0) {
+                parser = new VMSVersioningFTPEntryParser(config);
+            } else if (ukey.indexOf("WINDOWS") >= 0) {
+                parser = createNTFTPEntryParser(config);
+            } else if (ukey.indexOf("OS/2") >= 0) {
+                parser = new OS2FTPEntryParser(config);
+            } else if ((ukey.indexOf("OS/400") >= 0) || (ukey.indexOf("AS/400") >= 0)) {
+                parser = createOS400FTPEntryParser(config);
+            } else if (ukey.indexOf("MVS") >= 0) {
+                parser = new MVSFTPEntryParser();
+            } else if (ukey.indexOf("NETWARE") >= 0) {
+                parser = new NetwareFTPEntryParser(config);
+            } else if (ukey.indexOf("MACOS PETER") >= 0) {
+                parser = new MacOsPeterFTPEntryParser(config);
+            } else if (ukey.indexOf("TYPE: L8") >= 0) {
+                parser = new UnixFTPEntryParser(config);
+            } else {
+                throw new ParserInitializationException("Unknown parser type: " + key);
+            }
+        }
+
+        if (parser instanceof Configurable) {
+            ((Configurable)parser).configure(config);
+        }
+        
+        return parser;
+    }
+
+    /**
+     * Creates an NT FTP parser: if the config exists, and the system key equals
+     * {@link FTPClientConfig.SYST_NT} then a plain {@link NTFTPEntryParser} is used,
+     * otherwise a composite of {@link NTFTPEntryParser} and {@link UnixFTPEntryParser} is used.
+     * @param config the config to use, may be {@code null}
+     * @return the parser
+     */
+    private FTPFileEntryParser createNTFTPEntryParser(FTPClientConfig config) {
+        if (config != null && FTPClientConfig.SYST_NT.equals(
+                config.getServerSystemKey())) {
+            return new NTFTPEntryParser(config);
+        } else {
+            return new CompositeFileEntryParser(new FTPFileEntryParser[] {
+                new NTFTPEntryParser(config),
+                new UnixFTPEntryParser(config)
+            });
+        }
+    }
+
+    /**
+     * Creates an OS400 FTP parser: if the config exists, and the system key equals
+     * {@link FTPClientConfig.SYST_OS400} then a plain {@link OS400FTPEntryParser} is used,
+     * otherwise a composite of {@link OS400FTPEntryParser} and {@link UnixFTPEntryParser} is used.
+     * @param config the config to use, may be {@code null}
+     * @return the parser
+     */
+    private FTPFileEntryParser createOS400FTPEntryParser(FTPClientConfig config)
+    {
+        if (config != null
+            && FTPClientConfig.SYST_OS400.equals(config.getServerSystemKey())) {
+            return new OS400FTPEntryParser(config);
+        } else {
+            return new CompositeFileEntryParser(new FTPFileEntryParser[] {
+                new OS400FTPEntryParser(config),
+                new UnixFTPEntryParser(config)
+            });
+        }
+    }
+}
\ No newline at end of file