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 2016/01/17 17:13:15 UTC

[01/17] isis git commit: ISIS-1295: removed IsisContextStatic and ContextCategory, folded IsisContextThreadLocal into IsisContext

Repository: isis
Updated Branches:
  refs/heads/master 9fe8b0b9e -> e0e558526


ISIS-1295: removed IsisContextStatic and ContextCategory, folded IsisContextThreadLocal into IsisContext


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

Branch: refs/heads/master
Commit: ee58bb0c07d6b3cd897751e2c9e0e5d55f6528df
Parents: 9fe8b0b
Author: Dan Haywood <da...@haywood-associates.co.uk>
Authored: Mon Jan 4 18:38:19 2016 +0000
Committer: Dan Haywood <da...@haywood-associates.co.uk>
Committed: Mon Jan 4 18:38:19 2016 +0000

----------------------------------------------------------------------
 .../core/runtime/system/ContextCategory.java    |  79 --------
 .../core/runtime/system/DeploymentType.java     |  38 +---
 .../runtime/system/context/IsisContext.java     | 132 +++++++++++--
 .../system/context/IsisContextStatic.java       | 137 --------------
 .../system/context/IsisContextThreadLocal.java  | 183 -------------------
 .../core/runtime/context/IsisContextTest.java   | 140 --------------
 .../isis/DeploymentTypeAbstract.java            |   8 +-
 7 files changed, 128 insertions(+), 589 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/isis/blob/ee58bb0c/core/runtime/src/main/java/org/apache/isis/core/runtime/system/ContextCategory.java
----------------------------------------------------------------------
diff --git a/core/runtime/src/main/java/org/apache/isis/core/runtime/system/ContextCategory.java b/core/runtime/src/main/java/org/apache/isis/core/runtime/system/ContextCategory.java
deleted file mode 100644
index 90ac5de..0000000
--- a/core/runtime/src/main/java/org/apache/isis/core/runtime/system/ContextCategory.java
+++ /dev/null
@@ -1,79 +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.core.runtime.system;
-
-import java.util.List;
-
-import org.apache.isis.core.runtime.system.context.IsisContextStatic;
-import org.apache.isis.core.runtime.system.context.IsisContextThreadLocal;
-import org.apache.isis.core.runtime.system.session.IsisSessionFactory;
-
-/**
- * @see DeploymentType
- */
-public abstract class ContextCategory {
-
-    public static ContextCategory STATIC_RELAXED = new ContextCategory() {
-        @Override
-        public void initContext(final IsisSessionFactory sessionFactory) {
-            IsisContextStatic.createRelaxedInstance(sessionFactory);
-        }
-
-        @Override
-        public boolean canSpecifyViewers(final List<String> viewers) {
-            // no more than one
-            return viewers.size() <= 1;
-        }
-    };
-
-    public static ContextCategory STATIC = new ContextCategory() {
-        @Override
-        public void initContext(final IsisSessionFactory sessionFactory) {
-            IsisContextStatic.createInstance(sessionFactory);
-        }
-
-        @Override
-        public boolean canSpecifyViewers(final List<String> viewers) {
-            // no more than one
-            return viewers.size() == 1;
-        }
-    };
-    public static ContextCategory THREADLOCAL = new ContextCategory() {
-        @Override
-        public void initContext(final IsisSessionFactory sessionFactory) {
-            IsisContextThreadLocal.createInstance(sessionFactory);
-        }
-
-        @Override
-        public boolean canSpecifyViewers(final List<String> viewers) {
-            // as many as you like
-            return true;
-        }
-    };
-
-    public abstract void initContext(IsisSessionFactory sessionFactory);
-
-    /**
-     * Whether the list of connector names provided is compatible with this
-     * {@link ContextCategory}.
-     */
-    public abstract boolean canSpecifyViewers(List<String> viewers);
-
-}

http://git-wip-us.apache.org/repos/asf/isis/blob/ee58bb0c/core/runtime/src/main/java/org/apache/isis/core/runtime/system/DeploymentType.java
----------------------------------------------------------------------
diff --git a/core/runtime/src/main/java/org/apache/isis/core/runtime/system/DeploymentType.java b/core/runtime/src/main/java/org/apache/isis/core/runtime/system/DeploymentType.java
index 1371ec5..153d426 100644
--- a/core/runtime/src/main/java/org/apache/isis/core/runtime/system/DeploymentType.java
+++ b/core/runtime/src/main/java/org/apache/isis/core/runtime/system/DeploymentType.java
@@ -27,41 +27,20 @@ import org.apache.isis.core.commons.debug.DebugBuilder;
 import org.apache.isis.core.commons.debug.DebuggableWithTitle;
 import org.apache.isis.core.metamodel.deployment.DeploymentCategory;
 import org.apache.isis.core.metamodel.deployment.DeploymentCategoryProviderAbstract;
