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/07/12 09:08:32 UTC

[16/19] ISIS-463: mothballing BDD viewer

http://git-wip-us.apache.org/repos/asf/isis/blob/7276dc0b/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/fixtures/perform/checkthat/action/ArgumentSetValid.java
----------------------------------------------------------------------
diff --git a/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/fixtures/perform/checkthat/action/ArgumentSetValid.java b/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/fixtures/perform/checkthat/action/ArgumentSetValid.java
deleted file mode 100644
index 666b2e3..0000000
--- a/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/fixtures/perform/checkthat/action/ArgumentSetValid.java
+++ /dev/null
@@ -1,69 +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.viewer.bdd.common.fixtures.perform.checkthat.action;
-
-import java.util.List;
-
-import org.apache.isis.core.metamodel.adapter.ObjectAdapter;
-import org.apache.isis.core.metamodel.consent.Consent;
-import org.apache.isis.core.metamodel.spec.feature.ObjectAction;
-import org.apache.isis.core.metamodel.spec.feature.ObjectMember;
-import org.apache.isis.viewer.bdd.common.CellBinding;
-import org.apache.isis.viewer.bdd.common.ScenarioBoundValueException;
-import org.apache.isis.viewer.bdd.common.ScenarioCell;
-import org.apache.isis.viewer.bdd.common.fixtures.perform.PerformContext;
-import org.apache.isis.viewer.bdd.common.fixtures.perform.checkthat.ThatSubcommandAbstract;
-
-public class ArgumentSetValid extends ThatSubcommandAbstract {
-
-    public ArgumentSetValid() {
-        super("is valid for", "is valid", "valid");
-    }
-
-    // TODO: a lot of duplication with InvokeAction; simplify somehow?
-    @Override
-    public ObjectAdapter that(final PerformContext performContext) throws ScenarioBoundValueException {
-
-        final ObjectAdapter onAdapter = performContext.getOnAdapter();
-        final ObjectMember nakedObjectMember = performContext.getObjectMember();
-        final CellBinding onMemberBinding = performContext.getPeer().getOnMemberBinding();
-        final List<ScenarioCell> argumentCells = performContext.getArgumentCells();
-
-        final ObjectAction nakedObjectAction = (ObjectAction) nakedObjectMember;
-        final int parameterCount = nakedObjectAction.getParameterCount();
-        final boolean isContributedOneArgAction = nakedObjectAction.isContributed() && parameterCount == 1;
-
-        if (isContributedOneArgAction) {
-            return null;
-        }
-
-        // lookup arguments
-        final ObjectAdapter[] proposedArguments = performContext.getPeer().getAdapters(onAdapter, nakedObjectAction, onMemberBinding, argumentCells);
-
-        // validate arguments
-        final Consent argSetValid = nakedObjectAction.isProposedArgumentSetValid(onAdapter, proposedArguments);
-        if (argSetValid.isVetoed()) {
-            throw ScenarioBoundValueException.current(onMemberBinding, argSetValid.getReason());
-        }
-
-        // execute
-        return null;
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/isis/blob/7276dc0b/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/fixtures/perform/checkthat/collections/Containment.java
----------------------------------------------------------------------
diff --git a/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/fixtures/perform/checkthat/collections/Containment.java b/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/fixtures/perform/checkthat/collections/Containment.java
deleted file mode 100644
index ba485fb..0000000
--- a/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/fixtures/perform/checkthat/collections/Containment.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.viewer.bdd.common.fixtures.perform.checkthat.collections;
-
-import org.apache.isis.core.metamodel.adapter.ObjectAdapter;
-import org.apache.isis.core.metamodel.spec.feature.ObjectMember;
-import org.apache.isis.viewer.bdd.common.CellBinding;
-import org.apache.isis.viewer.bdd.common.ScenarioBoundValueException;
-import org.apache.isis.viewer.bdd.common.ScenarioCell;
-import org.apache.isis.viewer.bdd.common.fixtures.perform.PerformContext;
-import org.apache.isis.viewer.bdd.common.fixtures.perform.checkthat.AssertsContainment;
-
-public class Containment extends ThatAbstract {
-
-    private final AssertsContainment assertion;
-
-    public Containment(final AssertsContainment assertion) {
-        super(assertion.getKey());
-        this.assertion = assertion;
-    }
-
-    @Override
-    protected void doThat(final PerformContext performContext, final Iterable<ObjectAdapter> collection) throws ScenarioBoundValueException {
-
-        final ObjectMember nakedObjectMember = performContext.getObjectMember();
-        final CellBinding thatBinding = performContext.getPeer().getThatItBinding();
-        final CellBinding arg0Binding = performContext.getPeer().getArg0Binding();
-
-        if (!arg0Binding.isFound()) {
-            throw ScenarioBoundValueException.current(thatBinding, "(requires argument)");
-        }
-
-        final ScenarioCell arg0Cell = arg0Binding.getCurrentCell();
-
-        final ObjectAdapter containedAdapter = performContext.getPeer().getAdapter(null, nakedObjectMember.getSpecification(), arg0Binding, arg0Cell);
-
-        boolean contains = false;
-        for (final ObjectAdapter eachAdapter : collection) {
-            if (containedAdapter == eachAdapter) {
-                contains = true;
-                break;
-            }
-        }
-
-        if (!assertion.isSatisfiedBy(contains)) {
-            throw ScenarioBoundValueException.current(arg0Binding, assertion.getErrorMsgIfNotSatisfied());
-        }
-
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/isis/blob/7276dc0b/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/fixtures/perform/checkthat/collections/Emptiness.java
----------------------------------------------------------------------
diff --git a/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/fixtures/perform/checkthat/collections/Emptiness.java b/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/fixtures/perform/checkthat/collections/Emptiness.java
deleted file mode 100644
index e07ad75..0000000
--- a/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/fixtures/perform/checkthat/collections/Emptiness.java
+++ /dev/null
@@ -1,51 +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.viewer.bdd.common.fixtures.perform.checkthat.collections;
-
-import org.apache.isis.core.metamodel.adapter.ObjectAdapter;
-import org.apache.isis.viewer.bdd.common.CellBinding;
-import org.apache.isis.viewer.bdd.common.ScenarioBoundValueException;
-import org.apache.isis.viewer.bdd.common.fixtures.perform.PerformContext;
-import org.apache.isis.viewer.bdd.common.fixtures.perform.checkthat.AssertsEmpty;
-
-public class Emptiness extends ThatAbstract {
-
-    private final AssertsEmpty assertion;
-
-    public Emptiness(final AssertsEmpty assertion) {
-        super(assertion.getKey());
-        this.assertion = assertion;
-    }
-
-    @Override
-    protected void doThat(final PerformContext performContext, final Iterable<ObjectAdapter> collection) throws ScenarioBoundValueException {
-
-        boolean empty = true;
-        for (@SuppressWarnings("unused")
-        final ObjectAdapter eachObject : collection) {
-            empty = false;
-        }
-
-        if (!assertion.isSatisfiedBy(empty)) {
-            final CellBinding thatItBinding = performContext.getPeer().getThatItBinding();
-            throw ScenarioBoundValueException.current(thatItBinding, assertion.getErrorMsgIfNotSatisfied());
-        }
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/isis/blob/7276dc0b/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/fixtures/perform/checkthat/collections/ProposedAddTo.java
----------------------------------------------------------------------
diff --git a/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/fixtures/perform/checkthat/collections/ProposedAddTo.java b/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/fixtures/perform/checkthat/collections/ProposedAddTo.java
deleted file mode 100644
index 95cfd4c..0000000
--- a/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/fixtures/perform/checkthat/collections/ProposedAddTo.java
+++ /dev/null
@@ -1,43 +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.viewer.bdd.common.fixtures.perform.checkthat.collections;
-
-import org.apache.isis.core.metamodel.adapter.ObjectAdapter;
-import org.apache.isis.core.metamodel.consent.Consent;
-import org.apache.isis.core.metamodel.spec.feature.OneToManyAssociation;
-import org.apache.isis.viewer.bdd.common.fixtures.perform.PerformContext;
-import org.apache.isis.viewer.bdd.common.fixtures.perform.checkthat.AssertsValidity;
-import org.apache.isis.viewer.bdd.common.fixtures.perform.checkthat.ProposedArgumentValidityAbstract;
-
-public class ProposedAddTo extends ProposedArgumentValidityAbstract {
-
-    public ProposedAddTo(final AssertsValidity assertion) {
-        super(assertion);
-    }
-
-    @Override
-    protected Consent determineConsent(final PerformContext performContext, final ObjectAdapter toValidateAdapter) {
-
-        final ObjectAdapter onAdapter = performContext.getOnAdapter();
-        final OneToManyAssociation otma = (OneToManyAssociation) performContext.getObjectMember();
-
-        return otma.isValidToAdd(onAdapter, toValidateAdapter);
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/isis/blob/7276dc0b/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/fixtures/perform/checkthat/collections/ProposedRemoveFrom.java
----------------------------------------------------------------------
diff --git a/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/fixtures/perform/checkthat/collections/ProposedRemoveFrom.java b/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/fixtures/perform/checkthat/collections/ProposedRemoveFrom.java
deleted file mode 100644
index dc03f81..0000000
--- a/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/fixtures/perform/checkthat/collections/ProposedRemoveFrom.java
+++ /dev/null
@@ -1,43 +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.viewer.bdd.common.fixtures.perform.checkthat.collections;
-
-import org.apache.isis.core.metamodel.adapter.ObjectAdapter;
-import org.apache.isis.core.metamodel.consent.Consent;
-import org.apache.isis.core.metamodel.spec.feature.OneToManyAssociation;
-import org.apache.isis.viewer.bdd.common.fixtures.perform.PerformContext;
-import org.apache.isis.viewer.bdd.common.fixtures.perform.checkthat.AssertsValidity;
-import org.apache.isis.viewer.bdd.common.fixtures.perform.checkthat.ProposedArgumentValidityAbstract;
-
-public class ProposedRemoveFrom extends ProposedArgumentValidityAbstract {
-
-    public ProposedRemoveFrom(final AssertsValidity assertion) {
-        super(assertion);
-    }
-
-    @Override
-    protected Consent determineConsent(final PerformContext performContext, final ObjectAdapter toValidateAdapter) {
-
-        final ObjectAdapter onAdapter = performContext.getOnAdapter();
-        final OneToManyAssociation otma = (OneToManyAssociation) performContext.getObjectMember();
-
-        return otma.isValidToRemove(onAdapter, toValidateAdapter);
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/isis/blob/7276dc0b/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/fixtures/perform/checkthat/collections/Size.java
----------------------------------------------------------------------
diff --git a/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/fixtures/perform/checkthat/collections/Size.java b/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/fixtures/perform/checkthat/collections/Size.java
deleted file mode 100644
index 49ce0b0..0000000
--- a/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/fixtures/perform/checkthat/collections/Size.java
+++ /dev/null
@@ -1,69 +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.viewer.bdd.common.fixtures.perform.checkthat.collections;
-
-import org.apache.isis.core.metamodel.adapter.ObjectAdapter;
-import org.apache.isis.viewer.bdd.common.CellBinding;
-import org.apache.isis.viewer.bdd.common.ScenarioBoundValueException;
-import org.apache.isis.viewer.bdd.common.ScenarioCell;
-import org.apache.isis.viewer.bdd.common.fixtures.perform.PerformContext;
-
-public class Size extends ThatAbstract {
-
-    public Size() {
-        super("size");
-    }
-
-    @Override
-    protected void doThat(final PerformContext performContext, final Iterable<ObjectAdapter> collection) throws ScenarioBoundValueException {
-
-        final CellBinding thatBinding = performContext.getPeer().getThatItBinding();
-        final CellBinding arg0Binding = performContext.getPeer().getArg0Binding();
-
-        if (!arg0Binding.isFound()) {
-            throw ScenarioBoundValueException.current(thatBinding, "(requires argument)");
-        }
-
-        final ScenarioCell arg0Cell = arg0Binding.getCurrentCell();
-
-        final String expectedSizeStr = arg0Cell.getText();
-        final int expectedSize;
-        try {
-            expectedSize = Integer.parseInt(expectedSizeStr);
-        } catch (final NumberFormatException ex) {
-            throw ScenarioBoundValueException.current(arg0Binding, "(not an integer)");
-        }
-
-        if (expectedSize <= 0) {
-            throw ScenarioBoundValueException.current(arg0Binding, "(not a positive integer)");
-        }
-
-        int actualSize = 0;
-        for (@SuppressWarnings("unused")
-        final ObjectAdapter eachObject : collection) {
-            actualSize++;
-        }
-
-        if (expectedSize != actualSize) {
-            throw ScenarioBoundValueException.current(arg0Binding, "" + actualSize);
-        }
-
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/isis/blob/7276dc0b/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/fixtures/perform/checkthat/collections/ThatAbstract.java
----------------------------------------------------------------------
diff --git a/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/fixtures/perform/checkthat/collections/ThatAbstract.java b/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/fixtures/perform/checkthat/collections/ThatAbstract.java
deleted file mode 100644
index e5a39f5..0000000
--- a/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/fixtures/perform/checkthat/collections/ThatAbstract.java
+++ /dev/null
@@ -1,50 +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.viewer.bdd.common.fixtures.perform.checkthat.collections;
-
-import org.apache.isis.core.metamodel.adapter.ObjectAdapter;
-import org.apache.isis.core.metamodel.facets.collections.modify.CollectionFacet;
-import org.apache.isis.core.metamodel.spec.feature.OneToManyAssociation;
-import org.apache.isis.viewer.bdd.common.ScenarioBoundValueException;
-import org.apache.isis.viewer.bdd.common.fixtures.perform.PerformContext;
-import org.apache.isis.viewer.bdd.common.fixtures.perform.checkthat.ThatSubcommandAbstract;
-
-public abstract class ThatAbstract extends ThatSubcommandAbstract {
-
-    public ThatAbstract(final String key) {
-        super(key);
-    }
-
-    @Override
-    public ObjectAdapter that(final PerformContext performContext) throws ScenarioBoundValueException {
-
-        final ObjectAdapter onAdapter = performContext.getOnAdapter();
-        final OneToManyAssociation otma = (OneToManyAssociation) performContext.getObjectMember();
-
-        final ObjectAdapter nakedObjectRepresentingCollection = otma.get(onAdapter);
-        final CollectionFacet collectionFacet = nakedObjectRepresentingCollection.getSpecification().getFacet(CollectionFacet.class);
-
-        doThat(performContext, collectionFacet.iterable(nakedObjectRepresentingCollection));
-
-        return nakedObjectRepresentingCollection; // can alias if wish
-    }
-
-    protected abstract void doThat(PerformContext performContext, Iterable<ObjectAdapter> collection) throws ScenarioBoundValueException;
-
-}

http://git-wip-us.apache.org/repos/asf/isis/blob/7276dc0b/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/fixtures/perform/checkthat/object/NotSaved.java
----------------------------------------------------------------------
diff --git a/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/fixtures/perform/checkthat/object/NotSaved.java b/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/fixtures/perform/checkthat/object/NotSaved.java
deleted file mode 100644
index 544fe98..0000000
--- a/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/fixtures/perform/checkthat/object/NotSaved.java
+++ /dev/null
@@ -1,46 +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.viewer.bdd.common.fixtures.perform.checkthat.object;
-
-import org.apache.isis.core.metamodel.adapter.ObjectAdapter;
-import org.apache.isis.viewer.bdd.common.CellBinding;
-import org.apache.isis.viewer.bdd.common.ScenarioBoundValueException;
-import org.apache.isis.viewer.bdd.common.fixtures.perform.PerformContext;
-import org.apache.isis.viewer.bdd.common.fixtures.perform.checkthat.ThatSubcommandAbstract;
-
-public class NotSaved extends ThatSubcommandAbstract {
-
-    public NotSaved() {
-        super("is not saved", "is not persistent", "is not persisted", "not saved", "not persistent", "not persisted");
-    }
-
-    @Override
-    public ObjectAdapter that(final PerformContext performContext) throws ScenarioBoundValueException {
-
-        final ObjectAdapter onAdapter = performContext.getOnAdapter();
-        final CellBinding thatItBinding = performContext.getPeer().getThatItBinding();
-
-        if (onAdapter.representsPersistent()) {
-            throw ScenarioBoundValueException.current(thatItBinding, "(saved)");
-        }
-
-        return null;
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/isis/blob/7276dc0b/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/fixtures/perform/checkthat/object/NotValid.java
----------------------------------------------------------------------
diff --git a/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/fixtures/perform/checkthat/object/NotValid.java b/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/fixtures/perform/checkthat/object/NotValid.java
deleted file mode 100644
index f85f85c..0000000
--- a/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/fixtures/perform/checkthat/object/NotValid.java
+++ /dev/null
@@ -1,45 +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.viewer.bdd.common.fixtures.perform.checkthat.object;
-
-import org.apache.isis.core.metamodel.adapter.ObjectAdapter;
-import org.apache.isis.viewer.bdd.common.CellBinding;
-import org.apache.isis.viewer.bdd.common.ScenarioBoundValueException;
-import org.apache.isis.viewer.bdd.common.fixtures.perform.PerformContext;
-import org.apache.isis.viewer.bdd.common.fixtures.perform.checkthat.ThatSubcommandAbstract;
-
-public class NotValid extends ThatSubcommandAbstract {
-
-    public NotValid() {
-        super("is not valid", "is invalid", "not valid", "invalid");
-    }
-
-    @Override
-    public ObjectAdapter that(final PerformContext performContext) throws ScenarioBoundValueException {
-
-        final CellBinding thatItBinding = performContext.getPeer().getThatItBinding();
-
-        if (performContext.validObjectConsent().isAllowed()) {
-            throw ScenarioBoundValueException.current(thatItBinding, "(valid)");
-        }
-
-        return null;
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/isis/blob/7276dc0b/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/fixtures/perform/checkthat/object/Saved.java
----------------------------------------------------------------------
diff --git a/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/fixtures/perform/checkthat/object/Saved.java b/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/fixtures/perform/checkthat/object/Saved.java
deleted file mode 100644
index fdad338..0000000
--- a/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/fixtures/perform/checkthat/object/Saved.java
+++ /dev/null
@@ -1,46 +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.viewer.bdd.common.fixtures.perform.checkthat.object;
-
-import org.apache.isis.core.metamodel.adapter.ObjectAdapter;
-import org.apache.isis.viewer.bdd.common.CellBinding;
-import org.apache.isis.viewer.bdd.common.ScenarioBoundValueException;
-import org.apache.isis.viewer.bdd.common.fixtures.perform.PerformContext;
-import org.apache.isis.viewer.bdd.common.fixtures.perform.checkthat.ThatSubcommandAbstract;
-
-public class Saved extends ThatSubcommandAbstract {
-
-    public Saved() {
-        super("is saved", "is persistent", "is persisted", "saved", "persistent", "persisted");
-    }
-
-    @Override
-    public ObjectAdapter that(final PerformContext performContext) throws ScenarioBoundValueException {
-
-        final ObjectAdapter onAdapter = performContext.getOnAdapter();
-        final CellBinding thatItBinding = performContext.getPeer().getThatItBinding();
-
-        if (!onAdapter.representsPersistent()) {
-            throw ScenarioBoundValueException.current(thatItBinding, "(not saved)");
-        }
-
-        return null;
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/isis/blob/7276dc0b/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/fixtures/perform/checkthat/object/Valid.java
----------------------------------------------------------------------
diff --git a/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/fixtures/perform/checkthat/object/Valid.java b/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/fixtures/perform/checkthat/object/Valid.java
deleted file mode 100644
index 774ed63..0000000
--- a/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/fixtures/perform/checkthat/object/Valid.java
+++ /dev/null
@@ -1,44 +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.viewer.bdd.common.fixtures.perform.checkthat.object;
-
-import org.apache.isis.core.metamodel.adapter.ObjectAdapter;
-import org.apache.isis.viewer.bdd.common.CellBinding;
-import org.apache.isis.viewer.bdd.common.ScenarioBoundValueException;
-import org.apache.isis.viewer.bdd.common.fixtures.perform.PerformContext;
-import org.apache.isis.viewer.bdd.common.fixtures.perform.checkthat.ThatSubcommandAbstract;
-
-public class Valid extends ThatSubcommandAbstract {
-
-    public Valid() {
-        super("is valid", "valid");
-    }
-
-    @Override
-    public ObjectAdapter that(final PerformContext performContext) throws ScenarioBoundValueException {
-
-        if (!performContext.validObjectConsent().isAllowed()) {
-            final CellBinding thatItBinding = performContext.getPeer().getThatItBinding();
-            throw ScenarioBoundValueException.current(thatItBinding, "(not valid)");
-        }
-
-        return null;
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/isis/blob/7276dc0b/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/fixtures/perform/checkthat/property/Contains.java
----------------------------------------------------------------------
diff --git a/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/fixtures/perform/checkthat/property/Contains.java b/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/fixtures/perform/checkthat/property/Contains.java
deleted file mode 100644
index 4334c82..0000000
--- a/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/fixtures/perform/checkthat/property/Contains.java
+++ /dev/null
@@ -1,105 +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.viewer.bdd.common.fixtures.perform.checkthat.property;
-
-import java.util.Date;
-
-import org.apache.isis.core.commons.lang.StringUtils;
-import org.apache.isis.core.metamodel.adapter.ObjectAdapter;
-import org.apache.isis.core.metamodel.spec.feature.OneToOneAssociation;
-import org.apache.isis.core.progmodel.facets.value.date.DateValueFacet;
-import org.apache.isis.viewer.bdd.common.CellBinding;
-import org.apache.isis.viewer.bdd.common.ScenarioBoundValueException;
-import org.apache.isis.viewer.bdd.common.ScenarioCell;
-import org.apache.isis.viewer.bdd.common.fixtures.perform.PerformContext;
-import org.apache.isis.viewer.bdd.common.fixtures.perform.checkthat.ThatSubcommandAbstract;
-import org.apache.isis.viewer.bdd.common.parsers.DateParser;
-
-public class Contains extends ThatSubcommandAbstract {
-
-    public Contains() {
-        super("contains", "is", "does contain");
-    }
-
-    @Override
-    public ObjectAdapter that(final PerformContext performContext) throws ScenarioBoundValueException {
-
-        final OneToOneAssociation otoa = (OneToOneAssociation) performContext.getObjectMember();
-
-        // if we have an expected result
-        final CellBinding arg0Binding = performContext.getPeer().getArg0Binding();
-        final ScenarioCell arg0Cell = arg0Binding.getCurrentCell();
-        final String expected = arg0Cell.getText();
-
-        // get
-        final ObjectAdapter resultAdapter = otoa.get(performContext.getOnAdapter());
-
-        // see if matches null
-        if (resultAdapter == null) {
-            if (StringUtils.isNullOrEmpty(expected)) {
-                return resultAdapter;
-            }
-            throw ScenarioBoundValueException.current(arg0Binding, "(is null)");
-        }
-
-        final String resultTitle = resultAdapter.titleString();
-
-        if (!StringUtils.isNullOrEmpty(expected)) {
-
-            // see if expected matches an alias
-            final ObjectAdapter expectedAdapter = performContext.getPeer().getAliasRegistry().getAliased(expected);
-            if (expectedAdapter != null) {
-                // known
-                if (resultAdapter == expectedAdapter) {
-                    return resultAdapter;
-                }
-                throw ScenarioBoundValueException.current(arg0Binding, resultTitle);
-            }
-
-            // otherwise, see if date and if so compare as such
-            final DateValueFacet dateValueFacet = resultAdapter.getSpecification().getFacet(DateValueFacet.class);
-            if (dateValueFacet != null) {
-                final Date resultDate = dateValueFacet.dateValue(resultAdapter);
-
-                final DateParser dateParser = performContext.getDateParser();
-                final Date expectedDate = dateParser.parse(expected);
-                if (expectedDate != null) {
-                    if (expectedDate.compareTo(resultDate) == 0) {
-                        return resultAdapter; // ok
-                    }
-                }
-                final String format = dateParser.format(resultDate);
-                throw ScenarioBoundValueException.current(arg0Binding, format);
-            }
-
-            // otherwise, compare title
-            if (!StringUtils.nullSafeEquals(resultTitle, expected)) {
-                throw ScenarioBoundValueException.current(arg0Binding, resultTitle);
-            }
-        } else {
-            // try to provide a default
-            final String resultAlias = performContext.getPeer().getAliasRegistry().getAlias(resultAdapter);
-            final String resultStr = resultAlias != null ? resultAlias : resultTitle;
-            performContext.getPeer().provideDefault(arg0Cell, resultStr);
-        }
-
-        return resultAdapter;
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/isis/blob/7276dc0b/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/fixtures/perform/checkthat/property/DoesNotContain.java
----------------------------------------------------------------------
diff --git a/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/fixtures/perform/checkthat/property/DoesNotContain.java b/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/fixtures/perform/checkthat/property/DoesNotContain.java
deleted file mode 100644
index 9291a7d..0000000
--- a/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/fixtures/perform/checkthat/property/DoesNotContain.java
+++ /dev/null
@@ -1,78 +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.viewer.bdd.common.fixtures.perform.checkthat.property;
-
-import org.apache.isis.core.commons.lang.StringUtils;
-import org.apache.isis.core.metamodel.adapter.ObjectAdapter;
-import org.apache.isis.core.metamodel.spec.feature.OneToOneAssociation;
-import org.apache.isis.viewer.bdd.common.CellBinding;
-import org.apache.isis.viewer.bdd.common.ScenarioBoundValueException;
-import org.apache.isis.viewer.bdd.common.ScenarioCell;
-import org.apache.isis.viewer.bdd.common.fixtures.perform.PerformContext;
-import org.apache.isis.viewer.bdd.common.fixtures.perform.checkthat.ThatSubcommandAbstract;
-
-public class DoesNotContain extends ThatSubcommandAbstract {
-
-    public DoesNotContain() {
-        super("does not contain", "is not");
-    }
-
-    @Override
-    public ObjectAdapter that(final PerformContext performContext) throws ScenarioBoundValueException {
-
-        final OneToOneAssociation otoa = (OneToOneAssociation) performContext.getObjectMember();
-
-        // if we have an expected result
-        final CellBinding arg0Binding = performContext.getPeer().getArg0Binding();
-        final ScenarioCell arg0Cell = arg0Binding.getCurrentCell();
-        final String expected = arg0Cell.getText();
-
-        // get
-        final ObjectAdapter resultAdapter = otoa.get(performContext.getOnAdapter());
-
-        // see if matches null
-        if (resultAdapter == null) {
-            // ok
-            return null;
-        }
-
-        final String resultTitle = resultAdapter.titleString();
-
-        if (!StringUtils.isNullOrEmpty(expected)) {
-
-            // see if expected matches an alias
-            final ObjectAdapter expectedAdapter = performContext.getPeer().getAliasRegistry().getAliased(expected);
-            if (expectedAdapter != null) {
-                // known
-                if (resultAdapter != expectedAdapter) {
-                    return resultAdapter;
-                }
-                throw ScenarioBoundValueException.current(arg0Binding, "(does contain)");
-            }
-
-            // otherwise, compare title
-            if (StringUtils.nullSafeEquals(resultTitle, expected)) {
-                throw ScenarioBoundValueException.current(arg0Binding, "(does contain)");
-            }
-        }
-
-        return resultAdapter;
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/isis/blob/7276dc0b/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/fixtures/perform/checkthat/property/Empty.java
----------------------------------------------------------------------
diff --git a/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/fixtures/perform/checkthat/property/Empty.java b/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/fixtures/perform/checkthat/property/Empty.java
deleted file mode 100644
index b4fdd2b..0000000
--- a/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/fixtures/perform/checkthat/property/Empty.java
+++ /dev/null
@@ -1,54 +0,0 @@
-/*
- *  Licensed to the Apache Software Foundation (ASF) under one
- *  or more contributor license agreements.  See the NOTICE file
- *  distributed with this work for additional information
- *  regarding copyright ownership.  The ASF licenses this file
- *  to you under the Apache License, Version 2.0 (the
- *  "License"); you may not use this file except in compliance
- *  with the License.  You may obtain a copy of the License at
- *
- *        http://www.apache.org/licenses/LICENSE-2.0
- *
- *  Unless required by applicable law or agreed to in writing,
- *  software distributed under the License is distributed on an
- *  "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- *  KIND, either express or implied.  See the License for the
- *  specific language governing permissions and limitations
- *  under the License.
- */
-package org.apache.isis.viewer.bdd.common.fixtures.perform.checkthat.property;
-
-import org.apache.isis.core.metamodel.adapter.ObjectAdapter;
-import org.apache.isis.core.metamodel.spec.feature.OneToOneAssociation;
-import org.apache.isis.viewer.bdd.common.CellBinding;
-import org.apache.isis.viewer.bdd.common.ScenarioBoundValueException;
-import org.apache.isis.viewer.bdd.common.fixtures.perform.PerformContext;
-import org.apache.isis.viewer.bdd.common.fixtures.perform.checkthat.ThatSubcommandAbstract;
-
-public class Empty extends ThatSubcommandAbstract {
-
-    public Empty() {
-        super("is empty");
-    }
-
-    @Override
-    public ObjectAdapter that(final PerformContext performContext) throws ScenarioBoundValueException {
-
-        final OneToOneAssociation otoa = (OneToOneAssociation) performContext.getObjectMember();
-
-        // get
-        final ObjectAdapter resultAdapter = otoa.get(performContext.getOnAdapter());
-
-        if (resultAdapter != null) {
-            String actualStr = performContext.getPeer().getAliasRegistry().getAlias(resultAdapter);
-            if (actualStr == null) {
-                actualStr = resultAdapter.titleString();
-            }
-            final CellBinding thatItBinding = performContext.getPeer().getThatItBinding();
-            throw ScenarioBoundValueException.current(thatItBinding, actualStr);
-        }
-
-        return null;
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/isis/blob/7276dc0b/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/fixtures/perform/checkthat/property/NotEmpty.java
----------------------------------------------------------------------
diff --git a/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/fixtures/perform/checkthat/property/NotEmpty.java b/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/fixtures/perform/checkthat/property/NotEmpty.java
deleted file mode 100644
index c04153f..0000000
--- a/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/fixtures/perform/checkthat/property/NotEmpty.java
+++ /dev/null
@@ -1,50 +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.viewer.bdd.common.fixtures.perform.checkthat.property;
-
-import org.apache.isis.core.metamodel.adapter.ObjectAdapter;
-import org.apache.isis.core.metamodel.spec.feature.OneToOneAssociation;
-import org.apache.isis.viewer.bdd.common.CellBinding;
-import org.apache.isis.viewer.bdd.common.ScenarioBoundValueException;
-import org.apache.isis.viewer.bdd.common.fixtures.perform.PerformContext;
-import org.apache.isis.viewer.bdd.common.fixtures.perform.checkthat.ThatSubcommandAbstract;
-
-public class NotEmpty extends ThatSubcommandAbstract {
-
-    public NotEmpty() {
-        super("is not empty");
-    }
-
-    @Override
-    public ObjectAdapter that(final PerformContext performContext) throws ScenarioBoundValueException {
-
-        final OneToOneAssociation otoa = (OneToOneAssociation) performContext.getObjectMember();
-
-        // get
-        final ObjectAdapter resultAdapter = otoa.get(performContext.getOnAdapter());
-
-        if (resultAdapter == null) {
-            final CellBinding thatItBinding = performContext.getPeer().getThatItBinding();
-            throw ScenarioBoundValueException.current(thatItBinding, "(empty)");
-        }
-
-        return null;
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/isis/blob/7276dc0b/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/fixtures/perform/checkthat/property/ProposedClear.java
----------------------------------------------------------------------
diff --git a/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/fixtures/perform/checkthat/property/ProposedClear.java b/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/fixtures/perform/checkthat/property/ProposedClear.java
deleted file mode 100644
index 3befe79..0000000
--- a/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/fixtures/perform/checkthat/property/ProposedClear.java
+++ /dev/null
@@ -1,53 +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.viewer.bdd.common.fixtures.perform.checkthat.property;
-
-import org.apache.isis.core.metamodel.adapter.ObjectAdapter;
-import org.apache.isis.core.metamodel.consent.Consent;
-import org.apache.isis.core.metamodel.spec.feature.OneToOneAssociation;
-import org.apache.isis.viewer.bdd.common.CellBinding;
-import org.apache.isis.viewer.bdd.common.ScenarioBoundValueException;
-import org.apache.isis.viewer.bdd.common.fixtures.perform.PerformContext;
-import org.apache.isis.viewer.bdd.common.fixtures.perform.checkthat.AssertsValidity;
-import org.apache.isis.viewer.bdd.common.fixtures.perform.checkthat.ThatValidityAbstract;
-
-public class ProposedClear extends ThatValidityAbstract {
-
-    public ProposedClear(final AssertsValidity assertion) {
-        super(assertion);
-    }
-
-    @Override
-    public ObjectAdapter that(final PerformContext performContext) throws ScenarioBoundValueException {
-
-        final ObjectAdapter onAdapter = performContext.getOnAdapter();
-        final OneToOneAssociation otoa = (OneToOneAssociation) performContext.getObjectMember();
-
-        final Consent validityConsent = otoa.isAssociationValid(onAdapter, null);
-
-        if (!getAssertion().satisfiedBy(validityConsent)) {
-            final CellBinding thatBinding = performContext.getPeer().getThatItBinding();
-            throw ScenarioBoundValueException.current(thatBinding, getAssertion().getReason(validityConsent));
-        }
-
-        // can only return null.
-        return null;
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/isis/blob/7276dc0b/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/fixtures/perform/checkthat/property/ProposedSet.java
----------------------------------------------------------------------
diff --git a/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/fixtures/perform/checkthat/property/ProposedSet.java b/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/fixtures/perform/checkthat/property/ProposedSet.java
deleted file mode 100644
index 8c017cf..0000000
--- a/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/fixtures/perform/checkthat/property/ProposedSet.java
+++ /dev/null
@@ -1,43 +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.viewer.bdd.common.fixtures.perform.checkthat.property;
-
-import org.apache.isis.core.metamodel.adapter.ObjectAdapter;
-import org.apache.isis.core.metamodel.consent.Consent;
-import org.apache.isis.core.metamodel.spec.feature.OneToOneAssociation;
-import org.apache.isis.viewer.bdd.common.fixtures.perform.PerformContext;
-import org.apache.isis.viewer.bdd.common.fixtures.perform.checkthat.AssertsValidity;
-import org.apache.isis.viewer.bdd.common.fixtures.perform.checkthat.ProposedArgumentValidityAbstract;
-
-public class ProposedSet extends ProposedArgumentValidityAbstract {
-
-    public ProposedSet(final AssertsValidity assertion) {
-        super(assertion);
-    }
-
-    @Override
-    protected Consent determineConsent(final PerformContext performContext, final ObjectAdapter toValidateAdapter) {
-
-        final ObjectAdapter onAdapter = performContext.getOnAdapter();
-        final OneToOneAssociation otoa = (OneToOneAssociation) performContext.getObjectMember();
-
-        return otoa.isAssociationValid(onAdapter, toValidateAdapter);
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/isis/blob/7276dc0b/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/parsers/DateParser.java
----------------------------------------------------------------------
diff --git a/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/parsers/DateParser.java b/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/parsers/DateParser.java
deleted file mode 100644
index b32fe3b..0000000
--- a/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/parsers/DateParser.java
+++ /dev/null
@@ -1,130 +0,0 @@
-/*
- *  Licensed to the Apache Software Foundation (ASF) under one
- *  or more contributor license agreements.  See the NOTICE file
- *  distributed with this work for additional information
- *  regarding copyright ownership.  The ASF licenses this file
- *  to you under the Apache License, Version 2.0 (the
- *  "License"); you may not use this file except in compliance
- *  with the License.  You may obtain a copy of the License at
- *
- *        http://www.apache.org/licenses/LICENSE-2.0
- *
- *  Unless required by applicable law or agreed to in writing,
- *  software distributed under the License is distributed on an
- *  "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- *  KIND, either express or implied.  See the License for the
- *  specific language governing permissions and limitations
- *  under the License.
- */
-package org.apache.isis.viewer.bdd.common.parsers;
-
-import java.text.DateFormat;
-import java.text.MessageFormat;
-import java.text.ParseException;
-import java.text.SimpleDateFormat;
-import java.util.Date;
-import java.util.TimeZone;
-
-/**
- * A mutable wrapper around a {@link DateFormat}, allowing the date and time
- * parts of the format to be specified independently specified.
- */
-public class DateParser {
-
-    /**
-     * Taken from the {@link org.apache.isis.applib.value.Date}
-     */
-    private static final TimeZone UTC_TIME_ZONE;
-    static {
-        TimeZone timeZone = TimeZone.getTimeZone("Etc/UTC");
-        if (timeZone == null) {
-            timeZone = TimeZone.getTimeZone("UTC");
-        }
-        UTC_TIME_ZONE = timeZone;
-    }
-
-    private static final String DEFAULT_DATE_MASK = "yyyy-MM-dd";
-    private static final String DEFAULT_TIME_MASK = "hh:mm";
-
-    private String dateMask = DEFAULT_DATE_MASK;
-    private String timeMask = DEFAULT_TIME_MASK;
-    private DateFormat dateAndTimeFormat = null;
-    private DateFormat dateOnlyFormat = null;
-    private DateFormat timeOnlyFormat = null;
-
-    public DateParser() {
-    }
-
-    public Date parse(final String dateAndOrTimeStr) {
-        try {
-            return getDateAndTimeFormat().parse(dateAndOrTimeStr);
-        } catch (final ParseException e) {
-            try {
-                return getDateFormat().parse(dateAndOrTimeStr);
-            } catch (final ParseException e2) {
-                try {
-                    return getTimeFormat().parse(dateAndOrTimeStr);
-                } catch (final ParseException e3) {
-                    return null;
-                }
-            }
-        }
-    }
-
-    public void setDateFormat(final String dateMask) {
-        this.dateMask = dateMask;
-        invalidateFormats();
-    }
-
-    public void setTimeFormat(final String timeMask) {
-        this.timeMask = timeMask;
-        invalidateFormats();
-    }
-
-    private void invalidateFormats() {
-        this.dateAndTimeFormat = null;
-        this.dateOnlyFormat = null;
-        this.timeOnlyFormat = null;
-    }
-
-    public String format(final Date resultDate) {
-        return getDateAndTimeFormat().format(resultDate);
-    }
-
-    private DateFormat getDateAndTimeFormat() {
-        if (dateAndTimeFormat == null) {
-            dateAndTimeFormat = getUTCDateFormat(getCombinedMask());
-        }
-        return dateAndTimeFormat;
-    }
-
-    private DateFormat getTimeFormat() {
-        if (timeOnlyFormat == null) {
-            timeOnlyFormat = getUTCDateFormat(timeMask);
-        }
-        return timeOnlyFormat;
-    }
-
-    private DateFormat getDateFormat() {
-        if (dateOnlyFormat == null) {
-            dateOnlyFormat = getUTCDateFormat(dateMask);
-        }
-        return dateOnlyFormat;
-    }
-
-    private DateFormat getUTCDateFormat(final String dateTimeMask) {
-        final DateFormat dateFormat = new SimpleDateFormat(dateTimeMask);
-        dateFormat.setTimeZone(UTC_TIME_ZONE);
-        return dateFormat;
-    }
-
-    public String getCombinedMask() {
-        return MessageFormat.format("{0} {1}", dateMask, timeMask);
-    }
-
-    @Override
-    public String toString() {
-        return getCombinedMask();
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/isis/blob/7276dc0b/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/story/bootstrapping/AbstractHelper.java
----------------------------------------------------------------------
diff --git a/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/story/bootstrapping/AbstractHelper.java b/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/story/bootstrapping/AbstractHelper.java
deleted file mode 100644
index c994859..0000000
--- a/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/story/bootstrapping/AbstractHelper.java
+++ /dev/null
@@ -1,35 +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.viewer.bdd.common.story.bootstrapping;
-
-import org.apache.isis.viewer.bdd.common.Scenario;
-
-public abstract class AbstractHelper {
-
-    private final Scenario story;
-
-    public AbstractHelper(final Scenario story) {
-        this.story = story;
-    }
-
-    protected Scenario getStory() {
-        return story;
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/isis/blob/7276dc0b/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/story/bootstrapping/OpenSession.java
----------------------------------------------------------------------
diff --git a/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/story/bootstrapping/OpenSession.java b/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/story/bootstrapping/OpenSession.java
deleted file mode 100644
index a36de30..0000000
--- a/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/story/bootstrapping/OpenSession.java
+++ /dev/null
@@ -1,52 +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.viewer.bdd.common.story.bootstrapping;
-
-import java.util.List;
-
-import org.apache.isis.applib.fixtures.LogonFixture;
-import org.apache.isis.core.commons.authentication.AuthenticationSession;
-import org.apache.isis.core.runtime.authentication.AuthenticationManager;
-import org.apache.isis.core.runtime.fixtures.authentication.AuthenticationRequestLogonFixture;
-import org.apache.isis.core.runtime.system.context.IsisContext;
-import org.apache.isis.viewer.bdd.common.Scenario;
-
-public class OpenSession {
-
-    @SuppressWarnings("unused")
-    private final Scenario story;
-
-    public OpenSession(final Scenario story) {
-        this.story = story;
-    }
-
-    public void openSession(final String userName, final List<String> roles) {
-        IsisContext.closeSession();
-        final LogonFixture logonFixture = new LogonFixture(userName, roles);
-        final AuthenticationRequestLogonFixture authRequest = new AuthenticationRequestLogonFixture(logonFixture);
-        final AuthenticationSession authSession = getAuthenticationManager().authenticate(authRequest);
-
-        IsisContext.openSession(authSession);
-    }
-
-    protected AuthenticationManager getAuthenticationManager() {
-        return IsisContext.getAuthenticationManager();
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/isis/blob/7276dc0b/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/story/bootstrapping/RunViewer.java
----------------------------------------------------------------------
diff --git a/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/story/bootstrapping/RunViewer.java b/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/story/bootstrapping/RunViewer.java
deleted file mode 100644
index 185a206..0000000
--- a/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/story/bootstrapping/RunViewer.java
+++ /dev/null
@@ -1,43 +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.viewer.bdd.common.story.bootstrapping;
-
-import org.apache.isis.core.runtime.installerregistry.InstallerLookup;
-import org.apache.isis.core.runtime.installerregistry.installerapi.IsisViewerInstaller;
-import org.apache.isis.core.runtime.viewer.IsisViewer;
-import org.apache.isis.viewer.bdd.common.Scenario;
-
-public class RunViewer extends AbstractHelper {
-
-    private static final String DND_VIEWER_NAME = "dnd";
-
-    public RunViewer(final Scenario story) {
-        super(story);
-    }
-
-    public void run() {
-        final InstallerLookup installerLookup = getStory().getInstallerLookup();
-
-        final IsisViewerInstaller viewerInstaller = installerLookup.viewerInstaller(DND_VIEWER_NAME);
-        final IsisViewer viewer = viewerInstaller.createViewer();
-
-        viewer.init();
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/isis/blob/7276dc0b/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/story/bootstrapping/SetClock.java
----------------------------------------------------------------------
diff --git a/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/story/bootstrapping/SetClock.java b/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/story/bootstrapping/SetClock.java
deleted file mode 100644
index 32b980b..0000000
--- a/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/story/bootstrapping/SetClock.java
+++ /dev/null
@@ -1,41 +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.viewer.bdd.common.story.bootstrapping;
-
-import java.util.Calendar;
-import java.util.Date;
-
-import org.apache.isis.applib.fixtures.FixtureClock;
-import org.apache.isis.viewer.bdd.common.Scenario;
-
-public class SetClock extends AbstractHelper {
-
-    public SetClock(final Scenario story) {
-        super(story);
-    }
-
-    public void setClock(final Date date) {
-        final FixtureClock clock = FixtureClock.initialize();
-        final Calendar calendar = Calendar.getInstance();
-        calendar.setTime(date);
-        clock.setDate(calendar.get(Calendar.YEAR), calendar.get(Calendar.MONTH) + 1, calendar.get(Calendar.DAY_OF_MONTH));
-        clock.setTime(calendar.get(Calendar.HOUR_OF_DAY), calendar.get(Calendar.MINUTE));
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/isis/blob/7276dc0b/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/story/bootstrapping/ShutdownIsis.java
----------------------------------------------------------------------
diff --git a/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/story/bootstrapping/ShutdownIsis.java b/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/story/bootstrapping/ShutdownIsis.java
deleted file mode 100644
index dac6e66..0000000
--- a/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/story/bootstrapping/ShutdownIsis.java
+++ /dev/null
@@ -1,42 +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.viewer.bdd.common.story.bootstrapping;
-
-import org.apache.isis.core.runtime.system.IsisSystem;
-import org.apache.isis.core.runtime.system.context.IsisContext;
-import org.apache.isis.viewer.bdd.common.Scenario;
-
-public class ShutdownIsis extends AbstractHelper {
-
-    public ShutdownIsis(final Scenario story) {
-        super(story);
-    }
-
-    public void shutdown() {
-        final IsisSystem system = getStory().getSystem();
-
-        IsisContext.closeAllSessions();
-
-        if (system != null) {
-            system.shutdown();
-        }
-
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/isis/blob/7276dc0b/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/story/registries/AliasRegistryDefault.java
----------------------------------------------------------------------
diff --git a/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/story/registries/AliasRegistryDefault.java b/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/story/registries/AliasRegistryDefault.java
deleted file mode 100644
index 12f3ed6..0000000
--- a/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/story/registries/AliasRegistryDefault.java
+++ /dev/null
@@ -1,108 +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.viewer.bdd.common.story.registries;
-
-import java.util.Collections;
-import java.util.HashMap;
-import java.util.Iterator;
-import java.util.List;
-import java.util.Map;
-import java.util.Map.Entry;
-import java.util.Set;
-import java.util.TreeMap;
-
-import org.apache.isis.core.metamodel.adapter.ObjectAdapter;
-import org.apache.isis.core.runtime.system.context.IsisContext;
-import org.apache.isis.core.runtime.system.persistence.PersistenceSession;
-import org.apache.isis.viewer.bdd.common.AliasRegistry;
-import org.apache.isis.viewer.bdd.common.ScenarioValueException;
-
-public class AliasRegistryDefault implements AliasRegistry {
-
-    private final Map<String, ObjectAdapter> adaptersByAlias = new HashMap<String, ObjectAdapter>();
-    private final Map<ObjectAdapter, String> aliasesByAdapter = new HashMap<ObjectAdapter, String>();
-
-    /**
-     * @see #nextAlias()
-     * @see #aliasPrefixedAs(String, NakedObject)
-     */
-    private final Map<String, int[]> aliasCountsByPrefix = new TreeMap<String, int[]>();
-
-    @Override
-    public void aliasAs(final String alias, final ObjectAdapter adapter) {
-        adaptersByAlias.put(alias, adapter);
-        aliasesByAdapter.put(adapter, alias);
-    }
-
-    @Override
-    public ObjectAdapter getAliased(final String alias) {
-        return adaptersByAlias.get(alias);
-    }
-
-    @Override
-    public String getAlias(final ObjectAdapter adapter) {
-        return aliasesByAdapter.get(adapter);
-    }
-
-    @Override
-    public String aliasPrefixedAs(final String prefix, final ObjectAdapter adapter) {
-        int[] aliasCountForPrefix = aliasCountsByPrefix.get(prefix);
-        if (aliasCountForPrefix == null) {
-            aliasCountForPrefix = new int[1];
-            aliasCountsByPrefix.put(prefix, aliasCountForPrefix);
-        }
-        final String nextAliasForPrefix = nextAlias(prefix, aliasCountForPrefix);
-        adaptersByAlias.put(nextAliasForPrefix, adapter);
-        return nextAliasForPrefix;
-    }
-
-    private String nextAlias(final String prefix, final int[] heldAsCount) {
-        return prefix + "#" + (++heldAsCount[0]);
-    }
-
-    @Override
-    public Iterator<Entry<String, ObjectAdapter>> iterator() {
-        final Set<Entry<String, ObjectAdapter>> entrySet = adaptersByAlias.entrySet();
-        return Collections.unmodifiableSet(entrySet).iterator();
-    }
-
-    @Override
-    public void aliasService(final String aliasAs, final String className) throws ScenarioValueException {
-        final List<ObjectAdapter> serviceAdapters = getPersistenceSession().getServices();
-        for (final ObjectAdapter serviceAdapter : serviceAdapters) {
-            if (serviceAdapter.getSpecification().getFullIdentifier().equals(className)) {
-                adaptersByAlias.put(aliasAs, serviceAdapter);
-                return;
-            }
-        }
-        throw new ScenarioValueException("no such service");
-    }
-
-    protected PersistenceSession getPersistenceSession() {
-        return IsisContext.getPersistenceSession();
-    }
-
-    @Override
-    public void clear() {
-        this.adaptersByAlias.clear();
-        this.aliasesByAdapter.clear();
-        this.aliasCountsByPrefix.clear();
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/isis/blob/7276dc0b/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/story/registries/AliasRegistryHolder.java
----------------------------------------------------------------------
diff --git a/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/story/registries/AliasRegistryHolder.java b/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/story/registries/AliasRegistryHolder.java
deleted file mode 100644
index 1bbc75c..0000000
--- a/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/story/registries/AliasRegistryHolder.java
+++ /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.
- */
-package org.apache.isis.viewer.bdd.common.story.registries;
-
-import org.apache.isis.viewer.bdd.common.AliasRegistry;
-
-public interface AliasRegistryHolder {
-
-    AliasRegistry getAliasRegistry();
-
-}

http://git-wip-us.apache.org/repos/asf/isis/blob/7276dc0b/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/story/registries/ServiceRegistrySpi.java
----------------------------------------------------------------------
diff --git a/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/story/registries/ServiceRegistrySpi.java b/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/story/registries/ServiceRegistrySpi.java
deleted file mode 100644
index 25dff70..0000000
--- a/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/story/registries/ServiceRegistrySpi.java
+++ /dev/null
@@ -1,25 +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.viewer.bdd.common.story.registries;
-
-import org.apache.isis.viewer.bdd.common.ServiceRegistry;
-
-public interface ServiceRegistrySpi extends ServiceRegistry {
-
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/isis/blob/7276dc0b/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/util/Strings.java
----------------------------------------------------------------------
diff --git a/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/util/Strings.java b/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/util/Strings.java
deleted file mode 100644
index c3950c7..0000000
--- a/component/viewer/bdd/common/src/main/java/org/apache/isis/viewer/bdd/common/util/Strings.java
+++ /dev/null
@@ -1,26 +0,0 @@
-/*
- *  Licensed to the Apache Software Foundation (ASF) under one
- *  or more contributor license agreements.  See the NOTICE file
- *  distributed with this work for additional information
- *  regarding copyright ownership.  The ASF licenses this file
- *  to you under the Apache License, Version 2.0 (the
- *  "License"); you may not use this file except in compliance
- *  with the License.  You may obtain a copy of the License at
- *
- *        http://www.apache.org/licenses/LICENSE-2.0
- *
- *  Unless required by applicable law or agreed to in writing,
- *  software distributed under the License is distributed on an
- *  "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- *  KIND, either express or implied.  See the License for the
- *  specific language governing permissions and limitations
- *  under the License.
- */
-package org.apache.isis.viewer.bdd.common.util;
-
-public final class Strings {
-
-    private Strings() {
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/isis/blob/7276dc0b/component/viewer/bdd/common/src/site/apt/index.apt
----------------------------------------------------------------------
diff --git a/component/viewer/bdd/common/src/site/apt/index.apt b/component/viewer/bdd/common/src/site/apt/index.apt
deleted file mode 100644
index 1fa9d22..0000000
--- a/component/viewer/bdd/common/src/site/apt/index.apt
+++ /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.
-
-
-
-BDD Common
-
- The BDD <common> module provides integration logic with <Apache Isis>, 
- independent of any particular BDD testing framework.   Although
- the {{{../bdd-concordion/index.html}concordion}} module is the only user,
- it is separate from that module in order to enable integrations with other 
- BDD frameworks in the future.
-    
-Further Info
-  
-  See this module's {{{./apidocs/index.html}Javadoc}} and the 
-  {{{../docbkx/html/guide/isis-bdd-integration.html}user guide}} for more information.
- 

http://git-wip-us.apache.org/repos/asf/isis/blob/7276dc0b/component/viewer/bdd/common/src/site/apt/jottings.apt
----------------------------------------------------------------------
diff --git a/component/viewer/bdd/common/src/site/apt/jottings.apt b/component/viewer/bdd/common/src/site/apt/jottings.apt
deleted file mode 100644
index c5d1200..0000000
--- a/component/viewer/bdd/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/7276dc0b/component/viewer/bdd/common/src/site/site.xml
----------------------------------------------------------------------
diff --git a/component/viewer/bdd/common/src/site/site.xml b/component/viewer/bdd/common/src/site/site.xml
deleted file mode 100644
index aaffb84..0000000
--- a/component/viewer/bdd/common/src/site/site.xml
+++ /dev/null
@@ -1,40 +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="Common" href="index.html"/>
-		</breadcrumbs>
-
-		<menu name="BDD Common">
-			<item name="About" href="index.html" />
-            <item name="Jottings" href="jottings.html" />
-		</menu>
-        
-        <menu name="BDD Modules">
-            <item name="Common" href="../bdd-common/index.html" />
-            <item name="Concordion" href="../bdd-concordion/index.html" />
-        </menu>
-
-		<menu name="Maven Reports" ref="reports" />
-	</body>
-
-</project>

http://git-wip-us.apache.org/repos/asf/isis/blob/7276dc0b/component/viewer/bdd/common/src/test/java/org/apache/isis/viewer/bdd/common/parsers/DateParserTest.java
----------------------------------------------------------------------
diff --git a/component/viewer/bdd/common/src/test/java/org/apache/isis/viewer/bdd/common/parsers/DateParserTest.java b/component/viewer/bdd/common/src/test/java/org/apache/isis/viewer/bdd/common/parsers/DateParserTest.java
deleted file mode 100644
index 2ef1307..0000000
--- a/component/viewer/bdd/common/src/test/java/org/apache/isis/viewer/bdd/common/parsers/DateParserTest.java
+++ /dev/null
@@ -1,48 +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.viewer.bdd.common.parsers;
-
-import static org.hamcrest.Matchers.is;
-import static org.hamcrest.Matchers.not;
-import static org.hamcrest.Matchers.nullValue;
-import static org.junit.Assert.assertThat;
-
-import java.util.Date;
-
-import org.junit.Ignore;
-import org.junit.Test;
-
-public class DateParserTest {
-
-    /**
-     * Tracking down problem in ISIS-18...
-     * <p>
-     * This fails because 'MMM' is gonna be different in different languages.
-     */
-    @Ignore
-    @Test
-    public void parsesUnder_enUK_butNotUnder_deDE() throws Exception {
-        final DateParser dateParser = new DateParser();
-        dateParser.setDateFormat("dd-MMM-yyyy");
-        dateParser.setTimeFormat("hh:mm");
-        final Date parse = dateParser.parse("02-May-2010 09:20");
-        assertThat(parse, is(not(nullValue())));
-    }
-
-}