You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@marmotta.apache.org by wi...@apache.org on 2016/05/03 09:35:59 UTC

marmotta git commit: MARMOTTA-637: removed ldclient-provider-freebase

Repository: marmotta
Updated Branches:
  refs/heads/develop e2b8148e9 -> 6013c4aba


MARMOTTA-637: removed ldclient-provider-freebase


Project: http://git-wip-us.apache.org/repos/asf/marmotta/repo
Commit: http://git-wip-us.apache.org/repos/asf/marmotta/commit/6013c4ab
Tree: http://git-wip-us.apache.org/repos/asf/marmotta/tree/6013c4ab
Diff: http://git-wip-us.apache.org/repos/asf/marmotta/diff/6013c4ab

Branch: refs/heads/develop
Commit: 6013c4abad2d7981b8619bea62c0739290d8dc8d
Parents: e2b8148
Author: Sergio Fern�ndez <wi...@apache.org>
Authored: Tue May 3 09:35:39 2016 +0200
Committer: Sergio Fern�ndez <wi...@apache.org>
Committed: Tue May 3 09:35:39 2016 +0200

----------------------------------------------------------------------
 .../ldclient/ldclient-provider-freebase/pom.xml |  78 -------
 .../endpoint/freebase/FreebaseEndpoint.java     |  39 ----
 .../provider/freebase/FreebaseProvider.java     | 227 -------------------
 ...ache.marmotta.ldclient.api.endpoint.Endpoint |   1 -
 ....marmotta.ldclient.api.provider.DataProvider |   1 -
 .../test/freebase/TestFreebaseProvider.java     | 142 ------------
 .../src/test/resources/logback.xml              |  27 ---
 .../ldclient/test/freebase/m.07zqbwz.sparql     |  26 ---
 .../ldclient/test/freebase/m.0h21k1c.sparql     |  26 ---
 .../ldclient/test/freebase/m.0nzm.sparql        |  27 ---
 .../ldclient/test/freebase/m.0wqhskn.sparql     |  27 ---
 libraries/ldclient/pom.xml                      |   1 -
 12 files changed, 622 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/marmotta/blob/6013c4ab/libraries/ldclient/ldclient-provider-freebase/pom.xml
----------------------------------------------------------------------
diff --git a/libraries/ldclient/ldclient-provider-freebase/pom.xml b/libraries/ldclient/ldclient-provider-freebase/pom.xml
deleted file mode 100644
index bdac844..0000000
--- a/libraries/ldclient/ldclient-provider-freebase/pom.xml
+++ /dev/null
@@ -1,78 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<!--
-   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.
--->
-<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">
-    <modelVersion>4.0.0</modelVersion>
-
-    <parent>
-        <groupId>org.apache.marmotta</groupId>
-        <artifactId>marmotta-parent</artifactId>
-        <version>3.4.0-SNAPSHOT</version>
-        <relativePath>../../../parent</relativePath>
-    </parent>
-
-    <artifactId>ldclient-provider-freebase</artifactId>
-    <name>LDClient Provider: Freebase RDF Access</name>
-    <description>Implements patched Linked Data access to Freebase data.</description>
-
-    <dependencies>
-        <dependency>
-            <groupId>org.apache.marmotta</groupId>
-            <artifactId>ldclient-api</artifactId>
-        </dependency>
-        <dependency>
-            <groupId>org.apache.marmotta</groupId>
-            <artifactId>ldclient-core</artifactId>
-        </dependency>
-        <dependency>
-            <groupId>org.openrdf.sesame</groupId>
-            <artifactId>sesame-rio-turtle</artifactId>
-        </dependency>
-        <dependency>
-            <groupId>org.apache.marmotta</groupId>
-            <artifactId>marmotta-commons</artifactId>
-        </dependency>
-        <dependency>
-            <groupId>org.apache.marmotta</groupId>
-            <artifactId>marmotta-model-vocabs</artifactId>
-        </dependency>
-
-        <dependency>
-            <groupId>junit</groupId>
-            <artifactId>junit</artifactId>
-            <scope>test</scope>
-        </dependency>
-        <dependency>
-            <groupId>org.apache.marmotta</groupId>
-            <artifactId>ldclient-core</artifactId>
-            <version>${project.version}</version>
-            <type>test-jar</type>
-            <scope>test</scope>
-        </dependency>
-        <dependency>
-            <groupId>commons-io</groupId>
-            <artifactId>commons-io</artifactId>
-        </dependency>
-        <dependency>
-            <groupId>ch.qos.logback</groupId>
-            <artifactId>logback-classic</artifactId>
-            <scope>test</scope>
-        </dependency>
-
-    </dependencies>
-
-</project>

