You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@karaf.apache.org by jb...@apache.org on 2020/03/05 20:30:36 UTC

[karaf-decanter] branch master updated: [KARAF-6620] Remove the spring-boot-starter-decanter module

This is an automated email from the ASF dual-hosted git repository.

jbonofre pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/karaf-decanter.git


The following commit(s) were added to refs/heads/master by this push:
     new 4976f1d  [KARAF-6620] Remove the spring-boot-starter-decanter module
     new 25f5faa  Merge pull request #122 from fpapon/KARAF-6620
4976f1d is described below

commit 4976f1d0558193a24c58bac53ee2d9a9c6192426
Author: Francois Papon <fr...@openobject.fr>
AuthorDate: Tue Feb 18 18:22:12 2020 +0100

    [KARAF-6620] Remove the spring-boot-starter-decanter module
---
 pom.xml                                            |   1 -
 spring-boot-starter-decanter/etc/test.cfg          |  20 ----
 spring-boot-starter-decanter/pom.xml               |  88 --------------
 .../karaf/decanter/boot/DecanterAutoConfig.java    |  31 -----
 .../karaf/decanter/boot/DecanterConnect.java       |  54 ---------
 .../decanter/boot/DecanterRegistryFactory.java     | 130 ---------------------
 .../decanter/boot/LogbackDecanterAppender.java     | 110 -----------------
 .../resources/META-INF/decanter.bundles.default    |   9 --
 .../src/main/resources/META-INF/spring.factories   |   2 -
 .../decanter/boot/DecanterRegistryFactoryTest.java |  72 ------------
 .../src/test/resources/logback.xml                 |  39 -------
 11 files changed, 556 deletions(-)

diff --git a/pom.xml b/pom.xml
index 3812ac4..5b9683d 100644
--- a/pom.xml
+++ b/pom.xml
@@ -58,7 +58,6 @@
         <module>marshaller</module>
         <module>parser</module>
         <module>alerting</module>
-        <module>spring-boot-starter-decanter</module>
         <module>tools-jar-wrapper</module>
         <module>manual</module>
         <module>assembly</module>
