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 2013/02/20 08:42:39 UTC

[43/45] properly ignored files

http://git-wip-us.apache.org/repos/asf/incubator-marmotta/blob/5486b79f/platform/marmotta-core/target/classes/META-INF/ehcache.xml
----------------------------------------------------------------------
diff --git a/platform/marmotta-core/target/classes/META-INF/ehcache.xml b/platform/marmotta-core/target/classes/META-INF/ehcache.xml
deleted file mode 100644
index 1cb33e4..0000000
--- a/platform/marmotta-core/target/classes/META-INF/ehcache.xml
+++ /dev/null
@@ -1,496 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<!--
-
-    Copyright (C) 2013 Salzburg Research.
-
-    Licensed 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.
-
--->
-<!--
-CacheManager Configuration
-==========================
-An ehcache.xml corresponds to a single CacheManager.
-
-See instructions below or the ehcache schema (ehcache.xsd) on how to configure.
-
-System property tokens can be specified in this file which are replaced when the configuration
-is loaded. For example multicastGroupPort=${multicastGroupPort} can be replaced with the
-System property either from an environment variable or a system property specified with a
-command line switch such as -DmulticastGroupPort=4446.
-
-The attributes of <ehcache> are:
-* name - an optional name for the CacheManager.  The name is optional and primarily used 
-for documentation or to distinguish Terracotta clustered cache state.  With Terracotta 
-clustered caches, a combination of CacheManager name and cache name uniquely identify a 
-particular cache store in the Terracotta clustered memory.
-* updateCheck - an optional boolean flag specifying whether this CacheManager should check
-for new versions of Ehcache over the Internet.  If not specified, updateCheck="true".
-* monitoring - an optional setting that determines whether the CacheManager should 
-automatically register the SampledCacheMBean with the system MBean server.  Currently,
-this monitoring is only useful when using Terracotta and thus the "autodetect" value 
-will detect the presence of Terracotta and register the MBean.  Other allowed values 
-are "on" and "off".  The default is "autodetect".
--->    
-<ehcache xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:noNamespaceSchemaLocation="ehcache.xsd">
-
-    <!-- 
-    DiskStore configuration
-    =======================
-
-    The diskStore element is optional. To turn off disk store path creation, comment out the diskStore
-    element below.
-
-    Configure it if you have overflowToDisk or diskPersistent enabled for any cache.
-
-    If it is not configured, and a cache is created which requires a disk store, a warning will be
-     issued and java.io.tmpdir will automatically be used.
-
-    diskStore has only one attribute - "path". It is the path to the directory where
-    .data and .index files will be created.
-
-    If the path is one of the following Java System Property it is replaced by its value in the
-    running VM. For backward compatibility these are not specified without being enclosed in the ${token}
-    replacement syntax.
-
-    The following properties are translated:
-    * user.home - KiWiUser's home directory
-    * user.dir - KiWiUser's current working directory
-    * java.io.tmpdir - Default temp file path
-    * ehcache.disk.store.dir - A system property you would normally specify on the command line
-      e.g. java -Dehcache.disk.store.dir=/u01/myapp/diskdir ...
-
-    Subdirectories can be specified below the property e.g. java.io.tmpdir/one
-
-    -->
-    <diskStore path="java.io.tmpdir/lmf-cache"/>
-
-   <!--
-    Cachemanagereventlistener
-    =========================
-    Specifies a CacheManagerEventListenerFactory which is notified when Caches are added
-    or removed from the CacheManager.
-
-    The attributes of CacheManagerEventListenerFactory are:
-    * class - a fully qualified factory class name
-    * properties - comma separated properties having meaning only to the factory.
-
-    Sets the fully qualified class name to be registered as the CacheManager event listener.
-
-    The events include:
-    * adding a Cache
-    * removing a Cache
-
-    Callbacks to listener methods are synchronous and unsynchronized. It is the responsibility
-    of the implementer to safely handle the potential performance and thread safety issues
-    depending on what their listener is doing.
-
-    If no class is specified, no listener is created. There is no default.
-    -->
-    <cacheManagerEventListenerFactory class="" properties=""/>
-
-
-    <!--
-    CacheManagerPeerProvider
-    ========================
-    (For distributed operation)
-
-    Specifies a CacheManagerPeerProviderFactory which will be used to create a
-    CacheManagerPeerProvider, which discovers other CacheManagers in the cluster.
-
-    One or more providers can be configured. The first one in the ehcache.xml is the default, which is used
-    for replication and bootstrapping.
-
-    The attributes of cacheManagerPeerProviderFactory are:
-    * class - a fully qualified factory class name
-    * properties - comma separated properties having meaning only to the factory.
-
-    Providers are available for RMI, JGroups and JMS as shown following.
-
-    RMICacheManagerPeerProvider
-    +++++++++++++++++++++++++++
-
-    Ehcache comes with a built-in RMI-based distribution system with two means of discovery of
-    CacheManager peers participating in the cluster:
-    * automatic, using a multicast group. This one automatically discovers peers and detects
-      changes such as peers entering and leaving the group
-    * manual, using manual rmiURL configuration. A hardcoded list of peers is provided at
-      configuration time.
-
-    Configuring Automatic Discovery:
-    Automatic discovery is configured as per the following example:
-    <cacheManagerPeerProviderFactory
-                        class="net.sf.ehcache.distribution.RMICacheManagerPeerProviderFactory"
-                        properties="hostName=fully_qualified_hostname_or_ip,
-                                    peerDiscovery=automatic, multicastGroupAddress=230.0.0.1,
-                                    multicastGroupPort=4446, timeToLive=32"/>
-
-    Valid properties are:
-    * peerDiscovery (mandatory) - specify "automatic"
-    * multicastGroupAddress (mandatory) - specify a valid multicast group address
-    * multicastGroupPort (mandatory) - specify a dedicated port for the multicast heartbeat
-      traffic
-    * timeToLive - specify a value between 0 and 255 which determines how far the packets will
-      propagate.
-
-      By convention, the restrictions are:
-      0   - the same host
-      1   - the same subnet
-      32  - the same site
-      64  - the same region
-      128 - the same continent
-      255 - unrestricted
-
-     * hostName - the hostname or IP of the interface to be used for sending and receiving multicast packets
-       (relevant to mulithomed hosts only)
-
-    Configuring Manual Discovery:
-    Manual discovery requires a unique configuration per host. It is contains a list of rmiURLs for the peers, other
-    than itself. So, if we have server1, server2 and server3 the configuration will be:
-
-    In server1's configuration:
-    <cacheManagerPeerProviderFactory class=
-                          "net.sf.ehcache.distribution.RMICacheManagerPeerProviderFactory"
-                          properties="peerDiscovery=manual,
-                          rmiUrls=//server2:40000/sampleCache1|//server3:40000/sampleCache1
-                          | //server2:40000/sampleCache2|//server3:40000/sampleCache2"
-                          propertySeparator="," />
-
-    In server2's configuration:
-    <cacheManagerPeerProviderFactory class=
-                          "net.sf.ehcache.distribution.RMICacheManagerPeerProviderFactory"
-                          properties="peerDiscovery=manual,
-                          rmiUrls=//server1:40000/sampleCache1|//server3:40000/sampleCache1
-                          | //server1:40000/sampleCache2|//server3:40000/sampleCache2"
-                          propertySeparator="," />
-
-    In server3's configuration:
-    <cacheManagerPeerProviderFactory class=
-                          "net.sf.ehcache.distribution.RMICacheManagerPeerProviderFactory"
-                          properties="peerDiscovery=manual,
-                          rmiUrls=//server1:40000/sampleCache1|//server2:40000/sampleCache1
-                          | //server1:40000/sampleCache2|//server2:40000/sampleCache2"
-                          propertySeparator="," />
-
-
-    Valid properties are:
-    * peerDiscovery (mandatory) - specify "manual"
-    * rmiUrls (mandatory) - specify a pipe separated list of rmiUrls, in the form
-                            //hostname:port
-    * hostname (optional) - the hostname is the hostname of the remote CacheManager peer. The port is the listening
-      port of the RMICacheManagerPeerListener of the remote CacheManager peer.
-    
-    JGroupsCacheManagerPeerProvider
-    +++++++++++++++++++++++++++++++
-    <cacheManagerPeerProviderFactory class="net.sf.ehcache.distribution.jgroups.JGroupsCacheManagerPeerProviderFactory"
-                                     properties="connect=UDP(mcast_addr=231.12.21.132;mcast_port=45566;ip_ttl=32;
-                                     mcast_send_buf_size=150000;mcast_recv_buf_size=80000):
-                                     PING(timeout=2000;num_initial_members=6):
-                                     MERGE2(min_interval=5000;max_interval=10000):
-                                     FD_SOCK:VERIFY_SUSPECT(timeout=1500):
-                                     pbcast.NAKACK(gc_lag=10;retransmit_timeout=3000):
-                                     UNICAST(timeout=5000):
-                                     pbcast.STABLE(desired_avg_gossip=20000):
-                                     FRAG:
-                                     pbcast.GMS(join_timeout=5000;join_retry_timeout=2000;shun=false;print_local_addr=false)"
-                                     propertySeparator="::"
-            />
-     The only property necessary is the connect String used by jgroups to configure itself. Refer to the Jgroups documentation for explanation
-     of all the protocols. The example above uses UDP multicast. If the connect property is not specified the default JGroups connection will be
-     used.       
-
-
-    JMSCacheManagerPeerProviderFactory
-    ++++++++++++++++++++++++++++++++++
-    <cacheManagerPeerProviderFactory
-            class="net.sf.ehcache.distribution.jms.JMSCacheManagerPeerProviderFactory"
-            properties="..."
-            propertySeparator=","
-            />
-
-    The JMS PeerProviderFactory uses JNDI to maintain message queue independence. Refer to the manual for full configuration
-    examples using ActiveMQ and Open Message Queue.
-
-    Valid properties are:
-    * initialContextFactoryName (mandatory) - the name of the factory used to create the message queue initial context.
-    * providerURL (mandatory) - the JNDI configuration information for the service provider to use.
-    * topicConnectionFactoryBindingName (mandatory) - the JNDI binding name for the TopicConnectionFactory
-    * topicBindingName (mandatory) - the JNDI binding name for the topic name
-    * getQueueBindingName (mandatory only if using jmsCacheLoader) - the JNDI binding name for the queue name
-    * securityPrincipalName - the JNDI java.naming.security.principal
-    * securityCredentials - the JNDI java.naming.security.credentials
-    * urlPkgPrefixes - the JNDI java.naming.factory.url.pkgs
-    * userName - the user name to use when creating the TopicConnection to the Message Queue
-    * password - the password to use when creating the TopicConnection to the Message Queue
-    * acknowledgementMode - the JMS Acknowledgement mode for both publisher and subscriber. The available choices are
-                            AUTO_ACKNOWLEDGE, DUPS_OK_ACKNOWLEDGE and SESSION_TRANSACTED. The default is AUTO_ACKNOWLEDGE.
-    -->
-<!--    <cacheManagerPeerProviderFactory-->
-<!--            class="net.sf.ehcache.distribution.RMICacheManagerPeerProviderFactory"-->
-<!--            properties="peerDiscovery=automatic,-->
-<!--                        multicastGroupAddress=230.0.0.1,-->
-<!--                        multicastGroupPort=4446, timeToLive=1"-->
-<!--            propertySeparator=","-->
-<!--            />-->
-
-
-    <!--
-    CacheManagerPeerListener
-    ========================
-    (Enable for distributed operation)
-
-    Specifies a CacheManagerPeerListenerFactory which will be used to create a
-    CacheManagerPeerListener, which listens for messages from cache replicators participating in the cluster.
-
-    The attributes of cacheManagerPeerListenerFactory are:
-    class - a fully qualified factory class name
-    properties - comma separated properties having meaning only to the factory.
-
-    Ehcache comes with a built-in RMI-based distribution system. The listener component is
-    RMICacheManagerPeerListener which is configured using
-    RMICacheManagerPeerListenerFactory. It is configured as per the following example:
-
-    <cacheManagerPeerListenerFactory
-        class="net.sf.ehcache.distribution.RMICacheManagerPeerListenerFactory"
-        properties="hostName=fully_qualified_hostname_or_ip,
-                    port=40001,
-                    remoteObjectPort=40002,
-                    socketTimeoutMillis=120000"
-                    propertySeparator="," />
-
-    All properties are optional. They are:
-    * hostName - the hostName of the host the listener is running on. Specify
-      where the host is multihomed and you want to control the interface over which cluster
-      messages are received. Defaults to the host name of the default interface if not
-      specified.
-    * port - the port the RMI Registry listener listens on. This defaults to a free port if not specified.
-    * remoteObjectPort - the port number on which the remote objects bound in the registry receive calls.
-                         This defaults to a free port if not specified.
-    * socketTimeoutMillis - the number of ms client sockets will stay open when sending
-      messages to the listener. This should be long enough for the slowest message.
-      If not specified it defaults to 120000ms.
-
-    -->
-<!--    <cacheManagerPeerListenerFactory-->
-<!--            class="net.sf.ehcache.distribution.RMICacheManagerPeerListenerFactory"/>-->
-
-    <!-- Cache configuration.
-
-    The following attributes are required.
-
-    name:
-    Sets the name of the cache. This is used to identify the cache. It must be unique.
-
-    maxElementsInMemory:
-    Sets the maximum number of objects that will be created in memory
-
-        maxElementsOnDisk:
-    Sets the maximum number of objects that will be maintained in the DiskStore
-        The default value is zero, meaning unlimited.
-
-    eternal:
-    Sets whether elements are eternal. If eternal,  timeouts are ignored and the
-    element is never expired.
-
-    overflowToDisk:
-    Sets whether elements can overflow to disk when the memory store
-    has reached the maxInMemory limit.
-
-    The following attributes are optional.
-
-    timeToIdleSeconds:
-    Sets the time to idle for an element before it expires.
-    i.e. The maximum amount of time between accesses before an element expires
-    Is only used if the element is not eternal.
-    Optional attribute. A value of 0 means that an Element can idle for infinity.
-    The default value is 0.
-
-    timeToLiveSeconds:
-    Sets the time to live for an element before it expires.
-    i.e. The maximum time between creation time and when an element expires.
-    Is only used if the element is not eternal.
-    Optional attribute. A value of 0 means that and Element can live for infinity.
-    The default value is 0.
-
-    diskPersistent:
-    Whether the disk store persists between restarts of the Virtual Machine.
-    The default value is false.
-
-    diskExpiryThreadIntervalSeconds:
-    The number of seconds between runs of the disk expiry thread. The default value
-    is 120 seconds.
-
-    memoryStoreEvictionPolicy:
-    Policy would be enforced upon reaching the maxElementsInMemory limit. Default
-    policy is Least Recently Used (specified as LRU). Other policies available -
-    First In First Out (specified as FIFO) and Less Frequently Used
-    (specified as LFU)
-
-    -->
-
-    <!--
-    Mandatory Default Cache configuration. These settings will be applied to caches
-    created programmtically using CacheManager.add(String cacheName)
-    -->
-    <defaultCache
-            maxElementsInMemory="20000"
-            eternal="true"
-            overflowToDisk="false"
-            memoryStoreEvictionPolicy="LRU"
-            />
-
-    <cache name="kiwi.core.model.rdf.KiWiNode"
-           statistics="true"
-           maxElementsInMemory="10000"
-           eternal="true"
-           overflowToDisk="false"
-           memoryStoreEvictionPolicy="LRU"/>
-
-    <cache name="at.newmedialab.lmf.versioning.model.Version"
-           statistics="true"
-           maxElementsInMemory="10000"
-           eternal="true"
-           overflowToDisk="false"
-           memoryStoreEvictionPolicy="LRU"/>
-
-
-    <cache name="kiwi.core.model.rdf.KiWiNamespace"
-           statistics="true"
-           maxElementsInMemory="100"
-           eternal="true"
-           overflowToDisk="false"
-           memoryStoreEvictionPolicy="LRU"/>
-
-    <cache name="kiwi.core.model.user.KiWiGroup"
-           statistics="true"
-           maxElementsInMemory="100"
-           eternal="true"
-           overflowToDisk="false"
-           memoryStoreEvictionPolicy="LRU"/>
-
-    <cache name="kiwi.core.model.user.KiWiUser"
-           statistics="true"
-           maxElementsInMemory="100"
-           eternal="true"
-           overflowToDisk="false"
-           memoryStoreEvictionPolicy="LRU"/>
-
-
-    <cache name="kiwi.core.model.rdf.KiWiTriple"
-           statistics="true"
-           maxElementsInMemory="100000"
-           eternal="true"
-           overflowToDisk="false"
-           memoryStoreEvictionPolicy="LRU"/>
-
-    <cache name="kiwi.reasoner.model.Pattern"
-           statistics="true"
-           maxElementsInMemory="1000"
-           eternal="true"
-           overflowToDisk="false"
-           memoryStoreEvictionPolicy="LRU"/>
-
-    <cache name="kiwi.reasoner.model.Field"
-           statistics="true"
-           maxElementsInMemory="10000"
-           eternal="true"
-           overflowToDisk="false"
-           memoryStoreEvictionPolicy="LRU"/>
-
-    <cache name="org.hibernate.cache.StandardQueryCache"
-           statistics="true"
-           maxElementsInMemory="10000"
-           eternal="true"
-           overflowToDisk="false"
-           memoryStoreEvictionPolicy="LRU"/>
-
-    <cache name="org.hibernate.cache.UpdateTimestampsCache"
-           statistics="true"
-           maxElementsInMemory="10000"
-           eternal="true"
-           overflowToDisk="false"/>
-
-    <!-- the cache used for triple queries by KiWi -->
-    <!-- the cache used for triple queries by KiWi -->
-    <cache name="uri-node-cache"
-           statistics="true"
-           maxElementsInMemory="100000"
-           timeToIdleSeconds="3600"
-           overflowToDisk="false"/>
-    <cache name="anon-node-cache"
-           statistics="true"
-           maxElementsInMemory="10000"
-           timeToIdleSeconds="3600"
-           overflowToDisk="false"/>
-    <cache name="literal-cache"
-           statistics="true"
-           maxElementsInMemory="10000"
-           timeToIdleSeconds="3600"
-           overflowToDisk="false"/>
-
-    <cache name="triple-cache"
-           statistics="true"
-           maxElementsInMemory="100000"
-           memoryStoreEvictionPolicy="LRU"
-           overflowToDisk="false"/>
-
-    <cache name="namespace-prefix-cache"
-           statistics="true"
-           maxElementsInMemory="100"
-           overflowToDisk="true"/>
-
-    <cache name="namespace-uri-cache"
-           statistics="true"
-           maxElementsInMemory="100"
-           overflowToDisk="true"/>
-
-    <!-- the cache used for triple queries by KiWi -->
-    <cache name="query-cache"
-           statistics="true"
-           maxElementsInMemory="10000"
-           timeToIdleSeconds="3600"
-           overflowToDisk="false"/>
-
-    <!-- the cache used for resource lookups from module jar files -->
-    <cache name="resource-cache"
-           statistics="true"
-           maxElementsInMemory="10000"
-           timeToIdleSeconds="3600"
-           timeToLiveSeconds="3600"
-           overflowToDisk="false"
-           memoryStoreEvictionPolicy="LRU"/>
-
-    <!-- the cache used for triple queries by KiWi -->
-    <cache name="page-cache"
-           statistics="true"
-           maxElementsInMemory="500"
-           timeToIdleSeconds="3600"
-           memoryStoreEvictionPolicy="LRU"
-           overflowToDisk="true"/>
-
-    <!-- the cache used by the file system importer module -->
-    <cache name="fsimport-file-cache"
-           statistics="true"
-           maxElementsInMemory="500"
-           timeToIdleSeconds="3600"
-           memoryStoreEvictionPolicy="LRU"
-           diskPersistent="true"
-           eternal="true"/>
-
-<!--  uncomment to enable cache debugging -->
-<!-- 
-	<cacheManagerPeerListenerFactory
-	    class="org.terracotta.ehcachedx.monitor.probe.ProbePeerListenerFactory"
-	    properties="monitorAddress=localhost, monitorPort=9889" />
--->
-
-</ehcache>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-marmotta/blob/5486b79f/platform/marmotta-core/target/classes/META-INF/services/kiwi.core.api.io.RdfHtmlWriter
----------------------------------------------------------------------
diff --git a/platform/marmotta-core/target/classes/META-INF/services/kiwi.core.api.io.RdfHtmlWriter b/platform/marmotta-core/target/classes/META-INF/services/kiwi.core.api.io.RdfHtmlWriter
deleted file mode 100644
index 49259fe..0000000
--- a/platform/marmotta-core/target/classes/META-INF/services/kiwi.core.api.io.RdfHtmlWriter
+++ /dev/null
@@ -1 +0,0 @@
-at.newmedialab.templating.writer.RDFHtmlExtendedWriter
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-marmotta/blob/5486b79f/platform/marmotta-core/target/classes/META-INF/services/org.openrdf.rio.RDFWriterFactory
----------------------------------------------------------------------
diff --git a/platform/marmotta-core/target/classes/META-INF/services/org.openrdf.rio.RDFWriterFactory b/platform/marmotta-core/target/classes/META-INF/services/org.openrdf.rio.RDFWriterFactory
deleted file mode 100644
index e1c50b6..0000000
--- a/platform/marmotta-core/target/classes/META-INF/services/org.openrdf.rio.RDFWriterFactory
+++ /dev/null
@@ -1 +0,0 @@
-kiwi.core.rio.RDFHtmlWriterFactory
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-marmotta/blob/5486b79f/platform/marmotta-core/target/classes/kiwi-module.properties
----------------------------------------------------------------------
diff --git a/platform/marmotta-core/target/classes/kiwi-module.properties b/platform/marmotta-core/target/classes/kiwi-module.properties
deleted file mode 100644
index 28eef1f..0000000
--- a/platform/marmotta-core/target/classes/kiwi-module.properties
+++ /dev/null
@@ -1,55 +0,0 @@
-#
-# Copyright (C) 2013 Salzburg Research.
-#
-# Licensed 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.
-#
-
-name=Core Services
-
-subtitle = Configure LMF Core
-weight = 10
-
-icon_small = /admin/img/config_small.png
-
-#do not change!!!
-baseurl=/core
-
-adminpages=/admin/first_steps.html,\
-  /admin/about.html,\
-  /admin/configuration.html,\
-  /admin/tasks.html,\
-  /admin/import.html,\
-  /admin/export.html,\
-  /admin/dataview.html,\ 
-  /admin/contexts.html,\
-  /admin/prefixes.html,\
-  /admin/system.html,\
-  /admin/database.html,
-
-webservices=kiwi.core.webservices.config.ConfigurationWebService,\
-  kiwi.core.webservices.config.DependenciesWebService,\
-  kiwi.core.webservices.system.SystemWebService,\
-  kiwi.core.webservices.task.TaskManagerWebService,\
-  kiwi.core.webservices.io.ImportWebService,\
-  kiwi.core.webservices.io.ExportWebService,\
-  kiwi.core.webservices.statistics.StatisticsWebService,\
-  kiwi.core.webservices.modules.ModuleWebService,\
-  kiwi.core.webservices.resource.ResourceWebService,\
-  kiwi.core.webservices.resource.MetaWebService,\
-  kiwi.core.webservices.resource.ContentWebService,\
-  kiwi.core.webservices.resource.InspectionWebService,\
-  kiwi.core.webservices.triplestore.LdpWebService,\
-  kiwi.core.webservices.triplestore.ContextWebService,\
-  kiwi.core.webservices.triplestore.KnowledgeSpaceWebService,\
-  kiwi.core.webservices.prefix.PrefixWebService
-  
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-marmotta/blob/5486b79f/platform/marmotta-core/target/classes/logback-template.xml
----------------------------------------------------------------------
diff --git a/platform/marmotta-core/target/classes/logback-template.xml b/platform/marmotta-core/target/classes/logback-template.xml
deleted file mode 100644
index 4eff3ea..0000000
--- a/platform/marmotta-core/target/classes/logback-template.xml
+++ /dev/null
@@ -1,174 +0,0 @@
-<!--
-
-    Copyright (C) 2013 Salzburg Research.
-
-    Licensed 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 scan="true">
-
-    <define name="LMF_HOME" class="kiwi.core.services.logging.LMFLogbackPropertyDefiner">
-        <key>kiwi.home</key>
-    </define>
-
-    <define name="DEBUG" class="kiwi.core.services.logging.LMFLogbackPropertyDefiner">
-        <key>debug.enabled</key>
-    </define>
-
-
-    <!-- the LMF main log, roll over every day and keep at most one month -->
-    <appender name="main" class="ch.qos.logback.core.rolling.RollingFileAppender">
-        <file>${LMF_HOME}/log/lmf-main.log</file>
-
-        <rollingPolicy class="ch.qos.logback.core.rolling.TimeBasedRollingPolicy">
-            <!-- daily rollover -->
-            <fileNamePattern>${LMF_HOME}/log/lmf-main.%d{yyyy-MM-dd}.log</fileNamePattern>
-
-            <!-- keep 30 days' worth of history -->
-            <maxHistory>30</maxHistory>
-        </rollingPolicy>
-
-        <filter class="ch.qos.logback.classic.filter.ThresholdFilter">
-            <level>INFO</level>
-        </filter>
-
-        <!-- filter out Hibernate 4.x drop constraint messages, they clutter the log unnecessarily -->
-        <filter class="ch.qos.logback.core.filter.EvaluatorFilter">
-            <evaluator>
-                <expression>logger.endsWith("SchemaExport") &amp;&amp; formattedMessage.contains("alter table")</expression>
-            </evaluator>
-            <OnMismatch>NEUTRAL</OnMismatch>
-            <OnMatch>DENY</OnMatch>
-        </filter>
-
-        <encoder>
-            <pattern>%d{HH:mm:ss.SSS} %-5level %logger{36} - %msg%n</pattern>
-        </encoder>
-    </appender>
-
-    <!-- log all debug messages if debug is enabled, roll over every day and keep at most 3 days -->
-    <if condition='property("DEBUG").equals("true")'>
-        <then>
-            <logger name="org.hibernate.SQL" level="DEBUG" />
-            <logger name="org.hibernate.pretty" level="DEBUG" />
-
-            <appender name="debug" class="ch.qos.logback.core.rolling.RollingFileAppender">
-                <file>${LMF_HOME}/log/lmf-debug.log</file>
-
-                <rollingPolicy class="ch.qos.logback.core.rolling.TimeBasedRollingPolicy">
-                    <!-- daily rollover -->
-                    <fileNamePattern>${LMF_HOME}/log/lmf-debug.%d{yyyy-MM-dd}.log</fileNamePattern>
-
-                    <!-- keep 3 days' worth of history -->
-                    <maxHistory>3</maxHistory>
-                </rollingPolicy>
-
-                <encoder>
-                    <pattern>%d{HH:mm:ss.SSS} %-5level %logger{36} - %msg%n</pattern>
-                </encoder>
-            </appender>
-
-            <root>
-                <appender-ref ref="debug" />
-            </root>
-        </then>
-    </if>
-
-    <!-- a logger for logging search requests, keep all messages forever -->
-    <appender name="search" class="ch.qos.logback.core.FileAppender">
-        <file>${LMF_HOME}/log/lmf-search.log</file>
-        <encoder>
-            <pattern>%d{HH:mm:ss.SSS} - %msg%n</pattern>
-        </encoder>
-    </appender>
-
-    <!-- Separate Log File for Stanbol -->
-    <appender name="stanbol" class="ch.qos.logback.core.rolling.RollingFileAppender">
-        <file>${LMF_HOME}/log/lmf-stanbol.log</file>
-
-        <rollingPolicy class="ch.qos.logback.core.rolling.TimeBasedRollingPolicy">
-            <!-- daily rollover -->
-            <fileNamePattern>${LMF_HOME}/log/lmf-stanbol.%d{yyyy-MM-dd}.log</fileNamePattern>
-
-            <!-- keep 30 days' worth of history -->
-            <maxHistory>30</maxHistory>
-        </rollingPolicy>
-
-        <filter class="ch.qos.logback.classic.filter.ThresholdFilter">
-            <level>INFO</level>
-        </filter>
-
-        <encoder>
-            <pattern>%d{HH:mm:ss.SSS} %-5level %logger{36} - %msg%n</pattern>
-        </encoder>
-    </appender>
-
-    <!-- STDOUT logger, used for errors -->
-    <appender name="STDOUT" class="ch.qos.logback.core.ConsoleAppender">
-        <filter class="ch.qos.logback.classic.filter.ThresholdFilter">
-            <level>WARN</level>
-        </filter>
-
-        <!-- filter out Hibernate 4.x drop constraint messages, they clutter the log unnecessarily -->
-        <filter class="ch.qos.logback.core.filter.EvaluatorFilter">
-            <evaluator>
-                <expression>logger.endsWith("SchemaExport") &amp;&amp; formattedMessage.contains("alter table")</expression>
-            </evaluator>
-            <OnMismatch>NEUTRAL</OnMismatch>
-            <OnMatch>DENY</OnMatch>
-        </filter>
-
-        <encoder>
-<!--            <pattern>%d{HH:mm:ss.SSS} %-5level %logger{36} - %msg%n</pattern> -->
-            <pattern>%d{HH:mm:ss.SSS} %-5level - %msg%n</pattern>
-        </encoder>
-    </appender>
-
-
-    <!-- log all search messages only to the search log -->
-    <logger name="search" level="INFO" additivity="false">
-        <appender-ref ref="search" />
-    </logger>
-
-
-    <logger name="kiwi" level="INFO" />
-
-    <logger name="at.newmedialab" level="INFO" />
-
-    <logger name="org.hibernate.cache" level="ERROR" />
-    <logger name="org.hibernate" level="WARN" />
-
-    <!--
-    <logger name="org.hibernate.SQL" level="DEBUG" />
-    <logger name="org.hibernate.pretty" level="DEBUG" />
-    -->
-
-    <logger name="org.apache.solr" level="WARN" />
-
-    <logger name="org.quartz" level="WARN" />
-
-    <logger name="org.apache.stanbol" level="INFO" additivity="false">
-        <appender-ref ref="stanbol" />
-    </logger>
-    <logger name="org.apache.felix" level="INFO" additivity="false">
-        <appender-ref ref="stanbol" />
-    </logger>
-    <logger name="org.apache.clerezza" level="INFO" additivity="false">
-        <appender-ref ref="stanbol" />
-    </logger>
-
-    <root level="debug">
-        <appender-ref ref="STDOUT" />
-        <appender-ref ref="main" />
-    </root>
-</configuration>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-marmotta/blob/5486b79f/platform/marmotta-core/target/classes/rebel.xml
----------------------------------------------------------------------
diff --git a/platform/marmotta-core/target/classes/rebel.xml b/platform/marmotta-core/target/classes/rebel.xml
deleted file mode 100644
index 610a547..0000000
--- a/platform/marmotta-core/target/classes/rebel.xml
+++ /dev/null
@@ -1,9 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<application xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xmlns="http://www.zeroturnaround.com" xsi:schemaLocation="http://www.zeroturnaround.com http://www.zeroturnaround.com/alderaan/rebel-2_0.xsd">
-
-	<classpath>
-		<dir name="${rebel.root}/marmotta-core/target/classes">
-		</dir>
-	</classpath>
-
-</application>