+import org.apache.isis.core.runtime.system.context.IsisContext;
 import org.apache.isis.core.runtime.system.session.IsisSessionFactory;
 
 /**
  * Whether running on client or server side etc.
- * 
- * <p>
- * Previously this was an <tt>enum</tt>, but it is now a regular class. The
- * change has been made to provide more flexibility in setting up the
- * <tt>IsisContext</tt> lookup.
- * 
- * <p>
- * To use this capability:
- * <ul>
- * <li>Write your new implementation of <tt>IsisContext</tt>, along with a
- * static factory method (cf
- * <tt>IsisContextStatic#createInstance(IsisSessionFactory)</tt>)
- * <li>Create a new subclass of {@link ContextCategory} (also now a regular
- * class rather than an <tt>enum</tt>); this is where your code goes to
- * instantiate your <tt>IsisContext</tt> implementation</li>
- * <li>Create a new subclass of {@link DeploymentType}, passing in the custom
- * {@link ContextCategory} in its constructor</li>
- * <li>In your bootstrap code, instantiate your new {@link DeploymentType}
- * subclass</li>
- * <li>When you run your app, don't forget to specify your custom
- * {@link DeploymentType}, eg using the <tt>--type</tt> command line arg</li>
- * </ul>
  */
 public class DeploymentType extends DeploymentCategoryProviderAbstract {
 
     private static List<DeploymentType> deploymentTypes = Lists.newArrayList();
 
-    public static DeploymentType SERVER = new DeploymentType("SERVER", DeploymentCategory.PRODUCTION, ContextCategory.THREADLOCAL);
-    public static DeploymentType SERVER_EXPLORATION = new DeploymentType("SERVER_EXPLORATION", DeploymentCategory.EXPLORING, ContextCategory.THREADLOCAL);
-    public static DeploymentType SERVER_PROTOTYPE = new DeploymentType("SERVER_PROTOTYPE", DeploymentCategory.PROTOTYPING, ContextCategory.THREADLOCAL);
-    public static DeploymentType UNIT_TESTING = new DeploymentType("UNIT_TESTING", DeploymentCategory.PRODUCTION, ContextCategory.STATIC_RELAXED);
+    public static DeploymentType SERVER = new DeploymentType("SERVER", DeploymentCategory.PRODUCTION);
+    public static DeploymentType SERVER_EXPLORATION = new DeploymentType("SERVER_EXPLORATION", DeploymentCategory.EXPLORING);
+    public static DeploymentType SERVER_PROTOTYPE = new DeploymentType("SERVER_PROTOTYPE", DeploymentCategory.PROTOTYPING);
+    public static DeploymentType UNIT_TESTING = new DeploymentType("UNIT_TESTING", DeploymentCategory.PRODUCTION);
 
     /**
      * Look up {@link DeploymentType} by their {@link #name()}.
@@ -84,12 +63,10 @@ public class DeploymentType extends DeploymentCategoryProviderAbstract {
 
     private final String name;
     private final DeploymentCategory deploymentCategory;
-    private final ContextCategory contextCategory;
 
     public DeploymentType(
-            final String name, final DeploymentCategory category, final ContextCategory contextCategory) {
+            final String name, final DeploymentCategory category) {
         this.deploymentCategory = category;
-        this.contextCategory = contextCategory;
         this.name = name;
         deploymentTypes.add(this);
     }
@@ -100,7 +77,6 @@ public class DeploymentType extends DeploymentCategoryProviderAbstract {
             @Override
             public void debugData(final DebugBuilder debug) {
                 debug.appendln("Category", deploymentCategory);
-                debug.appendln("Context", contextCategory);
                 debug.appendln();
                 debug.appendln("Name", friendlyName());
                 debug.appendln("Should monitor", shouldMonitor());
@@ -114,7 +90,7 @@ public class DeploymentType extends DeploymentCategoryProviderAbstract {
     }
 
     public void initContext(final IsisSessionFactory sessionFactory) {
-        contextCategory.initContext(sessionFactory);
+        IsisContext.createInstance(sessionFactory);
     }
 
     public boolean shouldMonitor() {

http://git-wip-us.apache.org/repos/asf/isis/blob/ee58bb0c/core/runtime/src/main/java/org/apache/isis/core/runtime/system/context/IsisContext.java
----------------------------------------------------------------------
diff --git a/core/runtime/src/main/java/org/apache/isis/core/runtime/system/context/IsisContext.java b/core/runtime/src/main/java/org/apache/isis/core/runtime/system/context/IsisContext.java
index 0d49e9b..9fe9b17 100644
--- a/core/runtime/src/main/java/org/apache/isis/core/runtime/system/context/IsisContext.java
+++ b/core/runtime/src/main/java/org/apache/isis/core/runtime/system/context/IsisContext.java
@@ -19,7 +19,9 @@
 
 package org.apache.isis.core.runtime.system.context;
 
+import java.util.IdentityHashMap;
 import java.util.List;
+import java.util.Map;
 import java.util.concurrent.Callable;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
@@ -55,7 +57,7 @@ import org.apache.isis.core.runtime.system.transaction.IsisTransactionManager;
  * <p>
  * Somewhat analogous to (the static methods in) <tt>HibernateUtil</tt>.
  */
-public abstract class IsisContext implements DebuggableWithTitle {
+public class IsisContext implements DebuggableWithTitle {
 
     private static final Logger LOG = LoggerFactory.getLogger(IsisContext.class);
 
@@ -114,6 +116,7 @@ public abstract class IsisContext implements DebuggableWithTitle {
         NOT_REPLACEABLE, REPLACEABLE
     }
 
+
     /**
      * Creates a new instance of the {@link IsisSession} holder.
      * 
@@ -131,6 +134,13 @@ public abstract class IsisContext implements DebuggableWithTitle {
         this.replacePolicy = replacePolicy;
     }
 
+
+    protected IsisContext(final IsisSessionFactory sessionFactory) {
+        this(ContextReplacePolicy.NOT_REPLACEABLE, SessionClosePolicy.AUTO_CLOSE, sessionFactory);
+    }
+
+
+
     protected void shutdownInstance() {
         this.sessionFactory.shutdown();
     }
@@ -194,10 +204,39 @@ public abstract class IsisContext implements DebuggableWithTitle {
     /**
      * Creates a new {@link IsisSession} and binds into the current context.
      * 
+     * Is only intended to be called through
+     * {@link IsisContext#openSession(AuthenticationSession)}.
+     *
+     * <p>
+     * Implementation note: an alternative design would have just been to bind
+     * onto a thread local.
+     *
      * @throws IllegalStateException
      *             if already opened.
      */
-    public abstract IsisSession openSessionInstance(AuthenticationSession session);
+    public IsisSession openSessionInstance(final AuthenticationSession authenticationSession) {
+        final Thread thread = Thread.currentThread();
+        synchronized (sessionsByThread) {
+            applySessionClosePolicy();
+            final IsisSession session = getSessionFactoryInstance().openSession(authenticationSession);
+            if (LOG.isDebugEnabled()) {
+                LOG.debug("  opening session " + session + " (count " + sessionsByThread.size() + ") for " + authenticationSession.getUserName());
+            }
+            saveSession(thread, session);
+            session.open();
+            return session;
+        }
+    }
+
+    private IsisSession saveSession(final Thread thread, final IsisSession session) {
+        synchronized (sessionsByThread) {
+            sessionsByThread.put(thread, session);
+        }
+        if (LOG.isDebugEnabled()) {
+            LOG.debug("  saving session " + session + "; now have " + sessionsByThread.size() + " sessions");
+        }
+        return session;
+    }
 
     /**
      * Closes the {@link IsisSession} for the current context.
@@ -230,32 +269,43 @@ public abstract class IsisContext implements DebuggableWithTitle {
      * already have been {@link IsisSession#close() closed}.
      */
     protected void doClose() {
+        sessionsByThread.remove(Thread.currentThread());
     }
 
     /**
      * Shutdown the application.
      */
-    protected abstract void closeAllSessionsInstance();
+    public void closeAllSessionsInstance() {
+        shutdownAllThreads();
+    }
+
 
-    
 
     // ///////////////////////////////////////////////////////////
     // getSession()
     // ///////////////////////////////////////////////////////////
 
     /**
-     * Locates the current {@link IsisSession}.
-     * 
-     * <p>
-     * This might just be a singleton (eg {@link IsisContextStatic}), or could
-     * be retrieved from the thread (eg {@link IsisContextThreadLocal}).
+     * Locates the current {@link IsisSession} from the threadlocal.
+     *
+     * @see #openSessionInstance(AuthenticationSession)
      */
-    public abstract IsisSession getSessionInstance();
+    public IsisSession getSessionInstance() {
+        final Thread thread = Thread.currentThread();
+        return sessionsByThread.get(thread);
+    }
 
     /**
      * The {@link IsisSession} for specified {@link IsisSession#getId()}.
      */
-    protected abstract IsisSession getSessionInstance(String sessionId);
+    protected IsisSession getSessionInstance(final String executionContextId) {
+        for (final IsisSession data : sessionsByThread.values()) {
+            if (data.getId().equals(executionContextId)) {
+                return data;
+            }
+        }
+        return null;
+    }
 
     /**
      * All known session Ids.
@@ -263,7 +313,14 @@ public abstract class IsisContext implements DebuggableWithTitle {
      * <p>
      * Provided primarily for debugging.
      */
-    public abstract String[] allSessionIds();
+    public String[] allSessionIds() {
+        final String[] ids = new String[sessionsByThread.size()];
+        int i = 0;
+        for (final IsisSession data  : sessionsByThread.values()) {
+            ids[i++] = data.getId();
+        }
+        return ids;
+    }
 
     // ///////////////////////////////////////////////////////////
     // Static Convenience methods (session management)
@@ -517,6 +574,12 @@ public abstract class IsisContext implements DebuggableWithTitle {
     @Override
     public void debugData(final DebugBuilder debug) {
         debug.appendln("context ", this);
+        debug.appendTitle("Threads based Contexts");
+        for (final Map.Entry<Thread, IsisSession> entry : sessionsByThread.entrySet()) {
+            final Thread thread = entry.getKey();
+            final IsisSession data = entry.getValue();
+            debug.appendln(thread.toString(), data);
+        }
     }
 
     /**
@@ -562,4 +625,49 @@ public abstract class IsisContext implements DebuggableWithTitle {
             }
         }
     }
+
+
+
+    public static IsisContext createInstance(final IsisSessionFactory sessionFactory) {
+        return new IsisContext(sessionFactory);
+    }
+
+    // TODO: could convert this to a regular ThreadLocal, I think; except for the closeAllSessionsInstance() method...; is that method really needed?
+    private final Map<Thread, IsisSession> sessionsByThread = new IdentityHashMap<>();
+
+
+
+
+    // /////////////////////////////////////////////////////////
+    // Session
+    // /////////////////////////////////////////////////////////
+
+
+    protected void shutdownAllThreads() {
+        synchronized (sessionsByThread) {
+            for (final Map.Entry<Thread, IsisSession> entry : sessionsByThread.entrySet()) {
+                LOG.info("Shutting down thread: {}", entry.getKey().getName());
+                final IsisSession data = entry.getValue();
+                data.closeAll();
+            }
+        }
+    }
+
+
+
+    // /////////////////////////////////////////////////////////
+    // Debugging
+    // /////////////////////////////////////////////////////////
+
+    @Override
+    public String debugTitle() {
+        return "Isis (by thread) " + Thread.currentThread().getName();
+    }
+
+
+
+
+
+
+
 }

http://git-wip-us.apache.org/repos/asf/isis/blob/ee58bb0c/core/runtime/src/main/java/org/apache/isis/core/runtime/system/context/IsisContextStatic.java
----------------------------------------------------------------------
diff --git a/core/runtime/src/main/java/org/apache/isis/core/runtime/system/context/IsisContextStatic.java b/core/runtime/src/main/java/org/apache/isis/core/runtime/system/context/IsisContextStatic.java
deleted file mode 100644
index 165d23e..0000000
--- a/core/runtime/src/main/java/org/apache/isis/core/runtime/system/context/IsisContextStatic.java
+++ /dev/null
@@ -1,137 +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.core.runtime.system.context;
-
-import org.apache.isis.core.commons.authentication.AuthenticationSession;
-import org.apache.isis.core.commons.debug.DebugBuilder;
-import org.apache.isis.core.commons.debug.DebuggableWithTitle;
-import org.apache.isis.core.runtime.system.DeploymentType;
-import org.apache.isis.core.runtime.system.session.IsisSession;
-import org.apache.isis.core.runtime.system.session.IsisSessionFactory;
-
-/**
- * Provides <i>access to</i> the current {@link IsisSession} in a single-user
- * {@link DeploymentType deployment} (and thus implemented as a <tt>static</tt>
- * singleton).
- */
-public class IsisContextStatic extends IsisContext {
-
-    private IsisSession session;
-
-    // //////////////////////////////////////////////
-    // Singleton & Constructor
-    // //////////////////////////////////////////////
-
-    public static IsisContext createInstance(final IsisSessionFactory sessionFactory) {
-        return new IsisContextStatic(ContextReplacePolicy.NOT_REPLACEABLE, SessionClosePolicy.EXPLICIT_CLOSE, sessionFactory);
-    }
-
-    /**
-     * Intended for testing; the singleton can be replaced and sessions are
-     * autoclosed.
-     */
-    public static IsisContext createRelaxedInstance(final IsisSessionFactory sessionFactory) {
-        return new IsisContextStatic(ContextReplacePolicy.REPLACEABLE, SessionClosePolicy.AUTO_CLOSE, sessionFactory);
-    }
-
-    protected IsisContextStatic(final ContextReplacePolicy replacePolicy, final SessionClosePolicy sessionClosePolicy, final IsisSessionFactory sessionFactory) {
-        super(replacePolicy, sessionClosePolicy, sessionFactory);
-    }
-
-    @Override
-    public IsisSession getSessionInstance() {
-        return session;
-    }
-
-    // //////////////////////////////////////////////
-    // open, close
-    // //////////////////////////////////////////////
-
-    @Override
-    public IsisSession openSessionInstance(final AuthenticationSession authenticationSession) {
-        applySessionClosePolicy();
-        session = getSessionFactoryInstance().openSession(authenticationSession);
-        session.open();
-        return session;
-    }
-
-    @Override
-    public void doClose() {
-        session = null;
-    }
-
-    // //////////////////////////////////////////////
-    // sessionId(s)
-    // //////////////////////////////////////////////
-
-    @Override
-    protected IsisSession getSessionInstance(final String sessionId) {
-        return getSessionInstance();
-    }
-
-    @Override
-    public String[] allSessionIds() {
-        return new String[] { getSessionInstance().getId() };
-    }
-
-    // //////////////////////////////////////////////
-    // Session
-    // //////////////////////////////////////////////
-
-    @Override
-    public void closeAllSessionsInstance() {
-        final IsisSession sessionInstance = getSessionInstance();
-        if (sessionInstance != null) {
-            sessionInstance.closeAll();
-        }
-    }
-
-    // //////////////////////////////////////////////
-    // Debugging
-    // //////////////////////////////////////////////
-
-    @Override
-    public String debugTitle() {
-        return "Static Context";
-    }
-
-    public void debug(final DebugBuilder debug) {
-        debug.appendAsHexln("hash", hashCode());
-        session.debugState(debug);
-    }
-
-    public void debugAll(final DebugBuilder debug) {
-        debug(debug);
-        debug.appendln();
-
-        debug(debug, getPersistenceSession());
-    }
-
-    private void debug(final DebugBuilder debug, final Object object) {
-        if (object instanceof DebuggableWithTitle) {
-            final DebuggableWithTitle d = (DebuggableWithTitle) object;
-            debug.appendTitle(d.debugTitle());
-            d.debugData(debug);
-        } else {
-            debug.appendln("no debug for " + object);
-        }
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/isis/blob/ee58bb0c/core/runtime/src/main/java/org/apache/isis/core/runtime/system/context/IsisContextThreadLocal.java
----------------------------------------------------------------------
diff --git a/core/runtime/src/main/java/org/apache/isis/core/runtime/system/context/IsisContextThreadLocal.java b/core/runtime/src/main/java/org/apache/isis/core/runtime/system/context/IsisContextThreadLocal.java
deleted file mode 100644
index 1e25e5e..0000000
--- a/core/runtime/src/main/java/org/apache/isis/core/runtime/system/context/IsisContextThreadLocal.java
+++ /dev/null
@@ -1,183 +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.core.runtime.system.context;
-
-import java.util.IdentityHashMap;
-import java.util.Map;
-
-import org.slf4j.Logger;
-import org.slf4j.LoggerFactory;
-
-import org.apache.isis.core.commons.authentication.AuthenticationSession;
-import org.apache.isis.core.commons.debug.DebugBuilder;
-import org.apache.isis.core.runtime.system.session.IsisSession;
-import org.apache.isis.core.runtime.system.session.IsisSessionFactory;
-
-/**
- * Multi-user implementation of {@link IsisContext} that stores a set of components for
- * each thread in use.
- */
-public class IsisContextThreadLocal extends IsisContext {
-
-    private static final Logger LOG = LoggerFactory.getLogger(IsisContextThreadLocal.class);
-
-    public static IsisContext createInstance(final IsisSessionFactory sessionFactory) {
-        return new IsisContextThreadLocal(sessionFactory);
-    }
-
-    // TODO: could convert this to a regular ThreadLocal, I think; except for the closeAllSessionsInstance() method...; is that method really needed?
-    private final Map<Thread, IsisSession> sessionsByThread = new IdentityHashMap<>();
-
-    
-    // //////////////////////////////////////////////
-    // Constructor
-    // //////////////////////////////////////////////
-
-    protected IsisContextThreadLocal(final IsisSessionFactory sessionFactory) {
-        this(ContextReplacePolicy.NOT_REPLACEABLE, SessionClosePolicy.AUTO_CLOSE, sessionFactory);
-    }
-
-    protected IsisContextThreadLocal(final ContextReplacePolicy contextReplacePolicy, final SessionClosePolicy sessionClosePolicy, final IsisSessionFactory sessionFactory) {
-        super(contextReplacePolicy, sessionClosePolicy, sessionFactory);
-    }
-
-
-    // /////////////////////////////////////////////////////////
-    // Session
-    // /////////////////////////////////////////////////////////
-
-    @Override
-    public void closeAllSessionsInstance() {
-        shutdownAllThreads();
-    }
-
-    protected void shutdownAllThreads() {
-        synchronized (sessionsByThread) {
-            for (final Map.Entry<Thread, IsisSession> entry : sessionsByThread.entrySet()) {
-                LOG.info("Shutting down thread: {}", entry.getKey().getName());
-                final IsisSession data = entry.getValue();
-                data.closeAll();
-            }
-        }
-    }
-
-    @Override
-    protected void doClose() {
-        sessionsByThread.remove(Thread.currentThread());
-    }
-
-    // /////////////////////////////////////////////////////////
-    // Execution Context Ids
-    // /////////////////////////////////////////////////////////
-
-    @Override
-    public String[] allSessionIds() {
-        final String[] ids = new String[sessionsByThread.size()];
-        int i = 0;
-        for (final IsisSession data  : sessionsByThread.values()) {
-            ids[i++] = data.getId();
-        }
-        return ids;
-    }
-
-    // /////////////////////////////////////////////////////////
-    // Debugging
-    // /////////////////////////////////////////////////////////
-
-    @Override
-    public String debugTitle() {
-        return "Isis (by thread) " + Thread.currentThread().getName();
-    }
-
-    @Override
-    public void debugData(final DebugBuilder debug) {
-        super.debugData(debug);
-        debug.appendTitle("Threads based Contexts");
-        for (final Map.Entry<Thread, IsisSession> entry : sessionsByThread.entrySet()) {
-            final Thread thread = entry.getKey();
-            final IsisSession data = entry.getValue();
-            debug.appendln(thread.toString(), data);
-        }
-    }
-
-
-    // /////////////////////////////////////////////////////////
-    // open, close
-    // /////////////////////////////////////////////////////////
-
-    @Override
-    protected IsisSession getSessionInstance(final String executionContextId) {
-        for (final IsisSession data : sessionsByThread.values()) {
-            if (data.getId().equals(executionContextId)) {
-                return data;
-            }
-        }
-        return null;
-    }
-
-    /**
-     * Is only intended to be called through
-     * {@link IsisContext#openSession(AuthenticationSession)}.
-     * 
-     * <p>
-     * Implementation note: an alternative design would have just been to bind
-     * onto a thread local.
-     */
-    @Override
-    public IsisSession openSessionInstance(final AuthenticationSession authenticationSession) {
-        final Thread thread = Thread.currentThread();
-        synchronized (sessionsByThread) {
-            applySessionClosePolicy();
-            final IsisSession session = getSessionFactoryInstance().openSession(authenticationSession);
-            if (LOG.isDebugEnabled()) {
-                LOG.debug("  opening session " + session + " (count " + sessionsByThread.size() + ") for " + authenticationSession.getUserName());
-            }
-            saveSession(thread, session);
-            session.open();
-            return session;
-        }
-    }
-
-    private IsisSession saveSession(final Thread thread, final IsisSession session) {
-        synchronized (sessionsByThread) {
-            sessionsByThread.put(thread, session);
-        }
-        if (LOG.isDebugEnabled()) {
-            LOG.debug("  saving session " + session + "; now have " + sessionsByThread.size() + " sessions");
-        }
-        return session;
-    }
-
-    // /////////////////////////////////////////////////////////
-    // getCurrent() (Hook)
-    // /////////////////////////////////////////////////////////
-
-    /**
-     * Get {@link IsisSession execution context} used by the current thread.
-     * 
-     * @see #openSessionInstance(AuthenticationSession)
-     */
-    @Override
-    public IsisSession getSessionInstance() {
-        final Thread thread = Thread.currentThread();
-        return sessionsByThread.get(thread);
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/isis/blob/ee58bb0c/core/runtime/src/test/java/org/apache/isis/core/runtime/context/IsisContextTest.java
----------------------------------------------------------------------
diff --git a/core/runtime/src/test/java/org/apache/isis/core/runtime/context/IsisContextTest.java b/core/runtime/src/test/java/org/apache/isis/core/runtime/context/IsisContextTest.java
deleted file mode 100644
index 51afc3a..0000000
--- a/core/runtime/src/test/java/org/apache/isis/core/runtime/context/IsisContextTest.java
+++ /dev/null
@@ -1,140 +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.core.runtime.context;
-
-import java.util.Collections;
-import java.util.List;
-import org.jmock.Expectations;
-import org.jmock.auto.Mock;
-import org.junit.*;
-import org.apache.isis.applib.DomainObjectContainer;
-import org.apache.isis.core.commons.authentication.AuthenticationSession;
-import org.apache.isis.core.commons.config.IsisConfiguration;
-import org.apache.isis.core.commons.config.IsisConfigurationDefault;
-import org.apache.isis.core.metamodel.adapter.oid.OidMarshaller;
-import org.apache.isis.core.metamodel.services.ServicesInjectorSpi;
-import org.apache.isis.core.metamodel.spec.SpecificationLoaderSpi;
-import org.apache.isis.core.runtime.authentication.AuthenticationManager;
-import org.apache.isis.core.runtime.authentication.standard.SimpleSession;
-import org.apache.isis.core.runtime.authorization.AuthorizationManager;
-import org.apache.isis.core.runtime.system.persistence.PersistenceSessionFactory;
-import org.apache.isis.core.runtime.system.DeploymentType;
-import org.apache.isis.core.runtime.system.context.IsisContext;
-import org.apache.isis.core.runtime.system.context.IsisContextStatic;
-import org.apache.isis.core.runtime.system.persistence.PersistenceSession;
-import org.apache.isis.core.runtime.system.session.IsisSessionFactory;
-import org.apache.isis.core.unittestsupport.jmocking.JUnitRuleMockery2;
-import org.apache.isis.core.unittestsupport.jmocking.JUnitRuleMockery2.Mode;
-
-public class IsisContextTest {
-
-    @Rule
-    public JUnitRuleMockery2 context = JUnitRuleMockery2.createFor(Mode.INTERFACES_AND_CLASSES);
-    
-
-    private IsisConfiguration configuration;
-    
-    @Mock
-    private PersistenceSession mockPersistenceSession;
-    
-    @Mock
-    private SpecificationLoaderSpi mockSpecificationLoader;
-
-    @Mock
-    protected ServicesInjectorSpi mockServicesInjector;
-    @Mock
-    protected PersistenceSessionFactory mockPersistenceSessionFactory;
-    @Mock
-    protected AuthenticationManager mockAuthenticationManager;
-    @Mock
-    protected AuthorizationManager mockAuthorizationManager;
-
-    @Mock
-    protected DomainObjectContainer mockContainer;
-    
-    protected OidMarshaller oidMarshaller;
-
-    private List<Object> servicesList;
-
-
-    private AuthenticationSession authSession;
-
-
-    private IsisSessionFactory sessionFactory;
-
-    @Before
-    public void setUp() throws Exception {
-        IsisContext.testReset();
-
-        servicesList = Collections.emptyList();
-
-        configuration = new IsisConfigurationDefault();
-        
-        oidMarshaller = new OidMarshaller();
-        
-        context.ignoring(
-                mockPersistenceSession,
-                mockSpecificationLoader,
-                mockAuthenticationManager,
-                mockAuthorizationManager,
-                mockContainer);
-
-        sessionFactory = new IsisSessionFactory(DeploymentType.UNIT_TESTING, configuration, mockServicesInjector,
-                mockSpecificationLoader, mockAuthenticationManager, mockAuthorizationManager, mockPersistenceSessionFactory);
-        authSession = new SimpleSession("tester", Collections.<String>emptyList());
-        
-        IsisContext.setConfiguration(configuration);
-    }
-    
-    @After
-    public void tearDown() throws Exception {
-        if(IsisContext.inSession()) {
-            IsisContext.closeSession();
-        }
-    }
-    
-    @Test
-    public void getConfiguration() {
-        IsisContextStatic.createRelaxedInstance(sessionFactory);
-
-        Assert.assertEquals(configuration, IsisContext.getConfiguration());
-    }
-
-    @Test
-    public void openSession_getSpecificationLoader() {
-        IsisContextStatic.createRelaxedInstance(sessionFactory);
-
-        // expecting
-        context.checking(new Expectations() {{
-            one(mockPersistenceSessionFactory)
-                    .createPersistenceSession(mockServicesInjector, mockSpecificationLoader, authSession);
-            will(returnValue(mockPersistenceSession));
-        }});
-
-        IsisContext.openSession(authSession);
-
-        Assert.assertEquals(mockSpecificationLoader, IsisContext.getSpecificationLoader());
-        Assert.assertEquals(authSession, IsisContext.getAuthenticationSession());
-        final PersistenceSession persistenceSession = IsisContext.getPersistenceSession();
-        Assert.assertNotNull(persistenceSession);
-    }
-
-
-}

http://git-wip-us.apache.org/repos/asf/isis/blob/ee58bb0c/core/viewer-wicket-impl/src/main/java/org/apache/isis/viewer/wicket/viewer/integration/isis/DeploymentTypeAbstract.java
----------------------------------------------------------------------
diff --git a/core/viewer-wicket-impl/src/main/java/org/apache/isis/viewer/wicket/viewer/integration/isis/DeploymentTypeAbstract.java b/core/viewer-wicket-impl/src/main/java/org/apache/isis/viewer/wicket/viewer/integration/isis/DeploymentTypeAbstract.java
index cfca7c6..7076e5a 100644
--- a/core/viewer-wicket-impl/src/main/java/org/apache/isis/viewer/wicket/viewer/integration/isis/DeploymentTypeAbstract.java
+++ b/core/viewer-wicket-impl/src/main/java/org/apache/isis/viewer/wicket/viewer/integration/isis/DeploymentTypeAbstract.java
@@ -20,18 +20,12 @@
 package org.apache.isis.viewer.wicket.viewer.integration.isis;
 
 import org.apache.isis.core.metamodel.deployment.DeploymentCategory;
-import org.apache.isis.core.runtime.system.ContextCategory;
 import org.apache.isis.core.runtime.system.DeploymentType;
 
-/**
- * Simple adapter for Isis' {@link DeploymentType} class, specifying that the
- * {@link ContextCategory#THREADLOCAL} is used as the
- * {@link ContextCategory}.
- */
 public abstract class DeploymentTypeAbstract extends DeploymentType {
 
     public DeploymentTypeAbstract(final String name, final DeploymentCategory category) {
-        super(name, category, ContextCategory.THREADLOCAL);
+        super(name, category);
     }
 
 }


[13/17] isis git commit: [maven-release-plugin] prepare for next development iteration

Posted by da...@apache.org.
[maven-release-plugin] prepare for next development iteration


Project: http://git-wip-us.apache.org/repos/asf/isis/repo
Commit: http://git-wip-us.apache.org/repos/asf/isis/commit/006f98a2
Tree: http://git-wip-us.apache.org/repos/asf/isis/tree/006f98a2
Diff: http://git-wip-us.apache.org/repos/asf/isis/diff/006f98a2

Branch: refs/heads/master
Commit: 006f98a2a119eadc01313a5371148071a710c2bc
Parents: 54f7ec1
Author: Dan Haywood <da...@haywood-associates.co.uk>
Authored: Sun Jan 10 15:28:20 2016 +0000
Committer: Dan Haywood <da...@haywood-associates.co.uk>
Committed: Sun Jan 10 15:28:20 2016 +0000

----------------------------------------------------------------------
 example/archetype/simpleapp/pom.xml | 6 +-----
 1 file changed, 1 insertion(+), 5 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/isis/blob/006f98a2/example/archetype/simpleapp/pom.xml
----------------------------------------------------------------------
diff --git a/example/archetype/simpleapp/pom.xml b/example/archetype/simpleapp/pom.xml
index 4d52c33..e884eab 100644
--- a/example/archetype/simpleapp/pom.xml
+++ b/example/archetype/simpleapp/pom.xml
@@ -21,7 +21,7 @@
     <modelVersion>4.0.0</modelVersion>
     <groupId>org.apache.isis.archetype</groupId>
     <artifactId>simpleapp-archetype</artifactId>
-    <version>1.11.1</version>
+    <version>1.12.0-SNAPSHOT</version>
     <packaging>maven-archetype</packaging>
     <name>simpleapp-archetype</name>
     <build>
@@ -47,8 +47,4 @@
         <version>1.11.1</version>
         <relativePath>../../../core/pom.xml</relativePath>
     </parent>
-
-  <scm>
-    <tag>simpleapp-archetype-1.11.1</tag>
-  </scm>
 </project>


[03/17] isis git commit: ISIS-1287: fixing name of the isis-templates-idea.xml

Posted by da...@apache.org.
ISIS-1287: fixing name of the isis-templates-idea.xml


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

Branch: refs/heads/master
Commit: dab4fcadf302d5e291cb073f0d9c286c50957f79
Parents: e86e7ad
Author: Dan Haywood <da...@haywood-associates.co.uk>
Authored: Sun Jan 10 12:23:21 2016 +0000
Committer: Dan Haywood <da...@haywood-associates.co.uk>
Committed: Sun Jan 10 12:23:21 2016 +0000

----------------------------------------------------------------------
 .../resources/templates/isis-template-idea.xml  | 522 -------------------
 .../resources/templates/isis-templates-idea.xml | 522 +++++++++++++++++++
 2 files changed, 522 insertions(+), 522 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/isis/blob/dab4fcad/adocs/documentation/src/main/asciidoc/resources/templates/isis-template-idea.xml
----------------------------------------------------------------------
diff --git a/adocs/documentation/src/main/asciidoc/resources/templates/isis-template-idea.xml b/adocs/documentation/src/main/asciidoc/resources/templates/isis-template-idea.xml
deleted file mode 100644
index 916bceb..0000000
--- a/adocs/documentation/src/main/asciidoc/resources/templates/isis-template-idea.xml
+++ /dev/null
@@ -1,522 +0,0 @@
-<templateSet group="Apache Isis">
-  <template name="isa" value="@org.apache.isis.applib.annotation.Action()&#10;public $ReturnType$ $actionName$(final $ParameterType$ $parameterType$) {&#10;    return $END$null; // TODO: business logic here&#10;}&#10;" description="Apache Isis Action" toReformat="true" toShortenFQNames="true">
-    <variable name="actionName" expression="&quot;actionName&quot;" defaultValue="" alwaysStopAt="true" />
-    <variable name="ParameterType" expression="classNameComplete()" defaultValue="" alwaysStopAt="true" />
-    <variable name="parameterType" expression="suggestVariableName()" defaultValue="" alwaysStopAt="true" />
-    <variable name="ReturnType" expression="className()" defaultValue="" alwaysStopAt="true" />
-    <context>
-      <option name="HTML" value="false" />
-      <option name="XML" value="false" />
-      <option name="JAVA_CODE" value="false" />
-      <option name="JAVA_DECLARATION" value="true" />
-      <option name="JAVA_COMMENT" value="false" />
-      <option name="JAVA_STRING" value="false" />
-      <option name="COMPLETION" value="false" />
-      <option name="OTHER" value="false" />
-    </context>
-  </template>
-  <template name="isa-p-auto" value="public java.util.Collection&lt;$ParameterType$&gt; autoComplete$ParameterNum$$ActionName$(final String search) {&#10;    return $END$com.google.common.collect.Lists.newArrayList(); // TODO: return list of choices for argument N&#10;}" description="Apache Isis Action parameter auto-complete" toReformat="true" toShortenFQNames="true">
-    <variable name="ParameterNum" expression="&quot;Num&quot;" defaultValue="" alwaysStopAt="true" />
-    <variable name="ActionName" expression="&quot;ActionName&quot;" defaultValue="" alwaysStopAt="true" />
-    <variable name="ParameterType" expression="className()" defaultValue="" alwaysStopAt="true" />
-    <context>
-      <option name="HTML" value="false" />
-      <option name="XML" value="false" />
-      <option name="JAVA_CODE" value="false" />
-      <option name="JAVA_DECLARATION" value="true" />
-      <option name="JAVA_COMMENT" value="false" />
-      <option name="JAVA_STRING" value="false" />
-      <option name="COMPLETION" value="false" />
-      <option name="OTHER" value="false" />
-    </context>
-  </template>
-  <template name="isa-p-cho" value="public java.util.List&lt;$ParameterType$&gt; choices$ParameterNum$$ActionName$() {&#10;    return $END$com.google.common.collect.Lists.newArrayList(); // TODO: return list of choices for argument N&#10;}" description="Apache Isis Action parameter choices" toReformat="true" toShortenFQNames="true">
-    <variable name="ParameterNum" expression="&quot;Num&quot;" defaultValue="" alwaysStopAt="true" />
-    <variable name="ActionName" expression="&quot;ActionName&quot;" defaultValue="" alwaysStopAt="true" />
-    <variable name="ParameterType" expression="className()" defaultValue="" alwaysStopAt="true" />
-    <context>
-      <option name="HTML" value="false" />
-      <option name="XML" value="false" />
-      <option name="JAVA_CODE" value="false" />
-      <option name="JAVA_DECLARATION" value="true" />
-      <option name="JAVA_COMMENT" value="false" />
-      <option name="JAVA_STRING" value="false" />
-      <option name="COMPLETION" value="false" />
-      <option name="OTHER" value="false" />
-    </context>
-  </template>
-  <template name="isa-p-def" value="public $ParameterType$ default$ParameterNum$$ActionName$() {&#10;    return $END$null; // TODO: return default for argument N&#10;}" description="Apache Isis Action parameter defaults" toReformat="true" toShortenFQNames="true">
-    <variable name="ParameterNum" expression="&quot;Num&quot;" defaultValue="" alwaysStopAt="true" />
-    <variable name="ActionName" expression="&quot;ActionName&quot;" defaultValue="" alwaysStopAt="true" />
-    <variable name="ParameterType" expression="className()" defaultValue="" alwaysStopAt="true" />
-    <context>
-      <option name="HTML" value="false" />
-      <option name="XML" value="false" />
-      <option name="JAVA_CODE" value="false" />
-      <option name="JAVA_DECLARATION" value="true" />
-      <option name="JAVA_COMMENT" value="false" />
-      <option name="JAVA_STRING" value="false" />
-      <option name="COMPLETION" value="false" />
-      <option name="OTHER" value="false" />
-    </context>
-  </template>
-  <template name="isa-p-val" value="public String validate$ParamNum}$ActionName$(final $ParameterType$ $parameterType$) {&#10;    return $END$null; // TODO: return reason why action argument are invalid, null if ok&#10;}" description="Apache Isis Action parameter validation" toReformat="true" toShortenFQNames="true">
-    <variable name="ActionName" expression="&quot;ActionName&quot;" defaultValue="" alwaysStopAt="true" />
-    <variable name="ParameterType" expression="className()" defaultValue="" alwaysStopAt="true" />
-    <variable name="parameterType" expression="suggestVariableName()" defaultValue="" alwaysStopAt="true" />
-    <context>
-      <option name="HTML" value="false" />
-      <option name="XML" value="false" />
-      <option name="JAVA_CODE" value="false" />
-      <option name="JAVA_DECLARATION" value="true" />
-      <option name="JAVA_COMMENT" value="false" />
-      <option name="JAVA_STRING" value="false" />
-      <option name="COMPLETION" value="false" />
-      <option name="OTHER" value="false" />
-    </context>
-  </template>
-  <template name="isa-dis" value="public String disable$ActionName$() {&#10;    return $END$null; // TODO: return reason why action disabled, null if enabled&#10;}" description="Apache Isis Action disablement" toReformat="true" toShortenFQNames="true">
-    <variable name="ActionName" expression="&quot;ActionName&quot;" defaultValue="" alwaysStopAt="true" />
-    <context>
-      <option name="HTML" value="false" />
-      <option name="XML" value="false" />
-      <option name="JAVA_CODE" value="false" />
-      <option name="JAVA_DECLARATION" value="true" />
-      <option name="JAVA_COMMENT" value="false" />
-      <option name="JAVA_STRING" value="false" />
-      <option name="COMPLETION" value="false" />
-      <option name="OTHER" value="false" />
-    </context>
-  </template>
-  <template name="isa-event" value="public static class $ActionName$DomainEvent extends ActionDomainEvent{}&#10;@org.apache.isis.applib.annotation.Action(&#10;        domainEvent = $ActionName$DomainEvent.class&#10;)&#10;public $ReturnType$ $actionName$(final $ParameterType$ $parameterType$) {&#10;    return $END$null; // TODO: business logic here&#10;}&#10;" description="Apache Isis Action (with domain event)" toReformat="true" toShortenFQNames="true">
-    <variable name="actionName" expression="&quot;actionName&quot;" defaultValue="" alwaysStopAt="true" />
-    <variable name="ActionName" expression="capitalize(actionName)" defaultValue="" alwaysStopAt="false" />
-    <variable name="ParameterType" expression="classNameComplete()" defaultValue="" alwaysStopAt="true" />
-    <variable name="parameterType" expression="suggestVariableName()" defaultValue="" alwaysStopAt="true" />
-    <variable name="ReturnType" expression="className()" defaultValue="" alwaysStopAt="true" />
-    <context>
-      <option name="HTML" value="false" />
-      <option name="XML" value="false" />
-      <option name="JAVA_CODE" value="false" />
-      <option name="JAVA_DECLARATION" value="true" />
-      <option name="JAVA_COMMENT" value="false" />
-      <option name="JAVA_STRING" value="false" />
-      <option name="COMPLETION" value="false" />
-      <option name="OTHER" value="false" />
-    </context>
-  </template>
-  <template name="isa-event-decl" value="public static class $ActionName$DomainEvent extends ActionDomainEvent{}&#10;@org.apache.isis.applib.annotation.Action(&#10;        domainEvent = $ActionName$DomainEvent.class&#10;)&#10;" description="Apache Isis Action (domain event declaration only)" toReformat="true" toShortenFQNames="true">
-    <variable name="ActionName" expression="" defaultValue="" alwaysStopAt="true" />
-    <context>
-      <option name="HTML" value="false" />
-      <option name="XML" value="false" />
-      <option name="JAVA_CODE" value="false" />
-      <option name="JAVA_DECLARATION" value="true" />
-      <option name="JAVA_COMMENT" value="false" />
-      <option name="JAVA_STRING" value="false" />
-      <option name="COMPLETION" value="false" />
-      <option name="OTHER" value="false" />
-    </context>
-  </template>
-  <template name="isa-hid" value="public boolean hide$ActionName$() {&#10;    return $END$false; // TODO: return true if action is hidden, false if visible&#10;}" description="Apache Isis Action visibility" toReformat="true" toShortenFQNames="true">
-    <variable name="ActionName" expression="&quot;ActionName&quot;" defaultValue="" alwaysStopAt="true" />
-    <context>
-      <option name="HTML" value="false" />
-      <option name="XML" value="false" />
-      <option name="JAVA_CODE" value="false" />
-      <option name="JAVA_DECLARATION" value="true" />
-      <option name="JAVA_COMMENT" value="false" />
-      <option name="JAVA_STRING" value="false" />
-      <option name="COMPLETION" value="false" />
-      <option name="OTHER" value="false" />
-    </context>
-  </template>
-  <template name="isa-val" value="public String validate$ActionName$(final $ParameterType$ $parameterType$) {&#10;    return $END$null; // TODO: return reason why action arguments are invalid, null if ok&#10;}" description="Apache Isis Action validation" toReformat="true" toShortenFQNames="true">
-    <variable name="ActionName" expression="&quot;ActionName&quot;" defaultValue="" alwaysStopAt="true" />
-    <variable name="ParameterType" expression="className()" defaultValue="" alwaysStopAt="true" />
-    <variable name="parameterType" expression="suggestVariableName()" defaultValue="" alwaysStopAt="true" />
-    <context>
-      <option name="HTML" value="false" />
-      <option name="XML" value="false" />
-      <option name="JAVA_CODE" value="false" />
-      <option name="JAVA_DECLARATION" value="true" />
-      <option name="JAVA_COMMENT" value="false" />
-      <option name="JAVA_STRING" value="false" />
-      <option name="COMPLETION" value="false" />
-      <option name="OTHER" value="false" />
-    </context>
-  </template>
-  <template name="isc-dis" value="public String disable$CollectionName$() {&#10;    return $END$null; // TODO: return reason why collection read-only, null if editable&#10;}" description="Apache Isis Collection disablement" toReformat="true" toShortenFQNames="true">
-    <variable name="CollectionName" expression="&quot;CollectionName&quot;" defaultValue="" alwaysStopAt="true" />
-    <context>
-      <option name="HTML" value="false" />
-      <option name="XML" value="false" />
-      <option name="JAVA_CODE" value="false" />
-      <option name="JAVA_DECLARATION" value="true" />
-      <option name="JAVA_COMMENT" value="false" />
-      <option name="JAVA_STRING" value="false" />
-      <option name="COMPLETION" value="false" />
-      <option name="OTHER" value="false" />
-    </context>
-  </template>
-  <template name="isc-hid" value="public boolean hide$CollectionName$() {&#10;    return $END$false; // TODO: return true if hidden, false otherwise&#10;}" description="Apache Isis Collection visibility" toReformat="true" toShortenFQNames="false">
-    <variable name="CollectionName" expression="&quot;CollectionName&quot;" defaultValue="" alwaysStopAt="true" />
-    <context>
-      <option name="HTML" value="false" />
-      <option name="XML" value="false" />
-      <option name="JAVA_CODE" value="false" />
-      <option name="JAVA_DECLARATION" value="true" />
-      <option name="JAVA_COMMENT" value="false" />
-      <option name="JAVA_STRING" value="false" />
-      <option name="COMPLETION" value="false" />
-      <option name="OTHER" value="false" />
-    </context>
-  </template>
-  <template name="isc-jdo-1m-b-fk" value="@org.apache.isis.applib.annotation.Collection()&#10;@javax.jdo.annotations.Persistent(mappedBy=&quot;$elementNameInChild$&quot;, dependentElement=&quot;$trueOrFalse$&quot;)&#10;@lombok.Getter @lombok.Setter&#10;private java.util.SortedSet&lt;$ElementType$&gt; $collectionName$ = new java.util.TreeSet&lt;$ElementType$&gt;();&#10;" description="Apache Isis Collection (JDO, 1:m parent bidirectional to foreign key)" toReformat="true" toShortenFQNames="true">
-    <variable name="ElementType" expression="classNameComplete()" defaultValue="" alwaysStopAt="true" />
-    <variable name="collectionName" expression="suggestVariableName()" defaultValue="" alwaysStopAt="true" />
-    <variable name="elementNameInChild" expression="decapitalize(EntityName)" defaultValue="" alwaysStopAt="false" />
-    <variable name="trueOrFalse" expression="&quot;trueOrFalse&quot;" defaultValue="" alwaysStopAt="true" />
-    <context>
-      <option name="HTML" value="false" />
-      <option name="XML" value="false" />
-      <option name="JAVA_CODE" value="false" />
-      <option name="JAVA_DECLARATION" value="true" />
-      <option name="JAVA_COMMENT" value="false" />
-      <option name="JAVA_STRING" value="false" />
-      <option name="COMPLETION" value="false" />
-      <option name="OTHER" value="false" />
-    </context>
-  </template>
-  <template name="isc-jdo-1m-b-jt" value="@org.apache.isis.applib.annotation.Collection()&#10;@javax.jdo.annotations.Persistent(mappedBy=&quot;$elementNameInChild$&quot;, dependentElement=&quot;$trueOrFalse$&quot;)&#10;@javax.jdo.annotations.Join&#10;@lombok.Getter @lombok.Setter&#10;private java.util.SortedSet&lt;$ElementType$&gt; $collectionName$ = new java.util.TreeSet&lt;$ElementType$&gt;();&#10;" description="Apache Isis Collection (JDO, 1:m parent bidirectional to join table)" toReformat="true" toShortenFQNames="true">
-    <variable name="ElementType" expression="classNameComplete()" defaultValue="" alwaysStopAt="true" />
-    <variable name="collectionName" expression="suggestVariableName()" defaultValue="" alwaysStopAt="true" />
-    <variable name="elementNameInChild" expression="decapitalize(EntityName)" defaultValue="" alwaysStopAt="false" />
-    <variable name="trueOrFalse" expression="&quot;trueOrFalse&quot;" defaultValue="" alwaysStopAt="true" />
-    <context>
-      <option name="HTML" value="false" />
-      <option name="XML" value="false" />
-      <option name="JAVA_CODE" value="false" />
-      <option name="JAVA_DECLARATION" value="true" />
-      <option name="JAVA_COMMENT" value="false" />
-      <option name="JAVA_STRING" value="false" />
-      <option name="COMPLETION" value="false" />
-      <option name="OTHER" value="false" />
-    </context>
-  </template>
-  <template name="isc-jdo-1m-u-fk" value="@org.apache.isis.applib.annotation.Collection()&#10;@javax.jdo.annotations.Element(column=&quot;$ColumnName$&quot;, dependent=&quot;$trueOrFalse$&quot;)&#10;@lombok.Getter @lombok.Setter&#10;private java.util.SortedSet&lt;$ElementType$&gt; $collectionName$ = new java.util.TreeSet&lt;$ElementType$&gt;();&#10;" description="Apache Isis JDO Collection (1:m parent unidirectional)" toReformat="true" toShortenFQNames="true">
-    <variable name="ElementType" expression="classNameComplete()" defaultValue="" alwaysStopAt="true" />
-    <variable name="collectionName" expression="suggestVariableName()" defaultValue="" alwaysStopAt="true" />
-    <variable name="ColumnName" expression="&quot;ColumnName&quot;" defaultValue="" alwaysStopAt="true" />
-    <variable name="trueOrFalse" expression="&quot;trueOrFalse&quot;" defaultValue="" alwaysStopAt="true" />
-    <context>
-      <option name="HTML" value="false" />
-      <option name="XML" value="false" />
-      <option name="JAVA_CODE" value="false" />
-      <option name="JAVA_DECLARATION" value="true" />
-      <option name="JAVA_COMMENT" value="false" />
-      <option name="JAVA_STRING" value="false" />
-      <option name="COMPLETION" value="false" />
-      <option name="OTHER" value="false" />
-    </context>
-  </template>
-  <template name="isc-jdo-1m-u-jt" value="@org.apache.isis.applib.annotation.Collection()&#10;@javax.jdo.annotations.Join&#10;@javax.jdo.annotations.Element(dependent=&quot;$trueOrFalse$&quot;)&#10;@lombok.Getter @lombok.Setter&#10;private java.util.SortedSet&lt;$ElementType$&gt; $collectionName$ = new java.util.TreeSet&lt;$ElementType$&gt;();&#10;" description="Apache Isis Collection (JDO, 1:m parent unidirectional to join table)" toReformat="true" toShortenFQNames="true">
-    <variable name="ElementType" expression="classNameComplete()" defaultValue="" alwaysStopAt="true" />
-    <variable name="collectionName" expression="suggestVariableName()" defaultValue="" alwaysStopAt="true" />
-    <variable name="trueOrFalse" expression="&quot;trueOrFalse&quot;" defaultValue="" alwaysStopAt="true" />
-    <context>
-      <option name="HTML" value="false" />
-      <option name="XML" value="false" />
-      <option name="JAVA_CODE" value="false" />
-      <option name="JAVA_DECLARATION" value="true" />
-      <option name="JAVA_COMMENT" value="false" />
-      <option name="JAVA_STRING" value="false" />
-      <option name="COMPLETION" value="false" />
-      <option name="OTHER" value="false" />
-    </context>
-  </template>
-  <template name="isc-jdo-mn-ub-c" value="@org.apache.isis.applib.annotation.Collection()&#10;@javax.jdo.annotations.Persistent(mappedBy=&quot;$ChildCollectionNameInParent$&quot;)&#10;@lombok.Getter @lombok.Setter&#10;private java.util.SortedSet&lt;$ElementType$&gt; $collectionName$ = new java.util.TreeSet&lt;$ElementType$&gt;(); &#10;" description="Apache Isis Collection (JDO, m:n child)" toReformat="true" toShortenFQNames="true">
-    <variable name="ElementType" expression="classNameComplete()" defaultValue="" alwaysStopAt="true" />
-    <variable name="collectionName" expression="suggestVariableName()" defaultValue="" alwaysStopAt="true" />
-    <variable name="ChildCollectionNameInParent" expression="&quot;ChildCollectionNameInParent&quot;" defaultValue="" alwaysStopAt="true" />
-    <context>
-      <option name="HTML" value="false" />
-      <option name="XML" value="false" />
-      <option name="JAVA_CODE" value="false" />
-      <option name="JAVA_DECLARATION" value="true" />
-      <option name="JAVA_COMMENT" value="false" />
-      <option name="JAVA_STRING" value="false" />
-      <option name="COMPLETION" value="false" />
-      <option name="OTHER" value="false" />
-    </context>
-  </template>
-  <template name="isc-jdo-mn-ub-p" value="@org.apache.isis.applib.annotation.Collection()&#10;@javax.jdo.annotations.Persistent(table=&quot;$TableName$&quot;) &#10;@javax.jdo.annotations.Join(column=&quot;$ThisEntityFieldName$&quot;) &#10;@javax.jdo.annotations.Element(column=&quot;$RelatedEntityFieldName$&quot;)&#10;@lombok.Getter @lombok.Setter&#10;private java.util.SortedSet&lt;$ElementType$&gt; $collectionName$ = new java.util.TreeSet&lt;$ElementType$&gt;();&#10;" description="Apache Isis Collection (JDO, m:n parent)" toReformat="true" toShortenFQNames="true">
-    <variable name="ElementType" expression="classNameComplete()" defaultValue="" alwaysStopAt="true" />
-    <variable name="collectionName" expression="suggestVariableName()" defaultValue="" alwaysStopAt="true" />
-    <variable name="TableName" expression="&quot;TableName&quot;" defaultValue="" alwaysStopAt="true" />
-    <variable name="ThisEntityFieldName" expression="&quot;ThisEntityFieldName&quot;" defaultValue="" alwaysStopAt="true" />
-    <variable name="RelatedEntityFieldName" expression="&quot;RelatedEntityFieldName&quot;" defaultValue="" alwaysStopAt="true" />
-    <context>
-      <option name="HTML" value="false" />
-      <option name="XML" value="false" />
-      <option name="JAVA_CODE" value="false" />
-      <option name="JAVA_DECLARATION" value="true" />
-      <option name="JAVA_COMMENT" value="false" />
-      <option name="JAVA_STRING" value="false" />
-      <option name="COMPLETION" value="false" />
-      <option name="OTHER" value="false" />
-    </context>
-  </template>
-  <template name="isds-subscriber-on" value="@com.google.common.eventbus.Subscribe&#10;public void on(final $EventType$ ev) {&#10;    // TODO&#10;}&#10;" description="Apache Isis Domain Service Subscriber &quot;on&quot; event" toReformat="false" toShortenFQNames="true">
-    <variable name="EventType" expression="classNameComplete()" defaultValue="" alwaysStopAt="true" />
-    <context>
-      <option name="JAVA_DECLARATION" value="true" />
-    </context>
-  </template>
-  <template name="isjaxb-package.info" value="@javax.xml.bind.annotation.XmlSchema(&#10;        namespace = &quot;http://$namespaceBase$/$namespaceSuffix$/v$versionMajor$_$versionMinor$/$namespaceSuffix$.xsd&quot;,&#10;        xmlns = {&#10;                @javax.xml.bind.annotation.XmlNs(&#10;                        namespaceURI = &quot;http://isis.apache.org/schema/common&quot;,&#10;                        prefix = &quot;common&quot;&#10;                ),&#10;        },&#10;        elementFormDefault = javax.xml.bind.annotation.XmlNsForm.QUALIFIED&#10;)" toReformat="false" toShortenFQNames="true">
-    <variable name="namespaceBase" expression="        groovyScript(&quot;def str = _1; def list = str.split(\&quot;\\\\.\&quot;); def revlist = list.reverse(); def ret = revlist.iterator().join(\&quot;.\&quot;); return ret&quot;, currentPackage())" defaultValue="" alwaysStopAt="true" />
-    <variable name="namespaceSuffix" expression="groovyScript(&quot;def str = _1; def list = str.split(\&quot;\\\\.\&quot;); def revlist = list.reverse(); def ret = revlist[0]; return ret&quot;, currentPackage())" defaultValue="" alwaysStopAt="true" />
-    <variable name="versionMajor" expression="" defaultValue="1" alwaysStopAt="true" />
-    <variable name="versionMinor" expression="" defaultValue="0" alwaysStopAt="true" />
-    <context>
-      <option name="JAVA_DECLARATION" value="true" />
-    </context>
-  </template>
-  <template name="isinject" value="@javax.inject.Inject&#10;$ServiceType$ $serviceType$;&#10;" description="Apache Isis Injected Dependency Service" toReformat="true" toShortenFQNames="true">
-    <variable name="ServiceType" expression="className()" defaultValue="" alwaysStopAt="true" />
-    <variable name="serviceType" expression="suggestVariableName()" defaultValue="" alwaysStopAt="true" />
-    <context>
-      <option name="HTML" value="false" />
-      <option name="XML" value="false" />
-      <option name="JAVA_CODE" value="false" />
-      <option name="JAVA_DECLARATION" value="true" />
-      <option name="JAVA_COMMENT" value="false" />
-      <option name="JAVA_STRING" value="false" />
-      <option name="COMPLETION" value="false" />
-      <option name="OTHER" value="false" />
-    </context>
-  </template>
-  <template name="isid" value="//region &gt; title, icon etc&#10;public String title() {&#10;    final org.apache.isis.applib.util.TitleBuffer buf = new org.apache.isis.applib.util.TitleBuffer();&#10;    $END$// TODO: append to org.apache.isis.applib.util.TitleBuffer, typically value properties&#10;    return buf.toString();&#10;}&#10;public String iconName() {&#10;    return null; // TODO: return icon name (suffix)&#10;}&#10;public String cssClass() {&#10;    return null; // TODO: return CSS class name&#10;}&#10;//endregion" description="Apache Isis Identification region" toReformat="true" toShortenFQNames="true">
-    <context>
-      <option name="HTML" value="false" />
-      <option name="XML" value="false" />
-      <option name="JAVA_CODE" value="false" />
-      <option name="JAVA_DECLARATION" value="true" />
-      <option name="JAVA_COMMENT" value="false" />
-      <option name="JAVA_STRING" value="false" />
-      <option name="COMPLETION" value="false" />
-      <option name="OTHER" value="false" />
-    </context>
-  </template>
-  <template name="isnew" value="$Type$ $type$ = $container$.newTransientInstance($Type$.class);&#10;$END$// TODO: set up any properties&#10;&#10;$container$.persist($type$);&#10;" description="Apache Isis Commonly used method (factory for persistent)" toReformat="true" toShortenFQNames="true">
-    <variable name="Type" expression="className()" defaultValue="" alwaysStopAt="true" />
-    <variable name="type" expression="suggestVariableName()" defaultValue="" alwaysStopAt="true" />
-    <variable name="container" expression="&quot;container&quot;" defaultValue="" alwaysStopAt="true" />
-    <context>
-      <option name="HTML" value="false" />
-      <option name="XML" value="false" />
-      <option name="JAVA_CODE" value="false" />
-      <option name="JAVA_STATEMENT" value="true" />
-      <option name="JAVA_EXPRESSION" value="false" />
-      <option name="JAVA_DECLARATION" value="false" />
-      <option name="JAVA_COMMENT" value="false" />
-      <option name="JAVA_STRING" value="false" />
-      <option name="COMPLETION" value="false" />
-      <option name="OTHER" value="false" />
-    </context>
-  </template>
-  <template name="isp-jdo" value="@org.apache.isis.applib.annotation.Property()&#10;@javax.jdo.annotations.Column(allowsNull=&quot;$trueOrFalse$&quot;)&#10;@lombok.Getter @lombok.Setter&#10;private $PropertyType$ $propertyName$;&#10;" description="Apache Isis Property (JDO)" toReformat="true" toShortenFQNames="false">
-    <variable name="PropertyType" expression="classNameComplete()" defaultValue="" alwaysStopAt="true" />
-    <variable name="propertyName" expression="suggestVariableName()" defaultValue="" alwaysStopAt="true" />
-    <variable name="trueOrFalse" expression="" defaultValue="false" alwaysStopAt="true" />
-    <context>
-      <option name="HTML" value="false" />
-      <option name="XML" value="false" />
-      <option name="JAVA_CODE" value="false" />
-      <option name="JAVA_DECLARATION" value="true" />
-      <option name="JAVA_COMMENT" value="false" />
-      <option name="JAVA_STRING" value="false" />
-      <option name="COMPLETION" value="false" />
-      <option name="OTHER" value="false" />
-    </context>
-  </template>
-  <template name="isp-auto" value="public java.util.Collection&lt;$PropertyType$&gt; autoComplete$PropertyName$(final String search) {&#10;    return $END$com.google.common.collect.Lists.newArrayList(); // TODO: return list of choices for property&#10;}" description="Apache Isis Property auto-complete" toReformat="true" toShortenFQNames="true">
-    <variable name="PropertyName" expression="&quot;PropertyName&quot;" defaultValue="" alwaysStopAt="true" />
-    <variable name="PropertyType" expression="className()" defaultValue="" alwaysStopAt="true" />
-    <context>
-      <option name="HTML" value="false" />
-      <option name="XML" value="false" />
-      <option name="JAVA_CODE" value="false" />
-      <option name="JAVA_DECLARATION" value="true" />
-      <option name="JAVA_COMMENT" value="false" />
-      <option name="JAVA_STRING" value="false" />
-      <option name="COMPLETION" value="false" />
-      <option name="OTHER" value="false" />
-    </context>
-  </template>
-  <template name="isp-cho" value="public java.util.Collection&lt;$PropertyType$&gt; choices$PropertyName$() {&#10;    return $END$com.google.common.collect.Lists.newArrayList(); // TODO: return list of choices for property&#10;}" description="Apache Isis Property choices" toReformat="true" toShortenFQNames="true">
-    <variable name="PropertyName" expression="&quot;PropertyName&quot;" defaultValue="" alwaysStopAt="true" />
-    <variable name="PropertyType" expression="className()" defaultValue="" alwaysStopAt="true" />
-    <context>
-      <option name="HTML" value="false" />
-      <option name="XML" value="false" />
-      <option name="JAVA_CODE" value="false" />
-      <option name="JAVA_DECLARATION" value="true" />
-      <option name="JAVA_COMMENT" value="false" />
-      <option name="JAVA_STRING" value="false" />
-      <option name="COMPLETION" value="false" />
-      <option name="OTHER" value="false" />
-    </context>
-  </template>
-  <template name="isp-def" value="public $PropertyType$ default$PropertyName$() {&#10;    return $END$null; // TODO: return default for property when first created&#10;}" description="Apache Isis Property default" toReformat="true" toShortenFQNames="true">
-    <variable name="PropertyName" expression="&quot;PropertyName&quot;" defaultValue="" alwaysStopAt="true" />
-    <variable name="PropertyType" expression="className()" defaultValue="" alwaysStopAt="true" />
-    <context>
-      <option name="HTML" value="false" />
-      <option name="XML" value="false" />
-      <option name="JAVA_CODE" value="false" />
-      <option name="JAVA_DECLARATION" value="true" />
-      <option name="JAVA_COMMENT" value="false" />
-      <option name="JAVA_STRING" value="false" />
-      <option name="COMPLETION" value="false" />
-      <option name="OTHER" value="false" />
-    </context>
-  </template>
-  <template name="isp-dis" value="public String disable$PropertyName$() {&#10;    return $END$null; // TODO: return reason why property is disabled, null if editable&#10;}" description="Apache Isis Property disablement" toReformat="true" toShortenFQNames="true">
-    <variable name="PropertyName" expression="&quot;PropertyName&quot;" defaultValue="" alwaysStopAt="true" />
-    <context>
-      <option name="HTML" value="false" />
-      <option name="XML" value="false" />
-      <option name="JAVA_CODE" value="false" />
-      <option name="JAVA_DECLARATION" value="true" />
-      <option name="JAVA_COMMENT" value="false" />
-      <option name="JAVA_STRING" value="false" />
-      <option name="COMPLETION" value="false" />
-      <option name="OTHER" value="false" />
-    </context>
-  </template>
-  <template name="isp-hid" value="public boolean hide$PropertyName$() {&#10;  return $END$false; // TODO: return true if hidden, false if visible&#10; }" description="Apache Isis Property visibility" toReformat="true" toShortenFQNames="true">
-    <variable name="PropertyName" expression="&quot;PropertyName&quot;" defaultValue="" alwaysStopAt="true" />
-    <context>
-      <option name="HTML" value="false" />
-      <option name="XML" value="false" />
-      <option name="JAVA_CODE" value="false" />
-      <option name="JAVA_DECLARATION" value="true" />
-      <option name="JAVA_COMMENT" value="false" />
-      <option name="JAVA_STRING" value="false" />
-      <option name="COMPLETION" value="false" />
-      <option name="OTHER" value="false" />
-    </context>
-  </template>
-  <template name="isp-val" value="public String validate$PropertyName$(final $PropertyType$ $propertyName$) {&#10;  if ($propertyName$ == null) return null;&#10;  return $END$null; // TODO: return reason why proposed value is invalid, null if valid&#10; }" description="Apache Isis Property validation" toReformat="true" toShortenFQNames="true">
-    <variable name="PropertyName" expression="suggestVariableName()" defaultValue="" alwaysStopAt="true" />
-    <variable name="PropertyType" expression="className()" defaultValue="" alwaysStopAt="true" />
-    <variable name="propertyName" expression="suggestVariableName()" defaultValue="" alwaysStopAt="true" />
-    <context>
-      <option name="HTML" value="false" />
-      <option name="XML" value="false" />
-      <option name="JAVA_CODE" value="false" />
-      <option name="JAVA_DECLARATION" value="true" />
-      <option name="JAVA_COMMENT" value="false" />
-      <option name="JAVA_STRING" value="false" />
-      <option name="COMPLETION" value="false" />
-      <option name="OTHER" value="false" />
-    </context>
-  </template>
-  <template name="isobj-events" value="//region &gt; domain events&#10;public static abstract class PropertyDomainEvent&lt;T&gt;&#10;        extends org.apache.isis.applib.services.eventbus.PropertyDomainEvent&lt;$EntityName$,T&gt; {&#10;}&#10;public static abstract class CollectionDomainEvent&lt;T&gt;&#10;        extends org.apache.isis.applib.services.eventbus.CollectionDomainEvent&lt;$EntityName$,T&gt; {&#10;}&#10;public static abstract class ActionDomainEvent&#10;        extends org.apache.isis.applib.services.eventbus.ActionDomainEvent&lt;$EntityName$&gt; {&#10;}&#10;//endregion&#10;" description="Apache Isis Object: abstract domain events declarations" toReformat="true" toShortenFQNames="true">
-    <variable name="EntityName" expression="className()" defaultValue="" alwaysStopAt="false" />
-    <context>
-      <option name="HTML" value="false" />
-      <option name="XML" value="false" />
-      <option name="JAVA_CODE" value="false" />
-      <option name="JAVA_DECLARATION" value="true" />
-      <option name="JAVA_COMMENT" value="false" />
-      <option name="JAVA_STRING" value="false" />
-      <option name="COMPLETION" value="false" />
-      <option name="OTHER" value="false" />
-    </context>
-  </template>
-  <template name="isobj-region" value="//region &gt; $Region$ &#10;$END$ &#10;//endregion" description="Apache Isis Region" toReformat="true" toShortenFQNames="true">
-    <variable name="Region" expression="&quot;Region&quot;" defaultValue="" alwaysStopAt="true" />
-    <context>
-      <option name="HTML" value="false" />
-      <option name="XML" value="false" />
-      <option name="JAVA_CODE" value="false" />
-      <option name="JAVA_DECLARATION" value="true" />
-      <option name="JAVA_COMMENT" value="false" />
-      <option name="JAVA_STRING" value="false" />
-      <option name="COMPLETION" value="false" />
-      <option name="OTHER" value="false" />
-    </context>
-  </template>
-  <template name="isobj-standard" value="//region &gt; compareTo, toString&#10;@Override&#10;public int compareTo(final $EntityName$ other) {&#10;    return org.apache.isis.applib.util.ObjectContracts.compare(this, other, &quot;$property$&quot;);&#10;}&#10;@Override&#10;public String toString() {&#10;    return org.apache.isis.applib.util.ObjectContracts.toString(this, &quot;$property$&quot;);&#10;}&#10;//endregion&#10;" description="Apache Isis Object: standard methods (compareTo, toString)" toReformat="true" toShortenFQNames="true">
-    <variable name="EntityName" expression="className()" defaultValue="" alwaysStopAt="false" />
-    <variable name="property" expression="" defaultValue="" alwaysStopAt="true" />
-    <context>
-      <option name="HTML" value="false" />
-      <option name="XML" value="false" />
-      <option name="JAVA_CODE" value="false" />
-      <option name="JAVA_DECLARATION" value="true" />
-      <option name="JAVA_COMMENT" value="false" />
-      <option name="JAVA_STRING" value="false" />
-      <option name="COMPLETION" value="false" />
-      <option name="OTHER" value="false" />
-    </context>
-  </template>
-  <template name="isobj-validate" value="public String validate() {&#10;    $END$// TODO: return reason why object is in invalid state (and so cannot be saved/updated), or null if ok&#10;}" description="Apache Isis Object: validate method" toReformat="true" toShortenFQNames="true">
-    <context>
-      <option name="HTML" value="false" />
-      <option name="XML" value="false" />
-      <option name="JAVA_CODE" value="false" />
-      <option name="JAVA_DECLARATION" value="true" />
-      <option name="JAVA_COMMENT" value="false" />
-      <option name="JAVA_STRING" value="false" />
-      <option name="COMPLETION" value="false" />
-      <option name="OTHER" value="false" />
-    </context>
-  </template>
-  <template name="isp-jdo-11c" value="@javax.jdo.annotations.Column(allowsNull=&quot;$trueOrFalse$&quot;)&#10;@javax.jdo.annotations.Persistent(mappedBy=&quot;$fieldOnChild$&quot;)&#10;@lombok.Getter @lombok.Setter&#10;private $PropertyType$ $propertyName$;&#10;" description="Apache Isis Property (JDO, 1:1 bidirectional parent to foreign key)" toReformat="true" toShortenFQNames="false">
-    <variable name="PropertyType" expression="classNameComplete()" defaultValue="" alwaysStopAt="true" />
-    <variable name="propertyName" expression="suggestVariableName()" defaultValue="" alwaysStopAt="true" />
-    <variable name="fieldOnChild" expression="" defaultValue="" alwaysStopAt="true" />
-    <variable name="trueOrFalse" expression="" defaultValue="false" alwaysStopAt="true" />
-    <context>
-      <option name="HTML" value="false" />
-      <option name="XML" value="false" />
-      <option name="JAVA_CODE" value="false" />
-      <option name="JAVA_DECLARATION" value="true" />
-      <option name="JAVA_COMMENT" value="false" />
-      <option name="JAVA_STRING" value="false" />
-      <option name="COMPLETION" value="false" />
-      <option name="OTHER" value="false" />
-    </context>
-  </template>
-  <template name="isc-event-decl" value="public static class $CollectionName$DomainEvent extends CollectionDomainEvent&lt;$ElementType$&gt;{}&#10;@org.apache.isis.applib.annotation.Collection(&#10;        domainEvent = $CollectionName$DomainEvent.class&#10;)&#10;" description="Apache Isis Collection (domain event declaration only)" toReformat="true" toShortenFQNames="true">
-    <variable name="ElementType" expression="classNameComplete()" defaultValue="" alwaysStopAt="true" />
-    <variable name="CollectionName" expression="capitalize(collectionName)" defaultValue="" alwaysStopAt="false" />
-    <context>
-      <option name="HTML" value="false" />
-      <option name="XML" value="false" />
-      <option name="JAVA_CODE" value="false" />
-      <option name="JAVA_DECLARATION" value="true" />
-      <option name="JAVA_COMMENT" value="false" />
-      <option name="JAVA_STRING" value="false" />
-      <option name="COMPLETION" value="false" />
-      <option name="OTHER" value="false" />
-    </context>
-  </template>
-  <template name="isp-event-decl" value="public static class $PropertyName$DomainEvent extends PropertyDomainEvent&lt;$ElementType$&gt;{}&#10;@org.apache.isis.applib.annotation.Property(&#10;        domainEvent = $PropertyName$DomainEvent.class&#10;)&#10;" description="Apache Isis Property (domain event declaration only)" toReformat="true" toShortenFQNames="true">
-    <variable name="ElementType" expression="classNameComplete()" defaultValue="" alwaysStopAt="true" />
-    <variable name="PropertyName" expression="" defaultValue="" alwaysStopAt="true" />
-    <context>
-      <option name="HTML" value="false" />
-      <option name="XML" value="false" />
-      <option name="JAVA_CODE" value="false" />
-      <option name="JAVA_DECLARATION" value="true" />
-      <option name="JAVA_COMMENT" value="false" />
-      <option name="JAVA_STRING" value="false" />
-      <option name="COMPLETION" value="false" />
-      <option name="OTHER" value="false" />
-    </context>
-  </template>
-</templateSet>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/isis/blob/dab4fcad/adocs/documentation/src/main/asciidoc/resources/templates/isis-templates-idea.xml
----------------------------------------------------------------------
diff --git a/adocs/documentation/src/main/asciidoc/resources/templates/isis-templates-idea.xml b/adocs/documentation/src/main/asciidoc/resources/templates/isis-templates-idea.xml
new file mode 100644
index 0000000..916bceb
--- /dev/null
+++ b/adocs/documentation/src/main/asciidoc/resources/templates/isis-templates-idea.xml
@@ -0,0 +1,522 @@
+<templateSet group="Apache Isis">
+  <template name="isa" value="@org.apache.isis.applib.annotation.Action()&#10;public $ReturnType$ $actionName$(final $ParameterType$ $parameterType$) {&#10;    return $END$null; // TODO: business logic here&#10;}&#10;" description="Apache Isis Action" toReformat="true" toShortenFQNames="true">
+    <variable name="actionName" expression="&quot;actionName&quot;" defaultValue="" alwaysStopAt="true" />
+    <variable name="ParameterType" expression="classNameComplete()" defaultValue="" alwaysStopAt="true" />
+    <variable name="parameterType" expression="suggestVariableName()" defaultValue="" alwaysStopAt="true" />
+    <variable name="ReturnType" expression="className()" defaultValue="" alwaysStopAt="true" />
+    <context>
+      <option name="HTML" value="false" />
+      <option name="XML" value="false" />
+      <option name="JAVA_CODE" value="false" />
+      <option name="JAVA_DECLARATION" value="true" />
+      <option name="JAVA_COMMENT" value="false" />
+      <option name="JAVA_STRING" value="false" />
+      <option name="COMPLETION" value="false" />
+      <option name="OTHER" value="false" />
+    </context>
+  </template>
+  <template name="isa-p-auto" value="public java.util.Collection&lt;$ParameterType$&gt; autoComplete$ParameterNum$$ActionName$(final String search) {&#10;    return $END$com.google.common.collect.Lists.newArrayList(); // TODO: return list of choices for argument N&#10;}" description="Apache Isis Action parameter auto-complete" toReformat="true" toShortenFQNames="true">
+    <variable name="ParameterNum" expression="&quot;Num&quot;" defaultValue="" alwaysStopAt="true" />
+    <variable name="ActionName" expression="&quot;ActionName&quot;" defaultValue="" alwaysStopAt="true" />
+    <variable name="ParameterType" expression="className()" defaultValue="" alwaysStopAt="true" />
+    <context>
+      <option name="HTML" value="false" />
+      <option name="XML" value="false" />
+      <option name="JAVA_CODE" value="false" />
+      <option name="JAVA_DECLARATION" value="true" />
+      <option name="JAVA_COMMENT" value="false" />
+      <option name="JAVA_STRING" value="false" />
+      <option name="COMPLETION" value="false" />
+      <option name="OTHER" value="false" />
+    </context>
+  </template>
+  <template name="isa-p-cho" value="public java.util.List&lt;$ParameterType$&gt; choices$ParameterNum$$ActionName$() {&#10;    return $END$com.google.common.collect.Lists.newArrayList(); // TODO: return list of choices for argument N&#10;}" description="Apache Isis Action parameter choices" toReformat="true" toShortenFQNames="true">
+    <variable name="ParameterNum" expression="&quot;Num&quot;" defaultValue="" alwaysStopAt="true" />
+    <variable name="ActionName" expression="&quot;ActionName&quot;" defaultValue="" alwaysStopAt="true" />
+    <variable name="ParameterType" expression="className()" defaultValue="" alwaysStopAt="true" />
+    <context>
+      <option name="HTML" value="false" />
+      <option name="XML" value="false" />
+      <option name="JAVA_CODE" value="false" />
+      <option name="JAVA_DECLARATION" value="true" />
+      <option name="JAVA_COMMENT" value="false" />
+      <option name="JAVA_STRING" value="false" />
+      <option name="COMPLETION" value="false" />
+      <option name="OTHER" value="false" />
+    </context>
+  </template>
+  <template name="isa-p-def" value="public $ParameterType$ default$ParameterNum$$ActionName$() {&#10;    return $END$null; // TODO: return default for argument N&#10;}" description="Apache Isis Action parameter defaults" toReformat="true" toShortenFQNames="true">
+    <variable name="ParameterNum" expression="&quot;Num&quot;" defaultValue="" alwaysStopAt="true" />
+    <variable name="ActionName" expression="&quot;ActionName&quot;" defaultValue="" alwaysStopAt="true" />
+    <variable name="ParameterType" expression="className()" defaultValue="" alwaysStopAt="true" />
+    <context>
+      <option name="HTML" value="false" />
+      <option name="XML" value="false" />
+      <option name="JAVA_CODE" value="false" />
+      <option name="JAVA_DECLARATION" value="true" />
+      <option name="JAVA_COMMENT" value="false" />
+      <option name="JAVA_STRING" value="false" />
+      <option name="COMPLETION" value="false" />
+      <option name="OTHER" value="false" />
+    </context>
+  </template>
+  <template name="isa-p-val" value="public String validate$ParamNum}$ActionName$(final $ParameterType$ $parameterType$) {&#10;    return $END$null; // TODO: return reason why action argument are invalid, null if ok&#10;}" description="Apache Isis Action parameter validation" toReformat="true" toShortenFQNames="true">
+    <variable name="ActionName" expression="&quot;ActionName&quot;" defaultValue="" alwaysStopAt="true" />
+    <variable name="ParameterType" expression="className()" defaultValue="" alwaysStopAt="true" />
+    <variable name="parameterType" expression="suggestVariableName()" defaultValue="" alwaysStopAt="true" />
+    <context>
+      <option name="HTML" value="false" />
+      <option name="XML" value="false" />
+      <option name="JAVA_CODE" value="false" />
+      <option name="JAVA_DECLARATION" value="true" />
+      <option name="JAVA_COMMENT" value="false" />
+      <option name="JAVA_STRING" value="false" />
+      <option name="COMPLETION" value="false" />
+      <option name="OTHER" value="false" />
+    </context>
+  </template>
+  <template name="isa-dis" value="public String disable$ActionName$() {&#10;    return $END$null; // TODO: return reason why action disabled, null if enabled&#10;}" description="Apache Isis Action disablement" toReformat="true" toShortenFQNames="true">
+    <variable name="ActionName" expression="&quot;ActionName&quot;" defaultValue="" alwaysStopAt="true" />
+    <context>
+      <option name="HTML" value="false" />
+      <option name="XML" value="false" />
+      <option name="JAVA_CODE" value="false" />
+      <option name="JAVA_DECLARATION" value="true" />
+      <option name="JAVA_COMMENT" value="false" />
+      <option name="JAVA_STRING" value="false" />
+      <option name="COMPLETION" value="false" />
+      <option name="OTHER" value="false" />
+    </context>
+  </template>
+  <template name="isa-event" value="public static class $ActionName$DomainEvent extends ActionDomainEvent{}&#10;@org.apache.isis.applib.annotation.Action(&#10;        domainEvent = $ActionName$DomainEvent.class&#10;)&#10;public $ReturnType$ $actionName$(final $ParameterType$ $parameterType$) {&#10;    return $END$null; // TODO: business logic here&#10;}&#10;" description="Apache Isis Action (with domain event)" toReformat="true" toShortenFQNames="true">
+    <variable name="actionName" expression="&quot;actionName&quot;" defaultValue="" alwaysStopAt="true" />
+    <variable name="ActionName" expression="capitalize(actionName)" defaultValue="" alwaysStopAt="false" />
+    <variable name="ParameterType" expression="classNameComplete()" defaultValue="" alwaysStopAt="true" />
+    <variable name="parameterType" expression="suggestVariableName()" defaultValue="" alwaysStopAt="true" />
+    <variable name="ReturnType" expression="className()" defaultValue="" alwaysStopAt="true" />
+    <context>
+      <option name="HTML" value="false" />
+      <option name="XML" value="false" />
+      <option name="JAVA_CODE" value="false" />
+      <option name="JAVA_DECLARATION" value="true" />
+      <option name="JAVA_COMMENT" value="false" />
+      <option name="JAVA_STRING" value="false" />
+      <option name="COMPLETION" value="false" />
+      <option name="OTHER" value="false" />
+    </context>
+  </template>
+  <template name="isa-event-decl" value="public static class $ActionName$DomainEvent extends ActionDomainEvent{}&#10;@org.apache.isis.applib.annotation.Action(&#10;        domainEvent = $ActionName$DomainEvent.class&#10;)&#10;" description="Apache Isis Action (domain event declaration only)" toReformat="true" toShortenFQNames="true">
+    <variable name="ActionName" expression="" defaultValue="" alwaysStopAt="true" />
+    <context>
+      <option name="HTML" value="false" />
+      <option name="XML" value="false" />
+      <option name="JAVA_CODE" value="false" />
+      <option name="JAVA_DECLARATION" value="true" />
+      <option name="JAVA_COMMENT" value="false" />
+      <option name="JAVA_STRING" value="false" />
+      <option name="COMPLETION" value="false" />
+      <option name="OTHER" value="false" />
+    </context>
+  </template>
+  <template name="isa-hid" value="public boolean hide$ActionName$() {&#10;    return $END$false; // TODO: return true if action is hidden, false if visible&#10;}" description="Apache Isis Action visibility" toReformat="true" toShortenFQNames="true">
+    <variable name="ActionName" expression="&quot;ActionName&quot;" defaultValue="" alwaysStopAt="true" />
+    <context>
+      <option name="HTML" value="false" />
+      <option name="XML" value="false" />
+      <option name="JAVA_CODE" value="false" />
+      <option name="JAVA_DECLARATION" value="true" />
+      <option name="JAVA_COMMENT" value="false" />
+      <option name="JAVA_STRING" value="false" />
+      <option name="COMPLETION" value="false" />
+      <option name="OTHER" value="false" />
+    </context>
+  </template>
+  <template name="isa-val" value="public String validate$ActionName$(final $ParameterType$ $parameterType$) {&#10;    return $END$null; // TODO: return reason why action arguments are invalid, null if ok&#10;}" description="Apache Isis Action validation" toReformat="true" toShortenFQNames="true">
+    <variable name="ActionName" expression="&quot;ActionName&quot;" defaultValue="" alwaysStopAt="true" />
+    <variable name="ParameterType" expression="className()" defaultValue="" alwaysStopAt="true" />
+    <variable name="parameterType" expression="suggestVariableName()" defaultValue="" alwaysStopAt="true" />
+    <context>
+      <option name="HTML" value="false" />
+      <option name="XML" value="false" />
+      <option name="JAVA_CODE" value="false" />
+      <option name="JAVA_DECLARATION" value="true" />
+      <option name="JAVA_COMMENT" value="false" />
+      <option name="JAVA_STRING" value="false" />
+      <option name="COMPLETION" value="false" />
+      <option name="OTHER" value="false" />
+    </context>
+  </template>
+  <template name="isc-dis" value="public String disable$CollectionName$() {&#10;    return $END$null; // TODO: return reason why collection read-only, null if editable&#10;}" description="Apache Isis Collection disablement" toReformat="true" toShortenFQNames="true">
+    <variable name="CollectionName" expression="&quot;CollectionName&quot;" defaultValue="" alwaysStopAt="true" />
+    <context>
+      <option name="HTML" value="false" />
+      <option name="XML" value="false" />
+      <option name="JAVA_CODE" value="false" />
+      <option name="JAVA_DECLARATION" value="true" />
+      <option name="JAVA_COMMENT" value="false" />
+      <option name="JAVA_STRING" value="false" />
+      <option name="COMPLETION" value="false" />
+      <option name="OTHER" value="false" />
+    </context>
+  </template>
+  <template name="isc-hid" value="public boolean hide$CollectionName$() {&#10;    return $END$false; // TODO: return true if hidden, false otherwise&#10;}" description="Apache Isis Collection visibility" toReformat="true" toShortenFQNames="false">
+    <variable name="CollectionName" expression="&quot;CollectionName&quot;" defaultValue="" alwaysStopAt="true" />
+    <context>
+      <option name="HTML" value="false" />
+      <option name="XML" value="false" />
+      <option name="JAVA_CODE" value="false" />
+      <option name="JAVA_DECLARATION" value="true" />
+      <option name="JAVA_COMMENT" value="false" />
+      <option name="JAVA_STRING" value="false" />
+      <option name="COMPLETION" value="false" />
+      <option name="OTHER" value="false" />
+    </context>
+  </template>
+  <template name="isc-jdo-1m-b-fk" value="@org.apache.isis.applib.annotation.Collection()&#10;@javax.jdo.annotations.Persistent(mappedBy=&quot;$elementNameInChild$&quot;, dependentElement=&quot;$trueOrFalse$&quot;)&#10;@lombok.Getter @lombok.Setter&#10;private java.util.SortedSet&lt;$ElementType$&gt; $collectionName$ = new java.util.TreeSet&lt;$ElementType$&gt;();&#10;" description="Apache Isis Collection (JDO, 1:m parent bidirectional to foreign key)" toReformat="true" toShortenFQNames="true">
+    <variable name="ElementType" expression="classNameComplete()" defaultValue="" alwaysStopAt="true" />
+    <variable name="collectionName" expression="suggestVariableName()" defaultValue="" alwaysStopAt="true" />
+    <variable name="elementNameInChild" expression="decapitalize(EntityName)" defaultValue="" alwaysStopAt="false" />
+    <variable name="trueOrFalse" expression="&quot;trueOrFalse&quot;" defaultValue="" alwaysStopAt="true" />
+    <context>
+      <option name="HTML" value="false" />
+      <option name="XML" value="false" />
+      <option name="JAVA_CODE" value="false" />
+      <option name="JAVA_DECLARATION" value="true" />
+      <option name="JAVA_COMMENT" value="false" />
+      <option name="JAVA_STRING" value="false" />
+      <option name="COMPLETION" value="false" />
+      <option name="OTHER" value="false" />
+    </context>
+  </template>
+  <template name="isc-jdo-1m-b-jt" value="@org.apache.isis.applib.annotation.Collection()&#10;@javax.jdo.annotations.Persistent(mappedBy=&quot;$elementNameInChild$&quot;, dependentElement=&quot;$trueOrFalse$&quot;)&#10;@javax.jdo.annotations.Join&#10;@lombok.Getter @lombok.Setter&#10;private java.util.SortedSet&lt;$ElementType$&gt; $collectionName$ = new java.util.TreeSet&lt;$ElementType$&gt;();&#10;" description="Apache Isis Collection (JDO, 1:m parent bidirectional to join table)" toReformat="true" toShortenFQNames="true">
+    <variable name="ElementType" expression="classNameComplete()" defaultValue="" alwaysStopAt="true" />
+    <variable name="collectionName" expression="suggestVariableName()" defaultValue="" alwaysStopAt="true" />
+    <variable name="elementNameInChild" expression="decapitalize(EntityName)" defaultValue="" alwaysStopAt="false" />
+    <variable name="trueOrFalse" expression="&quot;trueOrFalse&quot;" defaultValue="" alwaysStopAt="true" />
+    <context>
+      <option name="HTML" value="false" />
+      <option name="XML" value="false" />
+      <option name="JAVA_CODE" value="false" />
+      <option name="JAVA_DECLARATION" value="true" />
+      <option name="JAVA_COMMENT" value="false" />
+      <option name="JAVA_STRING" value="false" />
+      <option name="COMPLETION" value="false" />
+      <option name="OTHER" value="false" />
+    </context>
+  </template>
+  <template name="isc-jdo-1m-u-fk" value="@org.apache.isis.applib.annotation.Collection()&#10;@javax.jdo.annotations.Element(column=&quot;$ColumnName$&quot;, dependent=&quot;$trueOrFalse$&quot;)&#10;@lombok.Getter @lombok.Setter&#10;private java.util.SortedSet&lt;$ElementType$&gt; $collectionName$ = new java.util.TreeSet&lt;$ElementType$&gt;();&#10;" description="Apache Isis JDO Collection (1:m parent unidirectional)" toReformat="true" toShortenFQNames="true">
+    <variable name="ElementType" expression="classNameComplete()" defaultValue="" alwaysStopAt="true" />
+    <variable name="collectionName" expression="suggestVariableName()" defaultValue="" alwaysStopAt="true" />
+    <variable name="ColumnName" expression="&quot;ColumnName&quot;" defaultValue="" alwaysStopAt="true" />
+    <variable name="trueOrFalse" expression="&quot;trueOrFalse&quot;" defaultValue="" alwaysStopAt="true" />
+    <context>
+      <option name="HTML" value="false" />
+      <option name="XML" value="false" />
+      <option name="JAVA_CODE" value="false" />
+      <option name="JAVA_DECLARATION" value="true" />
+      <option name="JAVA_COMMENT" value="false" />
+      <option name="JAVA_STRING" value="false" />
+      <option name="COMPLETION" value="false" />
+      <option name="OTHER" value="false" />
+    </context>
+  </template>
+  <template name="isc-jdo-1m-u-jt" value="@org.apache.isis.applib.annotation.Collection()&#10;@javax.jdo.annotations.Join&#10;@javax.jdo.annotations.Element(dependent=&quot;$trueOrFalse$&quot;)&#10;@lombok.Getter @lombok.Setter&#10;private java.util.SortedSet&lt;$ElementType$&gt; $collectionName$ = new java.util.TreeSet&lt;$ElementType$&gt;();&#10;" description="Apache Isis Collection (JDO, 1:m parent unidirectional to join table)" toReformat="true" toShortenFQNames="true">
+    <variable name="ElementType" expression="classNameComplete()" defaultValue="" alwaysStopAt="true" />
+    <variable name="collectionName" expression="suggestVariableName()" defaultValue="" alwaysStopAt="true" />
+    <variable name="trueOrFalse" expression="&quot;trueOrFalse&quot;" defaultValue="" alwaysStopAt="true" />
+    <context>
+      <option name="HTML" value="false" />
+      <option name="XML" value="false" />
+      <option name="JAVA_CODE" value="false" />
+      <option name="JAVA_DECLARATION" value="true" />
+      <option name="JAVA_COMMENT" value="false" />
+      <option name="JAVA_STRING" value="false" />
+      <option name="COMPLETION" value="false" />
+      <option name="OTHER" value="false" />
+    </context>
+  </template>
+  <template name="isc-jdo-mn-ub-c" value="@org.apache.isis.applib.annotation.Collection()&#10;@javax.jdo.annotations.Persistent(mappedBy=&quot;$ChildCollectionNameInParent$&quot;)&#10;@lombok.Getter @lombok.Setter&#10;private java.util.SortedSet&lt;$ElementType$&gt; $collectionName$ = new java.util.TreeSet&lt;$ElementType$&gt;(); &#10;" description="Apache Isis Collection (JDO, m:n child)" toReformat="true" toShortenFQNames="true">
+    <variable name="ElementType" expression="classNameComplete()" defaultValue="" alwaysStopAt="true" />
+    <variable name="collectionName" expression="suggestVariableName()" defaultValue="" alwaysStopAt="true" />
+    <variable name="ChildCollectionNameInParent" expression="&quot;ChildCollectionNameInParent&quot;" defaultValue="" alwaysStopAt="true" />
+    <context>
+      <option name="HTML" value="false" />
+      <option name="XML" value="false" />
+      <option name="JAVA_CODE" value="false" />
+      <option name="JAVA_DECLARATION" value="true" />
+      <option name="JAVA_COMMENT" value="false" />
+      <option name="JAVA_STRING" value="false" />
+      <option name="COMPLETION" value="false" />
+      <option name="OTHER" value="false" />
+    </context>
+  </template>
+  <template name="isc-jdo-mn-ub-p" value="@org.apache.isis.applib.annotation.Collection()&#10;@javax.jdo.annotations.Persistent(table=&quot;$TableName$&quot;) &#10;@javax.jdo.annotations.Join(column=&quot;$ThisEntityFieldName$&quot;) &#10;@javax.jdo.annotations.Element(column=&quot;$RelatedEntityFieldName$&quot;)&#10;@lombok.Getter @lombok.Setter&#10;private java.util.SortedSet&lt;$ElementType$&gt; $collectionName$ = new java.util.TreeSet&lt;$ElementType$&gt;();&#10;" description="Apache Isis Collection (JDO, m:n parent)" toReformat="true" toShortenFQNames="true">
+    <variable name="ElementType" expression="classNameComplete()" defaultValue="" alwaysStopAt="true" />
+    <variable name="collectionName" expression="suggestVariableName()" defaultValue="" alwaysStopAt="true" />
+    <variable name="TableName" expression="&quot;TableName&quot;" defaultValue="" alwaysStopAt="true" />
+    <variable name="ThisEntityFieldName" expression="&quot;ThisEntityFieldName&quot;" defaultValue="" alwaysStopAt="true" />
+    <variable name="RelatedEntityFieldName" expression="&quot;RelatedEntityFieldName&quot;" defaultValue="" alwaysStopAt="true" />
+    <context>
+      <option name="HTML" value="false" />
+      <option name="XML" value="false" />
+      <option name="JAVA_CODE" value="false" />
+      <option name="JAVA_DECLARATION" value="true" />
+      <option name="JAVA_COMMENT" value="false" />
+      <option name="JAVA_STRING" value="false" />
+      <option name="COMPLETION" value="false" />
+      <option name="OTHER" value="false" />
+    </context>
+  </template>
+  <template name="isds-subscriber-on" value="@com.google.common.eventbus.Subscribe&#10;public void on(final $EventType$ ev) {&#10;    // TODO&#10;}&#10;" description="Apache Isis Domain Service Subscriber &quot;on&quot; event" toReformat="false" toShortenFQNames="true">
+    <variable name="EventType" expression="classNameComplete()" defaultValue="" alwaysStopAt="true" />
+    <context>
+      <option name="JAVA_DECLARATION" value="true" />
+    </context>
+  </template>
+  <template name="isjaxb-package.info" value="@javax.xml.bind.annotation.XmlSchema(&#10;        namespace = &quot;http://$namespaceBase$/$namespaceSuffix$/v$versionMajor$_$versionMinor$/$namespaceSuffix$.xsd&quot;,&#10;        xmlns = {&#10;                @javax.xml.bind.annotation.XmlNs(&#10;                        namespaceURI = &quot;http://isis.apache.org/schema/common&quot;,&#10;                        prefix = &quot;common&quot;&#10;                ),&#10;        },&#10;        elementFormDefault = javax.xml.bind.annotation.XmlNsForm.QUALIFIED&#10;)" toReformat="false" toShortenFQNames="true">
+    <variable name="namespaceBase" expression="        groovyScript(&quot;def str = _1; def list = str.split(\&quot;\\\\.\&quot;); def revlist = list.reverse(); def ret = revlist.iterator().join(\&quot;.\&quot;); return ret&quot;, currentPackage())" defaultValue="" alwaysStopAt="true" />
+    <variable name="namespaceSuffix" expression="groovyScript(&quot;def str = _1; def list = str.split(\&quot;\\\\.\&quot;); def revlist = list.reverse(); def ret = revlist[0]; return ret&quot;, currentPackage())" defaultValue="" alwaysStopAt="true" />
+    <variable name="versionMajor" expression="" defaultValue="1" alwaysStopAt="true" />
+    <variable name="versionMinor" expression="" defaultValue="0" alwaysStopAt="true" />
+    <context>
+      <option name="JAVA_DECLARATION" value="true" />
+    </context>
+  </template>
+  <template name="isinject" value="@javax.inject.Inject&#10;$ServiceType$ $serviceType$;&#10;" description="Apache Isis Injected Dependency Service" toReformat="true" toShortenFQNames="true">
+    <variable name="ServiceType" expression="className()" defaultValue="" alwaysStopAt="true" />
+    <variable name="serviceType" expression="suggestVariableName()" defaultValue="" alwaysStopAt="true" />
+    <context>
+      <option name="HTML" value="false" />
+      <option name="XML" value="false" />
+      <option name="JAVA_CODE" value="false" />
+      <option name="JAVA_DECLARATION" value="true" />
+      <option name="JAVA_COMMENT" value="false" />
+      <option name="JAVA_STRING" value="false" />
+      <option name="COMPLETION" value="false" />
+      <option name="OTHER" value="false" />
+    </context>
+  </template>
+  <template name="isid" value="//region &gt; title, icon etc&#10;public String title() {&#10;    final org.apache.isis.applib.util.TitleBuffer buf = new org.apache.isis.applib.util.TitleBuffer();&#10;    $END$// TODO: append to org.apache.isis.applib.util.TitleBuffer, typically value properties&#10;    return buf.toString();&#10;}&#10;public String iconName() {&#10;    return null; // TODO: return icon name (suffix)&#10;}&#10;public String cssClass() {&#10;    return null; // TODO: return CSS class name&#10;}&#10;//endregion" description="Apache Isis Identification region" toReformat="true" toShortenFQNames="true">
+    <context>
+      <option name="HTML" value="false" />
+      <option name="XML" value="false" />
+      <option name="JAVA_CODE" value="false" />
+      <option name="JAVA_DECLARATION" value="true" />
+      <option name="JAVA_COMMENT" value="false" />
+      <option name="JAVA_STRING" value="false" />
+      <option name="COMPLETION" value="false" />
+      <option name="OTHER" value="false" />
+    </context>
+  </template>
+  <template name="isnew" value="$Type$ $type$ = $container$.newTransientInstance($Type$.class);&#10;$END$// TODO: set up any properties&#10;&#10;$container$.persist($type$);&#10;" description="Apache Isis Commonly used method (factory for persistent)" toReformat="true" toShortenFQNames="true">
+    <variable name="Type" expression="className()" defaultValue="" alwaysStopAt="true" />
+    <variable name="type" expression="suggestVariableName()" defaultValue="" alwaysStopAt="true" />
+    <variable name="container" expression="&quot;container&quot;" defaultValue="" alwaysStopAt="true" />
+    <context>
+      <option name="HTML" value="false" />
+      <option name="XML" value="false" />
+      <option name="JAVA_CODE" value="false" />
+      <option name="JAVA_STATEMENT" value="true" />
+      <option name="JAVA_EXPRESSION" value="false" />
+      <option name="JAVA_DECLARATION" value="false" />
+      <option name="JAVA_COMMENT" value="false" />
+      <option name="JAVA_STRING" value="false" />
+      <option name="COMPLETION" value="false" />
+      <option name="OTHER" value="false" />
+    </context>
+  </template>
+  <template name="isp-jdo" value="@org.apache.isis.applib.annotation.Property()&#10;@javax.jdo.annotations.Column(allowsNull=&quot;$trueOrFalse$&quot;)&#10;@lombok.Getter @lombok.Setter&#10;private $PropertyType$ $propertyName$;&#10;" description="Apache Isis Property (JDO)" toReformat="true" toShortenFQNames="false">
+    <variable name="PropertyType" expression="classNameComplete()" defaultValue="" alwaysStopAt="true" />
+    <variable name="propertyName" expression="suggestVariableName()" defaultValue="" alwaysStopAt="true" />
+    <variable name="trueOrFalse" expression="" defaultValue="false" alwaysStopAt="true" />
+    <context>
+      <option name="HTML" value="false" />
+      <option name="XML" value="false" />
+      <option name="JAVA_CODE" value="false" />
+      <option name="JAVA_DECLARATION" value="true" />
+      <option name="JAVA_COMMENT" value="false" />
+      <option name="JAVA_STRING" value="false" />
+      <option name="COMPLETION" value="false" />
+      <option name="OTHER" value="false" />
+    </context>
+  </template>
+  <template name="isp-auto" value="public java.util.Collection&lt;$PropertyType$&gt; autoComplete$PropertyName$(final String search) {&#10;    return $END$com.google.common.collect.Lists.newArrayList(); // TODO: return list of choices for property&#10;}" description="Apache Isis Property auto-complete" toReformat="true" toShortenFQNames="true">
+    <variable name="PropertyName" expression="&quot;PropertyName&quot;" defaultValue="" alwaysStopAt="true" />
+    <variable name="PropertyType" expression="className()" defaultValue="" alwaysStopAt="true" />
+    <context>
+      <option name="HTML" value="false" />
+      <option name="XML" value="false" />
+      <option name="JAVA_CODE" value="false" />
+      <option name="JAVA_DECLARATION" value="true" />
+      <option name="JAVA_COMMENT" value="false" />
+      <option name="JAVA_STRING" value="false" />
+      <option name="COMPLETION" value="false" />
+      <option name="OTHER" value="false" />
+    </context>
+  </template>
+  <template name="isp-cho" value="public java.util.Collection&lt;$PropertyType$&gt; choices$PropertyName$() {&#10;    return $END$com.google.common.collect.Lists.newArrayList(); // TODO: return list of choices for property&#10;}" description="Apache Isis Property choices" toReformat="true" toShortenFQNames="true">
+    <variable name="PropertyName" expression="&quot;PropertyName&quot;" defaultValue="" alwaysStopAt="true" />
+    <variable name="PropertyType" expression="className()" defaultValue="" alwaysStopAt="true" />
+    <context>
+      <option name="HTML" value="false" />
+      <option name="XML" value="false" />
+      <option name="JAVA_CODE" value="false" />
+      <option name="JAVA_DECLARATION" value="true" />
+      <option name="JAVA_COMMENT" value="false" />
+      <option name="JAVA_STRING" value="false" />
+      <option name="COMPLETION" value="false" />
+      <option name="OTHER" value="false" />
+    </context>
+  </template>
+  <template name="isp-def" value="public $PropertyType$ default$PropertyName$() {&#10;    return $END$null; // TODO: return default for property when first created&#10;}" description="Apache Isis Property default" toReformat="true" toShortenFQNames="true">
+    <variable name="PropertyName" expression="&quot;PropertyName&quot;" defaultValue="" alwaysStopAt="true" />
+    <variable name="PropertyType" expression="className()" defaultValue="" alwaysStopAt="true" />
+    <context>
+      <option name="HTML" value="false" />
+      <option name="XML" value="false" />
+      <option name="JAVA_CODE" value="false" />
+      <option name="JAVA_DECLARATION" value="true" />
+      <option name="JAVA_COMMENT" value="false" />
+      <option name="JAVA_STRING" value="false" />
+      <option name="COMPLETION" value="false" />
+      <option name="OTHER" value="false" />
+    </context>
+  </template>
+  <template name="isp-dis" value="public String disable$PropertyName$() {&#10;    return $END$null; // TODO: return reason why property is disabled, null if editable&#10;}" description="Apache Isis Property disablement" toReformat="true" toShortenFQNames="true">
+    <variable name="PropertyName" expression="&quot;PropertyName&quot;" defaultValue="" alwaysStopAt="true" />
+    <context>
+      <option name="HTML" value="false" />
+      <option name="XML" value="false" />
+      <option name="JAVA_CODE" value="false" />
+      <option name="JAVA_DECLARATION" value="true" />
+      <option name="JAVA_COMMENT" value="false" />
+      <option name="JAVA_STRING" value="false" />
+      <option name="COMPLETION" value="false" />
+      <option name="OTHER" value="false" />
+    </context>
+  </template>
+  <template name="isp-hid" value="public boolean hide$PropertyName$() {&#10;  return $END$false; // TODO: return true if hidden, false if visible&#10; }" description="Apache Isis Property visibility" toReformat="true" toShortenFQNames="true">
+    <variable name="PropertyName" expression="&quot;PropertyName&quot;" defaultValue="" alwaysStopAt="true" />
+    <context>
+      <option name="HTML" value="false" />
+      <option name="XML" value="false" />
+      <option name="JAVA_CODE" value="false" />
+      <option name="JAVA_DECLARATION" value="true" />
+      <option name="JAVA_COMMENT" value="false" />
+      <option name="JAVA_STRING" value="false" />
+      <option name="COMPLETION" value="false" />
+      <option name="OTHER" value="false" />
+    </context>
+  </template>
+  <template name="isp-val" value="public String validate$PropertyName$(final $PropertyType$ $propertyName$) {&#10;  if ($propertyName$ == null) return null;&#10;  return $END$null; // TODO: return reason why proposed value is invalid, null if valid&#10; }" description="Apache Isis Property validation" toReformat="true" toShortenFQNames="true">
+    <variable name="PropertyName" expression="suggestVariableName()" defaultValue="" alwaysStopAt="true" />
+    <variable name="PropertyType" expression="className()" defaultValue="" alwaysStopAt="true" />
+    <variable name="propertyName" expression="suggestVariableName()" defaultValue="" alwaysStopAt="true" />
+    <context>
+      <option name="HTML" value="false" />
+      <option name="XML" value="false" />
+      <option name="JAVA_CODE" value="false" />
+      <option name="JAVA_DECLARATION" value="true" />
+      <option name="JAVA_COMMENT" value="false" />
+      <option name="JAVA_STRING" value="false" />
+      <option name="COMPLETION" value="false" />
+      <option name="OTHER" value="false" />
+    </context>
+  </template>
+  <template name="isobj-events" value="//region &gt; domain events&#10;public static abstract class PropertyDomainEvent&lt;T&gt;&#10;        extends org.apache.isis.applib.services.eventbus.PropertyDomainEvent&lt;$EntityName$,T&gt; {&#10;}&#10;public static abstract class CollectionDomainEvent&lt;T&gt;&#10;        extends org.apache.isis.applib.services.eventbus.CollectionDomainEvent&lt;$EntityName$,T&gt; {&#10;}&#10;public static abstract class ActionDomainEvent&#10;        extends org.apache.isis.applib.services.eventbus.ActionDomainEvent&lt;$EntityName$&gt; {&#10;}&#10;//endregion&#10;" description="Apache Isis Object: abstract domain events declarations" toReformat="true" toShortenFQNames="true">
+    <variable name="EntityName" expression="className()" defaultValue="" alwaysStopAt="false" />
+    <context>
+      <option name="HTML" value="false" />
+      <option name="XML" value="false" />
+      <option name="JAVA_CODE" value="false" />
+      <option name="JAVA_DECLARATION" value="true" />
+      <option name="JAVA_COMMENT" value="false" />
+      <option name="JAVA_STRING" value="false" />
+      <option name="COMPLETION" value="false" />
+      <option name="OTHER" value="false" />
+    </context>
+  </template>
+  <template name="isobj-region" value="//region &gt; $Region$ &#10;$END$ &#10;//endregion" description="Apache Isis Region" toReformat="true" toShortenFQNames="true">
+    <variable name="Region" expression="&quot;Region&quot;" defaultValue="" alwaysStopAt="true" />
+    <context>
+      <option name="HTML" value="false" />
+      <option name="XML" value="false" />
+      <option name="JAVA_CODE" value="false" />
+      <option name="JAVA_DECLARATION" value="true" />
+      <option name="JAVA_COMMENT" value="false" />
+      <option name="JAVA_STRING" value="false" />
+      <option name="COMPLETION" value="false" />
+      <option name="OTHER" value="false" />
+    </context>
+  </template>
+  <template name="isobj-standard" value="//region &gt; compareTo, toString&#10;@Override&#10;public int compareTo(final $EntityName$ other) {&#10;    return org.apache.isis.applib.util.ObjectContracts.compare(this, other, &quot;$property$&quot;);&#10;}&#10;@Override&#10;public String toString() {&#10;    return org.apache.isis.applib.util.ObjectContracts.toString(this, &quot;$property$&quot;);&#10;}&#10;//endregion&#10;" description="Apache Isis Object: standard methods (compareTo, toString)" toReformat="true" toShortenFQNames="true">
+    <variable name="EntityName" expression="className()" defaultValue="" alwaysStopAt="false" />
+    <variable name="property" expression="" defaultValue="" alwaysStopAt="true" />
+    <context>
+      <option name="HTML" value="false" />
+      <option name="XML" value="false" />
+      <option name="JAVA_CODE" value="false" />
+      <option name="JAVA_DECLARATION" value="true" />
+      <option name="JAVA_COMMENT" value="false" />
+      <option name="JAVA_STRING" value="false" />
+      <option name="COMPLETION" value="false" />
+      <option name="OTHER" value="false" />
+    </context>
+  </template>
+  <template name="isobj-validate" value="public String validate() {&#10;    $END$// TODO: return reason why object is in invalid state (and so cannot be saved/updated), or null if ok&#10;}" description="Apache Isis Object: validate method" toReformat="true" toShortenFQNames="true">
+    <context>
+      <option name="HTML" value="false" />
+      <option name="XML" value="false" />
+      <option name="JAVA_CODE" value="false" />
+      <option name="JAVA_DECLARATION" value="true" />
+      <option name="JAVA_COMMENT" value="false" />
+      <option name="JAVA_STRING" value="false" />
+      <option name="COMPLETION" value="false" />
+      <option name="OTHER" value="false" />
+    </context>
+  </template>
+  <template name="isp-jdo-11c" value="@javax.jdo.annotations.Column(allowsNull=&quot;$trueOrFalse$&quot;)&#10;@javax.jdo.annotations.Persistent(mappedBy=&quot;$fieldOnChild$&quot;)&#10;@lombok.Getter @lombok.Setter&#10;private $PropertyType$ $propertyName$;&#10;" description="Apache Isis Property (JDO, 1:1 bidirectional parent to foreign key)" toReformat="true" toShortenFQNames="false">
+    <variable name="PropertyType" expression="classNameComplete()" defaultValue="" alwaysStopAt="true" />
+    <variable name="propertyName" expression="suggestVariableName()" defaultValue="" alwaysStopAt="true" />
+    <variable name="fieldOnChild" expression="" defaultValue="" alwaysStopAt="true" />
+    <variable name="trueOrFalse" expression="" defaultValue="false" alwaysStopAt="true" />
+    <context>
+      <option name="HTML" value="false" />
+      <option name="XML" value="false" />
+      <option name="JAVA_CODE" value="false" />
+      <option name="JAVA_DECLARATION" value="true" />
+      <option name="JAVA_COMMENT" value="false" />
+      <option name="JAVA_STRING" value="false" />
+      <option name="COMPLETION" value="false" />
+      <option name="OTHER" value="false" />
+    </context>
+  </template>
+  <template name="isc-event-decl" value="public static class $CollectionName$DomainEvent extends CollectionDomainEvent&lt;$ElementType$&gt;{}&#10;@org.apache.isis.applib.annotation.Collection(&#10;        domainEvent = $CollectionName$DomainEvent.class&#10;)&#10;" description="Apache Isis Collection (domain event declaration only)" toReformat="true" toShortenFQNames="true">
+    <variable name="ElementType" expression="classNameComplete()" defaultValue="" alwaysStopAt="true" />
+    <variable name="CollectionName" expression="capitalize(collectionName)" defaultValue="" alwaysStopAt="false" />
+    <context>
+      <option name="HTML" value="false" />
+      <option name="XML" value="false" />
+      <option name="JAVA_CODE" value="false" />
+      <option name="JAVA_DECLARATION" value="true" />
+      <option name="JAVA_COMMENT" value="false" />
+      <option name="JAVA_STRING" value="false" />
+      <option name="COMPLETION" value="false" />
+      <option name="OTHER" value="false" />
+    </context>
+  </template>
+  <template name="isp-event-decl" value="public static class $PropertyName$DomainEvent extends PropertyDomainEvent&lt;$ElementType$&gt;{}&#10;@org.apache.isis.applib.annotation.Property(&#10;        domainEvent = $PropertyName$DomainEvent.class&#10;)&#10;" description="Apache Isis Property (domain event declaration only)" toReformat="true" toShortenFQNames="true">
+    <variable name="ElementType" expression="classNameComplete()" defaultValue="" alwaysStopAt="true" />
+    <variable name="PropertyName" expression="" defaultValue="" alwaysStopAt="true" />
+    <context>
+      <option name="HTML" value="false" />
+      <option name="XML" value="false" />
+      <option name="JAVA_CODE" value="false" />
+      <option name="JAVA_DECLARATION" value="true" />
+      <option name="JAVA_COMMENT" value="false" />
+      <option name="JAVA_STRING" value="false" />
+      <option name="COMPLETION" value="false" />
+      <option name="OTHER" value="false" />
+    </context>
+  </template>
+</templateSet>
\ No newline at end of file


[05/17] isis git commit: ISIS-1296: remove -Xdoclint flag for javadoc since not recognized if using Java8 for release

Posted by da...@apache.org.
ISIS-1296: remove -Xdoclint flag for javadoc since not recognized if using Java8 for release


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

Branch: refs/heads/master
Commit: dad09086ea2dfb806bd65ead5f4b1b5a4a286589
Parents: 9d23232
Author: Dan Haywood <da...@haywood-associates.co.uk>
Authored: Sun Jan 10 13:41:53 2016 +0000
Committer: Dan Haywood <da...@haywood-associates.co.uk>
Committed: Sun Jan 10 13:41:53 2016 +0000

----------------------------------------------------------------------
 core/pom.xml | 4 +++-
 1 file changed, 3 insertions(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/isis/blob/dad09086/core/pom.xml
----------------------------------------------------------------------
diff --git a/core/pom.xml b/core/pom.xml
index 624fc0b..5b7de63 100644
--- a/core/pom.xml
+++ b/core/pom.xml
@@ -662,8 +662,10 @@
                     <version>2.9.1</version>
                     <inherited>true</inherited>
                     <configuration>
-                        <!-- as per http://stackoverflow.com/a/16743137/56880 -->
+                        <!-- as per http://stackoverflow.com/a/16743137/56880; only if using java 8 to build -->
+<!--
                         <additionalparam>-Xdoclint:none</additionalparam>
+-->
                         <debug>true</debug>
                         <minmemory>128m</minmemory>      
                         <maxmemory>1024m</maxmemory>


[17/17] isis git commit: ISIS-1296: updating website front page for 1.11.1

Posted by da...@apache.org.
ISIS-1296: updating website front page for 1.11.1


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

Branch: refs/heads/master
Commit: e0e55852607612ac2cf32d3c7d7adb17e6c8927d
Parents: 8812424
Author: Dan Haywood <da...@haywood-associates.co.uk>
Authored: Sun Jan 17 16:06:20 2016 +0000
Committer: Dan Haywood <da...@haywood-associates.co.uk>
Committed: Sun Jan 17 16:06:20 2016 +0000

----------------------------------------------------------------------
 adocs/documentation/src/main/asciidoc/index.html | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/isis/blob/e0e55852/adocs/documentation/src/main/asciidoc/index.html
----------------------------------------------------------------------
diff --git a/adocs/documentation/src/main/asciidoc/index.html b/adocs/documentation/src/main/asciidoc/index.html
index c6f0ca8..9a5b95a 100644
--- a/adocs/documentation/src/main/asciidoc/index.html
+++ b/adocs/documentation/src/main/asciidoc/index.html
@@ -664,7 +664,7 @@
 mvn archetype:generate  \
     -D archetypeGroupId=org.apache.isis.archetype \
     -D archetypeArtifactId=simpleapp-archetype \
-    -D archetypeVersion=1.11.0 \
+    -D archetypeVersion=1.11.1 \
     -D groupId=com.mycompany \
     -D artifactId=myapp \
     -D version=1.0-SNAPSHOT \


[08/17] isis git commit: ISIS-1296: updating pom.xml to use Isis 1.11.1; fixing JDOQL strings; reinstating eclipse .launch files (with some minor renames/rationalization and now using app manifests)

Posted by da...@apache.org.
ISIS-1296: updating pom.xml to use Isis 1.11.1; fixing JDOQL strings; reinstating eclipse .launch files (with some minor renames/rationalization and now using app manifests)


Project: http://git-wip-us.apache.org/repos/asf/isis/repo
Commit: http://git-wip-us.apache.org/repos/asf/isis/commit/0915e033
Tree: http://git-wip-us.apache.org/repos/asf/isis/tree/0915e033
Diff: http://git-wip-us.apache.org/repos/asf/isis/diff/0915e033

Branch: refs/heads/master
Commit: 0915e033657862f994d199040ef0631656fef305
Parents: 277f4cb
Author: Dan Haywood <da...@haywood-associates.co.uk>
Authored: Sun Jan 10 15:03:29 2016 +0000
Committer: Dan Haywood <da...@haywood-associates.co.uk>
Committed: Sun Jan 10 15:03:29 2016 +0000

----------------------------------------------------------------------
 .../java/domainapp/dom/simple/SimpleObject.java |  4 +--
 example/application/simpleapp/pom.xml           |  2 +-
 .../webapp/ide/eclipse/launch/.gitignore        |  8 +----
 .../ide/eclipse/launch/SimpleApp-JREBEL.launch  | 31 ++++++++++++++++++++
 .../launch/SimpleApp-PROTOTYPE-jrebel.launch    | 31 --------------------
 .../SimpleApp-PROTOTYPE-no-fixtures.launch      | 23 ---------------
 ...OTOTYPE-with-fixtures-bypass-security.launch | 20 +++++++++++++
 .../SimpleApp-PROTOTYPE-with-fixtures.launch    |  2 +-
 .../eclipse/launch/SimpleApp-PROTOTYPE.launch   | 20 +++++++++++++
 .../launch/SimpleApp-SERVER-no-fixtures.launch  | 23 ---------------
 .../ide/eclipse/launch/SimpleApp-SERVER.launch  | 20 +++++++++++++
 11 files changed, 96 insertions(+), 88 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/isis/blob/0915e033/example/application/simpleapp/dom/src/main/java/domainapp/dom/simple/SimpleObject.java
----------------------------------------------------------------------
diff --git a/example/application/simpleapp/dom/src/main/java/domainapp/dom/simple/SimpleObject.java b/example/application/simpleapp/dom/src/main/java/domainapp/dom/simple/SimpleObject.java
index a5fe4ef..2c0bc1f 100644
--- a/example/application/simpleapp/dom/src/main/java/domainapp/dom/simple/SimpleObject.java
+++ b/example/application/simpleapp/dom/src/main/java/domainapp/dom/simple/SimpleObject.java
@@ -54,11 +54,11 @@ import org.apache.isis.applib.util.ObjectContracts;
         @javax.jdo.annotations.Query(
                 name = "find", language = "JDOQL",
                 value = "SELECT "
-                        + "FROM domainapp.dom.modules.simple.SimpleObject "),
+                        + "FROM domainapp.dom.simple.SimpleObject "),
         @javax.jdo.annotations.Query(
                 name = "findByName", language = "JDOQL",
                 value = "SELECT "
-                        + "FROM domainapp.dom.modules.simple.SimpleObject "
+                        + "FROM domainapp.dom.simple.SimpleObject "
                         + "WHERE name.indexOf(:name) >= 0 ")
 })
 @javax.jdo.annotations.Unique(name="SimpleObject_name_UNQ", members = {"name"})

http://git-wip-us.apache.org/repos/asf/isis/blob/0915e033/example/application/simpleapp/pom.xml
----------------------------------------------------------------------
diff --git a/example/application/simpleapp/pom.xml b/example/application/simpleapp/pom.xml
index f3f0dc8..5724121 100644
--- a/example/application/simpleapp/pom.xml
+++ b/example/application/simpleapp/pom.xml
@@ -34,7 +34,7 @@
     </prerequisites>
 
     <properties>
-        <isis.version>1.11.0</isis.version>
+        <isis.version>1.11.1</isis.version>
 
         <project.build.sourceEncoding>UTF-8</project.build.sourceEncoding>
         <project.reporting.outputEncoding>UTF-8</project.reporting.outputEncoding>

http://git-wip-us.apache.org/repos/asf/isis/blob/0915e033/example/application/simpleapp/webapp/ide/eclipse/launch/.gitignore
----------------------------------------------------------------------
diff --git a/example/application/simpleapp/webapp/ide/eclipse/launch/.gitignore b/example/application/simpleapp/webapp/ide/eclipse/launch/.gitignore
index 3d97345..1d44fd4 100644
--- a/example/application/simpleapp/webapp/ide/eclipse/launch/.gitignore
+++ b/example/application/simpleapp/webapp/ide/eclipse/launch/.gitignore
@@ -1,8 +1,2 @@
 /SimpleApp-PROTOTYPE-jrebel.launch
-/SimpleApp-PROTOTYPE-no-fixtures.launch
-/SimpleApp-PROTOTYPE-with-fixtures.launch
-/SimpleApp-SERVER-no-fixtures.launch
-/SimpleApp-PROTOTYPE-jrebel.launch
-/SimpleApp-PROTOTYPE-no-fixtures.launch
-/SimpleApp-PROTOTYPE-with-fixtures.launch
-/SimpleApp-SERVER-no-fixtures.launch
+/SimpleApp-jrebel.launch

http://git-wip-us.apache.org/repos/asf/isis/blob/0915e033/example/application/simpleapp/webapp/ide/eclipse/launch/SimpleApp-JREBEL.launch
----------------------------------------------------------------------
diff --git a/example/application/simpleapp/webapp/ide/eclipse/launch/SimpleApp-JREBEL.launch b/example/application/simpleapp/webapp/ide/eclipse/launch/SimpleApp-JREBEL.launch
new file mode 100644
index 0000000..e45f7f0
--- /dev/null
+++ b/example/application/simpleapp/webapp/ide/eclipse/launch/SimpleApp-JREBEL.launch
@@ -0,0 +1,31 @@
+<?xml version="1.0" encoding="UTF-8" standalone="no"?>
+<launchConfiguration type="org.eclipse.jdt.launching.localJavaApplication">
+<listAttribute key="org.eclipse.debug.core.MAPPED_RESOURCE_PATHS">
+<listEntry value="/isis-core-webserver/src/main/java/org/apache/isis/WebServer.java"/>
+</listAttribute>
+<listAttribute key="org.eclipse.debug.core.MAPPED_RESOURCE_TYPES">
+<listEntry value="1"/>
+</listAttribute>
+<mapAttribute key="org.eclipse.debug.core.preferred_launchers">
+<mapEntry key="[debug]" value="org.eclipse.jdt.launching.localJavaApplication"/>
+<mapEntry key="[run]" value="org.eclipse.jdt.launching.localJavaApplication"/>
+</mapAttribute>
+<stringAttribute key="org.eclipse.debug.core.source_locator_id" value="org.eclipse.jdt.launching.sourceLocator.JavaSourceLookupDirector"/>
+<stringAttribute key="org.eclipse.debug.core.source_locator_memento" value="&lt;?xml version=&quot;1.0&quot; encoding=&quot;UTF-8&quot; standalone=&quot;no&quot;?&gt;&#13;&#10;&lt;sourceLookupDirector&gt;&#13;&#10;&lt;sourceContainers duplicates=&quot;false&quot;&gt;&#13;&#10;&lt;container memento=&quot;&amp;lt;?xml version=&amp;quot;1.0&amp;quot; encoding=&amp;quot;UTF-8&amp;quot; standalone=&amp;quot;no&amp;quot;?&amp;gt;&amp;#13;&amp;#10;&amp;lt;javaProject name=&amp;quot;isis-jrebel-plugin&amp;quot;/&amp;gt;&amp;#13;&amp;#10;&quot; typeId=&quot;org.eclipse.jdt.launching.sourceContainer.javaProject&quot;/&gt;&#13;&#10;&lt;container memento=&quot;&amp;lt;?xml version=&amp;quot;1.0&amp;quot; encoding=&amp;quot;UTF-8&amp;quot; standalone=&amp;quot;no&amp;quot;?&amp;gt;&amp;#13;&amp;#10;&amp;lt;default/&amp;gt;&amp;#13;&amp;#10;&quot; typeId=&quot;org.eclipse.debug.core.containerType.default&quot;/&gt;&#13;&#10;&lt;/sourceContainers&gt;&#13;&#10;&lt;/sourceLookupDirector&gt;&#13;&#10
 ;"/>
+<listAttribute key="org.eclipse.debug.ui.favoriteGroups">
+<listEntry value="org.eclipse.debug.ui.launchGroup.run"/>
+</listAttribute>
+<booleanAttribute key="org.eclipse.jdt.debug.ui.INCLUDE_EXTERNAL_JARS" value="true"/>
+<listAttribute key="org.eclipse.jdt.launching.CLASSPATH">
+<listEntry value="&lt;?xml version=&quot;1.0&quot; encoding=&quot;UTF-8&quot; standalone=&quot;no&quot;?&gt;&#13;&#10;&lt;runtimeClasspathEntry containerPath=&quot;org.eclipse.jdt.launching.JRE_CONTAINER/org.eclipse.jdt.internal.debug.ui.launcher.StandardVMType/JavaSE-1.6&quot; path=&quot;1&quot; type=&quot;4&quot;/&gt;&#13;&#10;"/>
+<listEntry value="&lt;?xml version=&quot;1.0&quot; encoding=&quot;UTF-8&quot; standalone=&quot;no&quot;?&gt;&#13;&#10;&lt;runtimeClasspathEntry path=&quot;3&quot; projectName=&quot;simple_wicket_restful_jdo-webapp&quot; type=&quot;1&quot;/&gt;&#13;&#10;"/>
+<listEntry value="&lt;?xml version=&quot;1.0&quot; encoding=&quot;UTF-8&quot; standalone=&quot;no&quot;?&gt;&#13;&#10;&lt;runtimeClasspathEntry containerPath=&quot;org.eclipse.m2e.MAVEN2_CLASSPATH_CONTAINER&quot; path=&quot;3&quot; type=&quot;4&quot;/&gt;&#13;&#10;"/>
+</listAttribute>
+<stringAttribute key="org.eclipse.jdt.launching.CLASSPATH_PROVIDER" value="org.eclipse.m2e.launchconfig.classpathProvider"/>
+<booleanAttribute key="org.eclipse.jdt.launching.DEFAULT_CLASSPATH" value="true"/>
+<stringAttribute key="org.eclipse.jdt.launching.MAIN_TYPE" value="org.apache.isis.WebServer"/>
+<stringAttribute key="org.eclipse.jdt.launching.PROGRAM_ARGUMENTS" value="--port 8080 --type PROTOTYPE"/>
+<stringAttribute key="org.eclipse.jdt.launching.PROJECT_ATTR" value="simpleapp-webapp"/>
+<stringAttribute key="org.eclipse.jdt.launching.SOURCE_PATH_PROVIDER" value="org.eclipse.m2e.launchconfig.sourcepathProvider"/>
+<stringAttribute key="org.eclipse.jdt.launching.VM_ARGUMENTS" value="${jrebel_args} -Drebel.log=false -Drebel.check_class_hash=true -Drebel.packages_exclude=org.apache.isis -Dproject.root=${project_loc}/.. -Dtarget.dir=target-ide -Drebel.plugins=C:/github/danhaywood/isis-jrebel-plugin/target/danhaywood-isis-jrebel-plugin-1.0.0-SNAPSHOT.jar -Disis-jrebel-plugin.packagePrefix=dom.simple,org.apache.isis.objectstore.jdo.applib -Disis-jrebel-plugin.loggingLevel=warn -XX:MaxPermSize=128m"/>
+</launchConfiguration>

http://git-wip-us.apache.org/repos/asf/isis/blob/0915e033/example/application/simpleapp/webapp/ide/eclipse/launch/SimpleApp-PROTOTYPE-jrebel.launch
----------------------------------------------------------------------
diff --git a/example/application/simpleapp/webapp/ide/eclipse/launch/SimpleApp-PROTOTYPE-jrebel.launch b/example/application/simpleapp/webapp/ide/eclipse/launch/SimpleApp-PROTOTYPE-jrebel.launch
deleted file mode 100644
index e45f7f0..0000000
--- a/example/application/simpleapp/webapp/ide/eclipse/launch/SimpleApp-PROTOTYPE-jrebel.launch
+++ /dev/null
@@ -1,31 +0,0 @@
-<?xml version="1.0" encoding="UTF-8" standalone="no"?>
-<launchConfiguration type="org.eclipse.jdt.launching.localJavaApplication">
-<listAttribute key="org.eclipse.debug.core.MAPPED_RESOURCE_PATHS">
-<listEntry value="/isis-core-webserver/src/main/java/org/apache/isis/WebServer.java"/>
-</listAttribute>
-<listAttribute key="org.eclipse.debug.core.MAPPED_RESOURCE_TYPES">
-<listEntry value="1"/>
-</listAttribute>
-<mapAttribute key="org.eclipse.debug.core.preferred_launchers">
-<mapEntry key="[debug]" value="org.eclipse.jdt.launching.localJavaApplication"/>
-<mapEntry key="[run]" value="org.eclipse.jdt.launching.localJavaApplication"/>
-</mapAttribute>
-<stringAttribute key="org.eclipse.debug.core.source_locator_id" value="org.eclipse.jdt.launching.sourceLocator.JavaSourceLookupDirector"/>
-<stringAttribute key="org.eclipse.debug.core.source_locator_memento" value="&lt;?xml version=&quot;1.0&quot; encoding=&quot;UTF-8&quot; standalone=&quot;no&quot;?&gt;&#13;&#10;&lt;sourceLookupDirector&gt;&#13;&#10;&lt;sourceContainers duplicates=&quot;false&quot;&gt;&#13;&#10;&lt;container memento=&quot;&amp;lt;?xml version=&amp;quot;1.0&amp;quot; encoding=&amp;quot;UTF-8&amp;quot; standalone=&amp;quot;no&amp;quot;?&amp;gt;&amp;#13;&amp;#10;&amp;lt;javaProject name=&amp;quot;isis-jrebel-plugin&amp;quot;/&amp;gt;&amp;#13;&amp;#10;&quot; typeId=&quot;org.eclipse.jdt.launching.sourceContainer.javaProject&quot;/&gt;&#13;&#10;&lt;container memento=&quot;&amp;lt;?xml version=&amp;quot;1.0&amp;quot; encoding=&amp;quot;UTF-8&amp;quot; standalone=&amp;quot;no&amp;quot;?&amp;gt;&amp;#13;&amp;#10;&amp;lt;default/&amp;gt;&amp;#13;&amp;#10;&quot; typeId=&quot;org.eclipse.debug.core.containerType.default&quot;/&gt;&#13;&#10;&lt;/sourceContainers&gt;&#13;&#10;&lt;/sourceLookupDirector&gt;&#13;&#10
 ;"/>
-<listAttribute key="org.eclipse.debug.ui.favoriteGroups">
-<listEntry value="org.eclipse.debug.ui.launchGroup.run"/>
-</listAttribute>
-<booleanAttribute key="org.eclipse.jdt.debug.ui.INCLUDE_EXTERNAL_JARS" value="true"/>
-<listAttribute key="org.eclipse.jdt.launching.CLASSPATH">
-<listEntry value="&lt;?xml version=&quot;1.0&quot; encoding=&quot;UTF-8&quot; standalone=&quot;no&quot;?&gt;&#13;&#10;&lt;runtimeClasspathEntry containerPath=&quot;org.eclipse.jdt.launching.JRE_CONTAINER/org.eclipse.jdt.internal.debug.ui.launcher.StandardVMType/JavaSE-1.6&quot; path=&quot;1&quot; type=&quot;4&quot;/&gt;&#13;&#10;"/>
-<listEntry value="&lt;?xml version=&quot;1.0&quot; encoding=&quot;UTF-8&quot; standalone=&quot;no&quot;?&gt;&#13;&#10;&lt;runtimeClasspathEntry path=&quot;3&quot; projectName=&quot;simple_wicket_restful_jdo-webapp&quot; type=&quot;1&quot;/&gt;&#13;&#10;"/>
-<listEntry value="&lt;?xml version=&quot;1.0&quot; encoding=&quot;UTF-8&quot; standalone=&quot;no&quot;?&gt;&#13;&#10;&lt;runtimeClasspathEntry containerPath=&quot;org.eclipse.m2e.MAVEN2_CLASSPATH_CONTAINER&quot; path=&quot;3&quot; type=&quot;4&quot;/&gt;&#13;&#10;"/>
-</listAttribute>
-<stringAttribute key="org.eclipse.jdt.launching.CLASSPATH_PROVIDER" value="org.eclipse.m2e.launchconfig.classpathProvider"/>
-<booleanAttribute key="org.eclipse.jdt.launching.DEFAULT_CLASSPATH" value="true"/>
-<stringAttribute key="org.eclipse.jdt.launching.MAIN_TYPE" value="org.apache.isis.WebServer"/>
-<stringAttribute key="org.eclipse.jdt.launching.PROGRAM_ARGUMENTS" value="--port 8080 --type PROTOTYPE"/>
-<stringAttribute key="org.eclipse.jdt.launching.PROJECT_ATTR" value="simpleapp-webapp"/>
-<stringAttribute key="org.eclipse.jdt.launching.SOURCE_PATH_PROVIDER" value="org.eclipse.m2e.launchconfig.sourcepathProvider"/>
-<stringAttribute key="org.eclipse.jdt.launching.VM_ARGUMENTS" value="${jrebel_args} -Drebel.log=false -Drebel.check_class_hash=true -Drebel.packages_exclude=org.apache.isis -Dproject.root=${project_loc}/.. -Dtarget.dir=target-ide -Drebel.plugins=C:/github/danhaywood/isis-jrebel-plugin/target/danhaywood-isis-jrebel-plugin-1.0.0-SNAPSHOT.jar -Disis-jrebel-plugin.packagePrefix=dom.simple,org.apache.isis.objectstore.jdo.applib -Disis-jrebel-plugin.loggingLevel=warn -XX:MaxPermSize=128m"/>
-</launchConfiguration>

http://git-wip-us.apache.org/repos/asf/isis/blob/0915e033/example/application/simpleapp/webapp/ide/eclipse/launch/SimpleApp-PROTOTYPE-no-fixtures.launch
----------------------------------------------------------------------
diff --git a/example/application/simpleapp/webapp/ide/eclipse/launch/SimpleApp-PROTOTYPE-no-fixtures.launch b/example/application/simpleapp/webapp/ide/eclipse/launch/SimpleApp-PROTOTYPE-no-fixtures.launch
deleted file mode 100644
index 96a9a54..0000000
--- a/example/application/simpleapp/webapp/ide/eclipse/launch/SimpleApp-PROTOTYPE-no-fixtures.launch
+++ /dev/null
@@ -1,23 +0,0 @@
-<?xml version="1.0" encoding="UTF-8" standalone="no"?>
-<launchConfiguration type="org.eclipse.jdt.launching.localJavaApplication">
-<listAttribute key="org.eclipse.debug.core.MAPPED_RESOURCE_PATHS">
-<listEntry value="/isis-core-webserver/src/main/java/org/apache/isis/WebServer.java"/>
-</listAttribute>
-<listAttribute key="org.eclipse.debug.core.MAPPED_RESOURCE_TYPES">
-<listEntry value="1"/>
-</listAttribute>
-<mapAttribute key="org.eclipse.debug.core.preferred_launchers">
-<mapEntry key="[debug]" value="org.eclipse.jdt.launching.localJavaApplication"/>
-<mapEntry key="[run]" value="org.eclipse.jdt.launching.localJavaApplication"/>
-</mapAttribute>
-<stringAttribute key="org.eclipse.debug.core.source_locator_id" value="org.eclipse.jdt.launching.sourceLocator.JavaSourceLookupDirector"/>
-<listAttribute key="org.eclipse.debug.ui.favoriteGroups">
-<listEntry value="org.eclipse.debug.ui.launchGroup.debug"/>
-</listAttribute>
-<booleanAttribute key="org.eclipse.jdt.debug.ui.INCLUDE_EXTERNAL_JARS" value="true"/>
-<stringAttribute key="org.eclipse.jdt.launching.CLASSPATH_PROVIDER" value="org.eclipse.m2e.launchconfig.classpathProvider"/>
-<stringAttribute key="org.eclipse.jdt.launching.MAIN_TYPE" value="org.apache.isis.WebServer"/>
-<stringAttribute key="org.eclipse.jdt.launching.PROGRAM_ARGUMENTS" value="--port 8080 --type SERVER_PROTOTYPE"/>
-<stringAttribute key="org.eclipse.jdt.launching.PROJECT_ATTR" value="simpleapp-webapp"/>
-<stringAttribute key="org.eclipse.jdt.launching.SOURCE_PATH_PROVIDER" value="org.eclipse.m2e.launchconfig.sourcepathProvider"/>
-</launchConfiguration>

http://git-wip-us.apache.org/repos/asf/isis/blob/0915e033/example/application/simpleapp/webapp/ide/eclipse/launch/SimpleApp-PROTOTYPE-with-fixtures-bypass-security.launch
----------------------------------------------------------------------
diff --git a/example/application/simpleapp/webapp/ide/eclipse/launch/SimpleApp-PROTOTYPE-with-fixtures-bypass-security.launch b/example/application/simpleapp/webapp/ide/eclipse/launch/SimpleApp-PROTOTYPE-with-fixtures-bypass-security.launch
new file mode 100644
index 0000000..16e483a
--- /dev/null
+++ b/example/application/simpleapp/webapp/ide/eclipse/launch/SimpleApp-PROTOTYPE-with-fixtures-bypass-security.launch
@@ -0,0 +1,20 @@
+<?xml version="1.0" encoding="UTF-8" standalone="no"?>
+<launchConfiguration type="org.eclipse.jdt.launching.localJavaApplication">
+<listAttribute key="org.eclipse.debug.core.MAPPED_RESOURCE_PATHS">
+<listEntry value="/isis-core-webserver/src/main/java/org/apache/isis/WebServer.java"/>
+</listAttribute>
+<listAttribute key="org.eclipse.debug.core.MAPPED_RESOURCE_TYPES">
+<listEntry value="1"/>
+</listAttribute>
+<mapAttribute key="org.eclipse.debug.core.preferred_launchers">
+<mapEntry key="[debug]" value="org.eclipse.jdt.launching.localJavaApplication"/>
+<mapEntry key="[run]" value="org.eclipse.jdt.launching.localJavaApplication"/>
+</mapAttribute>
+<stringAttribute key="org.eclipse.debug.core.source_locator_id" value="org.eclipse.jdt.launching.sourceLocator.JavaSourceLookupDirector"/>
+<booleanAttribute key="org.eclipse.jdt.debug.ui.INCLUDE_EXTERNAL_JARS" value="true"/>
+<stringAttribute key="org.eclipse.jdt.launching.CLASSPATH_PROVIDER" value="org.eclipse.m2e.launchconfig.classpathProvider"/>
+<stringAttribute key="org.eclipse.jdt.launching.MAIN_TYPE" value="org.apache.isis.WebServer"/>
+<stringAttribute key="org.eclipse.jdt.launching.PROGRAM_ARGUMENTS" value="--type SERVER_PROTOTYPE --manifest domainapp.app.DomainAppAppManifestWithFixturesBypassSecurity"/>
+<stringAttribute key="org.eclipse.jdt.launching.PROJECT_ATTR" value="simpleapp-webapp"/>
+<stringAttribute key="org.eclipse.jdt.launching.SOURCE_PATH_PROVIDER" value="org.eclipse.m2e.launchconfig.sourcepathProvider"/>
+</launchConfiguration>

http://git-wip-us.apache.org/repos/asf/isis/blob/0915e033/example/application/simpleapp/webapp/ide/eclipse/launch/SimpleApp-PROTOTYPE-with-fixtures.launch
----------------------------------------------------------------------
diff --git a/example/application/simpleapp/webapp/ide/eclipse/launch/SimpleApp-PROTOTYPE-with-fixtures.launch b/example/application/simpleapp/webapp/ide/eclipse/launch/SimpleApp-PROTOTYPE-with-fixtures.launch
index dbfb2b3..659195c 100644
--- a/example/application/simpleapp/webapp/ide/eclipse/launch/SimpleApp-PROTOTYPE-with-fixtures.launch
+++ b/example/application/simpleapp/webapp/ide/eclipse/launch/SimpleApp-PROTOTYPE-with-fixtures.launch
@@ -14,7 +14,7 @@
 <booleanAttribute key="org.eclipse.jdt.debug.ui.INCLUDE_EXTERNAL_JARS" value="true"/>
 <stringAttribute key="org.eclipse.jdt.launching.CLASSPATH_PROVIDER" value="org.eclipse.m2e.launchconfig.classpathProvider"/>
 <stringAttribute key="org.eclipse.jdt.launching.MAIN_TYPE" value="org.apache.isis.WebServer"/>
-<stringAttribute key="org.eclipse.jdt.launching.PROGRAM_ARGUMENTS" value="--port 8080 -D isis.persistor.datanucleus.install-fixtures=true --type SERVER_PROTOTYPE"/>
+<stringAttribute key="org.eclipse.jdt.launching.PROGRAM_ARGUMENTS" value="--type SERVER_PROTOTYPE --manifest domainapp.app.DomainAppAppManifestWithFixtures"/>
 <stringAttribute key="org.eclipse.jdt.launching.PROJECT_ATTR" value="simpleapp-webapp"/>
 <stringAttribute key="org.eclipse.jdt.launching.SOURCE_PATH_PROVIDER" value="org.eclipse.m2e.launchconfig.sourcepathProvider"/>
 </launchConfiguration>

http://git-wip-us.apache.org/repos/asf/isis/blob/0915e033/example/application/simpleapp/webapp/ide/eclipse/launch/SimpleApp-PROTOTYPE.launch
----------------------------------------------------------------------
diff --git a/example/application/simpleapp/webapp/ide/eclipse/launch/SimpleApp-PROTOTYPE.launch b/example/application/simpleapp/webapp/ide/eclipse/launch/SimpleApp-PROTOTYPE.launch
new file mode 100644
index 0000000..7e1303a
--- /dev/null
+++ b/example/application/simpleapp/webapp/ide/eclipse/launch/SimpleApp-PROTOTYPE.launch
@@ -0,0 +1,20 @@
+<?xml version="1.0" encoding="UTF-8" standalone="no"?>
+<launchConfiguration type="org.eclipse.jdt.launching.localJavaApplication">
+<listAttribute key="org.eclipse.debug.core.MAPPED_RESOURCE_PATHS">
+<listEntry value="/isis-core-webserver/src/main/java/org/apache/isis/WebServer.java"/>
+</listAttribute>
+<listAttribute key="org.eclipse.debug.core.MAPPED_RESOURCE_TYPES">
+<listEntry value="1"/>
+</listAttribute>
+<mapAttribute key="org.eclipse.debug.core.preferred_launchers">
+<mapEntry key="[debug]" value="org.eclipse.jdt.launching.localJavaApplication"/>
+<mapEntry key="[run]" value="org.eclipse.jdt.launching.localJavaApplication"/>
+</mapAttribute>
+<stringAttribute key="org.eclipse.debug.core.source_locator_id" value="org.eclipse.jdt.launching.sourceLocator.JavaSourceLookupDirector"/>
+<booleanAttribute key="org.eclipse.jdt.debug.ui.INCLUDE_EXTERNAL_JARS" value="true"/>
+<stringAttribute key="org.eclipse.jdt.launching.CLASSPATH_PROVIDER" value="org.eclipse.m2e.launchconfig.classpathProvider"/>
+<stringAttribute key="org.eclipse.jdt.launching.MAIN_TYPE" value="org.apache.isis.WebServer"/>
+<stringAttribute key="org.eclipse.jdt.launching.PROGRAM_ARGUMENTS" value="--type SERVER_PROTOTYPE"/>
+<stringAttribute key="org.eclipse.jdt.launching.PROJECT_ATTR" value="simpleapp-webapp"/>
+<stringAttribute key="org.eclipse.jdt.launching.SOURCE_PATH_PROVIDER" value="org.eclipse.m2e.launchconfig.sourcepathProvider"/>
+</launchConfiguration>

http://git-wip-us.apache.org/repos/asf/isis/blob/0915e033/example/application/simpleapp/webapp/ide/eclipse/launch/SimpleApp-SERVER-no-fixtures.launch
----------------------------------------------------------------------
diff --git a/example/application/simpleapp/webapp/ide/eclipse/launch/SimpleApp-SERVER-no-fixtures.launch b/example/application/simpleapp/webapp/ide/eclipse/launch/SimpleApp-SERVER-no-fixtures.launch
deleted file mode 100644
index 238b5a6..0000000
--- a/example/application/simpleapp/webapp/ide/eclipse/launch/SimpleApp-SERVER-no-fixtures.launch
+++ /dev/null
@@ -1,23 +0,0 @@
-<?xml version="1.0" encoding="UTF-8" standalone="no"?>
-<launchConfiguration type="org.eclipse.jdt.launching.localJavaApplication">
-<listAttribute key="org.eclipse.debug.core.MAPPED_RESOURCE_PATHS">
-<listEntry value="/isis-core-webserver/src/main/java/org/apache/isis/WebServer.java"/>
-</listAttribute>
-<listAttribute key="org.eclipse.debug.core.MAPPED_RESOURCE_TYPES">
-<listEntry value="1"/>
-</listAttribute>
-<mapAttribute key="org.eclipse.debug.core.preferred_launchers">
-<mapEntry key="[debug]" value="org.eclipse.jdt.launching.localJavaApplication"/>
-<mapEntry key="[run]" value="org.eclipse.jdt.launching.localJavaApplication"/>
-</mapAttribute>
-<stringAttribute key="org.eclipse.debug.core.source_locator_id" value="org.eclipse.jdt.launching.sourceLocator.JavaSourceLookupDirector"/>
-<listAttribute key="org.eclipse.debug.ui.favoriteGroups">
-<listEntry value="org.eclipse.debug.ui.launchGroup.run"/>
-</listAttribute>
-<booleanAttribute key="org.eclipse.jdt.debug.ui.INCLUDE_EXTERNAL_JARS" value="true"/>
-<stringAttribute key="org.eclipse.jdt.launching.CLASSPATH_PROVIDER" value="org.eclipse.m2e.launchconfig.classpathProvider"/>
-<stringAttribute key="org.eclipse.jdt.launching.MAIN_TYPE" value="org.apache.isis.WebServer"/>
-<stringAttribute key="org.eclipse.jdt.launching.PROGRAM_ARGUMENTS" value="--port 8080 --type SERVER"/>
-<stringAttribute key="org.eclipse.jdt.launching.PROJECT_ATTR" value="simpleapp-webapp"/>
-<stringAttribute key="org.eclipse.jdt.launching.SOURCE_PATH_PROVIDER" value="org.eclipse.m2e.launchconfig.sourcepathProvider"/>
-</launchConfiguration>

http://git-wip-us.apache.org/repos/asf/isis/blob/0915e033/example/application/simpleapp/webapp/ide/eclipse/launch/SimpleApp-SERVER.launch
----------------------------------------------------------------------
diff --git a/example/application/simpleapp/webapp/ide/eclipse/launch/SimpleApp-SERVER.launch b/example/application/simpleapp/webapp/ide/eclipse/launch/SimpleApp-SERVER.launch
new file mode 100644
index 0000000..deccfe8
--- /dev/null
+++ b/example/application/simpleapp/webapp/ide/eclipse/launch/SimpleApp-SERVER.launch
@@ -0,0 +1,20 @@
+<?xml version="1.0" encoding="UTF-8" standalone="no"?>
+<launchConfiguration type="org.eclipse.jdt.launching.localJavaApplication">
+<listAttribute key="org.eclipse.debug.core.MAPPED_RESOURCE_PATHS">
+<listEntry value="/isis-core-webserver/src/main/java/org/apache/isis/WebServer.java"/>
+</listAttribute>
+<listAttribute key="org.eclipse.debug.core.MAPPED_RESOURCE_TYPES">
+<listEntry value="1"/>
+</listAttribute>
+<mapAttribute key="org.eclipse.debug.core.preferred_launchers">
+<mapEntry key="[debug]" value="org.eclipse.jdt.launching.localJavaApplication"/>
+<mapEntry key="[run]" value="org.eclipse.jdt.launching.localJavaApplication"/>
+</mapAttribute>
+<stringAttribute key="org.eclipse.debug.core.source_locator_id" value="org.eclipse.jdt.launching.sourceLocator.JavaSourceLookupDirector"/>
+<booleanAttribute key="org.eclipse.jdt.debug.ui.INCLUDE_EXTERNAL_JARS" value="true"/>
+<stringAttribute key="org.eclipse.jdt.launching.CLASSPATH_PROVIDER" value="org.eclipse.m2e.launchconfig.classpathProvider"/>
+<stringAttribute key="org.eclipse.jdt.launching.MAIN_TYPE" value="org.apache.isis.WebServer"/>
+<stringAttribute key="org.eclipse.jdt.launching.PROGRAM_ARGUMENTS" value="--type SERVER"/>
+<stringAttribute key="org.eclipse.jdt.launching.PROJECT_ATTR" value="simpleapp-webapp"/>
+<stringAttribute key="org.eclipse.jdt.launching.SOURCE_PATH_PROVIDER" value="org.eclipse.m2e.launchconfig.sourcepathProvider"/>
+</launchConfiguration>


[04/17] isis git commit: ISIS-1296: using toolchain plugin to enforce Java7; don't call JDK8 APIs

Posted by da...@apache.org.
ISIS-1296: using toolchain plugin to enforce Java7; don't call JDK8 APIs


Project: http://git-wip-us.apache.org/repos/asf/isis/repo
Commit: http://git-wip-us.apache.org/repos/asf/isis/commit/9d232328
Tree: http://git-wip-us.apache.org/repos/asf/isis/tree/9d232328
Diff: http://git-wip-us.apache.org/repos/asf/isis/diff/9d232328

Branch: refs/heads/master
Commit: 9d2323286b734d8732c2c38411d073675a8ef13a
Parents: 0f92613
Author: Dan Haywood <da...@haywood-associates.co.uk>
Authored: Sun Jan 10 13:35:03 2016 +0000
Committer: Dan Haywood <da...@haywood-associates.co.uk>
Committed: Sun Jan 10 13:35:03 2016 +0000

----------------------------------------------------------------------
 .../isis/core/metamodel/facets/Annotations.java |  2 +-
 .../container/DomainObjectContainerDefault.java |  2 +-
 core/pom.xml                                    | 21 ++++++++++++++++++++
 .../unittestsupport/soap/SoapEndpointSpec.java  |  3 +--
 4 files changed, 24 insertions(+), 4 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/isis/blob/9d232328/core/metamodel/src/main/java/org/apache/isis/core/metamodel/facets/Annotations.java
----------------------------------------------------------------------
diff --git a/core/metamodel/src/main/java/org/apache/isis/core/metamodel/facets/Annotations.java b/core/metamodel/src/main/java/org/apache/isis/core/metamodel/facets/Annotations.java
index 707213c..1e08d5d 100644
--- a/core/metamodel/src/main/java/org/apache/isis/core/metamodel/facets/Annotations.java
+++ b/core/metamodel/src/main/java/org/apache/isis/core/metamodel/facets/Annotations.java
@@ -185,7 +185,7 @@ public final class Annotations  {
 
         for (Method method : cls.getDeclaredMethods()) {
             if(MethodScope.OBJECT.matchesScopeOf(method) &&
-                    method.getParameterCount() == 0) {
+                    method.getParameterTypes().length == 0) {
                 final Annotation annotation = method.getAnnotation(annotationClass);
                 if(annotation != null) {
                     evaluators.add(new MethodEvaluator(method, annotation));

http://git-wip-us.apache.org/repos/asf/isis/blob/9d232328/core/metamodel/src/main/java/org/apache/isis/core/metamodel/services/container/DomainObjectContainerDefault.java
----------------------------------------------------------------------
diff --git a/core/metamodel/src/main/java/org/apache/isis/core/metamodel/services/container/DomainObjectContainerDefault.java b/core/metamodel/src/main/java/org/apache/isis/core/metamodel/services/container/DomainObjectContainerDefault.java
index 7944bbf..1371109 100644
--- a/core/metamodel/src/main/java/org/apache/isis/core/metamodel/services/container/DomainObjectContainerDefault.java
+++ b/core/metamodel/src/main/java/org/apache/isis/core/metamodel/services/container/DomainObjectContainerDefault.java
@@ -195,7 +195,7 @@ public class DomainObjectContainerDefault
         }
         final Constructor<?>[] constructors = mixinClass.getConstructors();
         for (Constructor<?> constructor : constructors) {
-            if(constructor.getParameterCount() == 1 &&
+            if(constructor.getParameterTypes().length == 1 &&
                constructor.getParameterTypes()[0].isAssignableFrom(mixedIn.getClass())) {
                 final Object mixin;
                 try {

http://git-wip-us.apache.org/repos/asf/isis/blob/9d232328/core/pom.xml
----------------------------------------------------------------------
diff --git a/core/pom.xml b/core/pom.xml
index e28435f..624fc0b 100644
--- a/core/pom.xml
+++ b/core/pom.xml
@@ -948,6 +948,27 @@
 
             <plugin>
                 <groupId>org.apache.maven.plugins</groupId>
+                <artifactId>maven-toolchains-plugin</artifactId>
+                <version>1.1</version>
+                <executions>
+                    <execution>
+                        <goals>
+                            <goal>toolchain</goal>
+                        </goals>
+                    </execution>
+                </executions>
+                <configuration>
+                    <toolchains>
+                        <jdk>
+                            <version>1.7</version>
+                            <vendor>oracle</vendor>
+                        </jdk>
+                    </toolchains>
+                </configuration>
+            </plugin>
+
+            <plugin>
+                <groupId>org.apache.maven.plugins</groupId>
                 <artifactId>maven-enforcer-plugin</artifactId>
             </plugin>
 

http://git-wip-us.apache.org/repos/asf/isis/blob/9d232328/core/unittestsupport/src/main/java/org/apache/isis/core/unittestsupport/soap/SoapEndpointSpec.java
----------------------------------------------------------------------
diff --git a/core/unittestsupport/src/main/java/org/apache/isis/core/unittestsupport/soap/SoapEndpointSpec.java b/core/unittestsupport/src/main/java/org/apache/isis/core/unittestsupport/soap/SoapEndpointSpec.java
index e3511e6..e83439a 100644
--- a/core/unittestsupport/src/main/java/org/apache/isis/core/unittestsupport/soap/SoapEndpointSpec.java
+++ b/core/unittestsupport/src/main/java/org/apache/isis/core/unittestsupport/soap/SoapEndpointSpec.java
@@ -16,11 +16,10 @@
  */
 package org.apache.isis.core.unittestsupport.soap;
 
-import java.util.function.Supplier;
-
 import javax.annotation.Nullable;
 
 import com.google.common.base.Function;
+import com.google.common.base.Supplier;
 
 public class SoapEndpointSpec {
 


[11/17] isis git commit: ISIS-1296: recreating simpleapp archetype

Posted by da...@apache.org.
ISIS-1296: recreating simpleapp archetype


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

Branch: refs/heads/master
Commit: b06d913e750de0d6404b3fca51c3b0d328f2653a
Parents: 5d3d14b
Author: Dan Haywood <da...@haywood-associates.co.uk>
Authored: Sun Jan 10 15:25:00 2016 +0000
Committer: Dan Haywood <da...@haywood-associates.co.uk>
Committed: Sun Jan 10 15:25:00 2016 +0000

----------------------------------------------------------------------
 example/archetype/simpleapp/pom.xml             |   6 ++--
 .../java/domainapp/dom/simple/SimpleObject.java |   4 +--
 .../main/resources/archetype-resources/pom.xml  |   2 +-
 .../webapp/ide/eclipse/launch/.gitignore        |   8 +----
 ...OTOTYPE-with-fixtures-bypass-security.launch |  22 +++++++++++++
 .../SimpleApp-PROTOTYPE-with-fixtures.launch    |  22 +++++++++++++
 .../eclipse/launch/SimpleApp-PROTOTYPE.launch   |  22 +++++++++++++
 .../ide/eclipse/launch/SimpleApp-SERVER.launch  |  22 +++++++++++++
 ..._PROTOTYPE_with_fixtures-bypass-security.xml |  31 +++++++++++++++++++
 .../SimpleApp_PROTOTYPE_with_fixtures.xml       |  31 +++++++++++++++++++
 .../ide/intellij/launch/SimpleApp_SERVER.xml    |  31 +++++++++++++++++++
 .../launch/SimpleApp__enhance_only_.xml         |   2 +-
 .../src/main/jettyconsole/isis-banner.pdn       | Bin 69658 -> 64162 bytes
 .../src/main/jettyconsole/isis-banner.png       | Bin 30776 -> 27310 bytes
 .../projects/basic/archetype.properties         |   2 +-
 15 files changed, 190 insertions(+), 15 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/isis/blob/b06d913e/example/archetype/simpleapp/pom.xml
----------------------------------------------------------------------
diff --git a/example/archetype/simpleapp/pom.xml b/example/archetype/simpleapp/pom.xml
index aec882a..0a92bc9 100644
--- a/example/archetype/simpleapp/pom.xml
+++ b/example/archetype/simpleapp/pom.xml
@@ -17,11 +17,11 @@
   specific language governing permissions and limitations
   under the License.
 -->
-<project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
+<project xmlns="http://maven.apache.org/POM/4.0.0" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance">
     <modelVersion>4.0.0</modelVersion>
     <groupId>org.apache.isis.archetype</groupId>
     <artifactId>simpleapp-archetype</artifactId>
-    <version>1.12.0-SNAPSHOT</version>
+    <version>1.11.0-SNAPSHOT</version>
     <packaging>maven-archetype</packaging>
     <name>simpleapp-archetype</name>
     <build>
@@ -44,7 +44,7 @@
     <parent>
         <groupId>org.apache.isis.core</groupId>
         <artifactId>isis</artifactId>
-        <version>1.11.0</version>
+        <version>1.11.1</version>
         <relativePath>../../../core/pom.xml</relativePath>
     </parent>
 </project>

http://git-wip-us.apache.org/repos/asf/isis/blob/b06d913e/example/archetype/simpleapp/src/main/resources/archetype-resources/dom/src/main/java/domainapp/dom/simple/SimpleObject.java
----------------------------------------------------------------------
diff --git a/example/archetype/simpleapp/src/main/resources/archetype-resources/dom/src/main/java/domainapp/dom/simple/SimpleObject.java b/example/archetype/simpleapp/src/main/resources/archetype-resources/dom/src/main/java/domainapp/dom/simple/SimpleObject.java
index a5131bc..5137b73 100644
--- a/example/archetype/simpleapp/src/main/resources/archetype-resources/dom/src/main/java/domainapp/dom/simple/SimpleObject.java
+++ b/example/archetype/simpleapp/src/main/resources/archetype-resources/dom/src/main/java/domainapp/dom/simple/SimpleObject.java
@@ -57,11 +57,11 @@ import org.apache.isis.applib.util.ObjectContracts;
         @javax.jdo.annotations.Query(
                 name = "find", language = "JDOQL",
                 value = "SELECT "
-                        + "FROM domainapp.dom.modules.simple.SimpleObject "),
+                        + "FROM domainapp.dom.simple.SimpleObject "),
         @javax.jdo.annotations.Query(
                 name = "findByName", language = "JDOQL",
                 value = "SELECT "
-                        + "FROM domainapp.dom.modules.simple.SimpleObject "
+                        + "FROM domainapp.dom.simple.SimpleObject "
                         + "WHERE name.indexOf(:name) >= 0 ")
 })
 @javax.jdo.annotations.Unique(name="SimpleObject_name_UNQ", members = {"name"})

http://git-wip-us.apache.org/repos/asf/isis/blob/b06d913e/example/archetype/simpleapp/src/main/resources/archetype-resources/pom.xml
----------------------------------------------------------------------
diff --git a/example/archetype/simpleapp/src/main/resources/archetype-resources/pom.xml b/example/archetype/simpleapp/src/main/resources/archetype-resources/pom.xml
index 2de4361..f6c9980 100644
--- a/example/archetype/simpleapp/src/main/resources/archetype-resources/pom.xml
+++ b/example/archetype/simpleapp/src/main/resources/archetype-resources/pom.xml
@@ -32,7 +32,7 @@
     </prerequisites>
 
     <properties>
-        <isis.version>1.11.0</isis.version>
+        <isis.version>1.11.1</isis.version>
 
         <project.build.sourceEncoding>UTF-8</project.build.sourceEncoding>
         <project.reporting.outputEncoding>UTF-8</project.reporting.outputEncoding>

http://git-wip-us.apache.org/repos/asf/isis/blob/b06d913e/example/archetype/simpleapp/src/main/resources/archetype-resources/webapp/ide/eclipse/launch/.gitignore
----------------------------------------------------------------------
diff --git a/example/archetype/simpleapp/src/main/resources/archetype-resources/webapp/ide/eclipse/launch/.gitignore b/example/archetype/simpleapp/src/main/resources/archetype-resources/webapp/ide/eclipse/launch/.gitignore
index 3d97345..1d44fd4 100644
--- a/example/archetype/simpleapp/src/main/resources/archetype-resources/webapp/ide/eclipse/launch/.gitignore
+++ b/example/archetype/simpleapp/src/main/resources/archetype-resources/webapp/ide/eclipse/launch/.gitignore
@@ -1,8 +1,2 @@
 /SimpleApp-PROTOTYPE-jrebel.launch
-/SimpleApp-PROTOTYPE-no-fixtures.launch
-/SimpleApp-PROTOTYPE-with-fixtures.launch
-/SimpleApp-SERVER-no-fixtures.launch
-/SimpleApp-PROTOTYPE-jrebel.launch
-/SimpleApp-PROTOTYPE-no-fixtures.launch
-/SimpleApp-PROTOTYPE-with-fixtures.launch
-/SimpleApp-SERVER-no-fixtures.launch
+/SimpleApp-jrebel.launch

http://git-wip-us.apache.org/repos/asf/isis/blob/b06d913e/example/archetype/simpleapp/src/main/resources/archetype-resources/webapp/ide/eclipse/launch/SimpleApp-PROTOTYPE-with-fixtures-bypass-security.launch
----------------------------------------------------------------------
diff --git a/example/archetype/simpleapp/src/main/resources/archetype-resources/webapp/ide/eclipse/launch/SimpleApp-PROTOTYPE-with-fixtures-bypass-security.launch b/example/archetype/simpleapp/src/main/resources/archetype-resources/webapp/ide/eclipse/launch/SimpleApp-PROTOTYPE-with-fixtures-bypass-security.launch
new file mode 100644
index 0000000..8c3762b
--- /dev/null
+++ b/example/archetype/simpleapp/src/main/resources/archetype-resources/webapp/ide/eclipse/launch/SimpleApp-PROTOTYPE-with-fixtures-bypass-security.launch
@@ -0,0 +1,22 @@
+#set( $symbol_pound = '#' )
+#set( $symbol_dollar = '$' )
+#set( $symbol_escape = '\' )
+<?xml version="1.0" encoding="UTF-8"?><launchConfiguration type="org.eclipse.jdt.launching.localJavaApplication">
+  <listAttribute key="org.eclipse.debug.core.MAPPED_RESOURCE_PATHS">
+    <listEntry value="/isis-core-webserver/src/main/java/org/apache/isis/WebServer.java"/>
+  </listAttribute>
+  <listAttribute key="org.eclipse.debug.core.MAPPED_RESOURCE_TYPES">
+    <listEntry value="1"/>
+  </listAttribute>
+  <mapAttribute key="org.eclipse.debug.core.preferred_launchers">
+    <mapEntry value="org.eclipse.jdt.launching.localJavaApplication" key="[debug]"/>
+    <mapEntry value="org.eclipse.jdt.launching.localJavaApplication" key="[run]"/>
+  </mapAttribute>
+  <stringAttribute value="org.eclipse.jdt.launching.sourceLocator.JavaSourceLookupDirector" key="org.eclipse.debug.core.source_locator_id"/>
+  <booleanAttribute value="true" key="org.eclipse.jdt.debug.ui.INCLUDE_EXTERNAL_JARS"/>
+  <stringAttribute value="org.eclipse.m2e.launchconfig.classpathProvider" key="org.eclipse.jdt.launching.CLASSPATH_PROVIDER"/>
+  <stringAttribute value="org.apache.isis.WebServer" key="org.eclipse.jdt.launching.MAIN_TYPE"/>
+  <stringAttribute value="--type SERVER_PROTOTYPE --port 8080 --manifest domainapp.app.DomainAppAppManifestWithFixturesBypassSecurity" key="org.eclipse.jdt.launching.PROGRAM_ARGUMENTS"/>
+  <stringAttribute value="${rootArtifactId}-webapp" key="org.eclipse.jdt.launching.PROJECT_ATTR"/>
+  <stringAttribute value="org.eclipse.m2e.launchconfig.sourcepathProvider" key="org.eclipse.jdt.launching.SOURCE_PATH_PROVIDER"/>
+</launchConfiguration>

http://git-wip-us.apache.org/repos/asf/isis/blob/b06d913e/example/archetype/simpleapp/src/main/resources/archetype-resources/webapp/ide/eclipse/launch/SimpleApp-PROTOTYPE-with-fixtures.launch
----------------------------------------------------------------------
diff --git a/example/archetype/simpleapp/src/main/resources/archetype-resources/webapp/ide/eclipse/launch/SimpleApp-PROTOTYPE-with-fixtures.launch b/example/archetype/simpleapp/src/main/resources/archetype-resources/webapp/ide/eclipse/launch/SimpleApp-PROTOTYPE-with-fixtures.launch
new file mode 100644
index 0000000..21c8952
--- /dev/null
+++ b/example/archetype/simpleapp/src/main/resources/archetype-resources/webapp/ide/eclipse/launch/SimpleApp-PROTOTYPE-with-fixtures.launch
@@ -0,0 +1,22 @@
+#set( $symbol_pound = '#' )
+#set( $symbol_dollar = '$' )
+#set( $symbol_escape = '\' )
+<?xml version="1.0" encoding="UTF-8"?><launchConfiguration type="org.eclipse.jdt.launching.localJavaApplication">
+  <listAttribute key="org.eclipse.debug.core.MAPPED_RESOURCE_PATHS">
+    <listEntry value="/isis-core-webserver/src/main/java/org/apache/isis/WebServer.java"/>
+  </listAttribute>
+  <listAttribute key="org.eclipse.debug.core.MAPPED_RESOURCE_TYPES">
+    <listEntry value="1"/>
+  </listAttribute>
+  <mapAttribute key="org.eclipse.debug.core.preferred_launchers">
+    <mapEntry value="org.eclipse.jdt.launching.localJavaApplication" key="[debug]"/>
+    <mapEntry value="org.eclipse.jdt.launching.localJavaApplication" key="[run]"/>
+  </mapAttribute>
+  <stringAttribute value="org.eclipse.jdt.launching.sourceLocator.JavaSourceLookupDirector" key="org.eclipse.debug.core.source_locator_id"/>
+  <booleanAttribute value="true" key="org.eclipse.jdt.debug.ui.INCLUDE_EXTERNAL_JARS"/>
+  <stringAttribute value="org.eclipse.m2e.launchconfig.classpathProvider" key="org.eclipse.jdt.launching.CLASSPATH_PROVIDER"/>
+  <stringAttribute value="org.apache.isis.WebServer" key="org.eclipse.jdt.launching.MAIN_TYPE"/>
+  <stringAttribute value="--type SERVER_PROTOTYPE --port 8080 --manifest domainapp.app.DomainAppAppManifestWithFixtures" key="org.eclipse.jdt.launching.PROGRAM_ARGUMENTS"/>
+  <stringAttribute value="${rootArtifactId}-webapp" key="org.eclipse.jdt.launching.PROJECT_ATTR"/>
+  <stringAttribute value="org.eclipse.m2e.launchconfig.sourcepathProvider" key="org.eclipse.jdt.launching.SOURCE_PATH_PROVIDER"/>
+</launchConfiguration>

http://git-wip-us.apache.org/repos/asf/isis/blob/b06d913e/example/archetype/simpleapp/src/main/resources/archetype-resources/webapp/ide/eclipse/launch/SimpleApp-PROTOTYPE.launch
----------------------------------------------------------------------
diff --git a/example/archetype/simpleapp/src/main/resources/archetype-resources/webapp/ide/eclipse/launch/SimpleApp-PROTOTYPE.launch b/example/archetype/simpleapp/src/main/resources/archetype-resources/webapp/ide/eclipse/launch/SimpleApp-PROTOTYPE.launch
new file mode 100644
index 0000000..4afaada
--- /dev/null
+++ b/example/archetype/simpleapp/src/main/resources/archetype-resources/webapp/ide/eclipse/launch/SimpleApp-PROTOTYPE.launch
@@ -0,0 +1,22 @@
+#set( $symbol_pound = '#' )
+#set( $symbol_dollar = '$' )
+#set( $symbol_escape = '\' )
+<?xml version="1.0" encoding="UTF-8"?><launchConfiguration type="org.eclipse.jdt.launching.localJavaApplication">
+  <listAttribute key="org.eclipse.debug.core.MAPPED_RESOURCE_PATHS">
+    <listEntry value="/isis-core-webserver/src/main/java/org/apache/isis/WebServer.java"/>
+  </listAttribute>
+  <listAttribute key="org.eclipse.debug.core.MAPPED_RESOURCE_TYPES">
+    <listEntry value="1"/>
+  </listAttribute>
+  <mapAttribute key="org.eclipse.debug.core.preferred_launchers">
+    <mapEntry value="org.eclipse.jdt.launching.localJavaApplication" key="[debug]"/>
+    <mapEntry value="org.eclipse.jdt.launching.localJavaApplication" key="[run]"/>
+  </mapAttribute>
+  <stringAttribute value="org.eclipse.jdt.launching.sourceLocator.JavaSourceLookupDirector" key="org.eclipse.debug.core.source_locator_id"/>
+  <booleanAttribute value="true" key="org.eclipse.jdt.debug.ui.INCLUDE_EXTERNAL_JARS"/>
+  <stringAttribute value="org.eclipse.m2e.launchconfig.classpathProvider" key="org.eclipse.jdt.launching.CLASSPATH_PROVIDER"/>
+  <stringAttribute value="org.apache.isis.WebServer" key="org.eclipse.jdt.launching.MAIN_TYPE"/>
+  <stringAttribute value="--type SERVER_PROTOTYPE --port 8080" key="org.eclipse.jdt.launching.PROGRAM_ARGUMENTS"/>
+  <stringAttribute value="${rootArtifactId}-webapp" key="org.eclipse.jdt.launching.PROJECT_ATTR"/>
+  <stringAttribute value="org.eclipse.m2e.launchconfig.sourcepathProvider" key="org.eclipse.jdt.launching.SOURCE_PATH_PROVIDER"/>
+</launchConfiguration>

http://git-wip-us.apache.org/repos/asf/isis/blob/b06d913e/example/archetype/simpleapp/src/main/resources/archetype-resources/webapp/ide/eclipse/launch/SimpleApp-SERVER.launch
----------------------------------------------------------------------
diff --git a/example/archetype/simpleapp/src/main/resources/archetype-resources/webapp/ide/eclipse/launch/SimpleApp-SERVER.launch b/example/archetype/simpleapp/src/main/resources/archetype-resources/webapp/ide/eclipse/launch/SimpleApp-SERVER.launch
new file mode 100644
index 0000000..8473bf3
--- /dev/null
+++ b/example/archetype/simpleapp/src/main/resources/archetype-resources/webapp/ide/eclipse/launch/SimpleApp-SERVER.launch
@@ -0,0 +1,22 @@
+#set( $symbol_pound = '#' )
+#set( $symbol_dollar = '$' )
+#set( $symbol_escape = '\' )
+<?xml version="1.0" encoding="UTF-8"?><launchConfiguration type="org.eclipse.jdt.launching.localJavaApplication">
+  <listAttribute key="org.eclipse.debug.core.MAPPED_RESOURCE_PATHS">
+    <listEntry value="/isis-core-webserver/src/main/java/org/apache/isis/WebServer.java"/>
+  </listAttribute>
+  <listAttribute key="org.eclipse.debug.core.MAPPED_RESOURCE_TYPES">
+    <listEntry value="1"/>
+  </listAttribute>
+  <mapAttribute key="org.eclipse.debug.core.preferred_launchers">
+    <mapEntry value="org.eclipse.jdt.launching.localJavaApplication" key="[debug]"/>
+    <mapEntry value="org.eclipse.jdt.launching.localJavaApplication" key="[run]"/>
+  </mapAttribute>
+  <stringAttribute value="org.eclipse.jdt.launching.sourceLocator.JavaSourceLookupDirector" key="org.eclipse.debug.core.source_locator_id"/>
+  <booleanAttribute value="true" key="org.eclipse.jdt.debug.ui.INCLUDE_EXTERNAL_JARS"/>
+  <stringAttribute value="org.eclipse.m2e.launchconfig.classpathProvider" key="org.eclipse.jdt.launching.CLASSPATH_PROVIDER"/>
+  <stringAttribute value="org.apache.isis.WebServer" key="org.eclipse.jdt.launching.MAIN_TYPE"/>
+  <stringAttribute value="--type SERVER --port 8080" key="org.eclipse.jdt.launching.PROGRAM_ARGUMENTS"/>
+  <stringAttribute value="${rootArtifactId}-webapp" key="org.eclipse.jdt.launching.PROJECT_ATTR"/>
+  <stringAttribute value="org.eclipse.m2e.launchconfig.sourcepathProvider" key="org.eclipse.jdt.launching.SOURCE_PATH_PROVIDER"/>
+</launchConfiguration>

http://git-wip-us.apache.org/repos/asf/isis/blob/b06d913e/example/archetype/simpleapp/src/main/resources/archetype-resources/webapp/ide/intellij/launch/SimpleApp_PROTOTYPE_with_fixtures-bypass-security.xml
----------------------------------------------------------------------
diff --git a/example/archetype/simpleapp/src/main/resources/archetype-resources/webapp/ide/intellij/launch/SimpleApp_PROTOTYPE_with_fixtures-bypass-security.xml b/example/archetype/simpleapp/src/main/resources/archetype-resources/webapp/ide/intellij/launch/SimpleApp_PROTOTYPE_with_fixtures-bypass-security.xml
new file mode 100644
index 0000000..ad2c12e
--- /dev/null
+++ b/example/archetype/simpleapp/src/main/resources/archetype-resources/webapp/ide/intellij/launch/SimpleApp_PROTOTYPE_with_fixtures-bypass-security.xml
@@ -0,0 +1,31 @@
+#set( $symbol_pound = '#' )
+#set( $symbol_dollar = '$' )
+#set( $symbol_escape = '\' )
+<component name="ProjectRunConfigurationManager">
+  <configuration default="false" name="SimpleApp-PROTOTYPE (domainapp.app.DomainAppAppManifestWithFixturesBypassSecurity)" type="Application" factoryName="Application" singleton="true">
+    <extension name="coverage" enabled="false" merge="false" sample_coverage="true" runner="idea" />
+    <option name="MAIN_CLASS_NAME" value="org.apache.isis.WebServer" />
+    <option name="VM_PARAMETERS" value="" />
+    <option name="PROGRAM_PARAMETERS" value="--type SERVER_PROTOTYPE --port 8080 --manifest domainapp.app.DomainAppAppManifestWithFixturesBypassSecurity" />
+    <option name="WORKING_DIRECTORY" value="file://${symbol_dollar}MODULE_DIR${symbol_dollar}" />
+    <option name="ALTERNATIVE_JRE_PATH_ENABLED" value="false" />
+    <option name="ALTERNATIVE_JRE_PATH" value="" />
+    <option name="ENABLE_SWING_INSPECTOR" value="false" />
+    <option name="ENV_VARIABLES" />
+    <option name="PASS_PARENT_ENVS" value="true" />
+    <module name="${parentArtifactId}-webapp" />
+    <envs />
+    <RunnerSettings RunnerId="Debug">
+      <option name="DEBUG_PORT" value="" />
+      <option name="TRANSPORT" value="0" />
+      <option name="LOCAL" value="true" />
+    </RunnerSettings>
+    <RunnerSettings RunnerId="Run" />
+    <ConfigurationWrapper RunnerId="Debug" />
+    <ConfigurationWrapper RunnerId="Run" />
+    <method>
+      <option name="Make" enabled="false" />
+      <option name="Maven.BeforeRunTask" enabled="true" file="C:/Apache/Isis/example/application/${parentArtifactId}/dom/pom.xml" goal="datanucleus:enhance -o" />
+    </method>
+  </configuration>
+</component>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/isis/blob/b06d913e/example/archetype/simpleapp/src/main/resources/archetype-resources/webapp/ide/intellij/launch/SimpleApp_PROTOTYPE_with_fixtures.xml
----------------------------------------------------------------------
diff --git a/example/archetype/simpleapp/src/main/resources/archetype-resources/webapp/ide/intellij/launch/SimpleApp_PROTOTYPE_with_fixtures.xml b/example/archetype/simpleapp/src/main/resources/archetype-resources/webapp/ide/intellij/launch/SimpleApp_PROTOTYPE_with_fixtures.xml
new file mode 100644
index 0000000..fce6a52
--- /dev/null
+++ b/example/archetype/simpleapp/src/main/resources/archetype-resources/webapp/ide/intellij/launch/SimpleApp_PROTOTYPE_with_fixtures.xml
@@ -0,0 +1,31 @@
+#set( $symbol_pound = '#' )
+#set( $symbol_dollar = '$' )
+#set( $symbol_escape = '\' )
+<component name="ProjectRunConfigurationManager">
+  <configuration default="false" name="SimpleApp-PROTOTYPE (domainapp.app.DomainAppAppManifestWithFixtures)" type="Application" factoryName="Application" singleton="true">
+    <extension name="coverage" enabled="false" merge="false" sample_coverage="true" runner="idea" />
+    <option name="MAIN_CLASS_NAME" value="org.apache.isis.WebServer" />
+    <option name="VM_PARAMETERS" value="" />
+    <option name="PROGRAM_PARAMETERS" value="--type SERVER_PROTOTYPE --port 8080 --manifest domainapp.app.DomainAppAppManifestWithFixtures" />
+    <option name="WORKING_DIRECTORY" value="file://${symbol_dollar}MODULE_DIR${symbol_dollar}" />
+    <option name="ALTERNATIVE_JRE_PATH_ENABLED" value="false" />
+    <option name="ALTERNATIVE_JRE_PATH" value="" />
+    <option name="ENABLE_SWING_INSPECTOR" value="false" />
+    <option name="ENV_VARIABLES" />
+    <option name="PASS_PARENT_ENVS" value="true" />
+    <module name="${parentArtifactId}-webapp" />
+    <envs />
+    <RunnerSettings RunnerId="Debug">
+      <option name="DEBUG_PORT" value="" />
+      <option name="TRANSPORT" value="0" />
+      <option name="LOCAL" value="true" />
+    </RunnerSettings>
+    <RunnerSettings RunnerId="Run" />
+    <ConfigurationWrapper RunnerId="Debug" />
+    <ConfigurationWrapper RunnerId="Run" />
+    <method>
+      <option name="Make" enabled="false" />
+      <option name="Maven.BeforeRunTask" enabled="true" file="C:/Apache/Isis/example/application/${parentArtifactId}/dom/pom.xml" goal="datanucleus:enhance -o" />
+    </method>
+  </configuration>
+</component>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/isis/blob/b06d913e/example/archetype/simpleapp/src/main/resources/archetype-resources/webapp/ide/intellij/launch/SimpleApp_SERVER.xml
----------------------------------------------------------------------
diff --git a/example/archetype/simpleapp/src/main/resources/archetype-resources/webapp/ide/intellij/launch/SimpleApp_SERVER.xml b/example/archetype/simpleapp/src/main/resources/archetype-resources/webapp/ide/intellij/launch/SimpleApp_SERVER.xml
new file mode 100644
index 0000000..d2bb8d2
--- /dev/null
+++ b/example/archetype/simpleapp/src/main/resources/archetype-resources/webapp/ide/intellij/launch/SimpleApp_SERVER.xml
@@ -0,0 +1,31 @@
+#set( $symbol_pound = '#' )
+#set( $symbol_dollar = '$' )
+#set( $symbol_escape = '\' )
+<component name="ProjectRunConfigurationManager">
+  <configuration default="false" name="SimpleApp-SERVER" type="Application" factoryName="Application" singleton="true">
+    <extension name="coverage" enabled="false" merge="false" sample_coverage="true" runner="idea" />
+    <option name="MAIN_CLASS_NAME" value="org.apache.isis.WebServer" />
+    <option name="VM_PARAMETERS" value="" />
+    <option name="PROGRAM_PARAMETERS" value="--type SERVER --port 8080" />
+    <option name="WORKING_DIRECTORY" value="file://${symbol_dollar}MODULE_DIR${symbol_dollar}" />
+    <option name="ALTERNATIVE_JRE_PATH_ENABLED" value="false" />
+    <option name="ALTERNATIVE_JRE_PATH" value="" />
+    <option name="ENABLE_SWING_INSPECTOR" value="false" />
+    <option name="ENV_VARIABLES" />
+    <option name="PASS_PARENT_ENVS" value="true" />
+    <module name="${parentArtifactId}-webapp" />
+    <envs />
+    <RunnerSettings RunnerId="Debug">
+      <option name="DEBUG_PORT" value="" />
+      <option name="TRANSPORT" value="0" />
+      <option name="LOCAL" value="true" />
+    </RunnerSettings>
+    <RunnerSettings RunnerId="Run" />
+    <ConfigurationWrapper RunnerId="Debug" />
+    <ConfigurationWrapper RunnerId="Run" />
+    <method>
+      <option name="Make" enabled="false" />
+      <option name="Maven.BeforeRunTask" enabled="true" file="C:/Apache/Isis/example/application/${parentArtifactId}/dom/pom.xml" goal="datanucleus:enhance -o" />
+    </method>
+  </configuration>
+</component>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/isis/blob/b06d913e/example/archetype/simpleapp/src/main/resources/archetype-resources/webapp/ide/intellij/launch/SimpleApp__enhance_only_.xml
----------------------------------------------------------------------
diff --git a/example/archetype/simpleapp/src/main/resources/archetype-resources/webapp/ide/intellij/launch/SimpleApp__enhance_only_.xml b/example/archetype/simpleapp/src/main/resources/archetype-resources/webapp/ide/intellij/launch/SimpleApp__enhance_only_.xml
index cc13dea..38d337c 100644
--- a/example/archetype/simpleapp/src/main/resources/archetype-resources/webapp/ide/intellij/launch/SimpleApp__enhance_only_.xml
+++ b/example/archetype/simpleapp/src/main/resources/archetype-resources/webapp/ide/intellij/launch/SimpleApp__enhance_only_.xml
@@ -2,7 +2,7 @@
 #set( $symbol_dollar = '$' )
 #set( $symbol_escape = '\' )
 <component name="ProjectRunConfigurationManager">
-s  <configuration default="false" name="SimpleApp (enhance only)" type="Application" factoryName="Application">
+  <configuration default="false" name="SimpleApp (enhance only)" type="Application" factoryName="Application">
     <extension name="coverage" enabled="false" merge="false" sample_coverage="true" runner="idea" />
     <option name="MAIN_CLASS_NAME" value="org.apache.isis.Dummy" />
     <option name="VM_PARAMETERS" value="" />

http://git-wip-us.apache.org/repos/asf/isis/blob/b06d913e/example/archetype/simpleapp/src/main/resources/archetype-resources/webapp/src/main/jettyconsole/isis-banner.pdn
----------------------------------------------------------------------
diff --git a/example/archetype/simpleapp/src/main/resources/archetype-resources/webapp/src/main/jettyconsole/isis-banner.pdn b/example/archetype/simpleapp/src/main/resources/archetype-resources/webapp/src/main/jettyconsole/isis-banner.pdn
index 37543c9..43a53e6 100644
Binary files a/example/archetype/simpleapp/src/main/resources/archetype-resources/webapp/src/main/jettyconsole/isis-banner.pdn and b/example/archetype/simpleapp/src/main/resources/archetype-resources/webapp/src/main/jettyconsole/isis-banner.pdn differ

http://git-wip-us.apache.org/repos/asf/isis/blob/b06d913e/example/archetype/simpleapp/src/main/resources/archetype-resources/webapp/src/main/jettyconsole/isis-banner.png
----------------------------------------------------------------------
diff --git a/example/archetype/simpleapp/src/main/resources/archetype-resources/webapp/src/main/jettyconsole/isis-banner.png b/example/archetype/simpleapp/src/main/resources/archetype-resources/webapp/src/main/jettyconsole/isis-banner.png
index cd9ecfe..cf10bef 100644
Binary files a/example/archetype/simpleapp/src/main/resources/archetype-resources/webapp/src/main/jettyconsole/isis-banner.png and b/example/archetype/simpleapp/src/main/resources/archetype-resources/webapp/src/main/jettyconsole/isis-banner.png differ

http://git-wip-us.apache.org/repos/asf/isis/blob/b06d913e/example/archetype/simpleapp/src/test/resources/projects/basic/archetype.properties
----------------------------------------------------------------------
diff --git a/example/archetype/simpleapp/src/test/resources/projects/basic/archetype.properties b/example/archetype/simpleapp/src/test/resources/projects/basic/archetype.properties
index 24a32b3..dd5ee5c 100644
--- a/example/archetype/simpleapp/src/test/resources/projects/basic/archetype.properties
+++ b/example/archetype/simpleapp/src/test/resources/projects/basic/archetype.properties
@@ -1,4 +1,4 @@
-#Tue Dec 29 13:00:20 GMT 2015
+#Sun Jan 10 15:24:45 GMT 2016
 package=it.pkg
 version=0.1-SNAPSHOT
 groupId=archetype.it


[16/17] isis git commit: ISIS-1296: merging in 1.11.1-RC1 branch, fixing conflict

Posted by da...@apache.org.
ISIS-1296: merging in 1.11.1-RC1 branch, fixing conflict


Project: http://git-wip-us.apache.org/repos/asf/isis/repo
Commit: http://git-wip-us.apache.org/repos/asf/isis/commit/8812424a
Tree: http://git-wip-us.apache.org/repos/asf/isis/tree/8812424a
Diff: http://git-wip-us.apache.org/repos/asf/isis/diff/8812424a

Branch: refs/heads/master
Commit: 8812424a472b4e679417566f4aaeae907184caa1
Parents: 78bd18e 006f98a
Author: Dan Haywood <da...@haywood-associates.co.uk>
Authored: Sun Jan 17 15:06:26 2016 +0000
Committer: Dan Haywood <da...@haywood-associates.co.uk>
Committed: Sun Jan 17 15:06:26 2016 +0000

----------------------------------------------------------------------
 .../isis/core/metamodel/facets/Annotations.java |   2 +-
 .../container/DomainObjectContainerDefault.java |   2 +-
 core/pom.xml                                    |  25 ++++++++++++++-
 .../unittestsupport/soap/SoapEndpointSpec.java  |   3 +-
 .../java/domainapp/dom/simple/SimpleObject.java |   4 +--
 .../webapp/ide/eclipse/launch/.gitignore        |   8 +----
 .../ide/eclipse/launch/SimpleApp-JREBEL.launch  |  31 +++++++++++++++++++
 .../launch/SimpleApp-PROTOTYPE-jrebel.launch    |  31 -------------------
 .../SimpleApp-PROTOTYPE-no-fixtures.launch      |  23 --------------
 ...OTOTYPE-with-fixtures-bypass-security.launch |  20 ++++++++++++
 .../SimpleApp-PROTOTYPE-with-fixtures.launch    |   2 +-
 .../eclipse/launch/SimpleApp-PROTOTYPE.launch   |  20 ++++++++++++
 .../launch/SimpleApp-SERVER-no-fixtures.launch  |  23 --------------
 .../ide/eclipse/launch/SimpleApp-SERVER.launch  |  20 ++++++++++++
 ..._PROTOTYPE_with_fixtures-bypass-security.xml |  28 +++++++++++++++++
 .../SimpleApp_PROTOTYPE_with_fixtures.xml       |  28 +++++++++++++++++
 .../ide/intellij/launch/SimpleApp_SERVER.xml    |  28 +++++++++++++++++
 .../launch/SimpleApp__enhance_only_.xml         |   2 +-
 .../src/main/jettyconsole/isis-banner.pdn       | Bin 69658 -> 64162 bytes
 .../src/main/jettyconsole/isis-banner.png       | Bin 30776 -> 27310 bytes
 example/archetype/simpleapp/pom.xml             |   2 +-
 .../java/domainapp/dom/simple/SimpleObject.java |   4 +--
 .../main/resources/archetype-resources/pom.xml  |   2 +-
 .../webapp/ide/eclipse/launch/.gitignore        |   8 +----
 ...OTOTYPE-with-fixtures-bypass-security.launch |  22 +++++++++++++
 .../SimpleApp-PROTOTYPE-with-fixtures.launch    |  22 +++++++++++++
 .../eclipse/launch/SimpleApp-PROTOTYPE.launch   |  22 +++++++++++++
 .../ide/eclipse/launch/SimpleApp-SERVER.launch  |  22 +++++++++++++
 ..._PROTOTYPE_with_fixtures-bypass-security.xml |  31 +++++++++++++++++++
 .../SimpleApp_PROTOTYPE_with_fixtures.xml       |  31 +++++++++++++++++++
 .../ide/intellij/launch/SimpleApp_SERVER.xml    |  31 +++++++++++++++++++
 .../launch/SimpleApp__enhance_only_.xml         |   2 +-
 .../src/main/jettyconsole/isis-banner.pdn       | Bin 69658 -> 64162 bytes
 .../src/main/jettyconsole/isis-banner.png       | Bin 30776 -> 27310 bytes
 .../projects/basic/archetype.properties         |   2 +-
 35 files changed, 395 insertions(+), 106 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/isis/blob/8812424a/core/pom.xml
----------------------------------------------------------------------


[06/17] isis git commit: [maven-release-plugin] prepare release isis-1.11.1

Posted by da...@apache.org.
[maven-release-plugin] prepare release isis-1.11.1


Project: http://git-wip-us.apache.org/repos/asf/isis/repo
Commit: http://git-wip-us.apache.org/repos/asf/isis/commit/7c2621ad
Tree: http://git-wip-us.apache.org/repos/asf/isis/tree/7c2621ad
Diff: http://git-wip-us.apache.org/repos/asf/isis/diff/7c2621ad

Branch: refs/heads/master
Commit: 7c2621ade86f7e03c5a1c115e7685c26f4e67393
Parents: dad0908
Author: Dan Haywood <da...@haywood-associates.co.uk>
Authored: Sun Jan 10 14:09:15 2016 +0000
Committer: Dan Haywood <da...@haywood-associates.co.uk>
Committed: Sun Jan 10 14:09:15 2016 +0000

----------------------------------------------------------------------
 core/applib/pom.xml                          |  2 +-
 core/integtestsupport/pom.xml                |  2 +-
 core/log4j/pom.xml                           |  2 +-
 core/maven-plugin/pom.xml                    |  2 +-
 core/metamodel/pom.xml                       |  2 +-
 core/pom.xml                                 | 66 +++++++++++------------
 core/runtime/pom.xml                         |  2 +-
 core/schema/pom.xml                          |  2 +-
 core/security-shiro/pom.xml                  |  6 +--
 core/security/pom.xml                        |  2 +-
 core/specsupport/pom.xml                     |  2 +-
 core/unittestsupport/pom.xml                 |  2 +-
 core/viewer-restfulobjects-applib/pom.xml    |  2 +-
 core/viewer-restfulobjects-rendering/pom.xml |  2 +-
 core/viewer-restfulobjects-server/pom.xml    |  2 +-
 core/viewer-wicket-applib/pom.xml            |  2 +-
 core/viewer-wicket-impl/pom.xml              |  2 +-
 core/viewer-wicket-model/pom.xml             |  2 +-
 core/viewer-wicket-ui/pom.xml                |  2 +-
 core/webserver/pom.xml                       |  2 +-
 core/wrapper/pom.xml                         |  2 +-
 21 files changed, 55 insertions(+), 55 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/isis/blob/7c2621ad/core/applib/pom.xml
----------------------------------------------------------------------
diff --git a/core/applib/pom.xml b/core/applib/pom.xml
index 757908c..0c7fc02 100644
--- a/core/applib/pom.xml
+++ b/core/applib/pom.xml
@@ -23,7 +23,7 @@
     <parent>
         <groupId>org.apache.isis.core</groupId>
         <artifactId>isis</artifactId>
-        <version>1.12.0-SNAPSHOT</version>
+        <version>1.11.1</version>
     </parent>
 
     <artifactId>isis-core-applib</artifactId>

http://git-wip-us.apache.org/repos/asf/isis/blob/7c2621ad/core/integtestsupport/pom.xml
----------------------------------------------------------------------
diff --git a/core/integtestsupport/pom.xml b/core/integtestsupport/pom.xml
index 8491f67..3da7ac6 100644
--- a/core/integtestsupport/pom.xml
+++ b/core/integtestsupport/pom.xml
@@ -23,7 +23,7 @@
 	<parent>
 		<groupId>org.apache.isis.core</groupId>
 		<artifactId>isis</artifactId>
-        <version>1.12.0-SNAPSHOT</version>
+        <version>1.11.1</version>
 	</parent>
 
 	<artifactId>isis-core-integtestsupport</artifactId>

http://git-wip-us.apache.org/repos/asf/isis/blob/7c2621ad/core/log4j/pom.xml
----------------------------------------------------------------------
diff --git a/core/log4j/pom.xml b/core/log4j/pom.xml
index 4a029c1..1ef669f 100644
--- a/core/log4j/pom.xml
+++ b/core/log4j/pom.xml
@@ -15,7 +15,7 @@
     <parent>
         <groupId>org.apache.isis.core</groupId>
         <artifactId>isis</artifactId>
-        <version>1.12.0-SNAPSHOT</version>
+        <version>1.11.1</version>
     </parent>
 
     <artifactId>isis-core-log4j</artifactId>

http://git-wip-us.apache.org/repos/asf/isis/blob/7c2621ad/core/maven-plugin/pom.xml
----------------------------------------------------------------------
diff --git a/core/maven-plugin/pom.xml b/core/maven-plugin/pom.xml
index 4456432..d0a38ce 100644
--- a/core/maven-plugin/pom.xml
+++ b/core/maven-plugin/pom.xml
@@ -23,7 +23,7 @@
     <parent>
         <groupId>org.apache.isis.core</groupId>
         <artifactId>isis</artifactId>
-        <version>1.12.0-SNAPSHOT</version>
+        <version>1.11.1</version>
     </parent>
 
     <groupId>org.apache.isis.tool</groupId>

http://git-wip-us.apache.org/repos/asf/isis/blob/7c2621ad/core/metamodel/pom.xml
----------------------------------------------------------------------
diff --git a/core/metamodel/pom.xml b/core/metamodel/pom.xml
index 493c298..b7e6b59 100644
--- a/core/metamodel/pom.xml
+++ b/core/metamodel/pom.xml
@@ -23,7 +23,7 @@
     <parent>
         <groupId>org.apache.isis.core</groupId>
         <artifactId>isis</artifactId>
-        <version>1.12.0-SNAPSHOT</version>
+        <version>1.11.1</version>
     </parent>
 
     <artifactId>isis-core-metamodel</artifactId>

http://git-wip-us.apache.org/repos/asf/isis/blob/7c2621ad/core/pom.xml
----------------------------------------------------------------------
diff --git a/core/pom.xml b/core/pom.xml
index 5b7de63..b54a9c5 100644
--- a/core/pom.xml
+++ b/core/pom.xml
@@ -29,7 +29,7 @@
 
     <groupId>org.apache.isis.core</groupId>
     <artifactId>isis</artifactId>
-    <version>1.12.0-SNAPSHOT</version>
+    <version>1.11.1</version>
     
     <packaging>pom</packaging>
 
@@ -162,7 +162,7 @@
         <connection>scm:git:http://git.apache.org/isis.git/core</connection>
         <developerConnection>scm:git:https://git-wip-us.apache.org/repos/asf/isis.git/trunk/framework/</developerConnection>
         <url>git://git.apache.org/isis.git/core</url>
-      <tag>HEAD</tag>
+      <tag>isis-1.11.1</tag>
   </scm>
 
     <url>http://isis.apache.org</url>
@@ -1061,13 +1061,13 @@ ${license.additional-notes}
             <dependency>
                 <groupId>org.apache.isis.core</groupId>
                 <artifactId>isis-core-unittestsupport</artifactId>
-                <version>1.12.0-SNAPSHOT</version>
+                <version>1.11.1</version>
                 <!-- not scope=test, because referenced by some sql-tests-common under compile scope -->
             </dependency>
             <dependency>
                 <groupId>org.apache.isis.core</groupId>
                 <artifactId>isis-core-unittestsupport</artifactId>
-                <version>1.12.0-SNAPSHOT</version>
+                <version>1.11.1</version>
                 <type>test-jar</type>
                 <scope>test</scope>
             </dependency>
@@ -1076,14 +1076,14 @@ ${license.additional-notes}
             <dependency>
                 <groupId>org.apache.isis.core</groupId>
                 <artifactId>isis-core-applib</artifactId>
-                <version>1.12.0-SNAPSHOT</version>
+                <version>1.11.1</version>
                 <type>jar</type>
                 <scope>compile</scope>
             </dependency>
             <dependency>
                 <groupId>org.apache.isis.core</groupId>
                 <artifactId>isis-core-applib</artifactId>
-                <version>1.12.0-SNAPSHOT</version>
+                <version>1.11.1</version>
                 <type>test-jar</type>
                 <scope>test</scope>
             </dependency>
@@ -1092,14 +1092,14 @@ ${license.additional-notes}
             <dependency>
                 <groupId>org.apache.isis.core</groupId>
                 <artifactId>isis-core-schema</artifactId>
-                <version>1.12.0-SNAPSHOT</version>
+                <version>1.11.1</version>
                 <type>jar</type>
                 <scope>compile</scope>
             </dependency>
             <dependency>
                 <groupId>org.apache.isis.core</groupId>
                 <artifactId>isis-core-schema</artifactId>
-                <version>1.12.0-SNAPSHOT</version>
+                <version>1.11.1</version>
                 <type>test-jar</type>
                 <scope>test</scope>
             </dependency>
@@ -1108,7 +1108,7 @@ ${license.additional-notes}
             <dependency>
                 <groupId>org.apache.isis.core</groupId>
                 <artifactId>isis-core-log4j</artifactId>
-                <version>1.12.0-SNAPSHOT</version>
+                <version>1.11.1</version>
                 <type>jar</type>
                 <scope>compile</scope>
             </dependency>
@@ -1117,14 +1117,14 @@ ${license.additional-notes}
             <dependency>
                 <groupId>org.apache.isis.core</groupId>
                 <artifactId>isis-core-metamodel</artifactId>
-                <version>1.12.0-SNAPSHOT</version>
+                <version>1.11.1</version>
                 <type>jar</type>
                 <scope>compile</scope>
             </dependency>
             <dependency>
                 <groupId>org.apache.isis.core</groupId>
                 <artifactId>isis-core-metamodel</artifactId>
-                <version>1.12.0-SNAPSHOT</version>
+                <version>1.11.1</version>
                 <type>test-jar</type>
                 <scope>test</scope>
             </dependency>
@@ -1133,40 +1133,40 @@ ${license.additional-notes}
             <dependency>
                 <groupId>org.apache.isis.core</groupId>
                 <artifactId>isis-core-runtime</artifactId>
-                <version>1.12.0-SNAPSHOT</version>
+                <version>1.11.1</version>
             </dependency>
             <dependency>
                 <groupId>org.apache.isis.core</groupId>
                 <artifactId>isis-core-runtime</artifactId>
-                <version>1.12.0-SNAPSHOT</version>
+                <version>1.11.1</version>
                 <type>test-jar</type>
                 <scope>test</scope>
             </dependency>
             <dependency>
                 <groupId>org.apache.isis.core</groupId>
                 <artifactId>isis-core-wrapper</artifactId>
-                <version>1.12.0-SNAPSHOT</version>
+                <version>1.11.1</version>
             </dependency>
 
             <!-- webserver -->
             <dependency>
                 <groupId>org.apache.isis.core</groupId>
                 <artifactId>isis-core-webserver</artifactId>
-                <version>1.12.0-SNAPSHOT</version>
+                <version>1.11.1</version>
             </dependency>
 
             <!-- specsupport -->
             <dependency>
                 <groupId>org.apache.isis.core</groupId>
                 <artifactId>isis-core-specsupport</artifactId>
-                <version>1.12.0-SNAPSHOT</version>
+                <version>1.11.1</version>
             </dependency>
 
             <!-- integtestsupport -->
             <dependency>
                 <groupId>org.apache.isis.core</groupId>
                 <artifactId>isis-core-integtestsupport</artifactId>
-                <version>1.12.0-SNAPSHOT</version>
+                <version>1.11.1</version>
                 <!-- not scope=test, because referenced by some sql-tests-common under compile scope -->
             </dependency>
 
@@ -1174,36 +1174,36 @@ ${license.additional-notes}
             <dependency>
                 <groupId>org.apache.isis.core</groupId>
                 <artifactId>isis-core-viewer-restfulobjects-applib</artifactId>
-                <version>1.12.0-SNAPSHOT</version>
+                <version>1.11.1</version>
             </dependency>
             <dependency>
                 <groupId>org.apache.isis.core</groupId>
                 <artifactId>isis-core-viewer-restfulobjects-applib</artifactId>
-                <version>1.12.0-SNAPSHOT</version>
+                <version>1.11.1</version>
                 <type>test-jar</type>
                 <scope>test</scope>
             </dependency>
             <dependency>
                 <groupId>org.apache.isis.core</groupId>
                 <artifactId>isis-core-viewer-restfulobjects-rendering</artifactId>
-                <version>1.12.0-SNAPSHOT</version>
+                <version>1.11.1</version>
             </dependency>
             <dependency>
                 <groupId>org.apache.isis.core</groupId>
                 <artifactId>isis-core-viewer-restfulobjects-rendering</artifactId>
-                <version>1.12.0-SNAPSHOT</version>
+                <version>1.11.1</version>
                 <type>test-jar</type>
                 <scope>test</scope>
             </dependency>
             <dependency>
                 <groupId>org.apache.isis.core</groupId>
                 <artifactId>isis-core-viewer-restfulobjects-server</artifactId>
-                <version>1.12.0-SNAPSHOT</version>
+                <version>1.11.1</version>
             </dependency>
             <dependency>
                 <groupId>org.apache.isis.core</groupId>
                 <artifactId>isis-core-viewer-restfulobjects-server</artifactId>
-                <version>1.12.0-SNAPSHOT</version>
+                <version>1.11.1</version>
                 <type>test-jar</type>
                 <scope>test</scope>
             </dependency>
@@ -1212,12 +1212,12 @@ ${license.additional-notes}
             <dependency>
                 <groupId>org.apache.isis.core</groupId>
                 <artifactId>isis-core-security</artifactId>
-                <version>1.12.0-SNAPSHOT</version>
+                <version>1.11.1</version>
             </dependency>
             <dependency>
                 <groupId>org.apache.isis.core</groupId>
                 <artifactId>isis-core-security-shiro</artifactId>
-                <version>1.12.0-SNAPSHOT</version>
+                <version>1.11.1</version>
             </dependency>
 
             
@@ -1225,41 +1225,41 @@ ${license.additional-notes}
             <dependency>
                 <groupId>org.apache.isis.viewer</groupId>
                 <artifactId>isis-viewer-wicket-applib</artifactId>
-                <version>1.12.0-SNAPSHOT</version>
+                <version>1.11.1</version>
             </dependency>
             <dependency>
                 <groupId>org.apache.isis.viewer</groupId>
                 <artifactId>isis-viewer-wicket-model</artifactId>
-                <version>1.12.0-SNAPSHOT</version>
+                <version>1.11.1</version>
             </dependency>
             <dependency>
                 <groupId>org.apache.isis.viewer</groupId>
                 <artifactId>isis-viewer-wicket-model</artifactId>
-                <version>1.12.0-SNAPSHOT</version>
+                <version>1.11.1</version>
                 <scope>test</scope>
                 <type>test-jar</type>
             </dependency>
             <dependency>
                 <groupId>org.apache.isis.viewer</groupId>
                 <artifactId>isis-viewer-wicket-ui</artifactId>
-                <version>1.12.0-SNAPSHOT</version>
+                <version>1.11.1</version>
             </dependency>
             <dependency>
                 <groupId>org.apache.isis.viewer</groupId>
                 <artifactId>isis-viewer-wicket-ui</artifactId>
-                <version>1.12.0-SNAPSHOT</version>
+                <version>1.11.1</version>
                 <scope>test</scope>
                 <type>test-jar</type>
             </dependency>
             <dependency>
                 <groupId>org.apache.isis.viewer</groupId>
                 <artifactId>isis-viewer-wicket-impl</artifactId>
-                <version>1.12.0-SNAPSHOT</version>
+                <version>1.11.1</version>
             </dependency>
             <dependency>
                 <groupId>org.apache.isis.viewer</groupId>
                 <artifactId>isis-viewer-wicket-impl</artifactId>
-                <version>1.12.0-SNAPSHOT</version>
+                <version>1.11.1</version>
                 <scope>test</scope>
                 <type>test-jar</type>
             </dependency>
@@ -1269,7 +1269,7 @@ ${license.additional-notes}
             <dependency>
                 <groupId>org.apache.isis.tool</groupId>
                 <artifactId>isis-maven-plugin</artifactId>
-                <version>1.12.0-SNAPSHOT</version>
+                <version>1.11.1</version>
             </dependency>
 
             <!-- JodaTime -->

http://git-wip-us.apache.org/repos/asf/isis/blob/7c2621ad/core/runtime/pom.xml
----------------------------------------------------------------------
diff --git a/core/runtime/pom.xml b/core/runtime/pom.xml
index cacb227..c950886 100644
--- a/core/runtime/pom.xml
+++ b/core/runtime/pom.xml
@@ -23,7 +23,7 @@
 	<parent>
 		<groupId>org.apache.isis.core</groupId>
 		<artifactId>isis</artifactId>
-        <version>1.12.0-SNAPSHOT</version>
+        <version>1.11.1</version>
 	</parent>
 
 	<artifactId>isis-core-runtime</artifactId>

http://git-wip-us.apache.org/repos/asf/isis/blob/7c2621ad/core/schema/pom.xml
----------------------------------------------------------------------
diff --git a/core/schema/pom.xml b/core/schema/pom.xml
index 9bcc078..e864307 100644
--- a/core/schema/pom.xml
+++ b/core/schema/pom.xml
@@ -23,7 +23,7 @@
     <parent>
         <groupId>org.apache.isis.core</groupId>
         <artifactId>isis</artifactId>
-        <version>1.12.0-SNAPSHOT</version>
+        <version>1.11.1</version>
     </parent>
 
     <artifactId>isis-core-schema</artifactId>

http://git-wip-us.apache.org/repos/asf/isis/blob/7c2621ad/core/security-shiro/pom.xml
----------------------------------------------------------------------
diff --git a/core/security-shiro/pom.xml b/core/security-shiro/pom.xml
index 206e8d5..bab1ea0 100644
--- a/core/security-shiro/pom.xml
+++ b/core/security-shiro/pom.xml
@@ -23,12 +23,12 @@
 	<parent>
 		<groupId>org.apache.isis.core</groupId>
 		<artifactId>isis</artifactId>
-        <version>1.12.0-SNAPSHOT</version>
+        <version>1.11.1</version>
 	</parent>
 
 	<groupId>org.apache.isis.core</groupId>
 	<artifactId>isis-core-security-shiro</artifactId>
-    <version>1.12.0-SNAPSHOT</version>
+    <version>1.11.1</version>
 
 	<name>Isis Security Shiro</name>
 
@@ -65,7 +65,7 @@
 			<dependency>
 			    <groupId>org.apache.isis.core</groupId>
 			    <artifactId>isis-core-security-shiro</artifactId>
-				<version>1.12.0-SNAPSHOT</version>
+				<version>1.11.1</version>
 			</dependency>
     	</dependencies>
     </dependencyManagement>

http://git-wip-us.apache.org/repos/asf/isis/blob/7c2621ad/core/security/pom.xml
----------------------------------------------------------------------
diff --git a/core/security/pom.xml b/core/security/pom.xml
index 5464258..5951a70 100644
--- a/core/security/pom.xml
+++ b/core/security/pom.xml
@@ -23,7 +23,7 @@
 	<parent>
 		<groupId>org.apache.isis.core</groupId>
 		<artifactId>isis</artifactId>
-        <version>1.12.0-SNAPSHOT</version>
+        <version>1.11.1</version>
 	</parent>
 
 	<artifactId>isis-core-security</artifactId>

http://git-wip-us.apache.org/repos/asf/isis/blob/7c2621ad/core/specsupport/pom.xml
----------------------------------------------------------------------
diff --git a/core/specsupport/pom.xml b/core/specsupport/pom.xml
index a70b1a7..f8492cf 100644
--- a/core/specsupport/pom.xml
+++ b/core/specsupport/pom.xml
@@ -15,7 +15,7 @@
     <parent>
         <groupId>org.apache.isis.core</groupId>
         <artifactId>isis</artifactId>
-        <version>1.12.0-SNAPSHOT</version>
+        <version>1.11.1</version>
     </parent>
 
     <artifactId>isis-core-specsupport</artifactId>

http://git-wip-us.apache.org/repos/asf/isis/blob/7c2621ad/core/unittestsupport/pom.xml
----------------------------------------------------------------------
diff --git a/core/unittestsupport/pom.xml b/core/unittestsupport/pom.xml
index c9dffa6..71ed875 100644
--- a/core/unittestsupport/pom.xml
+++ b/core/unittestsupport/pom.xml
@@ -23,7 +23,7 @@
 	<parent>
 		<groupId>org.apache.isis.core</groupId>
 		<artifactId>isis</artifactId>
-        <version>1.12.0-SNAPSHOT</version>
+        <version>1.11.1</version>
 	</parent>
 
 	<artifactId>isis-core-unittestsupport</artifactId>

http://git-wip-us.apache.org/repos/asf/isis/blob/7c2621ad/core/viewer-restfulobjects-applib/pom.xml
----------------------------------------------------------------------
diff --git a/core/viewer-restfulobjects-applib/pom.xml b/core/viewer-restfulobjects-applib/pom.xml
index e5d989d..7bdbdd8 100644
--- a/core/viewer-restfulobjects-applib/pom.xml
+++ b/core/viewer-restfulobjects-applib/pom.xml
@@ -23,7 +23,7 @@
     <parent>
         <groupId>org.apache.isis.core</groupId>
         <artifactId>isis</artifactId>
-        <version>1.12.0-SNAPSHOT</version>
+        <version>1.11.1</version>
     </parent>
 
 	<artifactId>isis-core-viewer-restfulobjects-applib</artifactId>

http://git-wip-us.apache.org/repos/asf/isis/blob/7c2621ad/core/viewer-restfulobjects-rendering/pom.xml
----------------------------------------------------------------------
diff --git a/core/viewer-restfulobjects-rendering/pom.xml b/core/viewer-restfulobjects-rendering/pom.xml
index 5184877..37f2cd2 100644
--- a/core/viewer-restfulobjects-rendering/pom.xml
+++ b/core/viewer-restfulobjects-rendering/pom.xml
@@ -23,7 +23,7 @@
     <parent>
         <groupId>org.apache.isis.core</groupId>
         <artifactId>isis</artifactId>
-        <version>1.12.0-SNAPSHOT</version>
+        <version>1.11.1</version>
     </parent>
 
     <artifactId>isis-core-viewer-restfulobjects-rendering</artifactId>

http://git-wip-us.apache.org/repos/asf/isis/blob/7c2621ad/core/viewer-restfulobjects-server/pom.xml
----------------------------------------------------------------------
diff --git a/core/viewer-restfulobjects-server/pom.xml b/core/viewer-restfulobjects-server/pom.xml
index a2bc140..9cdc9c6 100644
--- a/core/viewer-restfulobjects-server/pom.xml
+++ b/core/viewer-restfulobjects-server/pom.xml
@@ -23,7 +23,7 @@
     <parent>
         <groupId>org.apache.isis.core</groupId>
         <artifactId>isis</artifactId>
-        <version>1.12.0-SNAPSHOT</version>
+        <version>1.11.1</version>
     </parent>
 
     <artifactId>isis-core-viewer-restfulobjects-server</artifactId>

http://git-wip-us.apache.org/repos/asf/isis/blob/7c2621ad/core/viewer-wicket-applib/pom.xml
----------------------------------------------------------------------
diff --git a/core/viewer-wicket-applib/pom.xml b/core/viewer-wicket-applib/pom.xml
index 54cb73f..1a2d707 100644
--- a/core/viewer-wicket-applib/pom.xml
+++ b/core/viewer-wicket-applib/pom.xml
@@ -24,7 +24,7 @@
 	<parent>
 		<groupId>org.apache.isis.core</groupId>
 		<artifactId>isis</artifactId>
-		<version>1.12.0-SNAPSHOT</version>
+		<version>1.11.1</version>
     </parent>
 
     <groupId>org.apache.isis.viewer</groupId>

http://git-wip-us.apache.org/repos/asf/isis/blob/7c2621ad/core/viewer-wicket-impl/pom.xml
----------------------------------------------------------------------
diff --git a/core/viewer-wicket-impl/pom.xml b/core/viewer-wicket-impl/pom.xml
index 1190f01..a811bf5 100644
--- a/core/viewer-wicket-impl/pom.xml
+++ b/core/viewer-wicket-impl/pom.xml
@@ -24,7 +24,7 @@
 	<parent>
 		<groupId>org.apache.isis.core</groupId>
 		<artifactId>isis</artifactId>
-		<version>1.12.0-SNAPSHOT</version>
+		<version>1.11.1</version>
 	</parent>
 
 	<name>Isis Wicket Viewer Implementation</name>

http://git-wip-us.apache.org/repos/asf/isis/blob/7c2621ad/core/viewer-wicket-model/pom.xml
----------------------------------------------------------------------
diff --git a/core/viewer-wicket-model/pom.xml b/core/viewer-wicket-model/pom.xml
index e4ff14d..e690404 100644
--- a/core/viewer-wicket-model/pom.xml
+++ b/core/viewer-wicket-model/pom.xml
@@ -24,7 +24,7 @@
 	<parent>
 		<groupId>org.apache.isis.core</groupId>
 		<artifactId>isis</artifactId>
-		<version>1.12.0-SNAPSHOT</version>
+		<version>1.11.1</version>
 	</parent>
 
     <groupId>org.apache.isis.viewer</groupId>

http://git-wip-us.apache.org/repos/asf/isis/blob/7c2621ad/core/viewer-wicket-ui/pom.xml
----------------------------------------------------------------------
diff --git a/core/viewer-wicket-ui/pom.xml b/core/viewer-wicket-ui/pom.xml
index 5de324b..141510c 100644
--- a/core/viewer-wicket-ui/pom.xml
+++ b/core/viewer-wicket-ui/pom.xml
@@ -24,7 +24,7 @@
 	<parent>
 		<groupId>org.apache.isis.core</groupId>
 		<artifactId>isis</artifactId>
-		<version>1.12.0-SNAPSHOT</version>
+		<version>1.11.1</version>
 	</parent>
 
     <groupId>org.apache.isis.viewer</groupId>

http://git-wip-us.apache.org/repos/asf/isis/blob/7c2621ad/core/webserver/pom.xml
----------------------------------------------------------------------
diff --git a/core/webserver/pom.xml b/core/webserver/pom.xml
index 4f222fe..1cba08e 100644
--- a/core/webserver/pom.xml
+++ b/core/webserver/pom.xml
@@ -23,7 +23,7 @@
     <parent>
 		<groupId>org.apache.isis.core</groupId>
 		<artifactId>isis</artifactId>
-        <version>1.12.0-SNAPSHOT</version>
+        <version>1.11.1</version>
     </parent>
 
 	<artifactId>isis-core-webserver</artifactId>

http://git-wip-us.apache.org/repos/asf/isis/blob/7c2621ad/core/wrapper/pom.xml
----------------------------------------------------------------------
diff --git a/core/wrapper/pom.xml b/core/wrapper/pom.xml
index e4486a5..656658c 100644
--- a/core/wrapper/pom.xml
+++ b/core/wrapper/pom.xml
@@ -23,7 +23,7 @@
     <parent>
         <groupId>org.apache.isis.core</groupId>
         <artifactId>isis</artifactId>
-        <version>1.12.0-SNAPSHOT</version>
+        <version>1.11.1</version>
 	</parent>
 
 	<artifactId>isis-core-wrapper</artifactId>


[02/17] isis git commit: ISIS-1295: removing ContextReplacePolicy since no longer required either

Posted by da...@apache.org.
ISIS-1295: removing ContextReplacePolicy since no longer required either


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

Branch: refs/heads/master
Commit: e86e7ad908d11da87b272986a726be81a899bdfc
Parents: ee58bb0
Author: Dan Haywood <da...@haywood-associates.co.uk>
Authored: Mon Jan 4 18:59:24 2016 +0000
Committer: Dan Haywood <da...@haywood-associates.co.uk>
Committed: Mon Jan 4 18:59:24 2016 +0000

----------------------------------------------------------------------
 .../runtime/system/context/IsisContext.java     | 30 +++++---------------
 1 file changed, 7 insertions(+), 23 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/isis/blob/e86e7ad9/core/runtime/src/main/java/org/apache/isis/core/runtime/system/context/IsisContext.java
----------------------------------------------------------------------
diff --git a/core/runtime/src/main/java/org/apache/isis/core/runtime/system/context/IsisContext.java b/core/runtime/src/main/java/org/apache/isis/core/runtime/system/context/IsisContext.java
index 9fe9b17..238d297 100644
--- a/core/runtime/src/main/java/org/apache/isis/core/runtime/system/context/IsisContext.java
+++ b/core/runtime/src/main/java/org/apache/isis/core/runtime/system/context/IsisContext.java
@@ -64,7 +64,6 @@ public class IsisContext implements DebuggableWithTitle {
     private static IsisContext singleton;
 
     private final IsisSessionFactory sessionFactory;
-    private final ContextReplacePolicy replacePolicy;
     private final SessionClosePolicy sessionClosePolicy;
 
     private static IsisConfiguration configuration;
@@ -108,35 +107,27 @@ public class IsisContext implements DebuggableWithTitle {
         AUTO_CLOSE
     }
 
-    /**
-     * Whether the {@link IsisContext#getInstance() singleton} itself may be
-     * replaced.
-     */
-    protected static enum ContextReplacePolicy {
-        NOT_REPLACEABLE, REPLACEABLE
-    }
-
 
     /**
      * Creates a new instance of the {@link IsisSession} holder.
      * 
      * <p>
-     * Will throw an exception if an instance has already been created and is
-     * not {@link ContextReplacePolicy#REPLACEABLE}.
+     * Will throw an exception if an instance has already been created.
      */
-    protected IsisContext(final ContextReplacePolicy replacePolicy, final SessionClosePolicy sessionClosePolicy, final IsisSessionFactory sessionFactory) {
-        if (singleton != null && !singleton.isContextReplaceable()) {
-            throw new IsisException("Isis Context already set up and cannot be replaced");
+    protected IsisContext(
+            final SessionClosePolicy sessionClosePolicy,
+            final IsisSessionFactory sessionFactory) {
+        if (singleton != null) {
+            throw new IsisException("Isis Context already set up");
         }
         singleton = this;
         this.sessionFactory = sessionFactory;
         this.sessionClosePolicy = sessionClosePolicy;
-        this.replacePolicy = replacePolicy;
     }
 
 
     protected IsisContext(final IsisSessionFactory sessionFactory) {
-        this(ContextReplacePolicy.NOT_REPLACEABLE, SessionClosePolicy.AUTO_CLOSE, sessionFactory);
+        this(SessionClosePolicy.AUTO_CLOSE, sessionFactory);
     }
 
 
@@ -168,13 +159,6 @@ public class IsisContext implements DebuggableWithTitle {
     // ///////////////////////////////////////////////////////////
 
     /**
-     * Whether a context singleton can simply be replaced or not.
-     */
-    public final boolean isContextReplaceable() {
-        return replacePolicy == ContextReplacePolicy.REPLACEABLE;
-    }
-
-    /**
      * Whether any open session can be automatically
      * {@link #closeSessionInstance() close}d on
      * {@link #openSessionInstance(AuthenticationSession) open}.


[09/17] isis git commit: ISIS-1296: adding/updating similar IntelliJ launch configs

Posted by da...@apache.org.
ISIS-1296: adding/updating similar IntelliJ launch configs


Project: http://git-wip-us.apache.org/repos/asf/isis/repo
Commit: http://git-wip-us.apache.org/repos/asf/isis/commit/89bd3fd5
Tree: http://git-wip-us.apache.org/repos/asf/isis/tree/89bd3fd5
Diff: http://git-wip-us.apache.org/repos/asf/isis/diff/89bd3fd5

Branch: refs/heads/master
Commit: 89bd3fd577466d759ba72d13f2bd0f6c88d15d03
Parents: 0915e03
Author: Dan Haywood <da...@haywood-associates.co.uk>
Authored: Sun Jan 10 15:12:04 2016 +0000
Committer: Dan Haywood <da...@haywood-associates.co.uk>
Committed: Sun Jan 10 15:12:04 2016 +0000

----------------------------------------------------------------------
 ...OTOTYPE-with-fixtures-bypass-security.launch |  2 +-
 .../SimpleApp-PROTOTYPE-with-fixtures.launch    |  2 +-
 .../eclipse/launch/SimpleApp-PROTOTYPE.launch   |  2 +-
 .../ide/eclipse/launch/SimpleApp-SERVER.launch  |  2 +-
 ..._PROTOTYPE_with_fixtures-bypass-security.xml | 28 ++++++++++++++++++++
 .../SimpleApp_PROTOTYPE_with_fixtures.xml       | 28 ++++++++++++++++++++
 .../ide/intellij/launch/SimpleApp_SERVER.xml    | 28 ++++++++++++++++++++
 .../launch/SimpleApp__enhance_only_.xml         |  2 +-
 8 files changed, 89 insertions(+), 5 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/isis/blob/89bd3fd5/example/application/simpleapp/webapp/ide/eclipse/launch/SimpleApp-PROTOTYPE-with-fixtures-bypass-security.launch
----------------------------------------------------------------------
diff --git a/example/application/simpleapp/webapp/ide/eclipse/launch/SimpleApp-PROTOTYPE-with-fixtures-bypass-security.launch b/example/application/simpleapp/webapp/ide/eclipse/launch/SimpleApp-PROTOTYPE-with-fixtures-bypass-security.launch
index 16e483a..91b8abb 100644
--- a/example/application/simpleapp/webapp/ide/eclipse/launch/SimpleApp-PROTOTYPE-with-fixtures-bypass-security.launch
+++ b/example/application/simpleapp/webapp/ide/eclipse/launch/SimpleApp-PROTOTYPE-with-fixtures-bypass-security.launch
@@ -14,7 +14,7 @@
 <booleanAttribute key="org.eclipse.jdt.debug.ui.INCLUDE_EXTERNAL_JARS" value="true"/>
 <stringAttribute key="org.eclipse.jdt.launching.CLASSPATH_PROVIDER" value="org.eclipse.m2e.launchconfig.classpathProvider"/>
 <stringAttribute key="org.eclipse.jdt.launching.MAIN_TYPE" value="org.apache.isis.WebServer"/>
-<stringAttribute key="org.eclipse.jdt.launching.PROGRAM_ARGUMENTS" value="--type SERVER_PROTOTYPE --manifest domainapp.app.DomainAppAppManifestWithFixturesBypassSecurity"/>
+<stringAttribute key="org.eclipse.jdt.launching.PROGRAM_ARGUMENTS" value="--type SERVER_PROTOTYPE --port 8080 --manifest domainapp.app.DomainAppAppManifestWithFixturesBypassSecurity"/>
 <stringAttribute key="org.eclipse.jdt.launching.PROJECT_ATTR" value="simpleapp-webapp"/>
 <stringAttribute key="org.eclipse.jdt.launching.SOURCE_PATH_PROVIDER" value="org.eclipse.m2e.launchconfig.sourcepathProvider"/>
 </launchConfiguration>

http://git-wip-us.apache.org/repos/asf/isis/blob/89bd3fd5/example/application/simpleapp/webapp/ide/eclipse/launch/SimpleApp-PROTOTYPE-with-fixtures.launch
----------------------------------------------------------------------
diff --git a/example/application/simpleapp/webapp/ide/eclipse/launch/SimpleApp-PROTOTYPE-with-fixtures.launch b/example/application/simpleapp/webapp/ide/eclipse/launch/SimpleApp-PROTOTYPE-with-fixtures.launch
index 659195c..a20d0ea 100644
--- a/example/application/simpleapp/webapp/ide/eclipse/launch/SimpleApp-PROTOTYPE-with-fixtures.launch
+++ b/example/application/simpleapp/webapp/ide/eclipse/launch/SimpleApp-PROTOTYPE-with-fixtures.launch
@@ -14,7 +14,7 @@
 <booleanAttribute key="org.eclipse.jdt.debug.ui.INCLUDE_EXTERNAL_JARS" value="true"/>
 <stringAttribute key="org.eclipse.jdt.launching.CLASSPATH_PROVIDER" value="org.eclipse.m2e.launchconfig.classpathProvider"/>
 <stringAttribute key="org.eclipse.jdt.launching.MAIN_TYPE" value="org.apache.isis.WebServer"/>
-<stringAttribute key="org.eclipse.jdt.launching.PROGRAM_ARGUMENTS" value="--type SERVER_PROTOTYPE --manifest domainapp.app.DomainAppAppManifestWithFixtures"/>
+<stringAttribute key="org.eclipse.jdt.launching.PROGRAM_ARGUMENTS" value="--type SERVER_PROTOTYPE --port 8080 --manifest domainapp.app.DomainAppAppManifestWithFixtures"/>
 <stringAttribute key="org.eclipse.jdt.launching.PROJECT_ATTR" value="simpleapp-webapp"/>
 <stringAttribute key="org.eclipse.jdt.launching.SOURCE_PATH_PROVIDER" value="org.eclipse.m2e.launchconfig.sourcepathProvider"/>
 </launchConfiguration>

http://git-wip-us.apache.org/repos/asf/isis/blob/89bd3fd5/example/application/simpleapp/webapp/ide/eclipse/launch/SimpleApp-PROTOTYPE.launch
----------------------------------------------------------------------
diff --git a/example/application/simpleapp/webapp/ide/eclipse/launch/SimpleApp-PROTOTYPE.launch b/example/application/simpleapp/webapp/ide/eclipse/launch/SimpleApp-PROTOTYPE.launch
index 7e1303a..918c5f1 100644
--- a/example/application/simpleapp/webapp/ide/eclipse/launch/SimpleApp-PROTOTYPE.launch
+++ b/example/application/simpleapp/webapp/ide/eclipse/launch/SimpleApp-PROTOTYPE.launch
@@ -14,7 +14,7 @@
 <booleanAttribute key="org.eclipse.jdt.debug.ui.INCLUDE_EXTERNAL_JARS" value="true"/>
 <stringAttribute key="org.eclipse.jdt.launching.CLASSPATH_PROVIDER" value="org.eclipse.m2e.launchconfig.classpathProvider"/>
 <stringAttribute key="org.eclipse.jdt.launching.MAIN_TYPE" value="org.apache.isis.WebServer"/>
-<stringAttribute key="org.eclipse.jdt.launching.PROGRAM_ARGUMENTS" value="--type SERVER_PROTOTYPE"/>
+<stringAttribute key="org.eclipse.jdt.launching.PROGRAM_ARGUMENTS" value="--type SERVER_PROTOTYPE --port 8080"/>
 <stringAttribute key="org.eclipse.jdt.launching.PROJECT_ATTR" value="simpleapp-webapp"/>
 <stringAttribute key="org.eclipse.jdt.launching.SOURCE_PATH_PROVIDER" value="org.eclipse.m2e.launchconfig.sourcepathProvider"/>
 </launchConfiguration>

http://git-wip-us.apache.org/repos/asf/isis/blob/89bd3fd5/example/application/simpleapp/webapp/ide/eclipse/launch/SimpleApp-SERVER.launch
----------------------------------------------------------------------
diff --git a/example/application/simpleapp/webapp/ide/eclipse/launch/SimpleApp-SERVER.launch b/example/application/simpleapp/webapp/ide/eclipse/launch/SimpleApp-SERVER.launch
index deccfe8..a1c0e67 100644
--- a/example/application/simpleapp/webapp/ide/eclipse/launch/SimpleApp-SERVER.launch
+++ b/example/application/simpleapp/webapp/ide/eclipse/launch/SimpleApp-SERVER.launch
@@ -14,7 +14,7 @@
 <booleanAttribute key="org.eclipse.jdt.debug.ui.INCLUDE_EXTERNAL_JARS" value="true"/>
 <stringAttribute key="org.eclipse.jdt.launching.CLASSPATH_PROVIDER" value="org.eclipse.m2e.launchconfig.classpathProvider"/>
 <stringAttribute key="org.eclipse.jdt.launching.MAIN_TYPE" value="org.apache.isis.WebServer"/>
-<stringAttribute key="org.eclipse.jdt.launching.PROGRAM_ARGUMENTS" value="--type SERVER"/>
+<stringAttribute key="org.eclipse.jdt.launching.PROGRAM_ARGUMENTS" value="--type SERVER --port 8080"/>
 <stringAttribute key="org.eclipse.jdt.launching.PROJECT_ATTR" value="simpleapp-webapp"/>
 <stringAttribute key="org.eclipse.jdt.launching.SOURCE_PATH_PROVIDER" value="org.eclipse.m2e.launchconfig.sourcepathProvider"/>
 </launchConfiguration>

http://git-wip-us.apache.org/repos/asf/isis/blob/89bd3fd5/example/application/simpleapp/webapp/ide/intellij/launch/SimpleApp_PROTOTYPE_with_fixtures-bypass-security.xml
----------------------------------------------------------------------
diff --git a/example/application/simpleapp/webapp/ide/intellij/launch/SimpleApp_PROTOTYPE_with_fixtures-bypass-security.xml b/example/application/simpleapp/webapp/ide/intellij/launch/SimpleApp_PROTOTYPE_with_fixtures-bypass-security.xml
new file mode 100644
index 0000000..9344c79
--- /dev/null
+++ b/example/application/simpleapp/webapp/ide/intellij/launch/SimpleApp_PROTOTYPE_with_fixtures-bypass-security.xml
@@ -0,0 +1,28 @@
+<component name="ProjectRunConfigurationManager">
+  <configuration default="false" name="SimpleApp-PROTOTYPE (domainapp.app.DomainAppAppManifestWithFixturesBypassSecurity)" type="Application" factoryName="Application" singleton="true">
+    <extension name="coverage" enabled="false" merge="false" sample_coverage="true" runner="idea" />
+    <option name="MAIN_CLASS_NAME" value="org.apache.isis.WebServer" />
+    <option name="VM_PARAMETERS" value="" />
+    <option name="PROGRAM_PARAMETERS" value="--type SERVER_PROTOTYPE --port 8080 --manifest domainapp.app.DomainAppAppManifestWithFixturesBypassSecurity" />
+    <option name="WORKING_DIRECTORY" value="file://$MODULE_DIR$" />
+    <option name="ALTERNATIVE_JRE_PATH_ENABLED" value="false" />
+    <option name="ALTERNATIVE_JRE_PATH" value="" />
+    <option name="ENABLE_SWING_INSPECTOR" value="false" />
+    <option name="ENV_VARIABLES" />
+    <option name="PASS_PARENT_ENVS" value="true" />
+    <module name="simpleapp-webapp" />
+    <envs />
+    <RunnerSettings RunnerId="Debug">
+      <option name="DEBUG_PORT" value="" />
+      <option name="TRANSPORT" value="0" />
+      <option name="LOCAL" value="true" />
+    </RunnerSettings>
+    <RunnerSettings RunnerId="Run" />
+    <ConfigurationWrapper RunnerId="Debug" />
+    <ConfigurationWrapper RunnerId="Run" />
+    <method>
+      <option name="Make" enabled="false" />
+      <option name="Maven.BeforeRunTask" enabled="true" file="C:/Apache/Isis/example/application/simpleapp/dom/pom.xml" goal="datanucleus:enhance -o" />
+    </method>
+  </configuration>
+</component>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/isis/blob/89bd3fd5/example/application/simpleapp/webapp/ide/intellij/launch/SimpleApp_PROTOTYPE_with_fixtures.xml
----------------------------------------------------------------------
diff --git a/example/application/simpleapp/webapp/ide/intellij/launch/SimpleApp_PROTOTYPE_with_fixtures.xml b/example/application/simpleapp/webapp/ide/intellij/launch/SimpleApp_PROTOTYPE_with_fixtures.xml
new file mode 100644
index 0000000..c813235
--- /dev/null
+++ b/example/application/simpleapp/webapp/ide/intellij/launch/SimpleApp_PROTOTYPE_with_fixtures.xml
@@ -0,0 +1,28 @@
+<component name="ProjectRunConfigurationManager">
+  <configuration default="false" name="SimpleApp-PROTOTYPE (domainapp.app.DomainAppAppManifestWithFixtures)" type="Application" factoryName="Application" singleton="true">
+    <extension name="coverage" enabled="false" merge="false" sample_coverage="true" runner="idea" />
+    <option name="MAIN_CLASS_NAME" value="org.apache.isis.WebServer" />
+    <option name="VM_PARAMETERS" value="" />
+    <option name="PROGRAM_PARAMETERS" value="--type SERVER_PROTOTYPE --port 8080 --manifest domainapp.app.DomainAppAppManifestWithFixtures" />
+    <option name="WORKING_DIRECTORY" value="file://$MODULE_DIR$" />
+    <option name="ALTERNATIVE_JRE_PATH_ENABLED" value="false" />
+    <option name="ALTERNATIVE_JRE_PATH" value="" />
+    <option name="ENABLE_SWING_INSPECTOR" value="false" />
+    <option name="ENV_VARIABLES" />
+    <option name="PASS_PARENT_ENVS" value="true" />
+    <module name="simpleapp-webapp" />
+    <envs />
+    <RunnerSettings RunnerId="Debug">
+      <option name="DEBUG_PORT" value="" />
+      <option name="TRANSPORT" value="0" />
+      <option name="LOCAL" value="true" />
+    </RunnerSettings>
+    <RunnerSettings RunnerId="Run" />
+    <ConfigurationWrapper RunnerId="Debug" />
+    <ConfigurationWrapper RunnerId="Run" />
+    <method>
+      <option name="Make" enabled="false" />
+      <option name="Maven.BeforeRunTask" enabled="true" file="C:/Apache/Isis/example/application/simpleapp/dom/pom.xml" goal="datanucleus:enhance -o" />
+    </method>
+  </configuration>
+</component>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/isis/blob/89bd3fd5/example/application/simpleapp/webapp/ide/intellij/launch/SimpleApp_SERVER.xml
----------------------------------------------------------------------
diff --git a/example/application/simpleapp/webapp/ide/intellij/launch/SimpleApp_SERVER.xml b/example/application/simpleapp/webapp/ide/intellij/launch/SimpleApp_SERVER.xml
new file mode 100644
index 0000000..a438f54
--- /dev/null
+++ b/example/application/simpleapp/webapp/ide/intellij/launch/SimpleApp_SERVER.xml
@@ -0,0 +1,28 @@
+<component name="ProjectRunConfigurationManager">
+  <configuration default="false" name="SimpleApp-SERVER" type="Application" factoryName="Application" singleton="true">
+    <extension name="coverage" enabled="false" merge="false" sample_coverage="true" runner="idea" />
+    <option name="MAIN_CLASS_NAME" value="org.apache.isis.WebServer" />
+    <option name="VM_PARAMETERS" value="" />
+    <option name="PROGRAM_PARAMETERS" value="--type SERVER --port 8080" />
+    <option name="WORKING_DIRECTORY" value="file://$MODULE_DIR$" />
+    <option name="ALTERNATIVE_JRE_PATH_ENABLED" value="false" />
+    <option name="ALTERNATIVE_JRE_PATH" value="" />
+    <option name="ENABLE_SWING_INSPECTOR" value="false" />
+    <option name="ENV_VARIABLES" />
+    <option name="PASS_PARENT_ENVS" value="true" />
+    <module name="simpleapp-webapp" />
+    <envs />
+    <RunnerSettings RunnerId="Debug">
+      <option name="DEBUG_PORT" value="" />
+      <option name="TRANSPORT" value="0" />
+      <option name="LOCAL" value="true" />
+    </RunnerSettings>
+    <RunnerSettings RunnerId="Run" />
+    <ConfigurationWrapper RunnerId="Debug" />
+    <ConfigurationWrapper RunnerId="Run" />
+    <method>
+      <option name="Make" enabled="false" />
+      <option name="Maven.BeforeRunTask" enabled="true" file="C:/Apache/Isis/example/application/simpleapp/dom/pom.xml" goal="datanucleus:enhance -o" />
+    </method>
+  </configuration>
+</component>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/isis/blob/89bd3fd5/example/application/simpleapp/webapp/ide/intellij/launch/SimpleApp__enhance_only_.xml
----------------------------------------------------------------------
diff --git a/example/application/simpleapp/webapp/ide/intellij/launch/SimpleApp__enhance_only_.xml b/example/application/simpleapp/webapp/ide/intellij/launch/SimpleApp__enhance_only_.xml
index 1a312f9..d3bfe6d 100644
--- a/example/application/simpleapp/webapp/ide/intellij/launch/SimpleApp__enhance_only_.xml
+++ b/example/application/simpleapp/webapp/ide/intellij/launch/SimpleApp__enhance_only_.xml
@@ -1,5 +1,5 @@
 <component name="ProjectRunConfigurationManager">
-s  <configuration default="false" name="SimpleApp (enhance only)" type="Application" factoryName="Application">
+  <configuration default="false" name="SimpleApp (enhance only)" type="Application" factoryName="Application">
     <extension name="coverage" enabled="false" merge="false" sample_coverage="true" runner="idea" />
     <option name="MAIN_CLASS_NAME" value="org.apache.isis.Dummy" />
     <option name="VM_PARAMETERS" value="" />


[14/17] isis git commit: ISIS-1287: adding docs to set up toolchains.xml

Posted by da...@apache.org.
ISIS-1287: adding docs to set up toolchains.xml


Project: http://git-wip-us.apache.org/repos/asf/isis/repo
Commit: http://git-wip-us.apache.org/repos/asf/isis/commit/86a787b6
Tree: http://git-wip-us.apache.org/repos/asf/isis/tree/86a787b6
Diff: http://git-wip-us.apache.org/repos/asf/isis/diff/86a787b6

Branch: refs/heads/master
Commit: 86a787b64f3a078ee6ce847f78be0426695da495
Parents: dab4fca
Author: Dan Haywood <da...@haywood-associates.co.uk>
Authored: Fri Jan 15 12:09:46 2016 +0000
Committer: Dan Haywood <da...@haywood-associates.co.uk>
Committed: Fri Jan 15 12:09:46 2016 +0000

----------------------------------------------------------------------
 .../asciidoc/guides/_cgcon_building-isis.adoc   | 78 +++++++++++++++++++-
 1 file changed, 75 insertions(+), 3 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/isis/blob/86a787b6/adocs/documentation/src/main/asciidoc/guides/_cgcon_building-isis.adoc
----------------------------------------------------------------------
diff --git a/adocs/documentation/src/main/asciidoc/guides/_cgcon_building-isis.adoc b/adocs/documentation/src/main/asciidoc/guides/_cgcon_building-isis.adoc
index 69ec333..3dd2675 100644
--- a/adocs/documentation/src/main/asciidoc/guides/_cgcon_building-isis.adoc
+++ b/adocs/documentation/src/main/asciidoc/guides/_cgcon_building-isis.adoc
@@ -8,12 +8,13 @@
 
 
 
-
+[[_cgcon_building-isis_git]]
 == Git
 
 The Apache Isis source code lives in a git repo.
 
 
+[[_cgcon_building-isis_git_installation]]
 === Installation
 
 The easiest place to get hold of command-line git is probably the http://git-scm.com/downloads[github download page].
@@ -33,7 +34,7 @@ If using Mac, you might also want to check out Atlassian's http://www.atlassian.
 
 
 
-
+[[_cgcon_building-isis_git_installation_cloning-the-apache-isis-repo]]
 ==== Cloning the Apache Isis repo
 
 First, clone the Apache Isis repo.
@@ -48,6 +49,8 @@ git clone https://git-wip-us.apache.org/repos/asf/isis.git
 
 If you are *not a committer*, please see the xref:cgcon.adoc#_cgcon_contributing[contributing] page for details on which repo to clone from.
 
+
+[[_cgcon_building-isis_git_installation_configuring-git]]
 ==== Configuring Git
 
 Next up is to configure your user name and password; see also https://git-wip-us.apache.org/[Apache's git] docs:
@@ -107,6 +110,7 @@ If you don't use git outside of Apache, you can add the `--global` flag so that
 
 
 
+[[_cgcon_building-isis_git_getting-help]]
 === Getting help
 
 Three commands of git that in particular worth knowing:
@@ -132,8 +136,27 @@ For further reading, see:
 * http://git-scm.com/docs/gitattributes[.gitattributes git-scm.com docs]
 
 
+[[_cgcon_building-isis_installing-java-7]]
+== Installing Java 7
+
+Apache Isis is compatible with Java 7 and Java 8.  To ensure backward compatibility with Java 7 the framework is built
+using Java 7, leveraging the link:http://maven.apache.org/plugins/maven-toolchains-plugin/[Maven toolchains plugin].
+(The discussion of toolchains itself is discussed xref:_cgcon_building-isis_configure-maven-toolchains-plugin[below]).
+
+
+Therefore install Java 7 JDK (and optionally Java 8 JDK as well).  Note that the JRE is _not_ sufficient.
+
+
+[TIP]
+====
+If you intend to contribute back patches to Apache Isis, note that you can still use Java 8 within your IDE to
+make changes.  Just be sure not to use any Java 8 APIs.
+====
+
+
 
 
+[[_cgcon_building-isis_installing-maven]]
 == Installing Maven
 
 Install Maven 3.0.x, downloadable http://maven.apache.org/download.html[here].
@@ -152,6 +175,52 @@ Previously we suggested `-XX:MaxPermSize=256m`, but this option has been removed
 ====
 
 
+[[_cgcon_building-isis_configure-maven-toolchains-plugin]]
+== Configure Maven toolchains plugin
+
+As noted xref:_cgcon_building-isis_installing-java-7[earlier], Apache Isis is built using Java 7, leveraging the
+link:http://maven.apache.org/plugins/maven-toolchains-plugin/[toolchains] plugin.  This is configured by placing the
+`toolchains.xml` file in `~/.m2` directory.
+
+You can use the following file as a template, adjusting paths for your platform:
+
+[source,xml]
+----
+<?xml version="1.0" encoding="UTF8"?>
+<toolchains>
+    <toolchain>
+        <type>jdk</type>
+        <provides>
+            <version>1.8</version>
+            <vendor>oracle</vendor>
+        </provides>
+        <configuration>
+            <jdkHome>/usr/lib64/jvm/jdk1.8.0_65</jdkHome>
+            <!--
+            <jdkHome>c:\Program Files\Java\jdk1.8.0_65</jdkHome>
+            -->
+        </configuration>
+    </toolchain>
+    <toolchain>
+        <type>jdk</type>
+        <provides>
+            <version>1.7</version>   <!--1-->
+            <vendor>oracle</vendor>
+        </provides>
+        <configuration>
+            <jdkHome>/usr/lib64/jvm/jdk1.7.0_79</jdkHome>
+            <!--
+            <jdkHome>c:\Program Files\Java\jdk1.7.0_79</jdkHome>
+            -->
+        </configuration>
+    </toolchain>
+</toolchains>
+----
+<1> The Apache Isis build is configured to search for the (`1.7, oracle`) JDK toolchain.
+
+
+
+[[_cgcon_building-isis_building-all-of-apache-isis]]
 == Building all of Apache Isis
 
 To build the source code from the command line, simply go to the root directory and type:
@@ -178,6 +247,7 @@ When using Eclipse, a Maven profile is configured such that Eclipse compiles to
 
 
 
+[[_cgcon_building-isis_checking-for-vulnerabilities]]
 == Checking for Vulnerabilities
 
 Apache Isis configures the link:https://www.owasp.org/index.php/Main_Page[OWASP] link:https://www.owasp.org/index.php/OWASP_Dependency_Check[dependency check] link:http://jeremylong.github.io/DependencyCheck/dependency-check-maven/index.html[Maven plugin] to determine whether the framework uses libraries that are known to have security vulnerabilities.
@@ -201,6 +271,7 @@ To disable, either run in offline mode (add `-o` or `--offline`) or omit the `ow
 
 
 
+[[_cgcon_building-isis_checking-for-use-of-internal-jdk-apis]]
 == Checking for use of internal JDK APIs
 
 Apache Isis configures the link:https://maven.apache.org/plugins-archives/maven-jdeps-plugin-3.0.0/[jdeps maven plugin] to check for any usage of internal JDK APIs.  This is in preparation for Java 9 module system (Jigsaw) which will prevent such usage of APIs.
@@ -215,8 +286,9 @@ mvn clean install -Djdeps
 This will fail the build on any module that currently uses an internal JDK API.
 
 
-[NOTE]
+[WARNING]
 ====
 At the time of writing the `isis-core-schema` module fails the build.
 ====
 
+


[07/17] isis git commit: [maven-release-plugin] prepare for next development iteration

Posted by da...@apache.org.
[maven-release-plugin] prepare for next development iteration


Project: http://git-wip-us.apache.org/repos/asf/isis/repo
Commit: http://git-wip-us.apache.org/repos/asf/isis/commit/277f4cb3
Tree: http://git-wip-us.apache.org/repos/asf/isis/tree/277f4cb3
Diff: http://git-wip-us.apache.org/repos/asf/isis/diff/277f4cb3

Branch: refs/heads/master
Commit: 277f4cb3cb6a0283e87844614fb33d0a1ebc7d11
Parents: 7c2621a
Author: Dan Haywood <da...@haywood-associates.co.uk>
Authored: Sun Jan 10 14:09:17 2016 +0000
Committer: Dan Haywood <da...@haywood-associates.co.uk>
Committed: Sun Jan 10 14:09:17 2016 +0000

----------------------------------------------------------------------
 core/applib/pom.xml                          |  2 +-
 core/integtestsupport/pom.xml                |  2 +-
 core/log4j/pom.xml                           |  2 +-
 core/maven-plugin/pom.xml                    |  2 +-
 core/metamodel/pom.xml                       |  2 +-
 core/pom.xml                                 | 66 +++++++++++------------
 core/runtime/pom.xml                         |  2 +-
 core/schema/pom.xml                          |  2 +-
 core/security-shiro/pom.xml                  |  6 +--
 core/security/pom.xml                        |  2 +-
 core/specsupport/pom.xml                     |  2 +-
 core/unittestsupport/pom.xml                 |  2 +-
 core/viewer-restfulobjects-applib/pom.xml    |  2 +-
 core/viewer-restfulobjects-rendering/pom.xml |  2 +-
 core/viewer-restfulobjects-server/pom.xml    |  2 +-
 core/viewer-wicket-applib/pom.xml            |  2 +-
 core/viewer-wicket-impl/pom.xml              |  2 +-
 core/viewer-wicket-model/pom.xml             |  2 +-
 core/viewer-wicket-ui/pom.xml                |  2 +-
 core/webserver/pom.xml                       |  2 +-
 core/wrapper/pom.xml                         |  2 +-
 21 files changed, 55 insertions(+), 55 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/isis/blob/277f4cb3/core/applib/pom.xml
----------------------------------------------------------------------
diff --git a/core/applib/pom.xml b/core/applib/pom.xml
index 0c7fc02..757908c 100644
--- a/core/applib/pom.xml
+++ b/core/applib/pom.xml
@@ -23,7 +23,7 @@
     <parent>
         <groupId>org.apache.isis.core</groupId>
         <artifactId>isis</artifactId>
-        <version>1.11.1</version>
+        <version>1.12.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>isis-core-applib</artifactId>

http://git-wip-us.apache.org/repos/asf/isis/blob/277f4cb3/core/integtestsupport/pom.xml
----------------------------------------------------------------------
diff --git a/core/integtestsupport/pom.xml b/core/integtestsupport/pom.xml
index 3da7ac6..8491f67 100644
--- a/core/integtestsupport/pom.xml
+++ b/core/integtestsupport/pom.xml
@@ -23,7 +23,7 @@
 	<parent>
 		<groupId>org.apache.isis.core</groupId>
 		<artifactId>isis</artifactId>
-        <version>1.11.1</version>
+        <version>1.12.0-SNAPSHOT</version>
 	</parent>
 
 	<artifactId>isis-core-integtestsupport</artifactId>

http://git-wip-us.apache.org/repos/asf/isis/blob/277f4cb3/core/log4j/pom.xml
----------------------------------------------------------------------
diff --git a/core/log4j/pom.xml b/core/log4j/pom.xml
index 1ef669f..4a029c1 100644
--- a/core/log4j/pom.xml
+++ b/core/log4j/pom.xml
@@ -15,7 +15,7 @@
     <parent>
         <groupId>org.apache.isis.core</groupId>
         <artifactId>isis</artifactId>
-        <version>1.11.1</version>
+        <version>1.12.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>isis-core-log4j</artifactId>

http://git-wip-us.apache.org/repos/asf/isis/blob/277f4cb3/core/maven-plugin/pom.xml
----------------------------------------------------------------------
diff --git a/core/maven-plugin/pom.xml b/core/maven-plugin/pom.xml
index d0a38ce..4456432 100644
--- a/core/maven-plugin/pom.xml
+++ b/core/maven-plugin/pom.xml
@@ -23,7 +23,7 @@
     <parent>
         <groupId>org.apache.isis.core</groupId>
         <artifactId>isis</artifactId>
-        <version>1.11.1</version>
+        <version>1.12.0-SNAPSHOT</version>
     </parent>
 
     <groupId>org.apache.isis.tool</groupId>

http://git-wip-us.apache.org/repos/asf/isis/blob/277f4cb3/core/metamodel/pom.xml
----------------------------------------------------------------------
diff --git a/core/metamodel/pom.xml b/core/metamodel/pom.xml
index b7e6b59..493c298 100644
--- a/core/metamodel/pom.xml
+++ b/core/metamodel/pom.xml
@@ -23,7 +23,7 @@
     <parent>
         <groupId>org.apache.isis.core</groupId>
         <artifactId>isis</artifactId>
-        <version>1.11.1</version>
+        <version>1.12.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>isis-core-metamodel</artifactId>

http://git-wip-us.apache.org/repos/asf/isis/blob/277f4cb3/core/pom.xml
----------------------------------------------------------------------
diff --git a/core/pom.xml b/core/pom.xml
index b54a9c5..5b7de63 100644
--- a/core/pom.xml
+++ b/core/pom.xml
@@ -29,7 +29,7 @@
 
     <groupId>org.apache.isis.core</groupId>
     <artifactId>isis</artifactId>
-    <version>1.11.1</version>
+    <version>1.12.0-SNAPSHOT</version>
     
     <packaging>pom</packaging>
 
@@ -162,7 +162,7 @@
         <connection>scm:git:http://git.apache.org/isis.git/core</connection>
         <developerConnection>scm:git:https://git-wip-us.apache.org/repos/asf/isis.git/trunk/framework/</developerConnection>
         <url>git://git.apache.org/isis.git/core</url>
-      <tag>isis-1.11.1</tag>
+      <tag>HEAD</tag>
   </scm>
 
     <url>http://isis.apache.org</url>
@@ -1061,13 +1061,13 @@ ${license.additional-notes}
             <dependency>
                 <groupId>org.apache.isis.core</groupId>
                 <artifactId>isis-core-unittestsupport</artifactId>
-                <version>1.11.1</version>
+                <version>1.12.0-SNAPSHOT</version>
                 <!-- not scope=test, because referenced by some sql-tests-common under compile scope -->
             </dependency>
             <dependency>
                 <groupId>org.apache.isis.core</groupId>
                 <artifactId>isis-core-unittestsupport</artifactId>
-                <version>1.11.1</version>
+                <version>1.12.0-SNAPSHOT</version>
                 <type>test-jar</type>
                 <scope>test</scope>
             </dependency>
@@ -1076,14 +1076,14 @@ ${license.additional-notes}
             <dependency>
                 <groupId>org.apache.isis.core</groupId>
                 <artifactId>isis-core-applib</artifactId>
-                <version>1.11.1</version>
+                <version>1.12.0-SNAPSHOT</version>
                 <type>jar</type>
                 <scope>compile</scope>
             </dependency>
             <dependency>
                 <groupId>org.apache.isis.core</groupId>
                 <artifactId>isis-core-applib</artifactId>
-                <version>1.11.1</version>
+                <version>1.12.0-SNAPSHOT</version>
                 <type>test-jar</type>
                 <scope>test</scope>
             </dependency>
@@ -1092,14 +1092,14 @@ ${license.additional-notes}
             <dependency>
                 <groupId>org.apache.isis.core</groupId>
                 <artifactId>isis-core-schema</artifactId>
-                <version>1.11.1</version>
+                <version>1.12.0-SNAPSHOT</version>
                 <type>jar</type>
                 <scope>compile</scope>
             </dependency>
             <dependency>
                 <groupId>org.apache.isis.core</groupId>
                 <artifactId>isis-core-schema</artifactId>
-                <version>1.11.1</version>
+                <version>1.12.0-SNAPSHOT</version>
                 <type>test-jar</type>
                 <scope>test</scope>
             </dependency>
@@ -1108,7 +1108,7 @@ ${license.additional-notes}
             <dependency>
                 <groupId>org.apache.isis.core</groupId>
                 <artifactId>isis-core-log4j</artifactId>
-                <version>1.11.1</version>
+                <version>1.12.0-SNAPSHOT</version>
                 <type>jar</type>
                 <scope>compile</scope>
             </dependency>
@@ -1117,14 +1117,14 @@ ${license.additional-notes}
             <dependency>
                 <groupId>org.apache.isis.core</groupId>
                 <artifactId>isis-core-metamodel</artifactId>
-                <version>1.11.1</version>
+                <version>1.12.0-SNAPSHOT</version>
                 <type>jar</type>
                 <scope>compile</scope>
             </dependency>
             <dependency>
                 <groupId>org.apache.isis.core</groupId>
                 <artifactId>isis-core-metamodel</artifactId>
-                <version>1.11.1</version>
+                <version>1.12.0-SNAPSHOT</version>
                 <type>test-jar</type>
                 <scope>test</scope>
             </dependency>
@@ -1133,40 +1133,40 @@ ${license.additional-notes}
             <dependency>
                 <groupId>org.apache.isis.core</groupId>
                 <artifactId>isis-core-runtime</artifactId>
-                <version>1.11.1</version>
+                <version>1.12.0-SNAPSHOT</version>
             </dependency>
             <dependency>
                 <groupId>org.apache.isis.core</groupId>
                 <artifactId>isis-core-runtime</artifactId>
-                <version>1.11.1</version>
+                <version>1.12.0-SNAPSHOT</version>
                 <type>test-jar</type>
                 <scope>test</scope>
             </dependency>
             <dependency>
                 <groupId>org.apache.isis.core</groupId>
                 <artifactId>isis-core-wrapper</artifactId>
-                <version>1.11.1</version>
+                <version>1.12.0-SNAPSHOT</version>
             </dependency>
 
             <!-- webserver -->
             <dependency>
                 <groupId>org.apache.isis.core</groupId>
                 <artifactId>isis-core-webserver</artifactId>
-                <version>1.11.1</version>
+                <version>1.12.0-SNAPSHOT</version>
             </dependency>
 
             <!-- specsupport -->
             <dependency>
                 <groupId>org.apache.isis.core</groupId>
                 <artifactId>isis-core-specsupport</artifactId>
-                <version>1.11.1</version>
+                <version>1.12.0-SNAPSHOT</version>
             </dependency>
 
             <!-- integtestsupport -->
             <dependency>
                 <groupId>org.apache.isis.core</groupId>
                 <artifactId>isis-core-integtestsupport</artifactId>
-                <version>1.11.1</version>
+                <version>1.12.0-SNAPSHOT</version>
                 <!-- not scope=test, because referenced by some sql-tests-common under compile scope -->
             </dependency>
 
@@ -1174,36 +1174,36 @@ ${license.additional-notes}
             <dependency>
                 <groupId>org.apache.isis.core</groupId>
                 <artifactId>isis-core-viewer-restfulobjects-applib</artifactId>
-                <version>1.11.1</version>
+                <version>1.12.0-SNAPSHOT</version>
             </dependency>
             <dependency>
                 <groupId>org.apache.isis.core</groupId>
                 <artifactId>isis-core-viewer-restfulobjects-applib</artifactId>
-                <version>1.11.1</version>
+                <version>1.12.0-SNAPSHOT</version>
                 <type>test-jar</type>
                 <scope>test</scope>
             </dependency>
             <dependency>
                 <groupId>org.apache.isis.core</groupId>
                 <artifactId>isis-core-viewer-restfulobjects-rendering</artifactId>
-                <version>1.11.1</version>
+                <version>1.12.0-SNAPSHOT</version>
             </dependency>
             <dependency>
                 <groupId>org.apache.isis.core</groupId>
                 <artifactId>isis-core-viewer-restfulobjects-rendering</artifactId>
-                <version>1.11.1</version>
+                <version>1.12.0-SNAPSHOT</version>
                 <type>test-jar</type>
                 <scope>test</scope>
             </dependency>
             <dependency>
                 <groupId>org.apache.isis.core</groupId>
                 <artifactId>isis-core-viewer-restfulobjects-server</artifactId>
-                <version>1.11.1</version>
+                <version>1.12.0-SNAPSHOT</version>
             </dependency>
             <dependency>
                 <groupId>org.apache.isis.core</groupId>
                 <artifactId>isis-core-viewer-restfulobjects-server</artifactId>
-                <version>1.11.1</version>
+                <version>1.12.0-SNAPSHOT</version>
                 <type>test-jar</type>
                 <scope>test</scope>
             </dependency>
@@ -1212,12 +1212,12 @@ ${license.additional-notes}
             <dependency>
                 <groupId>org.apache.isis.core</groupId>
                 <artifactId>isis-core-security</artifactId>
-                <version>1.11.1</version>
+                <version>1.12.0-SNAPSHOT</version>
             </dependency>
             <dependency>
                 <groupId>org.apache.isis.core</groupId>
                 <artifactId>isis-core-security-shiro</artifactId>
-                <version>1.11.1</version>
+                <version>1.12.0-SNAPSHOT</version>
             </dependency>
 
             
@@ -1225,41 +1225,41 @@ ${license.additional-notes}
             <dependency>
                 <groupId>org.apache.isis.viewer</groupId>
                 <artifactId>isis-viewer-wicket-applib</artifactId>
-                <version>1.11.1</version>
+                <version>1.12.0-SNAPSHOT</version>
             </dependency>
             <dependency>
                 <groupId>org.apache.isis.viewer</groupId>
                 <artifactId>isis-viewer-wicket-model</artifactId>
-                <version>1.11.1</version>
+                <version>1.12.0-SNAPSHOT</version>
             </dependency>
             <dependency>
                 <groupId>org.apache.isis.viewer</groupId>
                 <artifactId>isis-viewer-wicket-model</artifactId>
-                <version>1.11.1</version>
+                <version>1.12.0-SNAPSHOT</version>
                 <scope>test</scope>
                 <type>test-jar</type>
             </dependency>
             <dependency>
                 <groupId>org.apache.isis.viewer</groupId>
                 <artifactId>isis-viewer-wicket-ui</artifactId>
-                <version>1.11.1</version>
+                <version>1.12.0-SNAPSHOT</version>
             </dependency>
             <dependency>
                 <groupId>org.apache.isis.viewer</groupId>
                 <artifactId>isis-viewer-wicket-ui</artifactId>
-                <version>1.11.1</version>
+                <version>1.12.0-SNAPSHOT</version>
                 <scope>test</scope>
                 <type>test-jar</type>
             </dependency>
             <dependency>
                 <groupId>org.apache.isis.viewer</groupId>
                 <artifactId>isis-viewer-wicket-impl</artifactId>
-                <version>1.11.1</version>
+                <version>1.12.0-SNAPSHOT</version>
             </dependency>
             <dependency>
                 <groupId>org.apache.isis.viewer</groupId>
                 <artifactId>isis-viewer-wicket-impl</artifactId>
-                <version>1.11.1</version>
+                <version>1.12.0-SNAPSHOT</version>
                 <scope>test</scope>
                 <type>test-jar</type>
             </dependency>
@@ -1269,7 +1269,7 @@ ${license.additional-notes}
             <dependency>
                 <groupId>org.apache.isis.tool</groupId>
                 <artifactId>isis-maven-plugin</artifactId>
-                <version>1.11.1</version>
+                <version>1.12.0-SNAPSHOT</version>
             </dependency>
 
             <!-- JodaTime -->

http://git-wip-us.apache.org/repos/asf/isis/blob/277f4cb3/core/runtime/pom.xml
----------------------------------------------------------------------
diff --git a/core/runtime/pom.xml b/core/runtime/pom.xml
index c950886..cacb227 100644
--- a/core/runtime/pom.xml
+++ b/core/runtime/pom.xml
@@ -23,7 +23,7 @@
 	<parent>
 		<groupId>org.apache.isis.core</groupId>
 		<artifactId>isis</artifactId>
-        <version>1.11.1</version>
+        <version>1.12.0-SNAPSHOT</version>
 	</parent>
 
 	<artifactId>isis-core-runtime</artifactId>

http://git-wip-us.apache.org/repos/asf/isis/blob/277f4cb3/core/schema/pom.xml
----------------------------------------------------------------------
diff --git a/core/schema/pom.xml b/core/schema/pom.xml
index e864307..9bcc078 100644
--- a/core/schema/pom.xml
+++ b/core/schema/pom.xml
@@ -23,7 +23,7 @@
     <parent>
         <groupId>org.apache.isis.core</groupId>
         <artifactId>isis</artifactId>
-        <version>1.11.1</version>
+        <version>1.12.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>isis-core-schema</artifactId>

http://git-wip-us.apache.org/repos/asf/isis/blob/277f4cb3/core/security-shiro/pom.xml
----------------------------------------------------------------------
diff --git a/core/security-shiro/pom.xml b/core/security-shiro/pom.xml
index bab1ea0..206e8d5 100644
--- a/core/security-shiro/pom.xml
+++ b/core/security-shiro/pom.xml
@@ -23,12 +23,12 @@
 	<parent>
 		<groupId>org.apache.isis.core</groupId>
 		<artifactId>isis</artifactId>
-        <version>1.11.1</version>
+        <version>1.12.0-SNAPSHOT</version>
 	</parent>
 
 	<groupId>org.apache.isis.core</groupId>
 	<artifactId>isis-core-security-shiro</artifactId>
-    <version>1.11.1</version>
+    <version>1.12.0-SNAPSHOT</version>
 
 	<name>Isis Security Shiro</name>
 
@@ -65,7 +65,7 @@
 			<dependency>
 			    <groupId>org.apache.isis.core</groupId>
 			    <artifactId>isis-core-security-shiro</artifactId>
-				<version>1.11.1</version>
+				<version>1.12.0-SNAPSHOT</version>
 			</dependency>
     	</dependencies>
     </dependencyManagement>

http://git-wip-us.apache.org/repos/asf/isis/blob/277f4cb3/core/security/pom.xml
----------------------------------------------------------------------
diff --git a/core/security/pom.xml b/core/security/pom.xml
index 5951a70..5464258 100644
--- a/core/security/pom.xml
+++ b/core/security/pom.xml
@@ -23,7 +23,7 @@
 	<parent>
 		<groupId>org.apache.isis.core</groupId>
 		<artifactId>isis</artifactId>
-        <version>1.11.1</version>
+        <version>1.12.0-SNAPSHOT</version>
 	</parent>
 
 	<artifactId>isis-core-security</artifactId>

http://git-wip-us.apache.org/repos/asf/isis/blob/277f4cb3/core/specsupport/pom.xml
----------------------------------------------------------------------
diff --git a/core/specsupport/pom.xml b/core/specsupport/pom.xml
index f8492cf..a70b1a7 100644
--- a/core/specsupport/pom.xml
+++ b/core/specsupport/pom.xml
@@ -15,7 +15,7 @@
     <parent>
         <groupId>org.apache.isis.core</groupId>
         <artifactId>isis</artifactId>
-        <version>1.11.1</version>
+        <version>1.12.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>isis-core-specsupport</artifactId>

http://git-wip-us.apache.org/repos/asf/isis/blob/277f4cb3/core/unittestsupport/pom.xml
----------------------------------------------------------------------
diff --git a/core/unittestsupport/pom.xml b/core/unittestsupport/pom.xml
index 71ed875..c9dffa6 100644
--- a/core/unittestsupport/pom.xml
+++ b/core/unittestsupport/pom.xml
@@ -23,7 +23,7 @@
 	<parent>
 		<groupId>org.apache.isis.core</groupId>
 		<artifactId>isis</artifactId>
-        <version>1.11.1</version>
+        <version>1.12.0-SNAPSHOT</version>
 	</parent>
 
 	<artifactId>isis-core-unittestsupport</artifactId>

http://git-wip-us.apache.org/repos/asf/isis/blob/277f4cb3/core/viewer-restfulobjects-applib/pom.xml
----------------------------------------------------------------------
diff --git a/core/viewer-restfulobjects-applib/pom.xml b/core/viewer-restfulobjects-applib/pom.xml
index 7bdbdd8..e5d989d 100644
--- a/core/viewer-restfulobjects-applib/pom.xml
+++ b/core/viewer-restfulobjects-applib/pom.xml
@@ -23,7 +23,7 @@
     <parent>
         <groupId>org.apache.isis.core</groupId>
         <artifactId>isis</artifactId>
-        <version>1.11.1</version>
+        <version>1.12.0-SNAPSHOT</version>
     </parent>
 
 	<artifactId>isis-core-viewer-restfulobjects-applib</artifactId>

http://git-wip-us.apache.org/repos/asf/isis/blob/277f4cb3/core/viewer-restfulobjects-rendering/pom.xml
----------------------------------------------------------------------
diff --git a/core/viewer-restfulobjects-rendering/pom.xml b/core/viewer-restfulobjects-rendering/pom.xml
index 37f2cd2..5184877 100644
--- a/core/viewer-restfulobjects-rendering/pom.xml
+++ b/core/viewer-restfulobjects-rendering/pom.xml
@@ -23,7 +23,7 @@
     <parent>
         <groupId>org.apache.isis.core</groupId>
         <artifactId>isis</artifactId>
-        <version>1.11.1</version>
+        <version>1.12.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>isis-core-viewer-restfulobjects-rendering</artifactId>

http://git-wip-us.apache.org/repos/asf/isis/blob/277f4cb3/core/viewer-restfulobjects-server/pom.xml
----------------------------------------------------------------------
diff --git a/core/viewer-restfulobjects-server/pom.xml b/core/viewer-restfulobjects-server/pom.xml
index 9cdc9c6..a2bc140 100644
--- a/core/viewer-restfulobjects-server/pom.xml
+++ b/core/viewer-restfulobjects-server/pom.xml
@@ -23,7 +23,7 @@
     <parent>
         <groupId>org.apache.isis.core</groupId>
         <artifactId>isis</artifactId>
-        <version>1.11.1</version>
+        <version>1.12.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>isis-core-viewer-restfulobjects-server</artifactId>

http://git-wip-us.apache.org/repos/asf/isis/blob/277f4cb3/core/viewer-wicket-applib/pom.xml
----------------------------------------------------------------------
diff --git a/core/viewer-wicket-applib/pom.xml b/core/viewer-wicket-applib/pom.xml
index 1a2d707..54cb73f 100644
--- a/core/viewer-wicket-applib/pom.xml
+++ b/core/viewer-wicket-applib/pom.xml
@@ -24,7 +24,7 @@
 	<parent>
 		<groupId>org.apache.isis.core</groupId>
 		<artifactId>isis</artifactId>
-		<version>1.11.1</version>
+		<version>1.12.0-SNAPSHOT</version>
     </parent>
 
     <groupId>org.apache.isis.viewer</groupId>

http://git-wip-us.apache.org/repos/asf/isis/blob/277f4cb3/core/viewer-wicket-impl/pom.xml
----------------------------------------------------------------------
diff --git a/core/viewer-wicket-impl/pom.xml b/core/viewer-wicket-impl/pom.xml
index a811bf5..1190f01 100644
--- a/core/viewer-wicket-impl/pom.xml
+++ b/core/viewer-wicket-impl/pom.xml
@@ -24,7 +24,7 @@
 	<parent>
 		<groupId>org.apache.isis.core</groupId>
 		<artifactId>isis</artifactId>
-		<version>1.11.1</version>
+		<version>1.12.0-SNAPSHOT</version>
 	</parent>
 
 	<name>Isis Wicket Viewer Implementation</name>

http://git-wip-us.apache.org/repos/asf/isis/blob/277f4cb3/core/viewer-wicket-model/pom.xml
----------------------------------------------------------------------
diff --git a/core/viewer-wicket-model/pom.xml b/core/viewer-wicket-model/pom.xml
index e690404..e4ff14d 100644
--- a/core/viewer-wicket-model/pom.xml
+++ b/core/viewer-wicket-model/pom.xml
@@ -24,7 +24,7 @@
 	<parent>
 		<groupId>org.apache.isis.core</groupId>
 		<artifactId>isis</artifactId>
-		<version>1.11.1</version>
+		<version>1.12.0-SNAPSHOT</version>
 	</parent>
 
     <groupId>org.apache.isis.viewer</groupId>

http://git-wip-us.apache.org/repos/asf/isis/blob/277f4cb3/core/viewer-wicket-ui/pom.xml
----------------------------------------------------------------------
diff --git a/core/viewer-wicket-ui/pom.xml b/core/viewer-wicket-ui/pom.xml
index 141510c..5de324b 100644
--- a/core/viewer-wicket-ui/pom.xml
+++ b/core/viewer-wicket-ui/pom.xml
@@ -24,7 +24,7 @@
 	<parent>
 		<groupId>org.apache.isis.core</groupId>
 		<artifactId>isis</artifactId>
-		<version>1.11.1</version>
+		<version>1.12.0-SNAPSHOT</version>
 	</parent>
 
     <groupId>org.apache.isis.viewer</groupId>

http://git-wip-us.apache.org/repos/asf/isis/blob/277f4cb3/core/webserver/pom.xml
----------------------------------------------------------------------
diff --git a/core/webserver/pom.xml b/core/webserver/pom.xml
index 1cba08e..4f222fe 100644
--- a/core/webserver/pom.xml
+++ b/core/webserver/pom.xml
@@ -23,7 +23,7 @@
     <parent>
 		<groupId>org.apache.isis.core</groupId>
 		<artifactId>isis</artifactId>
-        <version>1.11.1</version>
+        <version>1.12.0-SNAPSHOT</version>
     </parent>
 
 	<artifactId>isis-core-webserver</artifactId>

http://git-wip-us.apache.org/repos/asf/isis/blob/277f4cb3/core/wrapper/pom.xml
----------------------------------------------------------------------
diff --git a/core/wrapper/pom.xml b/core/wrapper/pom.xml
index 656658c..e4486a5 100644
--- a/core/wrapper/pom.xml
+++ b/core/wrapper/pom.xml
@@ -23,7 +23,7 @@
     <parent>
         <groupId>org.apache.isis.core</groupId>
         <artifactId>isis</artifactId>
-        <version>1.11.1</version>
+        <version>1.12.0-SNAPSHOT</version>
 	</parent>
 
 	<artifactId>isis-core-wrapper</artifactId>


[10/17] isis git commit: ISIS-1296: updating the banner for the webconsole

Posted by da...@apache.org.
ISIS-1296: updating the banner for the webconsole


Project: http://git-wip-us.apache.org/repos/asf/isis/repo
Commit: http://git-wip-us.apache.org/repos/asf/isis/commit/5d3d14b4
Tree: http://git-wip-us.apache.org/repos/asf/isis/tree/5d3d14b4
Diff: http://git-wip-us.apache.org/repos/asf/isis/diff/5d3d14b4

Branch: refs/heads/master
Commit: 5d3d14b4f7ed3ad1619de3cd1935f10016f7fd28
Parents: 89bd3fd
Author: Dan Haywood <da...@haywood-associates.co.uk>
Authored: Sun Jan 10 15:24:14 2016 +0000
Committer: Dan Haywood <da...@haywood-associates.co.uk>
Committed: Sun Jan 10 15:24:14 2016 +0000

----------------------------------------------------------------------
 .../src/main/jettyconsole/isis-banner.pdn       | Bin 69658 -> 64162 bytes
 .../src/main/jettyconsole/isis-banner.png       | Bin 30776 -> 27310 bytes
 2 files changed, 0 insertions(+), 0 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/isis/blob/5d3d14b4/example/application/simpleapp/webapp/src/main/jettyconsole/isis-banner.pdn
----------------------------------------------------------------------
diff --git a/example/application/simpleapp/webapp/src/main/jettyconsole/isis-banner.pdn b/example/application/simpleapp/webapp/src/main/jettyconsole/isis-banner.pdn
index 37543c9..43a53e6 100644
Binary files a/example/application/simpleapp/webapp/src/main/jettyconsole/isis-banner.pdn and b/example/application/simpleapp/webapp/src/main/jettyconsole/isis-banner.pdn differ

http://git-wip-us.apache.org/repos/asf/isis/blob/5d3d14b4/example/application/simpleapp/webapp/src/main/jettyconsole/isis-banner.png
----------------------------------------------------------------------
diff --git a/example/application/simpleapp/webapp/src/main/jettyconsole/isis-banner.png b/example/application/simpleapp/webapp/src/main/jettyconsole/isis-banner.png
index cd9ecfe..cf10bef 100644
Binary files a/example/application/simpleapp/webapp/src/main/jettyconsole/isis-banner.png and b/example/application/simpleapp/webapp/src/main/jettyconsole/isis-banner.png differ


[12/17] isis git commit: [maven-release-plugin] prepare release simpleapp-archetype-1.11.1

Posted by da...@apache.org.
[maven-release-plugin] prepare release simpleapp-archetype-1.11.1


Project: http://git-wip-us.apache.org/repos/asf/isis/repo
Commit: http://git-wip-us.apache.org/repos/asf/isis/commit/54f7ec13
Tree: http://git-wip-us.apache.org/repos/asf/isis/tree/54f7ec13
Diff: http://git-wip-us.apache.org/repos/asf/isis/diff/54f7ec13

Branch: refs/heads/master
Commit: 54f7ec13c2a8588d974792a43f58df46d86572c2
Parents: b06d913
Author: Dan Haywood <da...@haywood-associates.co.uk>
Authored: Sun Jan 10 15:28:17 2016 +0000
Committer: Dan Haywood <da...@haywood-associates.co.uk>
Committed: Sun Jan 10 15:28:17 2016 +0000

----------------------------------------------------------------------
 example/archetype/simpleapp/pom.xml | 8 ++++++--
 1 file changed, 6 insertions(+), 2 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/isis/blob/54f7ec13/example/archetype/simpleapp/pom.xml
----------------------------------------------------------------------
diff --git a/example/archetype/simpleapp/pom.xml b/example/archetype/simpleapp/pom.xml
index 0a92bc9..4d52c33 100644
--- a/example/archetype/simpleapp/pom.xml
+++ b/example/archetype/simpleapp/pom.xml
@@ -17,11 +17,11 @@
   specific language governing permissions and limitations
   under the License.
 -->
-<project xmlns="http://maven.apache.org/POM/4.0.0" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance">
+<project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
     <modelVersion>4.0.0</modelVersion>
     <groupId>org.apache.isis.archetype</groupId>
     <artifactId>simpleapp-archetype</artifactId>
-    <version>1.11.0-SNAPSHOT</version>
+    <version>1.11.1</version>
     <packaging>maven-archetype</packaging>
     <name>simpleapp-archetype</name>
     <build>
@@ -47,4 +47,8 @@
         <version>1.11.1</version>
         <relativePath>../../../core/pom.xml</relativePath>
     </parent>
+
+  <scm>
+    <tag>simpleapp-archetype-1.11.1</tag>
+  </scm>
 </project>


[15/17] isis git commit: ISIS-1296: updating website and status for 1.11.1 release.

Posted by da...@apache.org.
ISIS-1296: updating website and status for 1.11.1 release.


Project: http://git-wip-us.apache.org/repos/asf/isis/repo
Commit: http://git-wip-us.apache.org/repos/asf/isis/commit/78bd18e2
Tree: http://git-wip-us.apache.org/repos/asf/isis/tree/78bd18e2
Diff: http://git-wip-us.apache.org/repos/asf/isis/diff/78bd18e2

Branch: refs/heads/master
Commit: 78bd18e207e83578f2d41d2b841c851214f9eb9e
Parents: 86a787b
Author: Dan Haywood <da...@haywood-associates.co.uk>
Authored: Sun Jan 17 14:57:01 2016 +0000
Committer: Dan Haywood <da...@haywood-associates.co.uk>
Committed: Sun Jan 17 14:57:01 2016 +0000

----------------------------------------------------------------------
 STATUS                                          |  3 +++
 .../main/asciidoc/_release-notes_1.11.1.adoc    | 20 ++++++++++++++++++++
 .../src/main/asciidoc/doap_isis.rdf             | 19 ++++++++++++++++++-
 .../src/main/asciidoc/downloads.adoc            | 10 +++++-----
 .../guides/_cgcom_cutting-a-release.adoc        |  4 ++--
 .../guides/_cgcom_post-release-successful.adoc  | 16 ++++++++++++----
 .../main/asciidoc/guides/_tg_pet-clinic.adoc    |  2 +-
 .../_tg_stop-scaffolding-start-coding.adoc      |  2 +-
 ...fun_getting-started_simpleapp-archetype.adoc |  2 +-
 .../asciidoc/guides/simpleapp-archetype.adoc    |  2 +-
 .../src/main/asciidoc/release-notes.adoc        | 15 ++++++++++++---
 11 files changed, 76 insertions(+), 19 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/isis/blob/78bd18e2/STATUS
----------------------------------------------------------------------
diff --git a/STATUS b/STATUS
index ae155ba..a5d5f1f 100644
--- a/STATUS
+++ b/STATUS
@@ -21,6 +21,9 @@ Description
 
 TLP releases:
 
+  * isis-1.11.1                                    : 17 Jan 2016
+  * simpleapp-archetype-1.11.1                     : 17 Jan 2016
+
   * isis-1.11.0                                    :  2 Jan 2016
   * simpleapp-archetype-1.11.0                     :  2 Jan 2016
 

http://git-wip-us.apache.org/repos/asf/isis/blob/78bd18e2/adocs/documentation/src/main/asciidoc/_release-notes_1.11.1.adoc
----------------------------------------------------------------------
diff --git a/adocs/documentation/src/main/asciidoc/_release-notes_1.11.1.adoc b/adocs/documentation/src/main/asciidoc/_release-notes_1.11.1.adoc
new file mode 100644
index 0000000..fae2ed9
--- /dev/null
+++ b/adocs/documentation/src/main/asciidoc/_release-notes_1.11.1.adoc
@@ -0,0 +1,20 @@
+[[r1.11.1]]
+= 1.11.1
+:notice: 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.
+:_basedir: ./
+:_imagesdir: images/
+:toc: right
+
+
+Apache Isis 1.11.1 is a bug fix release for Apache Isis 1.11.0, re-releasing using Java 7.
+
+Apache Isis is intended to be compatible with both Java 7 and Java 8.  However, it was found that v1.11.0 used a number
+of Java 8 APIs.  This release fixes this issue.
+
+
+
+== Bug
+
+* link:https://issues.apache.org/jira/browse/ISIS-1276[ISIS-1276] - Release activities for v1.11.1
+
+

http://git-wip-us.apache.org/repos/asf/isis/blob/78bd18e2/adocs/documentation/src/main/asciidoc/doap_isis.rdf
----------------------------------------------------------------------
diff --git a/adocs/documentation/src/main/asciidoc/doap_isis.rdf b/adocs/documentation/src/main/asciidoc/doap_isis.rdf
index 5834cf3..b9ca843 100644
--- a/adocs/documentation/src/main/asciidoc/doap_isis.rdf
+++ b/adocs/documentation/src/main/asciidoc/doap_isis.rdf
@@ -36,6 +36,23 @@
     <category rdf:resource="http://projects.apache.org/category/web-framework" />
 
     
+    <!-- 2016-01-17 releases -->
+    <release>
+      <Version>
+        <name>isis</name>
+        <created>2016-01-17</created>
+        <revision>1.11.1</revision>
+      </Version>
+    </release>
+    <release>
+      <Version>
+        <name>simpleapp-archetype</name>
+        <created>2016-01-17</created>
+        <revision>1.11.1</revision>
+      </Version>
+    </release>
+    
+
     <!-- 2016-01-02 releases -->
     <release>
       <Version>
@@ -51,7 +68,7 @@
         <revision>1.11.0</revision>
       </Version>
     </release>
-    
+
 
     <!-- 2015-11-10 releases -->
     <release>

http://git-wip-us.apache.org/repos/asf/isis/blob/78bd18e2/adocs/documentation/src/main/asciidoc/downloads.adoc
----------------------------------------------------------------------
diff --git a/adocs/documentation/src/main/asciidoc/downloads.adoc b/adocs/documentation/src/main/asciidoc/downloads.adoc
index a54662e..4a12657 100644
--- a/adocs/documentation/src/main/asciidoc/downloads.adoc
+++ b/adocs/documentation/src/main/asciidoc/downloads.adoc
@@ -25,12 +25,12 @@ If you want to build Apache Isis from formally released source tarballs, you can
 
 Core:
 
-* https://www.apache.org/dyn/closer.cgi/isis/isis-core/isis-1.11.0-source-release.zip[isis-1.11.0] (http://www.apache.org/dist/isis/isis-core/isis-1.11.0-source-release.zip.asc[asc], http://www.apache.org/dist/isis/isis-core/isis-1.11.0-source-release.zip.md5[md5])
+* https://www.apache.org/dyn/closer.cgi/isis/isis-core/isis-1.11.1-source-release.zip[isis-1.11.1] (http://www.apache.org/dist/isis/isis-core/isis-1.11.1-source-release.zip.asc[asc], http://www.apache.org/dist/isis/isis-core/isis-1.11.1-source-release.zip.md5[md5])
 
 
 Archetypes:
 
-* https://www.apache.org/dyn/closer.cgi/isis/archetype/simpleapp-archetype/simpleapp-archetype-1.11.0-source-release.zip[simpleapp-archetype-1.11.0] (http://www.apache.org/dist/isis/archetype/simpleapp-archetype/simpleapp-archetype-1.11.0-source-release.zip.asc[asc], http://www.apache.org/dist/isis/archetype/simpleapp-archetype/simpleapp-archetype-1.11.0-source-release.zip.md5[md5])
+* https://www.apache.org/dyn/closer.cgi/isis/archetype/simpleapp-archetype/simpleapp-archetype-1.11.1-source-release.zip[simpleapp-archetype-1.11.1] (http://www.apache.org/dist/isis/archetype/simpleapp-archetype/simpleapp-archetype-1.11.1-source-release.zip.asc[asc], http://www.apache.org/dist/isis/archetype/simpleapp-archetype/simpleapp-archetype-1.11.1-source-release.zip.md5[md5])
 
 
 
@@ -45,7 +45,7 @@ Then verify the signatures using a command such as:
 [source,bash]
 ----
 pgpk -a KEYS
-pgpv isis-1.11.0-source-release.zip.asc
+pgpv isis-1.11.1-source-release.zip.asc
 ----
 
 or
@@ -53,7 +53,7 @@ or
 [source,bash]
 ----
 pgp -ka KEYS
-pgp isis-1.11.0-source-release.zip.asc
+pgp isis-1.11.1-source-release.zip.asc
 ----
 
 
@@ -62,7 +62,7 @@ or
 [source,bash]
 ----
 gpg –import KEYS
-gpg –verify isis-1.11.0-source-release.zip.asc
+gpg –verify isis-1.11.1-source-release.zip.asc
 ----
 
 

http://git-wip-us.apache.org/repos/asf/isis/blob/78bd18e2/adocs/documentation/src/main/asciidoc/guides/_cgcom_cutting-a-release.adoc
----------------------------------------------------------------------
diff --git a/adocs/documentation/src/main/asciidoc/guides/_cgcom_cutting-a-release.adoc b/adocs/documentation/src/main/asciidoc/guides/_cgcom_cutting-a-release.adoc
index 0bdaa63..454af5e 100644
--- a/adocs/documentation/src/main/asciidoc/guides/_cgcom_cutting-a-release.adoc
+++ b/adocs/documentation/src/main/asciidoc/guides/_cgcom_cutting-a-release.adoc
@@ -124,7 +124,7 @@ cd core
 [[_cgcom_cutting-a-release_releasing-core_set-environment-variables]]
 === Set environment variables
 
-Set additional environment variables for the core "artefact":
+Set additional environment variables for the core "artifact":
 
 [source,bash]
 ----
@@ -378,7 +378,7 @@ cd ../example/application/simpleapp
 [[_cgcom_cutting-a-release_releasing-the-archetype_setup-environment-variables]]
 === Setup environment variables
 
-Set additional environment variables for the `simpleapp-archetype` artefact:
+Set additional environment variables for the `simpleapp-archetype` artifact:
 
 [source,bash]
 ----

http://git-wip-us.apache.org/repos/asf/isis/blob/78bd18e2/adocs/documentation/src/main/asciidoc/guides/_cgcom_post-release-successful.adoc
----------------------------------------------------------------------
diff --git a/adocs/documentation/src/main/asciidoc/guides/_cgcom_post-release-successful.adoc b/adocs/documentation/src/main/asciidoc/guides/_cgcom_post-release-successful.adoc
index ff2d41f..00d3681 100644
--- a/adocs/documentation/src/main/asciidoc/guides/_cgcom_post-release-successful.adoc
+++ b/adocs/documentation/src/main/asciidoc/guides/_cgcom_post-release-successful.adoc
@@ -155,22 +155,30 @@ svn delete $fullname-$old_ver-$zip
 popd
 ----
 
-For example:
-
 [source,bash]
 ----
 sh upd.sh 1.11.0 1.12.0
 ----
 
-The script downloads the artefacts from the Nexus release repository, adds the artefacts to subsversion and deletes the previous version.
+The script downloads the artifacts from the Nexus release repository, adds the artifacts to subversion and deletes the previous version.
+
+
+
+Double check that the files are correct; there is sometimes a small delay in the files becoming available in the release repository.  It should be sufficient to check just the `md5` or `.asc` files that these look valid (aren't HTML 404 error pages):
+
+[source,bash]
+----
+vi `find . -name *.md5`
+----
 
-At the end, commit the changes:
+Assuming all is good, commit the changes:
 
 [source]
 ----
 svn commit -m "publishing isis source releases to dist.apache.org"
 ----
 
+If the files are invalid, then revert using `svn revert . --recursive` and try again in a little while.
 
 
 

http://git-wip-us.apache.org/repos/asf/isis/blob/78bd18e2/adocs/documentation/src/main/asciidoc/guides/_tg_pet-clinic.adoc
----------------------------------------------------------------------
diff --git a/adocs/documentation/src/main/asciidoc/guides/_tg_pet-clinic.adoc b/adocs/documentation/src/main/asciidoc/guides/_tg_pet-clinic.adoc
index 39f836d..03a6926 100644
--- a/adocs/documentation/src/main/asciidoc/guides/_tg_pet-clinic.adoc
+++ b/adocs/documentation/src/main/asciidoc/guides/_tg_pet-clinic.adoc
@@ -62,7 +62,7 @@ Run the simpleapp archetype to build an empty Isis application:
 mvn archetype:generate  \
     -D archetypeGroupId=org.apache.isis.archetype \
     -D archetypeArtifactId=simpleapp-archetype \
-    -D archetypeVersion=1.11.0 \
+    -D archetypeVersion=1.11.1 \
     -D groupId=com.mycompany \
     -D artifactId=petclinic \
     -D version=1.0-SNAPSHOT \

http://git-wip-us.apache.org/repos/asf/isis/blob/78bd18e2/adocs/documentation/src/main/asciidoc/guides/_tg_stop-scaffolding-start-coding.adoc
----------------------------------------------------------------------
diff --git a/adocs/documentation/src/main/asciidoc/guides/_tg_stop-scaffolding-start-coding.adoc b/adocs/documentation/src/main/asciidoc/guides/_tg_stop-scaffolding-start-coding.adoc
index fb9de46..a541a06 100644
--- a/adocs/documentation/src/main/asciidoc/guides/_tg_stop-scaffolding-start-coding.adoc
+++ b/adocs/documentation/src/main/asciidoc/guides/_tg_stop-scaffolding-start-coding.adoc
@@ -30,7 +30,7 @@ Run the simpleapp archetype to build an empty Isis application:
 mvn archetype:generate  \
     -D archetypeGroupId=org.apache.isis.archetype \
     -D archetypeArtifactId=simpleapp-archetype \
-    -D archetypeVersion=1.11.0 \
+    -D archetypeVersion=1.11.1 \
     -D groupId=com.mycompany \
     -D artifactId=myapp \
     -D version=1.0-SNAPSHOT \

http://git-wip-us.apache.org/repos/asf/isis/blob/78bd18e2/adocs/documentation/src/main/asciidoc/guides/_ugfun_getting-started_simpleapp-archetype.adoc
----------------------------------------------------------------------
diff --git a/adocs/documentation/src/main/asciidoc/guides/_ugfun_getting-started_simpleapp-archetype.adoc b/adocs/documentation/src/main/asciidoc/guides/_ugfun_getting-started_simpleapp-archetype.adoc
index b91137b..e6d1ce4 100644
--- a/adocs/documentation/src/main/asciidoc/guides/_ugfun_getting-started_simpleapp-archetype.adoc
+++ b/adocs/documentation/src/main/asciidoc/guides/_ugfun_getting-started_simpleapp-archetype.adoc
@@ -22,7 +22,7 @@ To build the app from the latest stable release, then run the following command:
 mvn archetype:generate  \
     -D archetypeGroupId=org.apache.isis.archetype \
     -D archetypeArtifactId=simpleapp-archetype \
-    -D archetypeVersion=1.11.0 \
+    -D archetypeVersion=1.11.1 \
     -D groupId=com.mycompany \
     -D artifactId=myapp \
     -D version=1.0-SNAPSHOT \

http://git-wip-us.apache.org/repos/asf/isis/blob/78bd18e2/adocs/documentation/src/main/asciidoc/guides/simpleapp-archetype.adoc
----------------------------------------------------------------------
diff --git a/adocs/documentation/src/main/asciidoc/guides/simpleapp-archetype.adoc b/adocs/documentation/src/main/asciidoc/guides/simpleapp-archetype.adoc
index 315668c..1d66d57 100644
--- a/adocs/documentation/src/main/asciidoc/guides/simpleapp-archetype.adoc
+++ b/adocs/documentation/src/main/asciidoc/guides/simpleapp-archetype.adoc
@@ -25,7 +25,7 @@ Then run the following command:
 mvn archetype:generate  \
     -D archetypeGroupId=org.apache.isis.archetype \
     -D archetypeArtifactId=simpleapp-archetype \
-    -D archetypeVersion=1.11.0 \
+    -D archetypeVersion=1.11.1 \
     -D groupId=com.mycompany \
     -D artifactId=myapp \
     -D version=1.0-SNAPSHOT \

http://git-wip-us.apache.org/repos/asf/isis/blob/78bd18e2/adocs/documentation/src/main/asciidoc/release-notes.adoc
----------------------------------------------------------------------
diff --git a/adocs/documentation/src/main/asciidoc/release-notes.adoc b/adocs/documentation/src/main/asciidoc/release-notes.adoc
index 5a543f1..a279f2b 100644
--- a/adocs/documentation/src/main/asciidoc/release-notes.adoc
+++ b/adocs/documentation/src/main/asciidoc/release-notes.adoc
@@ -21,10 +21,18 @@ This table summarises all releases of Apache Isis to date.
 | Improves
 | Bugs
 
+| xref:r1.11.1[1.11.1]
+| 17-jan-2016
+| * https://issues.apache.org/jira/secure/ReleaseNote.jspa?projectId=12311171&version=12334640[1.11.1]
+| Re-release under Java 1.7 (using toolchains plugin).
+| 0
+| 0
+| 1
+
 | xref:r1.11.0[1.11.0]
 | 02-jan-2016
 | * https://issues.apache.org/jira/secure/ReleaseNote.jspa?projectId=12311171&version=12333974[1.11.0]
-| Combined release notes for core and simpleapp-archetype.
+| More flexible REST API, view models using JAXB.
 | 9
 | 19
 | 12
@@ -32,7 +40,7 @@ This table summarises all releases of Apache Isis to date.
 | xref:r1.10.0[1.10.0]
 | 10-nov-2015
 | * https://issues.apache.org/jira/secure/ReleaseNote.jspa?projectId=12311171&version=12333354[1.10.0]
-| Combined release notes for core and simpleapp-archetype.
+| New domain services, multi-tenancy support and mixins.
 | 7
 | 18
 | 12
@@ -40,7 +48,7 @@ This table summarises all releases of Apache Isis to date.
 | xref:r1.9.0[1.9.0]
 | 1-sep-2015
 | * https://issues.apache.org/jira/secure/ReleaseNote.jspa?projectId=12311171&version=12332806[1.9.0]
-| Combined release notes for core and simpleapp-archetype.
+| AppManifest, Restful Objects representations and other "under-the-cover" improvements.
 | 18
 | 50
 | 25
@@ -210,6 +218,7 @@ This table summarises all releases of Apache Isis to date.
 
 
 
+include::_release-notes_1.11.1.adoc[leveloffset=+1]
 include::_release-notes_1.11.0.adoc[leveloffset=+1]
 include::_release-notes_1.10.0.adoc[leveloffset=+1]
 include::_release-notes_1.9.0.adoc[leveloffset=+1]