http://git-wip-us.apache.org/repos/asf/marmotta/blob/6013c4ab/libraries/ldclient/ldclient-provider-freebase/src/main/java/org/apache/marmotta/ldclient/endpoint/freebase/FreebaseEndpoint.java
----------------------------------------------------------------------
diff --git a/libraries/ldclient/ldclient-provider-freebase/src/main/java/org/apache/marmotta/ldclient/endpoint/freebase/FreebaseEndpoint.java b/libraries/ldclient/ldclient-provider-freebase/src/main/java/org/apache/marmotta/ldclient/endpoint/freebase/FreebaseEndpoint.java
deleted file mode 100644
index b57e650..0000000
--- a/libraries/ldclient/ldclient-provider-freebase/src/main/java/org/apache/marmotta/ldclient/endpoint/freebase/FreebaseEndpoint.java
+++ /dev/null
@@ -1,39 +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.marmotta.ldclient.endpoint.freebase;
-
-import org.apache.marmotta.commons.http.ContentType;
-import org.apache.marmotta.ldclient.api.endpoint.Endpoint;
-import org.apache.marmotta.ldclient.provider.freebase.FreebaseProvider;
-
-/**
- * Endpoint for accessing RDF from Freebase.
- *
- * @author Sergio Fern�ndez
- */
-public class FreebaseEndpoint extends Endpoint {
-
-    public FreebaseEndpoint() {
-        super(FreebaseProvider.NAME, FreebaseProvider.NAME, FreebaseProvider.PATTERN, null, 86400L);
-        setPriority(PRIORITY_MEDIUM);
-        addContentType(new ContentType("text", "turtle", 1.0));
-        addContentType(new ContentType("text", "plain", 0.2));
-        addContentType(new ContentType("*", "*", 0.1));
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/marmotta/blob/6013c4ab/libraries/ldclient/ldclient-provider-freebase/src/main/java/org/apache/marmotta/ldclient/provider/freebase/FreebaseProvider.java
----------------------------------------------------------------------
diff --git a/libraries/ldclient/ldclient-provider-freebase/src/main/java/org/apache/marmotta/ldclient/provider/freebase/FreebaseProvider.java b/libraries/ldclient/ldclient-provider-freebase/src/main/java/org/apache/marmotta/ldclient/provider/freebase/FreebaseProvider.java
deleted file mode 100644
index 0cbdafc..0000000
--- a/libraries/ldclient/ldclient-provider-freebase/src/main/java/org/apache/marmotta/ldclient/provider/freebase/FreebaseProvider.java
+++ /dev/null
@@ -1,227 +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.marmotta.ldclient.provider.freebase;
-
-import com.google.common.base.Preconditions;
-
-import javolution.util.function.Predicate;
-import org.apache.commons.lang3.StringEscapeUtils;
-import org.apache.commons.lang3.StringUtils;
-import org.apache.marmotta.commons.sesame.model.ModelCommons;
-import org.apache.marmotta.ldclient.api.endpoint.Endpoint;
-import org.apache.marmotta.ldclient.exception.DataRetrievalException;
-import org.apache.marmotta.ldclient.services.provider.AbstractHttpProvider;
-import org.openrdf.model.Model;
-import org.openrdf.model.Statement;
-import org.openrdf.rio.RDFFormat;
-import org.openrdf.rio.RDFParseException;
-import org.openrdf.rio.Rio;
-
-import org.slf4j.Logger;
-import org.slf4j.LoggerFactory;
-
-import java.io.*;
-import java.net.URI;
-import java.util.Collections;
-import java.util.List;
-import java.util.regex.Matcher;
-import java.util.regex.Pattern;
-
-/**
- * Linked Data patched data provider to Freebase.
- * 
- * @author Sergio Fern�ndez
- */
-public class FreebaseProvider extends AbstractHttpProvider {
-
-    private static Logger log = LoggerFactory.getLogger(FreebaseProvider.class);
-
-    public static final String NAME = "Freebase";
-    public static final String PATTERN = "http(s?)://rdf\\.freebase\\.com/ns/.*";
-    public static final String API = "https://www.googleapis.com/freebase/v1/rdf/";
-    public static final RDFFormat DEFAULT_RDF_FORMAT = RDFFormat.TURTLE;
-    public static final String DEFAULT_ENCODING = "UTF-8";
-    private static final Pattern CHARSET_PATTERN = Pattern.compile("(?i)\\bcharset=\\s*\"?([^\\s;\"]*)");
-    private static final  Pattern FREEBASE_LITERAL_PATTERN = Pattern.compile("^\\s+([a-z]+:[a-z_]+(?:\\.+[a-z_]+)*)\\s+\"(.*)\"(@[a-z]+(\\-[a-z0-9]+)*)?(;|\\.)$");
-    private static final  Pattern FREEBASE_TRIPLE_PATTERN = Pattern.compile("^\\s+([a-z]+:[a-z_]+(?:\\.+[a-z_]+)*)\\s+(.*)(;|\\.)$");
-
-    /**
-     * Return the name of this data provider. To be used e.g. in the configuration and in log messages.
-     *
-     * @return provider name
-     */
-    @Override
-    public String getName() {
-        return NAME;
-    }
-
-    @Override
-    public String[] listMimeTypes() {
-        return new String[0];
-    }
-
-    /**
-     * Build the URL for calling the API to retrieve the data for the resource passed.
-     *
-     * @param uri resource uri
-     * @param endpoint endpoint
-     * @return api url
-     *
-     * @see <a href="https://developers.google.com/freebase/v1/rdf">Freebase RDF Lookup</a>
-     */
-    @Override
-    public List<String> buildRequestUrl(String uri, Endpoint endpoint) {
-        Preconditions.checkState(StringUtils.isNotBlank(uri));
-        String id = uri.substring(uri.lastIndexOf('/') + 1);
-        String url = API + id.replace('.', '/');
-        return Collections.singletonList(url);
-    }
-
-    @Override
-    public List<String> parseResponse(final String resourceUri, final String requestUrl, Model triples, InputStream in, final String contentType) throws DataRetrievalException {
-
-        RDFFormat format;
-        if (StringUtils.isNotBlank(contentType) && (contentType.contains("text/plain")||contentType.contains("text/turtle"))) {
-            format = DEFAULT_RDF_FORMAT;
-        } else {
-            format = Rio.getWriterFormatForMIMEType(contentType, DEFAULT_RDF_FORMAT);
-        }
-
-        try {
-            if (DEFAULT_RDF_FORMAT.equals(format)) {
-                String encoding;
-                Matcher m = CHARSET_PATTERN.matcher(contentType);
-                if (StringUtils.isNotBlank(contentType) && m.find()) {
-                    encoding = m.group(1).trim().toUpperCase();
-                } else {
-                    encoding = DEFAULT_ENCODING;
-                }
-                in = fix(in, encoding);
-            }
-            ModelCommons.add(triples, in, resourceUri, format, new Predicate<Statement>() {
-                @Override
-                public boolean test(Statement param) {
-                    return StringUtils.equals(param.getSubject().stringValue(), resourceUri);
-                }
-            });
-            return Collections.emptyList();
-        } catch (RDFParseException e) {
-            throw new DataRetrievalException("parse error while trying to parse Turtle from Freebase", e);
-        } catch (IOException e) {
-            throw new DataRetrievalException("I/O error while trying to read remote Turtle from Freebase", e);
-        }
-
-    }
-
-    /**
-     * Fixes Freebase deficiencies on Turtle serialization, doing
-     * some dirty things they may be semantically wrong.
-     *
-     * @param is stream with the raw data
-     * @return fixed stream
-     */
-    private InputStream fix(InputStream is, String encoding) throws IOException {
-        BufferedReader br = new BufferedReader(new InputStreamReader(is));
-        StringBuffer sb = new StringBuffer();
-        String line;
-        while ((line = br.readLine()) != null) {
-            Matcher literalMatcher = FREEBASE_LITERAL_PATTERN.matcher(line);
-            if (literalMatcher.matches()) {
-                //literal found
-                try {
-                    final String literal = literalMatcher.group(2);
-                    final String fixed = fixLiteral(literal);
-                    log.debug("literal: --{}--{}", literal, fixed);
-                    String triple = literalMatcher.group(1) + "    \"" + fixed + "\"";
-                    if (literalMatcher.group(3) != null) {
-                        triple += literalMatcher.group(3);
-                    }
-                    log.debug("new triple: {}", triple);
-                    sb.append("    " + triple + literalMatcher.group(5));
-                    sb.append(("\n"));
-                } catch (Exception e) {
-                    log.debug("Error fixing line, so triple ignored: {}", e.getMessage());
-                    log.trace("error on line: {}", line);
-                    warrantyClosing(sb, line);
-                }
-            } else {
-                Matcher tripleMatcher = FREEBASE_TRIPLE_PATTERN.matcher(line);
-                if (tripleMatcher.matches()) {
-                    String p = tripleMatcher.group(1);
-                    if (p.indexOf("..") >= 0) {
-                        log.debug("ignoring line due wrong property: {}", p);
-                        warrantyClosing(sb, line);
-                    } else {
-                        String o = tripleMatcher.group(2);
-                        if (o.charAt(0) == '<') {
-                            try {
-                                URI uri = URI.create(o.substring(1, o.length() - 1));
-                                sb.append("    " + p + "    <" + uri.toString() + ">" + tripleMatcher.group(3));
-                                sb.append("\n");
-                            } catch (RuntimeException e) {
-                                log.debug("Object uri not valid: {}", o.substring(1, o.length() - 1));
-                                warrantyClosing(sb, line);
-                            }
-                        } else {
-                            if (o.contains("$")) {
-                                o = o.replaceAll(Pattern.quote("$"), Matcher.quoteReplacement("\\$"));
-                            } else if (o.contains("\\u")) {
-                                o = StringEscapeUtils.unescapeJava(o);
-                            } else if (o.contains("\\x")) {
-                                o = org.apache.marmotta.commons.util.StringUtils.fixLatin1(o);
-                            }
-                            sb.append("    " + p + "    " + o + tripleMatcher.group(3));
-                            sb.append("\n");
-                        }
-                    }
-                } else {
-                    log.debug("default fallback");
-                    sb.append(line);
-                    sb.append("\n");
-                }
-            }
-        }
-        //System.out.println(sb.toString());
-        return new ByteArrayInputStream(sb.toString().getBytes());
-    }
-
-    private void warrantyClosing(StringBuffer sb, String line) {
-        if (line.endsWith(".")) {
-            sb.replace(sb.length()-2, sb.length(), ".\n");
-        }
-    }
-
-    private String fixLiteral(String literal) throws UnsupportedEncodingException {
-
-        //non-escaped quotes
-        literal = literal.replaceAll("\"", "'");
-
-        //wrong charset
-        if (literal.contains("\\x")) {
-            literal = org.apache.marmotta.commons.util.StringUtils.fixLatin1(literal);
-        }
-
-        //wrong unicode encoding
-        if (literal.contains("\\u")) {
-            literal = StringEscapeUtils.unescapeJava(literal);
-        }
-
-        return literal;
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/marmotta/blob/6013c4ab/libraries/ldclient/ldclient-provider-freebase/src/main/resources/META-INF/services/org.apache.marmotta.ldclient.api.endpoint.Endpoint
----------------------------------------------------------------------
diff --git a/libraries/ldclient/ldclient-provider-freebase/src/main/resources/META-INF/services/org.apache.marmotta.ldclient.api.endpoint.Endpoint b/libraries/ldclient/ldclient-provider-freebase/src/main/resources/META-INF/services/org.apache.marmotta.ldclient.api.endpoint.Endpoint
deleted file mode 100644
index fe6aa7e..0000000
--- a/libraries/ldclient/ldclient-provider-freebase/src/main/resources/META-INF/services/org.apache.marmotta.ldclient.api.endpoint.Endpoint
+++ /dev/null
@@ -1 +0,0 @@
-org.apache.marmotta.ldclient.endpoint.freebase.FreebaseEndpoint
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/marmotta/blob/6013c4ab/libraries/ldclient/ldclient-provider-freebase/src/main/resources/META-INF/services/org.apache.marmotta.ldclient.api.provider.DataProvider
----------------------------------------------------------------------
diff --git a/libraries/ldclient/ldclient-provider-freebase/src/main/resources/META-INF/services/org.apache.marmotta.ldclient.api.provider.DataProvider b/libraries/ldclient/ldclient-provider-freebase/src/main/resources/META-INF/services/org.apache.marmotta.ldclient.api.provider.DataProvider
deleted file mode 100644
index 3d396dc..0000000
--- a/libraries/ldclient/ldclient-provider-freebase/src/main/resources/META-INF/services/org.apache.marmotta.ldclient.api.provider.DataProvider
+++ /dev/null
@@ -1 +0,0 @@
-org.apache.marmotta.ldclient.provider.freebase.FreebaseProvider
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/marmotta/blob/6013c4ab/libraries/ldclient/ldclient-provider-freebase/src/test/java/org/apache/marmotta/ldclient/test/freebase/TestFreebaseProvider.java
----------------------------------------------------------------------
diff --git a/libraries/ldclient/ldclient-provider-freebase/src/test/java/org/apache/marmotta/ldclient/test/freebase/TestFreebaseProvider.java b/libraries/ldclient/ldclient-provider-freebase/src/test/java/org/apache/marmotta/ldclient/test/freebase/TestFreebaseProvider.java
deleted file mode 100644
index 16d45db..0000000
--- a/libraries/ldclient/ldclient-provider-freebase/src/test/java/org/apache/marmotta/ldclient/test/freebase/TestFreebaseProvider.java
+++ /dev/null
@@ -1,142 +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.marmotta.ldclient.test.freebase;
-
-import org.apache.marmotta.ldclient.exception.DataRetrievalException;
-import org.apache.marmotta.ldclient.test.provider.ProviderTestBase;
-import org.junit.Assume;
-import org.junit.Ignore;
-import org.junit.Test;
-import org.openrdf.rio.RDFParseException;
-
-import java.io.IOException;
-
-/**
- * Some tests over random data to Freebase to warranty that the provider
- * fixes some common deficiencies in the original data.
- *
- * @author Sergio Fern�ndez
- */
-public class TestFreebaseProvider extends ProviderTestBase {
-
-    private static final String ASF = "http://rdf.freebase.com/ns/m.0nzm";
-    private static final String MARMOTTA = "http://rdf.freebase.com/ns/m.0wqhskn";
-    private static final String SERGIO = "http://rdf.freebase.com/ns/m.07zqbwz";
-    private static final String WAS = "http://rdf.freebase.com/ns/m.0h21k1c";
-
-    @Override
-    protected void testResource(String uri) throws Exception {
-        try {
-            super.testResource(uri);
-        } catch (final Exception e) {
-            // Unfortunately, freebase often serves corrupt/invalid/unparsable data, e.g. non-escaped quotes in literals
-            Assume.assumeFalse("Freebase provided invalid RDF data for <" + uri + ">", checkCauseStack(e, DataRetrievalException.class, IOException.class, DataRetrievalException.class, RDFParseException.class));
-            throw e;
-        }
-    }
-
-    @Override
-    protected void testResource(String uri, String sparqlFile) throws Exception {
-        try {
-            super.testResource(uri, sparqlFile);
-        } catch (final Exception e) {
-            // Unfortunately, freebase often serves corrupt/invalid/unparsable data, e.g. non-escaped quotes in literals
-            Assume.assumeFalse("Freebase provided invalid RDF data for <" + uri + ">", checkCauseStack(e, DataRetrievalException.class, IOException.class, DataRetrievalException.class, RDFParseException.class));
-            throw e;
-        }
-    }
-
-    /**
-     * Tests accessing ASF's page from Freebase.
-     *
-     * @throws Exception
-     *
-     */
-    @Test
-    @Ignore
-    public void testASF() throws Exception {
-        testResource(ASF, "m.0nzm.sparql");
-    }
-
-    /**
-     * Tests accessing Marmotta's page from Freebase.
-     *
-     * @throws Exception
-     *
-     */
-    @Test
-    public void testMarmotta() throws Exception {
-        testResource(MARMOTTA, "m.0wqhskn.sparql");
-    }
-
-    /**
-     * Tests accessing Sergio's profile from Freebase.
-     *
-     * @throws Exception
-     *
-     */
-    @Test
-    public void testSergio() throws Exception {
-        testResource(SERGIO, "m.07zqbwz.sparql");
-    }
-
-    /**
-     * Tests accessing WAS's page from Freebase.
-     *
-     * @throws Exception
-     *
-     */
-    @Test
-    public void testWAS() throws Exception {
-        testResource(WAS, "m.0h21k1c.sparql");
-    }
-
-    @Test
-    public void test_m_0b1t1() throws Exception {
-        testResource("http://rdf.freebase.com/ns/m.0b1t1");
-    }
-
-    @Test
-    public void test_m_04jpl() throws Exception {
-        testResource("http://rdf.freebase.com/ns/m.04jpl");
-    }
-
-    @Test
-    public void test_m_036wy() throws Exception {
-        testResource("http://rdf.freebase.com/ns/m.036wy");
-    }
-
-    @Test
-    public void test_m_01d0fp() throws Exception {
-        testResource("http://rdf.freebase.com/ns/m.01d0fp");
-    }
-
-
-    @SafeVarargs
-    protected static boolean checkCauseStack(Throwable t, Class<? extends Throwable>... stack) {
-        return checkCauseStack(t, 0, stack);
-    }
-
-    @SafeVarargs
-    private static boolean checkCauseStack(Throwable t, int i, Class<? extends Throwable>... stack) {
-        return i >= stack.length || stack[i].isInstance(t) && checkCauseStack(t.getCause(), i + 1, stack);
-    }
-
-
-
-}

http://git-wip-us.apache.org/repos/asf/marmotta/blob/6013c4ab/libraries/ldclient/ldclient-provider-freebase/src/test/resources/logback.xml
----------------------------------------------------------------------
diff --git a/libraries/ldclient/ldclient-provider-freebase/src/test/resources/logback.xml b/libraries/ldclient/ldclient-provider-freebase/src/test/resources/logback.xml
deleted file mode 100644
index ea28135..0000000
--- a/libraries/ldclient/ldclient-provider-freebase/src/test/resources/logback.xml
+++ /dev/null
@@ -1,27 +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.
-  -->
-
-<configuration>
-    <appender name="CONSOLE" class="ch.qos.logback.core.ConsoleAppender">
-        <encoder>
-            <pattern>%d{HH:mm:ss.SSS} %level %logger{15} - %m%n</pattern>
-        </encoder>
-    </appender>
-    <root level="${root-level:-INFO}">
-        <appender-ref ref="CONSOLE"/>
-    </root>
-</configuration>

http://git-wip-us.apache.org/repos/asf/marmotta/blob/6013c4ab/libraries/ldclient/ldclient-provider-freebase/src/test/resources/org/apache/marmotta/ldclient/test/freebase/m.07zqbwz.sparql
----------------------------------------------------------------------
diff --git a/libraries/ldclient/ldclient-provider-freebase/src/test/resources/org/apache/marmotta/ldclient/test/freebase/m.07zqbwz.sparql b/libraries/ldclient/ldclient-provider-freebase/src/test/resources/org/apache/marmotta/ldclient/test/freebase/m.07zqbwz.sparql
deleted file mode 100644
index 8f3f336..0000000
--- a/libraries/ldclient/ldclient-provider-freebase/src/test/resources/org/apache/marmotta/ldclient/test/freebase/m.07zqbwz.sparql
+++ /dev/null
@@ -1,26 +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.
-#
-
-PREFIX ns: <http://rdf.freebase.com/ns/>
-PREFIX rdfs: <http://www.w3.org/2000/01/rdf-schema#>
-
-ASK {
-   ns:m.07zqbwz ns:rdf:type ns:people.person ;
-        rdfs:label "Sergio Fern�ndez"@en ;
-        ns:common.topic.official_website <http://www.wikier.org>  .
-}

http://git-wip-us.apache.org/repos/asf/marmotta/blob/6013c4ab/libraries/ldclient/ldclient-provider-freebase/src/test/resources/org/apache/marmotta/ldclient/test/freebase/m.0h21k1c.sparql
----------------------------------------------------------------------
diff --git a/libraries/ldclient/ldclient-provider-freebase/src/test/resources/org/apache/marmotta/ldclient/test/freebase/m.0h21k1c.sparql b/libraries/ldclient/ldclient-provider-freebase/src/test/resources/org/apache/marmotta/ldclient/test/freebase/m.0h21k1c.sparql
deleted file mode 100644
index 351d38a..0000000
--- a/libraries/ldclient/ldclient-provider-freebase/src/test/resources/org/apache/marmotta/ldclient/test/freebase/m.0h21k1c.sparql
+++ /dev/null
@@ -1,26 +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.
-#
-
-PREFIX ns: <http://rdf.freebase.com/ns/>
-PREFIX rdfs: <http://www.w3.org/2000/01/rdf-schema#>
-
-ASK {
-   ns:m.0h21k1c ns:rdf:type ns:music.musical_group ;
-        rdfs:label "We Are Standard"@en ;
-        ns:common.topic.official_website <http://www.wearestandard.net/> .
-}

http://git-wip-us.apache.org/repos/asf/marmotta/blob/6013c4ab/libraries/ldclient/ldclient-provider-freebase/src/test/resources/org/apache/marmotta/ldclient/test/freebase/m.0nzm.sparql
----------------------------------------------------------------------
diff --git a/libraries/ldclient/ldclient-provider-freebase/src/test/resources/org/apache/marmotta/ldclient/test/freebase/m.0nzm.sparql b/libraries/ldclient/ldclient-provider-freebase/src/test/resources/org/apache/marmotta/ldclient/test/freebase/m.0nzm.sparql
deleted file mode 100644
index e09f8f2..0000000
--- a/libraries/ldclient/ldclient-provider-freebase/src/test/resources/org/apache/marmotta/ldclient/test/freebase/m.0nzm.sparql
+++ /dev/null
@@ -1,27 +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.
-#
-
-PREFIX ns: <http://rdf.freebase.com/ns/>
-PREFIX rdfs: <http://www.w3.org/2000/01/rdf-schema#>
-
-ASK {
-   ns:m.0nzm ns:rdf:type ns:business.brand ;
-        ns:common.topic.alias "ASF"@en;
-        rdfs:label "Apache Software Foundation"@en ;
-        ns:common.topic.official_website <http://www.apache.org/> .
-}

http://git-wip-us.apache.org/repos/asf/marmotta/blob/6013c4ab/libraries/ldclient/ldclient-provider-freebase/src/test/resources/org/apache/marmotta/ldclient/test/freebase/m.0wqhskn.sparql
----------------------------------------------------------------------
diff --git a/libraries/ldclient/ldclient-provider-freebase/src/test/resources/org/apache/marmotta/ldclient/test/freebase/m.0wqhskn.sparql b/libraries/ldclient/ldclient-provider-freebase/src/test/resources/org/apache/marmotta/ldclient/test/freebase/m.0wqhskn.sparql
deleted file mode 100644
index 8afd1b8..0000000
--- a/libraries/ldclient/ldclient-provider-freebase/src/test/resources/org/apache/marmotta/ldclient/test/freebase/m.0wqhskn.sparql
+++ /dev/null
@@ -1,27 +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.
-#
-
-PREFIX ns: <http://rdf.freebase.com/ns/>
-PREFIX rdfs: <http://www.w3.org/2000/01/rdf-schema#>
-
-ASK {
-   ns:m.0wqhskn ns:rdf:type ns:computer.software ;
-        rdfs:label "Apache Marmotta"@en ;
-        ns:common.topic.official_website <http://marmotta.apache.org> ;
-        ns:common.topic.topic_equivalent_webpage <http://en.wikipedia.org/wiki/Apache_Marmotta> .
-}

http://git-wip-us.apache.org/repos/asf/marmotta/blob/6013c4ab/libraries/ldclient/pom.xml
----------------------------------------------------------------------
diff --git a/libraries/ldclient/pom.xml b/libraries/ldclient/pom.xml
index fc8a2ab..79f1c33 100644
--- a/libraries/ldclient/pom.xml
+++ b/libraries/ldclient/pom.xml
@@ -105,7 +105,6 @@
         <module>ldclient-provider-html</module>
         <module>ldclient-provider-ldap</module>
         <module>ldclient-provider-mediawiki</module>
-        <module>ldclient-provider-freebase</module>
         <module>ldclient-provider-phpbb</module>
         <module>ldclient-provider-facebook</module>
         <module>ldclient-provider-youtube</module>