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

[08/13] ISIS-522: mothballing SQL OS.

http://git-wip-us.apache.org/repos/asf/isis/blob/40561609/component/objectstore/sql/sql-tests-common/src/main/java/org/apache/isis/objectstore/sql/common/SqlIntegrationTestFixtures.java
----------------------------------------------------------------------
diff --git a/component/objectstore/sql/sql-tests-common/src/main/java/org/apache/isis/objectstore/sql/common/SqlIntegrationTestFixtures.java b/component/objectstore/sql/sql-tests-common/src/main/java/org/apache/isis/objectstore/sql/common/SqlIntegrationTestFixtures.java
deleted file mode 100644
index ada7051..0000000
--- a/component/objectstore/sql/sql-tests-common/src/main/java/org/apache/isis/objectstore/sql/common/SqlIntegrationTestFixtures.java
+++ /dev/null
@@ -1,230 +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.isis.objectstore.sql.common;
-
-import java.io.FileInputStream;
-import java.sql.Connection;
-import java.sql.Driver;
-import java.sql.DriverManager;
-import java.sql.SQLException;
-import java.sql.Statement;
-import java.util.List;
-import java.util.Properties;
-
-import org.apache.isis.core.commons.config.IsisConfiguration;
-import org.apache.isis.core.commons.config.IsisConfigurationDefault;
-import org.apache.isis.core.commons.exceptions.IsisException;
-import org.apache.isis.core.integtestsupport.IsisSystemWithFixtures;
-import org.apache.isis.core.integtestsupport.IsisSystemWithFixtures.Fixtures.Initialization;
-import org.apache.isis.core.runtime.installerregistry.installerapi.PersistenceMechanismInstallerAbstract;
-import org.apache.isis.core.tck.dom.poly.ReferencingPolyTypesEntity;
-import org.apache.isis.core.tck.dom.scalars.PrimitiveValuedEntity;
-import org.apache.isis.core.tck.dom.sqlos.SqlDomainObjectRepository;
-import org.apache.isis.core.tck.dom.sqlos.data.SimpleClass;
-import org.apache.isis.core.tck.dom.sqlos.data.SimpleClassTwo;
-import org.apache.isis.core.tck.dom.sqlos.data.SqlDataClass;
-import org.apache.isis.objectstore.sql.SqlObjectStore;
-
-/**
- * @author Kevin
- * 
- */
-public class SqlIntegrationTestFixtures {
-
-    static SqlIntegrationTestFixtures instance;
-
-    public static SqlIntegrationTestFixtures getInstance() {
-        if (instance == null) {
-            instance = new SqlIntegrationTestFixtures();
-        }
-        return instance;
-    }
-
-    public static void recreate() {
-        instance = new SqlIntegrationTestFixtures();
-    }
-
-    public enum State {
-        INITIALIZE, DONT_INITIALIZE;
-
-        public boolean isInitialize() {
-            return this == INITIALIZE;
-        }
-    }
-
-    private State state = State.INITIALIZE;
-
-    public State getState() {
-        return state;
-    }
-
-    public void setState(final State state) {
-        this.state = state;
-    }
-
-    // /////////////////////////////////////////////////////////////////////////
-    //
-    // /////////////////////////////////////////////////////////////////////////
-
-    private IsisSystemWithFixtures system;
-
-    // JDBC
-    private Connection conn = null;
-    private Statement stmt = null;
-
-    public void initSystem(final String propertiesDirectory, final String propertiesFileName) throws Exception {
-
-        final Properties properties = new Properties();
-        properties.load(new FileInputStream(propertiesDirectory + "/" + propertiesFileName));
-
-        initSystem(properties);
-    }
-
-    public void initSystem(final Properties properties) throws Exception {
-        final IsisConfigurationDefault configuration = new IsisConfigurationDefault();
-        configuration.add(properties);
-
-        sqlDomainObjectRepository = new SqlDomainObjectRepository();
-        if (system != null) {
-            system.tearDownSystem();
-        }
-
-        final PersistenceMechanismInstallerAbstract persistorInstaller = Utils.createPersistorInstaller(configuration);
-        system =
-            IsisSystemWithFixtures.builder().with(configuration).withServices(sqlDomainObjectRepository)
-                .with(Initialization.NO_INIT).with(persistorInstaller).build();
-
-        system.setUpSystem();
-
-        registerDriverAndConnect(configuration);
-    }
-
-    public void shutDown() throws Exception {
-        if (system != null) {
-            system.tearDownSystem();
-        }
-    }
-
-    // /////////////////////////////////////////////////////////////////////////
-    //
-    // /////////////////////////////////////////////////////////////////////////
-
-    @SuppressWarnings("unchecked")
-    private void registerDriverAndConnect(final IsisConfiguration isisConfiguration) throws SQLException,
-        ClassNotFoundException, InstantiationException, IllegalAccessException {
-        final String jdbcClassName = isisConfiguration.getString(SqlObjectStore.BASE_NAME + ".jdbc.driver");
-        if (jdbcClassName == null) {
-            conn = null;
-            stmt = null;
-            return;
-        }
-        final Class<Driver> driverClass = (Class<Driver>) Class.forName(jdbcClassName);
-        final Driver driver = driverClass.newInstance();
-        DriverManager.registerDriver(driver);
-
-        // jdbc - connect to DB and drop tables.
-        conn =
-            DriverManager.getConnection(isisConfiguration.getString(SqlObjectStore.BASE_NAME + ".jdbc.connection"),
-                isisConfiguration.getString(SqlObjectStore.BASE_NAME + ".jdbc.user"),
-                isisConfiguration.getString(SqlObjectStore.BASE_NAME + ".jdbc.password"));
-        stmt = conn.createStatement();
-    }
-
-    public void dropTable(final String tableName) {
-        if (stmt == null) {
-            if (tableName.equalsIgnoreCase("sqldataclass")) {
-                final List<SqlDataClass> list = sqlDomainObjectRepository.allDataClasses();
-                for (final SqlDataClass sqlDataClass : list) {
-                    sqlDomainObjectRepository.delete(sqlDataClass);
-                }
-                return;
-            }
-            if (tableName.equalsIgnoreCase("simpleclass")) {
-                final List<SimpleClass> list = sqlDomainObjectRepository.allSimpleClasses();
-                for (final SimpleClass sqlClass : list) {
-                    sqlDomainObjectRepository.delete(sqlClass);
-                }
-                return;
-            }
-            if (tableName.equalsIgnoreCase("simpleclasstwo")) {
-                final List<SimpleClassTwo> list = sqlDomainObjectRepository.allSimpleClassTwos();
-                for (final SimpleClassTwo sqlClass : list) {
-                    sqlDomainObjectRepository.delete(sqlClass);
-                }
-                return;
-            }
-            if (tableName.equalsIgnoreCase("primitivevaluedentity")) {
-                final List<PrimitiveValuedEntity> list = sqlDomainObjectRepository.allPrimitiveValueEntities();
-                for (final PrimitiveValuedEntity pve : list) {
-                    sqlDomainObjectRepository.delete(pve);
-                }
-                return;
-            }
-            throw new IsisException("Unknown table: " + tableName);
-        }
-
-        try {
-            String tableIdentifier = Utils.tableIdentifierFor(tableName);
-            stmt.executeUpdate("DROP TABLE " + tableIdentifier);
-        } catch (final SQLException e) {
-            // this can happen, not a problem.
-            // e.printStackTrace();
-        }
-    }
-
-    public void sqlExecute(final String sqlString) throws SQLException {
-        if (stmt != null) {
-            stmt.executeUpdate(sqlString);
-        }
-    }
-
-    // /////////////////////////////////////////////////////////////////////////
-    //
-    // /////////////////////////////////////////////////////////////////////////
-
-    private SqlDomainObjectRepository sqlDomainObjectRepository = null;
-
-    private SqlDataClass sqlDataClass;
-    private ReferencingPolyTypesEntity referencingPolyTypesEntity;
-
-    public SqlDomainObjectRepository getSqlDataClassFactory() {
-        return sqlDomainObjectRepository;
-    }
-
-    public SqlDataClass getSqlDataClass() {
-        return sqlDataClass;
-    }
-
-    public void setSqlDataClass(SqlDataClass sqlDataClass) {
-        this.sqlDataClass = sqlDataClass;
-    }
-
-    public ReferencingPolyTypesEntity getPolyTestClass() {
-        return referencingPolyTypesEntity;
-    }
-
-    public void setPolyTestClass(final ReferencingPolyTypesEntity referencingPolyTypesEntity) {
-        this.referencingPolyTypesEntity = referencingPolyTypesEntity;
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/isis/blob/40561609/component/objectstore/sql/sql-tests-common/src/main/java/org/apache/isis/objectstore/sql/common/Utils.java
----------------------------------------------------------------------
diff --git a/component/objectstore/sql/sql-tests-common/src/main/java/org/apache/isis/objectstore/sql/common/Utils.java b/component/objectstore/sql/sql-tests-common/src/main/java/org/apache/isis/objectstore/sql/common/Utils.java
deleted file mode 100644
index c037e61..0000000
--- a/component/objectstore/sql/sql-tests-common/src/main/java/org/apache/isis/objectstore/sql/common/Utils.java
+++ /dev/null
@@ -1,61 +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.isis.objectstore.sql.common;
-
-import org.apache.isis.core.commons.config.IsisConfiguration;
-import org.apache.isis.core.objectstore.InMemoryPersistenceMechanismInstaller;
-import org.apache.isis.core.runtime.installerregistry.installerapi.PersistenceMechanismInstallerAbstract;
-import org.apache.isis.objectstore.sql.Sql;
-import org.apache.isis.objectstore.sql.SqlObjectStore;
-import org.apache.isis.objectstore.sql.SqlPersistorInstaller;
-import org.apache.isis.objectstore.xml.XmlPersistenceMechanismInstaller;
-
-public class Utils {
-
-    static PersistenceMechanismInstallerAbstract createPersistorInstaller(final IsisConfiguration configuration) {
-        
-        final String jdbcDriver = configuration.getString(SqlObjectStore.BASE_NAME + ".jdbc.driver");
-        if (jdbcDriver != null) {
-            return new SqlPersistorInstaller();
-        } 
-        
-        final String persistor = configuration.getString("isis.persistor");
-        if (persistor.equals(InMemoryPersistenceMechanismInstaller.NAME)) {
-            return new InMemoryPersistenceMechanismInstaller();
-        }
-        if (persistor.equals(XmlPersistenceMechanismInstaller.NAME)) {
-            return new XmlPersistenceMechanismInstaller();
-        }
-        if (persistor.equals(SqlPersistorInstaller.NAME)) {
-            return new SqlPersistorInstaller();
-        }
-        return new InMemoryPersistenceMechanismInstaller();
-    }
-
-    static String tableIdentifierFor(final String tableName) {
-        if (tableName.substring(0, 4).toUpperCase().equals("ISIS")) {
-            return Sql.tableIdentifier(tableName);
-        } else {
-            return Sql.tableIdentifier("isis_" + tableName);
-        }
-    }
-
-
-
-}

http://git-wip-us.apache.org/repos/asf/isis/blob/40561609/component/objectstore/sql/sql-tests-common/src/main/resources/log4j.properties
----------------------------------------------------------------------
diff --git a/component/objectstore/sql/sql-tests-common/src/main/resources/log4j.properties b/component/objectstore/sql/sql-tests-common/src/main/resources/log4j.properties
deleted file mode 100644
index b36337f..0000000
--- a/component/objectstore/sql/sql-tests-common/src/main/resources/log4j.properties
+++ /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.
-# apache's log4j is used to provide system logging.
-log4j.rootCategory=DEBUG, File
-log4j.rootCategory=INFO, Console
-
-
-# The console appender
-log4j.appender.Console=org.apache.log4j.ConsoleAppender
-log4j.appender.Console.target=System.out
-log4j.appender.Console.layout=org.apache.log4j.PatternLayout
-log4j.appender.Console.layout.ConversionPattern=%d{ABSOLUTE}  [%-20c{1} %-10t %-5p]  %m%n
-
-
-log4j.appender.File=org.apache.log4j.RollingFileAppender
-log4j.appender.File.file=isis.log
-log4j.appender.File.append=false
-#log4j.appender.File.maxFileSize=500KB
-#log4j.appender.File.maxBackupIndex=1
-log4j.appender.File.layout=org.apache.log4j.PatternLayout
-log4j.appender.File.layout.ConversionPattern=%d [%-20c{1} %-10t %-5p]  %m%n
-
-
-
-

http://git-wip-us.apache.org/repos/asf/isis/blob/40561609/component/objectstore/sql/sql-tests-common/src/site/apt/index.apt
----------------------------------------------------------------------
diff --git a/component/objectstore/sql/sql-tests-common/src/site/apt/index.apt b/component/objectstore/sql/sql-tests-common/src/site/apt/index.apt
deleted file mode 100644
index 025703e..0000000
--- a/component/objectstore/sql/sql-tests-common/src/site/apt/index.apt
+++ /dev/null
@@ -1,28 +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.
-
-
-
-SQL ObjectStore Integration Tests
-
- This module holds the integration tests for the {{{../index.html}SQL ObjectStore}}.
-
-Further Info
-  
- See this module's {{{./apidocs/index.html}Javadoc}} and {{{../docbkx/html/guide/isis-sql-objectstore.html}User Guide}} for more information.
- 
-

http://git-wip-us.apache.org/repos/asf/isis/blob/40561609/component/objectstore/sql/sql-tests-common/src/site/apt/jottings.apt
----------------------------------------------------------------------
diff --git a/component/objectstore/sql/sql-tests-common/src/site/apt/jottings.apt b/component/objectstore/sql/sql-tests-common/src/site/apt/jottings.apt
deleted file mode 100644
index c5d1200..0000000
--- a/component/objectstore/sql/sql-tests-common/src/site/apt/jottings.apt
+++ /dev/null
@@ -1,24 +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.
-
-
-
-Jottings
- 
-  This page is to capture any random jottings relating to this module prior 
-  to being moved into formal documentation. 
- 

http://git-wip-us.apache.org/repos/asf/isis/blob/40561609/component/objectstore/sql/sql-tests-common/src/site/site.xml
----------------------------------------------------------------------
diff --git a/component/objectstore/sql/sql-tests-common/src/site/site.xml b/component/objectstore/sql/sql-tests-common/src/site/site.xml
deleted file mode 100644
index 9aa405b..0000000
--- a/component/objectstore/sql/sql-tests-common/src/site/site.xml
+++ /dev/null
@@ -1,39 +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>
-
-    <body>
-        <breadcrumbs>
-            <item name="Tests"  href="index.html"/>
-        </breadcrumbs>
-
-        <menu name="SQL Objectstore Tests">
-            <item name="About" href="index.html" />
-        </menu>
-
-        <menu name="SQL OS Modules">
-            <item name="Implementation" href="../sql-impl/index.html" />
-            <item name="Tests" href="../sql-tests-common/index.html" />
-            <item name="Integration Tests" href="../sql-tests-served/index.html" />
-        </menu>
-
-        <menu name="Maven Reports" ref="reports" />
-    </body>
-</project>

http://git-wip-us.apache.org/repos/asf/isis/blob/40561609/component/objectstore/sql/sql-tests-common/src/test/config/hsql-poly.properties
----------------------------------------------------------------------
diff --git a/component/objectstore/sql/sql-tests-common/src/test/config/hsql-poly.properties b/component/objectstore/sql/sql-tests-common/src/test/config/hsql-poly.properties
deleted file mode 100644
index cd5ea6e..0000000
--- a/component/objectstore/sql/sql-tests-common/src/test/config/hsql-poly.properties
+++ /dev/null
@@ -1,29 +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.
-isis.persistor=sql
-
-isis.persistor.sql.jdbc.driver=org.hsqldb.jdbcDriver
-isis.persistor.sql.jdbc.connection=jdbc:hsqldb:file:hsql-db/polytests
-isis.persistor.sql.jdbc.user=sa
-isis.persistor.sql.jdbc.password=
-
-# testing
-isis.logging.objectstore=on
-isis.persistor.sql.default.command.beginTransaction=
-isis.persistor.sql.default.command.commitTransaction=
-isis.persistor.sql.default.command.abortTransaction=
-

http://git-wip-us.apache.org/repos/asf/isis/blob/40561609/component/objectstore/sql/sql-tests-common/src/test/config/hsql.properties
----------------------------------------------------------------------
diff --git a/component/objectstore/sql/sql-tests-common/src/test/config/hsql.properties b/component/objectstore/sql/sql-tests-common/src/test/config/hsql.properties
deleted file mode 100644
index 22c9758..0000000
--- a/component/objectstore/sql/sql-tests-common/src/test/config/hsql.properties
+++ /dev/null
@@ -1,33 +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.
-isis.persistor=sql
-
-isis.persistor.sql.jdbc.driver=org.hsqldb.jdbcDriver
-isis.persistor.sql.jdbc.connection=jdbc:hsqldb:file:hsql-db/tests
-isis.persistor.sql.jdbc.user=sa
-isis.persistor.sql.jdbc.password=
-
-# testing
-isis.persistor.sql.datatypes.string=VARCHAR(70)
-isis.persistor.sql.default.password.seed=gfkhgdf76453fhgj#$
-isis.persistor.sql.default.command.beginTransaction=
-isis.persistor.sql.default.command.commitTransaction=
-isis.persistor.sql.default.command.abortTransaction=
-
-isis.persistor.sql.datatypes.blob=BLOB(1000)
-
-

http://git-wip-us.apache.org/repos/asf/isis/blob/40561609/component/objectstore/sql/sql-tests-common/src/test/java/org/apache/isis/objectstore/sql/HsqlTest.java
----------------------------------------------------------------------
diff --git a/component/objectstore/sql/sql-tests-common/src/test/java/org/apache/isis/objectstore/sql/HsqlTest.java b/component/objectstore/sql/sql-tests-common/src/test/java/org/apache/isis/objectstore/sql/HsqlTest.java
deleted file mode 100644
index 17b9bfc..0000000
--- a/component/objectstore/sql/sql-tests-common/src/test/java/org/apache/isis/objectstore/sql/HsqlTest.java
+++ /dev/null
@@ -1,72 +0,0 @@
-/*
- *  Licensed to the Apache Software Foundation (ASF) under one
- *  or more contributor license agreements.  See the NOTICE file
- *  distributed with this work for additional information
- *  regarding copyright ownership.  The ASF licenses this file
- *  to you under the Apache License, Version 2.0 (the
- *  "License"); you may not use this file except in compliance
- *  with the License.  You may obtain a copy of the License at
- *
- *        http://www.apache.org/licenses/LICENSE-2.0
- *
- *  Unless required by applicable law or agreed to in writing,
- *  software distributed under the License is distributed on an
- *  "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- *  KIND, either express or implied.  See the License for the
- *  specific language governing permissions and limitations
- *  under the License.
- */
-package org.apache.isis.objectstore.sql;
-
-import org.junit.BeforeClass;
-import org.junit.FixMethodOrder;
-import org.junit.runners.MethodSorters;
-
-import org.apache.isis.core.unittestsupport.files.Files;
-import org.apache.isis.core.unittestsupport.files.Files.Recursion;
-import org.apache.isis.objectstore.sql.common.Data;
-import org.apache.isis.objectstore.sql.common.SqlIntegrationTestData;
-import org.apache.isis.objectstore.sql.common.SqlIntegrationTestFixtures;
-
-/**
- * @author Kevin kevin@kmz.co.za
- * 
- *         This test implementation uses the HyperSQL database engine to perform "serverless" tests of data creation and
- *         reloading.
- * 
- * 
- * @version $Rev$ $Date$
- */
-@FixMethodOrder(MethodSorters.NAME_ASCENDING)
-public class HsqlTest extends SqlIntegrationTestData {
-
-    @BeforeClass
-    public static void deleteHsqlDbFiles() {
-        Files.deleteFilesWithPrefix("hsql-db", "tests", Recursion.DONT_RECURSE);
-    }
-
-    @Override
-    protected void testCreate() throws Exception {
-        final SqlIntegrationTestFixtures sqlIntegrationTestFixtures = getSqlIntegrationTestFixtures();
-        for (final String tableName : Data.getTableNames()) {
-            sqlIntegrationTestFixtures.dropTable(tableName);
-        }
-        super.testCreate();
-    }
-
-    // @Override
-    // protected String getSqlSetupString() {
-    // return "COMMIT;";
-    // }
-
-    @Override
-    public String getPropertiesFilename() {
-        return "hsql.properties";
-    }
-
-    @Override
-    public String getSqlTeardownString() {
-        return "SHUTDOWN;";
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/isis/blob/40561609/component/objectstore/sql/sql-tests-common/src/test/java/org/apache/isis/objectstore/sql/PolymorphismTest.java
----------------------------------------------------------------------
diff --git a/component/objectstore/sql/sql-tests-common/src/test/java/org/apache/isis/objectstore/sql/PolymorphismTest.java b/component/objectstore/sql/sql-tests-common/src/test/java/org/apache/isis/objectstore/sql/PolymorphismTest.java
deleted file mode 100755
index 49039e5..0000000
--- a/component/objectstore/sql/sql-tests-common/src/test/java/org/apache/isis/objectstore/sql/PolymorphismTest.java
+++ /dev/null
@@ -1,374 +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.isis.objectstore.sql;
-
-import static org.hamcrest.CoreMatchers.is;
-import static org.junit.Assert.assertEquals;
-import static org.junit.Assert.assertNotNull;
-import static org.junit.Assert.assertThat;
-import static org.junit.Assert.assertTrue;
-
-import java.util.List;
-
-import org.junit.After;
-import org.junit.Before;
-import org.junit.BeforeClass;
-import org.junit.FixMethodOrder;
-import org.junit.Test;
-import org.junit.runners.MethodSorters;
-
-import org.apache.isis.core.runtime.system.context.IsisContext;
-import org.apache.isis.core.tck.dom.poly.Empty;
-import org.apache.isis.core.tck.dom.poly.EmptyEntityWithOwnProperty;
-import org.apache.isis.core.tck.dom.poly.ReferencingPolyTypesEntity;
-import org.apache.isis.core.tck.dom.poly.SelfReferencingEntity;
-import org.apache.isis.core.tck.dom.poly.StringBaseEntity;
-import org.apache.isis.core.tck.dom.poly.StringBaseEntitySub;
-import org.apache.isis.core.tck.dom.poly.StringBaseEntitySubThree;
-import org.apache.isis.core.tck.dom.poly.StringBaseEntitySubTwo;
-import org.apache.isis.core.tck.dom.poly.Stringable;
-import org.apache.isis.core.tck.dom.poly.StringableEntityWithOwnDerivedProperty;
-import org.apache.isis.core.tck.dom.poly.StringableEntityWithOwnProperties;
-import org.apache.isis.core.tck.dom.poly.StringableEntityWithOwnProperty;
-import org.apache.isis.core.unittestsupport.files.Files;
-import org.apache.isis.core.unittestsupport.files.Files.Recursion;
-import org.apache.isis.objectstore.sql.common.SqlIntegrationTestCommonBase;
-import org.apache.isis.objectstore.sql.common.SqlIntegrationTestFixtures;
-import org.apache.isis.objectstore.sql.common.SqlIntegrationTestFixtures.State;
-
-/**
- * @author Kevin kevin@kmz.co.za
- * 
- *         This test implementation uses the HyperSQL database engine to perform "serverless" tests of polymorphic class
- *         object creation and reloading.
- * 
- *         The sql object store thus allows your domain objects to have properties referenced via interface or
- *         superclass. Both single reference properties and property collections are supported.
- * 
- * 
- * @version $Rev$ $Date$
- */
-
-@FixMethodOrder(MethodSorters.NAME_ASCENDING)
-public class PolymorphismTest extends SqlIntegrationTestCommonBase {
-
-    private static final String IMPL_A_STRING = "Impl A String";
-    private static final String IMPL_B_STRING = "Impl B String";
-    private static final String CHILD_1 = "Child 1";
-
-    private static StringableEntityWithOwnProperty polyIntImpA;
-    private static StringableEntityWithOwnProperties polyIntImpB;
-
-    @Override
-    public String getPropertiesFilename() {
-        return "hsql-poly.properties";
-    }
-
-    @BeforeClass
-    public static void deleteHsqlDbFiles() {
-        Files.deleteFilesWithPrefix("hsql-db", "poly", Recursion.DONT_RECURSE);
-    }
-
-    @Override
-    public void resetPersistenceStoreDirectlyIfRequired() {
-        getSqlIntegrationTestFixtures();
-    }
-
-    @Override
-    public String getSqlTeardownString() {
-        return "SHUTDOWN;";
-    }
-
-    // Order is important. The next three "tests" must be executed in the correct sequential order.
-    @Test
-    /**
-     * Sets up the database connection and tells the test framework to create an instance of the 
-     * Isis framework for the next "test".
-     */
-    public void test1SetupStoreAndDatabaseConnection() throws Exception {
-        testSetup();
-    }
-
-    @Before
-    public void setUpXactn() throws Exception {
-        IsisContext.getTransactionManager().startTransaction();
-    }
-
-    @After
-    public void tearDownXactn() throws Exception {
-        IsisContext.getTransactionManager().endTransaction();
-        assertThat(IsisContext.getTransactionManager().getTransaction().getState().isComplete(), is(true));
-        
-    }
-
-    @Test
-    /**
-     * Uses the database connection to drop database tables related to these tests.
-     * This forces (and exercises the ability of) the object store to re-create the tables.
-     *  
-     * Also uses factory methods within the Isis framework to create the test data,
-     * thus exercising the "create data" portion of the object store.
-     * 
-     * The Isis framework will be again be re-created in the next test unless the 
-     * object store is "in-memory" (this is required since "in-memory" has to be
-     * left alone for created data to still be present in the next test).
-     */
-    public void test2SetupDataWithDatabaseConnection() throws Exception {
-        final SqlIntegrationTestFixtures sqlIntegrationTestFixtures = getSqlIntegrationTestFixtures();
-        sqlIntegrationTestFixtures.dropTable("ISIS_SELFREFERENCINGENTITY");
-        sqlIntegrationTestFixtures.dropTable("ISIS_STRINGABLEENTITYWITHOWNPROPERTY");
-        sqlIntegrationTestFixtures.dropTable("ISIS_STRINGABLEENTITYWITHOWNPROPERTIES");
-        sqlIntegrationTestFixtures.dropTable("ISIS_STRINGBASEENTITYSUB");
-        sqlIntegrationTestFixtures.dropTable("ISIS_STRINGBASEENTITYSUBTWO");
-        sqlIntegrationTestFixtures.dropTable("ISIS_STRINGBASEENTITYSUBTHREE");
-        sqlIntegrationTestFixtures.dropTable("ISIS_REFERENCINGPOLYTYPESENTITY");
-        sqlIntegrationTestFixtures.dropTable("ISIS_STRINGBASEENTITY");
-        sqlIntegrationTestFixtures.dropTable("ISIS_STRINGABLE");
-
-        final ReferencingPolyTypesEntity referencingPolyTypesEntity = factory.newPolyTestClass();
-        referencingPolyTypesEntity.setString("polyTestClassString");
-
-        // Setup self-referencing collection
-        final SelfReferencingEntity polySelfRefClassParent = factory.newPolySelfRefClass();
-        polySelfRefClassParent.setString("Parent");
-
-        final SelfReferencingEntity polySelfRefClassChild1 = factory.newPolySelfRefClass();
-        polySelfRefClassChild1.setString(CHILD_1);
-        polySelfRefClassParent.addToPolySelfRefClasses(polySelfRefClassChild1);
-
-        final SelfReferencingEntity polySelfRefClassChild2 = factory.newPolySelfRefClass();
-        polySelfRefClassChild2.setString("Child 2");
-        polySelfRefClassParent.addToPolySelfRefClasses(polySelfRefClassChild2);
-        factory.save(polySelfRefClassChild2);
-
-        final SelfReferencingEntity polySelfRefClassChild3 = factory.newPolySelfRefClass();
-        polySelfRefClassChild3.setString("Child 1 of Child 1");
-        polySelfRefClassChild1.addToPolySelfRefClasses(polySelfRefClassChild3);
-
-        factory.save(polySelfRefClassChild3);
-        factory.save(polySelfRefClassChild1);
-
-        factory.save(polySelfRefClassParent);
-        referencingPolyTypesEntity.setPolySelfRefClass(polySelfRefClassParent);
-
-        // polyTestClass.setPolyTestInterface(polyTestClass);
-
-        polyIntImpA = factory.newPolyInterfaceImplA();
-        polyIntImpA.setString(IMPL_A_STRING);
-        polyIntImpA.setSpecial("special");
-        factory.save(polyIntImpA);
-
-        referencingPolyTypesEntity.setPolyInterfaceType(polyIntImpA);
-        referencingPolyTypesEntity.getPolyInterfaces().add(polyIntImpA);
-
-        // setup the polyTestClass
-        final StringBaseEntitySub stringBaseEntitySub = factory.newPolySubClassOne();
-        stringBaseEntitySub.setStringBase("PolySubClassOne 1");
-        stringBaseEntitySub.setStringClassOne("Class 1");
-
-        final StringBaseEntitySubTwo stringBaseEntitySubTwo = factory.newPolySubClassTwo();
-        stringBaseEntitySubTwo.setStringBase("PolySubClassTwo 1");
-        stringBaseEntitySubTwo.setStringClassTwo("Class 2");
-
-        final StringBaseEntitySubThree stringBaseEntitySubThree = factory.newPolySubClassThree();
-        stringBaseEntitySubThree.setStringBase("PolySubClassThree 1");
-        stringBaseEntitySubThree.setStringClassThree("Another String");
-        stringBaseEntitySubThree.setStringClassTwo("Class 3");
-
-        referencingPolyTypesEntity.getPolyBaseClasses().add(stringBaseEntitySub);
-        referencingPolyTypesEntity.getPolyBaseClasses().add(stringBaseEntitySubTwo);
-        referencingPolyTypesEntity.getPolyBaseClasses().add(stringBaseEntitySubThree);
-
-        factory.save(stringBaseEntitySub);
-        factory.save(stringBaseEntitySubTwo);
-        factory.save(stringBaseEntitySubThree);
-
-        // store it and step the state engine
-        factory.save(referencingPolyTypesEntity);
-
-        setFixtureInitializationState(State.DONT_INITIALIZE, "in-memory");
-    }
-
-    /**
-     * The actual "tests". Unless the test is using the "in-memory" object store 
-     * the Isis framework is re-created, thus ensuring that no domain objects are
-     * left over from the previous "create" step, forcing the objects to be created
-     * via the object store.
-     * 
-     * Exercises the "restore data" portion of the object store.
-     * 
-     * Confirms that polymorphic classes are loaded as expected (via interface, 
-     * via super-class, etc.)
-     */
-    @Test
-    public void test3All() throws Exception {
-        load();
-
-        setUpFactory();
-
-        polymorphicLoad();
-        interfaceLoad();
-        loadSelfReferencingCollection();
-        interfaceLoadProperty();
-        interfaceLoadCollection();
-        interfaceEditSave();
-        interfaceEditLoad();
-        allInterfacesInstancesLoaded();
-        interfacesLoadedByQuery();
-        interfacesLoadedByQuerySpecial();
-        findByMatchPartialEntity();
-        cannotFindByMatchWithWrongValue();
-
-        // Must be here so that the Isis framework is initialised for the next test package.
-        setFixtureInitializationState(State.INITIALIZE);
-    }
-
-    private void load() {
-        final List<ReferencingPolyTypesEntity> dataClasses = factory.allPolyTestClasses();
-        assertEquals(1, dataClasses.size());
-        final ReferencingPolyTypesEntity referencingPolyTypesEntity = dataClasses.get(0);
-
-        getSqlIntegrationTestFixtures().setPolyTestClass(referencingPolyTypesEntity);
-
-        setFixtureInitializationState(State.DONT_INITIALIZE);
-    }
-
-    private void polymorphicLoad() {
-        final List<StringBaseEntity> polyBaseClasses = referencingPolyTypesEntity.getPolyBaseClasses();
-        assertEquals(3, polyBaseClasses.size());
-
-        StringBaseEntity polyClassBase = polyBaseClasses.get(0);
-        assertTrue(polyClassBase instanceof StringBaseEntitySub);
-        assertEquals("PolySubClassOne 1", polyClassBase.getStringBase());
-        final StringBaseEntitySub stringBaseEntitySub = (StringBaseEntitySub) polyClassBase;
-        assertEquals("Class 1", stringBaseEntitySub.getStringClassOne());
-
-        polyClassBase = polyBaseClasses.get(1);
-        assertTrue(polyClassBase instanceof StringBaseEntitySubTwo);
-        final StringBaseEntitySubTwo stringBaseEntitySubTwo = (StringBaseEntitySubTwo) polyClassBase;
-        assertEquals("Class 2", stringBaseEntitySubTwo.getStringClassTwo());
-
-        polyClassBase = polyBaseClasses.get(2);
-        assertTrue(polyClassBase instanceof StringBaseEntitySubThree);
-        final StringBaseEntitySubThree stringBaseEntitySubThree = (StringBaseEntitySubThree) polyClassBase;
-        assertEquals("Class 3", stringBaseEntitySubThree.getStringClassTwo());
-        assertEquals("Another String", stringBaseEntitySubThree.getStringClassThree());
-    }
-
-    private void interfaceLoad() {
-        final Stringable loaded = referencingPolyTypesEntity.getPolyInterfaceType();
-        factory.resolve(loaded);
-        assertEquals(polyIntImpA.getString(), loaded.getString());
-    }
-
-    private void loadSelfReferencingCollection() {
-        final SelfReferencingEntity polySelfRefParent = referencingPolyTypesEntity.getPolySelfRefClass();
-        final List<SelfReferencingEntity> list = polySelfRefParent.getPolySelfRefClasses();
-        assertEquals(2, list.size());
-
-        SelfReferencingEntity polySelfRefChild1 = null;
-        for (final SelfReferencingEntity selfReferencingEntity : list) {
-            if (selfReferencingEntity.getString().equals(CHILD_1)) {
-                polySelfRefChild1 = selfReferencingEntity;
-            }
-        }
-        assertNotNull(polySelfRefChild1);
-
-        assertEquals(CHILD_1, polySelfRefChild1.title());
-
-        List<SelfReferencingEntity> list2 = polySelfRefChild1.getPolySelfRefClasses();
-        factory.resolve(polySelfRefChild1);
-        list2 = polySelfRefChild1.getPolySelfRefClasses();
-        assertEquals(1, list2.size());
-    }
-
-    private void interfaceLoadProperty() {
-        final Stringable loaded = referencingPolyTypesEntity.getPolyInterfaceType();
-        assertEquals(polyIntImpA.getString(), loaded.getString());
-    }
-
-    private void interfaceLoadCollection() {
-        final List<Stringable> list = referencingPolyTypesEntity.getPolyInterfaces();
-
-        assertEquals(1, list.size());
-        final Stringable loaded = list.get(0);
-
-        assertEquals(polyIntImpA.getString(), loaded.getString());
-    }
-
-    private void interfaceEditSave() {
-        polyIntImpB = factory.newPolyInterfaceImplB();
-        polyIntImpB.setString(IMPL_B_STRING);
-        polyIntImpB.setSpecial("special");
-        polyIntImpB.setInteger(1);
-
-        factory.save(polyIntImpB);
-
-        referencingPolyTypesEntity.setPolyInterfaceType(polyIntImpB);
-
-        setFixtureInitializationState(State.INITIALIZE);
-    }
-
-    private void interfaceEditLoad() {
-        load(); // reload data
-
-        final Stringable loaded = referencingPolyTypesEntity.getPolyInterfaceType();
-        assertEquals(polyIntImpB.getString(), loaded.getString());
-    }
-
-    private void allInterfacesInstancesLoaded() {
-        final List<Stringable> list = factory.allPolyInterfaces();
-        assertEquals(2, list.size());
-    }
-
-    private void interfacesLoadedByQuery() {
-        // PolyInterface query = polyIntImpA;
-
-        final StringableEntityWithOwnDerivedProperty query = new StringableEntityWithOwnDerivedProperty();
-        query.setString(IMPL_A_STRING);
-
-        final List<Stringable> list = factory.queryPolyInterfaces(query);
-        assertEquals(1, list.size());
-    }
-
-    private void interfacesLoadedByQuerySpecial() {
-
-        final StringableEntityWithOwnDerivedProperty query = new StringableEntityWithOwnDerivedProperty();
-
-        final List<Stringable> list = factory.queryPolyInterfaces(query);
-        assertEquals(2, list.size());
-    }
-
-    private void findByMatchPartialEntity() {
-        final Empty match = new EmptyEntityWithOwnProperty();
-        final List<Empty> matches = factory.allEmptyInterfacesThatMatch(match);
-        assertEquals(1, matches.size());
-
-        final Empty empty = matches.get(0);
-        final StringableEntityWithOwnProperties imp = (StringableEntityWithOwnProperties) empty;
-        assertEquals(IMPL_B_STRING, imp.getString());
-    }
-
-    private void cannotFindByMatchWithWrongValue() {
-        final StringableEntityWithOwnProperties match = new StringableEntityWithOwnProperties();
-        match.setInteger(0);
-        final List<Empty> matches = factory.allEmptyInterfacesThatMatch(match);
-        assertEquals(0, matches.size());
-    }
-}

http://git-wip-us.apache.org/repos/asf/isis/blob/40561609/component/objectstore/sql/sql-tests-common/src/test/java/org/apache/isis/objectstore/sql/crosscheck/InMemoryPersistenceTest.java
----------------------------------------------------------------------
diff --git a/component/objectstore/sql/sql-tests-common/src/test/java/org/apache/isis/objectstore/sql/crosscheck/InMemoryPersistenceTest.java b/component/objectstore/sql/sql-tests-common/src/test/java/org/apache/isis/objectstore/sql/crosscheck/InMemoryPersistenceTest.java
deleted file mode 100644
index 4885b77..0000000
--- a/component/objectstore/sql/sql-tests-common/src/test/java/org/apache/isis/objectstore/sql/crosscheck/InMemoryPersistenceTest.java
+++ /dev/null
@@ -1,67 +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.isis.objectstore.sql.crosscheck;
-
-import java.util.Properties;
-
-import org.junit.FixMethodOrder;
-import org.junit.runners.MethodSorters;
-
-import org.apache.isis.objectstore.sql.common.SqlIntegrationTestData;
-import org.apache.isis.objectstore.sql.common.SqlIntegrationTestFixtures;
-import org.apache.isis.objectstore.sql.common.SqlIntegrationTestFixtures.State;
-
-@FixMethodOrder(MethodSorters.NAME_ASCENDING)
-public class InMemoryPersistenceTest extends SqlIntegrationTestData {
-
-    @Override
-    public Properties getProperties() {
-        final Properties properties = new Properties();
-        properties.put("isis.persistor", "in-memory");
-        properties.put("isis.logging.objectstore", "off");
-        return properties;
-    }
-
-    @Override
-    protected void testSetup() {
-        resetPersistenceStoreDirectlyIfRequired();
-        SqlIntegrationTestFixtures.recreate();
-        try {
-            SqlIntegrationTestFixtures.getInstance().initSystem(getProperties());
-        } catch (Exception e) {
-            e.printStackTrace();
-        }
-        getSqlIntegrationTestFixtures().setState(State.INITIALIZE);
-    }
-
-    @Override
-    public String getPropertiesFilename() {
-        return "inmemory.properties";
-    }
-
-    @Override
-    public String getSqlTeardownString() {
-        return "SHUTDOWN;";
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/isis/blob/40561609/component/objectstore/sql/sql-tests-common/src/test/java/org/apache/isis/objectstore/sql/crosscheck/XmlPersistenceTest.java
----------------------------------------------------------------------
diff --git a/component/objectstore/sql/sql-tests-common/src/test/java/org/apache/isis/objectstore/sql/crosscheck/XmlPersistenceTest.java b/component/objectstore/sql/sql-tests-common/src/test/java/org/apache/isis/objectstore/sql/crosscheck/XmlPersistenceTest.java
deleted file mode 100644
index 1916a95..0000000
--- a/component/objectstore/sql/sql-tests-common/src/test/java/org/apache/isis/objectstore/sql/crosscheck/XmlPersistenceTest.java
+++ /dev/null
@@ -1,65 +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.isis.objectstore.sql.crosscheck;
-
-import java.util.Properties;
-
-import org.apache.isis.core.unittestsupport.files.Files;
-import org.apache.isis.core.unittestsupport.files.Files.Recursion;
-import org.apache.isis.objectstore.sql.common.SqlIntegrationTestData;
-import org.apache.isis.objectstore.sql.common.SqlIntegrationTestFixtures;
-import org.apache.isis.objectstore.sql.common.SqlIntegrationTestFixtures.State;
-
-public class XmlPersistenceTest extends SqlIntegrationTestData {
-
-    @Override
-    public void resetPersistenceStoreDirectlyIfRequired() {
-        Files.deleteFiles("xml/objects", ".xml", Recursion.DO_RECURSE);
-    }
-
-    @Override
-    protected void testSetup() {
-        resetPersistenceStoreDirectlyIfRequired();
-        SqlIntegrationTestFixtures.recreate();
-        try {
-            SqlIntegrationTestFixtures.getInstance().initSystem(getProperties());
-        } catch (Exception e) {
-            e.printStackTrace();
-        }
-        getSqlIntegrationTestFixtures().setState(State.INITIALIZE);
-    }
-
-    @Override
-    public Properties getProperties() {
-        final Properties properties = new Properties();
-        properties.put("isis.persistor", "xml");
-        properties.put("isis.logging.objectstore", "off");
-        return properties;
-    }
-
-    @Override
-    public String getPropertiesFilename() {
-        return "xml.properties";
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/isis/blob/40561609/component/objectstore/sql/sql-tests-served/pom.xml
----------------------------------------------------------------------
diff --git a/component/objectstore/sql/sql-tests-served/pom.xml b/component/objectstore/sql/sql-tests-served/pom.xml
deleted file mode 100644
index 1fc1aef..0000000
--- a/component/objectstore/sql/sql-tests-served/pom.xml
+++ /dev/null
@@ -1,163 +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/maven-v4_0_0.xsd">
-
-    <modelVersion>4.0.0</modelVersion>
-
-    <parent>
-        <groupId>org.apache.isis.objectstore</groupId>
-        <artifactId>isis-objectstore-sql</artifactId>
-        <version>1.0.0-SNAPSHOT</version>
-    </parent>
-
-    <artifactId>isis-objectstore-sql-tests-served</artifactId>
-
-    <name>Isis SQL ObjectStore Integration Tests - Served</name>
-
-    <properties>
-	    <siteBaseDir>..</siteBaseDir>
-		<relativeUrl>sql-tests-served/</relativeUrl>
-
-        <postgresql.version>9.2-1002.jdbc4</postgresql.version>
-        <mysql.version>5.1.25</mysql.version>
-    </properties>
-
-    <!-- used in Site generation for relative references. -->
-    <url>http://isis.apache.org/${relativeUrl}</url>
-
-    <description>Runs the common tests against a few server implementations.
-Just add your server implementation to org.apache.isis.extensions.sql.objectstore</description>
-    <build>
-        <plugins>
-            <!-- TODO: currently set to ignore test failures -->
-            <plugin>
-                <groupId>org.apache.maven.plugins</groupId>
-                <artifactId>maven-surefire-plugin</artifactId>
-                <configuration>
-                    <testFailureIgnore>true</testFailureIgnore>
-                </configuration>
-            </plugin>
-        </plugins>
-    </build>
-
-    <reporting>
-        <plugins>
-            <plugin>
-                <groupId>org.apache.maven.plugins</groupId>
-                <artifactId>maven-project-info-reports-plugin</artifactId>
-				<version>${maven-project-info-reports-plugin}</version>
-                <inherited>false</inherited>
-                <configuration>
-                	<dependencyLocationsEnabled>false</dependencyLocationsEnabled>
-                </configuration>
-                <reportSets>
-                    <reportSet>
-                        <inherited>false</inherited>
-                        <reports>
-                            <report>dependency-management</report>
-                            <report>dependencies</report>
-                            <report>dependency-convergence</report>
-                            <report>plugins</report>
-                            <report>summary</report>
-                        </reports>
-                    </reportSet>
-                </reportSets>
-            </plugin>
-        </plugins>
-    </reporting>
-
-    <dependencyManagement>
-        <dependencies>
-			<!-- SQL integration tests common -->
-            <dependency>
-				<groupId>${project.groupId}</groupId>
-                <artifactId>isis-objectstore-sql-tests-common</artifactId>
-				<version>${project.version}</version>
-            </dependency>
-
-            <!-- JDBC drivers -->
-            <dependency>
-                <groupId>postgresql</groupId>
-                <artifactId>postgresql</artifactId>
-                <version>${postgresql.version}</version>
-            </dependency>
-            <dependency>
-                <groupId>mysql</groupId>
-                <artifactId>mysql-connector-java</artifactId>
-                <version>${mysql.version}</version>
-            </dependency>
-        </dependencies>
-    </dependencyManagement>
-
-    <dependencies>
-
-        <dependency>
-            <groupId>org.apache.isis.core</groupId>
-            <artifactId>isis-core-runtime</artifactId>
-        </dependency>
-        <!--  Required for TestProxy -->
-		<!-- Isis defaults -->
-        <dependency>
-            <groupId>org.apache.isis.core</groupId>
-            <artifactId>isis-core-objectstore</artifactId>
-        </dependency>
-        <dependency>
-            <groupId>org.apache.isis.core</groupId>
-            <artifactId>isis-core-objectstore</artifactId>
-            <type>test-jar</type>
-            <scope>test</scope>
-        </dependency>
-        <dependency>
-        	<groupId>org.apache.isis.core</groupId>
-        	<artifactId>isis-core-bytecode-cglib</artifactId>
-            <scope>test</scope>
-        </dependency>
-
-
-		<!-- Isis Object store -->
-        <dependency>
-		<groupId>${project.groupId}</groupId>
-            <artifactId>isis-objectstore-sql-impl</artifactId>
-        </dependency>
-
-		<!-- Test common -->
-        <dependency>
-            <groupId>${project.groupId}</groupId>
-            <artifactId>isis-objectstore-sql-tests-common</artifactId>
-        </dependency>
-		<dependency>
-			<groupId>${project.groupId}</groupId>
-			<artifactId>isis-objectstore-sql-tests-common</artifactId>
-            <type>test-jar</type>
-        	<scope>test</scope>
-		</dependency>
-
-
-        <!-- Required to support the implemented servers -->
-        <dependency>
-            <groupId>postgresql</groupId>
-            <artifactId>postgresql</artifactId>
-        </dependency>
-        <dependency>
-            <groupId>mysql</groupId>
-            <artifactId>mysql-connector-java</artifactId>
-        </dependency>
-    </dependencies>
-</project>

http://git-wip-us.apache.org/repos/asf/isis/blob/40561609/component/objectstore/sql/sql-tests-served/src/main/resources/log4j.properties
----------------------------------------------------------------------
diff --git a/component/objectstore/sql/sql-tests-served/src/main/resources/log4j.properties b/component/objectstore/sql/sql-tests-served/src/main/resources/log4j.properties
deleted file mode 100644
index bcafd74..0000000
--- a/component/objectstore/sql/sql-tests-served/src/main/resources/log4j.properties
+++ /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.
-# apache's log4j is used to provide system logging.
-log4j.rootCategory=DEBUG, Console, File
-#log4j.rootCategory=INFO, Console, File
-
-
-# The console appender
-log4j.appender.Console=org.apache.log4j.ConsoleAppender
-log4j.appender.Console.target=System.out
-log4j.appender.Console.layout=org.apache.log4j.PatternLayout
-log4j.appender.Console.layout.ConversionPattern=%d{ABSOLUTE}  [%-20c{1} %-10t %-5p]  %m%n
-
-
-log4j.appender.File=org.apache.log4j.RollingFileAppender
-log4j.appender.File.file=isis.log
-log4j.appender.File.append=false
-#log4j.appender.File.maxFileSize=500KB
-#log4j.appender.File.maxBackupIndex=1
-log4j.appender.File.layout=org.apache.log4j.PatternLayout
-log4j.appender.File.layout.ConversionPattern=%d [%-20c{1} %-10t %-5p]  %m%n
-
-
-
-

http://git-wip-us.apache.org/repos/asf/isis/blob/40561609/component/objectstore/sql/sql-tests-served/src/site/apt/index.apt
----------------------------------------------------------------------
diff --git a/component/objectstore/sql/sql-tests-served/src/site/apt/index.apt b/component/objectstore/sql/sql-tests-served/src/site/apt/index.apt
deleted file mode 100644
index 1668418..0000000
--- a/component/objectstore/sql/sql-tests-served/src/site/apt/index.apt
+++ /dev/null
@@ -1,29 +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.
-
-
-
-SQL ObjectStore Integration Tests
-  
-  This module runs tests against a few common database servers.
-
-  It will need to be configured for your server environment.
-
-Further Info
-  
- See this module's {{{./apidocs/index.html}Javadoc}} and {{{../docbkx/html/guide/isis-sql-objectstore.html}User Guide}} for more information.
-

http://git-wip-us.apache.org/repos/asf/isis/blob/40561609/component/objectstore/sql/sql-tests-served/src/site/apt/jottings.apt
----------------------------------------------------------------------
diff --git a/component/objectstore/sql/sql-tests-served/src/site/apt/jottings.apt b/component/objectstore/sql/sql-tests-served/src/site/apt/jottings.apt
deleted file mode 100644
index c5d1200..0000000
--- a/component/objectstore/sql/sql-tests-served/src/site/apt/jottings.apt
+++ /dev/null
@@ -1,24 +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.
-
-
-
-Jottings
- 
-  This page is to capture any random jottings relating to this module prior 
-  to being moved into formal documentation. 
- 

http://git-wip-us.apache.org/repos/asf/isis/blob/40561609/component/objectstore/sql/sql-tests-served/src/site/site.xml
----------------------------------------------------------------------
diff --git a/component/objectstore/sql/sql-tests-served/src/site/site.xml b/component/objectstore/sql/sql-tests-served/src/site/site.xml
deleted file mode 100644
index 521d3ce..0000000
--- a/component/objectstore/sql/sql-tests-served/src/site/site.xml
+++ /dev/null
@@ -1,39 +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>
-
-    <body>
-        <breadcrumbs>
-            <item name="Integration Tests"  href="index.html"/>
-        </breadcrumbs>
-
-        <menu name="SQL ObjectStore Tests">
-            <item name="About" href="index.html" />
-        </menu>
-
-        <menu name="SQL OS Modules">
-            <item name="Implementation" href="../sql-impl/index.html" />
-            <item name="Common Tests" href="../sql-tests-common/index.html" />
-            <item name="Integration Tests" href="../sql-tests-served/index.html" />
-        </menu>
-
-        <menu name="Maven Reports" ref="reports" />
-    </body>
-</project>

http://git-wip-us.apache.org/repos/asf/isis/blob/40561609/component/objectstore/sql/sql-tests-served/src/test/config/db2.properties
----------------------------------------------------------------------
diff --git a/component/objectstore/sql/sql-tests-served/src/test/config/db2.properties b/component/objectstore/sql/sql-tests-served/src/test/config/db2.properties
deleted file mode 100644
index 4e5195d..0000000
--- a/component/objectstore/sql/sql-tests-served/src/test/config/db2.properties
+++ /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.
-
-
-
-# Sample configuration
-# Edit this file with your server and authentication details.
-
-# DB2 test
-isis.persistence.sql.jdbc.driver=com.ibm.db2.jcc.DB2Driver
-isis.persistence.sql.jdbc.connection=jdbc:db2://gtd-dev:50000/proddb
-isis.persistence.sql.jdbc.user=db2admin
-isis.persistence.sql.jdbc.password=db2srvtest

http://git-wip-us.apache.org/repos/asf/isis/blob/40561609/component/objectstore/sql/sql-tests-served/src/test/config/mssqlserver.properties
----------------------------------------------------------------------
diff --git a/component/objectstore/sql/sql-tests-served/src/test/config/mssqlserver.properties b/component/objectstore/sql/sql-tests-served/src/test/config/mssqlserver.properties
deleted file mode 100644
index b1db3b7..0000000
--- a/component/objectstore/sql/sql-tests-served/src/test/config/mssqlserver.properties
+++ /dev/null
@@ -1,32 +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.
-
-
-
-# Sample configuration
-# Edit this file with your server and authentication details.
-
-
-# SQL Server
-#isis.persistence.sql.jdbc.driver=com.microsoft.sqlserver.jdbc.SQLServerDriver
-#isis.persistence.sql.jdbc.connection=jdbc:sqlserver://SPRSRMS21;databaseName=AnalyticalData
-
-isis.persistence.sql.jdbc.driver=net.sourceforge.jtds.jdbc.Driver
-isis.persistence.sql.jdbc.connection=jdbc:jtds:sqlserver://SPRSRMS21;databaseName=AnalyticalData
-
-isis.persistence.sql.jdbc.user=grip
-isis.persistence.sql.jdbc.password=grip

http://git-wip-us.apache.org/repos/asf/isis/blob/40561609/component/objectstore/sql/sql-tests-served/src/test/config/mysql.properties
----------------------------------------------------------------------
diff --git a/component/objectstore/sql/sql-tests-served/src/test/config/mysql.properties b/component/objectstore/sql/sql-tests-served/src/test/config/mysql.properties
deleted file mode 100644
index 117c681..0000000
--- a/component/objectstore/sql/sql-tests-served/src/test/config/mysql.properties
+++ /dev/null
@@ -1,29 +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.
-
-
-# Sample configuration
-# Edit this file with your server and authentication details.
-#
-# If this file exists, it overrides the MySqlTest#getProperties() method
-isis.persistor.sql.jdbc.driver=com.mysql.jdbc.Driver
-isis.persistor.sql.jdbc.connection=jdbc:mysql://abacus/noftest?useTimezone=false
-#true&serverTimezone=GMT
-isis.persistor.sql.jdbc.user=nof
-isis.persistor.sql.jdbc.password=
-
-isis.persistor.sql.datatypes.double=DOUBLE PRECISION
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/isis/blob/40561609/component/objectstore/sql/sql-tests-served/src/test/config/postgresql.properties
----------------------------------------------------------------------
diff --git a/component/objectstore/sql/sql-tests-served/src/test/config/postgresql.properties b/component/objectstore/sql/sql-tests-served/src/test/config/postgresql.properties
deleted file mode 100644
index b9fccfb..0000000
--- a/component/objectstore/sql/sql-tests-served/src/test/config/postgresql.properties
+++ /dev/null
@@ -1,29 +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.
-
-
-# Sample configuration
-# Edit this file with your server and authentication details.
-# If this file exists, it overrides the PostreSqlTest#getProperties() method
-isis.persistor.sql.jdbc.driver=org.postgresql.Driver
-isis.persistor.sql.jdbc.connection=jdbc:postgresql://abacus/noftest
-isis.persistor.sql.jdbc.user=nof
-isis.persistor.sql.jdbc.password=
-
-isis.persistor.sql.datatypes.timestamp=TIMESTAMP
-isis.persistor.sql.datatypes.datetime=TIMESTAMP
-isis.persistor.sql.datatypes.double=DOUBLE PRECISION
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/isis/blob/40561609/component/objectstore/sql/sql-tests-served/src/test/java/org/apache/isis/objectstore/sql/MySqlIntegrationTest.java
----------------------------------------------------------------------
diff --git a/component/objectstore/sql/sql-tests-served/src/test/java/org/apache/isis/objectstore/sql/MySqlIntegrationTest.java b/component/objectstore/sql/sql-tests-served/src/test/java/org/apache/isis/objectstore/sql/MySqlIntegrationTest.java
deleted file mode 100644
index 25e838a..0000000
--- a/component/objectstore/sql/sql-tests-served/src/test/java/org/apache/isis/objectstore/sql/MySqlIntegrationTest.java
+++ /dev/null
@@ -1,55 +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.isis.objectstore.sql;
-
-import java.util.Properties;
-
-import org.apache.isis.objectstore.sql.common.SqlIntegrationTestData;
-
-public class MySqlIntegrationTest extends SqlIntegrationTestData {
-
-    /**/
-    @Override
-    public Properties getProperties() {
-        Properties properties = super.getProperties();
-        if (properties == null) {
-            // Only used if *sql.properties is not found
-            properties = new Properties();
-            properties.put(SqlObjectStore.BASE_NAME + ".jdbc.driver", "com.mysql.jdbc.Driver");
-            // properties.put(SqlObjectStore.BASE_NAME + ".jdbc.connection",
-            // "jdbc:mysql://abacus/noftest&useTimezone=true&serverTimezone=GMT");
-            properties.put(SqlObjectStore.BASE_NAME + ".jdbc.connection", "jdbc:mysql://abacus/noftest&useLegacyDatetimeCode=false");
-            properties.put(SqlObjectStore.BASE_NAME + ".jdbc.user", "nof");
-            properties.put(SqlObjectStore.BASE_NAME + ".jdbc.jdbc.password", "");
-        }
-        return properties;
-    }
-
-    /**/
-
-    @Override
-    public String getPropertiesFilename() {
-        return "mysql.properties";
-    }
-    
-}

http://git-wip-us.apache.org/repos/asf/isis/blob/40561609/component/objectstore/sql/sql-tests-served/src/test/java/org/apache/isis/objectstore/sql/PostgreSqlIntegrationTest.java
----------------------------------------------------------------------
diff --git a/component/objectstore/sql/sql-tests-served/src/test/java/org/apache/isis/objectstore/sql/PostgreSqlIntegrationTest.java b/component/objectstore/sql/sql-tests-served/src/test/java/org/apache/isis/objectstore/sql/PostgreSqlIntegrationTest.java
deleted file mode 100644
index b3ca865..0000000
--- a/component/objectstore/sql/sql-tests-served/src/test/java/org/apache/isis/objectstore/sql/PostgreSqlIntegrationTest.java
+++ /dev/null
@@ -1,56 +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.isis.objectstore.sql;
-
-import java.util.Properties;
-
-import org.apache.isis.objectstore.sql.common.SqlIntegrationTestData;
-
-public class PostgreSqlIntegrationTest extends SqlIntegrationTestData {
-
-    @Override
-    public Properties getProperties() {
-        Properties properties = super.getProperties();
-        if (properties == null) {
-            properties = new Properties();
-            // Only used if src/test/config/postgresql.properties does not
-            // exist.
-            properties.put(SqlObjectStore.BASE_NAME + ".jdbc.driver", "org.postgresql.Driver");
-            properties.put(SqlObjectStore.BASE_NAME + ".jdbc.connection", "jdbc:postgresql://abacus/noftest");
-            properties.put(SqlObjectStore.BASE_NAME + ".jdbc.user", "nof");
-            properties.put(SqlObjectStore.BASE_NAME + ".jdbc.password", "");
-
-            // properties.put(SqlObjectStore.BASE_NAME + ".datatypes.timestamp",
-            // "TIMESTAMP");
-            // properties.put(SqlObjectStore.BASE_NAME + ".datatypes.datetime",
-            // "TIMESTAMP");
-        }
-        return properties;
-    }
-
-    @Override
-    public String getPropertiesFilename() {
-        return "postgresql.properties";
-    }
-
-}