diff --git a/spring-boot-starter-decanter/etc/test.cfg b/spring-boot-starter-decanter/etc/test.cfg
deleted file mode 100644
index f8b458f..0000000
--- a/spring-boot-starter-decanter/etc/test.cfg
+++ /dev/null
@@ -1,20 +0,0 @@
-################################################################################
-#
-#    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.
-#
-################################################################################
-
-mykey=myvalue
diff --git a/spring-boot-starter-decanter/pom.xml b/spring-boot-starter-decanter/pom.xml
deleted file mode 100644
index 6939b19..0000000
--- a/spring-boot-starter-decanter/pom.xml
+++ /dev/null
@@ -1,88 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
-
-    <!--
-
-        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.
-    -->
-
-    <modelVersion>4.0.0</modelVersion>
-
-    <parent>
-        <groupId>org.apache.karaf</groupId>
-        <artifactId>decanter</artifactId>
-        <version>2.3.0-SNAPSHOT</version>
-        <relativePath>../pom.xml</relativePath>
-    </parent>
-
-    <groupId>org.apache.karaf.decanter</groupId>
-    <artifactId>spring-boot-starter-decanter</artifactId>
-    <name>Apache Karaf :: Decanter :: Spring Boot Starter</name>
-
-    <dependencies>
-        <dependency>
-            <groupId>org.apache.felix</groupId>
-            <artifactId>org.apache.felix.connect</artifactId>
-            <version>0.1.0</version>
-        </dependency>
-        <dependency>
-            <groupId>org.apache.felix</groupId>
-            <artifactId>org.apache.felix.scr</artifactId>
-            <version>2.0.2</version>
-        </dependency>
-        <dependency>
-            <groupId>org.apache.karaf.decanter.appender</groupId>
-            <artifactId>org.apache.karaf.decanter.appender.kafka</artifactId>
-            <version>${project.version}</version>
-        </dependency>
-        <dependency>
-            <groupId>org.apache.karaf.decanter.appender</groupId>
-            <artifactId>org.apache.karaf.decanter.appender.log</artifactId>
-            <version>${project.version}</version>
-        </dependency>
-        <dependency>
-            <groupId>org.apache.karaf.decanter.marshaller</groupId>
-            <artifactId>org.apache.karaf.decanter.marshaller.json</artifactId>
-        </dependency>
-        <dependency>
-            <groupId>ch.qos.logback</groupId>
-            <artifactId>logback-classic</artifactId>
-            <version>1.1.5</version>
-        </dependency>
-        <dependency>
-            <groupId>org.apache.felix</groupId>
-            <artifactId>org.apache.felix.eventadmin</artifactId>
-            <version>1.4.6</version>
-        </dependency>
-        <dependency>
-            <groupId>org.apache.felix</groupId>
-            <artifactId>org.apache.felix.configadmin</artifactId>
-            <version>1.8.8</version>
-        </dependency>
-        <dependency>
-            <groupId>org.apache.felix</groupId>
-            <artifactId>org.apache.felix.fileinstall</artifactId>
-            <version>3.5.4</version>
-        </dependency>
-        
-        <dependency>
-            <groupId>org.springframework.boot</groupId>
-            <artifactId>spring-boot-autoconfigure</artifactId>
-            <version>2.1.3.RELEASE</version>
-        </dependency>
-    </dependencies>
-
-</project>
\ No newline at end of file
diff --git a/spring-boot-starter-decanter/src/main/java/org/apache/karaf/decanter/boot/DecanterAutoConfig.java b/spring-boot-starter-decanter/src/main/java/org/apache/karaf/decanter/boot/DecanterAutoConfig.java
deleted file mode 100644
index ac29f0c..0000000
--- a/spring-boot-starter-decanter/src/main/java/org/apache/karaf/decanter/boot/DecanterAutoConfig.java
+++ /dev/null
@@ -1,31 +0,0 @@
-/**
- * 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.karaf.decanter.boot;
-
-import org.springframework.context.annotation.Bean;
-import org.springframework.context.annotation.Configuration;
-
-@Configuration
-public class DecanterAutoConfig {
-
-    @Bean
-    DecanterConnect createDecanterConnect() throws Exception {
-        return new DecanterConnect();
-    }
-}
diff --git a/spring-boot-starter-decanter/src/main/java/org/apache/karaf/decanter/boot/DecanterConnect.java b/spring-boot-starter-decanter/src/main/java/org/apache/karaf/decanter/boot/DecanterConnect.java
deleted file mode 100644
index 8a851e3..0000000
--- a/spring-boot-starter-decanter/src/main/java/org/apache/karaf/decanter/boot/DecanterConnect.java
+++ /dev/null
@@ -1,54 +0,0 @@
-/**
- * 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.karaf.decanter.boot;
-
-import javax.annotation.PreDestroy;
-
-import org.osgi.framework.BundleContext;
-import org.osgi.framework.BundleException;
-import org.osgi.service.event.EventAdmin;
-import org.osgi.util.tracker.ServiceTracker;
-
-@org.springframework.context.annotation.Configuration
-public class DecanterConnect {
-    private BundleContext registryContext;
-
-    public DecanterConnect() throws Exception {
-        registryContext = new DecanterRegistryFactory().create();
-        LogbackDecanterAppender.setDispatcher(getService(registryContext, EventAdmin.class));
-    }
-
-    private <S>S getService(BundleContext context, Class<S> serviceClazz) {
-        ServiceTracker<S, S> tracker = new ServiceTracker<S, S>(context, serviceClazz, null);
-        try {
-            tracker.open();
-            return tracker.getService();
-        } finally {
-            tracker.close();
-        }
-    }
-
-    @PreDestroy
-    public void close() {
-        try {
-            registryContext.getBundle(0).stop();
-        } catch (BundleException e) {
-        }
-    }
-}
diff --git a/spring-boot-starter-decanter/src/main/java/org/apache/karaf/decanter/boot/DecanterRegistryFactory.java b/spring-boot-starter-decanter/src/main/java/org/apache/karaf/decanter/boot/DecanterRegistryFactory.java
deleted file mode 100644
index 42b689b..0000000
--- a/spring-boot-starter-decanter/src/main/java/org/apache/karaf/decanter/boot/DecanterRegistryFactory.java
+++ /dev/null
@@ -1,130 +0,0 @@
-/**
- * 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.karaf.decanter.boot;
-
-import static org.apache.felix.connect.launch.PojoServiceRegistryFactory.BUNDLE_DESCRIPTORS;
-
-import java.io.BufferedReader;
-import java.io.IOException;
-import java.io.InputStream;
-import java.io.InputStreamReader;
-import java.net.URISyntaxException;
-import java.nio.charset.Charset;
-import java.util.ArrayList;
-import java.util.HashMap;
-import java.util.HashSet;
-import java.util.List;
-import java.util.ServiceLoader;
-import java.util.Set;
-
-import org.apache.felix.connect.launch.BundleDescriptor;
-import org.apache.felix.connect.launch.ClasspathScanner;
-import org.apache.felix.connect.launch.PojoServiceRegistryFactory;
-import org.osgi.framework.BundleContext;
-import org.osgi.framework.Constants;
-import org.osgi.framework.FrameworkUtil;
-
-/**
- * Creates a felix connect instance from a list of bundle symbolic names provided in a file.
- * All listed bundles must be present in the project classpath.
- */
-public class DecanterRegistryFactory {
-    private static final String BUNDLES_CONFIG = "META-INF/decanter.bundles";
-    private static final String BUNDLES_CONFIG_DEFAULT = "META-INF/decanter.bundles.default";
-
-    public BundleContext create() throws Exception {
-        setSysPropDefault("felix.fileinstall.dir", "etc");
-        setSysPropDefault("felix.fileinstall.noInitialDelay", "true");
-        PojoServiceRegistryFactory srFactory = ServiceLoader
-            .load(PojoServiceRegistryFactory.class).iterator().next();
-        HashMap<String, Object> pojoSrConfig = new HashMap<>();
-        pojoSrConfig.put(BUNDLE_DESCRIPTORS, getBundles());
-        return srFactory.newPojoServiceRegistry(pojoSrConfig).getBundleContext();
-    }
-    
-    private void setSysPropDefault(String key, String defaultValue) {
-        if (System.getProperty(key) == null) {
-            System.setProperty(key, defaultValue);
-        }
-    }
-
-    List<BundleDescriptor> getBundles() throws URISyntaxException, IOException, Exception {
-        InputStream is = getStream(BUNDLES_CONFIG);
-        if (is == null) {
-            is = getStream(BUNDLES_CONFIG_DEFAULT);
-        }
-        List<String> bundleNames = readLines(is);
-        String filter = getBundleFilter(bundleNames);
-        FrameworkUtil.createFilter(filter);
-        List<BundleDescriptor> bundles = new ClasspathScanner().scanForBundles(filter);
-        assertAllPresent(bundles, new HashSet<String>(bundleNames));
-        //printNames(bundles);
-        return bundles;
-    }
-
-    private List<String> readLines(InputStream is) throws IOException {
-        try (
-            BufferedReader reader = new BufferedReader(new InputStreamReader(is, Charset.forName("utf-8")))
-            ) {
-            List<String> lines = new ArrayList<>();
-            String line;
-            while ((line = reader.readLine()) != null) {
-                lines.add(line);
-            }
-            return lines;
-        }
-        
-        
-    }
-
-    private void assertAllPresent(List<BundleDescriptor> bundles, Set<String> bundleNames) {
-        Set<String> bundlesPresent = new HashSet<>();
-        for (BundleDescriptor bundle : bundles) {
-            bundlesPresent.add(getSymbolicName(bundle)); 
-        }
-        for (String expected : bundleNames) {
-            if (!bundlesPresent.contains(expected)) {
-                throw new RuntimeException("Bundle " + expected + " was not loaded");
-            }
-        }
-    }
-
-    private InputStream getStream(String path) throws URISyntaxException {
-        return this.getClass().getClassLoader().getResourceAsStream(path);
-    }
-    
-    static String getBundleFilter(List<String> bundles) {
-        StringBuilder joined = new StringBuilder();
-        joined.append("(|(Bundle-SymbolicName=");
-        boolean first = true;
-        for (String bundle : bundles) {
-            if (!first) {
-                joined.append(")(Bundle-SymbolicName=");
-            }
-            first = false;
-            joined.append(bundle);
-        }
-        joined.append("))");
-        return joined.toString();
-    }
-
-    private String getSymbolicName(BundleDescriptor desc) {
-        return desc.getHeaders().get(Constants.BUNDLE_SYMBOLICNAME);
-    }
-}
diff --git a/spring-boot-starter-decanter/src/main/java/org/apache/karaf/decanter/boot/LogbackDecanterAppender.java b/spring-boot-starter-decanter/src/main/java/org/apache/karaf/decanter/boot/LogbackDecanterAppender.java
deleted file mode 100644
index b3f4836..0000000
--- a/spring-boot-starter-decanter/src/main/java/org/apache/karaf/decanter/boot/LogbackDecanterAppender.java
+++ /dev/null
@@ -1,110 +0,0 @@
-/**
- * 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.karaf.decanter.boot;
-
-import java.net.InetAddress;
-import java.util.HashMap;
-import java.util.Map;
-
-import org.osgi.service.event.Event;
-import org.osgi.service.event.EventAdmin;
-import org.slf4j.Logger;
-import org.slf4j.LoggerFactory;
-import org.slf4j.MDC;
-
-import ch.qos.logback.classic.spi.ILoggingEvent;
-import ch.qos.logback.core.AppenderBase;
-
-/**
- * Logback appender for usage in non OSGi environments like spring boot.
- * Forwards all log messages to an EventAdmin instance that needs to be injected.
- */
-public class LogbackDecanterAppender extends AppenderBase<ILoggingEvent> {
-    private static final String MDC_IN_LOG_APPENDER = "inLogAppender";
-    private final static String[] ignoredCategories = {"org.apache.karaf.decanter", "org.apache.kafka", "org.talend.decanter.connect"};
-    private final static Logger LOGGER = LoggerFactory.getLogger(LogbackDecanterAppender.class);
-
-    private static EventAdmin dispatcher;
-    
-    public static void setDispatcher(EventAdmin dispatcher) {
-        LogbackDecanterAppender.dispatcher = dispatcher;
-    }
-
-    protected void append(ILoggingEvent event) {
-        try {
-            if (MDC.get(MDC_IN_LOG_APPENDER) != null) {
-                // Avoid recursion
-                return;
-            }
-            MDC.put(MDC_IN_LOG_APPENDER, "true");
-            appendInternal(event);
-        } catch (Exception e) {
-            LOGGER.warn("Error while appending event", e);
-        } finally {
-            MDC.remove(MDC_IN_LOG_APPENDER);
-        }
-    }
-
-    private void appendInternal(ILoggingEvent event) throws Exception {
-        if (isIgnored(event.getLoggerName())) {
-            LOGGER.trace("{} logger is ignored by the log collector", event.getLoggerName());
-            return;
-        }
-
-        LOGGER.debug("Publishing log event to the appenders ...");
-
-        Map<String, Object> data = new HashMap<>();
-        data.put("type", "log");
-        String karafName = System.getProperty("karaf.name");
-        if (karafName != null) {
-            data.put("karafName", karafName);
-        }
-
-        data.put("hostAddress", InetAddress.getLocalHost().getHostAddress());
-        data.put("hostName", InetAddress.getLocalHost().getHostName());
-
-        data.put("timestamp", event.getTimeStamp());
-        data.put("loggerName", event.getLoggerName());
-        data.put("threadName", event.getThreadName());
-        data.put("message", event.getMessage());
-        data.put("level", event.getLevel().toString());
-        data.put("MDC", event.getMDCPropertyMap());
-        String loggerName = event.getLoggerName();
-        if (loggerName == null || loggerName.isEmpty()) {
-            loggerName = "default";
-        }
-        String topic = "decanter/collect/log/" + loggerName.replace(".", "/").replace(" ", "_").replace("{", "_").replace("}", "_").replace("$", "_");
-        if (dispatcher != null) {
-            dispatcher.postEvent(new Event(topic, data));
-        }
-    }
-
-    private boolean isIgnored(String loggerName) {
-        if (loggerName == null) {
-            return true;
-        }
-        for (String cat : ignoredCategories) {
-            if (loggerName.startsWith(cat)) {
-                return true;
-            }
-        }
-        return false;
-    }
-
-}
diff --git a/spring-boot-starter-decanter/src/main/resources/META-INF/decanter.bundles.default b/spring-boot-starter-decanter/src/main/resources/META-INF/decanter.bundles.default
deleted file mode 100644
index d9f5b9b..0000000
--- a/spring-boot-starter-decanter/src/main/resources/META-INF/decanter.bundles.default
+++ /dev/null
@@ -1,9 +0,0 @@
-org.apache.felix.connect
-org.apache.felix.scr
-org.apache.felix.eventadmin
-org.apache.felix.configadmin
-org.apache.felix.fileinstall
-org.apache.karaf.decanter.api
-org.apache.karaf.decanter.marshaller.json
-org.apache.karaf.decanter.appender.log
-org.apache.karaf.decanter.appender.kafka
diff --git a/spring-boot-starter-decanter/src/main/resources/META-INF/spring.factories b/spring-boot-starter-decanter/src/main/resources/META-INF/spring.factories
deleted file mode 100644
index 51d03ea..0000000
--- a/spring-boot-starter-decanter/src/main/resources/META-INF/spring.factories
+++ /dev/null
@@ -1,2 +0,0 @@
-org.springframework.boot.autoconfigure.EnableAutoConfiguration=org.apache.karaf.decanter.boot.DecanterAutoConfig
-
diff --git a/spring-boot-starter-decanter/src/test/java/org/apache/karaf/decanter/boot/DecanterRegistryFactoryTest.java b/spring-boot-starter-decanter/src/test/java/org/apache/karaf/decanter/boot/DecanterRegistryFactoryTest.java
deleted file mode 100644
index 6a3ba11..0000000
--- a/spring-boot-starter-decanter/src/test/java/org/apache/karaf/decanter/boot/DecanterRegistryFactoryTest.java
+++ /dev/null
@@ -1,72 +0,0 @@
-/**
- * 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.apache.karaf.decanter.boot;
-
-import java.util.Arrays;
-
-import org.junit.Assert;
-import org.junit.Test;
-import org.osgi.framework.BundleContext;
-import org.osgi.framework.FrameworkUtil;
-import org.osgi.framework.ServiceReference;
-import org.osgi.service.cm.Configuration;
-import org.osgi.service.cm.ConfigurationAdmin;
-
-public class DecanterRegistryFactoryTest {
-
-    @Test
-    public void testBundleFilter() throws Exception {
-        String bundleFilter = DecanterRegistryFactory.getBundleFilter(Arrays.asList("test", "test2"));
-        FrameworkUtil.createFilter(bundleFilter);
-    }
-
-    @Test
-    public void testCreate() throws Exception {
-        DecanterRegistryFactory factory = new DecanterRegistryFactory();
-        BundleContext context = factory.create();
-        checkConfigPresent(context);
-        context.getBundle().stop();
-    }
-
-    private void checkConfigPresent(BundleContext context) throws Exception {
-        ServiceReference<ConfigurationAdmin> sref = context.getServiceReference(ConfigurationAdmin.class);
-        ConfigurationAdmin configAdmin = context.getService(sref);
-        Configuration config = configAdmin.getConfiguration("test");
-        Assert.assertEquals("myvalue", config.getProperties().get("mykey"));
-        context.ungetService(sref);
-    }
-}
diff --git a/spring-boot-starter-decanter/src/test/resources/logback.xml b/spring-boot-starter-decanter/src/test/resources/logback.xml
deleted file mode 100644
index 737a992..0000000
--- a/spring-boot-starter-decanter/src/test/resources/logback.xml
+++ /dev/null
@@ -1,39 +0,0 @@
-<configuration>
-
-  <!--
-
-      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.
-  -->
-
-  <appender name="DECANTER" class="org.apache.karaf.decanter.boot.LogbackDecanterAppender">
-    <encoder>
-      <pattern>%-4relative [%thread] %-5level %logger{35} - %msg %n</pattern>
-    </encoder>
-  </appender>
-
-  <appender name="STDOUT" class="ch.qos.logback.core.ConsoleAppender">
-    <!-- encoders are assigned the type
-         ch.qos.logback.classic.encoder.PatternLayoutEncoder by default -->
-    <encoder>
-      <pattern>%-4relative [%thread] %-5level %logger{35} - %msg %n</pattern>
-    </encoder>
-  </appender>
-
-  <root level="INFO">
-    <appender-ref ref="STDOUT" />
-    <appender-ref ref="DECANTER" />
-  </root>
-</configuration>
\ No newline at end of file