http://git-wip-us.apache.org/repos/asf/incubator-marmotta/blob/5486b79f/platform/marmotta-core/target/classes/templates/404.ftl
----------------------------------------------------------------------
diff --git a/platform/marmotta-core/target/classes/templates/404.ftl b/platform/marmotta-core/target/classes/templates/404.ftl
deleted file mode 100644
index 416f677..0000000
--- a/platform/marmotta-core/target/classes/templates/404.ftl
+++ /dev/null
@@ -1,98 +0,0 @@
-<#--
-
-    Copyright (C) 2013 Salzburg Research.
-
-    Licensed 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.
-
--->
-<!DOCTYPE html>
-<html lang="en">
-
-<head>
-  <title>404 Not Found - LMF Linked Data Explorer</title>
-  <meta http-equiv="Content-Type" content="text/html;charset=utf-8" />  
-  <script src="${baseUri}core/public/js/lib/jquery-1.7.2.js" type="text/javascript" ></script>
-  <link href="${baseUri}core/public/style/style.css" title="screen" rel="stylesheet" type="text/css" />
-  <link href="${baseUri}core/public/style/scheme/blue.css" title="screen" rel="stylesheet" type="text/css" />  
-  <link href="${baseUri}core/public/style/scheme/dark.css" title="screen" rel="stylesheet" type="text/css" />  
-  <link href="${baseUri}core/public/style/rdfhtml.css" title="screen" rel="stylesheet" type="text/css" />  
-  <style type="text/css">
-    div#center {
-      float: none; 
-      width: auto; 
-      vertical-align: middle; 
-      min-height: 400px; 
-      margin: 0; 
-      padding: 2em 30% 5em 30%;
-    }
-    div#center > * {
-      margin-top: 2em;
-      font-size: 1.6em;
-    }
-    div#center > p > a > img {
-      vertical-align: text-top;
-      margin-left: 0.15em;
-    }
-  </style>  
-</head>
-
-<body>
-
-<div id="wrapper">
-
-    <div id="header">
-        <a id="logo" href="${baseUri}">
-            <img src="${baseUri}core/public/img/logo/lmf-logo.png" alt="LMF" />
-        </a>    
-        <h1>LMF Linked Data Explorer</h1>
-    </div>
-
-    <div id="center">
-        <div id="content">
-
-          <h2>404 Not Found</h2>
-        
-          <p>
-            <strong><a href="${baseUri}resource?uri=${encoded_uri}">${uri}</a></strong><a href="${uri}"><img src="${baseUri}core/public/img/icon/link.png" alt="${uri}" title="go to ${uri} directly" /></a>
-          </p>
-          
-          <p>
-            Sorry, but ${message}.
-          </p>  
-        
-        </div>
-        
-    </div>
-    
-    <div class="clear"></div>
-    <div id="footer">
-        <div id="footer_line">
-            <span>
-                <abbr title="Linked Media Framework">LMF</abbr> is a project of <a href="http://www.newmedialab.at/">SNML-TNG</a></span>
-            </span>
-        </div>
-    </div>    
-
-</div>
-
-<script type="text/javascript"> 
-
-  $(document).ready(function() {
-
-  });
-
-</script> 
-
-</body>
-
-</html>

http://git-wip-us.apache.org/repos/asf/incubator-marmotta/blob/5486b79f/platform/marmotta-core/target/classes/templates/admin.ftl
----------------------------------------------------------------------
diff --git a/platform/marmotta-core/target/classes/templates/admin.ftl b/platform/marmotta-core/target/classes/templates/admin.ftl
deleted file mode 100644
index 8a20c9b..0000000
--- a/platform/marmotta-core/target/classes/templates/admin.ftl
+++ /dev/null
@@ -1,93 +0,0 @@
-<#--
-
-    Copyright (C) 2013 Salzburg Research.
-
-    Licensed 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.
-
--->
-<!DOCTYPE html PUBLIC "-//W3C//DTD XHTML 1.0 Transitional//EN"
-        "http://www.w3.org/TR/xhtml1/DTD/xhtml1-transitional.dtd">
-
-<html xmlns="http://www.w3.org/1999/xhtml" dir="ltr">
-
-<head>
-
-    <meta http-equiv="Content-Type" content="text/html; charset=UTF-8" />
-    <meta http-equiv="Default-Style" content="${DEFAULT_STYLE}">
-    <link href="${SERVER_URL}core/public/style/javadoc.css" rel="stylesheet" type="text/css" />
-    <link href="${SERVER_URL}core/public/style/style.css" rel="stylesheet" type="text/css" />
-    <link href="${SERVER_URL}core/public/style/scheme/blue.css" title="blue" rel="stylesheet" type="text/css" />
-    <link href="${SERVER_URL}core/public/style/scheme/dark.css" title="dark" rel="alternate stylesheet" type="text/css" />
-    <link href="${SERVER_URL}core/public/img/icon/lmf.ico" rel="SHORTCUT ICON">
-    <script type="text/javascript">
-        var _BASIC_URL = "${BASIC_URL}";
-        //use _SERVER_URL for webservice calls
-        var _SERVER_URL = "${SERVER_URL}";
-    </script>
-    <#if USER_MODULE_IS_ACTIVE>
-        <link href="${SERVER_URL}user/admin/style/style.css" rel="stylesheet" type="text/css">
-        <script type="text/javascript" src="${SERVER_URL}user/admin/widgets/user.js"></script>
-        <script type="text/javascript">
-            window.onload = function () {
-                    LoginLogout.draw(_SERVER_URL,"login_logout");
-            }
-        </script>
-    </#if>
-    ${HEAD}
-    <title>Apache Marmotta</title>
-
-<body>
-
-<div id="wrapper">
-    <div id="header">
-        <a id="logo" href="${SERVER_URL}" title="${PROJECT}">
-            <img src="${SERVER_URL}${LOGO}" alt="${PROJECT} logo" />
-        </a>
-        <h1>${CURRENT_MODULE} - ${CURRENT_TITLE}</h1>
-        <#if USER_MODULE_IS_ACTIVE>
-            <div id="login_logout"></div>
-        </#if>
-    </div>
-    <div class="clear"></div>
-    <div id="left">
-        <ul id="menu">
-            <#list MODULE_MENU as menu>
-            <li class="menu_item">
-                <div class="menu_heading">${menu.properties["title"]}</div>
-                <ul class="submenu">
-                <#list menu.submenu as submenu>
-                    <li
-                        <#if submenu.properties["active"]> class="active" </#if>
-                    >
-                    <a href="${submenu.properties["path"]}">${submenu.properties["title"]}</a>
-                    </li>
-                </#list>
-                </ul>
-            </li>
-            </#list>
-        </ul>
-    </div>
-    <div id="center">
-        <div id="content">
-        ${CONTENT}
-        </div>
-    </div>
-    <div class="clear"></div>
-    <div id="footer">
-        <div id="footer_line">
-            <span>
-                ${FOOTER}
-            </span>
-        </div>
-    </div>
-</div>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-marmotta/blob/5486b79f/platform/marmotta-core/target/classes/templates/admin_old.ftl
----------------------------------------------------------------------
diff --git a/platform/marmotta-core/target/classes/templates/admin_old.ftl b/platform/marmotta-core/target/classes/templates/admin_old.ftl
deleted file mode 100644
index 5444bdc..0000000
--- a/platform/marmotta-core/target/classes/templates/admin_old.ftl
+++ /dev/null
@@ -1,86 +0,0 @@
-<#--
-
-    Copyright (C) 2013 Salzburg Research.
-
-    Licensed 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.
-
--->
-<!DOCTYPE html>
-<html>
-    <head>
-	    <meta http-equiv="Content-Type" content="text/html; charset=UTF-8" />
-        <meta http-equiv="Default-Style" content="${DEFAULT_STYLE}">
-        <link href="${SERVER_URL}core/public/style/javadoc.css" rel="stylesheet" type="text/css" />
-	    <link href="${SERVER_URL}core/public/style/style1.css" title="screen" rel="stylesheet" type="text/css" />
-        <link href="${SERVER_URL}core/public/style/style2.css" title="beamer" rel="alternate stylesheet" type="text/css" />
-        <link href="${SERVER_URL}core/public/img/icon-small.ico" rel="SHORTCUT ICON">
-        <script type="text/javascript">
-            var _BASIC_URL = "${BASIC_URL}";
-            //use _SERVER_URL for webservice calls
-            var _SERVER_URL = "${SERVER_URL}";
-        </script>
-        <script type="text/javascript" src="${SERVER_URL}core/public/js/lib/jquery-1.7.2.js"></script>
-        <script type="text/javascript" src="${SERVER_URL}core/public/js/widgets/current-user.js"></script>
-        <script type="text/javascript">
-            $(function() {
-        	  new LMF.currentUserWidget(_SERVER_URL, document.getElementById("login_logout")).init();
-        	});
-        </script>
-        ${HEAD}
-        <title>LMF - The Linked Media Server</title>
-        <style type="text/css">
-        	#login_logout {
-				float: right;
-				margin: 5px;
-        	}
-        </style>
-    </head>
-    <body>
-        <a id="top-link" href="${SERVER_URL}">TOPLINK</a>
-        <div id="wrapper">
-            <div id="header">
-                <div id="logo">
-                    <a href="${SERVER_URL}"><img src="${SERVER_URL}core/public/img/lmf-white.png" /></a>
-                </div>
-                <div id="header_text">
-                	<h1>${CURRENT_MODULE} - ${CURRENT_TITLE}</h1>
-                	<div id="topnav">
-    	            	<div id="login_logout"></div>
-    	            </div>
-                </div>
-            </div>
-            <div class="clear"></div>
-            <div id="left">
-                        <#list MODULE_MENU as menu>
-                            <h1>${menu.properties["title"]}</h1>
-                            <#list menu.submenu as submenu>
-                                <a href="${submenu.properties["path"]}"
-                                <#if submenu.properties["active"]> class="active" </#if>
-                                >${submenu.properties["title"]}</a>
-                            </#list>
-                        </#list>
-            </div>
-            <div id="center">
-                ${CONTENT}
-            </div>
-            <div class="clear"></div>
-            <div id="footer">
-                <span>
-                    <a href="http://lmf.googlecode.com">LMF</a> 
-                    is a project of 
-                    <a href="http://www.newmedialab.at/">SNML-TNG</a>
-                </span>
-            </div>
-        </div>
-    </body>
-</html>

http://git-wip-us.apache.org/repos/asf/incubator-marmotta/blob/5486b79f/platform/marmotta-core/target/classes/templates/rdfhtml.ftl
----------------------------------------------------------------------
diff --git a/platform/marmotta-core/target/classes/templates/rdfhtml.ftl b/platform/marmotta-core/target/classes/templates/rdfhtml.ftl
deleted file mode 100644
index bcdea06..0000000
--- a/platform/marmotta-core/target/classes/templates/rdfhtml.ftl
+++ /dev/null
@@ -1,326 +0,0 @@
-<#--
-
-    Copyright (C) 2013 Salzburg Research.
-
-    Licensed 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.
-
--->
-<!DOCTYPE html>
-<html lang="en" prefix="${prefixMappings}" xmlns="http://www.w3.org/1999/html">
-
-<head>
-  <title>Resource/s in HTML</title>
-  <meta http-equiv="Content-Type" content="text/html;charset=utf-8" />
-  <script type="text/javascript" src="${baseUri}core/public/js/lib/jquery-1.7.2.js"></script>
-    <link href="${baseUri}core/public/style/style.css" rel="stylesheet" type="text/css" />
-    <link href="${baseUri}core/public/style/scheme/blue.css" title="blue" rel="stylesheet" type="text/css" />
-    <link href="${baseUri}core/public/style/scheme/dark.css" title="dark" rel="alternate stylesheet" type="text/css" />
-    <link href="${baseUri}core/public/style/rdfhtml.css" rel="stylesheet" type="text/css" />
-
-  <script>
-      $(document).ready(function(){
-          $(".submenu li").click(function(event){
-              event.preventDefault();
-              if(!$(this).hasClass("active")) {
-                  $(".submenu").children().removeClass("active");
-                  $(this).addClass("active");
-                  var tabid = $(this).children(":first").attr("href").substring(1);
-                  $("#content").children().hide();
-                  $("#"+tabid).show();
-              }
-          })
-
-          $("a.ldcache").each(function(index) {
-              $(this).click(function() {
-                  window.location.href = "${baseUri}resource?uri=" + encodeURIComponent($(this).attr("href"));
-                  return false;
-              });
-          });
-
-          function loader(uri, type, target) {
-
-              var table = $("#"+target);
-
-              function linkify(text) {
-                  var exp = /(\b(https?|ftp|file):\/\/[-A-Z0-9+&@#\/%?=~_|!:,.;]*[-A-Z0-9+&@#\/%=~_|])/ig;
-                  return text.replace(exp,"<a href='$1' class='ldcache'>$1</a>");
-              }
-              function zebra(index) {
-                  return ( index % 2 ? "even": "odd" );
-              }
-              function createRow(data, cssClass) {
-                  return $("<tr>", {})
-                          .append($("<td>", {html: linkify(data.s)}))
-                          .append($("<td>", {html: linkify(data.p)}))
-                          .append($("<td>", {html: linkify(data.o)}))
-                          .append($("<td>", {html: linkify(data.c)}))
-                          .addClass(cssClass);
-              }
-              return {
-                  resource: uri,
-                  target: table,
-                  offset: 0,
-                  limit: 10,
-                  fetch: function() {
-                      var self = this;
-                      $.getJSON("${baseUri}inspect/" + type, {uri: self.resource, start: self.offset, limit: self.limit}, function(data) {
-                          if(data.length == 0) {
-                              console.log(table);
-                              table.replaceWith("<p class='no_triples'>No triples to display</p>");
-                          }
-                          for( var i in data) {
-                              var t = data[i];
-                              table.append(createRow(t, zebra(i)));
-                          }
-                      });
-                  },
-                  next: function(step) {
-                      step = step || this.limit;
-                      this.offset += step;
-                      this.fetch();
-                  },
-                  prev: function(step) {
-                      step = step || this.limit
-                      this.offset = Math.max(this.offset - step, 0);
-                      this.fetch();
-                  },
-                  more: function() {
-                      this.limit += 5;
-                      this.fetch();
-                  },
-                  less: function() {
-                      this.limit = Math.max(this.limit - 5, 5);
-                      this.fetch();
-                  },
-                  first: function() {
-                      this.offset = 0;
-                      this.fetch();
-                  }
-              };
-          }
-
-      <#if resources?size = 1>
-          var subjLoader = new loader("${resources[0].uri}", "subject", "inspect_subject");
-          subjLoader.fetch();
-          $("#s0").click(function() {subjLoader.first();});
-          $("#s1").click(function() {subjLoader.prev();});
-          $("#s2").click(function() {subjLoader.next();});
-          $("#s3").click(function() {subjLoader.more();});
-          $("#s4").click(function() {subjLoader.less();});
-
-          var propLoader = new loader("${resources[0].uri}", "predicate", "inspect_property");
-          propLoader.fetch();
-
-          var objLoader = new loader("${resources[0].uri}", "object", "inspect_object");
-          objLoader.fetch();
-      </#if>
-
-      })
-  </script>
-</head>
-
-<body>
-<#function zebra index>
-    <#if (index % 2) == 0>
-        <#return "odd" />
-    <#else>
-        <#return "even" />
-    </#if>
-</#function>
-
-<#function cacheClass object>
-    <#if object.cache?has_content>
-        <#return "ldcache" />
-    <#else>
-        <#return "" />
-    </#if>
-</#function>
-
-<#function rdfaAttributes object>
-    <#return "${rdfaDatatype(object)} ${rdfaLanguage(object)}" />
-</#function>
-
-<#function rdfaDatatype object>
-    <#if object.datatype?has_content>
-        <#return "datatype=\"${object.datatype}\"" />
-    <#else>
-        <#return "" />
-    </#if>
-</#function>
-
-<#function rdfaLanguage object>
-    <#if object.lang?has_content>
-        <#return "lang=\"${object.lang}\"" />
-    <#else>
-        <#return "" />
-    </#if>
-</#function>
-
-<div id="wrapper">
-    <div id="header">
-        <a id="logo" href="${SERVER_URL}">
-            <img src="${SERVER_URL}${LOGO}">
-        </a>
-        <h1>RDF/HTML</h1>
-        <#if resources?size = 1>
-        <div id="top_serialisation_links">
-            <a href="${baseUri}resource?uri=${resources[0].encoded_uri}&amp;format=application/rdf%2Bxml">RDF/XML</a>&nbsp;|&nbsp;
-            <a href="${baseUri}resource?uri=${resources[0].encoded_uri}&amp;format=text/rdf%2Bn3">N3</a>&nbsp;|&nbsp;
-            <a href="${baseUri}resource?uri=${resources[0].encoded_uri}&amp;format=text/turtle">Turtle</a>&nbsp;|&nbsp;
-            <a href="${baseUri}resource?uri=${resources[0].encoded_uri}&amp;format=application/rdf%2Bjson">RDF/JSON</a>&nbsp;|&nbsp;
-            <a href="${baseUri}resource?uri=${resources[0].encoded_uri}&amp;format=application/ld%2Bjson">JSON-LD</a>
-        </div>
-        <div class="clean"></div>
-        </#if>
-    </div>
-    <div class="clear"></div>
-    <div id="left">
-    <ul id="menu">
-        <li class="menu_item">
-        <div class="menu_heading">Views</div>
-        <ul class="submenu">
-                <li class="active"><a href="#tab-raw-triples">Triples</a></li>
-                <#if resources?size = 1>
-                <li><a href="#tab-inspection">Inspector</a></li>
-                </#if>
-            </ul>
-        </li>
-    </ul>
-    </div>
-    <div id="center">
-        <div id="content">
-            <div id="tab-raw-triples">
-
-            <h1>Triples</h1>
-            <#if resources?has_content>
-                <#list resources as resource>
-                    <h2><a href="${resource.uri}" class="ldcache">${resource.uri}</a>
-                        <#if timemaplink??>
-                            <a style="float:right" id="timemap_link" href="${baseUri}${timemaplink}${resource.uri}">
-                                <img style="width: 24px" title="browser versions" alt="memento" src="${baseUri}core/public/img/icon/memento_logo_128.png">
-                            </a>
-                        </#if>
-                    </h2>
-                    <table class="simple_table">
-                        <tr class="trClassHeader">
-                            <th>property</th>
-                            <th>has value</th>
-                            <th>context</th>
-                            <th id="info">info</th>
-                        </tr>
-                        <#list resource.triples as triple>
-                            <tr class="${zebra(triple_index)}">
-                                <td><a href="${triple.predicate.uri}" class="ldcache">${triple.predicate.curie}</a></td>
-                                <td about="${resource.uri}">
-                                    <#if triple.object.uri?has_content>
-                                        <a rel="${triple.predicate.curie}" href="${triple.object.uri}" class="${cacheClass(triple.object)}">${triple.object.curie}</a>
-                                    <#else>
-                                        <span property="${triple.predicate.curie}" ${rdfaAttributes(triple.object)}>${triple.object.value}</span>
-                                    </#if>
-                                </td>
-                                <td><a href="${triple.context.uri}">${triple.context.curie}</a></td>
-                                <td>${triple.info}</td>
-                            </tr>
-                        </#list>
-                    </table>
-                    <#if resources?size != 1>
-                    <p id="rawrdf">
-                        Get this resource in raw RDF:
-                        <a href="${baseUri}resource?uri=${resource.encoded_uri}&amp;format=application/rdf%2Bxml">RDF/XML</a>,
-                        <a href="${baseUri}resource?uri=${resource.encoded_uri}&amp;format=text/rdf%2Bn3">N3</a>,
-                        <a href="${baseUri}resource?uri=${resource.encoded_uri}&amp;format=text/turtle">Turtle</a>,
-                        <a href="${baseUri}resource?uri=${resource.encoded_uri}&amp;format=application/rdf%2Bjson">RDF/JSON</a>,
-                        <a href="${baseUri}resource?uri=${resource.encoded_uri}&amp;format=application/ld%2Bjson">JSON-LD</a>
-                    </p>
-                    </#if>
-                </#list>
-            <#else>
-                <p>
-                    No local triples to display!
-                </p>
-            </#if>
-
-            </div>
-
-        <#if resources?size = 1>
-            <div id="tab-inspection" style="display: none">
-                <h1>Inspection of <a href="${resources[0].uri}" class="ldcache">${resources[0].uri}</a></h1>
-                <div class="introspectionDetails">
-                    <h2>Resource as Subject</h2>
-                    <div id="table_buttons">
-                    <button id="s0">|&lt;</button>
-                    <button id="s1">&lt;</button>
-                    <button id="s2">&gt;</button>
-                    <button id="s3">+</button>
-                    <button id="s4">-</button>
-                    </div>
-                    <table id="inspect_subject" class="simple_table">
-                        <tr class="trClassHeader">
-                            <th>Subject</th>
-                            <th>Property</th>
-                            <th>Object</th>
-                            <th>Context</th>
-                        </tr>
-                    </table>
-                </div>
-                <div class="introspectionDetails">
-                    <h2>Resource as Property</h2>
-                    <table id="inspect_property" class="simple_table">
-                        <tr class="trClassHeader">
-                            <th>Subject</th>
-                            <th>Property</th>
-                            <th>Object</th>
-                            <th>Context</th>
-                        </tr>
-                    </table>
-                </div>
-                <div class="introspectionDetails">
-                    <h2>Resource as Object</h2>
-                    <table id="inspect_object" class="simple_table">
-                        <tr class="trClassHeader">
-                            <th>Subject</th>
-                            <th>Property</th>
-                            <th>Object</th>
-                            <th>Context</th>
-                        </tr>
-                    </table>
-                </div>
-                <!--
-                <div class="introspectionDetails">
-                    <h4><a href="${resources[0].uri}" class="ldcache">${resources[0].uri}</a> as Context</h4>
-                	<table id="inspect_context">
-                      <tr class="trClassHeader">
-                        <th>Subject</th>
-                        <th>Property</th>
-                        <th>Object</th>
-                        <th>Context<th>
-                      </tr>
-                	</table>
-                </div>
-                -->
-            </div>
-        </#if>
-        </div>
-    </div>
-    <div class="clear"></div>
-    <div id="footer">
-        <div id="footer_line">
-            <span>
-            ${FOOTER}
-            </span>
-        </div>
-    </div>
-</div>
-</body>
-
-</html>

http://git-wip-us.apache.org/repos/asf/incubator-marmotta/blob/5486b79f/platform/marmotta-core/target/classes/web/admin/about.html
----------------------------------------------------------------------
diff --git a/platform/marmotta-core/target/classes/web/admin/about.html b/platform/marmotta-core/target/classes/web/admin/about.html
deleted file mode 100644
index 94de506..0000000
--- a/platform/marmotta-core/target/classes/web/admin/about.html
+++ /dev/null
@@ -1,116 +0,0 @@
-<!--
-
-    Copyright (C) 2013 Salzburg Research.
-
-    Licensed 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.
-
--->
-<html>
-<head>
-<!--###BEGIN_HEAD###-->
-<title>Core Module</title>
-<!--###END_HEAD###-->
-</head>
-<body>
-  <!--###BEGIN_CONTENT###-->
-  <h1>About</h1>
-  <p>The Linked Media Framework is an easy-to-setup server application that bundles
-    central Semantic Web technologies to offer advanced services. The Linked Media
-    Framework consists of LMF Core and LMF Modules.</p>
-  <h2>
-    <a id="LMF_Core"></a>LMF Core<a class="section_anchor" href="#LMF_Core"></a>
-  </h2>
-  <p>
-    The core component of the Linked Media Framework is a <strong>Linked Data
-      Server</strong> that allows to expose data following the <a rel="nofollow"
-      href="http://linkeddatabook.com/editions/1.0/">Linked Data Principles</a>:
-  </p>
-  <ol>
-    <li>Use URIs as names for things.</li>
-    <li>Use HTTP URIs, so that people can look up those names.</li>
-    <li>When someone looks up a URI, provide useful information, using the standards
-      (RDF, SPARQL).</li>
-    <li>Include links to other URIs, so that they can discover more things.</li>
-  </ol>
-  <p></p>
-  <p>
-    The Linked Data Server implemented as part of the LMF goes beyond the Linked Data
-    principles by extending them with Linked Data Updates and by integrating management of
-    metadata and content and making both accessible in a uniform way. Our extensions are
-    described in more detail in <a
-      href="http://code.google.com/p/lmf/wiki/PrinciplesLinkedMedia">PrinciplesLinkedMedia</a>.
-    In addition to the Linked Data Server, the LMF Core also offers a SPARQL endpoint.
-  </p>
-  <p>Whereas the extension of the Linked Data principles is already conceptually
-    well-described, we are currently still working on a proper specification and extension
-    of Semantic Search and SPARQL endpoint for Linked Data servers.</p>
-  <p>
-    <strong>The LMF Core can be downloaded in the <a rel="nofollow"
-      href="http://code.google.com/p/lmf/downloads/list">Downloads</a> section!
-    </strong>
-  </p>
-  <h2>
-    <a id="LMF_Modules"></a>LMF Modules<a class="section_anchor" href="#LMF_Modules"></a>
-  </h2>
-  <p>As extension for the LMF Core, we are working on a number of optional modules
-    that can be used to extend the functionality of the Linked Media Server:</p>
-  <p>Implemented:</p>
-  <ul>
-    <li><strong><a
-        href="http://code.google.com/p/lmf/wiki/ModuleSemanticSearch">LMF Semantic
-          Search</a></strong> offers a highly configurable <strong>Semantic Search</strong> service
-      based on Apache SOLR. Several semantic search indexes can be configured in the same
-      LMF instance. Setting up and using the Semantic Search component is described in <a
-      href="http://code.google.com/p/lmf/wiki/ModuleSemanticSearch">SemanticSearch</a>,
-      the path language used for configuring it is described in <a
-      href="http://code.google.com/p/lmf/wiki/ModuleLDPath">LDPath</a>.
-    </li>
-    <li><strong><a
-        href="http://code.google.com/p/lmf/wiki/ModuleLinkedDataCaching">LMF Linked
-          Data Cache</a></strong> implements a cache to the Linked Data Cloud that is transparently
-      used when querying the content of the LMF using either SPARQL or the Semantic Search
-      component. In case a local resource links to a remote resource in the Linked Data
-      Cloud and this relationship is queried, the remote resource will be retrieved in the
-      background and cached locally.</li>
-    <li><strong><a
-        href="http://code.google.com/p/lmf/wiki/ModuleReasoning">LMF Reasoner</a></strong>
-      implements a rule-based reasoner that allows to process Datalog-style rules over RDF
-      triples; the LMF Reasoner will be based on the reasoning component developed in the
-      KiWi project, the predecessor of the LMF (state: implemented)</li>
-  </ul>
-  <p></p>
-  <p>In Progress:</p>
-  <ul>
-    <li><strong>LMF Permissions</strong> implements and extends the <a rel="nofollow"
-      href="http://www.w3.org/wiki/WebID">WebID</a> and <a rel="nofollow"
-      href="http://www.w3.org/wiki/WebAccessControl">WebACL</a> specifications for
-      standards-conforming authentication and access control in the Linked Media
-      Framework. (state: almost completed)</li>
-    <li><strong>LMF Enhancer</strong> offers semantic enhancement of content by
-      analysing textual and media content; the LMF Enhancer will build upon UIMA, Apache
-      Tika, and our own <a rel="nofollow" href="http://incubator.apache.org/stanbol/">Apache
-        Stanbol</a> framework (state: started)</li>
-    <li><strong>LMF Media Interlinking</strong> will implement support for multimedia
-      interlinking based on the work in the <a rel="nofollow"
-      href="http://www.w3.org/2008/WebVideo/Fragments/">W3C Multimedia Fragments WG</a>
-      and the <a rel="nofollow" href="http://www.w3.org/2008/01/media-annotations-wg.html">W3C
-        Multimedia Annotations WG</a></li>
-    <li><strong>LMF Versioning</strong> implements versioning of metadata updates;
-      versioning itself is already carried out by LMF Core, but the management of versions
-      will be carried out by this module (state: started)</li>
-  </ul>
-  <p></p>
-  <!--###END_CONTENT###-->
-</body>
-</html>
-

http://git-wip-us.apache.org/repos/asf/incubator-marmotta/blob/5486b79f/platform/marmotta-core/target/classes/web/admin/configuration.html
----------------------------------------------------------------------
diff --git a/platform/marmotta-core/target/classes/web/admin/configuration.html b/platform/marmotta-core/target/classes/web/admin/configuration.html
deleted file mode 100644
index 9d0ba01..0000000
--- a/platform/marmotta-core/target/classes/web/admin/configuration.html
+++ /dev/null
@@ -1,62 +0,0 @@
-<!--
-
-    Copyright (C) 2013 Salzburg Research.
-
-    Licensed 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.
-
--->
-<html>
-<head>
-<!--###BEGIN_HEAD###-->
-    <title>Core Module Configuration</title>
-    <link type="text/css" rel="stylesheet" href="../public/js/widgets/configurator/style.css">
-    <script type="text/javascript" src="../public/js/lib/jquery-1.7.2.js"></script>
-    <script type="text/javascript" src="../public/js/widgets/configurator/configurator.js"></script>
-    <script type="text/javascript" src="js/widgets/database.js"></script>
-    <script type="text/javascript">
-        jQuery(document).ready(function(){
-            var options = {
-                url : _SERVER_URL,
-                container : "lmf_configurator",
-                blacklist: ['ldcache.endpoint.','ldcache.endpoint.','prefix.','security.permission.','security.restriction.','database.','solr.cores.available','solr.cores.enabled','user.admin.']
-            }
-            var configurator = new Configurator(options);
-            $('#lmf_database').lmf_database({host:_SERVER_URL});
-        });
-    </script>
-<!--###END_HEAD###-->
-</head>
-<body>
-<div id="main">
-<div id="contents">
-<!--###BEGIN_CONTENT###-->
-<h1>Linked Media Core Configuration</h1>
-        <p>
-            Here you can configure the LMF Core.<br/>
-            The configuration contains:
-        </p>
-        <ul>
-            <li><a href="#generic">Generic Parameter Configuration</a></li>
-            <li><a href="#database">Database Configuration</a></li>
-        </ul>
-        <div id="lmf_configurator">
-            <h4>Loading configurator</h4>
-        </div>
-        <div id="lmf_database">
-            <h4>Loading database manager</h4>
-        </div>
-<!--###END_CONTENT###-->
-</div>
-</div>
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/incubator-marmotta/blob/5486b79f/platform/marmotta-core/target/classes/web/admin/contexts.html
----------------------------------------------------------------------
diff --git a/platform/marmotta-core/target/classes/web/admin/contexts.html b/platform/marmotta-core/target/classes/web/admin/contexts.html
deleted file mode 100644
index 6a97ced..0000000
--- a/platform/marmotta-core/target/classes/web/admin/contexts.html
+++ /dev/null
@@ -1,89 +0,0 @@
-<!--
-
-    Copyright (C) 2013 Salzburg Research.
-
-    Licensed 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.
-
--->
-<html>
-<head>
-<!--###BEGIN_HEAD###-->
-    <title>Contexts</title>
-    <link type="text/css" rel="stylesheet" href="../public/js/widgets/configurator/style.css" />
-<!--###END_HEAD###-->
-</head>
-<body>
-<div id="main">
-<div id="contents">
-<!--###BEGIN_CONTENT###-->
-    <h1>Contexts</h1>
-    <h2>Triple Contexts / Graphs</h2>
-    <p>
-        In LMF we call <em>contexts</em> to triple containers with their own URI; 
-        what is commonly known as 
-        <a href="http://www.w3.org/TR/sparql11-query/#namedAndDefaultGraph">graphs</a>
-        in SPARQL.
-    </p>
-    <p>
-        Currently there are <span id="contexts-count">0</span> contexts in LMF:
-    </p>    
-    <table id="contexts" class="simple_table">
-      <tr class="subtitle">
-        <th>Context</th>
-        <th>Label</th>
-        <th>&nbsp;</th>
-      </tr>    
-    </table>  
-    
-    <script type="text/javascript" src="/webjars/jquery/1.8.2/jquery.min.js"></script>
-    <script type="text/javascript">
-        jQuery(document).ready(function() {
-
-            function appendContext(ctx, id) {
-                var uri = ctx["uri"];
-                var label = (ctx["label"] ? ctx["label"] : "");
-            	$("table#contexts > tbody:last").append("<tr id=\"context" + id + "\"><td><a href=\"" + uri + "\">" + uri + "</a></td><td>" + label + "</td><td><a href=\"#contexts\" class=\"deleteContext\">delete</a></td></tr>");
-            }
-
-            function deleteContext(uri, id) {
-            	$.ajax({
-            	    url: uri,
-            	    type: "DELETE",
-            	    success: function(result) {
-            	    	alert("Context " + uri + " deleted!");
-            	        $("tr#" + id).remove();
-            	    }
-            	});
-            }        
-            
-            $.getJSON("../../context/list", {labels:"true"}, function(data) {
-                var count = 0;
-                for (i in data) {                  
-                	appendContext(data[i], count);
-                	$("span#contexts-count").html(++count);
-                }
-                $("a.deleteContext").click(function() {
-                    var row = $(this).closest("td").closest("tr");
-                    var uri = row.find("td:first").text();
-                    var id = row.attr("id");
-                    deleteContext(uri, id);
-                });
-            });        
-            
-        });
-    </script>
-<!--###END_CONTENT###-->
-</div>
-</div>
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/incubator-marmotta/blob/5486b79f/platform/marmotta-core/target/classes/web/admin/css/admin-style.css
----------------------------------------------------------------------
diff --git a/platform/marmotta-core/target/classes/web/admin/css/admin-style.css b/platform/marmotta-core/target/classes/web/admin/css/admin-style.css
deleted file mode 100644
index 93f36ba..0000000
--- a/platform/marmotta-core/target/classes/web/admin/css/admin-style.css
+++ /dev/null
@@ -1,65 +0,0 @@
-/**
- * Copyright (C) 2013 Salzburg Research.
- *
- * Licensed 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.
- */
-
-.jumplink {
-    font-size: 75%;
-}
-
-.stat_status {
-    border-radius: 10px 10px 10px 10px;
-    display: inline-block;
-    float: right;
-    height: 20px;
-    width: 20px;
-    background-color: red;
-}
-.stat_status.on {
-    background-color: darkGreen;
-}
-
-#refresh_box {
-    display: inline-block;
-    float: right;
-    margin-top: 25px;
-    background-color: white;
-    margin-right: 7px;
-    padding: 1px;
-    border-radius: 3px;
-    -webkit-border-radius: 3px;
-}
-
-#messages>div {
-    margin: 5px;
-    padding: 5px;
-    border: 1px solid orange;
-    background: rgba(255, 255, 0, 0.3);
-    border-radius: 5px;
-}
-
-#messages>div.error {
-    border-color: red;
-    background: rgba(255, 0, 0, 0.3);
-}
-
-#refresh_interval {
-    text-align: right;
-    width: 2.5em;
-}
-
-.updating {
-    background: url("../../public/img/loader/lmf-loader_16.gif") no-repeat left center;
-    padding-left: 20px;
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-marmotta/blob/5486b79f/platform/marmotta-core/target/classes/web/admin/css/sgvizler.chart.css
----------------------------------------------------------------------
diff --git a/platform/marmotta-core/target/classes/web/admin/css/sgvizler.chart.css b/platform/marmotta-core/target/classes/web/admin/css/sgvizler.chart.css
deleted file mode 100644
index 6cc17e9..0000000
--- a/platform/marmotta-core/target/classes/web/admin/css/sgvizler.chart.css
+++ /dev/null
@@ -1,52 +0,0 @@
-/**
- * Copyright (C) 2013 Salzburg Research.
- *
- * Licensed 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.
- */
-
-/*** sMap ***/
-
-div.sgvizler-sMap{
-    padding: 0;
-    margin: 0;
-    font-family: sans-serif;
-}
-div.sgvizler-sMap h1, div.sgvizler-sMap p{
-    font-size: 11pt;
-    margin: 2px 0 1px 0;
-}
-div.sgvizler-sMap p.text{
-    font-family: serif;
-}
-div.sgvizler-sMap div.img{
-    float: right;
-    padding: 10px;
-}
-
-/*** pForce ***/
-
-circle.node {
-  stroke: #999;
-  stroke-width: 0.5px;
-}
-
-line.link {
-  stroke: #999;
-  stroke-opacity: .6;
-}
-
-.nodetext { 
-    pointer-events: none; 
-    font: 10px sans-serif; 
-    color: black;
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-marmotta/blob/5486b79f/platform/marmotta-core/target/classes/web/admin/database.html
----------------------------------------------------------------------
diff --git a/platform/marmotta-core/target/classes/web/admin/database.html b/platform/marmotta-core/target/classes/web/admin/database.html
deleted file mode 100644
index f1c5678..0000000
--- a/platform/marmotta-core/target/classes/web/admin/database.html
+++ /dev/null
@@ -1,35 +0,0 @@
-<!--
-
-    Copyright (C) 2013 Salzburg Research.
-
-    Licensed 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.
-
--->
-<html>
-<head>
-    <!--###BEGIN_HEAD###-->
-    <title>Core Module</title>
-    <script type="text/javascript">
-        (function() {
-            window.open('../../database/');
-        })();
-    </script>
-    <!--###END_HEAD###-->
-</head>
-<body>
-<!--###BEGIN_CONTENT###-->
-<h1>Manage LMF database via web-interface</h1>
-<a href="../../database/" target="_blank">Open database administration page in new window.</a>
-<!--###END_CONTENT###-->
-</body>
-</html>
\ No newline at end of file